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 2016/03/23 19:59:33 UTC

[13/23] camel git commit: Refactoring Exception Hierarchy. MessagingException is being removed.

Refactoring Exception Hierarchy. 
MessagingException is being removed.



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

Branch: refs/heads/master
Commit: 87fb63ee183759818914e3fa4a0741800abf48c1
Parents: 5537bb5
Author: oalles <oa...@neivi.es>
Authored: Tue Mar 22 13:32:55 2016 +0100
Committer: Claus Ibsen <da...@apache.org>
Committed: Wed Mar 23 18:46:10 2016 +0100

----------------------------------------------------------------------
 .../apache/camel/component/cm/CMProducer.java   | 38 ++++-----
 .../org/apache/camel/component/cm/CMSender.java | 58 +++++++-------
 .../component/cm/CMSenderOneMessageImpl.java    | 13 ++--
 .../cm/exceptions/HostUnavailableException.java | 79 ++++++++++---------
 .../cm/exceptions/MessagingException.java       | 40 ----------
 .../cm/exceptions/XMLConstructionException.java | 78 +++++++++----------
 .../cmresponse/CMResponseException.java         | 82 ++++++++++----------
 .../cmsender/CMResponseExceptionSender.java     | 61 +++++++--------
 .../InsufficientBalanceExceptionSender.java     | 61 +++++++--------
 .../cmsender/InvalidMSISDNExceptionSender.java  | 61 +++++++--------
 .../InvalidProductTokenExceptionSender.java     | 61 +++++++--------
 ...ountFoundForProductTokenExceptionSender.java | 61 +++++++--------
 .../cmsender/NoMessageExceptionSender.java      | 61 +++++++--------
 .../NotPhoneNumberFoundExceptionSender.java     | 61 +++++++--------
 .../cmsender/UnknownErrorExceptionSender.java   | 61 +++++++--------
 .../UnroutableMessageExceptionSender.java       | 61 +++++++--------
 16 files changed, 436 insertions(+), 501 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/main/java/org/apache/camel/component/cm/CMProducer.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/main/java/org/apache/camel/component/cm/CMProducer.java b/components/camel-cm/src/main/java/org/apache/camel/component/cm/CMProducer.java
index b3003cb..e4f5722 100644
--- a/components/camel-cm/src/main/java/org/apache/camel/component/cm/CMProducer.java
+++ b/components/camel-cm/src/main/java/org/apache/camel/component/cm/CMProducer.java
@@ -47,32 +47,26 @@ public class CMProducer extends DefaultProducer {
     }
 
     /**
-     * Producer is a exchange processor. This process is built in several steps.
-     * 1. Validate message receive from client 2. Send validated message to CM
-     * endpoints. 3. Process response from CM endpoints.
+     * Producer is a exchange processor. This process is built in several steps. 1. Validate message receive from client 2. Send validated message to CM endpoints. 3. Process response from CM
+     * endpoints.
      */
     @Override
     public void process(final Exchange exchange) throws Exception {
 
         // Immutable message receive from clients. Throws camel ' s
         // InvalidPayloadException
-        final SMSMessage smsMessage = exchange.getIn()
-                .getMandatoryBody(SMSMessage.class);
+        final SMSMessage smsMessage = exchange.getIn().getMandatoryBody(SMSMessage.class);
 
         // Validates Payload - SMSMessage
-        log.trace("Validating SMSMessage instance provided: {}",
-                smsMessage.toString());
-        final Set<ConstraintViolation<SMSMessage>> constraintViolations = getValidator()
-                .validate(smsMessage);
+        log.trace("Validating SMSMessage instance provided: {}", smsMessage.toString());
+        final Set<ConstraintViolation<SMSMessage>> constraintViolations = getValidator().validate(smsMessage);
         if (constraintViolations.size() > 0) {
             final StringBuffer msg = new StringBuffer();
             for (final ConstraintViolation<SMSMessage> cv : constraintViolations) {
-                msg.append(String.format("- Invalid value for %s: %s",
-                        cv.getPropertyPath().toString(), cv.getMessage()));
+                msg.append(String.format("- Invalid value for %s: %s", cv.getPropertyPath().toString(), cv.getMessage()));
             }
             log.debug(msg.toString());
-            throw new InvalidPayloadRuntimeException(exchange,
-                    SMSMessage.class);
+            throw new InvalidPayloadRuntimeException(exchange, SMSMessage.class);
         }
         log.trace("SMSMessage instance is valid: {}", smsMessage.toString());
 
@@ -80,26 +74,23 @@ public class CMProducer extends DefaultProducer {
         // CMMessage
         // This is the instance we will use to build the XML document to be
         // sent to CM SMS GW.
-        final CMMessage cmMessage = new CMMessage(smsMessage.getPhoneNumber(),
-                smsMessage.getMessage());
+        final CMMessage cmMessage = new CMMessage(smsMessage.getPhoneNumber(), smsMessage.getMessage());
         log.debug("CMMessage instance build from valid SMSMessage instance");
 
         if (smsMessage.getFrom() == null || smsMessage.getFrom().isEmpty()) {
             String df = getConfiguration().getDefaultFrom();
             cmMessage.setSender(df);
-            log.debug("Dynamic sender is set to default dynamic sender: {}",
-                    df);
+            log.debug("Dynamic sender is set to default dynamic sender: {}", df);
         }
 
         // Remember, this can be null.
         cmMessage.setIdAsString(smsMessage.getId());
 
         // Unicode and multipart
-        cmMessage.setUnicodeAndMultipart(
-                getConfiguration().getDefaultMaxNumberOfParts());
+        cmMessage.setUnicodeAndMultipart(getConfiguration().getDefaultMaxNumberOfParts());
 
         // 2. Send a validated sms message to CM endpoints
-        // throws MessagingException for abnormal situations.
+        //  for abnormal situations.
         sender.send(cmMessage);
 
         log.debug("Request accepted by CM Host: {}", cmMessage.toString());
@@ -118,13 +109,10 @@ public class CMProducer extends DefaultProducer {
         if (configuration.isTestConnectionOnStartup()) {
             try {
                 log.debug("Checking connection - {}", getEndpoint().getCMUrl());
-                HttpClientBuilder.create().build()
-                        .execute(new HttpHead(getEndpoint().getCMUrl()));
+                HttpClientBuilder.create().build().execute(new HttpHead(getEndpoint().getCMUrl()));
                 log.debug("Connection to {}: OK", getEndpoint().getCMUrl());
             } catch (final Exception e) {
-                log.debug("Connection to {}: NOT AVAILABLE",
-                        getEndpoint().getCMUrl());
-                throw new HostUnavailableException(e);
+                throw new HostUnavailableException(String.format("Connection to %s: NOT AVAILABLE", getEndpoint().getCMUrl()), e);
             }
         }
 

http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/main/java/org/apache/camel/component/cm/CMSender.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/main/java/org/apache/camel/component/cm/CMSender.java b/components/camel-cm/src/main/java/org/apache/camel/component/cm/CMSender.java
index d3eceeb..661f4dd 100644
--- a/components/camel-cm/src/main/java/org/apache/camel/component/cm/CMSender.java
+++ b/components/camel-cm/src/main/java/org/apache/camel/component/cm/CMSender.java
@@ -1,30 +1,28 @@
-/**
- * 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.cm;
-
-import org.apache.camel.component.cm.exceptions.MessagingException;
-
-/**
- * Sends a validated sms message to CM endpoints
- */
-public interface CMSender {
-
-    /**
-     * Sends a validated sms message to CM Endpoints.
-     */
-    void send(CMMessage cmMessage) throws MessagingException;
-}
+/**
+ * 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.cm;
+
+/**
+ * Sends a validated sms message to CM endpoints
+ */
+public interface CMSender {
+
+    /**
+     * Sends a validated sms message to CM Endpoints.
+     */
+    void send(CMMessage cmMessage);
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/main/java/org/apache/camel/component/cm/CMSenderOneMessageImpl.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/main/java/org/apache/camel/component/cm/CMSenderOneMessageImpl.java b/components/camel-cm/src/main/java/org/apache/camel/component/cm/CMSenderOneMessageImpl.java
index 101905e..07e0e14 100644
--- a/components/camel-cm/src/main/java/org/apache/camel/component/cm/CMSenderOneMessageImpl.java
+++ b/components/camel-cm/src/main/java/org/apache/camel/component/cm/CMSenderOneMessageImpl.java
@@ -41,7 +41,6 @@ import org.w3c.dom.Element;
 import org.w3c.dom.Text;
 
 import org.apache.camel.component.cm.exceptions.CMDirectException;
-import org.apache.camel.component.cm.exceptions.MessagingException;
 import org.apache.camel.component.cm.exceptions.XMLConstructionException;
 import org.apache.camel.component.cm.exceptions.cmresponse.CMResponseException;
 import org.apache.camel.component.cm.exceptions.cmresponse.InsufficientBalanceException;
@@ -71,17 +70,17 @@ public class CMSenderOneMessageImpl implements CMSender {
     }
 
     /**
-     * Sends a previously validated SMSMessage to CM endpoint
+     * Sends a message to CM endpoints. 1. CMMessage instance is going to be marshalled to xml. 2. Post request xml string to CMEndpoint.
      */
     @Override
-    public void send(final CMMessage cmMessage) throws MessagingException {
+    public void send(final CMMessage cmMessage) {
 
         // See: Check https://dashboard.onlinesmsgateway.com/docs for responses
 
         // 1.Construct XML. Throws XMLConstructionException
         final String xml = createXml(cmMessage);
 
-        // 2. Try to send to CM SMS Provider ...Throws CMResponse
+        // 2. Try to send to CM SMS Provider ...Throws CMResponseException
         doHttpPost(url, xml);
     }
 
@@ -245,11 +244,11 @@ public class CMSenderOneMessageImpl implements CMSender {
         } catch (final IOException io) {
             throw new CMDirectException(io);
         } catch (Throwable t) {
-            if (!(t instanceof MessagingException)) {
+            if (!(t instanceof CMDirectException)) {
                 // Chain it
-                t = new MessagingException(t);
+                t = new CMDirectException(t);
             }
-            throw (MessagingException) t;
+            throw (CMDirectException) t;
         }
     }
 }

http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/HostUnavailableException.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/HostUnavailableException.java b/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/HostUnavailableException.java
index 4e1348c..73bf0d0 100644
--- a/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/HostUnavailableException.java
+++ b/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/HostUnavailableException.java
@@ -1,40 +1,39 @@
-/**
- * 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.cm.exceptions;
-
-public class HostUnavailableException extends MessagingException {
-
-    public HostUnavailableException() {
-    }
-
-    public HostUnavailableException(final String message) {
-        super(message);
-    }
-
-    public HostUnavailableException(final Throwable cause) {
-        super(cause);
-    }
-
-    public HostUnavailableException(final String message, final Throwable cause) {
-        super(message, cause);
-    }
-
-    public HostUnavailableException(final String message, final Throwable cause,
-            final boolean enableSuppression, final boolean writableStackTrace) {
-        super(message, cause, enableSuppression, writableStackTrace);
-    }
-}
+/**
+ * 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.cm.exceptions;
+
+public class HostUnavailableException extends CMDirectException {
+
+    public HostUnavailableException() {
+    }
+
+    public HostUnavailableException(final String message) {
+        super(message);
+    }
+
+    public HostUnavailableException(final Throwable cause) {
+        super(cause);
+    }
+
+    public HostUnavailableException(final String message, final Throwable cause) {
+        super(message, cause);
+    }
+
+    public HostUnavailableException(final String message, final Throwable cause, final boolean enableSuppression, final boolean writableStackTrace) {
+        super(message, cause, enableSuppression, writableStackTrace);
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/MessagingException.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/MessagingException.java b/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/MessagingException.java
deleted file mode 100644
index ddf9c87..0000000
--- a/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/MessagingException.java
+++ /dev/null
@@ -1,40 +0,0 @@
-/**
- * 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.cm.exceptions;
-
-public class MessagingException extends CMDirectException {
-
-    public MessagingException() {
-    }
-
-    public MessagingException(final String message) {
-        super(message);
-    }
-
-    public MessagingException(final Throwable cause) {
-        super(cause);
-    }
-
-    public MessagingException(final String message, final Throwable cause) {
-        super(message, cause);
-    }
-
-    public MessagingException(final String message, final Throwable cause,
-            final boolean enableSuppression, final boolean writableStackTrace) {
-        super(message, cause, enableSuppression, writableStackTrace);
-    }
-}

http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/XMLConstructionException.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/XMLConstructionException.java b/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/XMLConstructionException.java
index a6dae02..5086e70 100644
--- a/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/XMLConstructionException.java
+++ b/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/XMLConstructionException.java
@@ -1,39 +1,39 @@
-/**
- * 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.cm.exceptions;
-
-public class XMLConstructionException extends MessagingException {
-
-    public XMLConstructionException() {
-    }
-
-    public XMLConstructionException(final String message) {
-        super(message);
-    }
-
-    public XMLConstructionException(final Throwable cause) {
-        super(cause);
-    }
-
-    public XMLConstructionException(final String message, final Throwable cause) {
-        super(message, cause);
-    }
-
-    public XMLConstructionException(final String message, final Throwable cause, final boolean enableSuppression, final boolean writableStackTrace) {
-        super(message, cause, enableSuppression, writableStackTrace);
-    }
-}
+/**
+ * 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.cm.exceptions;
+
+public class XMLConstructionException extends CMDirectException {
+
+    public XMLConstructionException() {
+    }
+
+    public XMLConstructionException(final String message) {
+        super(message);
+    }
+
+    public XMLConstructionException(final Throwable cause) {
+        super(cause);
+    }
+
+    public XMLConstructionException(final String message, final Throwable cause) {
+        super(message, cause);
+    }
+
+    public XMLConstructionException(final String message, final Throwable cause, final boolean enableSuppression, final boolean writableStackTrace) {
+        super(message, cause, enableSuppression, writableStackTrace);
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/cmresponse/CMResponseException.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/cmresponse/CMResponseException.java b/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/cmresponse/CMResponseException.java
index 7251c51..4ed4f6e 100644
--- a/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/cmresponse/CMResponseException.java
+++ b/components/camel-cm/src/main/java/org/apache/camel/component/cm/exceptions/cmresponse/CMResponseException.java
@@ -1,41 +1,41 @@
-/**
- * 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.cm.exceptions.cmresponse;
-
-import org.apache.camel.component.cm.exceptions.MessagingException;
-
-public class CMResponseException extends MessagingException {
-
-    public CMResponseException() {
-    }
-
-    public CMResponseException(final String message) {
-        super(message);
-    }
-
-    public CMResponseException(final Throwable cause) {
-        super(cause);
-    }
-
-    public CMResponseException(final String message, final Throwable cause) {
-        super(message, cause);
-    }
-
-    public CMResponseException(final String message, final Throwable cause, final boolean enableSuppression, final boolean writableStackTrace) {
-        super(message, cause, enableSuppression, writableStackTrace);
-    }
-}
+/**
+ * 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.cm.exceptions.cmresponse;
+
+import org.apache.camel.component.cm.exceptions.CMDirectException;
+
+public class CMResponseException extends CMDirectException {
+
+    public CMResponseException() {
+    }
+
+    public CMResponseException(final String message) {
+        super(message);
+    }
+
+    public CMResponseException(final Throwable cause) {
+        super(cause);
+    }
+
+    public CMResponseException(final String message, final Throwable cause) {
+        super(message, cause);
+    }
+
+    public CMResponseException(final String message, final Throwable cause, final boolean enableSuppression, final boolean writableStackTrace) {
+        super(message, cause, enableSuppression, writableStackTrace);
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/CMResponseExceptionSender.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/CMResponseExceptionSender.java b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/CMResponseExceptionSender.java
index f116f28..fe23ae9 100644
--- a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/CMResponseExceptionSender.java
+++ b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/CMResponseExceptionSender.java
@@ -1,31 +1,30 @@
-/**
- * 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.cm.test.mocks.cmsender;
-
-import org.apache.camel.component.cm.CMMessage;
-import org.apache.camel.component.cm.CMSender;
-import org.apache.camel.component.cm.exceptions.MessagingException;
-import org.apache.camel.component.cm.exceptions.cmresponse.CMResponseException;
-
-public class CMResponseExceptionSender implements CMSender {
-
-    @Override
-    public void send(CMMessage cmMessage) throws MessagingException {
-        throw new CMResponseException();
-    }
-
-}
+/**
+ * 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.cm.test.mocks.cmsender;
+
+import org.apache.camel.component.cm.CMMessage;
+import org.apache.camel.component.cm.CMSender;
+import org.apache.camel.component.cm.exceptions.cmresponse.CMResponseException;
+
+public class CMResponseExceptionSender implements CMSender {
+
+    @Override
+    public void send(CMMessage cmMessage)  {
+        throw new CMResponseException();
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/InsufficientBalanceExceptionSender.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/InsufficientBalanceExceptionSender.java b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/InsufficientBalanceExceptionSender.java
index 03f940d..413df91 100644
--- a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/InsufficientBalanceExceptionSender.java
+++ b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/InsufficientBalanceExceptionSender.java
@@ -1,31 +1,30 @@
-/**
- * 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.cm.test.mocks.cmsender;
-
-import org.apache.camel.component.cm.CMMessage;
-import org.apache.camel.component.cm.CMSender;
-import org.apache.camel.component.cm.exceptions.MessagingException;
-import org.apache.camel.component.cm.exceptions.cmresponse.InsufficientBalanceException;
-
-public class InsufficientBalanceExceptionSender implements CMSender {
-
-    @Override
-    public void send(CMMessage cmMessage) throws MessagingException {
-        throw new InsufficientBalanceException();
-    }
-
-}
+/**
+ * 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.cm.test.mocks.cmsender;
+
+import org.apache.camel.component.cm.CMMessage;
+import org.apache.camel.component.cm.CMSender;
+import org.apache.camel.component.cm.exceptions.cmresponse.InsufficientBalanceException;
+
+public class InsufficientBalanceExceptionSender implements CMSender {
+
+    @Override
+    public void send(CMMessage cmMessage) {
+        throw new InsufficientBalanceException();
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/InvalidMSISDNExceptionSender.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/InvalidMSISDNExceptionSender.java b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/InvalidMSISDNExceptionSender.java
index b45d113..09107d5 100644
--- a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/InvalidMSISDNExceptionSender.java
+++ b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/InvalidMSISDNExceptionSender.java
@@ -1,31 +1,30 @@
-/**
- * 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.cm.test.mocks.cmsender;
-
-import org.apache.camel.component.cm.CMMessage;
-import org.apache.camel.component.cm.CMSender;
-import org.apache.camel.component.cm.exceptions.MessagingException;
-import org.apache.camel.component.cm.exceptions.cmresponse.InvalidMSISDNException;
-
-public class InvalidMSISDNExceptionSender implements CMSender {
-
-    @Override
-    public void send(CMMessage cmMessage) throws MessagingException {
-        throw new InvalidMSISDNException();
-    }
-
-}
+/**
+ * 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.cm.test.mocks.cmsender;
+
+import org.apache.camel.component.cm.CMMessage;
+import org.apache.camel.component.cm.CMSender;
+import org.apache.camel.component.cm.exceptions.cmresponse.InvalidMSISDNException;
+
+public class InvalidMSISDNExceptionSender implements CMSender {
+
+    @Override
+    public void send(CMMessage cmMessage)  {
+        throw new InvalidMSISDNException();
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/InvalidProductTokenExceptionSender.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/InvalidProductTokenExceptionSender.java b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/InvalidProductTokenExceptionSender.java
index 7ff256c..102cbf4 100644
--- a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/InvalidProductTokenExceptionSender.java
+++ b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/InvalidProductTokenExceptionSender.java
@@ -1,31 +1,30 @@
-/**
- * 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.cm.test.mocks.cmsender;
-
-import org.apache.camel.component.cm.CMMessage;
-import org.apache.camel.component.cm.CMSender;
-import org.apache.camel.component.cm.exceptions.MessagingException;
-import org.apache.camel.component.cm.exceptions.cmresponse.InvalidProductTokenException;
-
-public class InvalidProductTokenExceptionSender implements CMSender {
-
-    @Override
-    public void send(CMMessage cmMessage) throws MessagingException {
-        throw new InvalidProductTokenException();
-    }
-
-}
+/**
+ * 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.cm.test.mocks.cmsender;
+
+import org.apache.camel.component.cm.CMMessage;
+import org.apache.camel.component.cm.CMSender;
+import org.apache.camel.component.cm.exceptions.cmresponse.InvalidProductTokenException;
+
+public class InvalidProductTokenExceptionSender implements CMSender {
+
+    @Override
+    public void send(CMMessage cmMessage)  {
+        throw new InvalidProductTokenException();
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/NoAccountFoundForProductTokenExceptionSender.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/NoAccountFoundForProductTokenExceptionSender.java b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/NoAccountFoundForProductTokenExceptionSender.java
index 8b57406..7fb4c2b 100644
--- a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/NoAccountFoundForProductTokenExceptionSender.java
+++ b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/NoAccountFoundForProductTokenExceptionSender.java
@@ -1,31 +1,30 @@
-/**
- * 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.cm.test.mocks.cmsender;
-
-import org.apache.camel.component.cm.CMMessage;
-import org.apache.camel.component.cm.CMSender;
-import org.apache.camel.component.cm.exceptions.MessagingException;
-import org.apache.camel.component.cm.exceptions.cmresponse.NoAccountFoundForProductTokenException;
-
-public class NoAccountFoundForProductTokenExceptionSender implements CMSender {
-
-    @Override
-    public void send(CMMessage cmMessage) throws MessagingException {
-        throw new NoAccountFoundForProductTokenException();
-    }
-
-}
+/**
+ * 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.cm.test.mocks.cmsender;
+
+import org.apache.camel.component.cm.CMMessage;
+import org.apache.camel.component.cm.CMSender;
+import org.apache.camel.component.cm.exceptions.cmresponse.NoAccountFoundForProductTokenException;
+
+public class NoAccountFoundForProductTokenExceptionSender implements CMSender {
+
+    @Override
+    public void send(CMMessage cmMessage)  {
+        throw new NoAccountFoundForProductTokenException();
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/NoMessageExceptionSender.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/NoMessageExceptionSender.java b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/NoMessageExceptionSender.java
index 9520934..6e27dcf 100644
--- a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/NoMessageExceptionSender.java
+++ b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/NoMessageExceptionSender.java
@@ -1,31 +1,30 @@
-/**
- * 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.cm.test.mocks.cmsender;
-
-import org.apache.camel.component.cm.CMMessage;
-import org.apache.camel.component.cm.CMSender;
-import org.apache.camel.component.cm.exceptions.MessagingException;
-import org.apache.camel.component.cm.exceptions.cmresponse.NoMessageException;
-
-public class NoMessageExceptionSender implements CMSender {
-
-    @Override
-    public void send(CMMessage cmMessage) throws MessagingException {
-        throw new NoMessageException();
-    }
-
-}
+/**
+ * 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.cm.test.mocks.cmsender;
+
+import org.apache.camel.component.cm.CMMessage;
+import org.apache.camel.component.cm.CMSender;
+import org.apache.camel.component.cm.exceptions.cmresponse.NoMessageException;
+
+public class NoMessageExceptionSender implements CMSender {
+
+    @Override
+    public void send(CMMessage cmMessage) {
+        throw new NoMessageException();
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/NotPhoneNumberFoundExceptionSender.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/NotPhoneNumberFoundExceptionSender.java b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/NotPhoneNumberFoundExceptionSender.java
index a85639b..162ef38 100644
--- a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/NotPhoneNumberFoundExceptionSender.java
+++ b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/NotPhoneNumberFoundExceptionSender.java
@@ -1,31 +1,30 @@
-/**
- * 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.cm.test.mocks.cmsender;
-
-import org.apache.camel.component.cm.CMMessage;
-import org.apache.camel.component.cm.CMSender;
-import org.apache.camel.component.cm.exceptions.MessagingException;
-import org.apache.camel.component.cm.exceptions.cmresponse.NotPhoneNumberFoundException;
-
-public class NotPhoneNumberFoundExceptionSender implements CMSender {
-
-    @Override
-    public void send(CMMessage cmMessage) throws MessagingException {
-        throw new NotPhoneNumberFoundException();
-    }
-
-}
+/**
+ * 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.cm.test.mocks.cmsender;
+
+import org.apache.camel.component.cm.CMMessage;
+import org.apache.camel.component.cm.CMSender;
+import org.apache.camel.component.cm.exceptions.cmresponse.NotPhoneNumberFoundException;
+
+public class NotPhoneNumberFoundExceptionSender implements CMSender {
+
+    @Override
+    public void send(CMMessage cmMessage)  {
+        throw new NotPhoneNumberFoundException();
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/UnknownErrorExceptionSender.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/UnknownErrorExceptionSender.java b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/UnknownErrorExceptionSender.java
index d20723f..33e4565 100644
--- a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/UnknownErrorExceptionSender.java
+++ b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/UnknownErrorExceptionSender.java
@@ -1,31 +1,30 @@
-/**
- * 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.cm.test.mocks.cmsender;
-
-import org.apache.camel.component.cm.CMMessage;
-import org.apache.camel.component.cm.CMSender;
-import org.apache.camel.component.cm.exceptions.MessagingException;
-import org.apache.camel.component.cm.exceptions.cmresponse.UnknownErrorException;
-
-public class UnknownErrorExceptionSender implements CMSender {
-
-    @Override
-    public void send(CMMessage cmMessage) throws MessagingException {
-        throw new UnknownErrorException();
-    }
-
-}
+/**
+ * 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.cm.test.mocks.cmsender;
+
+import org.apache.camel.component.cm.CMMessage;
+import org.apache.camel.component.cm.CMSender;
+import org.apache.camel.component.cm.exceptions.cmresponse.UnknownErrorException;
+
+public class UnknownErrorExceptionSender implements CMSender {
+
+    @Override
+    public void send(CMMessage cmMessage) {
+        throw new UnknownErrorException();
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/87fb63ee/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/UnroutableMessageExceptionSender.java
----------------------------------------------------------------------
diff --git a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/UnroutableMessageExceptionSender.java b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/UnroutableMessageExceptionSender.java
index 3b6af1e..3657ac7 100644
--- a/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/UnroutableMessageExceptionSender.java
+++ b/components/camel-cm/src/test/java/org/apache/camel/component/cm/test/mocks/cmsender/UnroutableMessageExceptionSender.java
@@ -1,31 +1,30 @@
-/**
- * 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.cm.test.mocks.cmsender;
-
-import org.apache.camel.component.cm.CMMessage;
-import org.apache.camel.component.cm.CMSender;
-import org.apache.camel.component.cm.exceptions.MessagingException;
-import org.apache.camel.component.cm.exceptions.cmresponse.UnroutableMessageException;
-
-public class UnroutableMessageExceptionSender implements CMSender {
-
-    @Override
-    public void send(CMMessage cmMessage) throws MessagingException {
-        throw new UnroutableMessageException();
-    }
-
-}
+/**
+ * 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.cm.test.mocks.cmsender;
+
+import org.apache.camel.component.cm.CMMessage;
+import org.apache.camel.component.cm.CMSender;
+import org.apache.camel.component.cm.exceptions.cmresponse.UnroutableMessageException;
+
+public class UnroutableMessageExceptionSender implements CMSender {
+
+    @Override
+    public void send(CMMessage cmMessage)  {
+        throw new UnroutableMessageException();
+    }
+
+}