You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by pa...@apache.org on 2020/08/16 15:20:15 UTC

[camel] branch master updated (6059794 -> 6950001)

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

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


    from 6059794  Fix reference to bean binding documentation
     new 41de62b  VertxWebsocketConsumer: Remove unused private field.
     new 6950001  CouchbaseProducer: Avoid potential overflow in integer multiplication.

The 2 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:
 .../java/org/apache/camel/component/couchbase/CouchbaseProducer.java   | 2 +-
 .../apache/camel/component/vertx/websocket/VertxWebsocketConsumer.java | 3 ---
 2 files changed, 1 insertion(+), 4 deletions(-)


[camel] 02/02: CouchbaseProducer: Avoid potential overflow in integer multiplication.

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

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

commit 695000151f7b2614a89953ce064faacb9228720f
Author: Pascal Schumacher <pa...@gmx.net>
AuthorDate: Sun Aug 16 17:17:13 2020 +0200

    CouchbaseProducer: Avoid potential overflow in integer multiplication.
---
 .../java/org/apache/camel/component/couchbase/CouchbaseProducer.java    | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/components/camel-couchbase/src/main/java/org/apache/camel/component/couchbase/CouchbaseProducer.java b/components/camel-couchbase/src/main/java/org/apache/camel/component/couchbase/CouchbaseProducer.java
index 4c97728..b31ed72 100644
--- a/components/camel-couchbase/src/main/java/org/apache/camel/component/couchbase/CouchbaseProducer.java
+++ b/components/camel-couchbase/src/main/java/org/apache/camel/component/couchbase/CouchbaseProducer.java
@@ -168,7 +168,7 @@ public class CouchbaseProducer extends DefaultProducer {
         UpsertOptions options = UpsertOptions.upsertOptions()
                 .expiry(Duration.ofSeconds(expiry))
                 .durability(persistTo, replicateTo)
-                .timeout(Duration.ofMillis(retryAttempts * producerRetryPause))
+                .timeout(Duration.ofMillis(retryAttempts * (long) producerRetryPause))
                 .retryStrategy(BestEffortRetryStrategy.withExponentialBackoff(Duration.ofMillis(producerRetryPause), Duration.ofMillis(producerRetryPause), 1));
 
         MutationResult result = collection.upsert(id, obj, options);


[camel] 01/02: VertxWebsocketConsumer: Remove unused private field.

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

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

commit 41de62b4fe53995bd11eee965eb996747ed7dcf2
Author: Pascal Schumacher <pa...@gmx.net>
AuthorDate: Sun Aug 16 17:12:39 2020 +0200

    VertxWebsocketConsumer: Remove unused private field.
---
 .../apache/camel/component/vertx/websocket/VertxWebsocketConsumer.java | 3 ---
 1 file changed, 3 deletions(-)

diff --git a/components/camel-vertx-websocket/src/main/java/org/apache/camel/component/vertx/websocket/VertxWebsocketConsumer.java b/components/camel-vertx-websocket/src/main/java/org/apache/camel/component/vertx/websocket/VertxWebsocketConsumer.java
index 2813ce3..674bbf8 100644
--- a/components/camel-vertx-websocket/src/main/java/org/apache/camel/component/vertx/websocket/VertxWebsocketConsumer.java
+++ b/components/camel-vertx-websocket/src/main/java/org/apache/camel/component/vertx/websocket/VertxWebsocketConsumer.java
@@ -16,8 +16,6 @@
  */
 package org.apache.camel.component.vertx.websocket;
 
-import java.util.concurrent.ConcurrentHashMap;
-
 import io.vertx.core.http.ServerWebSocket;
 import org.apache.camel.AsyncCallback;
 import org.apache.camel.Exchange;
@@ -34,7 +32,6 @@ public class VertxWebsocketConsumer extends DefaultConsumer {
     private static final Logger LOG = LoggerFactory.getLogger(VertxWebsocketConsumer.class);
 
     private final VertxWebsocketEndpoint endpoint;
-    private final ConcurrentHashMap<String, ServerWebSocket> connectedPeers = new ConcurrentHashMap();
 
     public VertxWebsocketConsumer(VertxWebsocketEndpoint endpoint, Processor processor) {
         super(endpoint, processor);