You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by da...@apache.org on 2019/11/11 13:48:59 UTC

[camel] branch master updated: CAMEL-14167: camel-stream - Remove url support

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

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


The following commit(s) were added to refs/heads/master by this push:
     new 726e9dd  CAMEL-14167: camel-stream - Remove url support
726e9dd is described below

commit 726e9dd0d5a21a7caa1bba3ade39a6bb51c1871d
Author: Claus Ibsen <cl...@gmail.com>
AuthorDate: Mon Nov 11 14:48:25 2019 +0100

    CAMEL-14167: camel-stream - Remove url support
---
 components/camel-stream/pom.xml                    |   5 -
 .../src/main/docs/stream-component.adoc            |  18 +-
 .../camel/component/stream/StreamComponent.java    |   7 -
 .../camel/component/stream/StreamConsumer.java     |  24 ---
 .../camel/component/stream/StreamEndpoint.java     |  49 +----
 .../camel/component/stream/StreamProducer.java     |  40 +---
 .../component/stream/StreamToUrlJettyTest.java     |  53 -----
 .../camel/component/stream/StreamToUrlTest.java    |  74 -------
 .../endpoint/dsl/StreamEndpointBuilderFactory.java | 221 +--------------------
 .../springboot/StreamComponentConfiguration.java   |   2 +-
 10 files changed, 11 insertions(+), 482 deletions(-)

diff --git a/components/camel-stream/pom.xml b/components/camel-stream/pom.xml
index 1a4ecf0..b1a967a 100644
--- a/components/camel-stream/pom.xml
+++ b/components/camel-stream/pom.xml
@@ -69,11 +69,6 @@
             <artifactId>junit</artifactId>
             <scope>test</scope>
         </dependency>
-        <dependency>
-            <groupId>org.apache.camel</groupId>
-            <artifactId>camel-jetty</artifactId>
-            <scope>test</scope>
-        </dependency>
 
     </dependencies>
 
diff --git a/components/camel-stream/src/main/docs/stream-component.adoc b/components/camel-stream/src/main/docs/stream-component.adoc
index 0891083..d6e6642 100644
--- a/components/camel-stream/src/main/docs/stream-component.adoc
+++ b/components/camel-stream/src/main/docs/stream-component.adoc
@@ -4,7 +4,7 @@
 *Since Camel 1.3*
 
 The Stream component provides access to the `System.in`, `System.out`
-and `System.err` streams as well as allowing streaming of file and URL.
+and `System.err` streams as well as allowing streaming of file.
 
 Maven users will need to add the following dependency to their `pom.xml`
 for this component:
@@ -21,21 +21,14 @@ for this component:
 
 == URI format
 
-[source,java]
+[source,text]
 -----------------------
 stream:in[?options]
 stream:out[?options]
 stream:err[?options]
 stream:header[?options]
------------------------
-
-In addition, the `file` and `url` endpoint URIs are supported:
-
-[source,java]
----------------------------------
 stream:file?fileName=/foo/bar.txt
-stream:url[?options]
----------------------------------
+-----------------------
 
 If the `stream:header` URI is specified, the `stream` header is used to
 find the stream to write to. This option is available only for stream
@@ -80,7 +73,7 @@ with the following path and query parameters:
 |===
 
 
-=== Query Parameters (24 parameters):
+=== Query Parameters (21 parameters):
 
 
 [width="100%",cols="2,5,^1,2",options="header"]
@@ -88,7 +81,6 @@ with the following path and query parameters:
 | Name | Description | Default | Type
 | *encoding* (common) | You can configure the encoding (is a charset name) to use text-based streams (for example, message body is a String object). If not provided, Camel uses the JVM default Charset. |  | String
 | *fileName* (common) | When using the stream:file URI format, this option specifies the filename to stream to/from. |  | String
-| *url* (common) | When using the stream:url URI format, this option specifies the URL to stream to/from. The input/output stream will be opened using the JDK URLConnection facility. |  | String
 | *bridgeErrorHandler* (consumer) | Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by the routing Error Handler. By default the consumer will use the org.apache.camel.spi.ExceptionHandler to deal with exceptions, that will be logged at WARN or ERROR level and ignored. | false | boolean
 | *fileWatcher* (consumer) | To use JVM file watcher to listen for file change events to support re-loading files that may be overwritten, somewhat like tail --retry | false | boolean
 | *groupLines* (consumer) | To group X number of lines in the consumer. For example to group 10 lines and therefore only spit out an Exchange with 10 lines, instead of 1 Exchange per line. |  | int
@@ -106,8 +98,6 @@ with the following path and query parameters:
 | *delay* (producer) | Initial delay in milliseconds before producing the stream. |  | long
 | *lazyStartProducer* (producer) | Whether the producer should be started lazy (on the first message). By starting lazy you can use this to allow CamelContext and routes to startup in situations where a producer may otherwise fail during starting and cause the route to fail being started. By deferring this startup to be lazy then the startup failure can be handled during routing messages via Camel's routing error handlers. Beware that when the first message is processed then creating and [...]
 | *basicPropertyBinding* (advanced) | Whether the endpoint should use basic property binding (Camel 2.x) or the newer property binding with additional capabilities | false | boolean
-| *connectTimeout* (advanced) | Sets a specified timeout value, in milliseconds, to be used when opening a communications link to the resource referenced by this URLConnection. If the timeout expires before the connection can be established, a java.net.SocketTimeoutException is raised. A timeout of zero is interpreted as an infinite timeout. |  | int
-| *httpHeaders* (advanced) | Optional http headers to use in request when using HTTP URL. |  | Map
 | *readTimeout* (advanced) | Sets the read timeout to a specified timeout, in milliseconds. A non-zero value specifies the timeout when reading from Input stream when a connection is established to a resource. If the timeout expires before there is data available for read, a java.net.SocketTimeoutException is raised. A timeout of zero is interpreted as an infinite timeout. |  | int
 | *synchronous* (advanced) | Sets whether synchronous processing should be strictly used, or Camel is allowed to use asynchronous processing (if supported). | false | boolean
 |===
diff --git a/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamComponent.java b/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamComponent.java
index 8c0d070..2ab7f80 100644
--- a/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamComponent.java
+++ b/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamComponent.java
@@ -21,7 +21,6 @@ import java.util.Map;
 import org.apache.camel.Endpoint;
 import org.apache.camel.spi.annotations.Component;
 import org.apache.camel.support.DefaultComponent;
-import org.apache.camel.util.URISupport;
 
 /**
  * Component providing streams connectivity
@@ -35,12 +34,6 @@ public class StreamComponent extends DefaultComponent {
     @Override
     protected Endpoint createEndpoint(String uri, String remaining, Map<String, Object> parameters) throws Exception {
         StreamEndpoint answer = new StreamEndpoint(uri, this);
-
-        Map<String, Object> httpHeaders = URISupport.extractProperties(parameters, "httpHeaders.");
-        if (!httpHeaders.isEmpty()) {
-            answer.setHttpHeaders(httpHeaders);
-        }
-
         answer.setKind(remaining);
         setProperties(answer, parameters);
         return answer;
diff --git a/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamConsumer.java b/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamConsumer.java
index 58db8f4..c29bf8f 100644
--- a/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamConsumer.java
+++ b/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamConsumer.java
@@ -22,8 +22,6 @@ import java.io.FileInputStream;
 import java.io.IOException;
 import java.io.InputStream;
 import java.io.InputStreamReader;
-import java.net.URL;
-import java.net.URLConnection;
 import java.nio.charset.Charset;
 import java.util.ArrayList;
 import java.util.Arrays;
@@ -133,9 +131,6 @@ public class StreamConsumer extends DefaultConsumer implements Runnable {
         } else if ("file".equals(uri)) {
             inputStream = resolveStreamFromFile();
             inputStreamToClose = inputStream;
-        } else if ("url".equals(uri)) {
-            inputStream = resolveStreamFromUrl();
-            inputStreamToClose = inputStream;
         }
 
         if (inputStream != null) {
@@ -287,25 +282,6 @@ public class StreamConsumer extends DefaultConsumer implements Runnable {
         }
     }
 
-    private InputStream resolveStreamFromUrl() throws IOException {
-        String u = endpoint.getUrl();
-        StringHelper.notEmpty(u, "url");
-        log.debug("About to read from url: {}", u);
-
-        URL url = new URL(u);
-        URLConnection c = url.openConnection();
-        if (endpoint.getConnectTimeout() > 0) {
-            c.setConnectTimeout(endpoint.getConnectTimeout());
-        }
-        if (endpoint.getReadTimeout() > 0) {
-            c.setReadTimeout(endpoint.getReadTimeout());
-        }
-        if (endpoint.getHttpHeaders() != null) {
-            endpoint.getHttpHeaders().forEach((k, v) -> c.addRequestProperty(k, v.toString()));
-        }
-        return c.getInputStream();
-    }
-
     private InputStream resolveStreamFromFile() throws IOException {
         String fileName = endpoint.getFileName();
         StringHelper.notEmpty(fileName, "fileName");
diff --git a/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamEndpoint.java b/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamEndpoint.java
index 7ebeca0..533859e 100644
--- a/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamEndpoint.java
+++ b/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamEndpoint.java
@@ -31,18 +31,16 @@ import org.apache.camel.spi.UriPath;
 import org.apache.camel.support.DefaultEndpoint;
 
 /**
- * The stream: component provides access to the system-in, system-out and system-err streams as well as allowing streaming of file and URL.
+ * The stream: component provides access to the system-in, system-out and system-err streams as well as allowing streaming of file.
  */
 @UriEndpoint(firstVersion = "1.3.0", scheme = "stream", title = "Stream", syntax = "stream:kind", label = "file,system")
 public class StreamEndpoint extends DefaultEndpoint {
 
     private transient Charset charset;
 
-    @UriPath(enums = "in,out,err,header,file,url") @Metadata(required = true)
+    @UriPath(enums = "in,out,err,header,file") @Metadata(required = true)
     private String kind;
     @UriParam
-    private String url;
-    @UriParam
     private String fileName;
     @UriParam(label = "consumer")
     private boolean scanStream;
@@ -70,10 +68,6 @@ public class StreamEndpoint extends DefaultEndpoint {
     private int autoCloseCount;
     @UriParam(label = "consumer")
     private GroupStrategy groupStrategy = new DefaultGroupStrategy();
-    @UriParam(label = "advanced", prefix = "httpHeaders.", multiValue = true)
-    private Map<String, Object> httpHeaders;
-    @UriParam(label = "advanced")
-    private int connectTimeout;
     @UriParam(label = "advanced")
     private int readTimeout;
 
@@ -130,18 +124,6 @@ public class StreamEndpoint extends DefaultEndpoint {
         this.fileName = fileName;
     }
 
-    public String getUrl() {
-        return url;
-    }
-
-    /**
-     * When using the stream:url URI format, this option specifies the URL to stream to/from.
-     * The input/output stream will be opened using the JDK URLConnection facility.
-     */
-    public void setUrl(String url) {
-        this.url = url;
-    }
-
     public long getDelay() {
         return delay;
     }
@@ -297,33 +279,6 @@ public class StreamEndpoint extends DefaultEndpoint {
         return charset;
     }
 
-    public Map<String, Object> getHttpHeaders() {
-        return httpHeaders;
-    }
-
-    /**
-     * Optional http headers to use in request when using HTTP URL.
-     */
-    public void setHttpHeaders(Map<String, Object> httpHeaders) {
-        this.httpHeaders = httpHeaders;
-    }
-
-    public int getConnectTimeout() {
-        return connectTimeout;
-    }
-
-    /**
-     * Sets a specified timeout value, in milliseconds, to be used
-     * when opening a communications link to the resource referenced
-     * by this URLConnection.  If the timeout expires before the
-     * connection can be established, a
-     * java.net.SocketTimeoutException is raised. A timeout of zero is
-     * interpreted as an infinite timeout.
-     */
-    public void setConnectTimeout(int connectTimeout) {
-        this.connectTimeout = connectTimeout;
-    }
-
     public int getReadTimeout() {
         return readTimeout;
     }
diff --git a/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamProducer.java b/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamProducer.java
index 2693eb1..2e8066b 100644
--- a/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamProducer.java
+++ b/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamProducer.java
@@ -20,12 +20,9 @@ import java.io.BufferedWriter;
 import java.io.File;
 import java.io.FileOutputStream;
 import java.io.IOException;
-import java.io.InputStream;
 import java.io.OutputStream;
 import java.io.OutputStreamWriter;
 import java.io.Writer;
-import java.net.URL;
-import java.net.URLConnection;
 import java.nio.charset.Charset;
 import java.util.Arrays;
 import java.util.List;
@@ -48,8 +45,7 @@ public class StreamProducer extends DefaultProducer {
     private StreamEndpoint endpoint;
     private String uri;
     private OutputStream outputStream;
-    private URLConnection urlConnection;
-    private AtomicInteger count = new AtomicInteger();
+    private final AtomicInteger count = new AtomicInteger();
 
     public StreamProducer(StreamEndpoint endpoint, String uri) throws Exception {
         super(endpoint);
@@ -82,26 +78,6 @@ public class StreamProducer extends DefaultProducer {
         }
     }
 
-    private OutputStream resolveStreamFromUrl() throws IOException {
-        String u = endpoint.getUrl();
-        StringHelper.notEmpty(u, "url");
-        log.debug("About to write to url: {}", u);
-
-        URL url = new URL(u);
-        urlConnection = url.openConnection();
-        urlConnection.setDoOutput(true);
-        if (endpoint.getConnectTimeout() > 0) {
-            urlConnection.setConnectTimeout(endpoint.getConnectTimeout());
-        }
-        if (endpoint.getReadTimeout() > 0) {
-            urlConnection.setReadTimeout(endpoint.getReadTimeout());
-        }
-        if (endpoint.getHttpHeaders() != null) {
-            endpoint.getHttpHeaders().forEach((k, v) -> urlConnection.addRequestProperty(k, v.toString()));
-        }
-        return urlConnection.getOutputStream();
-    }
-
     private OutputStream resolveStreamFromFile() throws IOException {
         String fileName = endpoint.getFileName();
         StringHelper.notEmpty(fileName, "fileName");
@@ -167,8 +143,6 @@ public class StreamProducer extends DefaultProducer {
             outputStream = System.err;
         } else if ("file".equals(uri)) {
             outputStream = resolveStreamFromFile();
-        } else if ("url".equals(uri)) {
-            outputStream = resolveStreamFromUrl();
         }
         count.set(outputStream == null ? 0 : endpoint.getAutoCloseCount());
         log.debug("Opened stream '{}'", endpoint.getEndpointKey());
@@ -205,20 +179,8 @@ public class StreamProducer extends DefaultProducer {
 
         // never ever close a system stream
         if (!systemStream && expiredStream) {
-
-            if (urlConnection != null) {
-                // force a flush as it may first send data over the wire when we are done
-                try {
-                    InputStream is = urlConnection.getInputStream();
-                    IOHelper.close(is);
-                } catch (Throwable e) {
-                    // ignore
-                }
-            }
-
             outputStream.close();
             outputStream = null;
-            urlConnection = null;
             log.debug("Closed stream '{}'", endpoint.getEndpointKey());
         }
     }
diff --git a/components/camel-stream/src/test/java/org/apache/camel/component/stream/StreamToUrlJettyTest.java b/components/camel-stream/src/test/java/org/apache/camel/component/stream/StreamToUrlJettyTest.java
deleted file mode 100644
index 834d54d..0000000
--- a/components/camel-stream/src/test/java/org/apache/camel/component/stream/StreamToUrlJettyTest.java
+++ /dev/null
@@ -1,53 +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.component.stream;
-
-import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.test.junit4.CamelTestSupport;
-import org.junit.Test;
-
-/**
- * Unit test for producer writing to URL.
- */
-public class StreamToUrlJettyTest extends CamelTestSupport {
-
-    @Override
-    protected RouteBuilder createRouteBuilder() {
-        return new RouteBuilder() {
-            public void configure() {
-                from("direct:start")
-                        // just send one message at a time
-                        .to("stream:url?autoCloseCount=1&url=http://localhost:8080/foo&httpHeaders.content-type=text/plain");
-
-                from("jetty:http://localhost:8080/foo")
-                    .log("Jetty foo")
-                    .to("mock:foo");
-            }
-        };
-    }
-
-    @Test
-    public void shouldSendToUrlOutputStream() throws Exception {
-        getMockEndpoint("mock:foo").expectedBodiesReceived("Hello" + System.lineSeparator(), "World" + System.lineSeparator());
-
-        template.sendBody("direct:start", "Hello");
-        template.sendBody("direct:start", "World");
-
-        assertMockEndpointsSatisfied();
-    }
-
-}
diff --git a/components/camel-stream/src/test/java/org/apache/camel/component/stream/StreamToUrlTest.java b/components/camel-stream/src/test/java/org/apache/camel/component/stream/StreamToUrlTest.java
deleted file mode 100644
index 1d206fe..0000000
--- a/components/camel-stream/src/test/java/org/apache/camel/component/stream/StreamToUrlTest.java
+++ /dev/null
@@ -1,74 +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.component.stream;
-import java.io.ByteArrayOutputStream;
-
-import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.stream.mock.MockURLConnection;
-import org.apache.camel.test.junit4.CamelTestSupport;
-import org.junit.After;
-import org.junit.Test;
-
-/**
- * Unit test for producer writing to URL.
- */
-public class StreamToUrlTest extends CamelTestSupport {
-
-    ByteArrayOutputStream buffer = new ByteArrayOutputStream();
-
-    String message = "message";
-
-    String existingHandlers = System.getProperty("java.protocol.handler.pkgs");
-
-    @Override
-    protected void doPreSetup() throws Exception {
-        System.setProperty("java.protocol.handler.pkgs", getClass().getPackage().getName());
-        MockURLConnection.setOutputStream(buffer);
-    }
-
-    @Override
-    @After
-    public void tearDown() throws Exception {
-        if (existingHandlers != null) {
-            System.setProperty("java.protocol.handler.pkgs", existingHandlers);
-        }
-        super.tearDown();
-    }
-
-    @Override
-    protected RouteBuilder createRouteBuilder() {
-        return new RouteBuilder() {
-            public void configure() {
-                from("direct:start").to("stream:url?url=mock:&httpHeaders.foo=123&httpHeaders.bar=yes");
-            }
-        };
-    }
-
-    @Test
-    public void shouldSendToUrlOutputStream() throws Exception {
-        // When
-        template.sendBody("direct:start", message);
-
-        // Then
-        String messageReceived = new String(buffer.toByteArray()).trim();
-        assertEquals(message, messageReceived);
-
-        assertEquals("123", MockURLConnection.getHeaders().get("foo"));
-        assertEquals("yes", MockURLConnection.getHeaders().get("bar"));
-    }
-
-}
diff --git a/core/camel-endpointdsl/src/main/java/org/apache/camel/builder/endpoint/dsl/StreamEndpointBuilderFactory.java b/core/camel-endpointdsl/src/main/java/org/apache/camel/builder/endpoint/dsl/StreamEndpointBuilderFactory.java
index 67a6f0c..9ca6019 100644
--- a/core/camel-endpointdsl/src/main/java/org/apache/camel/builder/endpoint/dsl/StreamEndpointBuilderFactory.java
+++ b/core/camel-endpointdsl/src/main/java/org/apache/camel/builder/endpoint/dsl/StreamEndpointBuilderFactory.java
@@ -16,7 +16,6 @@
  */
 package org.apache.camel.builder.endpoint.dsl;
 
-import java.util.Map;
 import javax.annotation.Generated;
 import org.apache.camel.ExchangePattern;
 import org.apache.camel.builder.EndpointConsumerBuilder;
@@ -26,7 +25,7 @@ import org.apache.camel.spi.ExceptionHandler;
 
 /**
  * The stream: component provides access to the system-in, system-out and
- * system-err streams as well as allowing streaming of file and URL.
+ * system-err streams as well as allowing streaming of file.
  * 
  * Generated by camel-package-maven-plugin - do not edit this file!
  */
@@ -69,19 +68,6 @@ public interface StreamEndpointBuilderFactory {
             return this;
         }
         /**
-         * When using the stream:url URI format, this option specifies the URL
-         * to stream to/from. The input/output stream will be opened using the
-         * JDK URLConnection facility.
-         * 
-         * The option is a: <code>java.lang.String</code> type.
-         * 
-         * Group: common
-         */
-        default StreamEndpointConsumerBuilder url(String url) {
-            doSetProperty("url", url);
-            return this;
-        }
-        /**
          * Allows for bridging the consumer to the Camel routing Error Handler,
          * which mean any exceptions occurred while the consumer is trying to
          * pickup incoming messages, or the likes, will now be processed as a
@@ -424,65 +410,6 @@ public interface StreamEndpointBuilderFactory {
             return this;
         }
         /**
-         * Sets a specified timeout value, in milliseconds, to be used when
-         * opening a communications link to the resource referenced by this
-         * URLConnection. If the timeout expires before the connection can be
-         * established, a java.net.SocketTimeoutException is raised. A timeout
-         * of zero is interpreted as an infinite timeout.
-         * 
-         * The option is a: <code>int</code> type.
-         * 
-         * Group: advanced
-         */
-        default AdvancedStreamEndpointConsumerBuilder connectTimeout(
-                int connectTimeout) {
-            doSetProperty("connectTimeout", connectTimeout);
-            return this;
-        }
-        /**
-         * Sets a specified timeout value, in milliseconds, to be used when
-         * opening a communications link to the resource referenced by this
-         * URLConnection. If the timeout expires before the connection can be
-         * established, a java.net.SocketTimeoutException is raised. A timeout
-         * of zero is interpreted as an infinite timeout.
-         * 
-         * The option will be converted to a <code>int</code> type.
-         * 
-         * Group: advanced
-         */
-        default AdvancedStreamEndpointConsumerBuilder connectTimeout(
-                String connectTimeout) {
-            doSetProperty("connectTimeout", connectTimeout);
-            return this;
-        }
-        /**
-         * Optional http headers to use in request when using HTTP URL.
-         * 
-         * The option is a: <code>java.util.Map&lt;java.lang.String,
-         * java.lang.Object&gt;</code> type.
-         * 
-         * Group: advanced
-         */
-        default AdvancedStreamEndpointConsumerBuilder httpHeaders(
-                Map<String, Object> httpHeaders) {
-            doSetProperty("httpHeaders", httpHeaders);
-            return this;
-        }
-        /**
-         * Optional http headers to use in request when using HTTP URL.
-         * 
-         * The option will be converted to a
-         * <code>java.util.Map&lt;java.lang.String, java.lang.Object&gt;</code>
-         * type.
-         * 
-         * Group: advanced
-         */
-        default AdvancedStreamEndpointConsumerBuilder httpHeaders(
-                String httpHeaders) {
-            doSetProperty("httpHeaders", httpHeaders);
-            return this;
-        }
-        /**
          * Sets the read timeout to a specified timeout, in milliseconds. A
          * non-zero value specifies the timeout when reading from Input stream
          * when a connection is established to a resource. If the timeout
@@ -579,19 +506,6 @@ public interface StreamEndpointBuilderFactory {
             return this;
         }
         /**
-         * When using the stream:url URI format, this option specifies the URL
-         * to stream to/from. The input/output stream will be opened using the
-         * JDK URLConnection facility.
-         * 
-         * The option is a: <code>java.lang.String</code> type.
-         * 
-         * Group: common
-         */
-        default StreamEndpointProducerBuilder url(String url) {
-            doSetProperty("url", url);
-            return this;
-        }
-        /**
          * Number of messages to process before closing stream on Producer side.
          * Never close stream by default (only when Producer is stopped). If
          * more messages are sent, the stream is reopened for another
@@ -748,65 +662,6 @@ public interface StreamEndpointBuilderFactory {
             return this;
         }
         /**
-         * Sets a specified timeout value, in milliseconds, to be used when
-         * opening a communications link to the resource referenced by this
-         * URLConnection. If the timeout expires before the connection can be
-         * established, a java.net.SocketTimeoutException is raised. A timeout
-         * of zero is interpreted as an infinite timeout.
-         * 
-         * The option is a: <code>int</code> type.
-         * 
-         * Group: advanced
-         */
-        default AdvancedStreamEndpointProducerBuilder connectTimeout(
-                int connectTimeout) {
-            doSetProperty("connectTimeout", connectTimeout);
-            return this;
-        }
-        /**
-         * Sets a specified timeout value, in milliseconds, to be used when
-         * opening a communications link to the resource referenced by this
-         * URLConnection. If the timeout expires before the connection can be
-         * established, a java.net.SocketTimeoutException is raised. A timeout
-         * of zero is interpreted as an infinite timeout.
-         * 
-         * The option will be converted to a <code>int</code> type.
-         * 
-         * Group: advanced
-         */
-        default AdvancedStreamEndpointProducerBuilder connectTimeout(
-                String connectTimeout) {
-            doSetProperty("connectTimeout", connectTimeout);
-            return this;
-        }
-        /**
-         * Optional http headers to use in request when using HTTP URL.
-         * 
-         * The option is a: <code>java.util.Map&lt;java.lang.String,
-         * java.lang.Object&gt;</code> type.
-         * 
-         * Group: advanced
-         */
-        default AdvancedStreamEndpointProducerBuilder httpHeaders(
-                Map<String, Object> httpHeaders) {
-            doSetProperty("httpHeaders", httpHeaders);
-            return this;
-        }
-        /**
-         * Optional http headers to use in request when using HTTP URL.
-         * 
-         * The option will be converted to a
-         * <code>java.util.Map&lt;java.lang.String, java.lang.Object&gt;</code>
-         * type.
-         * 
-         * Group: advanced
-         */
-        default AdvancedStreamEndpointProducerBuilder httpHeaders(
-                String httpHeaders) {
-            doSetProperty("httpHeaders", httpHeaders);
-            return this;
-        }
-        /**
          * Sets the read timeout to a specified timeout, in milliseconds. A
          * non-zero value specifies the timeout when reading from Input stream
          * when a connection is established to a resource. If the timeout
@@ -902,19 +757,6 @@ public interface StreamEndpointBuilderFactory {
             doSetProperty("fileName", fileName);
             return this;
         }
-        /**
-         * When using the stream:url URI format, this option specifies the URL
-         * to stream to/from. The input/output stream will be opened using the
-         * JDK URLConnection facility.
-         * 
-         * The option is a: <code>java.lang.String</code> type.
-         * 
-         * Group: common
-         */
-        default StreamEndpointBuilder url(String url) {
-            doSetProperty("url", url);
-            return this;
-        }
     }
 
     /**
@@ -953,63 +795,6 @@ public interface StreamEndpointBuilderFactory {
             return this;
         }
         /**
-         * Sets a specified timeout value, in milliseconds, to be used when
-         * opening a communications link to the resource referenced by this
-         * URLConnection. If the timeout expires before the connection can be
-         * established, a java.net.SocketTimeoutException is raised. A timeout
-         * of zero is interpreted as an infinite timeout.
-         * 
-         * The option is a: <code>int</code> type.
-         * 
-         * Group: advanced
-         */
-        default AdvancedStreamEndpointBuilder connectTimeout(int connectTimeout) {
-            doSetProperty("connectTimeout", connectTimeout);
-            return this;
-        }
-        /**
-         * Sets a specified timeout value, in milliseconds, to be used when
-         * opening a communications link to the resource referenced by this
-         * URLConnection. If the timeout expires before the connection can be
-         * established, a java.net.SocketTimeoutException is raised. A timeout
-         * of zero is interpreted as an infinite timeout.
-         * 
-         * The option will be converted to a <code>int</code> type.
-         * 
-         * Group: advanced
-         */
-        default AdvancedStreamEndpointBuilder connectTimeout(
-                String connectTimeout) {
-            doSetProperty("connectTimeout", connectTimeout);
-            return this;
-        }
-        /**
-         * Optional http headers to use in request when using HTTP URL.
-         * 
-         * The option is a: <code>java.util.Map&lt;java.lang.String,
-         * java.lang.Object&gt;</code> type.
-         * 
-         * Group: advanced
-         */
-        default AdvancedStreamEndpointBuilder httpHeaders(
-                Map<String, Object> httpHeaders) {
-            doSetProperty("httpHeaders", httpHeaders);
-            return this;
-        }
-        /**
-         * Optional http headers to use in request when using HTTP URL.
-         * 
-         * The option will be converted to a
-         * <code>java.util.Map&lt;java.lang.String, java.lang.Object&gt;</code>
-         * type.
-         * 
-         * Group: advanced
-         */
-        default AdvancedStreamEndpointBuilder httpHeaders(String httpHeaders) {
-            doSetProperty("httpHeaders", httpHeaders);
-            return this;
-        }
-        /**
          * Sets the read timeout to a specified timeout, in milliseconds. A
          * non-zero value specifies the timeout when reading from Input stream
          * when a connection is established to a resource. If the timeout
@@ -1069,7 +854,7 @@ public interface StreamEndpointBuilderFactory {
     /**
      * Stream (camel-stream)
      * The stream: component provides access to the system-in, system-out and
-     * system-err streams as well as allowing streaming of file and URL.
+     * system-err streams as well as allowing streaming of file.
      * 
      * Category: file,system
      * Available as of version: 1.3
@@ -1079,7 +864,7 @@ public interface StreamEndpointBuilderFactory {
      * 
      * Path parameter: kind (required)
      * Kind of stream to use such as System.in or System.out.
-     * The value can be one of: in, out, err, header, file, url
+     * The value can be one of: in, out, err, header, file
      */
     default StreamEndpointBuilder stream(String path) {
         class StreamEndpointBuilderImpl extends AbstractEndpointBuilder implements StreamEndpointBuilder, AdvancedStreamEndpointBuilder {
diff --git a/platforms/spring-boot/components-starter/camel-stream-starter/src/main/java/org/apache/camel/component/stream/springboot/StreamComponentConfiguration.java b/platforms/spring-boot/components-starter/camel-stream-starter/src/main/java/org/apache/camel/component/stream/springboot/StreamComponentConfiguration.java
index d460d63..ae221d8 100644
--- a/platforms/spring-boot/components-starter/camel-stream-starter/src/main/java/org/apache/camel/component/stream/springboot/StreamComponentConfiguration.java
+++ b/platforms/spring-boot/components-starter/camel-stream-starter/src/main/java/org/apache/camel/component/stream/springboot/StreamComponentConfiguration.java
@@ -22,7 +22,7 @@ import org.springframework.boot.context.properties.ConfigurationProperties;
 
 /**
  * The stream: component provides access to the system-in, system-out and
- * system-err streams as well as allowing streaming of file and URL.
+ * system-err streams as well as allowing streaming of file.
  * 
  * Generated by camel-package-maven-plugin - do not edit this file!
  */