You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by on...@apache.org on 2017/07/17 05:19:04 UTC

[1/2] camel git commit: CAMEL-11524-Add quoteReplacement

Repository: camel
Updated Branches:
  refs/heads/camel-2.19.x a0a82de0e -> 9c9aa099e


CAMEL-11524-Add quoteReplacement


Project: http://git-wip-us.apache.org/repos/asf/camel/repo
Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/dc6897fc
Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/dc6897fc
Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/dc6897fc

Branch: refs/heads/camel-2.19.x
Commit: dc6897fc2df288d7fe9bad5e46458a2a7ec13fd1
Parents: a0a82de
Author: onders86 <on...@gmail.com>
Authored: Sat Jul 15 08:33:59 2017 +0300
Committer: onders86 <on...@gmail.com>
Committed: Mon Jul 17 08:11:35 2017 +0300

----------------------------------------------------------------------
 .../component/file/GenericFileEndpoint.java     |  3 +-
 .../file/FileConsumeDoneFileIssueTest.java      | 30 ++++++++++++++++++++
 2 files changed, 32 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/dc6897fc/camel-core/src/main/java/org/apache/camel/component/file/GenericFileEndpoint.java
----------------------------------------------------------------------
diff --git a/camel-core/src/main/java/org/apache/camel/component/file/GenericFileEndpoint.java b/camel-core/src/main/java/org/apache/camel/component/file/GenericFileEndpoint.java
index 0bea0ba..f60b12a 100644
--- a/camel-core/src/main/java/org/apache/camel/component/file/GenericFileEndpoint.java
+++ b/camel-core/src/main/java/org/apache/camel/component/file/GenericFileEndpoint.java
@@ -23,6 +23,7 @@ import java.util.Comparator;
 import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
+import java.util.regex.Matcher;
 import java.util.regex.Pattern;
 
 import org.apache.camel.CamelContext;
@@ -1316,7 +1317,7 @@ public abstract class GenericFileEndpoint<T> extends ScheduledPollEndpoint imple
 
         // we only support ${file:name} or ${file:name.noext} as dynamic placeholders for done files
         String path = FileUtil.onlyPath(fileName);
-        String onlyName = FileUtil.stripPath(fileName);
+        String onlyName = Matcher.quoteReplacement(FileUtil.stripPath(fileName));
 
         pattern = pattern.replaceFirst("\\$\\{file:name\\}", onlyName);
         pattern = pattern.replaceFirst("\\$simple\\{file:name\\}", onlyName);

http://git-wip-us.apache.org/repos/asf/camel/blob/dc6897fc/camel-core/src/test/java/org/apache/camel/component/file/FileConsumeDoneFileIssueTest.java
----------------------------------------------------------------------
diff --git a/camel-core/src/test/java/org/apache/camel/component/file/FileConsumeDoneFileIssueTest.java b/camel-core/src/test/java/org/apache/camel/component/file/FileConsumeDoneFileIssueTest.java
index 4f05221..19cdd08 100644
--- a/camel-core/src/test/java/org/apache/camel/component/file/FileConsumeDoneFileIssueTest.java
+++ b/camel-core/src/test/java/org/apache/camel/component/file/FileConsumeDoneFileIssueTest.java
@@ -89,6 +89,36 @@ public class FileConsumeDoneFileIssueTest extends ContextTestSupport {
         assertFalse("Done file should be deleted", new File("target/done2/c.txt.done").exists());
         
     }
+    
+    public void testFileDoneFileNameContainingDollarSign() throws Exception {
+        NotifyBuilder notify = new NotifyBuilder(context).whenDone(3).create();
+
+        template.sendBodyAndHeader("file:target/done2", "A", Exchange.FILE_NAME, "$a$.txt");
+        template.sendBodyAndHeader("file:target/done2", "B", Exchange.FILE_NAME, "$b.txt");
+        template.sendBodyAndHeader("file:target/done2", "C", Exchange.FILE_NAME, "c$.txt");
+        template.sendBodyAndHeader("file:target/done2", "a", Exchange.FILE_NAME, "$a$.txt.done");
+        template.sendBodyAndHeader("file:target/done2", "b", Exchange.FILE_NAME, "$b.txt.done");
+        template.sendBodyAndHeader("file:target/done2", "c", Exchange.FILE_NAME, "c$.txt.done");
+        
+        assertTrue("Done file should exists", new File("target/done2/$a$.txt.done").exists());
+        assertTrue("Done file should exists", new File("target/done2/$b.txt.done").exists());
+        assertTrue("Done file should exists", new File("target/done2/c$.txt.done").exists());
+
+        getMockEndpoint("mock:result").expectedBodiesReceivedInAnyOrder("A", "B", "C");
+
+        context.startRoute("bar");
+
+        assertMockEndpointsSatisfied();
+        assertTrue(notify.matchesMockWaitTime());
+
+        Thread.sleep(50);
+
+        // the done file should be deleted
+        assertFalse("Done file should be deleted", new File("target/done2/$a$.txt.done").exists());
+        assertFalse("Done file should be deleted", new File("target/done2/$b.txt.done").exists());
+        assertFalse("Done file should be deleted", new File("target/done2/c$.txt.done").exists());
+        
+    }
 
     @Override
     protected RouteBuilder createRouteBuilder() throws Exception {


[2/2] camel git commit: CAMEL-11509 - httpcomponents-core 4.4.6 ContentType.create changed. so use ContentType.parse instead

Posted by on...@apache.org.
CAMEL-11509 - httpcomponents-core 4.4.6 ContentType.create changed. so use ContentType.parse instead


Project: http://git-wip-us.apache.org/repos/asf/camel/repo
Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/9c9aa099
Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/9c9aa099
Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/9c9aa099

Branch: refs/heads/camel-2.19.x
Commit: 9c9aa099e8cf1fc99c3444cc95339073ca46d134
Parents: dc6897f
Author: onders86 <on...@gmail.com>
Authored: Wed Jul 5 15:33:27 2017 +0300
Committer: onders86 <on...@gmail.com>
Committed: Mon Jul 17 08:17:38 2017 +0300

----------------------------------------------------------------------
 .../camel/component/http4/HttpProducer.java     |   2 +-
 ...tpProducerContentTypeWithSemiColomnTest.java | 113 +++++++++++++++++++
 2 files changed, 114 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/9c9aa099/components/camel-http4/src/main/java/org/apache/camel/component/http4/HttpProducer.java
----------------------------------------------------------------------
diff --git a/components/camel-http4/src/main/java/org/apache/camel/component/http4/HttpProducer.java b/components/camel-http4/src/main/java/org/apache/camel/component/http4/HttpProducer.java
index 4c6154c..be67e73 100644
--- a/components/camel-http4/src/main/java/org/apache/camel/component/http4/HttpProducer.java
+++ b/components/camel-http4/src/main/java/org/apache/camel/component/http4/HttpProducer.java
@@ -505,7 +505,7 @@ public class HttpProducer extends DefaultProducer {
                     //it removes "boundary" from Content-Type; I have to use contentType.create method.
                     if (contentTypeString != null) {
                         // using ContentType.parser for charset
-                        if (contentTypeString.indexOf("charset") > 0) {
+                        if (contentTypeString.indexOf("charset") > 0 || contentTypeString.indexOf(";") > 0) {
                             contentType = ContentType.parse(contentTypeString);
                         } else {
                             contentType = ContentType.create(contentTypeString);

http://git-wip-us.apache.org/repos/asf/camel/blob/9c9aa099/components/camel-http4/src/test/java/org/apache/camel/component/http4/HttpProducerContentTypeWithSemiColomnTest.java
----------------------------------------------------------------------
diff --git a/components/camel-http4/src/test/java/org/apache/camel/component/http4/HttpProducerContentTypeWithSemiColomnTest.java b/components/camel-http4/src/test/java/org/apache/camel/component/http4/HttpProducerContentTypeWithSemiColomnTest.java
new file mode 100644
index 0000000..695dfc3
--- /dev/null
+++ b/components/camel-http4/src/test/java/org/apache/camel/component/http4/HttpProducerContentTypeWithSemiColomnTest.java
@@ -0,0 +1,113 @@
+/**
+ * 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.http4;
+
+import java.io.IOException;
+
+import org.apache.camel.Exchange;
+import org.apache.camel.Processor;
+import org.apache.http.HttpException;
+import org.apache.http.HttpRequest;
+import org.apache.http.HttpResponse;
+import org.apache.http.HttpStatus;
+import org.apache.http.entity.StringEntity;
+import org.apache.http.impl.bootstrap.HttpServer;
+import org.apache.http.impl.bootstrap.ServerBootstrap;
+import org.apache.http.protocol.HttpContext;
+import org.apache.http.protocol.HttpRequestHandler;
+import org.junit.After;
+import org.junit.Before;
+import org.junit.Test;
+
+public class HttpProducerContentTypeWithSemiColomnTest extends BaseHttpTest {
+
+    private static final String CONTENT_TYPE = "multipart/form-data;boundary=---------------------------j2radvtrk";
+    
+    private HttpServer localServer;
+    
+    @Before
+    @Override
+    public void setUp() throws Exception {
+        localServer = ServerBootstrap.bootstrap().
+                setHttpProcessor(getBasicHttpProcessor()).
+                setConnectionReuseStrategy(getConnectionReuseStrategy()).
+                setResponseFactory(getHttpResponseFactory()).
+                setExpectationVerifier(getHttpExpectationVerifier()).
+                setSslContext(getSSLContext()).
+                registerHandler("/content", new HttpRequestHandler() {
+                    @Override
+                    public void handle(HttpRequest request, HttpResponse response, HttpContext context) throws HttpException, IOException {
+                        String contentType = request.getFirstHeader(Exchange.CONTENT_TYPE).getValue();
+                        
+                        assertEquals(CONTENT_TYPE.replace(";", "; "), contentType);
+
+                        response.setEntity(new StringEntity(contentType, "ASCII"));
+                        response.setStatusCode(HttpStatus.SC_OK);
+                    }
+                }).create();
+        localServer.start();
+
+        super.setUp();
+    }
+
+    @After
+    @Override
+    public void tearDown() throws Exception {
+        super.tearDown();
+
+        if (localServer != null) {
+            localServer.stop();
+        }
+    }
+    
+    @Test
+    public void testContentTypeWithBoundary() throws Exception {
+        Exchange out = template.request("http4://" + localServer.getInetAddress().getHostName() + ":" + localServer.getLocalPort() + "/content", new Processor() {
+
+            @Override
+            public void process(Exchange exchange) throws Exception {
+                exchange.getIn().setHeader(Exchange.CONTENT_TYPE, CONTENT_TYPE);
+                exchange.getIn().setBody("This is content");
+            }
+            
+        });
+
+        assertNotNull(out);
+        assertFalse("Should not fail", out.isFailed());
+        assertEquals(CONTENT_TYPE.replace(";", "; "), out.getOut().getBody(String.class));
+        
+    }
+    
+    @Test
+    public void testContentTypeWithBoundaryWithIgnoreResponseBody() throws Exception {
+        Exchange out = template.request("http4://" + localServer.getInetAddress().getHostName() + ":" + localServer.getLocalPort() + "/content?ignoreResponseBody=true", new Processor() {
+
+            @Override
+            public void process(Exchange exchange) throws Exception {
+                exchange.getIn().setHeader(Exchange.CONTENT_TYPE, CONTENT_TYPE);
+                exchange.getIn().setBody("This is content");
+            }
+            
+        });
+
+        assertNotNull(out);
+        assertFalse("Should not fail", out.isFailed());
+        assertNull(out.getOut().getBody());
+        
+    }
+}
\ No newline at end of file