You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by ac...@apache.org on 2021/02/24 10:48:29 UTC

[camel-kafka-connector] branch camel-master updated (865903e -> 8246cb6)

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

acosentino pushed a change to branch camel-master
in repository https://gitbox.apache.org/repos/asf/camel-kafka-connector.git.


    from 865903e  Regen all configs with secret/sensitive values (ref: issue #1050)
     new ae33d52  Add SMT for GenericFile of Camel-file-kafka-connector
     new 8e18da3  Fixed CS
     new 8246cb6  Add SMT for GenericFile of Camel-file-kafka-connector - Regen docs

The 3 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:
 .../resources/connectors/camel-file-sink.json      |  5 +++-
 .../resources/connectors/camel-file-source.json    |  5 +++-
 .../generated/resources/camel-aws2-sqs-sink.json   | 14 +++++++++
 .../docs/camel-aws2-sqs-kafka-sink-connector.adoc  |  4 ++-
 .../aws2sqs/CamelAws2sqsSinkConnectorConfig.java   |  8 +++++
 connectors/camel-file-kafka-connector/pom.xml      |  5 ++++
 .../src/generated/resources/camel-file-sink.json   |  5 +++-
 .../src/generated/resources/camel-file-source.json |  5 +++-
 .../main/docs/camel-file-kafka-sink-connector.adoc |  9 +++++-
 .../docs/camel-file-kafka-source-connector.adoc    |  9 +++++-
 .../file/transformers/FileTransforms.java}         | 34 +++++++++++-----------
 .../camel-file-kafka-sink-connector.adoc           |  9 +++++-
 .../camel-file-kafka-source-connector.adoc         |  9 +++++-
 13 files changed, 95 insertions(+), 26 deletions(-)
 copy connectors/{camel-ssh-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/ssh/transformers/SshTransforms.java => camel-file-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/file/transformers/FileTransforms.java} (61%)


[camel-kafka-connector] 02/03: Fixed CS

Posted by ac...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

acosentino pushed a commit to branch camel-master
in repository https://gitbox.apache.org/repos/asf/camel-kafka-connector.git

commit 8e18da39ed714b5b701a56edf7f4d446f6b3e60e
Author: Andrea Cosentino <an...@gmail.com>
AuthorDate: Wed Feb 24 10:47:42 2021 +0100

    Fixed CS
---
 .../file/transformers/FileTransforms.java          | 27 +++++++++-------------
 1 file changed, 11 insertions(+), 16 deletions(-)

diff --git a/connectors/camel-file-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/file/transformers/FileTransforms.java b/connectors/camel-file-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/file/transformers/FileTransforms.java
index 173ed11..7c82441 100644
--- a/connectors/camel-file-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/file/transformers/FileTransforms.java
+++ b/connectors/camel-file-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/file/transformers/FileTransforms.java
@@ -17,8 +17,6 @@
 package org.apache.camel.kafkaconnector.file.transformers;
 
 import java.io.File;
-import java.io.FileNotFoundException;
-import java.io.FileReader;
 import java.io.IOException;
 import java.nio.charset.StandardCharsets;
 import java.util.Map;
@@ -32,11 +30,9 @@ import org.apache.kafka.connect.transforms.Transformation;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class FileTransforms <R extends ConnectRecord<R>> implements Transformation<R> {
+public class FileTransforms<R extends ConnectRecord<R>> implements Transformation<R> {
     public static final String FIELD_KEY_CONFIG = "key";
-    public static final ConfigDef CONFIG_DEF = new ConfigDef()
-            .define(FIELD_KEY_CONFIG, ConfigDef.Type.STRING, null, ConfigDef.Importance.MEDIUM,
-                    "Transforms File to String");
+    public static final ConfigDef CONFIG_DEF = new ConfigDef().define(FIELD_KEY_CONFIG, ConfigDef.Type.STRING, null, ConfigDef.Importance.MEDIUM, "Transforms File to String");
 
     private static final Logger LOG = LoggerFactory.getLogger(FileTransforms.class);
 
@@ -46,17 +42,16 @@ public class FileTransforms <R extends ConnectRecord<R>> implements Transformati
 
         if (r.value() instanceof GenericFile) {
             LOG.debug("Converting record from RemoteFile to text");
-            GenericFile<File> message = (GenericFile<File>) r.value();
+            GenericFile<File> message = (GenericFile<File>)r.value();
             String c = null;
-			try {
-				c = FileUtils.readFileToString(message.getFile(), StandardCharsets.UTF_8);
-			} catch (IOException e) {
-				// TODO Auto-generated catch block
-				e.printStackTrace();
-			}
-            
-            return r.newRecord(r.topic(), r.kafkaPartition(), null, r.key(),
-                    SchemaHelper.buildSchemaBuilderForType(c), c, r.timestamp());
+            try {
+                c = FileUtils.readFileToString(message.getFile(), StandardCharsets.UTF_8);
+            } catch (IOException e) {
+                // TODO Auto-generated catch block
+                e.printStackTrace();
+            }
+
+            return r.newRecord(r.topic(), r.kafkaPartition(), null, r.key(), SchemaHelper.buildSchemaBuilderForType(c), c, r.timestamp());
 
         } else {
             LOG.debug("Unexpected message type: {}", r.value().getClass());


[camel-kafka-connector] 01/03: Add SMT for GenericFile of Camel-file-kafka-connector

Posted by ac...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

acosentino pushed a commit to branch camel-master
in repository https://gitbox.apache.org/repos/asf/camel-kafka-connector.git

commit ae33d521cb63692c2e0c0e7d63fd68fa59fa7e42
Author: Andrea Cosentino <an...@gmail.com>
AuthorDate: Wed Feb 24 10:24:02 2021 +0100

    Add SMT for GenericFile of Camel-file-kafka-connector
---
 connectors/camel-file-kafka-connector/pom.xml      |  5 ++
 .../file/transformers/FileTransforms.java          | 82 ++++++++++++++++++++++
 2 files changed, 87 insertions(+)

diff --git a/connectors/camel-file-kafka-connector/pom.xml b/connectors/camel-file-kafka-connector/pom.xml
index 07fb01e..cfd563a 100644
--- a/connectors/camel-file-kafka-connector/pom.xml
+++ b/connectors/camel-file-kafka-connector/pom.xml
@@ -44,6 +44,11 @@
       <groupId>org.apache.camel</groupId>
       <artifactId>camel-file</artifactId>
     </dependency>
+    <dependency>
+	  <groupId>commons-io</groupId>
+	  <artifactId>commons-io</artifactId>
+      <version>${commons-io-version}</version>
+	</dependency>
     <!--START OF GENERATED CODE-->
     <dependency>
       <groupId>org.apache.camel.kafkaconnector</groupId>
diff --git a/connectors/camel-file-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/file/transformers/FileTransforms.java b/connectors/camel-file-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/file/transformers/FileTransforms.java
new file mode 100644
index 0000000..173ed11
--- /dev/null
+++ b/connectors/camel-file-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/file/transformers/FileTransforms.java
@@ -0,0 +1,82 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.kafkaconnector.file.transformers;
+
+import java.io.File;
+import java.io.FileNotFoundException;
+import java.io.FileReader;
+import java.io.IOException;
+import java.nio.charset.StandardCharsets;
+import java.util.Map;
+
+import org.apache.camel.component.file.GenericFile;
+import org.apache.camel.kafkaconnector.utils.SchemaHelper;
+import org.apache.commons.io.FileUtils;
+import org.apache.kafka.common.config.ConfigDef;
+import org.apache.kafka.connect.connector.ConnectRecord;
+import org.apache.kafka.connect.transforms.Transformation;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+public class FileTransforms <R extends ConnectRecord<R>> implements Transformation<R> {
+    public static final String FIELD_KEY_CONFIG = "key";
+    public static final ConfigDef CONFIG_DEF = new ConfigDef()
+            .define(FIELD_KEY_CONFIG, ConfigDef.Type.STRING, null, ConfigDef.Importance.MEDIUM,
+                    "Transforms File to String");
+
+    private static final Logger LOG = LoggerFactory.getLogger(FileTransforms.class);
+
+    @Override
+    public R apply(R r) {
+        Object value = r.value();
+
+        if (r.value() instanceof GenericFile) {
+            LOG.debug("Converting record from RemoteFile to text");
+            GenericFile<File> message = (GenericFile<File>) r.value();
+            String c = null;
+			try {
+				c = FileUtils.readFileToString(message.getFile(), StandardCharsets.UTF_8);
+			} catch (IOException e) {
+				// TODO Auto-generated catch block
+				e.printStackTrace();
+			}
+            
+            return r.newRecord(r.topic(), r.kafkaPartition(), null, r.key(),
+                    SchemaHelper.buildSchemaBuilderForType(c), c, r.timestamp());
+
+        } else {
+            LOG.debug("Unexpected message type: {}", r.value().getClass());
+
+            return r;
+        }
+    }
+
+    @Override
+    public ConfigDef config() {
+        return CONFIG_DEF;
+    }
+
+    @Override
+    public void close() {
+
+    }
+
+    @Override
+    public void configure(Map<String, ?> map) {
+
+    }
+}


[camel-kafka-connector] 03/03: Add SMT for GenericFile of Camel-file-kafka-connector - Regen docs

Posted by ac...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

acosentino pushed a commit to branch camel-master
in repository https://gitbox.apache.org/repos/asf/camel-kafka-connector.git

commit 8246cb6bf4575c7e9549e5f8c256aa852e98e34c
Author: Andrea Cosentino <an...@gmail.com>
AuthorDate: Wed Feb 24 10:59:05 2021 +0100

    Add SMT for GenericFile of Camel-file-kafka-connector - Regen docs
---
 .../generated/resources/connectors/camel-file-sink.json    |  5 ++++-
 .../generated/resources/connectors/camel-file-source.json  |  5 ++++-
 .../src/generated/resources/camel-aws2-sqs-sink.json       | 14 ++++++++++++++
 .../src/main/docs/camel-aws2-sqs-kafka-sink-connector.adoc |  4 +++-
 .../aws2sqs/CamelAws2sqsSinkConnectorConfig.java           |  8 ++++++++
 connectors/camel-file-kafka-connector/pom.xml              |  6 +++---
 .../src/generated/resources/camel-file-sink.json           |  5 ++++-
 .../src/generated/resources/camel-file-source.json         |  5 ++++-
 .../src/main/docs/camel-file-kafka-sink-connector.adoc     |  9 ++++++++-
 .../src/main/docs/camel-file-kafka-source-connector.adoc   |  9 ++++++++-
 .../pages/connectors/camel-file-kafka-sink-connector.adoc  |  9 ++++++++-
 .../connectors/camel-file-kafka-source-connector.adoc      |  9 ++++++++-
 12 files changed, 76 insertions(+), 12 deletions(-)

diff --git a/camel-kafka-connector-catalog/src/generated/resources/connectors/camel-file-sink.json b/camel-kafka-connector-catalog/src/generated/resources/connectors/camel-file-sink.json
index 77bd8b6..6bd482a 100644
--- a/camel-kafka-connector-catalog/src/generated/resources/connectors/camel-file-sink.json
+++ b/camel-kafka-connector-catalog/src/generated/resources/connectors/camel-file-sink.json
@@ -188,5 +188,8 @@
 			"priority": "MEDIUM",
 			"required": "false"
 		}
-	}
+	},
+	"transforms": [
+		"org.apache.camel.kafkaconnector.file.transformers.FileTransforms"
+	]
 }
\ No newline at end of file
diff --git a/camel-kafka-connector-catalog/src/generated/resources/connectors/camel-file-source.json b/camel-kafka-connector-catalog/src/generated/resources/connectors/camel-file-source.json
index 9e98226..1b7125f 100644
--- a/camel-kafka-connector-catalog/src/generated/resources/connectors/camel-file-source.json
+++ b/camel-kafka-connector-catalog/src/generated/resources/connectors/camel-file-source.json
@@ -577,5 +577,8 @@
 			"priority": "MEDIUM",
 			"required": "false"
 		}
-	}
+	},
+	"transforms": [
+		"org.apache.camel.kafkaconnector.file.transformers.FileTransforms"
+	]
 }
\ No newline at end of file
diff --git a/connectors/camel-aws2-sqs-kafka-connector/src/generated/resources/camel-aws2-sqs-sink.json b/connectors/camel-aws2-sqs-kafka-connector/src/generated/resources/camel-aws2-sqs-sink.json
index 8d185cb..be8e767 100644
--- a/connectors/camel-aws2-sqs-kafka-connector/src/generated/resources/camel-aws2-sqs-sink.json
+++ b/connectors/camel-aws2-sqs-kafka-connector/src/generated/resources/camel-aws2-sqs-sink.json
@@ -85,6 +85,13 @@
 			"priority": "MEDIUM",
 			"required": "false"
 		},
+		"camel.sink.endpoint.batchSeparator": {
+			"name": "camel.sink.endpoint.batchSeparator",
+			"description": "Set the separator when passing a String to send batch message operation",
+			"defaultValue": "\",\"",
+			"priority": "MEDIUM",
+			"required": "false"
+		},
 		"camel.sink.endpoint.delaySeconds": {
 			"name": "camel.sink.endpoint.delaySeconds",
 			"description": "Delay sending messages for a number of seconds.",
@@ -269,6 +276,13 @@
 			"priority": "MEDIUM",
 			"required": "false"
 		},
+		"camel.component.aws2-sqs.batchSeparator": {
+			"name": "camel.component.aws2-sqs.batchSeparator",
+			"description": "Set the separator when passing a String to send batch message operation",
+			"defaultValue": "\",\"",
+			"priority": "MEDIUM",
+			"required": "false"
+		},
 		"camel.component.aws2-sqs.delaySeconds": {
 			"name": "camel.component.aws2-sqs.delaySeconds",
 			"description": "Delay sending messages for a number of seconds.",
diff --git a/connectors/camel-aws2-sqs-kafka-connector/src/main/docs/camel-aws2-sqs-kafka-sink-connector.adoc b/connectors/camel-aws2-sqs-kafka-connector/src/main/docs/camel-aws2-sqs-kafka-sink-connector.adoc
index 1ed8652..d218f26 100644
--- a/connectors/camel-aws2-sqs-kafka-connector/src/main/docs/camel-aws2-sqs-kafka-sink-connector.adoc
+++ b/connectors/camel-aws2-sqs-kafka-connector/src/main/docs/camel-aws2-sqs-kafka-sink-connector.adoc
@@ -24,7 +24,7 @@ connector.class=org.apache.camel.kafkaconnector.aws2sqs.CamelAws2sqsSinkConnecto
 ----
 
 
-The camel-aws2-sqs sink connector supports 54 options, which are listed below.
+The camel-aws2-sqs sink connector supports 56 options, which are listed below.
 
 
 
@@ -42,6 +42,7 @@ The camel-aws2-sqs sink connector supports 54 options, which are listed below.
 | *camel.sink.endpoint.region* | The region in which SQS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | false | MEDIUM
 | *camel.sink.endpoint.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | false | MEDIUM
 | *camel.sink.endpoint.useDefaultCredentialsProvider* | Set whether the SQS client should expect to load credentials on an AWS infra instance or to expect static credentials to be passed in. | false | false | MEDIUM
+| *camel.sink.endpoint.batchSeparator* | Set the separator when passing a String to send batch message operation | "," | false | MEDIUM
 | *camel.sink.endpoint.delaySeconds* | Delay sending messages for a number of seconds. | null | false | MEDIUM
 | *camel.sink.endpoint.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then cre [...]
 | *camel.sink.endpoint.messageDeduplicationIdStrategy* | Only for FIFO queues. Strategy for setting the messageDeduplicationId on the message. Can be one of the following options: useExchangeId, useContentBasedDeduplication. For the useContentBasedDeduplication option, no messageDeduplicationId will be set on the message. One of: [useExchangeId] [useContentBasedDeduplication] | "useExchangeId" | false | MEDIUM
@@ -68,6 +69,7 @@ The camel-aws2-sqs sink connector supports 54 options, which are listed below.
 | *camel.component.aws2-sqs.region* | The region in which SQS client needs to work. When using this parameter, the configuration will expect the lowercase name of the region (for example ap-east-1) You'll need to use the name Region.EU_WEST_1.id() | null | false | MEDIUM
 | *camel.component.aws2-sqs.trustAllCertificates* | If we want to trust all certificates in case of overriding the endpoint | false | false | MEDIUM
 | *camel.component.aws2-sqs.useDefaultCredentials Provider* | Set whether the SQS client should expect to load credentials on an AWS infra instance or to expect static credentials to be passed in. | false | false | MEDIUM
+| *camel.component.aws2-sqs.batchSeparator* | Set the separator when passing a String to send batch message operation | "," | false | MEDIUM
 | *camel.component.aws2-sqs.delaySeconds* | Delay sending messages for a number of seconds. | null | false | MEDIUM
 | *camel.component.aws2-sqs.lazyStartProducer* | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed the [...]
 | *camel.component.aws2-sqs.messageDeduplicationId Strategy* | Only for FIFO queues. Strategy for setting the messageDeduplicationId on the message. Can be one of the following options: useExchangeId, useContentBasedDeduplication. For the useContentBasedDeduplication option, no messageDeduplicationId will be set on the message. One of: [useExchangeId] [useContentBasedDeduplication] | "useExchangeId" | false | MEDIUM
diff --git a/connectors/camel-aws2-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sqs/CamelAws2sqsSinkConnectorConfig.java b/connectors/camel-aws2-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sqs/CamelAws2sqsSinkConnectorConfig.java
index 7cf20a2..a1f50a0 100644
--- a/connectors/camel-aws2-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sqs/CamelAws2sqsSinkConnectorConfig.java
+++ b/connectors/camel-aws2-sqs-kafka-connector/src/main/java/org/apache/camel/kafkaconnector/aws2sqs/CamelAws2sqsSinkConnectorConfig.java
@@ -57,6 +57,9 @@ public class CamelAws2sqsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_USE_DEFAULT_CREDENTIALS_PROVIDER_CONF = "camel.sink.endpoint.useDefaultCredentialsProvider";
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_USE_DEFAULT_CREDENTIALS_PROVIDER_DOC = "Set whether the SQS client should expect to load credentials on an AWS infra instance or to expect static credentials to be passed in.";
     public static final Boolean CAMEL_SINK_AWS2SQS_ENDPOINT_USE_DEFAULT_CREDENTIALS_PROVIDER_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_BATCH_SEPARATOR_CONF = "camel.sink.endpoint.batchSeparator";
+    public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_BATCH_SEPARATOR_DOC = "Set the separator when passing a String to send batch message operation";
+    public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_BATCH_SEPARATOR_DEFAULT = ",";
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_DELAY_SECONDS_CONF = "camel.sink.endpoint.delaySeconds";
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_DELAY_SECONDS_DOC = "Delay sending messages for a number of seconds.";
     public static final String CAMEL_SINK_AWS2SQS_ENDPOINT_DELAY_SECONDS_DEFAULT = null;
@@ -135,6 +138,9 @@ public class CamelAws2sqsSinkConnectorConfig extends CamelSinkConnectorConfig {
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_USE_DEFAULT_CREDENTIALS_PROVIDER_CONF = "camel.component.aws2-sqs.useDefaultCredentialsProvider";
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_USE_DEFAULT_CREDENTIALS_PROVIDER_DOC = "Set whether the SQS client should expect to load credentials on an AWS infra instance or to expect static credentials to be passed in.";
     public static final Boolean CAMEL_SINK_AWS2SQS_COMPONENT_USE_DEFAULT_CREDENTIALS_PROVIDER_DEFAULT = false;
+    public static final String CAMEL_SINK_AWS2SQS_COMPONENT_BATCH_SEPARATOR_CONF = "camel.component.aws2-sqs.batchSeparator";
+    public static final String CAMEL_SINK_AWS2SQS_COMPONENT_BATCH_SEPARATOR_DOC = "Set the separator when passing a String to send batch message operation";
+    public static final String CAMEL_SINK_AWS2SQS_COMPONENT_BATCH_SEPARATOR_DEFAULT = ",";
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_DELAY_SECONDS_CONF = "camel.component.aws2-sqs.delaySeconds";
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_DELAY_SECONDS_DOC = "Delay sending messages for a number of seconds.";
     public static final String CAMEL_SINK_AWS2SQS_COMPONENT_DELAY_SECONDS_DEFAULT = null;
@@ -210,6 +216,7 @@ public class CamelAws2sqsSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_ENDPOINT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_REGION_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SQS_ENDPOINT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_USE_DEFAULT_CREDENTIALS_PROVIDER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SQS_ENDPOINT_USE_DEFAULT_CREDENTIALS_PROVIDER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_USE_DEFAULT_CREDENTIALS_PROVIDER_DOC);
+        conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_BATCH_SEPARATOR_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_ENDPOINT_BATCH_SEPARATOR_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_BATCH_SEPARATOR_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_DELAY_SECONDS_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_ENDPOINT_DELAY_SECONDS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_DELAY_SECONDS_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SQS_ENDPOINT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_ENDPOINT_MESSAGE_DEDUPLICATION_ID_STRATEGY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_ENDPOINT_MESSAGE_DEDUPLICATION_ID_STRATEGY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_ENDPOINT_MESSAGE_DEDUPLICATION_ID_STRATEGY_DOC);
@@ -236,6 +243,7 @@ public class CamelAws2sqsSinkConnectorConfig extends CamelSinkConnectorConfig {
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_REGION_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_COMPONENT_REGION_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_REGION_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_TRUST_ALL_CERTIFICATES_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SQS_COMPONENT_TRUST_ALL_CERTIFICATES_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_TRUST_ALL_CERTIFICATES_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_USE_DEFAULT_CREDENTIALS_PROVIDER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SQS_COMPONENT_USE_DEFAULT_CREDENTIALS_PROVIDER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_USE_DEFAULT_CREDENTIALS_PROVIDER_DOC);
+        conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_BATCH_SEPARATOR_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_COMPONENT_BATCH_SEPARATOR_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_BATCH_SEPARATOR_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_DELAY_SECONDS_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_COMPONENT_DELAY_SECONDS_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_DELAY_SECONDS_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_LAZY_START_PRODUCER_CONF, ConfigDef.Type.BOOLEAN, CAMEL_SINK_AWS2SQS_COMPONENT_LAZY_START_PRODUCER_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_LAZY_START_PRODUCER_DOC);
         conf.define(CAMEL_SINK_AWS2SQS_COMPONENT_MESSAGE_DEDUPLICATION_ID_STRATEGY_CONF, ConfigDef.Type.STRING, CAMEL_SINK_AWS2SQS_COMPONENT_MESSAGE_DEDUPLICATION_ID_STRATEGY_DEFAULT, ConfigDef.Importance.MEDIUM, CAMEL_SINK_AWS2SQS_COMPONENT_MESSAGE_DEDUPLICATION_ID_STRATEGY_DOC);
diff --git a/connectors/camel-file-kafka-connector/pom.xml b/connectors/camel-file-kafka-connector/pom.xml
index cfd563a..28897cc 100644
--- a/connectors/camel-file-kafka-connector/pom.xml
+++ b/connectors/camel-file-kafka-connector/pom.xml
@@ -45,10 +45,10 @@
       <artifactId>camel-file</artifactId>
     </dependency>
     <dependency>
-	  <groupId>commons-io</groupId>
-	  <artifactId>commons-io</artifactId>
+      <groupId>commons-io</groupId>
+      <artifactId>commons-io</artifactId>
       <version>${commons-io-version}</version>
-	</dependency>
+    </dependency>
     <!--START OF GENERATED CODE-->
     <dependency>
       <groupId>org.apache.camel.kafkaconnector</groupId>
diff --git a/connectors/camel-file-kafka-connector/src/generated/resources/camel-file-sink.json b/connectors/camel-file-kafka-connector/src/generated/resources/camel-file-sink.json
index 0454f02..41e337f 100644
--- a/connectors/camel-file-kafka-connector/src/generated/resources/camel-file-sink.json
+++ b/connectors/camel-file-kafka-connector/src/generated/resources/camel-file-sink.json
@@ -188,5 +188,8 @@
 			"priority": "MEDIUM",
 			"required": "false"
 		}
-	}
+	},
+	"transforms": [
+		"org.apache.camel.kafkaconnector.file.transformers.FileTransforms"
+	]
 }
\ No newline at end of file
diff --git a/connectors/camel-file-kafka-connector/src/generated/resources/camel-file-source.json b/connectors/camel-file-kafka-connector/src/generated/resources/camel-file-source.json
index 569ec4c..5fd28ac 100644
--- a/connectors/camel-file-kafka-connector/src/generated/resources/camel-file-source.json
+++ b/connectors/camel-file-kafka-connector/src/generated/resources/camel-file-source.json
@@ -577,5 +577,8 @@
 			"priority": "MEDIUM",
 			"required": "false"
 		}
-	}
+	},
+	"transforms": [
+		"org.apache.camel.kafkaconnector.file.transformers.FileTransforms"
+	]
 }
\ No newline at end of file
diff --git a/connectors/camel-file-kafka-connector/src/main/docs/camel-file-kafka-sink-connector.adoc b/connectors/camel-file-kafka-connector/src/main/docs/camel-file-kafka-sink-connector.adoc
index dc8a3de..ada98a6 100644
--- a/connectors/camel-file-kafka-connector/src/main/docs/camel-file-kafka-sink-connector.adoc
+++ b/connectors/camel-file-kafka-connector/src/main/docs/camel-file-kafka-sink-connector.adoc
@@ -67,10 +67,17 @@ The camel-file sink connector has no converters out of the box.
 
 
 
-The camel-file sink connector has no transforms out of the box.
+The camel-file sink connector supports 0 transforms out of the box, which are listed below.
 
 
 
+[source,java]
+----
+
+org.apache.camel.kafkaconnector.file.transformers.FileTransforms
+
+----
+
 
 
 The camel-file sink connector has no aggregation strategies out of the box.
diff --git a/connectors/camel-file-kafka-connector/src/main/docs/camel-file-kafka-source-connector.adoc b/connectors/camel-file-kafka-connector/src/main/docs/camel-file-kafka-source-connector.adoc
index df08bfa..e62994b 100644
--- a/connectors/camel-file-kafka-connector/src/main/docs/camel-file-kafka-source-connector.adoc
+++ b/connectors/camel-file-kafka-connector/src/main/docs/camel-file-kafka-source-connector.adoc
@@ -122,10 +122,17 @@ The camel-file source connector has no converters out of the box.
 
 
 
-The camel-file source connector has no transforms out of the box.
+The camel-file source connector supports 0 transforms out of the box, which are listed below.
 
 
 
+[source,java]
+----
+
+org.apache.camel.kafkaconnector.file.transformers.FileTransforms
+
+----
+
 
 
 The camel-file source connector has no aggregation strategies out of the box.
diff --git a/docs/modules/ROOT/pages/connectors/camel-file-kafka-sink-connector.adoc b/docs/modules/ROOT/pages/connectors/camel-file-kafka-sink-connector.adoc
index dc8a3de..ada98a6 100644
--- a/docs/modules/ROOT/pages/connectors/camel-file-kafka-sink-connector.adoc
+++ b/docs/modules/ROOT/pages/connectors/camel-file-kafka-sink-connector.adoc
@@ -67,10 +67,17 @@ The camel-file sink connector has no converters out of the box.
 
 
 
-The camel-file sink connector has no transforms out of the box.
+The camel-file sink connector supports 0 transforms out of the box, which are listed below.
 
 
 
+[source,java]
+----
+
+org.apache.camel.kafkaconnector.file.transformers.FileTransforms
+
+----
+
 
 
 The camel-file sink connector has no aggregation strategies out of the box.
diff --git a/docs/modules/ROOT/pages/connectors/camel-file-kafka-source-connector.adoc b/docs/modules/ROOT/pages/connectors/camel-file-kafka-source-connector.adoc
index df08bfa..e62994b 100644
--- a/docs/modules/ROOT/pages/connectors/camel-file-kafka-source-connector.adoc
+++ b/docs/modules/ROOT/pages/connectors/camel-file-kafka-source-connector.adoc
@@ -122,10 +122,17 @@ The camel-file source connector has no converters out of the box.
 
 
 
-The camel-file source connector has no transforms out of the box.
+The camel-file source connector supports 0 transforms out of the box, which are listed below.
 
 
 
+[source,java]
+----
+
+org.apache.camel.kafkaconnector.file.transformers.FileTransforms
+
+----
+
 
 
 The camel-file source connector has no aggregation strategies out of the box.