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 2010/02/23 13:46:55 UTC

svn commit: r915312 - in /camel/trunk/components/camel-http/src: main/java/org/apache/camel/component/http/HttpComponent.java test/java/org/apache/camel/component/http/HttpConcurrentTest.java

Author: davsclaus
Date: Tue Feb 23 12:46:55 2010
New Revision: 915312

URL: http://svn.apache.org/viewvc?rev=915312&view=rev
Log:
CAMEL-1530: Polished the logging a bit and added concurrent test.

Added:
    camel/trunk/components/camel-http/src/test/java/org/apache/camel/component/http/HttpConcurrentTest.java   (with props)
Modified:
    camel/trunk/components/camel-http/src/main/java/org/apache/camel/component/http/HttpComponent.java

Modified: camel/trunk/components/camel-http/src/main/java/org/apache/camel/component/http/HttpComponent.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-http/src/main/java/org/apache/camel/component/http/HttpComponent.java?rev=915312&r1=915311&r2=915312&view=diff
==============================================================================
--- camel/trunk/components/camel-http/src/main/java/org/apache/camel/component/http/HttpComponent.java (original)
+++ camel/trunk/components/camel-http/src/main/java/org/apache/camel/component/http/HttpComponent.java Tue Feb 23 12:46:55 2010
@@ -157,10 +157,10 @@
         // create default connection manager if none provided
         if (httpConnectionManager == null) {
             httpConnectionManager = createConnectionManager(clientParams, uri);
+        } else if (LOG.isDebugEnabled()) {
+            LOG.debug("Using existing ClientConnectionManager: " + httpConnectionManager);
         }
 
-        LOG.info("Using ClientConnectionManager: " + httpConnectionManager);
-
         HttpEndpoint endpoint = new HttpEndpoint(uri, this, httpUri, clientParams, httpConnectionManager, httpClientConfigurer);
         if (httpBinding != null) {
             endpoint.setBinding(httpBinding);
@@ -180,9 +180,6 @@
     }
 
     protected ClientConnectionManager createConnectionManager(HttpParams clientParams, String uri) {
-        StringBuilder sb = new StringBuilder("Created ClientConnectionManager configured with");
-        ThreadSafeClientConnManager answer;
-
         SchemeRegistry schemeRegistry = new SchemeRegistry();
         if (isSecureConnection(uri)) {
             schemeRegistry.register(new Scheme("https", SSLSocketFactory.getSocketFactory(), 443));
@@ -190,27 +187,19 @@
             schemeRegistry.register(new Scheme("http", PlainSocketFactory.getSocketFactory(), 80));
         }
 
-        answer = new ThreadSafeClientConnManager(clientParams, schemeRegistry);
-
         // configure additional configurations
         ConnManagerParamBean param = new ConnManagerParamBean(clientParams);
         if (getMaxTotalConnections() > 0) {
-            sb.append(" maxTotalConnections=" + getMaxTotalConnections());
             param.setMaxTotalConnections(getMaxTotalConnections());
         }
         if (getConnectionsPerRoute() > 0) {
-            sb.append(" connectionsPerRoute=" + getConnectionsPerRoute());
             param.setConnectionsPerRoute(new ConnPerRouteBean(getConnectionsPerRoute()));
         }
 
-        // log information about the created connection manager
-        if (LOG.isDebugEnabled()) {
-            String msg = sb.toString();
-            if (msg.endsWith("with")) {
-                msg += " default values";
-            }
-            LOG.debug(msg + ": " + answer);
-        }
+        ThreadSafeClientConnManager answer;
+        answer = new ThreadSafeClientConnManager(clientParams, schemeRegistry);
+
+        LOG.info("Created ClientConnectionManager " + answer);
 
         return answer;
     }

Added: camel/trunk/components/camel-http/src/test/java/org/apache/camel/component/http/HttpConcurrentTest.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-http/src/test/java/org/apache/camel/component/http/HttpConcurrentTest.java?rev=915312&view=auto
==============================================================================
--- camel/trunk/components/camel-http/src/test/java/org/apache/camel/component/http/HttpConcurrentTest.java (added)
+++ camel/trunk/components/camel-http/src/test/java/org/apache/camel/component/http/HttpConcurrentTest.java Tue Feb 23 12:46:55 2010
@@ -0,0 +1,97 @@
+/**
+ * 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.http;
+
+import java.io.IOException;
+import java.util.HashSet;
+import java.util.Map;
+import java.util.Set;
+import java.util.concurrent.Callable;
+import java.util.concurrent.ConcurrentHashMap;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.Executors;
+import java.util.concurrent.Future;
+import java.util.concurrent.atomic.AtomicInteger;
+
+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.localserver.LocalTestServer;
+import org.apache.http.protocol.HttpContext;
+import org.apache.http.protocol.HttpRequestHandler;
+import org.junit.Test;
+
+/**
+ * @version $Revision$
+ */
+public class HttpConcurrentTest extends BaseHttpTest {
+
+    private final AtomicInteger counter = new AtomicInteger();
+
+    @Override
+    protected void registerHandler(LocalTestServer server) {
+        server.register("/", new HttpRequestHandler() {
+            public void handle(HttpRequest request, HttpResponse response, HttpContext context) throws HttpException, IOException {
+                try {
+                    Thread.sleep(1000);
+                } catch (InterruptedException e) {
+                    // ignore
+                }
+                response.setStatusCode(HttpStatus.SC_OK);
+                response.setEntity(new StringEntity("" + counter.incrementAndGet()));
+            }
+        });
+    }
+
+    @Test
+    public void testNoConcurrentProducers() throws Exception {
+        doSendMessages(1, 1);
+    }
+
+    @Test
+    public void testConcurrentProducers() throws Exception {
+        doSendMessages(10, 5);
+    }
+
+    private void doSendMessages(int files, int poolSize) throws Exception {
+        ExecutorService executor = Executors.newFixedThreadPool(poolSize);
+        Map<Integer, Future> responses = new ConcurrentHashMap();
+        for (int i = 0; i < files; i++) {
+            final int index = i;
+            Future out = executor.submit(new Callable<Object>() {
+                public Object call() throws Exception {
+                    return template.requestBody("http://" + getHostName() + ":" + getPort(), null, String.class);
+                }
+            });
+            responses.put(index, out);
+        }
+
+        assertEquals(files, responses.size());
+
+        // get all responses
+        Set unique = new HashSet();
+        for (Future future : responses.values()) {
+            unique.add(future.get());
+        }
+
+        // should be 10 unique responses
+        assertEquals("Should be " + files + " unique responses", files, unique.size());
+    }
+
+}

Propchange: camel/trunk/components/camel-http/src/test/java/org/apache/camel/component/http/HttpConcurrentTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/trunk/components/camel-http/src/test/java/org/apache/camel/component/http/HttpConcurrentTest.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date