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 2020/02/28 13:21:15 UTC

[camel-examples] branch master updated (cbc1ca3 -> ff57210)

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

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


    from cbc1ca3  Cleaning up property placeholders
     new 8cdbc69  Bump to 3.2.0-SNAPSHOT
     new 8d39215  Bump to version 3.2.0-SNAPSHOT also rest-karaf-osgi-activator example
     new eb6c3b9  Removed Camel-example-google-pubsub since the underline structure is now different
     new ff57210  Regen READMe

The 4 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:
 examples/README.adoc                               |   4 +-
 examples/camel-example-activemq-tomcat/pom.xml     |   2 +-
 examples/camel-example-aggregate/pom.xml           |   2 +-
 examples/camel-example-any23/pom.xml               |   2 +-
 .../camel-example-artemis-amqp-blueprint/pom.xml   |   2 +-
 .../camel-example-artemis-large-messages/pom.xml   |   2 +-
 examples/camel-example-artemis/pom.xml             |   2 +-
 examples/camel-example-as2/pom.xml                 |   2 +-
 examples/camel-example-bigxml-split/pom.xml        |   2 +-
 examples/camel-example-billboard-aggr/pom.xml      |   2 +-
 examples/camel-example-cafe-endpointdsl/pom.xml    |   2 +-
 examples/camel-example-cafe/pom.xml                |   2 +-
 .../camel-example-cassandra-kubernetes/pom.xml     |   2 +-
 examples/camel-example-cdi-aws-s3/pom.xml          |   2 +-
 examples/camel-example-cdi-cassandraql/pom.xml     |   2 +-
 examples/camel-example-cdi-kubernetes/pom.xml      |   2 +-
 examples/camel-example-cdi-metrics/pom.xml         |   2 +-
 examples/camel-example-cdi-properties/pom.xml      |   2 +-
 examples/camel-example-cdi-rest-servlet/pom.xml    |   2 +-
 examples/camel-example-cdi-test/pom.xml            |   2 +-
 examples/camel-example-cdi-xml/pom.xml             |   2 +-
 examples/camel-example-cdi/pom.xml                 |   2 +-
 examples/camel-example-console/pom.xml             |   2 +-
 examples/camel-example-cxf-blueprint/pom.xml       |   2 +-
 examples/camel-example-cxf-proxy/pom.xml           |   2 +-
 examples/camel-example-cxf-tomcat/pom.xml          |   2 +-
 .../pom.xml                                        |   2 +-
 examples/camel-example-cxf/pom.xml                 |   2 +-
 examples/camel-example-debezium/pom.xml            |   2 +-
 examples/camel-example-ehcache-blueprint/pom.xml   |   2 +-
 examples/camel-example-fhir-osgi/pom.xml           |   2 +-
 examples/camel-example-fhir/pom.xml                |   2 +-
 examples/camel-example-ftp/pom.xml                 |   2 +-
 examples/camel-example-google-pubsub/README.adoc   |  68 -------
 examples/camel-example-google-pubsub/pom.xml       | 123 -------------
 .../google/pubsub/CreateTopicSubscription.java     |  89 ---------
 .../google/pubsub/MessageConsumerClient.java       |  66 -------
 .../google/pubsub/MessagePublisherClient.java      |  84 ---------
 .../camel/example/google/pubsub/PubsubUtil.java    |  56 ------
 .../src/main/resources/META-INF/LICENSE.txt        | 203 ---------------------
 .../src/main/resources/META-INF/NOTICE.txt         |  11 --
 .../src/main/resources/application.properties      |  40 ----
 .../src/main/resources/example.properties          |  40 ----
 .../src/main/resources/log4j2.properties           |  23 ---
 .../camel-example-hazelcast-kubernetes/pom.xml     |   2 +-
 examples/camel-example-java8/pom.xml               |   2 +-
 examples/camel-example-jdbc/pom.xml                |   2 +-
 examples/camel-example-jms-file/pom.xml            |   2 +-
 examples/camel-example-jmx/pom.xml                 |   2 +-
 examples/camel-example-jooq/pom.xml                |   2 +-
 examples/camel-example-kafka/pom.xml               |   2 +-
 examples/camel-example-kotlin/pom.xml              |   2 +-
 examples/camel-example-loadbalancing/pom.xml       |   2 +-
 examples/camel-example-loan-broker-cxf/pom.xml     |   2 +-
 examples/camel-example-loan-broker-jms/pom.xml     |   2 +-
 examples/camel-example-main-artemis/pom.xml        |   2 +-
 examples/camel-example-main-tiny/pom.xml           |   2 +-
 examples/camel-example-main-xml/pom.xml            |   2 +-
 examples/camel-example-main/pom.xml                |   2 +-
 examples/camel-example-management/pom.xml          |   2 +-
 examples/camel-example-micrometer/pom.xml          |   2 +-
 examples/camel-example-mybatis/pom.xml             |   2 +-
 .../camel-example-netty-custom-correlation/pom.xml |   2 +-
 .../camel-example-netty-http/myapp-cdi/pom.xml     |   2 +-
 .../camel-example-netty-http/myapp-one/pom.xml     |   2 +-
 .../camel-example-netty-http/myapp-two/pom.xml     |   2 +-
 examples/camel-example-netty-http/pom.xml          |   2 +-
 .../shared-netty-http-server/pom.xml               |   2 +-
 examples/camel-example-olingo4-blueprint/pom.xml   |   2 +-
 examples/camel-example-openapi-cdi/pom.xml         |   2 +-
 examples/camel-example-openapi-osgi/pom.xml        |   2 +-
 examples/camel-example-pojo-messaging/pom.xml      |   2 +-
 .../camel-example-reactive-executor-vertx/pom.xml  |   2 +-
 .../core-rest/pom.xml                              |   2 +-
 .../distribution/pom.xml                           |   2 +-
 .../parent/pom.xml                                 |   6 +-
 .../pom.xml                                        |   4 +-
 .../provision/pom.xml                              |   2 +-
 .../tika-detect/pom.xml                            |   2 +-
 .../tika-parse/pom.xml                             |   2 +-
 examples/camel-example-route-throttling/pom.xml    |   2 +-
 .../camel-example-servlet-rest-blueprint/pom.xml   |   2 +-
 examples/camel-example-servlet-tomcat/pom.xml      |   2 +-
 examples/camel-example-spark-rest/pom.xml          |   2 +-
 examples/camel-example-splunk/pom.xml              |   2 +-
 examples/camel-example-spring-javaconfig/pom.xml   |   2 +-
 examples/camel-example-spring-jms/pom.xml          |   2 +-
 examples/camel-example-spring-pulsar/pom.xml       |   2 +-
 examples/camel-example-spring-security/pom.xml     |   2 +-
 examples/camel-example-spring-ws/pom.xml           |   2 +-
 examples/camel-example-spring-xquery/pom.xml       |   2 +-
 examples/camel-example-spring/pom.xml              |   2 +-
 examples/camel-example-sql-blueprint/pom.xml       |   2 +-
 examples/camel-example-ssh-security/pom.xml        |   2 +-
 examples/camel-example-ssh/pom.xml                 |   2 +-
 examples/camel-example-swagger-cdi/pom.xml         |   2 +-
 examples/camel-example-swagger-osgi/pom.xml        |   2 +-
 examples/camel-example-telegram/pom.xml            |   2 +-
 .../camel-example-transformer-blueprint/pom.xml    |   2 +-
 examples/camel-example-transformer-cdi/pom.xml     |   2 +-
 examples/camel-example-transformer-demo/pom.xml    |   2 +-
 .../pom.xml                                        |   2 +-
 examples/camel-example-twitter-websocket/pom.xml   |   2 +-
 examples/camel-example-widget-gadget-cdi/pom.xml   |   2 +-
 examples/camel-example-widget-gadget-java/pom.xml  |   2 +-
 examples/camel-example-widget-gadget-xml/pom.xml   |   2 +-
 examples/pom.xml                                   |   3 +-
 107 files changed, 99 insertions(+), 905 deletions(-)
 delete mode 100644 examples/camel-example-google-pubsub/README.adoc
 delete mode 100644 examples/camel-example-google-pubsub/pom.xml
 delete mode 100644 examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/CreateTopicSubscription.java
 delete mode 100644 examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/MessageConsumerClient.java
 delete mode 100644 examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/MessagePublisherClient.java
 delete mode 100644 examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/PubsubUtil.java
 delete mode 100644 examples/camel-example-google-pubsub/src/main/resources/META-INF/LICENSE.txt
 delete mode 100644 examples/camel-example-google-pubsub/src/main/resources/META-INF/NOTICE.txt
 delete mode 100644 examples/camel-example-google-pubsub/src/main/resources/application.properties
 delete mode 100644 examples/camel-example-google-pubsub/src/main/resources/example.properties
 delete mode 100644 examples/camel-example-google-pubsub/src/main/resources/log4j2.properties


[camel-examples] 03/04: Removed Camel-example-google-pubsub since the underline structure is now different

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

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

commit eb6c3b93dd773b431b1866e434001ad1a2c06f15
Author: Andrea Cosentino <an...@gmail.com>
AuthorDate: Fri Feb 28 12:29:56 2020 +0100

    Removed Camel-example-google-pubsub since the underline structure is now different
---
 examples/camel-example-google-pubsub/README.adoc   |  68 -------
 examples/camel-example-google-pubsub/pom.xml       | 123 -------------
 .../google/pubsub/CreateTopicSubscription.java     |  89 ---------
 .../google/pubsub/MessageConsumerClient.java       |  66 -------
 .../google/pubsub/MessagePublisherClient.java      |  84 ---------
 .../camel/example/google/pubsub/PubsubUtil.java    |  56 ------
 .../src/main/resources/META-INF/LICENSE.txt        | 203 ---------------------
 .../src/main/resources/META-INF/NOTICE.txt         |  11 --
 .../src/main/resources/application.properties      |  40 ----
 .../src/main/resources/example.properties          |  40 ----
 .../src/main/resources/log4j2.properties           |  23 ---
 examples/pom.xml                                   |   1 -
 12 files changed, 804 deletions(-)

diff --git a/examples/camel-example-google-pubsub/README.adoc b/examples/camel-example-google-pubsub/README.adoc
deleted file mode 100644
index 4e74f09..0000000
--- a/examples/camel-example-google-pubsub/README.adoc
+++ /dev/null
@@ -1,68 +0,0 @@
-# Camel Google Pubsub example
-
-= Introduction
-
-An example which shows how to integrate Camel with Google Pubsub.
-
-== Preparing Google Pubsub
-
-This example requires a Google Cloud Account with a Pubsub subscription.
-To create a Goolge Cloud account please visit https://cloud.google.com.
-To setup Pubsub subscription see https://cloud.google.com/pubsub/docs/overview
-
-A topic and subscription need to be created and the topic and subscription name
-set in the application.properties.
-
-The topic and subscription (with names as configured in application.properties) can be created within the
-Google Cloud Console or by running:
-
-    mvn compile exec:java -Ppubsub-create-topic-subscription
-
-
-In the application.properties you need to specify the
-
-For authenticating against Google Cloud one of the following options can be used:
-
-Using your default credentials::
-  Comment out  `credentials.fileLocation`, `credentials.account` and `credentials.key`
-Using a json service account credentials file::
-  Set `credentials.fileLocation` to the location of the json credentials file.
-  Comment out  `credentials.account` and `credentials.key`
-Using an account and key::
-  Set `credentials.account` to the service account email and `credentials.key` to the service account key.
-
-== Run
-
-Run the consumer and producer in separate shells:
-
-
-    mvn compile exec:java -Ppubsub-producer
-
-    mvn compile exec:java -Ppubsub-consumer
-
-Initially, some messages are sent programmatically.
-
-On the command prompt for the producer, type the messages. Each line is sent as one message to Google Pubsub.
-Press `Ctrl-C` to exit.
-
-As the pubsub channel is persistent the consumer and producer do not need to run at the same time.
-
-Messages can be send from the Google Pubsub console which will be picked up by the consumer.
-
-== Configuration
-
-You can configure the details in the file:
-  `src/main/resources/application.properties`
-
-You can enable verbose logging by adjusting the `src/main/resources/log4j2.properties`
-  file as documented in the file.
-
-=== Help and contributions
-
-If you hit any problem using Camel or have some feedback, 
-then please https://camel.apache.org/support.html[let us know].
-
-We also love contributors, 
-so https://camel.apache.org/contributing.html[get involved] :-)
-
-The Camel riders!
diff --git a/examples/camel-example-google-pubsub/pom.xml b/examples/camel-example-google-pubsub/pom.xml
deleted file mode 100644
index 622e0d2..0000000
--- a/examples/camel-example-google-pubsub/pom.xml
+++ /dev/null
@@ -1,123 +0,0 @@
-<?xml version="1.0"?>
-<!--
-
-    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.
-
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
-
-    <modelVersion>4.0.0</modelVersion>
-
-    <parent>
-        <groupId>org.apache.camel.example</groupId>
-        <artifactId>examples</artifactId>
-        <version>3.2.0-SNAPSHOT</version>
-    </parent>
-
-    <artifactId>camel-example-google-pubsub</artifactId>
-    <name>Camel :: Example :: Google-Pubsub</name>
-    <description>An example for Google Pubsub</description>
-
-    <properties>
-        <category>Messaging</category>
-    </properties>
-
-    <dependencyManagement>
-        <dependencies>
-            <!-- Add Camel BOM -->
-            <dependency>
-                <groupId>org.apache.camel</groupId>
-                <artifactId>camel-bom</artifactId>
-                <version>${project.version}</version>
-                <type>pom</type>
-                <scope>import</scope>
-            </dependency>
-        </dependencies>
-    </dependencyManagement>
-
-    <dependencies>
-
-        <!-- camel -->
-        <dependency>
-            <groupId>org.apache.camel</groupId>
-            <artifactId>camel-core</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.camel</groupId>
-            <artifactId>camel-google-pubsub</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.camel</groupId>
-            <artifactId>camel-stream</artifactId>
-        </dependency>
-
-        <!-- logging -->
-        <dependency>
-            <groupId>org.apache.logging.log4j</groupId>
-            <artifactId>log4j-api</artifactId>
-            <version>${log4j2-version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.logging.log4j</groupId>
-            <artifactId>log4j-core</artifactId>
-            <version>${log4j2-version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.logging.log4j</groupId>
-            <artifactId>log4j-slf4j-impl</artifactId>
-            <version>${log4j2-version}</version>
-        </dependency>
-    </dependencies>
-
-    <profiles>
-
-        <profile>
-            <id>pubsub-producer</id>
-            <properties>
-                <target.main.class>org.apache.camel.example.google.pubsub.MessagePublisherClient</target.main.class>
-            </properties>
-        </profile>
-
-        <profile>
-            <id>pubsub-consumer</id>
-            <properties>
-                <target.main.class>org.apache.camel.example.google.pubsub.MessageConsumerClient</target.main.class>
-            </properties>
-        </profile>
-
-        <profile>
-            <id>pubsub-create-topic-subscription</id>
-            <properties>
-                <target.main.class>org.apache.camel.example.google.pubsub.CreateTopicSubscription</target.main.class>
-            </properties>
-        </profile>
-    </profiles>
-
-    <build>
-        <plugins>
-            <!-- Allows the example to be run via 'mvn compile exec:java' -->
-            <plugin>
-                <groupId>org.codehaus.mojo</groupId>
-                <artifactId>exec-maven-plugin</artifactId>
-                <configuration>
-                    <mainClass>${target.main.class}</mainClass>
-                    <includePluginDependencies>false</includePluginDependencies>
-                </configuration>
-            </plugin>
-        </plugins>
-    </build>
-
-</project>
diff --git a/examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/CreateTopicSubscription.java b/examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/CreateTopicSubscription.java
deleted file mode 100644
index 573b82b..0000000
--- a/examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/CreateTopicSubscription.java
+++ /dev/null
@@ -1,89 +0,0 @@
-/*
- * 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.example.google.pubsub;
-
-import java.util.Properties;
-
-import com.google.api.client.googleapis.json.GoogleJsonResponseException;
-import com.google.api.services.pubsub.Pubsub;
-import com.google.api.services.pubsub.model.Subscription;
-import com.google.api.services.pubsub.model.Topic;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-public final class CreateTopicSubscription {
-    private static final Logger LOG = LoggerFactory.getLogger(CreateTopicSubscription.class);
-
-    private CreateTopicSubscription() {
-    }
-
-    public static void main(String[] args) throws Exception {
-        createTopicSubscriptionPair(10);
-    }
-
-    private static void createTopicSubscriptionPair(int ackDeadlineSeconds) throws Exception {
-        Properties properties = PubsubUtil.loadProperties();
-        String projectId = properties.getProperty("pubsub.projectId");
-        String topic = properties.getProperty("pubsub.topic");
-        String subscriptionName = properties.getProperty("pubsub.subscription");
-
-        String topicFullName = String.format("projects/%s/topics/%s",
-                projectId,
-                topic);
-
-        String subscriptionFullName = String.format("projects/%s/subscriptions/%s",
-                projectId,
-                subscriptionName);
-
-        Pubsub pubsub = PubsubUtil
-                .createConnectionFactory(properties)
-                .getDefaultClient();
-
-        try {
-            pubsub.projects()
-                    .topics()
-                    .create(topicFullName, new Topic())
-                    .execute();
-        } catch (GoogleJsonResponseException e) {
-            // 409 indicates that the resource is available already
-            if (409 == e.getStatusCode()) {
-                LOG.info("Topic {} already exist", topic);
-            } else {
-                throw e;
-            }
-        }
-
-        try {
-            Subscription subscription = new Subscription()
-                    .setTopic(topicFullName)
-                    .setAckDeadlineSeconds(ackDeadlineSeconds);
-
-            pubsub.projects()
-                    .subscriptions()
-                    .create(subscriptionFullName, subscription)
-                    .execute();
-        } catch (GoogleJsonResponseException e) {
-            // 409 indicates that the resource is available already
-            if (409 == e.getStatusCode()) {
-                LOG.info("Subscription {} already exist", subscriptionName);
-            } else {
-                throw e;
-            }
-        }
-    }
-
-}
diff --git a/examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/MessageConsumerClient.java b/examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/MessageConsumerClient.java
deleted file mode 100644
index 5c542ef..0000000
--- a/examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/MessageConsumerClient.java
+++ /dev/null
@@ -1,66 +0,0 @@
-/*
- * 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.example.google.pubsub;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.google.pubsub.GooglePubsubComponent;
-import org.apache.camel.impl.DefaultCamelContext;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-public final class MessageConsumerClient {
-
-    private static final Logger LOG = LoggerFactory.getLogger(MessageConsumerClient.class);
-
-    private MessageConsumerClient() {
-    }
-
-    public static void main(String[] args) throws Exception {
-
-        LOG.info("About to run Google-pubsub-camel integration...");
-
-        CamelContext camelContext = new DefaultCamelContext();
-
-        // setup google pubsub component
-        GooglePubsubComponent googlePubsub = PubsubUtil.createComponent();
-        camelContext.addComponent("google-pubsub", googlePubsub);
-
-        // Add route to send messages to Google pubsub
-
-        camelContext.addRoutes(new RouteBuilder() {
-            public void configure() {
-                camelContext.getPropertiesComponent().setLocation("classpath:example.properties");
-
-                log.info("About to start route: Google Pubsub -> Log ");
-
-                from("google-pubsub:{{pubsub.projectId}}:{{pubsub.subscription}}?"
-                        + "maxMessagesPerPoll={{consumer.maxMessagesPerPoll}}&"
-                        + "concurrentConsumers={{consumer.concurrentConsumers}}")
-                        .routeId("FromGooglePubsub")
-                        .log("${body}");
-            }
-        });
-        camelContext.start();
-
-        // let it run for 5 minutes before shutting down
-        Thread.sleep(5 * 60 * 1000);
-
-        camelContext.stop();
-    }
-
-}
diff --git a/examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/MessagePublisherClient.java b/examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/MessagePublisherClient.java
deleted file mode 100644
index b29a18e..0000000
--- a/examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/MessagePublisherClient.java
+++ /dev/null
@@ -1,84 +0,0 @@
-/*
- * 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.example.google.pubsub;
-
-import java.util.Calendar;
-import java.util.HashMap;
-import java.util.Map;
-
-import org.apache.camel.CamelContext;
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.google.pubsub.GooglePubsubComponent;
-import org.apache.camel.impl.DefaultCamelContext;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-public final class MessagePublisherClient {
-
-    private static final Logger LOG = LoggerFactory.getLogger(MessagePublisherClient.class);
-
-    private MessagePublisherClient() {
-    }
-
-    public static void main(String[] args) throws Exception {
-
-        LOG.info("About to run Google-pubsub-camel integration...");
-
-        String testPubsubMessage = "Test Message from  MessagePublisherClient " + Calendar.getInstance().getTime();
-
-        CamelContext camelContext = new DefaultCamelContext();
-
-        // Add route to send messages to Google Pubsub
-
-        camelContext.addRoutes(new RouteBuilder() {
-            public void configure() {
-                camelContext.getPropertiesComponent().setLocation("classpath:example.properties");
-
-                // setup google pubsub component
-                GooglePubsubComponent googlePubsub = PubsubUtil.createComponent();
-                camelContext.addComponent("google-pubsub", googlePubsub);
-
-                from("direct:googlePubsubStart").routeId("DirectToGooglePubsub")
-                        .to("google-pubsub:{{pubsub.projectId}}:{{pubsub.topic}}").log("${headers}");
-
-
-                // Takes input from the command line.
-
-                from("stream:in")
-                        .to("direct:googlePubsubStart");
-
-            }
-
-        });
-
-        ProducerTemplate producerTemplate = camelContext.createProducerTemplate();
-        camelContext.start();
-
-        Map<String, Object> headers = new HashMap<>();
-
-        producerTemplate.sendBodyAndHeaders("direct:googlePubsubStart", testPubsubMessage, headers);
-
-        LOG.info("Successfully published message to Pubsub.");
-        System.out.println("Enter text on the line below : [Press Ctrl-C to exit.] ");
-
-        Thread.sleep(5 * 60 * 1000);
-
-        camelContext.stop();
-    }
-
-}
diff --git a/examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/PubsubUtil.java b/examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/PubsubUtil.java
deleted file mode 100644
index c129346..0000000
--- a/examples/camel-example-google-pubsub/src/main/java/org/apache/camel/example/google/pubsub/PubsubUtil.java
+++ /dev/null
@@ -1,56 +0,0 @@
-/*
- * 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.example.google.pubsub;
-
-import java.io.InputStream;
-import java.util.Properties;
-
-import org.apache.camel.component.google.pubsub.GooglePubsubComponent;
-import org.apache.camel.component.google.pubsub.GooglePubsubConnectionFactory;
-
-public interface PubsubUtil {
-
-    static GooglePubsubComponent createComponent() {
-        GooglePubsubComponent component = new GooglePubsubComponent();
-        Properties properties = loadProperties();
-        GooglePubsubConnectionFactory connectionFactory = createConnectionFactory(properties);
-        component.setConnectionFactory(connectionFactory);
-        return component;
-    }
-
-    static GooglePubsubConnectionFactory createConnectionFactory(Properties properties) {
-        GooglePubsubConnectionFactory connectionFactory = new GooglePubsubConnectionFactory();
-        connectionFactory.setCredentialsFileLocation(properties.getProperty("credentials.fileLocation"));
-        connectionFactory.setServiceAccount(properties.getProperty("credentials.account"));
-        connectionFactory.setServiceAccountKey(properties.getProperty("credentials.key"));
-        connectionFactory.setServiceURL(properties.getProperty("pubsub.serviceUrl"));
-        return connectionFactory;
-    }
-
-    static Properties loadProperties() {
-        Properties properties = new Properties();
-        InputStream fileIn = PubsubUtil.class.getClassLoader().getResourceAsStream("example.properties");
-        try {
-            properties.load(fileIn);
-
-        } catch (Exception e) {
-            throw new RuntimeException(e);
-        }
-
-        return properties;
-    }
-}
diff --git a/examples/camel-example-google-pubsub/src/main/resources/META-INF/LICENSE.txt b/examples/camel-example-google-pubsub/src/main/resources/META-INF/LICENSE.txt
deleted file mode 100644
index 6b0b127..0000000
--- a/examples/camel-example-google-pubsub/src/main/resources/META-INF/LICENSE.txt
+++ /dev/null
@@ -1,203 +0,0 @@
-
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
-
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-
-   1. Definitions.
-
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-
-   END OF TERMS AND CONDITIONS
-
-   APPENDIX: How to apply the Apache License to your work.
-
-      To apply the Apache License to your work, attach the following
-      boilerplate notice, with the fields enclosed by brackets "[]"
-      replaced with your own identifying information. (Don't include
-      the brackets!)  The text should be enclosed in the appropriate
-      comment syntax for the file format. We also recommend that a
-      file or class name and description of purpose be included on the
-      same "printed page" as the copyright notice for easier
-      identification within third-party archives.
-
-   Copyright [yyyy] [name of copyright owner]
-
-   Licensed 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.
-
diff --git a/examples/camel-example-google-pubsub/src/main/resources/META-INF/NOTICE.txt b/examples/camel-example-google-pubsub/src/main/resources/META-INF/NOTICE.txt
deleted file mode 100644
index 2e215bf..0000000
--- a/examples/camel-example-google-pubsub/src/main/resources/META-INF/NOTICE.txt
+++ /dev/null
@@ -1,11 +0,0 @@
-   =========================================================================
-   ==  NOTICE file corresponding to the section 4 d of                    ==
-   ==  the Apache License, Version 2.0,                                   ==
-   ==  in this case for the Apache Camel distribution.                    ==
-   =========================================================================
-
-   This product includes software developed by
-   The Apache Software Foundation (http://www.apache.org/).
-
-   Please read the different LICENSE files present in the licenses directory of
-   this distribution.
diff --git a/examples/camel-example-google-pubsub/src/main/resources/application.properties b/examples/camel-example-google-pubsub/src/main/resources/application.properties
deleted file mode 100644
index 680832a..0000000
--- a/examples/camel-example-google-pubsub/src/main/resources/application.properties
+++ /dev/null
@@ -1,40 +0,0 @@
-## ---------------------------------------------------------------------------
-## 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.
-## ---------------------------------------------------------------------------
-
-# Consumer properties
-
-# No of simultaneous pull requests
-consumer.concurrentConsumers=1
-
-# Max number of messages per poll
-consumer.maxMessagesPerPoll=10
-
-# Pubsub service url. Defaults to google cloud default endpoint
-# pubsub.serviceUrl=localhost:8383
-
-pubsub.projectId=scg-bi-sandbox
-
-# Google Pubsub topic
-pubsub.topic=camel-google-pubsub-example
-# Google Pubsub subscription
-pubsub.subscription=camel-google-pubsub-example.sub
-
-
-#credentials.fileLocation=
-#credentials.account=test-account@camel-pubsub-component.iam.gserviceaccount.com
-#credentials.key=-----BEGIN PRIVATE KEY-----\nMIIEvQIBADANBgkqhkiG9w0BAQEFAASCBKcwggSjAgEAAoIBAQCfCiEwLed3hJ+h\n3zkpsGZj+MEB8MbpbqdUsiAp+Ok05zchGHM8iEG5s4gh013CI0rnta4zYDTrB98p\nBD+BX0TFP4S1QecSK0RoaJ8OmLYgYN56olobbedPRRdZIwopvQ7wSIqrEwWtez6Y\nRXcQzykYzETDEc2s0JyJU9BI2ZAENPbMheZICUkLHJdX0FqVf5WTtRDXnyL79CiW\nRirqN+eJdhq46Dz/TlEymuMePZVWAdcx0v8xv102H9bqFWtJvin8pD6fIT6f2iL1\ne/lQjNUVvX7Sx2EuLWZlPo+mWNvRCTXZymTcluj0jleAYhjuMc2xVEDx2RaCt2sx\nCo2Nb0edAgMBAAECggEAIFEJn2WkhCfB3D2kuvDqTWQtq/xGHw [...]
-
diff --git a/examples/camel-example-google-pubsub/src/main/resources/example.properties b/examples/camel-example-google-pubsub/src/main/resources/example.properties
deleted file mode 100644
index 680832a..0000000
--- a/examples/camel-example-google-pubsub/src/main/resources/example.properties
+++ /dev/null
@@ -1,40 +0,0 @@
-## ---------------------------------------------------------------------------
-## 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.
-## ---------------------------------------------------------------------------
-
-# Consumer properties
-
-# No of simultaneous pull requests
-consumer.concurrentConsumers=1
-
-# Max number of messages per poll
-consumer.maxMessagesPerPoll=10
-
-# Pubsub service url. Defaults to google cloud default endpoint
-# pubsub.serviceUrl=localhost:8383
-
-pubsub.projectId=scg-bi-sandbox
-
-# Google Pubsub topic
-pubsub.topic=camel-google-pubsub-example
-# Google Pubsub subscription
-pubsub.subscription=camel-google-pubsub-example.sub
-
-
-#credentials.fileLocation=
-#credentials.account=test-account@camel-pubsub-component.iam.gserviceaccount.com
-#credentials.key=-----BEGIN PRIVATE KEY-----\nMIIEvQIBADANBgkqhkiG9w0BAQEFAASCBKcwggSjAgEAAoIBAQCfCiEwLed3hJ+h\n3zkpsGZj+MEB8MbpbqdUsiAp+Ok05zchGHM8iEG5s4gh013CI0rnta4zYDTrB98p\nBD+BX0TFP4S1QecSK0RoaJ8OmLYgYN56olobbedPRRdZIwopvQ7wSIqrEwWtez6Y\nRXcQzykYzETDEc2s0JyJU9BI2ZAENPbMheZICUkLHJdX0FqVf5WTtRDXnyL79CiW\nRirqN+eJdhq46Dz/TlEymuMePZVWAdcx0v8xv102H9bqFWtJvin8pD6fIT6f2iL1\ne/lQjNUVvX7Sx2EuLWZlPo+mWNvRCTXZymTcluj0jleAYhjuMc2xVEDx2RaCt2sx\nCo2Nb0edAgMBAAECggEAIFEJn2WkhCfB3D2kuvDqTWQtq/xGHw [...]
-
diff --git a/examples/camel-example-google-pubsub/src/main/resources/log4j2.properties b/examples/camel-example-google-pubsub/src/main/resources/log4j2.properties
deleted file mode 100644
index d406a9f..0000000
--- a/examples/camel-example-google-pubsub/src/main/resources/log4j2.properties
+++ /dev/null
@@ -1,23 +0,0 @@
-## ---------------------------------------------------------------------------
-## 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.
-## ---------------------------------------------------------------------------
-
-appender.out.type = Console
-appender.out.name = out
-appender.out.layout.type = PatternLayout
-appender.out.layout.pattern = %d [%-15.15t] %-5p %-30.30c{1} - %m%n
-rootLogger.level = INFO
-rootLogger.appenderRef.out.ref = out
diff --git a/examples/pom.xml b/examples/pom.xml
index 985247d..9dbaac3 100644
--- a/examples/pom.xml
+++ b/examples/pom.xml
@@ -113,7 +113,6 @@
         <module>camel-example-debezium</module>
         <module>camel-example-ehcache-blueprint</module>
         <module>camel-example-ftp</module>
-        <module>camel-example-google-pubsub</module>
         <module>camel-example-hazelcast-kubernetes</module>
         <module>camel-example-java8</module>
         <module>camel-example-jdbc</module>


[camel-examples] 01/04: Bump to 3.2.0-SNAPSHOT

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

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

commit 8cdbc69141ffc325632bef1642b6b561916f32d4
Author: Andrea Cosentino <an...@gmail.com>
AuthorDate: Fri Feb 28 12:09:33 2020 +0100

    Bump to 3.2.0-SNAPSHOT
---
 examples/camel-example-activemq-tomcat/pom.xml                     | 2 +-
 examples/camel-example-aggregate/pom.xml                           | 2 +-
 examples/camel-example-any23/pom.xml                               | 2 +-
 examples/camel-example-artemis-amqp-blueprint/pom.xml              | 2 +-
 examples/camel-example-artemis-large-messages/pom.xml              | 2 +-
 examples/camel-example-artemis/pom.xml                             | 2 +-
 examples/camel-example-as2/pom.xml                                 | 2 +-
 examples/camel-example-bigxml-split/pom.xml                        | 2 +-
 examples/camel-example-billboard-aggr/pom.xml                      | 2 +-
 examples/camel-example-cafe-endpointdsl/pom.xml                    | 2 +-
 examples/camel-example-cafe/pom.xml                                | 2 +-
 examples/camel-example-cassandra-kubernetes/pom.xml                | 2 +-
 examples/camel-example-cdi-aws-s3/pom.xml                          | 2 +-
 examples/camel-example-cdi-cassandraql/pom.xml                     | 2 +-
 examples/camel-example-cdi-kubernetes/pom.xml                      | 2 +-
 examples/camel-example-cdi-metrics/pom.xml                         | 2 +-
 examples/camel-example-cdi-properties/pom.xml                      | 2 +-
 examples/camel-example-cdi-rest-servlet/pom.xml                    | 2 +-
 examples/camel-example-cdi-test/pom.xml                            | 2 +-
 examples/camel-example-cdi-xml/pom.xml                             | 2 +-
 examples/camel-example-cdi/pom.xml                                 | 2 +-
 examples/camel-example-console/pom.xml                             | 2 +-
 examples/camel-example-cxf-blueprint/pom.xml                       | 2 +-
 examples/camel-example-cxf-proxy/pom.xml                           | 2 +-
 examples/camel-example-cxf-tomcat/pom.xml                          | 2 +-
 examples/camel-example-cxf-ws-security-signature/pom.xml           | 2 +-
 examples/camel-example-cxf/pom.xml                                 | 2 +-
 examples/camel-example-debezium/pom.xml                            | 2 +-
 examples/camel-example-ehcache-blueprint/pom.xml                   | 2 +-
 examples/camel-example-fhir-osgi/pom.xml                           | 2 +-
 examples/camel-example-fhir/pom.xml                                | 2 +-
 examples/camel-example-ftp/pom.xml                                 | 2 +-
 examples/camel-example-google-pubsub/pom.xml                       | 2 +-
 examples/camel-example-hazelcast-kubernetes/pom.xml                | 2 +-
 examples/camel-example-java8/pom.xml                               | 2 +-
 examples/camel-example-jdbc/pom.xml                                | 2 +-
 examples/camel-example-jms-file/pom.xml                            | 2 +-
 examples/camel-example-jmx/pom.xml                                 | 2 +-
 examples/camel-example-jooq/pom.xml                                | 2 +-
 examples/camel-example-kafka/pom.xml                               | 2 +-
 examples/camel-example-kotlin/pom.xml                              | 2 +-
 examples/camel-example-loadbalancing/pom.xml                       | 2 +-
 examples/camel-example-loan-broker-cxf/pom.xml                     | 2 +-
 examples/camel-example-loan-broker-jms/pom.xml                     | 2 +-
 examples/camel-example-main-artemis/pom.xml                        | 2 +-
 examples/camel-example-main-tiny/pom.xml                           | 2 +-
 examples/camel-example-main-xml/pom.xml                            | 2 +-
 examples/camel-example-main/pom.xml                                | 2 +-
 examples/camel-example-management/pom.xml                          | 2 +-
 examples/camel-example-micrometer/pom.xml                          | 2 +-
 examples/camel-example-mybatis/pom.xml                             | 2 +-
 examples/camel-example-netty-custom-correlation/pom.xml            | 2 +-
 examples/camel-example-netty-http/myapp-cdi/pom.xml                | 2 +-
 examples/camel-example-netty-http/myapp-one/pom.xml                | 2 +-
 examples/camel-example-netty-http/myapp-two/pom.xml                | 2 +-
 examples/camel-example-netty-http/pom.xml                          | 2 +-
 examples/camel-example-netty-http/shared-netty-http-server/pom.xml | 2 +-
 examples/camel-example-olingo4-blueprint/pom.xml                   | 2 +-
 examples/camel-example-openapi-cdi/pom.xml                         | 2 +-
 examples/camel-example-openapi-osgi/pom.xml                        | 2 +-
 examples/camel-example-pojo-messaging/pom.xml                      | 2 +-
 examples/camel-example-reactive-executor-vertx/pom.xml             | 2 +-
 examples/camel-example-route-throttling/pom.xml                    | 2 +-
 examples/camel-example-servlet-rest-blueprint/pom.xml              | 2 +-
 examples/camel-example-servlet-tomcat/pom.xml                      | 2 +-
 examples/camel-example-spark-rest/pom.xml                          | 2 +-
 examples/camel-example-splunk/pom.xml                              | 2 +-
 examples/camel-example-spring-javaconfig/pom.xml                   | 2 +-
 examples/camel-example-spring-jms/pom.xml                          | 2 +-
 examples/camel-example-spring-pulsar/pom.xml                       | 2 +-
 examples/camel-example-spring-security/pom.xml                     | 2 +-
 examples/camel-example-spring-ws/pom.xml                           | 2 +-
 examples/camel-example-spring-xquery/pom.xml                       | 2 +-
 examples/camel-example-spring/pom.xml                              | 2 +-
 examples/camel-example-sql-blueprint/pom.xml                       | 2 +-
 examples/camel-example-ssh-security/pom.xml                        | 2 +-
 examples/camel-example-ssh/pom.xml                                 | 2 +-
 examples/camel-example-swagger-cdi/pom.xml                         | 2 +-
 examples/camel-example-swagger-osgi/pom.xml                        | 2 +-
 examples/camel-example-telegram/pom.xml                            | 2 +-
 examples/camel-example-transformer-blueprint/pom.xml               | 2 +-
 examples/camel-example-transformer-cdi/pom.xml                     | 2 +-
 examples/camel-example-transformer-demo/pom.xml                    | 2 +-
 examples/camel-example-twitter-websocket-blueprint/pom.xml         | 2 +-
 examples/camel-example-twitter-websocket/pom.xml                   | 2 +-
 examples/camel-example-widget-gadget-cdi/pom.xml                   | 2 +-
 examples/camel-example-widget-gadget-java/pom.xml                  | 2 +-
 examples/camel-example-widget-gadget-xml/pom.xml                   | 2 +-
 examples/pom.xml                                                   | 2 +-
 89 files changed, 89 insertions(+), 89 deletions(-)

diff --git a/examples/camel-example-activemq-tomcat/pom.xml b/examples/camel-example-activemq-tomcat/pom.xml
index e748fc5..3a50231 100644
--- a/examples/camel-example-activemq-tomcat/pom.xml
+++ b/examples/camel-example-activemq-tomcat/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-activemq-tomcat</artifactId>
diff --git a/examples/camel-example-aggregate/pom.xml b/examples/camel-example-aggregate/pom.xml
index 0b8be6f..ef4c5df 100644
--- a/examples/camel-example-aggregate/pom.xml
+++ b/examples/camel-example-aggregate/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-aggregate</artifactId>
diff --git a/examples/camel-example-any23/pom.xml b/examples/camel-example-any23/pom.xml
index 43580f6..da2b411 100644
--- a/examples/camel-example-any23/pom.xml
+++ b/examples/camel-example-any23/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-any23</artifactId>
diff --git a/examples/camel-example-artemis-amqp-blueprint/pom.xml b/examples/camel-example-artemis-amqp-blueprint/pom.xml
index bdeb5d5..bdffc51 100644
--- a/examples/camel-example-artemis-amqp-blueprint/pom.xml
+++ b/examples/camel-example-artemis-amqp-blueprint/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-artemis-amqp-blueprint</artifactId>
diff --git a/examples/camel-example-artemis-large-messages/pom.xml b/examples/camel-example-artemis-large-messages/pom.xml
index 20ae02e..1c5c3bf 100644
--- a/examples/camel-example-artemis-large-messages/pom.xml
+++ b/examples/camel-example-artemis-large-messages/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-artemis-large-messages</artifactId>
diff --git a/examples/camel-example-artemis/pom.xml b/examples/camel-example-artemis/pom.xml
index cc86e21..7cb1368 100644
--- a/examples/camel-example-artemis/pom.xml
+++ b/examples/camel-example-artemis/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-artemis</artifactId>
diff --git a/examples/camel-example-as2/pom.xml b/examples/camel-example-as2/pom.xml
index be71e4c..a9c916f 100644
--- a/examples/camel-example-as2/pom.xml
+++ b/examples/camel-example-as2/pom.xml
@@ -22,7 +22,7 @@
   <parent>
     <groupId>org.apache.camel.example</groupId>
     <artifactId>examples</artifactId>
-    <version>3.1.0-SNAPSHOT</version>
+    <version>3.2.0-SNAPSHOT</version>
   </parent>
   <artifactId>camel-example-as2</artifactId>
   <name>Camel :: Example :: AS2</name>
diff --git a/examples/camel-example-bigxml-split/pom.xml b/examples/camel-example-bigxml-split/pom.xml
index c5cbd5b..991065e 100644
--- a/examples/camel-example-bigxml-split/pom.xml
+++ b/examples/camel-example-bigxml-split/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-bigxml-split</artifactId>
diff --git a/examples/camel-example-billboard-aggr/pom.xml b/examples/camel-example-billboard-aggr/pom.xml
index 7b5fe94..9704a04 100644
--- a/examples/camel-example-billboard-aggr/pom.xml
+++ b/examples/camel-example-billboard-aggr/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-billboard-aggr</artifactId>
diff --git a/examples/camel-example-cafe-endpointdsl/pom.xml b/examples/camel-example-cafe-endpointdsl/pom.xml
index 150bef4..46587e5 100644
--- a/examples/camel-example-cafe-endpointdsl/pom.xml
+++ b/examples/camel-example-cafe-endpointdsl/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cafe-endpointdsl</artifactId>
diff --git a/examples/camel-example-cafe/pom.xml b/examples/camel-example-cafe/pom.xml
index aff30c3..dc542d9 100644
--- a/examples/camel-example-cafe/pom.xml
+++ b/examples/camel-example-cafe/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cafe</artifactId>
diff --git a/examples/camel-example-cassandra-kubernetes/pom.xml b/examples/camel-example-cassandra-kubernetes/pom.xml
index ad3ede9..2b03cda 100644
--- a/examples/camel-example-cassandra-kubernetes/pom.xml
+++ b/examples/camel-example-cassandra-kubernetes/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cassandra-kubernetes</artifactId>
diff --git a/examples/camel-example-cdi-aws-s3/pom.xml b/examples/camel-example-cdi-aws-s3/pom.xml
index 5735ee8..c542c96 100644
--- a/examples/camel-example-cdi-aws-s3/pom.xml
+++ b/examples/camel-example-cdi-aws-s3/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cdi-aws-s3</artifactId>
diff --git a/examples/camel-example-cdi-cassandraql/pom.xml b/examples/camel-example-cdi-cassandraql/pom.xml
index 690eaa1..a056855 100644
--- a/examples/camel-example-cdi-cassandraql/pom.xml
+++ b/examples/camel-example-cdi-cassandraql/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cdi-cassandraql</artifactId>
diff --git a/examples/camel-example-cdi-kubernetes/pom.xml b/examples/camel-example-cdi-kubernetes/pom.xml
index 8556353..642c353 100644
--- a/examples/camel-example-cdi-kubernetes/pom.xml
+++ b/examples/camel-example-cdi-kubernetes/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cdi-kubernetes</artifactId>
diff --git a/examples/camel-example-cdi-metrics/pom.xml b/examples/camel-example-cdi-metrics/pom.xml
index 018162a..b25a09c 100644
--- a/examples/camel-example-cdi-metrics/pom.xml
+++ b/examples/camel-example-cdi-metrics/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cdi-metrics</artifactId>
diff --git a/examples/camel-example-cdi-properties/pom.xml b/examples/camel-example-cdi-properties/pom.xml
index 3c1cb3a..baad490 100644
--- a/examples/camel-example-cdi-properties/pom.xml
+++ b/examples/camel-example-cdi-properties/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cdi-properties</artifactId>
diff --git a/examples/camel-example-cdi-rest-servlet/pom.xml b/examples/camel-example-cdi-rest-servlet/pom.xml
index 4ba849c..9b6675b 100644
--- a/examples/camel-example-cdi-rest-servlet/pom.xml
+++ b/examples/camel-example-cdi-rest-servlet/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cdi-rest-servlet</artifactId>
diff --git a/examples/camel-example-cdi-test/pom.xml b/examples/camel-example-cdi-test/pom.xml
index 7f6efcb..aa0e392 100644
--- a/examples/camel-example-cdi-test/pom.xml
+++ b/examples/camel-example-cdi-test/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cdi-test</artifactId>
diff --git a/examples/camel-example-cdi-xml/pom.xml b/examples/camel-example-cdi-xml/pom.xml
index d61fde2..d1b357d 100644
--- a/examples/camel-example-cdi-xml/pom.xml
+++ b/examples/camel-example-cdi-xml/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cdi-xml</artifactId>
diff --git a/examples/camel-example-cdi/pom.xml b/examples/camel-example-cdi/pom.xml
index 583441a..2925146 100644
--- a/examples/camel-example-cdi/pom.xml
+++ b/examples/camel-example-cdi/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cdi</artifactId>
diff --git a/examples/camel-example-console/pom.xml b/examples/camel-example-console/pom.xml
index 4748be2..3d3be5e 100644
--- a/examples/camel-example-console/pom.xml
+++ b/examples/camel-example-console/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-console</artifactId>
diff --git a/examples/camel-example-cxf-blueprint/pom.xml b/examples/camel-example-cxf-blueprint/pom.xml
index 6436e19..785b5a1 100644
--- a/examples/camel-example-cxf-blueprint/pom.xml
+++ b/examples/camel-example-cxf-blueprint/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cxf-blueprint</artifactId>
diff --git a/examples/camel-example-cxf-proxy/pom.xml b/examples/camel-example-cxf-proxy/pom.xml
index 8642fd2..60d6a2e 100644
--- a/examples/camel-example-cxf-proxy/pom.xml
+++ b/examples/camel-example-cxf-proxy/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cxf-proxy</artifactId>
diff --git a/examples/camel-example-cxf-tomcat/pom.xml b/examples/camel-example-cxf-tomcat/pom.xml
index d7c50d1..6fcb7d0 100644
--- a/examples/camel-example-cxf-tomcat/pom.xml
+++ b/examples/camel-example-cxf-tomcat/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cxf-tomcat</artifactId>
diff --git a/examples/camel-example-cxf-ws-security-signature/pom.xml b/examples/camel-example-cxf-ws-security-signature/pom.xml
index e23df02..ce093a5 100644
--- a/examples/camel-example-cxf-ws-security-signature/pom.xml
+++ b/examples/camel-example-cxf-ws-security-signature/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cxf-ws-security-signature</artifactId>
diff --git a/examples/camel-example-cxf/pom.xml b/examples/camel-example-cxf/pom.xml
index 9a6dfa9..22a0e1a 100644
--- a/examples/camel-example-cxf/pom.xml
+++ b/examples/camel-example-cxf/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-cxf</artifactId>
diff --git a/examples/camel-example-debezium/pom.xml b/examples/camel-example-debezium/pom.xml
index 22a7a2a..5bac3b7 100644
--- a/examples/camel-example-debezium/pom.xml
+++ b/examples/camel-example-debezium/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-debezium</artifactId>
diff --git a/examples/camel-example-ehcache-blueprint/pom.xml b/examples/camel-example-ehcache-blueprint/pom.xml
index 16200ed..5e0cc5d 100644
--- a/examples/camel-example-ehcache-blueprint/pom.xml
+++ b/examples/camel-example-ehcache-blueprint/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-ehcache-blueprint</artifactId>
diff --git a/examples/camel-example-fhir-osgi/pom.xml b/examples/camel-example-fhir-osgi/pom.xml
index f5f4716..c475be1 100644
--- a/examples/camel-example-fhir-osgi/pom.xml
+++ b/examples/camel-example-fhir-osgi/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-fhir-osgi</artifactId>
diff --git a/examples/camel-example-fhir/pom.xml b/examples/camel-example-fhir/pom.xml
index 35d65e2..8a2a6ec 100644
--- a/examples/camel-example-fhir/pom.xml
+++ b/examples/camel-example-fhir/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-fhir</artifactId>
diff --git a/examples/camel-example-ftp/pom.xml b/examples/camel-example-ftp/pom.xml
index fd83f68..9d5aebe 100644
--- a/examples/camel-example-ftp/pom.xml
+++ b/examples/camel-example-ftp/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-ftp</artifactId>
diff --git a/examples/camel-example-google-pubsub/pom.xml b/examples/camel-example-google-pubsub/pom.xml
index 430ce02..622e0d2 100644
--- a/examples/camel-example-google-pubsub/pom.xml
+++ b/examples/camel-example-google-pubsub/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-google-pubsub</artifactId>
diff --git a/examples/camel-example-hazelcast-kubernetes/pom.xml b/examples/camel-example-hazelcast-kubernetes/pom.xml
index 0013dbe..566cfbb 100644
--- a/examples/camel-example-hazelcast-kubernetes/pom.xml
+++ b/examples/camel-example-hazelcast-kubernetes/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-hazelcast-kubernetes</artifactId>
diff --git a/examples/camel-example-java8/pom.xml b/examples/camel-example-java8/pom.xml
index 5481131..76a3280 100644
--- a/examples/camel-example-java8/pom.xml
+++ b/examples/camel-example-java8/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-java8</artifactId>
diff --git a/examples/camel-example-jdbc/pom.xml b/examples/camel-example-jdbc/pom.xml
index 7dd870f..4fc676d 100644
--- a/examples/camel-example-jdbc/pom.xml
+++ b/examples/camel-example-jdbc/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-jdbc</artifactId>
diff --git a/examples/camel-example-jms-file/pom.xml b/examples/camel-example-jms-file/pom.xml
index 6f4eec8..1c0c5fe 100644
--- a/examples/camel-example-jms-file/pom.xml
+++ b/examples/camel-example-jms-file/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-jms-file</artifactId>
diff --git a/examples/camel-example-jmx/pom.xml b/examples/camel-example-jmx/pom.xml
index 33f54d4..4a12ea0 100644
--- a/examples/camel-example-jmx/pom.xml
+++ b/examples/camel-example-jmx/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-jmx</artifactId>
diff --git a/examples/camel-example-jooq/pom.xml b/examples/camel-example-jooq/pom.xml
index 0d42c3f..aec28a7 100644
--- a/examples/camel-example-jooq/pom.xml
+++ b/examples/camel-example-jooq/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-jooq</artifactId>
diff --git a/examples/camel-example-kafka/pom.xml b/examples/camel-example-kafka/pom.xml
index cd216d1..04fb3d7 100644
--- a/examples/camel-example-kafka/pom.xml
+++ b/examples/camel-example-kafka/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-kafka</artifactId>
diff --git a/examples/camel-example-kotlin/pom.xml b/examples/camel-example-kotlin/pom.xml
index 7cd0e6d..4fc5b83 100644
--- a/examples/camel-example-kotlin/pom.xml
+++ b/examples/camel-example-kotlin/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-kotlin</artifactId>
diff --git a/examples/camel-example-loadbalancing/pom.xml b/examples/camel-example-loadbalancing/pom.xml
index 3869da9..f00716a 100644
--- a/examples/camel-example-loadbalancing/pom.xml
+++ b/examples/camel-example-loadbalancing/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-loadbalancing</artifactId>
diff --git a/examples/camel-example-loan-broker-cxf/pom.xml b/examples/camel-example-loan-broker-cxf/pom.xml
index c62a8c4..ee588be 100644
--- a/examples/camel-example-loan-broker-cxf/pom.xml
+++ b/examples/camel-example-loan-broker-cxf/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-loan-broker-cxf</artifactId>
diff --git a/examples/camel-example-loan-broker-jms/pom.xml b/examples/camel-example-loan-broker-jms/pom.xml
index 89bbb80..40eff81 100644
--- a/examples/camel-example-loan-broker-jms/pom.xml
+++ b/examples/camel-example-loan-broker-jms/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-loan-broker-jms</artifactId>
diff --git a/examples/camel-example-main-artemis/pom.xml b/examples/camel-example-main-artemis/pom.xml
index 538855d..05080fe 100644
--- a/examples/camel-example-main-artemis/pom.xml
+++ b/examples/camel-example-main-artemis/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-main-artemis</artifactId>
diff --git a/examples/camel-example-main-tiny/pom.xml b/examples/camel-example-main-tiny/pom.xml
index 489759c..39e14ce 100644
--- a/examples/camel-example-main-tiny/pom.xml
+++ b/examples/camel-example-main-tiny/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-main-tiny</artifactId>
diff --git a/examples/camel-example-main-xml/pom.xml b/examples/camel-example-main-xml/pom.xml
index 9ea5eeb..f6c6e76 100644
--- a/examples/camel-example-main-xml/pom.xml
+++ b/examples/camel-example-main-xml/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-main-xml</artifactId>
diff --git a/examples/camel-example-main/pom.xml b/examples/camel-example-main/pom.xml
index 5967a31..faf281a 100644
--- a/examples/camel-example-main/pom.xml
+++ b/examples/camel-example-main/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-main</artifactId>
diff --git a/examples/camel-example-management/pom.xml b/examples/camel-example-management/pom.xml
index 256046e..951540f 100644
--- a/examples/camel-example-management/pom.xml
+++ b/examples/camel-example-management/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-management</artifactId>
diff --git a/examples/camel-example-micrometer/pom.xml b/examples/camel-example-micrometer/pom.xml
index 49fe849..3803567 100644
--- a/examples/camel-example-micrometer/pom.xml
+++ b/examples/camel-example-micrometer/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-micrometer</artifactId>
diff --git a/examples/camel-example-mybatis/pom.xml b/examples/camel-example-mybatis/pom.xml
index 83709c4..3da0377 100644
--- a/examples/camel-example-mybatis/pom.xml
+++ b/examples/camel-example-mybatis/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-mybatis</artifactId>
diff --git a/examples/camel-example-netty-custom-correlation/pom.xml b/examples/camel-example-netty-custom-correlation/pom.xml
index c3496c2..9447372 100644
--- a/examples/camel-example-netty-custom-correlation/pom.xml
+++ b/examples/camel-example-netty-custom-correlation/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-netty-custom-correlation</artifactId>
diff --git a/examples/camel-example-netty-http/myapp-cdi/pom.xml b/examples/camel-example-netty-http/myapp-cdi/pom.xml
index 01a77a0..60af471 100644
--- a/examples/camel-example-netty-http/myapp-cdi/pom.xml
+++ b/examples/camel-example-netty-http/myapp-cdi/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <artifactId>camel-example-netty-http</artifactId>
         <groupId>org.apache.camel.example</groupId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-netty-myapp-cdi</artifactId>
diff --git a/examples/camel-example-netty-http/myapp-one/pom.xml b/examples/camel-example-netty-http/myapp-one/pom.xml
index 022dc78..395b716 100644
--- a/examples/camel-example-netty-http/myapp-one/pom.xml
+++ b/examples/camel-example-netty-http/myapp-one/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <artifactId>camel-example-netty-http</artifactId>
         <groupId>org.apache.camel.example</groupId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-netty-myapp-one</artifactId>
diff --git a/examples/camel-example-netty-http/myapp-two/pom.xml b/examples/camel-example-netty-http/myapp-two/pom.xml
index c2015e0..c118f01 100644
--- a/examples/camel-example-netty-http/myapp-two/pom.xml
+++ b/examples/camel-example-netty-http/myapp-two/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <artifactId>camel-example-netty-http</artifactId>
         <groupId>org.apache.camel.example</groupId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-netty-myapp-two</artifactId>
diff --git a/examples/camel-example-netty-http/pom.xml b/examples/camel-example-netty-http/pom.xml
index 9879aa3..0426f04 100644
--- a/examples/camel-example-netty-http/pom.xml
+++ b/examples/camel-example-netty-http/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-netty-http</artifactId>
diff --git a/examples/camel-example-netty-http/shared-netty-http-server/pom.xml b/examples/camel-example-netty-http/shared-netty-http-server/pom.xml
index 0703f3a..49263d3 100644
--- a/examples/camel-example-netty-http/shared-netty-http-server/pom.xml
+++ b/examples/camel-example-netty-http/shared-netty-http-server/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <artifactId>camel-example-netty-http</artifactId>
         <groupId>org.apache.camel.example</groupId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-netty-http-shared</artifactId>
diff --git a/examples/camel-example-olingo4-blueprint/pom.xml b/examples/camel-example-olingo4-blueprint/pom.xml
index 1ea33ee..8a33a9f 100644
--- a/examples/camel-example-olingo4-blueprint/pom.xml
+++ b/examples/camel-example-olingo4-blueprint/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-olingo4-blueprint</artifactId>
diff --git a/examples/camel-example-openapi-cdi/pom.xml b/examples/camel-example-openapi-cdi/pom.xml
index 9544562..ee16a1a 100644
--- a/examples/camel-example-openapi-cdi/pom.xml
+++ b/examples/camel-example-openapi-cdi/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-openapi-cdi</artifactId>
diff --git a/examples/camel-example-openapi-osgi/pom.xml b/examples/camel-example-openapi-osgi/pom.xml
index f25d337..000f03c 100644
--- a/examples/camel-example-openapi-osgi/pom.xml
+++ b/examples/camel-example-openapi-osgi/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-openapi-osgi</artifactId>
diff --git a/examples/camel-example-pojo-messaging/pom.xml b/examples/camel-example-pojo-messaging/pom.xml
index 3b94f42..b41cb14 100644
--- a/examples/camel-example-pojo-messaging/pom.xml
+++ b/examples/camel-example-pojo-messaging/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-pojo-messaging</artifactId>
diff --git a/examples/camel-example-reactive-executor-vertx/pom.xml b/examples/camel-example-reactive-executor-vertx/pom.xml
index 4029b42..99157fa 100644
--- a/examples/camel-example-reactive-executor-vertx/pom.xml
+++ b/examples/camel-example-reactive-executor-vertx/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-reactive-executor-vertx</artifactId>
diff --git a/examples/camel-example-route-throttling/pom.xml b/examples/camel-example-route-throttling/pom.xml
index af7c4e0..8083149 100644
--- a/examples/camel-example-route-throttling/pom.xml
+++ b/examples/camel-example-route-throttling/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-route-throttling</artifactId>
diff --git a/examples/camel-example-servlet-rest-blueprint/pom.xml b/examples/camel-example-servlet-rest-blueprint/pom.xml
index 2b4e482..05a6b94 100644
--- a/examples/camel-example-servlet-rest-blueprint/pom.xml
+++ b/examples/camel-example-servlet-rest-blueprint/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-servlet-rest-blueprint</artifactId>
diff --git a/examples/camel-example-servlet-tomcat/pom.xml b/examples/camel-example-servlet-tomcat/pom.xml
index eea8ed9..9badc66 100644
--- a/examples/camel-example-servlet-tomcat/pom.xml
+++ b/examples/camel-example-servlet-tomcat/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-servlet-tomcat</artifactId>
diff --git a/examples/camel-example-spark-rest/pom.xml b/examples/camel-example-spark-rest/pom.xml
index 6191643..24a053b 100644
--- a/examples/camel-example-spark-rest/pom.xml
+++ b/examples/camel-example-spark-rest/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-spark-rest</artifactId>
diff --git a/examples/camel-example-splunk/pom.xml b/examples/camel-example-splunk/pom.xml
index 806804b..5a9ef82 100644
--- a/examples/camel-example-splunk/pom.xml
+++ b/examples/camel-example-splunk/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-splunk</artifactId>
diff --git a/examples/camel-example-spring-javaconfig/pom.xml b/examples/camel-example-spring-javaconfig/pom.xml
index a64bf69..4b002fb 100644
--- a/examples/camel-example-spring-javaconfig/pom.xml
+++ b/examples/camel-example-spring-javaconfig/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-spring-javaconfig</artifactId>
diff --git a/examples/camel-example-spring-jms/pom.xml b/examples/camel-example-spring-jms/pom.xml
index 44c10a8..e6b9465 100644
--- a/examples/camel-example-spring-jms/pom.xml
+++ b/examples/camel-example-spring-jms/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-spring-jms</artifactId>
diff --git a/examples/camel-example-spring-pulsar/pom.xml b/examples/camel-example-spring-pulsar/pom.xml
index 8ce2a4f..0abd9a3 100644
--- a/examples/camel-example-spring-pulsar/pom.xml
+++ b/examples/camel-example-spring-pulsar/pom.xml
@@ -21,7 +21,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-spring-pulsar</artifactId>
diff --git a/examples/camel-example-spring-security/pom.xml b/examples/camel-example-spring-security/pom.xml
index fb4023b..9f75bde 100644
--- a/examples/camel-example-spring-security/pom.xml
+++ b/examples/camel-example-spring-security/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-spring-security</artifactId>
diff --git a/examples/camel-example-spring-ws/pom.xml b/examples/camel-example-spring-ws/pom.xml
index 9caa84e..aa64c1e 100644
--- a/examples/camel-example-spring-ws/pom.xml
+++ b/examples/camel-example-spring-ws/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-spring-ws</artifactId>
diff --git a/examples/camel-example-spring-xquery/pom.xml b/examples/camel-example-spring-xquery/pom.xml
index a8e09dc..fbca050 100644
--- a/examples/camel-example-spring-xquery/pom.xml
+++ b/examples/camel-example-spring-xquery/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-spring-xquery</artifactId>
diff --git a/examples/camel-example-spring/pom.xml b/examples/camel-example-spring/pom.xml
index 9a626b2..5fbc528 100644
--- a/examples/camel-example-spring/pom.xml
+++ b/examples/camel-example-spring/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-spring</artifactId>
diff --git a/examples/camel-example-sql-blueprint/pom.xml b/examples/camel-example-sql-blueprint/pom.xml
index 5e1295a..a15053c 100644
--- a/examples/camel-example-sql-blueprint/pom.xml
+++ b/examples/camel-example-sql-blueprint/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-sql-blueprint</artifactId>
diff --git a/examples/camel-example-ssh-security/pom.xml b/examples/camel-example-ssh-security/pom.xml
index f5abd6e..95bd880 100644
--- a/examples/camel-example-ssh-security/pom.xml
+++ b/examples/camel-example-ssh-security/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-ssh-security</artifactId>
diff --git a/examples/camel-example-ssh/pom.xml b/examples/camel-example-ssh/pom.xml
index cd4eae1..290d227 100644
--- a/examples/camel-example-ssh/pom.xml
+++ b/examples/camel-example-ssh/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-ssh</artifactId>
diff --git a/examples/camel-example-swagger-cdi/pom.xml b/examples/camel-example-swagger-cdi/pom.xml
index 4aeea90..133591c 100644
--- a/examples/camel-example-swagger-cdi/pom.xml
+++ b/examples/camel-example-swagger-cdi/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-swagger-cdi</artifactId>
diff --git a/examples/camel-example-swagger-osgi/pom.xml b/examples/camel-example-swagger-osgi/pom.xml
index f47fe4a..f64e073 100644
--- a/examples/camel-example-swagger-osgi/pom.xml
+++ b/examples/camel-example-swagger-osgi/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-swagger-osgi</artifactId>
diff --git a/examples/camel-example-telegram/pom.xml b/examples/camel-example-telegram/pom.xml
index f30176a..5ba4862 100644
--- a/examples/camel-example-telegram/pom.xml
+++ b/examples/camel-example-telegram/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-telegram</artifactId>
diff --git a/examples/camel-example-transformer-blueprint/pom.xml b/examples/camel-example-transformer-blueprint/pom.xml
index 90c3cfb..e7c0b36 100644
--- a/examples/camel-example-transformer-blueprint/pom.xml
+++ b/examples/camel-example-transformer-blueprint/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-transformer-blueprint</artifactId>
diff --git a/examples/camel-example-transformer-cdi/pom.xml b/examples/camel-example-transformer-cdi/pom.xml
index aa59c90..fd93fce 100644
--- a/examples/camel-example-transformer-cdi/pom.xml
+++ b/examples/camel-example-transformer-cdi/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-transformer-cdi</artifactId>
diff --git a/examples/camel-example-transformer-demo/pom.xml b/examples/camel-example-transformer-demo/pom.xml
index cb0998a..d20051e 100644
--- a/examples/camel-example-transformer-demo/pom.xml
+++ b/examples/camel-example-transformer-demo/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-transformer-demo</artifactId>
diff --git a/examples/camel-example-twitter-websocket-blueprint/pom.xml b/examples/camel-example-twitter-websocket-blueprint/pom.xml
index 4bd6cbb..1318e05 100644
--- a/examples/camel-example-twitter-websocket-blueprint/pom.xml
+++ b/examples/camel-example-twitter-websocket-blueprint/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-twitter-websocket-blueprint</artifactId>
diff --git a/examples/camel-example-twitter-websocket/pom.xml b/examples/camel-example-twitter-websocket/pom.xml
index 269b4f0..73514df 100644
--- a/examples/camel-example-twitter-websocket/pom.xml
+++ b/examples/camel-example-twitter-websocket/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-twitter-websocket</artifactId>
diff --git a/examples/camel-example-widget-gadget-cdi/pom.xml b/examples/camel-example-widget-gadget-cdi/pom.xml
index 1e4d828..768dbf6 100644
--- a/examples/camel-example-widget-gadget-cdi/pom.xml
+++ b/examples/camel-example-widget-gadget-cdi/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-widget-gadget-cdi</artifactId>
diff --git a/examples/camel-example-widget-gadget-java/pom.xml b/examples/camel-example-widget-gadget-java/pom.xml
index c628315..bb65cd5 100644
--- a/examples/camel-example-widget-gadget-java/pom.xml
+++ b/examples/camel-example-widget-gadget-java/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-widget-gadget-java</artifactId>
diff --git a/examples/camel-example-widget-gadget-xml/pom.xml b/examples/camel-example-widget-gadget-xml/pom.xml
index 8092be1..f198423 100644
--- a/examples/camel-example-widget-gadget-xml/pom.xml
+++ b/examples/camel-example-widget-gadget-xml/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
 
     <artifactId>camel-example-widget-gadget-xml</artifactId>
diff --git a/examples/pom.xml b/examples/pom.xml
index 3709013..985247d 100644
--- a/examples/pom.xml
+++ b/examples/pom.xml
@@ -30,7 +30,7 @@
 
     <groupId>org.apache.camel.example</groupId>
     <artifactId>examples</artifactId>
-    <version>3.1.0-SNAPSHOT</version>
+    <version>3.2.0-SNAPSHOT</version>
     <packaging>pom</packaging>
 
     <name>Camel Examples</name>


[camel-examples] 02/04: Bump to version 3.2.0-SNAPSHOT also rest-karaf-osgi-activator example

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

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

commit 8d3921574f9b728d9eb820747653ccfb040beb52
Author: Andrea Cosentino <an...@gmail.com>
AuthorDate: Fri Feb 28 12:13:22 2020 +0100

    Bump to version 3.2.0-SNAPSHOT also rest-karaf-osgi-activator example
---
 examples/camel-example-rest-karaf-osgi-activator/core-rest/pom.xml  | 2 +-
 .../camel-example-rest-karaf-osgi-activator/distribution/pom.xml    | 2 +-
 examples/camel-example-rest-karaf-osgi-activator/parent/pom.xml     | 6 +++---
 examples/camel-example-rest-karaf-osgi-activator/pom.xml            | 4 ++--
 examples/camel-example-rest-karaf-osgi-activator/provision/pom.xml  | 2 +-
 .../camel-example-rest-karaf-osgi-activator/tika-detect/pom.xml     | 2 +-
 examples/camel-example-rest-karaf-osgi-activator/tika-parse/pom.xml | 2 +-
 7 files changed, 10 insertions(+), 10 deletions(-)

diff --git a/examples/camel-example-rest-karaf-osgi-activator/core-rest/pom.xml b/examples/camel-example-rest-karaf-osgi-activator/core-rest/pom.xml
index 8f0467d..6d9b0be 100644
--- a/examples/camel-example-rest-karaf-osgi-activator/core-rest/pom.xml
+++ b/examples/camel-example-rest-karaf-osgi-activator/core-rest/pom.xml
@@ -22,7 +22,7 @@
 	<parent>
 		<groupId>org.apache.camel.example</groupId>
         <artifactId>camel-example-rest-karaf-osgi-activator-parent</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
         <relativePath>../parent</relativePath>
 	</parent>
 	<artifactId>camel-example-rest-karaf-osgi-activator-core-rest</artifactId>
diff --git a/examples/camel-example-rest-karaf-osgi-activator/distribution/pom.xml b/examples/camel-example-rest-karaf-osgi-activator/distribution/pom.xml
index c8d51ba..a1a9573 100644
--- a/examples/camel-example-rest-karaf-osgi-activator/distribution/pom.xml
+++ b/examples/camel-example-rest-karaf-osgi-activator/distribution/pom.xml
@@ -23,7 +23,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>camel-example-rest-karaf-osgi-activator-parent</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
         <relativePath>../parent</relativePath>
     </parent>
 
diff --git a/examples/camel-example-rest-karaf-osgi-activator/parent/pom.xml b/examples/camel-example-rest-karaf-osgi-activator/parent/pom.xml
index 7f2c60e..21c16c1 100644
--- a/examples/camel-example-rest-karaf-osgi-activator/parent/pom.xml
+++ b/examples/camel-example-rest-karaf-osgi-activator/parent/pom.xml
@@ -19,13 +19,13 @@
 -->
 <project xmlns="http://maven.apache.org/POM/4.0.0"
     xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-    xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+    xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <modelVersion>4.0.0</modelVersion>
 
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>camel-example-rest-karaf-osgi-activator</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
     <artifactId>camel-example-rest-karaf-osgi-activator-parent</artifactId>
     <name>Camel :: Example :: REST :: Karaf :: OSGi Activator :: Parent</name>
@@ -44,4 +44,4 @@
         </pluginManagement>
     </build>
 
-</project>
\ No newline at end of file
+</project>
diff --git a/examples/camel-example-rest-karaf-osgi-activator/pom.xml b/examples/camel-example-rest-karaf-osgi-activator/pom.xml
index dff9033..7a7919c 100644
--- a/examples/camel-example-rest-karaf-osgi-activator/pom.xml
+++ b/examples/camel-example-rest-karaf-osgi-activator/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>examples</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
     </parent>
   
 	<artifactId>camel-example-rest-karaf-osgi-activator</artifactId>
@@ -85,4 +85,4 @@
             </plugin>
         </plugins>
     </build>
-</project>
\ No newline at end of file
+</project>
diff --git a/examples/camel-example-rest-karaf-osgi-activator/provision/pom.xml b/examples/camel-example-rest-karaf-osgi-activator/provision/pom.xml
index 2a42079..fc7be21 100644
--- a/examples/camel-example-rest-karaf-osgi-activator/provision/pom.xml
+++ b/examples/camel-example-rest-karaf-osgi-activator/provision/pom.xml
@@ -23,7 +23,7 @@
   <parent>
         <groupId>org.apache.camel.example</groupId>
         <artifactId>camel-example-rest-karaf-osgi-activator-parent</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
         <relativePath>../parent</relativePath>
     </parent>
   <artifactId>camel-example-rest-karaf-osgi-activator-provision</artifactId>
diff --git a/examples/camel-example-rest-karaf-osgi-activator/tika-detect/pom.xml b/examples/camel-example-rest-karaf-osgi-activator/tika-detect/pom.xml
index 450ee05..0153161 100644
--- a/examples/camel-example-rest-karaf-osgi-activator/tika-detect/pom.xml
+++ b/examples/camel-example-rest-karaf-osgi-activator/tika-detect/pom.xml
@@ -22,7 +22,7 @@
 	<parent>
 		<groupId>org.apache.camel.example</groupId>
         <artifactId>camel-example-rest-karaf-osgi-activator-parent</artifactId>
-        <version>3.1.0-SNAPSHOT</version>
+        <version>3.2.0-SNAPSHOT</version>
         <relativePath>../parent</relativePath>
 	</parent>
 	<artifactId>camel-example-rest-karaf-osgi-activator-tika-detect</artifactId>
diff --git a/examples/camel-example-rest-karaf-osgi-activator/tika-parse/pom.xml b/examples/camel-example-rest-karaf-osgi-activator/tika-parse/pom.xml
index 163db6a..675415a 100644
--- a/examples/camel-example-rest-karaf-osgi-activator/tika-parse/pom.xml
+++ b/examples/camel-example-rest-karaf-osgi-activator/tika-parse/pom.xml
@@ -22,7 +22,7 @@
 	<parent>
 		<groupId>org.apache.camel.example</groupId>
 		<artifactId>camel-example-rest-karaf-osgi-activator-parent</artifactId>
-		<version>3.1.0-SNAPSHOT</version>
+		<version>3.2.0-SNAPSHOT</version>
 		<relativePath>../parent</relativePath>
 	</parent>
 	<artifactId>camel-example-rest-karaf-osgi-activator-tika-parse</artifactId>


[camel-examples] 04/04: Regen READMe

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

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

commit ff57210c60d8c27dcc2d79ff133cd10fbb966e4c
Author: Andrea Cosentino <an...@gmail.com>
AuthorDate: Fri Feb 28 13:14:52 2020 +0100

    Regen READMe
---
 examples/README.adoc | 4 +---
 1 file changed, 1 insertion(+), 3 deletions(-)

diff --git a/examples/README.adoc b/examples/README.adoc
index 57ef260..8d450d3 100644
--- a/examples/README.adoc
+++ b/examples/README.adoc
@@ -11,7 +11,7 @@ View the individual example READMEs for details.
 == Examples
 
 // examples: START
-Number of Examples: 85 (0 deprecated)
+Number of Examples: 84 (0 deprecated)
 
 [width="100%",cols="4,2,4",options="header"]
 |===
@@ -129,8 +129,6 @@ Number of Examples: 85 (0 deprecated)
         streaming mode
     
 
-| link:camel-example-google-pubsub/README.adoc[Google Pubsub] (camel-example-google-pubsub) | Messaging | An example for Google Pubsub
-
 | link:camel-example-jms-file/README.adoc[JMS-File] (camel-example-jms-file) | Messaging | An example that persists messages from JMS to files
 
 | link:camel-example-kafka/README.adoc[Kafka] (camel-example-kafka) | Messaging | An example for Kafka