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 2016/05/17 11:28:36 UTC

[1/2] camel git commit: Added a little test case to show Connection close header scenario

Repository: camel
Updated Branches:
  refs/heads/master ab6e80713 -> 84af62540


Added a little test case to show Connection close header scenario


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

Branch: refs/heads/master
Commit: 777bd16753ec9171241604801ccf662c7ce7cf9d
Parents: ab6e807
Author: Andrea Cosentino <an...@gmail.com>
Authored: Tue May 17 13:23:12 2016 +0200
Committer: Andrea Cosentino <an...@gmail.com>
Committed: Tue May 17 13:23:12 2016 +0200

----------------------------------------------------------------------
 .../http4/HttpProducerConnectioCloseTest.java   | 103 +++++++++++++++++++
 1 file changed, 103 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/777bd167/components/camel-http4/src/test/java/org/apache/camel/component/http4/HttpProducerConnectioCloseTest.java
----------------------------------------------------------------------
diff --git a/components/camel-http4/src/test/java/org/apache/camel/component/http4/HttpProducerConnectioCloseTest.java b/components/camel-http4/src/test/java/org/apache/camel/component/http4/HttpProducerConnectioCloseTest.java
new file mode 100644
index 0000000..d5075b9
--- /dev/null
+++ b/components/camel-http4/src/test/java/org/apache/camel/component/http4/HttpProducerConnectioCloseTest.java
@@ -0,0 +1,103 @@
+/**
+ * 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 org.apache.camel.Exchange;
+import org.apache.camel.component.http4.handler.BasicValidationHandler;
+import org.apache.camel.component.mock.MockEndpoint;
+import org.apache.camel.http.common.HttpHeaderFilterStrategy;
+import org.apache.camel.impl.JndiRegistry;
+import org.apache.http.impl.bootstrap.HttpServer;
+import org.apache.http.impl.bootstrap.ServerBootstrap;
+import org.apache.http.protocol.HTTP;
+import org.junit.After;
+import org.junit.Before;
+import org.junit.Test;
+
+import org.apache.camel.EndpointInject;
+
+/**
+ * Unit test that show custom header filter useful to send Connection Close header
+ *
+ * @version 
+ */
+public class HttpProducerConnectioCloseTest extends BaseHttpTest {
+
+    private HttpServer localServer;
+    
+    @EndpointInject(uri = "mock:result")
+    protected MockEndpoint mockResultEndpoint;
+    
+    @Before
+    @Override
+    public void setUp() throws Exception {
+        localServer = ServerBootstrap.bootstrap().
+                setHttpProcessor(getBasicHttpProcessor()).
+                setConnectionReuseStrategy(getConnectionReuseStrategy()).
+                setResponseFactory(getHttpResponseFactory()).
+                setExpectationVerifier(getHttpExpectationVerifier()).
+                setSslContext(getSSLContext()).
+                registerHandler("/myget", new BasicValidationHandler("GET", null, null, getExpectedContent())).
+                create();
+        localServer.start();
+
+        super.setUp();
+    }
+
+    @After
+    @Override
+    public void tearDown() throws Exception {
+        super.tearDown();
+
+        if (localServer != null) {
+            localServer.stop();
+        }
+    }
+
+    @Test
+    public void noDataDefaultIsGet() throws Exception {
+        HttpComponent component = context.getComponent("http4", HttpComponent.class);
+        component.setConnectionTimeToLive(1000L);
+        HttpEndpoint endpoiont = (HttpEndpoint) component.createEndpoint("http4://" + localServer.getInetAddress().getHostName() + ":" + localServer.getLocalPort() + "/myget?headerFilterStrategy=#myFilter");
+        HttpProducer producer = new HttpProducer(endpoiont);
+        Exchange exchange = producer.createExchange();
+        exchange.getIn().setBody(null);
+        exchange.getIn().setHeader("connection", HTTP.CONN_CLOSE);
+        producer.start();
+        producer.process(exchange);
+        producer.stop();
+
+        assertEquals(HTTP.CONN_CLOSE, exchange.getOut().getHeader("connection"));
+        assertExchange(exchange);
+    }
+    
+    @Override
+    protected JndiRegistry createRegistry() throws Exception {
+        JndiRegistry jndi = new JndiRegistry(createJndiContext());
+        ConnectionCloseHeaderFilter connectionCloseFilterStrategy = new ConnectionCloseHeaderFilter();
+        jndi.bind("myFilter", connectionCloseFilterStrategy);
+        return jndi;
+    }
+    
+    class ConnectionCloseHeaderFilter extends HttpHeaderFilterStrategy {
+        @Override
+        protected void initialize() {
+           super.initialize();
+           getOutFilter().remove("connection");
+       }
+    }
+}
\ No newline at end of file


[2/2] camel git commit: Fixed CS

Posted by ac...@apache.org.
Fixed CS


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

Branch: refs/heads/master
Commit: 84af62540b748c3da97b16113ab4c058b0c2ea10
Parents: 777bd16
Author: Andrea Cosentino <an...@gmail.com>
Authored: Tue May 17 13:28:03 2016 +0200
Committer: Andrea Cosentino <an...@gmail.com>
Committed: Tue May 17 13:28:03 2016 +0200

----------------------------------------------------------------------
 .../http4/HttpProducerConnectioCloseTest.java       | 16 ++++++++--------
 1 file changed, 8 insertions(+), 8 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/84af6254/components/camel-http4/src/test/java/org/apache/camel/component/http4/HttpProducerConnectioCloseTest.java
----------------------------------------------------------------------
diff --git a/components/camel-http4/src/test/java/org/apache/camel/component/http4/HttpProducerConnectioCloseTest.java b/components/camel-http4/src/test/java/org/apache/camel/component/http4/HttpProducerConnectioCloseTest.java
index d5075b9..29b8c15 100644
--- a/components/camel-http4/src/test/java/org/apache/camel/component/http4/HttpProducerConnectioCloseTest.java
+++ b/components/camel-http4/src/test/java/org/apache/camel/component/http4/HttpProducerConnectioCloseTest.java
@@ -16,6 +16,7 @@
  */
 package org.apache.camel.component.http4;
 
+import org.apache.camel.EndpointInject;
 import org.apache.camel.Exchange;
 import org.apache.camel.component.http4.handler.BasicValidationHandler;
 import org.apache.camel.component.mock.MockEndpoint;
@@ -28,8 +29,6 @@ import org.junit.After;
 import org.junit.Before;
 import org.junit.Test;
 
-import org.apache.camel.EndpointInject;
-
 /**
  * Unit test that show custom header filter useful to send Connection Close header
  *
@@ -37,11 +36,11 @@ import org.apache.camel.EndpointInject;
  */
 public class HttpProducerConnectioCloseTest extends BaseHttpTest {
 
-    private HttpServer localServer;
-    
     @EndpointInject(uri = "mock:result")
     protected MockEndpoint mockResultEndpoint;
     
+    private HttpServer localServer;
+    
     @Before
     @Override
     public void setUp() throws Exception {
@@ -72,7 +71,8 @@ public class HttpProducerConnectioCloseTest extends BaseHttpTest {
     public void noDataDefaultIsGet() throws Exception {
         HttpComponent component = context.getComponent("http4", HttpComponent.class);
         component.setConnectionTimeToLive(1000L);
-        HttpEndpoint endpoiont = (HttpEndpoint) component.createEndpoint("http4://" + localServer.getInetAddress().getHostName() + ":" + localServer.getLocalPort() + "/myget?headerFilterStrategy=#myFilter");
+        HttpEndpoint endpoiont = (HttpEndpoint) component.createEndpoint("http4://" + localServer.getInetAddress().getHostName() + ":" 
+            + localServer.getLocalPort() + "/myget?headerFilterStrategy=#myFilter");
         HttpProducer producer = new HttpProducer(endpoiont);
         Exchange exchange = producer.createExchange();
         exchange.getIn().setBody(null);
@@ -96,8 +96,8 @@ public class HttpProducerConnectioCloseTest extends BaseHttpTest {
     class ConnectionCloseHeaderFilter extends HttpHeaderFilterStrategy {
         @Override
         protected void initialize() {
-           super.initialize();
-           getOutFilter().remove("connection");
-       }
+            super.initialize();
+            getOutFilter().remove("connection");
+        }
     }
 }
\ No newline at end of file