You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by ni...@apache.org on 2014/06/18 09:00:06 UTC

[1/4] git commit: CAMEL-7520 Support to setup the handler even the Jetty server is created

Repository: camel
Updated Branches:
  refs/heads/master ef4d0a7ec -> 601c14356


CAMEL-7520 Support to setup the handler even the Jetty server is created


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

Branch: refs/heads/master
Commit: 8c7dcebd8bb477654226ee3d8132ecf36aa8058a
Parents: b6a8799
Author: Willem Jiang <wi...@gmail.com>
Authored: Wed Jun 18 14:36:46 2014 +0800
Committer: Willem Jiang <wi...@gmail.com>
Committed: Wed Jun 18 14:56:15 2014 +0800

----------------------------------------------------------------------
 .../component/jetty/JettyHttpComponent.java     | 38 +++++++++++++-------
 1 file changed, 25 insertions(+), 13 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/8c7dcebd/components/camel-jetty/src/main/java/org/apache/camel/component/jetty/JettyHttpComponent.java
----------------------------------------------------------------------
diff --git a/components/camel-jetty/src/main/java/org/apache/camel/component/jetty/JettyHttpComponent.java b/components/camel-jetty/src/main/java/org/apache/camel/component/jetty/JettyHttpComponent.java
index f9d4ebf..6d15b68 100644
--- a/components/camel-jetty/src/main/java/org/apache/camel/component/jetty/JettyHttpComponent.java
+++ b/components/camel-jetty/src/main/java/org/apache/camel/component/jetty/JettyHttpComponent.java
@@ -312,6 +312,13 @@ public class JettyHttpComponent extends HttpComponent {
                 CONNECTORS.put(connectorKey, connectorRef);
                 
             } else {
+                
+                if (endpoint.getHandlers() != null && !endpoint.getHandlers().isEmpty()) {
+                    // As the server is started, we need to stop the server for a while to add the new handler
+                    connectorRef.server.stop();
+                    addJettyHandlers(connectorRef.server, endpoint.getHandlers());
+                    connectorRef.server.start();
+                }
                 // ref track the connector
                 connectorRef.increment();
             }
@@ -925,19 +932,7 @@ public class JettyHttpComponent extends HttpComponent {
         ServletContextHandler context = new ServletContextHandler(server, "/", ServletContextHandler.NO_SECURITY | ServletContextHandler.NO_SESSIONS);
         context.setConnectorNames(new String[] {connector.getName()});
 
-        if (handlers != null && !handlers.isEmpty()) {
-            for (Handler handler : handlers) {
-                if (handler instanceof HandlerWrapper) {
-                    ((HandlerWrapper) handler).setHandler(server.getHandler());
-                    server.setHandler(handler);
-                } else {
-                    HandlerCollection handlerCollection = new HandlerCollection();
-                    handlerCollection.addHandler(server.getHandler());
-                    handlerCollection.addHandler(handler);
-                    server.setHandler(handlerCollection);
-                }
-            }
-        }
+        addJettyHandlers(server, handlers);
 
         CamelServlet camelServlet;
         boolean jetty = endpoint.getUseContinuation() != null ? endpoint.getUseContinuation() : isUseContinuation();
@@ -968,6 +963,23 @@ public class JettyHttpComponent extends HttpComponent {
         return camelServlet;
     }
     
+    protected void addJettyHandlers(Server server, List<Handler> handlers) {
+        if (handlers != null && !handlers.isEmpty()) {
+            for (Handler handler : handlers) {
+                if (handler instanceof HandlerWrapper) {
+                    ((HandlerWrapper) handler).setHandler(server.getHandler());
+                    server.setHandler(handler);
+                } else {
+                    HandlerCollection handlerCollection = new HandlerCollection();
+                    handlerCollection.addHandler(server.getHandler());
+                    handlerCollection.addHandler(handler);
+                    server.setHandler(handlerCollection);
+                }
+            }
+        }
+        
+    }
+    
     protected Server createServer() throws Exception {
         Server server = new Server();
         ContextHandlerCollection collection = new ContextHandlerCollection();


[2/4] git commit: Added an unit test for camel-http redirect according to the mailing list

Posted by ni...@apache.org.
Added an unit test for camel-http redirect according to the mailing list


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

Branch: refs/heads/master
Commit: b6a87991c7049e21d8b7249d69101c8584ab4d7d
Parents: a7cd3b7
Author: Willem Jiang <wi...@gmail.com>
Authored: Tue Jun 17 11:57:15 2014 +0800
Committer: Willem Jiang <wi...@gmail.com>
Committed: Wed Jun 18 14:56:15 2014 +0800

----------------------------------------------------------------------
 .../camel/component/jetty/HttpRedirectTest.java | 48 ++++++++++++++++----
 1 file changed, 38 insertions(+), 10 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/b6a87991/components/camel-jetty/src/test/java/org/apache/camel/component/jetty/HttpRedirectTest.java
----------------------------------------------------------------------
diff --git a/components/camel-jetty/src/test/java/org/apache/camel/component/jetty/HttpRedirectTest.java b/components/camel-jetty/src/test/java/org/apache/camel/component/jetty/HttpRedirectTest.java
index e139e47..cd26dae 100644
--- a/components/camel-jetty/src/test/java/org/apache/camel/component/jetty/HttpRedirectTest.java
+++ b/components/camel-jetty/src/test/java/org/apache/camel/component/jetty/HttpRedirectTest.java
@@ -21,10 +21,11 @@ import org.apache.camel.Processor;
 import org.apache.camel.RuntimeCamelException;
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.http.HttpOperationFailedException;
+import org.apache.camel.component.mock.MockEndpoint;
 import org.junit.Test;
 
 /**
- * @version 
+ * @version
  */
 public class HttpRedirectTest extends BaseJettyTest {
 
@@ -34,7 +35,8 @@ public class HttpRedirectTest extends BaseJettyTest {
             template.requestBody("http://localhost:{{port}}/test", "Hello World", String.class);
             fail("Should have thrown an exception");
         } catch (RuntimeCamelException e) {
-            HttpOperationFailedException cause = assertIsInstanceOf(HttpOperationFailedException.class, e.getCause());
+            HttpOperationFailedException cause = assertIsInstanceOf(HttpOperationFailedException.class,
+                                                                    e.getCause());
             assertEquals(301, cause.getStatusCode());
             assertEquals(true, cause.isRedirectError());
             assertEquals(true, cause.hasRedirectLocation());
@@ -43,19 +45,45 @@ public class HttpRedirectTest extends BaseJettyTest {
         }
     }
 
+    @Test
+    public void testHttpRedirectFromCamelRoute() throws Exception {
+        MockEndpoint errorEndpoint = context.getEndpoint("mock:error", MockEndpoint.class);
+        errorEndpoint.expectedMessageCount(1);
+        MockEndpoint resultEndpoint = context.getEndpoint("mock:result", MockEndpoint.class);
+        resultEndpoint.expectedMessageCount(0);
+        try {
+            template.requestBody("direct:start", "Hello World", String.class);
+            fail("Should have thrown an exception");
+        } catch (RuntimeCamelException e) {
+            HttpOperationFailedException cause = assertIsInstanceOf(HttpOperationFailedException.class,
+                                                                    e.getCause());
+            assertEquals(302, cause.getStatusCode());
+        }
+        errorEndpoint.assertIsSatisfied();
+        resultEndpoint.assertIsSatisfied();
+    }
+
     @Override
     protected RouteBuilder createRouteBuilder() throws Exception {
         return new RouteBuilder() {
             @Override
             public void configure() throws Exception {
-                from("jetty://http://localhost:{{port}}/test")
-                    .process(new Processor() {
-                        public void process(Exchange exchange) throws Exception {
-                            exchange.getOut().setHeader(Exchange.HTTP_RESPONSE_CODE, 301);
-                            exchange.getOut().setHeader("location", "http://localhost:" + getPort() + "/newtest");
-                        }
-                    });
+                from("jetty://http://localhost:{{port}}/test").process(new Processor() {
+                    public void process(Exchange exchange) throws Exception {
+                        exchange.getOut().setHeader(Exchange.HTTP_RESPONSE_CODE, 301);
+                        exchange.getOut().setHeader("location", "http://localhost:" + getPort() + "/newtest");
+                    }
+                });
+                from("jetty://http://localhost:{{port}}/remove").process(new Processor() {
+                    public void process(Exchange exchange) throws Exception {
+                        exchange.getOut().setHeader(Exchange.HTTP_RESPONSE_CODE, 302);
+                    }
+                });
+                
+                from("direct:start").onException(HttpOperationFailedException.class).to("mock:error").end()
+                    .to("http://localhost:{{port}}/remove?throwExceptionOnFailure=true").to("mock:result");
+
             }
         };
     }
-}
\ No newline at end of file
+}


[3/4] git commit: CAMEL-7487 Fixed the CS errors of camel-core

Posted by ni...@apache.org.
CAMEL-7487 Fixed the CS errors of camel-core


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

Branch: refs/heads/master
Commit: a7cd3b78fd0406b87d2e415b71988f17f4e7aa95
Parents: ef4d0a7
Author: Willem Jiang <wi...@gmail.com>
Authored: Tue Jun 17 10:08:46 2014 +0800
Committer: Willem Jiang <wi...@gmail.com>
Committed: Wed Jun 18 14:56:15 2014 +0800

----------------------------------------------------------------------
 .../camel/util/component/ApiMethodHelper.java       | 16 ++++++++--------
 .../camel/util/component/ApiMethodParser.java       |  6 +++---
 .../util/component/ApiMethodPropertiesHelper.java   |  8 ++++----
 .../util/component/ArgumentSubstitutionParser.java  | 16 ++++++++++++++++
 .../camel/util/component/ApiMethodHelperTest.java   |  2 +-
 .../component/ApiMethodPropertiesHelperTest.java    |  2 +-
 .../component/ArgumentSubstitutionParserTest.java   | 16 ++++++++++++++++
 7 files changed, 49 insertions(+), 17 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/a7cd3b78/camel-core/src/main/java/org/apache/camel/util/component/ApiMethodHelper.java
----------------------------------------------------------------------
diff --git a/camel-core/src/main/java/org/apache/camel/util/component/ApiMethodHelper.java b/camel-core/src/main/java/org/apache/camel/util/component/ApiMethodHelper.java
index 27ba116..b4401eb 100644
--- a/camel-core/src/main/java/org/apache/camel/util/component/ApiMethodHelper.java
+++ b/camel-core/src/main/java/org/apache/camel/util/component/ApiMethodHelper.java
@@ -51,7 +51,7 @@ public final class ApiMethodHelper<T extends Enum<T> & ApiMethod> {
     private final Map<String, Class<?>> validArguments = new HashMap<String, Class<?>>();
 
     // maps aliases to actual method names
-    private final HashMap<String, Set<String>> aliases = new HashMap<String, Set<String>>();
+    private final HashMap<String, Set<String>> aliasesMap = new HashMap<String, Set<String>>();
 
     /**
      * Create a helper to work with a {@link ApiMethod}, using optional method aliases.
@@ -95,10 +95,10 @@ public final class ApiMethodHelper<T extends Enum<T> & ApiMethod> {
                         builder.append(Character.toLowerCase(firstChar)).append(alias.substring(1));
                         alias = builder.toString();
                     }
-                    Set<String> names = this.aliases.get(alias);
+                    Set<String> names = aliasesMap.get(alias);
                     if (names == null) {
                         names = new HashSet<String>();
-                        this.aliases.put(alias, names);
+                        aliasesMap.put(alias, names);
                     }
                     names.add(name);
                 }
@@ -158,9 +158,9 @@ public final class ApiMethodHelper<T extends Enum<T> & ApiMethod> {
     public List<ApiMethod> getCandidateMethods(String name, String... argNames) {
         List<T> methods = methodMap.get(name);
         if (methods == null) {
-            if (aliases.containsKey(name)) {
+            if (aliasesMap.containsKey(name)) {
                 methods = new ArrayList<T>();
-                for (String method : aliases.get(name)) {
+                for (String method : aliasesMap.get(name)) {
                     methods.addAll(methodMap.get(method));
                 }
             }
@@ -241,9 +241,9 @@ public final class ApiMethodHelper<T extends Enum<T> & ApiMethod> {
     public List<Object> getArguments(final String name) throws IllegalArgumentException {
         List<Object> arguments = argumentsMap.get(name);
         if (arguments == null) {
-            if (aliases.containsKey(name)) {
+            if (aliasesMap.containsKey(name)) {
                 arguments = new ArrayList<Object>();
-                for (String method : aliases.get(name)) {
+                for (String method : aliasesMap.get(name)) {
                     arguments.addAll(argumentsMap.get(method));
                 }
             }
@@ -279,7 +279,7 @@ public final class ApiMethodHelper<T extends Enum<T> & ApiMethod> {
      * @return alias names mapped to method names.
      */
     public Map<String, Set<String>> getAliases() {
-        return Collections.unmodifiableMap(aliases);
+        return Collections.unmodifiableMap(aliasesMap);
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/camel/blob/a7cd3b78/camel-core/src/main/java/org/apache/camel/util/component/ApiMethodParser.java
----------------------------------------------------------------------
diff --git a/camel-core/src/main/java/org/apache/camel/util/component/ApiMethodParser.java b/camel-core/src/main/java/org/apache/camel/util/component/ApiMethodParser.java
index 1003df4..03c9124 100644
--- a/camel-core/src/main/java/org/apache/camel/util/component/ApiMethodParser.java
+++ b/camel-core/src/main/java/org/apache/camel/util/component/ApiMethodParser.java
@@ -138,9 +138,9 @@ public abstract class ApiMethodParser<T> {
                     allArguments.put(name, type);
                 } else {
                     if (argClass != type) {
-                        throw new IllegalArgumentException("Argument [" + name +
-                                "] is used in multiple methods with different types " +
-                                argClass.getCanonicalName() + ", " + type.getCanonicalName());
+                        throw new IllegalArgumentException("Argument [" + name 
+                                + "] is used in multiple methods with different types " 
+                                + argClass.getCanonicalName() + ", " + type.getCanonicalName());
                     }
                 }
             }

http://git-wip-us.apache.org/repos/asf/camel/blob/a7cd3b78/camel-core/src/main/java/org/apache/camel/util/component/ApiMethodPropertiesHelper.java
----------------------------------------------------------------------
diff --git a/camel-core/src/main/java/org/apache/camel/util/component/ApiMethodPropertiesHelper.java b/camel-core/src/main/java/org/apache/camel/util/component/ApiMethodPropertiesHelper.java
index 4cd692c..e5e9441 100644
--- a/camel-core/src/main/java/org/apache/camel/util/component/ApiMethodPropertiesHelper.java
+++ b/camel-core/src/main/java/org/apache/camel/util/component/ApiMethodPropertiesHelper.java
@@ -33,10 +33,10 @@ import org.slf4j.LoggerFactory;
  */
 public abstract class ApiMethodPropertiesHelper<C> {
 
-    protected Logger LOG = LoggerFactory.getLogger(ApiMethodPropertiesHelper.class);
+    protected static final Logger LOG = LoggerFactory.getLogger(ApiMethodPropertiesHelper.class);
 
     // set of field names which are specific to the api, to be excluded from method argument considerations
-    protected final Set<String> COMPONENT_CONFIG_FIELDS = new HashSet<String>();
+    protected final Set<String> componentConfigFields = new HashSet<String>();
 
     protected final Class<?> componentConfigClass;
     protected final String propertyPrefix;
@@ -47,7 +47,7 @@ public abstract class ApiMethodPropertiesHelper<C> {
         this.propertyPrefix = propertyPrefix;
 
         for (Field field : componentConfiguration.getDeclaredFields()) {
-            COMPONENT_CONFIG_FIELDS.add(field.getName());
+            componentConfigFields.add(field.getName());
         }
     }
 
@@ -77,7 +77,7 @@ public abstract class ApiMethodPropertiesHelper<C> {
         if (IntrospectionSupport.getProperties(endpointConfiguration, properties, null, false)) {
             final Set<String> names = properties.keySet();
             // remove component config properties so we only have endpoint properties
-            names.removeAll(COMPONENT_CONFIG_FIELDS);
+            names.removeAll(componentConfigFields);
         }
         if (LOG.isDebugEnabled()) {
             final Set<String> names = properties.keySet();

http://git-wip-us.apache.org/repos/asf/camel/blob/a7cd3b78/camel-core/src/main/java/org/apache/camel/util/component/ArgumentSubstitutionParser.java
----------------------------------------------------------------------
diff --git a/camel-core/src/main/java/org/apache/camel/util/component/ArgumentSubstitutionParser.java b/camel-core/src/main/java/org/apache/camel/util/component/ArgumentSubstitutionParser.java
index 2544dff..d9686e9 100644
--- a/camel-core/src/main/java/org/apache/camel/util/component/ArgumentSubstitutionParser.java
+++ b/camel-core/src/main/java/org/apache/camel/util/component/ArgumentSubstitutionParser.java
@@ -1,3 +1,19 @@
+/**
+ * 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.util.component;
 
 import java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/camel/blob/a7cd3b78/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodHelperTest.java
----------------------------------------------------------------------
diff --git a/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodHelperTest.java b/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodHelperTest.java
index 1fb84b7..601b671 100644
--- a/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodHelperTest.java
+++ b/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodHelperTest.java
@@ -28,7 +28,7 @@ import static org.junit.Assert.assertEquals;
 
 public class ApiMethodHelperTest {
 
-    private static TestMethod[] sayHis = new TestMethod[] { TestMethod.SAYHI, TestMethod.SAYHI_1};
+    private static TestMethod[] sayHis = new TestMethod[] {TestMethod.SAYHI, TestMethod.SAYHI_1};
     private static ApiMethodHelper<TestMethod> apiMethodHelper;
 
     static {

http://git-wip-us.apache.org/repos/asf/camel/blob/a7cd3b78/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodPropertiesHelperTest.java
----------------------------------------------------------------------
diff --git a/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodPropertiesHelperTest.java b/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodPropertiesHelperTest.java
index 65b7538..9a78421 100644
--- a/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodPropertiesHelperTest.java
+++ b/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodPropertiesHelperTest.java
@@ -38,7 +38,7 @@ public class ApiMethodPropertiesHelperTest {
     private static final String VALUE_4 = "true";
 
     private static ApiMethodPropertiesHelper propertiesHelper =
-            new ApiMethodPropertiesHelper<TestComponentConfiguration>(TestComponentConfiguration.class, TEST_PREFIX){};
+            new ApiMethodPropertiesHelper<TestComponentConfiguration>(TestComponentConfiguration.class, TEST_PREFIX) { };
 
     @Test
     public void testGetExchangeProperties() throws Exception {

http://git-wip-us.apache.org/repos/asf/camel/blob/a7cd3b78/camel-core/src/test/java/org/apache/camel/util/component/ArgumentSubstitutionParserTest.java
----------------------------------------------------------------------
diff --git a/camel-core/src/test/java/org/apache/camel/util/component/ArgumentSubstitutionParserTest.java b/camel-core/src/test/java/org/apache/camel/util/component/ArgumentSubstitutionParserTest.java
index a9487c0..6f095b4 100644
--- a/camel-core/src/test/java/org/apache/camel/util/component/ArgumentSubstitutionParserTest.java
+++ b/camel-core/src/test/java/org/apache/camel/util/component/ArgumentSubstitutionParserTest.java
@@ -1,3 +1,19 @@
+/**
+ * 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.util.component;
 
 import java.util.ArrayList;


[4/4] git commit: CAMEL-7487 fixes some CS error in camel-core

Posted by ni...@apache.org.
CAMEL-7487 fixes some CS error in camel-core


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

Branch: refs/heads/master
Commit: 601c14356685b09465ca067da8da7407e33599c9
Parents: 8c7dceb
Author: Willem Jiang <wi...@gmail.com>
Authored: Wed Jun 18 14:59:33 2014 +0800
Committer: Willem Jiang <wi...@gmail.com>
Committed: Wed Jun 18 14:59:33 2014 +0800

----------------------------------------------------------------------
 .../java/org/apache/camel/util/component/ApiMethodHelperTest.java  | 2 +-
 .../apache/camel/util/component/ApiMethodPropertiesHelperTest.java | 2 +-
 2 files changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/601c1435/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodHelperTest.java
----------------------------------------------------------------------
diff --git a/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodHelperTest.java b/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodHelperTest.java
index 601b671..93597aa 100644
--- a/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodHelperTest.java
+++ b/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodHelperTest.java
@@ -134,7 +134,7 @@ public class ApiMethodHelperTest {
         assertEquals("greetUs(name1, name2)", "Greetings Dave, Frank", ApiMethodHelper.invokeMethod(proxy, TestMethod.GREETUS, properties));
 
         properties.clear();
-        properties.put("names", new String[] { "Dave", "Frank" });
+        properties.put("names", new String[] {"Dave", "Frank"});
         assertEquals("greetAll(names)", "Greetings Dave, Frank", ApiMethodHelper.invokeMethod(proxy, TestMethod.GREETALL, properties));
 
         // test with a derived proxy

http://git-wip-us.apache.org/repos/asf/camel/blob/601c1435/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodPropertiesHelperTest.java
----------------------------------------------------------------------
diff --git a/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodPropertiesHelperTest.java b/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodPropertiesHelperTest.java
index 9a78421..f2b0ae0 100644
--- a/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodPropertiesHelperTest.java
+++ b/camel-core/src/test/java/org/apache/camel/util/component/ApiMethodPropertiesHelperTest.java
@@ -37,7 +37,7 @@ public class ApiMethodPropertiesHelperTest {
     private static final String VALUE_3 = "value3";
     private static final String VALUE_4 = "true";
 
-    private static ApiMethodPropertiesHelper propertiesHelper =
+    private static ApiMethodPropertiesHelper<TestComponentConfiguration> propertiesHelper =
             new ApiMethodPropertiesHelper<TestComponentConfiguration>(TestComponentConfiguration.class, TEST_PREFIX) { };
 
     @Test