You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by zr...@apache.org on 2018/02/18 19:31:24 UTC

[camel] branch master updated: Checkstyle fixes

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

zregvart 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 18b0638  Checkstyle fixes
18b0638 is described below

commit 18b063840ea4a8276449684eaf06ff85f8391036
Author: Zoran Regvart <zr...@apache.org>
AuthorDate: Sun Feb 18 20:31:20 2018 +0100

    Checkstyle fixes
---
 .../apache/camel/component/mail/MailBinding.java   |  2 +-
 .../spring/boot/LogListenerDiscoveryTest.java      |  4 +--
 .../spring/boot/UuidGeneratorDiscoveryTest.java    |  4 +--
 .../undertow/ws/UndertowWsConsumerRouteTest.java   |  2 +-
 .../ws/UndertowWsProducerRouteRestartTest.java     | 42 +++++++++++-----------
 .../undertow/ws/UndertowWsProducerRouteTest.java   |  1 -
 .../component/xchange/XChangeAccountProducer.java  | 10 ++----
 .../component/xchange/XChangeConfiguration.java    | 10 ++----
 .../camel/component/xchange/XChangeEndpoint.java   |  2 +-
 .../xchange/XChangeMarketDataProducer.java         |  6 ++--
 .../component/xchange/XChangeMetaDataProducer.java | 20 ++++-------
 .../xchange/account/AccountProducerTest.java       |  6 ++--
 .../xchange/market/MarketDataProducerTest.java     |  8 ++---
 .../xchange/metadata/MetaDataProducerTest.java     | 14 ++++----
 .../xmlsecurity/XAdESSignaturePropertiesTest.java  |  2 +-
 .../component/xmpp/XmppMultiUserChatTest.java      |  2 +-
 .../camel/component/xmpp/XmppRouteChatTest.java    |  2 +-
 ...ppRouteMultipleProducersSingleConsumerTest.java |  2 +-
 .../src/test/resources/application.properties      | 17 +++++++++
 .../src/test/resources/application.properties      | 17 +++++++++
 .../src/test/resources/application.properties      | 17 +++++++++
 .../src/test/resources/application.properties      | 17 +++++++++
 .../src/test/resources/application.properties      | 17 +++++++++
 .../src/test/resources/application.properties      |  2 +-
 .../src/test/resources/application.properties      | 17 +++++++++
 .../src/test/resources/application.properties      |  2 +-
 .../src/test/resources/application.properties      | 17 +++++++++
 .../src/test/resources/application.properties      | 17 +++++++++
 .../src/test/resources/application.properties      | 17 +++++++++
 29 files changed, 217 insertions(+), 79 deletions(-)

diff --git a/components/camel-mail/src/main/java/org/apache/camel/component/mail/MailBinding.java b/components/camel-mail/src/main/java/org/apache/camel/component/mail/MailBinding.java
index ac157ed..0d4348e 100644
--- a/components/camel-mail/src/main/java/org/apache/camel/component/mail/MailBinding.java
+++ b/components/camel-mail/src/main/java/org/apache/camel/component/mail/MailBinding.java
@@ -307,7 +307,7 @@ public class MailBinding {
 
         for (int i = 0; i < mp.getCount(); i++) {
             Part part = mp.getBodyPart(i);
-            LOG.trace("Part #{}: {}", i , part);
+            LOG.trace("Part #{}: {}", i, part);
 
             if (part.isMimeType("multipart/*")) {
                 LOG.trace("Part #{}: is mimetype: multipart/*", i);
diff --git a/components/camel-spring-boot/src/test/java/org/apache/camel/spring/boot/LogListenerDiscoveryTest.java b/components/camel-spring-boot/src/test/java/org/apache/camel/spring/boot/LogListenerDiscoveryTest.java
index a4bfc6f..6110fc5 100644
--- a/components/camel-spring-boot/src/test/java/org/apache/camel/spring/boot/LogListenerDiscoveryTest.java
+++ b/components/camel-spring-boot/src/test/java/org/apache/camel/spring/boot/LogListenerDiscoveryTest.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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.
@@ -56,4 +56,4 @@ public class LogListenerDiscoveryTest {
             return null;
         }
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-spring-boot/src/test/java/org/apache/camel/spring/boot/UuidGeneratorDiscoveryTest.java b/components/camel-spring-boot/src/test/java/org/apache/camel/spring/boot/UuidGeneratorDiscoveryTest.java
index 867e6a5..d9282e8 100644
--- a/components/camel-spring-boot/src/test/java/org/apache/camel/spring/boot/UuidGeneratorDiscoveryTest.java
+++ b/components/camel-spring-boot/src/test/java/org/apache/camel/spring/boot/UuidGeneratorDiscoveryTest.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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.
@@ -54,4 +54,4 @@ public class UuidGeneratorDiscoveryTest {
             return UUID.randomUUID().toString();
         }
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-undertow/src/test/java/org/apache/camel/component/undertow/ws/UndertowWsConsumerRouteTest.java b/components/camel-undertow/src/test/java/org/apache/camel/component/undertow/ws/UndertowWsConsumerRouteTest.java
index 94a96d0..3a25a3f 100644
--- a/components/camel-undertow/src/test/java/org/apache/camel/component/undertow/ws/UndertowWsConsumerRouteTest.java
+++ b/components/camel-undertow/src/test/java/org/apache/camel/component/undertow/ws/UndertowWsConsumerRouteTest.java
@@ -40,8 +40,8 @@ import org.apache.camel.component.undertow.UndertowConstants.EventType;
 import org.apache.camel.converter.IOConverter;
 import org.asynchttpclient.AsyncHttpClient;
 import org.asynchttpclient.DefaultAsyncHttpClient;
-import org.asynchttpclient.ws.WebSocketListener;
 import org.asynchttpclient.ws.WebSocket;
+import org.asynchttpclient.ws.WebSocketListener;
 import org.asynchttpclient.ws.WebSocketUpgradeHandler;
 import org.junit.Assert;
 import org.junit.Test;
diff --git a/components/camel-undertow/src/test/java/org/apache/camel/component/undertow/ws/UndertowWsProducerRouteRestartTest.java b/components/camel-undertow/src/test/java/org/apache/camel/component/undertow/ws/UndertowWsProducerRouteRestartTest.java
index e625c9b..5a5f6ab 100644
--- a/components/camel-undertow/src/test/java/org/apache/camel/component/undertow/ws/UndertowWsProducerRouteRestartTest.java
+++ b/components/camel-undertow/src/test/java/org/apache/camel/component/undertow/ws/UndertowWsProducerRouteRestartTest.java
@@ -69,27 +69,27 @@ public class UndertowWsProducerRouteRestartTest extends BaseUndertowTest {
         AsyncHttpClient c = new DefaultAsyncHttpClient();
 
         WebSocket websocket = c.prepareGet("ws://localhost:" + getPort() + "/shop")
-                .execute(new WebSocketUpgradeHandler.Builder().addWebSocketListener(new WebSocketListener() {
-					@Override
-                    public void onTextFrame(String message, boolean finalFragment, int rsv) {
-                        received.add(message);
-                        log.info("received --> " + message);
-                        latch.countDown();
-                    }
-
-                    @Override
-                    public void onOpen(WebSocket websocket) {
-                    }
-
-                    @Override
-                    public void onClose(WebSocket websocket, int code, String reason) {
-                    }
-
-                    @Override
-                    public void onError(Throwable t) {
-                        t.printStackTrace();
-                    }
-                }).build()).get();
+            .execute(new WebSocketUpgradeHandler.Builder().addWebSocketListener(new WebSocketListener() {
+                @Override
+                public void onTextFrame(String message, boolean finalFragment, int rsv) {
+                    received.add(message);
+                    log.info("received --> " + message);
+                    latch.countDown();
+                }
+
+                @Override
+                public void onOpen(WebSocket websocket) {
+                }
+
+                @Override
+                public void onClose(WebSocket websocket, int code, String reason) {
+                }
+
+                @Override
+                public void onError(Throwable t) {
+                    t.printStackTrace();
+                }
+            }).build()).get();
 
         // Send message to the direct endpoint
         producer.sendBodyAndHeader("Beer on stock at Apache Mall", UndertowConstants.SEND_TO_ALL, "true");
diff --git a/components/camel-undertow/src/test/java/org/apache/camel/component/undertow/ws/UndertowWsProducerRouteTest.java b/components/camel-undertow/src/test/java/org/apache/camel/component/undertow/ws/UndertowWsProducerRouteTest.java
index e338961..fc27066 100644
--- a/components/camel-undertow/src/test/java/org/apache/camel/component/undertow/ws/UndertowWsProducerRouteTest.java
+++ b/components/camel-undertow/src/test/java/org/apache/camel/component/undertow/ws/UndertowWsProducerRouteTest.java
@@ -4,7 +4,6 @@
  * 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
diff --git a/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeAccountProducer.java b/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeAccountProducer.java
index 7dd5e86..7ecee9f 100644
--- a/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeAccountProducer.java
+++ b/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeAccountProducer.java
@@ -40,16 +40,12 @@ public class XChangeAccountProducer extends DefaultProducer {
         if (XChangeMethod.balances == method) {
             Object body = endpoint.getBalances();
             exchange.getMessage().setBody(body);
-        } 
-        
-        else if (XChangeMethod.fundingHistory == method) {
+        } else if (XChangeMethod.fundingHistory == method) {
             Object body = endpoint.getFundingHistory();
             exchange.getMessage().setBody(body);
-        } 
-        
-        else if (XChangeMethod.wallets == method) {
+        } else if (XChangeMethod.wallets == method) {
             Object body = endpoint.getWallets();
             exchange.getMessage().setBody(body);
         } 
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeConfiguration.java b/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeConfiguration.java
index 36f9376..090e7f9 100644
--- a/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeConfiguration.java
+++ b/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeConfiguration.java
@@ -44,11 +44,13 @@ public class XChangeConfiguration {
         currencies, currencyMetaData, currencyPairs, currencyPairMetaData,
         // Marketdata service methods
         ticker 
-        }
+    }
     
     public static final String HEADER_CURRENCY = "Currency";
     public static final String HEADER_CURRENCY_PAIR = "CurrencyPair";
     
+    static Map<String, Class<? extends Exchange>> xchangeMapping = new HashMap<>();
+
     @UriPath(description = "The exchange to connect to") @Metadata(required = "true")
     private String name;
     @UriParam(description = "The service to call") @Metadata(required = "true")
@@ -60,12 +62,6 @@ public class XChangeConfiguration {
     @UriParam(description = "The currency pair") 
     private CurrencyPair currencyPair;
 
-    static Map<String, Class<? extends Exchange>> xchangeMapping = new HashMap<>();
-    static {
-        // Add name mappings here that do not follow the convention 
-        // nameMapping.put("binance", BinanceExchange.class);
-    }
-    
     public XChangeConfiguration(XChangeComponent component) {
         ObjectHelper.notNull(component, "component");
     }
diff --git a/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeEndpoint.java b/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeEndpoint.java
index 88cfe4dd..b906d1b 100644
--- a/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeEndpoint.java
+++ b/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeEndpoint.java
@@ -134,7 +134,7 @@ public class XChangeEndpoint extends DefaultEndpoint {
         });
         return balances.stream().sorted(new Comparator<Balance>() {
             public int compare(Balance o1, Balance o2) {
-               return o1.getCurrency().compareTo(o2.getCurrency());
+                return o1.getCurrency().compareTo(o2.getCurrency());
             }
         }).collect(Collectors.toList());
     }
diff --git a/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeMarketDataProducer.java b/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeMarketDataProducer.java
index ecd74a4..c03f27a 100644
--- a/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeMarketDataProducer.java
+++ b/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeMarketDataProducer.java
@@ -16,14 +16,14 @@
  */
 package org.apache.camel.component.xchange;
 
-import static org.apache.camel.component.xchange.XChangeConfiguration.HEADER_CURRENCY_PAIR;
-
 import org.apache.camel.Exchange;
 import org.apache.camel.component.xchange.XChangeConfiguration.XChangeMethod;
 import org.apache.camel.impl.DefaultProducer;
 import org.knowm.xchange.currency.CurrencyPair;
 import org.knowm.xchange.dto.marketdata.Ticker;
 
+import static org.apache.camel.component.xchange.XChangeConfiguration.HEADER_CURRENCY_PAIR;
+
 public class XChangeMarketDataProducer extends DefaultProducer {
     
     public XChangeMarketDataProducer(XChangeEndpoint endpoint) {
@@ -49,4 +49,4 @@ public class XChangeMarketDataProducer extends DefaultProducer {
             exchange.getMessage().setBody(ticker);
         }
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeMetaDataProducer.java b/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeMetaDataProducer.java
index 502ba0b..7486902 100644
--- a/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeMetaDataProducer.java
+++ b/components/camel-xchange/src/main/java/org/apache/camel/component/xchange/XChangeMetaDataProducer.java
@@ -16,15 +16,15 @@
  */
 package org.apache.camel.component.xchange;
 
-import static org.apache.camel.component.xchange.XChangeConfiguration.HEADER_CURRENCY;
-import static org.apache.camel.component.xchange.XChangeConfiguration.HEADER_CURRENCY_PAIR;
-
 import org.apache.camel.Exchange;
 import org.apache.camel.component.xchange.XChangeConfiguration.XChangeMethod;
 import org.apache.camel.impl.DefaultProducer;
 import org.knowm.xchange.currency.Currency;
 import org.knowm.xchange.currency.CurrencyPair;
 
+import static org.apache.camel.component.xchange.XChangeConfiguration.HEADER_CURRENCY;
+import static org.apache.camel.component.xchange.XChangeConfiguration.HEADER_CURRENCY_PAIR;
+
 public class XChangeMetaDataProducer extends DefaultProducer {
     
     public XChangeMetaDataProducer(XChangeEndpoint endpoint) {
@@ -45,22 +45,16 @@ public class XChangeMetaDataProducer extends DefaultProducer {
         if (XChangeMethod.currencies == method) {
             Object body = endpoint.getCurrencies();
             exchange.getMessage().setBody(body);
-        } 
-        
-        else if (XChangeMethod.currencyPairs == method) {
+        } else if (XChangeMethod.currencyPairs == method) {
             Object body = endpoint.getCurrencyPairs();
             exchange.getMessage().setBody(body);
-        } 
-        
-        else if (XChangeMethod.currencyMetaData == method) {
+        } else if (XChangeMethod.currencyMetaData == method) {
             Currency curr = exchange.getMessage().getHeader(HEADER_CURRENCY, Currency.class);
             curr = curr != null ? curr : exchange.getMessage().getBody(Currency.class);
             curr = curr != null ? curr : endpoint.getConfiguration().getCurrency();
             Object body = endpoint.getCurrencyMetaData(curr);
             exchange.getMessage().setBody(body);
-        } 
-        
-        else if (XChangeMethod.currencyPairMetaData == method) {
+        } else if (XChangeMethod.currencyPairMetaData == method) {
             CurrencyPair pair = exchange.getIn().getHeader(HEADER_CURRENCY_PAIR, CurrencyPair.class);
             pair = pair != null ? pair : exchange.getMessage().getBody(CurrencyPair.class);
             pair = pair != null ? pair : endpoint.getConfiguration().getCurrencyPair();
@@ -68,4 +62,4 @@ public class XChangeMetaDataProducer extends DefaultProducer {
             exchange.getMessage().setBody(body);
         }
     }
-}
\ No newline at end of file
+}
diff --git a/components/camel-xchange/src/test/java/org/apache/camel/component/xchange/account/AccountProducerTest.java b/components/camel-xchange/src/test/java/org/apache/camel/component/xchange/account/AccountProducerTest.java
index c1803f5..1b9ddd7 100644
--- a/components/camel-xchange/src/test/java/org/apache/camel/component/xchange/account/AccountProducerTest.java
+++ b/components/camel-xchange/src/test/java/org/apache/camel/component/xchange/account/AccountProducerTest.java
@@ -37,13 +37,13 @@ public class AccountProducerTest extends CamelTestSupport {
             public void configure() throws Exception {
                 
                 from("direct:balances")
-                .to("xchange:binance?service=account&method=balances");
+                    .to("xchange:binance?service=account&method=balances");
                 
                 from("direct:wallets")
-                .to("xchange:binance?service=account&method=wallets");
+                    .to("xchange:binance?service=account&method=wallets");
                 
                 from("direct:fundingHistory")
-                .to("xchange:binance?service=account&method=fundingHistory");
+                    .to("xchange:binance?service=account&method=fundingHistory");
             }
         };
     }
diff --git a/components/camel-xchange/src/test/java/org/apache/camel/component/xchange/market/MarketDataProducerTest.java b/components/camel-xchange/src/test/java/org/apache/camel/component/xchange/market/MarketDataProducerTest.java
index 461737d..26466cd 100644
--- a/components/camel-xchange/src/test/java/org/apache/camel/component/xchange/market/MarketDataProducerTest.java
+++ b/components/camel-xchange/src/test/java/org/apache/camel/component/xchange/market/MarketDataProducerTest.java
@@ -16,8 +16,6 @@
  */
 package org.apache.camel.component.xchange.market;
 
-import static org.apache.camel.component.xchange.XChangeConfiguration.HEADER_CURRENCY_PAIR;
-
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.test.junit4.CamelTestSupport;
 import org.junit.Assert;
@@ -25,6 +23,8 @@ import org.junit.Test;
 import org.knowm.xchange.currency.CurrencyPair;
 import org.knowm.xchange.dto.marketdata.Ticker;
 
+import static org.apache.camel.component.xchange.XChangeConfiguration.HEADER_CURRENCY_PAIR;
+
 public class MarketDataProducerTest extends CamelTestSupport {
 
     @Override
@@ -34,10 +34,10 @@ public class MarketDataProducerTest extends CamelTestSupport {
             public void configure() throws Exception {
                 
                 from("direct:ticker")
-                .to("xchange:binance?service=marketdata&method=ticker");
+                    .to("xchange:binance?service=marketdata&method=ticker");
                 
                 from("direct:tickerBTCUSDT")
-                .to("xchange:binance?service=marketdata&method=ticker&currencyPair=BTC/USDT");
+                    .to("xchange:binance?service=marketdata&method=ticker&currencyPair=BTC/USDT");
             }
         };
     }
diff --git a/components/camel-xchange/src/test/java/org/apache/camel/component/xchange/metadata/MetaDataProducerTest.java b/components/camel-xchange/src/test/java/org/apache/camel/component/xchange/metadata/MetaDataProducerTest.java
index d99c4c2..3617f08 100644
--- a/components/camel-xchange/src/test/java/org/apache/camel/component/xchange/metadata/MetaDataProducerTest.java
+++ b/components/camel-xchange/src/test/java/org/apache/camel/component/xchange/metadata/MetaDataProducerTest.java
@@ -16,9 +16,6 @@
  */
 package org.apache.camel.component.xchange.metadata;
 
-import static org.apache.camel.component.xchange.XChangeConfiguration.HEADER_CURRENCY;
-import static org.apache.camel.component.xchange.XChangeConfiguration.HEADER_CURRENCY_PAIR;
-
 import java.util.List;
 
 import org.apache.camel.builder.RouteBuilder;
@@ -30,6 +27,9 @@ import org.knowm.xchange.currency.CurrencyPair;
 import org.knowm.xchange.dto.meta.CurrencyMetaData;
 import org.knowm.xchange.dto.meta.CurrencyPairMetaData;
 
+import static org.apache.camel.component.xchange.XChangeConfiguration.HEADER_CURRENCY;
+import static org.apache.camel.component.xchange.XChangeConfiguration.HEADER_CURRENCY_PAIR;
+
 public class MetaDataProducerTest extends CamelTestSupport {
 
     @Override
@@ -39,16 +39,16 @@ public class MetaDataProducerTest extends CamelTestSupport {
             public void configure() throws Exception {
                 
                 from("direct:currencies")
-                .to("xchange:binance?service=metadata&method=currencies");
+                    .to("xchange:binance?service=metadata&method=currencies");
                 
                 from("direct:currencyMetaData")
-                .to("xchange:binance?service=metadata&method=currencyMetaData");
+                    .to("xchange:binance?service=metadata&method=currencyMetaData");
                 
                 from("direct:currencyPairs")
-                .to("xchange:binance?service=metadata&method=currencyPairs");
+                    .to("xchange:binance?service=metadata&method=currencyPairs");
                 
                 from("direct:currencyPairMetaData")
-                .to("xchange:binance?service=metadata&method=currencyPairMetaData");
+                    .to("xchange:binance?service=metadata&method=currencyPairMetaData");
             }
         };
     }
diff --git a/components/camel-xmlsecurity/src/test/java/org/apache/camel/component/xmlsecurity/XAdESSignaturePropertiesTest.java b/components/camel-xmlsecurity/src/test/java/org/apache/camel/component/xmlsecurity/XAdESSignaturePropertiesTest.java
index eb64c1a..a3cd093 100644
--- a/components/camel-xmlsecurity/src/test/java/org/apache/camel/component/xmlsecurity/XAdESSignaturePropertiesTest.java
+++ b/components/camel-xmlsecurity/src/test/java/org/apache/camel/component/xmlsecurity/XAdESSignaturePropertiesTest.java
@@ -838,7 +838,7 @@ public class XAdESSignaturePropertiesTest extends CamelTestSupport {
         checkXpath(doc, xpathString, prefix2Namespace, expectedResult, false);
     }
         
-   static void checkXpath(Document doc, String xpathString, final Map<String, String> prefix2Namespace, String expectedResult, boolean startsWith)
+    static void checkXpath(Document doc, String xpathString, final Map<String, String> prefix2Namespace, String expectedResult, boolean startsWith)
             throws XPathExpressionException {
 
         XPathExpression expr = getXpath(xpathString, prefix2Namespace);
diff --git a/components/camel-xmpp/src/test/java/org/apache/camel/component/xmpp/XmppMultiUserChatTest.java b/components/camel-xmpp/src/test/java/org/apache/camel/component/xmpp/XmppMultiUserChatTest.java
index 09cbe1c..7ef83f9 100644
--- a/components/camel-xmpp/src/test/java/org/apache/camel/component/xmpp/XmppMultiUserChatTest.java
+++ b/components/camel-xmpp/src/test/java/org/apache/camel/component/xmpp/XmppMultiUserChatTest.java
@@ -28,10 +28,10 @@ import org.junit.Test;
  */
 public class XmppMultiUserChatTest extends CamelTestSupport {
 
-    private EmbeddedXmppTestServer embeddedXmppTestServer;
     protected MockEndpoint consumerEndpoint;
     protected String body1 = "the first message";
     protected String body2 = "the second message";
+    private EmbeddedXmppTestServer embeddedXmppTestServer;
 
     @Override
     protected JndiRegistry createRegistry() throws Exception {
diff --git a/components/camel-xmpp/src/test/java/org/apache/camel/component/xmpp/XmppRouteChatTest.java b/components/camel-xmpp/src/test/java/org/apache/camel/component/xmpp/XmppRouteChatTest.java
index 61dc10f..2436c41 100644
--- a/components/camel-xmpp/src/test/java/org/apache/camel/component/xmpp/XmppRouteChatTest.java
+++ b/components/camel-xmpp/src/test/java/org/apache/camel/component/xmpp/XmppRouteChatTest.java
@@ -27,11 +27,11 @@ import org.junit.Test;
  */
 public class XmppRouteChatTest extends CamelTestSupport {
 
-    private EmbeddedXmppTestServer embeddedXmppTestServer;
     protected MockEndpoint consumerEndpoint;
     protected MockEndpoint producerEndpoint;
     protected String body1 = "the first message";
     protected String body2 = "the second message";
+    private EmbeddedXmppTestServer embeddedXmppTestServer;
 
     @Override
     protected JndiRegistry createRegistry() throws Exception {
diff --git a/components/camel-xmpp/src/test/java/org/apache/camel/component/xmpp/XmppRouteMultipleProducersSingleConsumerTest.java b/components/camel-xmpp/src/test/java/org/apache/camel/component/xmpp/XmppRouteMultipleProducersSingleConsumerTest.java
index 3c5e3bc..5a8af86 100644
--- a/components/camel-xmpp/src/test/java/org/apache/camel/component/xmpp/XmppRouteMultipleProducersSingleConsumerTest.java
+++ b/components/camel-xmpp/src/test/java/org/apache/camel/component/xmpp/XmppRouteMultipleProducersSingleConsumerTest.java
@@ -26,9 +26,9 @@ import org.junit.Test;
  * @version 
  */
 public class XmppRouteMultipleProducersSingleConsumerTest extends CamelTestSupport {
-    private EmbeddedXmppTestServer embeddedXmppTestServer;
     protected MockEndpoint goodEndpoint;
     protected MockEndpoint badEndpoint;
+    private EmbeddedXmppTestServer embeddedXmppTestServer;
 
     @Override
     protected JndiRegistry createRegistry() throws Exception {
diff --git a/platforms/spring-boot/components-starter/camel-dns-starter/src/test/resources/application.properties b/platforms/spring-boot/components-starter/camel-dns-starter/src/test/resources/application.properties
index 33406d2..71e1678 100644
--- a/platforms/spring-boot/components-starter/camel-dns-starter/src/test/resources/application.properties
+++ b/platforms/spring-boot/components-starter/camel-dns-starter/src/test/resources/application.properties
@@ -1 +1,18 @@
+## ---------------------------------------------------------------------------
+## 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.
+## ---------------------------------------------------------------------------
+
 spring.main.banner-mode=off
diff --git a/platforms/spring-boot/components-starter/camel-ehcache-starter/src/test/resources/application.properties b/platforms/spring-boot/components-starter/camel-ehcache-starter/src/test/resources/application.properties
index 3a5de5b..8d7f9c8 100644
--- a/platforms/spring-boot/components-starter/camel-ehcache-starter/src/test/resources/application.properties
+++ b/platforms/spring-boot/components-starter/camel-ehcache-starter/src/test/resources/application.properties
@@ -1 +1,18 @@
+## ---------------------------------------------------------------------------
+## 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.
+## ---------------------------------------------------------------------------
+
 spring.main.banner-mode = off
diff --git a/platforms/spring-boot/components-starter/camel-etcd-starter/src/test/resources/application.properties b/platforms/spring-boot/components-starter/camel-etcd-starter/src/test/resources/application.properties
index 33406d2..71e1678 100644
--- a/platforms/spring-boot/components-starter/camel-etcd-starter/src/test/resources/application.properties
+++ b/platforms/spring-boot/components-starter/camel-etcd-starter/src/test/resources/application.properties
@@ -1 +1,18 @@
+## ---------------------------------------------------------------------------
+## 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.
+## ---------------------------------------------------------------------------
+
 spring.main.banner-mode=off
diff --git a/platforms/spring-boot/components-starter/camel-hazelcast-starter/src/test/resources/application.properties b/platforms/spring-boot/components-starter/camel-hazelcast-starter/src/test/resources/application.properties
index 3a5de5b..8d7f9c8 100644
--- a/platforms/spring-boot/components-starter/camel-hazelcast-starter/src/test/resources/application.properties
+++ b/platforms/spring-boot/components-starter/camel-hazelcast-starter/src/test/resources/application.properties
@@ -1 +1,18 @@
+## ---------------------------------------------------------------------------
+## 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.
+## ---------------------------------------------------------------------------
+
 spring.main.banner-mode = off
diff --git a/platforms/spring-boot/components-starter/camel-infinispan-starter/src/test/resources/application.properties b/platforms/spring-boot/components-starter/camel-infinispan-starter/src/test/resources/application.properties
index 3a5de5b..8d7f9c8 100644
--- a/platforms/spring-boot/components-starter/camel-infinispan-starter/src/test/resources/application.properties
+++ b/platforms/spring-boot/components-starter/camel-infinispan-starter/src/test/resources/application.properties
@@ -1 +1,18 @@
+## ---------------------------------------------------------------------------
+## 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.
+## ---------------------------------------------------------------------------
+
 spring.main.banner-mode = off
diff --git a/platforms/spring-boot/components-starter/camel-netty-http-starter/src/test/resources/application.properties b/platforms/spring-boot/components-starter/camel-netty-http-starter/src/test/resources/application.properties
index d568c34..5b74b86 100644
--- a/platforms/spring-boot/components-starter/camel-netty-http-starter/src/test/resources/application.properties
+++ b/platforms/spring-boot/components-starter/camel-netty-http-starter/src/test/resources/application.properties
@@ -1 +1 @@
-spring.main.banner-mode = off
\ No newline at end of file
+## ---------------------------------------------------------------------------
## 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.
## ---------------------------------------------------------------------------

spring.main.banner-mode = off
\ No newline at end of file
diff --git a/platforms/spring-boot/components-starter/camel-netty4-http-starter/src/test/resources/application.properties b/platforms/spring-boot/components-starter/camel-netty4-http-starter/src/test/resources/application.properties
index 33406d2..71e1678 100644
--- a/platforms/spring-boot/components-starter/camel-netty4-http-starter/src/test/resources/application.properties
+++ b/platforms/spring-boot/components-starter/camel-netty4-http-starter/src/test/resources/application.properties
@@ -1 +1,18 @@
+## ---------------------------------------------------------------------------
+## 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.
+## ---------------------------------------------------------------------------
+
 spring.main.banner-mode=off
diff --git a/platforms/spring-boot/components-starter/camel-reactive-streams-starter/src/test/resources/application.properties b/platforms/spring-boot/components-starter/camel-reactive-streams-starter/src/test/resources/application.properties
index d568c34..5b74b86 100644
--- a/platforms/spring-boot/components-starter/camel-reactive-streams-starter/src/test/resources/application.properties
+++ b/platforms/spring-boot/components-starter/camel-reactive-streams-starter/src/test/resources/application.properties
@@ -1 +1 @@
-spring.main.banner-mode = off
\ No newline at end of file
+## ---------------------------------------------------------------------------
## 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.
## ---------------------------------------------------------------------------

spring.main.banner-mode = off
\ No newline at end of file
diff --git a/platforms/spring-boot/components-starter/camel-ribbon-starter/src/test/resources/application.properties b/platforms/spring-boot/components-starter/camel-ribbon-starter/src/test/resources/application.properties
index 33406d2..71e1678 100644
--- a/platforms/spring-boot/components-starter/camel-ribbon-starter/src/test/resources/application.properties
+++ b/platforms/spring-boot/components-starter/camel-ribbon-starter/src/test/resources/application.properties
@@ -1 +1,18 @@
+## ---------------------------------------------------------------------------
+## 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.
+## ---------------------------------------------------------------------------
+
 spring.main.banner-mode=off
diff --git a/platforms/spring-boot/components-starter/camel-servlet-starter/src/test/resources/application.properties b/platforms/spring-boot/components-starter/camel-servlet-starter/src/test/resources/application.properties
index 33406d2..71e1678 100644
--- a/platforms/spring-boot/components-starter/camel-servlet-starter/src/test/resources/application.properties
+++ b/platforms/spring-boot/components-starter/camel-servlet-starter/src/test/resources/application.properties
@@ -1 +1,18 @@
+## ---------------------------------------------------------------------------
+## 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.
+## ---------------------------------------------------------------------------
+
 spring.main.banner-mode=off
diff --git a/platforms/spring-boot/components-starter/camel-sql-starter/src/test/resources/application.properties b/platforms/spring-boot/components-starter/camel-sql-starter/src/test/resources/application.properties
index 33406d2..71e1678 100644
--- a/platforms/spring-boot/components-starter/camel-sql-starter/src/test/resources/application.properties
+++ b/platforms/spring-boot/components-starter/camel-sql-starter/src/test/resources/application.properties
@@ -1 +1,18 @@
+## ---------------------------------------------------------------------------
+## 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.
+## ---------------------------------------------------------------------------
+
 spring.main.banner-mode=off

-- 
To stop receiving notification emails like this one, please contact
zregvart@apache.org.