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 2013/06/05 17:12:46 UTC

[02/11] CAMEL-6428: Fixed CS

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/AbstractRestProcessor.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/AbstractRestProcessor.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/AbstractRestProcessor.java
index 1e40d18..82e2c14 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/AbstractRestProcessor.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/AbstractRestProcessor.java
@@ -16,22 +16,31 @@
  */
 package org.apache.camel.component.salesforce.internal.processor;
 
+import java.io.InputStream;
+import java.lang.reflect.InvocationTargetException;
+import java.lang.reflect.Method;
+import java.util.Map;
+
 import org.apache.camel.AsyncCallback;
 import org.apache.camel.Exchange;
-import org.apache.camel.util.ServiceHelper;
 import org.apache.camel.component.salesforce.SalesforceEndpoint;
 import org.apache.camel.component.salesforce.api.SalesforceException;
 import org.apache.camel.component.salesforce.api.dto.AbstractSObjectBase;
 import org.apache.camel.component.salesforce.internal.PayloadFormat;
 import org.apache.camel.component.salesforce.internal.client.DefaultRestClient;
 import org.apache.camel.component.salesforce.internal.client.RestClient;
+import org.apache.camel.util.ServiceHelper;
 
-import java.io.InputStream;
-import java.lang.reflect.InvocationTargetException;
-import java.lang.reflect.Method;
-import java.util.Map;
-
-import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.*;
+import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.API_VERSION;
+import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.SOBJECT_BLOB_FIELD_NAME;
+import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.SOBJECT_CLASS;
+import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.SOBJECT_EXT_ID_NAME;
+import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.SOBJECT_EXT_ID_VALUE;
+import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.SOBJECT_FIELDS;
+import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.SOBJECT_ID;
+import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.SOBJECT_NAME;
+import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.SOBJECT_QUERY;
+import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.SOBJECT_SEARCH;
 
 public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor {
 
@@ -46,7 +55,7 @@ public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor
         final PayloadFormat payloadFormat = endpoint.getConfiguration().getPayloadFormat();
 
         this.restClient = new DefaultRestClient(httpClient, endpointConfigMap.get(API_VERSION),
-            payloadFormat.toString().toLowerCase() , session);
+                payloadFormat.toString().toLowerCase(), session);
 
         this.classMap = endpoint.getComponent().getClassMap();
     }
@@ -130,8 +139,7 @@ public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor
                     });
                     break;
 
-                case GET_SOBJECT:
-                {
+                case GET_SOBJECT: {
                     String sObjectIdValue;
                     // determine parameters from input AbstractSObject
                     final AbstractSObjectBase sObjectBase = exchange.getIn().getBody(AbstractSObjectBase.class);
@@ -165,8 +173,7 @@ public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor
                     break;
                 }
 
-                case CREATE_SOBJECT:
-                {
+                case CREATE_SOBJECT: {
                     // determine parameters from input AbstractSObject
                     AbstractSObjectBase sObjectBase = exchange.getIn().getBody(AbstractSObjectBase.class);
                     if (sObjectBase != null) {
@@ -176,18 +183,17 @@ public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor
                     }
 
                     restClient.createSObject(sObjectName, getRequestStream(exchange),
-                        new RestClient.ResponseCallback() {
-                        @Override
-                        public void onResponse(InputStream response, SalesforceException exception) {
-                            processResponse(exchange, response, exception, callback);
-                        }
-                    });
+                            new RestClient.ResponseCallback() {
+                                @Override
+                                public void onResponse(InputStream response, SalesforceException exception) {
+                                    processResponse(exchange, response, exception, callback);
+                                }
+                            });
 
                     break;
                 }
 
-                case UPDATE_SOBJECT:
-                {
+                case UPDATE_SOBJECT: {
                     // determine parameters from input AbstractSObject
                     final AbstractSObjectBase sObjectBase = exchange.getIn().getBody(AbstractSObjectBase.class);
                     String sObjectId;
@@ -204,19 +210,18 @@ public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor
 
                     final String finalsObjectId = sObjectId;
                     restClient.updateSObject(sObjectName, sObjectId, getRequestStream(exchange),
-                        new RestClient.ResponseCallback() {
-                            @Override
-                            public void onResponse(InputStream response, SalesforceException exception) {
-                                processResponse(exchange, response, exception, callback);
-                                restoreFields(exchange, sObjectBase, finalsObjectId, null, null);
-                            }
-                        });
+                            new RestClient.ResponseCallback() {
+                                @Override
+                                public void onResponse(InputStream response, SalesforceException exception) {
+                                    processResponse(exchange, response, exception, callback);
+                                    restoreFields(exchange, sObjectBase, finalsObjectId, null, null);
+                                }
+                            });
 
                     break;
                 }
 
-                case DELETE_SOBJECT:
-                {
+                case DELETE_SOBJECT: {
                     // determine parameters from input AbstractSObject
                     final AbstractSObjectBase sObjectBase = exchange.getIn().getBody(AbstractSObjectBase.class);
                     String sObjectIdValue;
@@ -239,12 +244,11 @@ public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor
                     break;
                 }
 
-                case GET_SOBJECT_WITH_ID:
-                {
+                case GET_SOBJECT_WITH_ID: {
                     Object oldValue = null;
                     String sObjectExtIdValue;
                     final String sObjectExtIdName = getParameter(SOBJECT_EXT_ID_NAME,
-                        exchange, IGNORE_BODY, NOT_OPTIONAL);
+                            exchange, IGNORE_BODY, NOT_OPTIONAL);
 
                     // determine parameters from input AbstractSObject
                     final AbstractSObjectBase sObjectBase = exchange.getIn().getBody(AbstractSObjectBase.class);
@@ -262,22 +266,21 @@ public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor
 
                     final Object finalOldValue = oldValue;
                     restClient.getSObjectWithId(sObjectName, sObjectExtIdName, sObjectExtIdValue,
-                        new RestClient.ResponseCallback() {
-                            @Override
-                            public void onResponse(InputStream response, SalesforceException exception) {
-                                processResponse(exchange, response, exception, callback);
-                                restoreFields(exchange, sObjectBase, null, sObjectExtIdName, finalOldValue);
-                            }
-                        });
+                            new RestClient.ResponseCallback() {
+                                @Override
+                                public void onResponse(InputStream response, SalesforceException exception) {
+                                    processResponse(exchange, response, exception, callback);
+                                    restoreFields(exchange, sObjectBase, null, sObjectExtIdName, finalOldValue);
+                                }
+                            });
 
                     break;
                 }
 
-                case UPSERT_SOBJECT:
-                {
+                case UPSERT_SOBJECT: {
                     String sObjectExtIdValue;
                     final String sObjectExtIdName = getParameter(SOBJECT_EXT_ID_NAME, exchange,
-                        IGNORE_BODY, NOT_OPTIONAL);
+                            IGNORE_BODY, NOT_OPTIONAL);
 
                     // determine parameters from input AbstractSObject
                     Object oldValue = null;
@@ -295,7 +298,7 @@ public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor
 
                     final Object finalOldValue = oldValue;
                     restClient.upsertSObject(sObjectName, sObjectExtIdName, sObjectExtIdValue,
-                        getRequestStream(exchange), new RestClient.ResponseCallback() {
+                            getRequestStream(exchange), new RestClient.ResponseCallback() {
                         @Override
                         public void onResponse(InputStream response, SalesforceException exception) {
                             processResponse(exchange, response, exception, callback);
@@ -306,8 +309,7 @@ public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor
                     break;
                 }
 
-                case DELETE_SOBJECT_WITH_ID:
-                {
+                case DELETE_SOBJECT_WITH_ID: {
                     final String sObjectExtIdName = getParameter(SOBJECT_EXT_ID_NAME, exchange, IGNORE_BODY, NOT_OPTIONAL);
 
                     // determine parameters from input AbstractSObject
@@ -325,22 +327,21 @@ public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor
 
                     final Object finalOldValue = oldValue;
                     restClient.deleteSObjectWithId(sObjectName, sObjectExtIdName, sObjectExtIdValue,
-                        new RestClient.ResponseCallback() {
-                            @Override
-                            public void onResponse(InputStream response, SalesforceException exception) {
-                                processResponse(exchange, response, exception, callback);
-                                restoreFields(exchange, sObjectBase, null, sObjectExtIdName, finalOldValue);
-                            }
-                        });
+                            new RestClient.ResponseCallback() {
+                                @Override
+                                public void onResponse(InputStream response, SalesforceException exception) {
+                                    processResponse(exchange, response, exception, callback);
+                                    restoreFields(exchange, sObjectBase, null, sObjectExtIdName, finalOldValue);
+                                }
+                            });
 
                     break;
                 }
 
-                case GET_BLOB_FIELD:
-                {
+                case GET_BLOB_FIELD: {
                     // get blob field name
                     final String sObjectBlobFieldName = getParameter(SOBJECT_BLOB_FIELD_NAME,
-                        exchange, IGNORE_BODY, NOT_OPTIONAL);
+                            exchange, IGNORE_BODY, NOT_OPTIONAL);
 
                     // determine parameters from input AbstractSObject
                     final AbstractSObjectBase sObjectBase = exchange.getIn().getBody(AbstractSObjectBase.class);
@@ -355,13 +356,13 @@ public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor
                     final String sObjectId = sObjectIdValue;
 
                     restClient.getBlobField(sObjectName, sObjectId, sObjectBlobFieldName,
-                        new RestClient.ResponseCallback() {
-                            @Override
-                            public void onResponse(InputStream response, SalesforceException exception) {
-                                processResponse(exchange, response, exception, callback);
-                                restoreFields(exchange, sObjectBase, sObjectId, null, null);
-                            }
-                        });
+                            new RestClient.ResponseCallback() {
+                                @Override
+                                public void onResponse(InputStream response, SalesforceException exception) {
+                                    processResponse(exchange, response, exception, callback);
+                                    restoreFields(exchange, sObjectBase, sObjectId, null, null);
+                                }
+                            });
                     break;
                 }
 
@@ -409,16 +410,16 @@ public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor
 
         } catch (SalesforceException e) {
             exchange.setException(new SalesforceException(
-                String.format("Error processing %s: [%s] \"%s\"",
-                    operationName, e.getStatusCode(), e.getMessage()),
-                e));
+                    String.format("Error processing %s: [%s] \"%s\"",
+                            operationName, e.getStatusCode(), e.getMessage()),
+                    e));
             callback.done(true);
             return true;
         } catch (RuntimeException e) {
             exchange.setException(new SalesforceException(
-                String.format("Unexpected Error processing %s: \"%s\"",
-                    operationName, e.getMessage()),
-                e));
+                    String.format("Unexpected Error processing %s: \"%s\"",
+                            operationName, e.getMessage()),
+                    e));
             callback.done(true);
             return true;
         }
@@ -454,19 +455,19 @@ public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor
             setMethod.invoke(sObjectBase, value);
         } catch (NoSuchMethodException e) {
             throw new SalesforceException(
-                String.format("SObject %s does not have a field %s",
-                    sObjectBase.getClass().getName(), name),
-                e);
+                    String.format("SObject %s does not have a field %s",
+                            sObjectBase.getClass().getName(), name),
+                    e);
         } catch (InvocationTargetException e) {
             throw new SalesforceException(
-                String.format("Error setting value %s.%s",
-                    sObjectBase.getClass().getSimpleName(), name),
-                e);
+                    String.format("Error setting value %s.%s",
+                            sObjectBase.getClass().getSimpleName(), name),
+                    e);
         } catch (IllegalAccessException e) {
             throw new SalesforceException(
-                String.format("Error accessing value %s.%s",
-                    sObjectBase.getClass().getSimpleName(), name),
-                e);
+                    String.format("Error accessing value %s.%s",
+                            sObjectBase.getClass().getSimpleName(), name),
+                    e);
         }
     }
 
@@ -478,24 +479,24 @@ public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor
 
             // clear the value with the set method
             Method setMethod = sObjectBase.getClass().getMethod("set" + propertyName, getMethod.getReturnType());
-            setMethod.invoke(sObjectBase, new Object[] { null });
+            setMethod.invoke(sObjectBase, new Object[]{null});
 
             return value;
         } catch (NoSuchMethodException e) {
             throw new SalesforceException(
-                String.format("SObject %s does not have a field %s",
-                    sObjectBase.getClass().getSimpleName(), propertyName),
-                e);
+                    String.format("SObject %s does not have a field %s",
+                            sObjectBase.getClass().getSimpleName(), propertyName),
+                    e);
         } catch (InvocationTargetException e) {
             throw new SalesforceException(
-                String.format("Error getting/setting value %s.%s",
-                    sObjectBase.getClass().getSimpleName(), propertyName),
-                e);
+                    String.format("Error getting/setting value %s.%s",
+                            sObjectBase.getClass().getSimpleName(), propertyName),
+                    e);
         } catch (IllegalAccessException e) {
             throw new SalesforceException(
-                String.format("Error accessing value %s.%s",
-                    sObjectBase.getClass().getSimpleName(), propertyName),
-                e);
+                    String.format("Error accessing value %s.%s",
+                            sObjectBase.getClass().getSimpleName(), propertyName),
+                    e);
         }
     }
 
@@ -521,12 +522,12 @@ public abstract class AbstractRestProcessor extends AbstractSalesforceProcessor
             final String className = getParameter(SOBJECT_CLASS, exchange, IGNORE_BODY, NOT_OPTIONAL);
             try {
                 sObjectClass = endpoint.getComponent().getCamelContext()
-                    .getClassResolver().resolveMandatoryClass(className);
+                        .getClassResolver().resolveMandatoryClass(className);
             } catch (ClassNotFoundException e) {
                 throw new SalesforceException(
-                    String.format("SObject class not found %s, %s",
-                        className, e.getMessage()),
-                    e);
+                        String.format("SObject class not found %s, %s",
+                                className, e.getMessage()),
+                        e);
             }
         }
         exchange.setProperty(RESPONSE_CLASS, sObjectClass);

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/AbstractSalesforceProcessor.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/AbstractSalesforceProcessor.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/AbstractSalesforceProcessor.java
index e784458..c214c01 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/AbstractSalesforceProcessor.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/AbstractSalesforceProcessor.java
@@ -16,19 +16,19 @@
  */
 package org.apache.camel.component.salesforce.internal.processor;
 
+import java.util.Map;
+
 import org.apache.camel.AsyncCallback;
 import org.apache.camel.Exchange;
-import org.eclipse.jetty.client.HttpClient;
 import org.apache.camel.component.salesforce.SalesforceComponent;
 import org.apache.camel.component.salesforce.SalesforceEndpoint;
 import org.apache.camel.component.salesforce.api.SalesforceException;
 import org.apache.camel.component.salesforce.internal.OperationName;
 import org.apache.camel.component.salesforce.internal.SalesforceSession;
+import org.eclipse.jetty.client.HttpClient;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import java.util.Map;
-
 public abstract class AbstractSalesforceProcessor implements SalesforceProcessor {
 
     protected static final boolean NOT_OPTIONAL = false;
@@ -60,12 +60,13 @@ public abstract class AbstractSalesforceProcessor implements SalesforceProcessor
     /**
      * Gets value for a parameter from header, endpoint config, or exchange body (optional).
      *
-     * @param exchange exchange to inspect
+     * @param exchange      exchange to inspect
      * @param convertInBody converts In body to String value if true
-     * @param propName name of property
-     * @param optional if {@code true} returns null, otherwise throws RestException
+     * @param propName      name of property
+     * @param optional      if {@code true} returns null, otherwise throws RestException
      * @return value of property, or {@code null} for optional parameters if not found.
-     * @throws org.apache.camel.component.salesforce.api.SalesforceException if the property can't be found.
+     * @throws org.apache.camel.component.salesforce.api.SalesforceException
+     *          if the property can't be found.
      */
     protected final String getParameter(String propName, Exchange exchange, boolean convertInBody, boolean optional) throws SalesforceException {
         String propValue = exchange.getIn().getHeader(propName, String.class);

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/BulkApiProcessor.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/BulkApiProcessor.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/BulkApiProcessor.java
index 6e070f7..d461207 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/BulkApiProcessor.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/BulkApiProcessor.java
@@ -16,21 +16,32 @@
  */
 package org.apache.camel.component.salesforce.internal.processor;
 
-import org.apache.camel.*;
-import org.apache.camel.converter.stream.StreamCacheConverter;
-import org.apache.camel.util.ServiceHelper;
+import java.io.IOException;
+import java.io.InputStream;
+import java.util.List;
+
+import org.apache.camel.AsyncCallback;
+import org.apache.camel.CamelException;
+import org.apache.camel.Exchange;
+import org.apache.camel.InvalidPayloadException;
+import org.apache.camel.Message;
+import org.apache.camel.StreamCache;
 import org.apache.camel.component.salesforce.SalesforceEndpoint;
 import org.apache.camel.component.salesforce.SalesforceEndpointConfig;
 import org.apache.camel.component.salesforce.api.SalesforceException;
-import org.apache.camel.component.salesforce.api.dto.bulk.*;
+import org.apache.camel.component.salesforce.api.dto.bulk.BatchInfo;
+import org.apache.camel.component.salesforce.api.dto.bulk.ContentType;
+import org.apache.camel.component.salesforce.api.dto.bulk.JobInfo;
 import org.apache.camel.component.salesforce.internal.client.BulkApiClient;
 import org.apache.camel.component.salesforce.internal.client.DefaultBulkApiClient;
+import org.apache.camel.converter.stream.StreamCacheConverter;
+import org.apache.camel.util.ServiceHelper;
 
-import java.io.IOException;
-import java.io.InputStream;
-import java.util.List;
-
-import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.*;
+import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.BATCH_ID;
+import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.CONTENT_TYPE;
+import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.JOB_ID;
+import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.RESULT_ID;
+import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.SOBJECT_QUERY;
 
 public class BulkApiProcessor extends AbstractSalesforceProcessor {
 
@@ -40,7 +51,7 @@ public class BulkApiProcessor extends AbstractSalesforceProcessor {
         super(endpoint);
 
         this.bulkClient = new DefaultBulkApiClient(
-            endpointConfigMap.get(SalesforceEndpointConfig.API_VERSION), session, httpClient);
+                endpointConfigMap.get(SalesforceEndpointConfig.API_VERSION), session, httpClient);
     }
 
     @Override
@@ -112,7 +123,7 @@ public class BulkApiProcessor extends AbstractSalesforceProcessor {
                 case CREATE_BATCH:
                     // since request is in the body, use headers or endpoint params
                     ContentType contentType = ContentType.fromValue(
-                        getParameter(CONTENT_TYPE, exchange, IGNORE_BODY, NOT_OPTIONAL));
+                            getParameter(CONTENT_TYPE, exchange, IGNORE_BODY, NOT_OPTIONAL));
                     jobId = getParameter(JOB_ID, exchange, IGNORE_BODY, NOT_OPTIONAL);
 
                     InputStream request;
@@ -249,17 +260,17 @@ public class BulkApiProcessor extends AbstractSalesforceProcessor {
                     } else {
                         jobId = getParameter(JOB_ID, exchange, IGNORE_BODY, NOT_OPTIONAL);
                         contentType = ContentType.fromValue(
-                            getParameter(CONTENT_TYPE, exchange, IGNORE_BODY, NOT_OPTIONAL));
+                                getParameter(CONTENT_TYPE, exchange, IGNORE_BODY, NOT_OPTIONAL));
                         // reuse SOBJECT_QUERY property
                         soqlQuery = getParameter(SOBJECT_QUERY, exchange, USE_BODY, NOT_OPTIONAL);
                     }
                     bulkClient.createBatchQuery(jobId, soqlQuery, contentType,
-                        new BulkApiClient.BatchInfoResponseCallback() {
-                        @Override
-                        public void onResponse(BatchInfo batchInfo, SalesforceException ex) {
-                            processResponse(exchange, batchInfo, ex, callback);
-                        }
-                    });
+                            new BulkApiClient.BatchInfoResponseCallback() {
+                                @Override
+                                public void onResponse(BatchInfo batchInfo, SalesforceException ex) {
+                                    processResponse(exchange, batchInfo, ex, callback);
+                                }
+                            });
 
                     break;
 
@@ -323,23 +334,23 @@ public class BulkApiProcessor extends AbstractSalesforceProcessor {
 
         } catch (SalesforceException e) {
             exchange.setException(new SalesforceException(
-                String.format("Error processing %s: [%s] \"%s\"",
-                    operationName, e.getStatusCode(), e.getMessage()),
-                e));
+                    String.format("Error processing %s: [%s] \"%s\"",
+                            operationName, e.getStatusCode(), e.getMessage()),
+                    e));
             callback.done(true);
             done = true;
         } catch (InvalidPayloadException e) {
             exchange.setException(new SalesforceException(
-                String.format("Unexpected Error processing %s: \"%s\"",
-                    operationName, e.getMessage()),
-                e));
+                    String.format("Unexpected Error processing %s: \"%s\"",
+                            operationName, e.getMessage()),
+                    e));
             callback.done(true);
             done = true;
         } catch (RuntimeException e) {
             exchange.setException(new SalesforceException(
-                String.format("Unexpected Error processing %s: \"%s\"",
-                    operationName, e.getMessage()),
-                e));
+                    String.format("Unexpected Error processing %s: \"%s\"",
+                            operationName, e.getMessage()),
+                    e));
             callback.done(true);
             done = true;
         }

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/JsonRestProcessor.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/JsonRestProcessor.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/JsonRestProcessor.java
index 3ac32c6..528d8ca 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/JsonRestProcessor.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/JsonRestProcessor.java
@@ -16,22 +16,29 @@
  */
 package org.apache.camel.component.salesforce.internal.processor;
 
+import java.io.ByteArrayInputStream;
+import java.io.ByteArrayOutputStream;
+import java.io.IOException;
+import java.io.InputStream;
+import java.util.List;
+
 import org.apache.camel.AsyncCallback;
 import org.apache.camel.Exchange;
 import org.apache.camel.Message;
+import org.apache.camel.component.salesforce.SalesforceEndpoint;
+import org.apache.camel.component.salesforce.api.SalesforceException;
+import org.apache.camel.component.salesforce.api.dto.AbstractSObjectBase;
+import org.apache.camel.component.salesforce.api.dto.CreateSObjectResult;
+import org.apache.camel.component.salesforce.api.dto.GlobalObjects;
+import org.apache.camel.component.salesforce.api.dto.RestResources;
+import org.apache.camel.component.salesforce.api.dto.SObjectBasicInfo;
+import org.apache.camel.component.salesforce.api.dto.SObjectDescription;
+import org.apache.camel.component.salesforce.api.dto.SearchResult;
+import org.apache.camel.component.salesforce.api.dto.Version;
 import org.codehaus.jackson.map.ObjectMapper;
 import org.codehaus.jackson.map.SerializationConfig;
 import org.codehaus.jackson.type.TypeReference;
 import org.eclipse.jetty.util.StringUtil;
-import org.apache.camel.component.salesforce.SalesforceEndpoint;
-import org.apache.camel.component.salesforce.api.SalesforceException;
-import org.apache.camel.component.salesforce.api.dto.*;
-
-import java.io.ByteArrayInputStream;
-import java.io.ByteArrayOutputStream;
-import java.io.IOException;
-import java.io.InputStream;
-import java.util.List;
 
 public class JsonRestProcessor extends AbstractRestProcessor {
 
@@ -53,7 +60,8 @@ public class JsonRestProcessor extends AbstractRestProcessor {
         switch (operationName) {
             case GET_VERSIONS:
                 // handle in built response types
-                exchange.setProperty(RESPONSE_TYPE, new TypeReference<List<Version>>() {});
+                exchange.setProperty(RESPONSE_TYPE, new TypeReference<List<Version>>() {
+                });
                 break;
 
             case GET_RESOURCES:
@@ -88,7 +96,8 @@ public class JsonRestProcessor extends AbstractRestProcessor {
 
             case SEARCH:
                 // handle known response type
-                exchange.setProperty(RESPONSE_TYPE, new TypeReference<List<SearchResult>>() {});
+                exchange.setProperty(RESPONSE_TYPE, new TypeReference<List<SearchResult>>() {
+                });
                 break;
 
         }
@@ -112,7 +121,7 @@ public class JsonRestProcessor extends AbstractRestProcessor {
                     final String body = in.getBody(String.class);
                     if (null == body) {
                         String msg = "Unsupported request message body " +
-                            (in.getBody() == null ? null : in.getBody().getClass());
+                                (in.getBody() == null ? null : in.getBody().getClass());
                         throw new SalesforceException(msg, null);
                     } else {
                         request = new ByteArrayInputStream(body.getBytes(StringUtil.__UTF8_CHARSET));

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/XmlRestProcessor.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/XmlRestProcessor.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/XmlRestProcessor.java
index 75449b6..905127a 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/XmlRestProcessor.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/processor/XmlRestProcessor.java
@@ -16,6 +16,13 @@
  */
 package org.apache.camel.component.salesforce.internal.processor;
 
+import java.io.ByteArrayInputStream;
+import java.io.ByteArrayOutputStream;
+import java.io.IOException;
+import java.io.InputStream;
+import java.io.OutputStreamWriter;
+import java.io.Writer;
+
 import com.thoughtworks.xstream.XStream;
 import com.thoughtworks.xstream.XStreamException;
 import com.thoughtworks.xstream.io.HierarchicalStreamWriter;
@@ -27,13 +34,18 @@ import com.thoughtworks.xstream.mapper.CannotResolveClassException;
 import org.apache.camel.AsyncCallback;
 import org.apache.camel.Exchange;
 import org.apache.camel.Message;
-import org.eclipse.jetty.util.StringUtil;
 import org.apache.camel.component.salesforce.SalesforceEndpoint;
 import org.apache.camel.component.salesforce.api.JodaTimeConverter;
 import org.apache.camel.component.salesforce.api.SalesforceException;
-import org.apache.camel.component.salesforce.api.dto.*;
-
-import java.io.*;
+import org.apache.camel.component.salesforce.api.dto.AbstractSObjectBase;
+import org.apache.camel.component.salesforce.api.dto.CreateSObjectResult;
+import org.apache.camel.component.salesforce.api.dto.GlobalObjects;
+import org.apache.camel.component.salesforce.api.dto.RestResources;
+import org.apache.camel.component.salesforce.api.dto.SObjectBasicInfo;
+import org.apache.camel.component.salesforce.api.dto.SObjectDescription;
+import org.apache.camel.component.salesforce.api.dto.SearchResults;
+import org.apache.camel.component.salesforce.api.dto.Versions;
+import org.eclipse.jetty.util.StringUtil;
 
 import static org.apache.camel.component.salesforce.SalesforceEndpointConfig.SOBJECT_NAME;
 
@@ -44,22 +56,22 @@ public class XmlRestProcessor extends AbstractRestProcessor {
     // not very efficient when both JSON and XML are used together with a single Thread pool
     // but this will do for now
     private static ThreadLocal<XStream> xStream =
-        new ThreadLocal<XStream>() {
-            @Override
-            protected XStream initialValue() {
-                // use NoNameCoder to avoid escaping __ in custom field names
-                // and CompactWriter to avoid pretty printing
-                XStream result = new XStream(new XppDriver(new NoNameCoder()) {
-                    @Override
-                    public HierarchicalStreamWriter createWriter(Writer out) {
-                        return new CompactWriter(out, getNameCoder());
-                    }
+            new ThreadLocal<XStream>() {
+                @Override
+                protected XStream initialValue() {
+                    // use NoNameCoder to avoid escaping __ in custom field names
+                    // and CompactWriter to avoid pretty printing
+                    XStream result = new XStream(new XppDriver(new NoNameCoder()) {
+                        @Override
+                        public HierarchicalStreamWriter createWriter(Writer out) {
+                            return new CompactWriter(out, getNameCoder());
+                        }
 
-                });
-                result.registerConverter(new JodaTimeConverter());
-                return result;
-            }
-        };
+                    });
+                    result.registerConverter(new JodaTimeConverter());
+                    return result;
+                }
+            };
 
     private static final String RESPONSE_ALIAS = XmlRestProcessor.class.getName() + ".responseAlias";
 
@@ -91,7 +103,7 @@ public class XmlRestProcessor extends AbstractRestProcessor {
 
                 // need to add alias for Salesforce XML that uses SObject name as root element
                 exchange.setProperty(RESPONSE_ALIAS,
-                    getParameter(SOBJECT_NAME, exchange, USE_BODY, NOT_OPTIONAL));
+                        getParameter(SOBJECT_NAME, exchange, USE_BODY, NOT_OPTIONAL));
                 break;
 
             case GET_DESCRIPTION:
@@ -100,13 +112,13 @@ public class XmlRestProcessor extends AbstractRestProcessor {
 
                 // need to add alias for Salesforce XML that uses SObject name as root element
                 exchange.setProperty(RESPONSE_ALIAS,
-                    getParameter(SOBJECT_NAME, exchange, USE_BODY, NOT_OPTIONAL));
+                        getParameter(SOBJECT_NAME, exchange, USE_BODY, NOT_OPTIONAL));
                 break;
 
             case GET_SOBJECT:
                 // need to add alias for Salesforce XML that uses SObject name as root element
                 exchange.setProperty(RESPONSE_ALIAS,
-                    getParameter(SOBJECT_NAME, exchange, IGNORE_BODY, NOT_OPTIONAL));
+                        getParameter(SOBJECT_NAME, exchange, IGNORE_BODY, NOT_OPTIONAL));
                 break;
 
             case CREATE_SOBJECT:
@@ -117,7 +129,7 @@ public class XmlRestProcessor extends AbstractRestProcessor {
             case GET_SOBJECT_WITH_ID:
                 // need to add alias for Salesforce XML that uses SObject name as root element
                 exchange.setProperty(RESPONSE_ALIAS,
-                    getParameter(SOBJECT_NAME, exchange, IGNORE_BODY, NOT_OPTIONAL));
+                        getParameter(SOBJECT_NAME, exchange, IGNORE_BODY, NOT_OPTIONAL));
                 break;
 
             case UPSERT_SOBJECT:
@@ -129,7 +141,7 @@ public class XmlRestProcessor extends AbstractRestProcessor {
             case QUERY_MORE:
                 // need to add alias for Salesforce XML that uses SObject name as root element
                 exchange.setProperty(RESPONSE_ALIAS,
-                    "QueryResult");
+                        "QueryResult");
                 break;
 
             case SEARCH:
@@ -162,7 +174,7 @@ public class XmlRestProcessor extends AbstractRestProcessor {
                     final String body = in.getBody(String.class);
                     if (null == body) {
                         String msg = "Unsupported request message body " +
-                            (in.getBody() == null ? null : in.getBody().getClass());
+                                (in.getBody() == null ? null : in.getBody().getClass());
                         throw new SalesforceException(msg, null);
                     } else {
                         request = new ByteArrayInputStream(body.getBytes(StringUtil.__UTF8_CHARSET));

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/streaming/PushTopicHelper.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/streaming/PushTopicHelper.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/streaming/PushTopicHelper.java
index 4e51281..70e8fa4 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/streaming/PushTopicHelper.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/streaming/PushTopicHelper.java
@@ -16,9 +16,11 @@
  */
 package org.apache.camel.component.salesforce.internal.streaming;
 
+import java.io.ByteArrayInputStream;
+import java.io.IOException;
+import java.util.concurrent.TimeUnit;
+
 import org.apache.camel.CamelException;
-import org.codehaus.jackson.map.ObjectMapper;
-import org.eclipse.jetty.http.HttpStatus;
 import org.apache.camel.component.salesforce.SalesforceEndpointConfig;
 import org.apache.camel.component.salesforce.api.SalesforceException;
 import org.apache.camel.component.salesforce.api.dto.CreateSObjectResult;
@@ -26,13 +28,11 @@ import org.apache.camel.component.salesforce.internal.client.RestClient;
 import org.apache.camel.component.salesforce.internal.client.SyncResponseCallback;
 import org.apache.camel.component.salesforce.internal.dto.PushTopic;
 import org.apache.camel.component.salesforce.internal.dto.QueryRecordsPushTopic;
+import org.codehaus.jackson.map.ObjectMapper;
+import org.eclipse.jetty.http.HttpStatus;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import java.io.ByteArrayInputStream;
-import java.io.IOException;
-import java.util.concurrent.TimeUnit;
-
 public class PushTopicHelper {
     private static final Logger LOG = LoggerFactory.getLogger(PushTopicHelper.class);
     private static final ObjectMapper objectMapper = new ObjectMapper();
@@ -56,9 +56,9 @@ public class PushTopicHelper {
         try {
             // use SOQL to lookup Topic, since Name is not an external ID!!!
             restClient.query("SELECT Id, Name, Query, ApiVersion, IsActive, " +
-                "NotifyForFields, NotifyForOperations, Description " +
-                "FROM PushTopic WHERE Name = '" + topicName + "'",
-                callback);
+                    "NotifyForFields, NotifyForOperations, Description " +
+                    "FROM PushTopic WHERE Name = '" + topicName + "'",
+                    callback);
 
             if (!callback.await(API_TIMEOUT, TimeUnit.SECONDS)) {
                 throw new SalesforceException("API call timeout!", null);
@@ -67,7 +67,7 @@ public class PushTopicHelper {
                 throw callback.getException();
             }
             QueryRecordsPushTopic records = objectMapper.readValue(callback.getResponse(),
-                QueryRecordsPushTopic.class);
+                    QueryRecordsPushTopic.class);
             if (records.getTotalSize() == 1) {
 
                 PushTopic topic = records.getRecords().get(0);
@@ -75,11 +75,11 @@ public class PushTopicHelper {
 
                 // check if we need to update topic query, notifyForFields or notifyForOperations
                 if (!query.equals(topic.getQuery()) ||
-                    (config.getNotifyForFields() != null &&
-                        !config.getNotifyForFields().equals(topic.getNotifyForFields())) ||
-                    (config.getNotifyForOperations() != null &&
-                        !config.getNotifyForOperations().equals(topic.getNotifyForOperations()))
-                    ) {
+                        (config.getNotifyForFields() != null &&
+                                !config.getNotifyForFields().equals(topic.getNotifyForFields())) ||
+                        (config.getNotifyForOperations() != null &&
+                                !config.getNotifyForOperations().equals(topic.getNotifyForOperations()))
+                        ) {
 
                     if (!config.isUpdateTopic()) {
                         String msg = "Query doesn't match existing Topic and updateTopic is set to false";
@@ -96,17 +96,17 @@ public class PushTopicHelper {
 
         } catch (SalesforceException e) {
             throw new CamelException(
-                String.format("Error retrieving Topic %s: %s", topicName, e.getMessage()),
-                e);
+                    String.format("Error retrieving Topic %s: %s", topicName, e.getMessage()),
+                    e);
         } catch (IOException e) {
             throw new CamelException(
-                String.format("Un-marshaling error retrieving Topic %s: %s", topicName, e.getMessage()),
-                e);
+                    String.format("Un-marshaling error retrieving Topic %s: %s", topicName, e.getMessage()),
+                    e);
         } catch (InterruptedException e) {
             Thread.currentThread().interrupt();
             throw new CamelException(
-                String.format("Un-marshaling error retrieving Topic %s: %s", topicName, e.getMessage()),
-                e);
+                    String.format("Un-marshaling error retrieving Topic %s: %s", topicName, e.getMessage()),
+                    e);
         } finally {
             // close stream to close HttpConnection
             if (callback.getResponse() != null) {
@@ -132,7 +132,7 @@ public class PushTopicHelper {
         final SyncResponseCallback callback = new SyncResponseCallback();
         try {
             restClient.createSObject(PUSH_TOPIC_OBJECT_NAME,
-                new ByteArrayInputStream(objectMapper.writeValueAsBytes(topic)), callback);
+                    new ByteArrayInputStream(objectMapper.writeValueAsBytes(topic)), callback);
 
             if (!callback.await(API_TIMEOUT, TimeUnit.SECONDS)) {
                 throw new SalesforceException("API call timeout!", null);
@@ -144,23 +144,23 @@ public class PushTopicHelper {
             CreateSObjectResult result = objectMapper.readValue(callback.getResponse(), CreateSObjectResult.class);
             if (!result.getSuccess()) {
                 final SalesforceException salesforceException = new SalesforceException(
-                    result.getErrors(), HttpStatus.BAD_REQUEST_400);
+                        result.getErrors(), HttpStatus.BAD_REQUEST_400);
                 throw new CamelException(
-                    String.format("Error creating Topic %s: %s", topicName, result.getErrors()),
-                    salesforceException);
+                        String.format("Error creating Topic %s: %s", topicName, result.getErrors()),
+                        salesforceException);
             }
         } catch (SalesforceException e) {
             throw new CamelException(
-                String.format("Error creating Topic %s: %s", topicName, e.getMessage()),
-                e);
+                    String.format("Error creating Topic %s: %s", topicName, e.getMessage()),
+                    e);
         } catch (IOException e) {
             throw new CamelException(
-                String.format("Un-marshaling error creating Topic %s: %s", topicName, e.getMessage()),
-                e);
+                    String.format("Un-marshaling error creating Topic %s: %s", topicName, e.getMessage()),
+                    e);
         } catch (InterruptedException e) {
             throw new CamelException(
-                String.format("Un-marshaling error creating Topic %s: %s", topicName, e.getMessage()),
-                e);
+                    String.format("Un-marshaling error creating Topic %s: %s", topicName, e.getMessage()),
+                    e);
         } finally {
             if (callback.getResponse() != null) {
                 try {
@@ -185,8 +185,8 @@ public class PushTopicHelper {
             topic.setNotifyForOperations(config.getNotifyForOperations());
 
             restClient.updateSObject("PushTopic", topicId,
-                new ByteArrayInputStream(objectMapper.writeValueAsBytes(topic)),
-                callback);
+                    new ByteArrayInputStream(objectMapper.writeValueAsBytes(topic)),
+                    callback);
 
             if (!callback.await(API_TIMEOUT, TimeUnit.SECONDS)) {
                 throw new SalesforceException("API call timeout!", null);
@@ -197,18 +197,18 @@ public class PushTopicHelper {
 
         } catch (SalesforceException e) {
             throw new CamelException(
-                String.format("Error updating topic %s with query [%s] : %s", topicName, query, e.getMessage()),
-                e);
+                    String.format("Error updating topic %s with query [%s] : %s", topicName, query, e.getMessage()),
+                    e);
         } catch (InterruptedException e) {
             // reset interrupt status
             Thread.currentThread().interrupt();
             throw new CamelException(
-                String.format("Error updating topic %s with query [%s] : %s", topicName, query, e.getMessage()),
-                e);
+                    String.format("Error updating topic %s with query [%s] : %s", topicName, query, e.getMessage()),
+                    e);
         } catch (IOException e) {
             throw new CamelException(
-                String.format("Error updating topic %s with query [%s] : %s", topicName, query, e.getMessage()),
-                e);
+                    String.format("Error updating topic %s with query [%s] : %s", topicName, query, e.getMessage()),
+                    e);
         } finally {
             if (callback.getResponse() != null) {
                 try {

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/streaming/SubscriptionHelper.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/streaming/SubscriptionHelper.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/streaming/SubscriptionHelper.java
index b3bd50f..f31fdda 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/streaming/SubscriptionHelper.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/internal/streaming/SubscriptionHelper.java
@@ -16,8 +16,18 @@
  */
 package org.apache.camel.component.salesforce.internal.streaming;
 
+import java.io.IOException;
+import java.util.HashMap;
+import java.util.Map;
+import java.util.concurrent.ConcurrentHashMap;
+import java.util.concurrent.CountDownLatch;
+
 import org.apache.camel.CamelException;
 import org.apache.camel.Service;
+import org.apache.camel.component.salesforce.SalesforceComponent;
+import org.apache.camel.component.salesforce.SalesforceConsumer;
+import org.apache.camel.component.salesforce.internal.SalesforceSession;
+import org.apache.camel.component.salesforce.internal.client.SalesforceSecurityListener;
 import org.cometd.bayeux.Message;
 import org.cometd.bayeux.client.ClientSessionChannel;
 import org.cometd.client.BayeuxClient;
@@ -27,22 +37,15 @@ import org.eclipse.jetty.client.ContentExchange;
 import org.eclipse.jetty.client.HttpClient;
 import org.eclipse.jetty.http.HttpHeaders;
 import org.eclipse.jetty.http.HttpSchemes;
-import org.apache.camel.component.salesforce.SalesforceComponent;
-import org.apache.camel.component.salesforce.SalesforceConsumer;
-import org.apache.camel.component.salesforce.internal.SalesforceSession;
-import org.apache.camel.component.salesforce.internal.client.SalesforceSecurityListener;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import java.io.IOException;
-import java.util.HashMap;
-import java.util.Map;
-import java.util.concurrent.ConcurrentHashMap;
-import java.util.concurrent.CountDownLatch;
-
 import static java.util.concurrent.TimeUnit.MILLISECONDS;
 import static java.util.concurrent.TimeUnit.SECONDS;
-import static org.cometd.bayeux.Channel.*;
+import static org.cometd.bayeux.Channel.META_CONNECT;
+import static org.cometd.bayeux.Channel.META_HANDSHAKE;
+import static org.cometd.bayeux.Channel.META_SUBSCRIBE;
+import static org.cometd.bayeux.Channel.META_UNSUBSCRIBE;
 import static org.cometd.bayeux.Message.ERROR_FIELD;
 import static org.cometd.bayeux.Message.SUBSCRIPTION_FIELD;
 
@@ -128,11 +131,11 @@ public class SubscriptionHelper implements Service {
                         LOG.debug("Refreshing subscriptions to {} channels on reconnect", listenerMap.size());
                         // reconnected to Salesforce, subscribe to existing channels
                         final Map<SalesforceConsumer, ClientSessionChannel.MessageListener> map =
-                            new HashMap<SalesforceConsumer, ClientSessionChannel.MessageListener>();
+                                new HashMap<SalesforceConsumer, ClientSessionChannel.MessageListener>();
                         map.putAll(listenerMap);
                         listenerMap.clear();
                         for (Map.Entry<SalesforceConsumer, ClientSessionChannel.MessageListener> entry :
-                            map.entrySet()) {
+                                map.entrySet()) {
                             final SalesforceConsumer consumer = entry.getKey();
                             final String topicName = consumer.getTopicName();
                             try {
@@ -140,9 +143,9 @@ public class SubscriptionHelper implements Service {
                             } catch (CamelException e) {
                                 // let the consumer handle the exception
                                 consumer.handleException(
-                                    String.format("Error refreshing subscription to topic [%s]: %s",
-                                        topicName, e.getMessage()),
-                                    e);
+                                        String.format("Error refreshing subscription to topic [%s]: %s",
+                                                topicName, e.getMessage()),
+                                        e);
                             }
                         }
 
@@ -159,15 +162,15 @@ public class SubscriptionHelper implements Service {
         if (!client.waitFor(waitMs, BayeuxClient.State.CONNECTED)) {
             if (handshakeException != null) {
                 throw new CamelException(
-                    String.format("Exception during HANDSHAKE: %s", handshakeException.getMessage()),
-                    handshakeException);
+                        String.format("Exception during HANDSHAKE: %s", handshakeException.getMessage()),
+                        handshakeException);
             } else if (handshakeError != null) {
                 throw new CamelException(String.format("Error during HANDSHAKE: %s", handshakeError));
             } else if (connectError != null) {
                 throw new CamelException(String.format("Error during CONNECT: %s", connectError));
             } else {
                 throw new CamelException(
-                    String.format("Handshake request timeout after %s seconds", CONNECT_TIMEOUT));
+                        String.format("Handshake request timeout after %s seconds", CONNECT_TIMEOUT));
             }
         }
 
@@ -207,17 +210,17 @@ public class SubscriptionHelper implements Service {
                 try {
                     final boolean isHttps = HttpSchemes.HTTPS.equals(String.valueOf(exchange.getScheme()));
                     exchange.setEventListener(new SalesforceSecurityListener(
-                        httpClient.getDestination(exchange.getAddress(), isHttps),
-                        exchange, session, accessToken));
+                            httpClient.getDestination(exchange.getAddress(), isHttps),
+                            exchange, session, accessToken));
                 } catch (IOException e) {
                     throw new RuntimeException(
-                        String.format("Error adding SalesforceSecurityListener to exchange %s", e.getMessage()),
-                        e);
+                            String.format("Error adding SalesforceSecurityListener to exchange %s", e.getMessage()),
+                            e);
                 }
 
                 // add current security token obtained from session
                 exchange.addRequestHeader(HttpHeaders.AUTHORIZATION,
-                "OAuth " + accessToken);
+                        "OAuth " + accessToken);
             }
         };
 
@@ -280,10 +283,10 @@ public class SubscriptionHelper implements Service {
                     String message;
                     if (subscribeError[0] != null) {
                         message = String.format("Error subscribing to topic %s: %s",
-                            topicName, subscribeError[0]);
+                                topicName, subscribeError[0]);
                     } else {
                         message = String.format("Timeout error subscribing to topic %s after %s seconds",
-                            topicName, CHANNEL_TIMEOUT);
+                                topicName, CHANNEL_TIMEOUT);
                     }
                     throw new CamelException(message);
                 }
@@ -347,10 +350,10 @@ public class SubscriptionHelper implements Service {
                         String message;
                         if (unsubscribeError[0] != null) {
                             message = String.format("Error unsubscribing from topic %s: %s",
-                                topicName, unsubscribeError[0]);
+                                    topicName, unsubscribeError[0]);
                         } else {
                             message = String.format("Timeout error unsubscribing from topic %s after %s seconds",
-                                topicName, CHANNEL_TIMEOUT);
+                                    topicName, CHANNEL_TIMEOUT);
                         }
                         throw new CamelException(message);
                     }

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/AbstractSalesforceTestBase.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/AbstractSalesforceTestBase.java b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/AbstractSalesforceTestBase.java
index 3130a5b..7ce7311 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/AbstractSalesforceTestBase.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/AbstractSalesforceTestBase.java
@@ -16,11 +16,11 @@
  */
 package org.apache.camel.component.salesforce;
 
+import java.io.IOException;
+
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.test.junit4.CamelTestSupport;
 import org.apache.camel.component.salesforce.dto.Merchandise__c;
-
-import java.io.IOException;
+import org.apache.camel.test.junit4.CamelTestSupport;
 
 public abstract class AbstractSalesforceTestBase extends CamelTestSupport {
 

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/BulkApiBatchIntegrationTest.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/BulkApiBatchIntegrationTest.java b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/BulkApiBatchIntegrationTest.java
index bed6a0c..5406c16 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/BulkApiBatchIntegrationTest.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/BulkApiBatchIntegrationTest.java
@@ -16,17 +16,21 @@
  */
 package org.apache.camel.component.salesforce;
 
-import org.apache.camel.component.salesforce.api.dto.bulk.*;
-import org.apache.camel.component.salesforce.dto.Merchandise__c;
-import org.junit.experimental.theories.DataPoints;
-import org.junit.experimental.theories.Theory;
-
 import java.io.InputStream;
 import java.util.ArrayList;
 import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
 
+import org.apache.camel.component.salesforce.api.dto.bulk.BatchInfo;
+import org.apache.camel.component.salesforce.api.dto.bulk.BatchStateEnum;
+import org.apache.camel.component.salesforce.api.dto.bulk.ContentType;
+import org.apache.camel.component.salesforce.api.dto.bulk.JobInfo;
+import org.apache.camel.component.salesforce.api.dto.bulk.OperationEnum;
+import org.apache.camel.component.salesforce.dto.Merchandise__c;
+import org.junit.experimental.theories.DataPoints;
+import org.junit.experimental.theories.Theory;
+
 public class BulkApiBatchIntegrationTest extends AbstractBulkApiTestBase {
     private static final String TEST_REQUEST_XML = "/test-request.xml";
     private static final String TEST_REQUEST_CSV = "/test-request.csv";

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/BulkApiJobIntegrationTest.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/BulkApiJobIntegrationTest.java b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/BulkApiJobIntegrationTest.java
index 9010aa4..c3e52c3 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/BulkApiJobIntegrationTest.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/BulkApiJobIntegrationTest.java
@@ -16,6 +16,9 @@
  */
 package org.apache.camel.component.salesforce;
 
+import java.util.ArrayList;
+import java.util.List;
+
 import org.apache.camel.component.salesforce.api.dto.bulk.ContentType;
 import org.apache.camel.component.salesforce.api.dto.bulk.JobInfo;
 import org.apache.camel.component.salesforce.api.dto.bulk.JobStateEnum;
@@ -24,9 +27,6 @@ import org.apache.camel.component.salesforce.dto.Merchandise__c;
 import org.junit.experimental.theories.DataPoints;
 import org.junit.experimental.theories.Theory;
 
-import java.util.ArrayList;
-import java.util.List;
-
 public class BulkApiJobIntegrationTest extends AbstractBulkApiTestBase {
 
     // test jobs for testJobLifecycle

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/BulkApiQueryIntegrationTest.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/BulkApiQueryIntegrationTest.java b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/BulkApiQueryIntegrationTest.java
index 0f22ee1..bcfd062 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/BulkApiQueryIntegrationTest.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/BulkApiQueryIntegrationTest.java
@@ -16,14 +16,18 @@
  */
 package org.apache.camel.component.salesforce;
 
-import org.apache.camel.component.salesforce.api.dto.bulk.*;
+import java.io.InputStream;
+import java.util.List;
+
+import org.apache.camel.component.salesforce.api.dto.bulk.BatchInfo;
+import org.apache.camel.component.salesforce.api.dto.bulk.BatchStateEnum;
+import org.apache.camel.component.salesforce.api.dto.bulk.ContentType;
+import org.apache.camel.component.salesforce.api.dto.bulk.JobInfo;
+import org.apache.camel.component.salesforce.api.dto.bulk.OperationEnum;
 import org.apache.camel.component.salesforce.dto.Merchandise__c;
 import org.junit.experimental.theories.DataPoints;
 import org.junit.experimental.theories.Theory;
 
-import java.io.InputStream;
-import java.util.List;
-
 public class BulkApiQueryIntegrationTest extends AbstractBulkApiTestBase {
 
     @DataPoints

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/LoginConfigHelper.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/LoginConfigHelper.java b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/LoginConfigHelper.java
index 1f8b480..365639d 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/LoginConfigHelper.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/LoginConfigHelper.java
@@ -16,13 +16,13 @@
  */
 package org.apache.camel.component.salesforce;
 
-import org.junit.Assert;
-
 import java.io.FileInputStream;
 import java.io.IOException;
 import java.io.InputStream;
 import java.util.Properties;
 
+import org.junit.Assert;
+
 public class LoginConfigHelper extends Assert {
 
     private static final String TEST_LOGIN_PROPERTIES = "test-salesforce-login.properties";
@@ -33,9 +33,9 @@ public class LoginConfigHelper extends Assert {
         Properties properties = new Properties();
         InputStream stream = new FileInputStream(TEST_LOGIN_PROPERTIES);
         if (null == stream) {
-            throw new IllegalArgumentException("Create a properties file named " +
-                TEST_LOGIN_PROPERTIES + " with clientId, clientSecret, userName, and password" +
-                " for a Salesforce account with the Merchandise object from Salesforce Guides.");
+            throw new IllegalArgumentException("Create a properties file named "
+                + TEST_LOGIN_PROPERTIES + " with clientId, clientSecret, userName, and password"
+                + " for a Salesforce account with the Merchandise object from Salesforce Guides.");
         }
         properties.load(stream);
 

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/RestApiIntegrationTest.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/RestApiIntegrationTest.java b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/RestApiIntegrationTest.java
index a33d17d..a7510e3 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/RestApiIntegrationTest.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/RestApiIntegrationTest.java
@@ -16,8 +16,24 @@
  */
 package org.apache.camel.component.salesforce;
 
+import java.io.FileOutputStream;
+import java.io.InputStream;
+import java.nio.channels.Channels;
+import java.nio.channels.FileChannel;
+import java.nio.channels.ReadableByteChannel;
+import java.util.HashMap;
+import java.util.List;
+
 import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.salesforce.api.dto.*;
+import org.apache.camel.component.salesforce.api.dto.CreateSObjectResult;
+import org.apache.camel.component.salesforce.api.dto.GlobalObjects;
+import org.apache.camel.component.salesforce.api.dto.RestResources;
+import org.apache.camel.component.salesforce.api.dto.SObjectBasicInfo;
+import org.apache.camel.component.salesforce.api.dto.SObjectDescription;
+import org.apache.camel.component.salesforce.api.dto.SearchResult;
+import org.apache.camel.component.salesforce.api.dto.SearchResults;
+import org.apache.camel.component.salesforce.api.dto.Version;
+import org.apache.camel.component.salesforce.api.dto.Versions;
 import org.apache.camel.component.salesforce.dto.Document;
 import org.apache.camel.component.salesforce.dto.Line_Item__c;
 import org.apache.camel.component.salesforce.dto.Merchandise__c;
@@ -26,14 +42,6 @@ import org.junit.Test;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import java.io.FileOutputStream;
-import java.io.InputStream;
-import java.nio.channels.Channels;
-import java.nio.channels.FileChannel;
-import java.nio.channels.ReadableByteChannel;
-import java.util.HashMap;
-import java.util.List;
-
 public class RestApiIntegrationTest extends AbstractSalesforceTestBase {
 
     private static final Logger LOG = LoggerFactory.getLogger(RestApiIntegrationTest.class);
@@ -153,27 +161,27 @@ public class RestApiIntegrationTest extends AbstractSalesforceTestBase {
     }
 
     private void doTestCreateUpdateDelete(String suffix) throws InterruptedException {
-        Merchandise__c merchandise__c = new Merchandise__c();
-        merchandise__c.setName("Wee Wee Wee Plane");
-        merchandise__c.setDescription__c("Microlite plane");
-        merchandise__c.setPrice__c(2000.0);
-        merchandise__c.setTotal_Inventory__c(50.0);
+        Merchandise__c merchandise = new Merchandise__c();
+        merchandise.setName("Wee Wee Wee Plane");
+        merchandise.setDescription__c("Microlite plane");
+        merchandise.setPrice__c(2000.0);
+        merchandise.setTotal_Inventory__c(50.0);
         CreateSObjectResult result = template().requestBody("direct:CreateSObject" + suffix,
-            merchandise__c, CreateSObjectResult.class);
+            merchandise, CreateSObjectResult.class);
         assertNotNull(result);
         assertTrue("Create success", result.getSuccess());
         LOG.debug("Create: " + result);
 
         // test JSON update
         // make the plane cheaper
-        merchandise__c.setPrice__c(1500.0);
+        merchandise.setPrice__c(1500.0);
         // change inventory to half
-        merchandise__c.setTotal_Inventory__c(25.0);
+        merchandise.setTotal_Inventory__c(25.0);
         // also need to set the Id
-        merchandise__c.setId(result.getId());
+        merchandise.setId(result.getId());
 
         assertNull(template().requestBodyAndHeader("direct:UpdateSObject" + suffix,
-            merchandise__c, SalesforceEndpointConfig.SOBJECT_ID, result.getId()));
+            merchandise, SalesforceEndpointConfig.SOBJECT_ID, result.getId()));
         LOG.debug("Update successful");
 
         // delete the newly created SObject
@@ -189,34 +197,34 @@ public class RestApiIntegrationTest extends AbstractSalesforceTestBase {
 
     private void doTestCreateUpdateDeleteWithId(String suffix) throws InterruptedException {
         // get line item with Name 1
-        Line_Item__c line_item__c = template().requestBody("direct:getSObjectWithId" + suffix, TEST_LINE_ITEM_ID,
+        Line_Item__c lineItem = template().requestBody("direct:getSObjectWithId" + suffix, TEST_LINE_ITEM_ID,
             Line_Item__c.class);
-        assertNotNull(line_item__c);
-        LOG.debug("GetWithId: {}", line_item__c);
+        assertNotNull(lineItem);
+        LOG.debug("GetWithId: {}", lineItem);
 
         // test insert with id
         // set the unit price and sold
-        line_item__c.setUnit_Price__c(1000.0);
-        line_item__c.setUnits_Sold__c(50.0);
+        lineItem.setUnit_Price__c(1000.0);
+        lineItem.setUnits_Sold__c(50.0);
         // update line item with Name NEW_LINE_ITEM_ID
-        line_item__c.setName(NEW_LINE_ITEM_ID);
+        lineItem.setName(NEW_LINE_ITEM_ID);
 
         CreateSObjectResult result = template().requestBodyAndHeader("direct:upsertSObject" + suffix,
-            line_item__c, SalesforceEndpointConfig.SOBJECT_EXT_ID_VALUE, NEW_LINE_ITEM_ID,
+            lineItem, SalesforceEndpointConfig.SOBJECT_EXT_ID_VALUE, NEW_LINE_ITEM_ID,
             CreateSObjectResult.class);
         assertNotNull(result);
         assertTrue(result.getSuccess());
         LOG.debug("CreateWithId: {}", result);
 
         // clear read only parent type fields
-        line_item__c.setInvoice_Statement__c(null);
-        line_item__c.setMerchandise__c(null);
+        lineItem.setInvoice_Statement__c(null);
+        lineItem.setMerchandise__c(null);
         // change the units sold
-        line_item__c.setUnits_Sold__c(25.0);
+        lineItem.setUnits_Sold__c(25.0);
 
         // update line item with Name NEW_LINE_ITEM_ID
         result = template().requestBodyAndHeader("direct:upsertSObject" + suffix,
-            line_item__c, SalesforceEndpointConfig.SOBJECT_EXT_ID_VALUE, NEW_LINE_ITEM_ID,
+            lineItem, SalesforceEndpointConfig.SOBJECT_EXT_ID_VALUE, NEW_LINE_ITEM_ID,
             CreateSObjectResult.class);
         assertNull(result);
         LOG.debug("UpdateWithId: {}", result);

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/StreamingApiIntegrationTest.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/StreamingApiIntegrationTest.java b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/StreamingApiIntegrationTest.java
index d72ca2b..f80c2f6 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/StreamingApiIntegrationTest.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/StreamingApiIntegrationTest.java
@@ -37,8 +37,7 @@ public class StreamingApiIntegrationTest extends AbstractSalesforceTestBase {
 
         Merchandise__c merchandise = new Merchandise__c();
         merchandise.setName("TestNotification");
-        merchandise.setDescription__c("Merchandise for testing Streaming API updated on " +
-            new DateTime().toString());
+        merchandise.setDescription__c("Merchandise for testing Streaming API updated on " + new DateTime().toString());
         merchandise.setPrice__c(9.99);
         merchandise.setTotal_Inventory__c(1000.0);
         CreateSObjectResult result = template().requestBody(
@@ -80,10 +79,9 @@ public class StreamingApiIntegrationTest extends AbstractSalesforceTestBase {
             public void configure() throws Exception {
 
                 // test topic subscription
-                from("salesforce:CamelTestTopic?notifyForFields=ALL&notifyForOperations=ALL&" +
-//                    "sObjectClass=org.apache.camel.component.salesforce.dto.Merchandise__c&" +
-                    "sObjectName=Merchandise__c&" +
-                    "updateTopic=true&sObjectQuery=SELECT Id, Name FROM Merchandise__c").
+                from("salesforce:CamelTestTopic?notifyForFields=ALL&notifyForOperations=ALL&"
+                    + "sObjectName=Merchandise__c&"
+                    + "updateTopic=true&sObjectQuery=SELECT Id, Name FROM Merchandise__c").
                     to("mock:CamelTestTopic");
 
                 // route for creating test record
@@ -92,8 +90,8 @@ public class StreamingApiIntegrationTest extends AbstractSalesforceTestBase {
 
                 // route for finding test topic
                 from("direct:query").
-                    to("salesforce:query?sObjectQuery=SELECT Id FROM PushTopic WHERE Name = 'CamelTestTopic'&" +
-                        "sObjectClass=org.apache.camel.component.salesforce.internal.dto.QueryRecordsPushTopic");
+                    to("salesforce:query?sObjectQuery=SELECT Id FROM PushTopic WHERE Name = 'CamelTestTopic'&"
+                        + "sObjectClass=org.apache.camel.component.salesforce.internal.dto.QueryRecordsPushTopic");
 
                 // route for removing test record
                 from("direct:deleteSObjectWithId").

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/Document.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/Document.java b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/Document.java
index 090f2b1..a448bb3 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/Document.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/Document.java
@@ -5,8 +5,8 @@
 package org.apache.camel.component.salesforce.dto;
 
 import com.thoughtworks.xstream.annotations.XStreamAlias;
-import org.codehaus.jackson.annotate.JsonProperty;
 import org.apache.camel.component.salesforce.api.dto.AbstractSObjectBase;
+import org.codehaus.jackson.annotate.JsonProperty;
 
 /**
  * Salesforce DTO for SObject Document

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/Line_Item__c.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/Line_Item__c.java b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/Line_Item__c.java
index 1bf3668..31bc4ce 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/Line_Item__c.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/Line_Item__c.java
@@ -17,8 +17,8 @@
 package org.apache.camel.component.salesforce.dto;
 
 import com.thoughtworks.xstream.annotations.XStreamAlias;
-import org.codehaus.jackson.annotate.JsonProperty;
 import org.apache.camel.component.salesforce.api.dto.AbstractSObjectBase;
+import org.codehaus.jackson.annotate.JsonProperty;
 
 @XStreamAlias("Line_Item__c")
 public class Line_Item__c extends AbstractSObjectBase {

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/Merchandise__c.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/Merchandise__c.java b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/Merchandise__c.java
index 3e3d36a..f7a76db 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/Merchandise__c.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/Merchandise__c.java
@@ -17,8 +17,8 @@
 package org.apache.camel.component.salesforce.dto;
 
 import com.thoughtworks.xstream.annotations.XStreamAlias;
-import org.codehaus.jackson.annotate.JsonProperty;
 import org.apache.camel.component.salesforce.api.dto.AbstractSObjectBase;
+import org.codehaus.jackson.annotate.JsonProperty;
 
 @XStreamAlias("Merchandise__c")
 public class Merchandise__c extends AbstractSObjectBase {

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/QueryRecordsLine_Item__c.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/QueryRecordsLine_Item__c.java b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/QueryRecordsLine_Item__c.java
index a2d00cb..34dcad4 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/QueryRecordsLine_Item__c.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/dto/QueryRecordsLine_Item__c.java
@@ -16,11 +16,11 @@
  */
 package org.apache.camel.component.salesforce.dto;
 
+import java.util.List;
+
 import com.thoughtworks.xstream.annotations.XStreamImplicit;
 import org.apache.camel.component.salesforce.api.dto.AbstractQueryRecordsBase;
 
-import java.util.List;
-
 public class QueryRecordsLine_Item__c extends AbstractQueryRecordsBase {
     @XStreamImplicit
     private List<Line_Item__c> records;

http://git-wip-us.apache.org/repos/asf/camel/blob/aaa2710c/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/internal/SessionIntegrationTest.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/internal/SessionIntegrationTest.java b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/internal/SessionIntegrationTest.java
index 5e5ab5f..c8159b8 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/internal/SessionIntegrationTest.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/test/java/org/apache/camel/component/salesforce/internal/SessionIntegrationTest.java
@@ -16,9 +16,9 @@
  */
 package org.apache.camel.component.salesforce.internal;
 
+import org.apache.camel.component.salesforce.LoginConfigHelper;
 import org.eclipse.jetty.client.HttpClient;
 import org.eclipse.jetty.client.RedirectListener;
-import org.apache.camel.component.salesforce.LoginConfigHelper;
 import org.junit.Assert;
 import org.junit.Test;
 import org.slf4j.Logger;