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:48 UTC

[04/11] git commit: CAMEL-6428: Fixed CS

CAMEL-6428: Fixed CS


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

Branch: refs/heads/master
Commit: aaa2710cb8e7d23db4819599d87cb1a9af8c4549
Parents: 0c401b9
Author: Claus Ibsen <da...@apache.org>
Authored: Wed Jun 5 17:05:11 2013 +0200
Committer: Claus Ibsen <da...@apache.org>
Committed: Wed Jun 5 17:12:31 2013 +0200

----------------------------------------------------------------------
 .../component/salesforce/SalesforceComponent.java  |   26 +-
 .../component/salesforce/SalesforceConsumer.java   |   38 +-
 .../component/salesforce/SalesforceEndpoint.java   |    6 +-
 .../salesforce/SalesforceEndpointConfig.java       |   12 +-
 .../component/salesforce/SalesforceProducer.java   |   37 +-
 .../salesforce/api/JodaTimeConverter.java          |   10 +-
 .../salesforce/api/PicklistEnumConverter.java      |   24 +-
 .../salesforce/api/SalesforceException.java        |    6 +-
 .../salesforce/api/dto/AbstractDTOBase.java        |    6 +-
 .../salesforce/api/dto/CreateSObjectResult.java    |    4 +-
 .../salesforce/api/dto/GlobalObjects.java          |    4 +-
 .../component/salesforce/api/dto/RestError.java    |    4 +-
 .../salesforce/api/dto/SObjectBasicInfo.java       |    4 +-
 .../salesforce/api/dto/SObjectDescription.java     |    4 +-
 .../component/salesforce/api/dto/SObjectField.java |    4 +-
 .../salesforce/api/dto/SearchResults.java          |    4 +-
 .../component/salesforce/api/dto/Versions.java     |    4 +-
 .../salesforce/api/dto/bulk/BatchInfo.java         |  180 +++----
 .../salesforce/api/dto/bulk/BatchInfoList.java     |   28 +-
 .../salesforce/api/dto/bulk/BatchResult.java       |   28 +-
 .../salesforce/api/dto/bulk/BatchStateEnum.java    |    7 +-
 .../api/dto/bulk/ConcurrencyModeEnum.java          |    7 +-
 .../salesforce/api/dto/bulk/ContentType.java       |    5 +-
 .../component/salesforce/api/dto/bulk/Error.java   |   42 +-
 .../component/salesforce/api/dto/bulk/JobInfo.java |  384 ++++++---------
 .../salesforce/api/dto/bulk/JobStateEnum.java      |    7 +-
 .../salesforce/api/dto/bulk/ObjectFactory.java     |   37 +-
 .../salesforce/api/dto/bulk/OperationEnum.java     |    7 +-
 .../salesforce/api/dto/bulk/QueryResult.java       |   28 +-
 .../salesforce/api/dto/bulk/QueryResultList.java   |   28 +-
 .../component/salesforce/api/dto/bulk/Result.java  |   54 +--
 .../salesforce/api/dto/bulk/ResultError.java       |   60 +--
 .../component/salesforce/api/dto/bulk/SObject.java |   66 ++--
 .../salesforce/api/dto/bulk/StatusCode.java        |    5 +-
 .../salesforce/api/dto/bulk/package-info.java      |    3 +-
 .../salesforce/internal/SalesforceSession.java     |   45 +-
 .../internal/client/AbstractClientBase.java        |   28 +-
 .../salesforce/internal/client/BulkApiClient.java  |   10 +-
 .../internal/client/DefaultBulkApiClient.java      |   68 ++--
 .../internal/client/DefaultRestClient.java         |   30 +-
 .../salesforce/internal/client/RestClient.java     |   75 ++--
 .../client/SalesforceSecurityListener.java         |   12 +-
 .../internal/client/SyncResponseCallback.java      |    4 +-
 .../salesforce/internal/dto/PushTopic.java         |    2 +-
 .../internal/dto/QueryRecordsPushTopic.java        |    4 +-
 .../salesforce/internal/dto/RestErrors.java        |    4 +-
 .../internal/processor/AbstractRestProcessor.java  |  183 ++++----
 .../processor/AbstractSalesforceProcessor.java     |   15 +-
 .../internal/processor/BulkApiProcessor.java       |   65 ++-
 .../internal/processor/JsonRestProcessor.java      |   33 +-
 .../internal/processor/XmlRestProcessor.java       |   62 ++-
 .../internal/streaming/PushTopicHelper.java        |   78 ++--
 .../internal/streaming/SubscriptionHelper.java     |   59 ++-
 .../salesforce/AbstractSalesforceTestBase.java     |    6 +-
 .../salesforce/BulkApiBatchIntegrationTest.java    |   14 +-
 .../salesforce/BulkApiJobIntegrationTest.java      |    6 +-
 .../salesforce/BulkApiQueryIntegrationTest.java    |   12 +-
 .../component/salesforce/LoginConfigHelper.java    |   10 +-
 .../salesforce/RestApiIntegrationTest.java         |   68 ++--
 .../salesforce/StreamingApiIntegrationTest.java    |   14 +-
 .../camel/component/salesforce/dto/Document.java   |    2 +-
 .../component/salesforce/dto/Line_Item__c.java     |    2 +-
 .../component/salesforce/dto/Merchandise__c.java   |    2 +-
 .../salesforce/dto/QueryRecordsLine_Item__c.java   |    4 +-
 .../internal/SessionIntegrationTest.java           |    2 +-
 .../apache/camel/maven/CamelSalesforceMojo.java    |  149 +++---
 .../maven/CamelSalesforceMojoIntegrationTest.java  |   22 +-
 67 files changed, 1063 insertions(+), 1200 deletions(-)
----------------------------------------------------------------------


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/SalesforceComponent.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceComponent.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceComponent.java
index a48502a..57ee583 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceComponent.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceComponent.java
@@ -16,25 +16,25 @@
  */
 package org.apache.camel.component.salesforce;
 
+import java.util.Collections;
+import java.util.HashMap;
+import java.util.Map;
+import java.util.Set;
+
 import org.apache.camel.Endpoint;
-import org.apache.camel.impl.DefaultComponent;
-import org.apache.camel.util.ObjectHelper;
-import org.apache.camel.util.ServiceHelper;
-import org.eclipse.jetty.client.HttpClient;
-import org.eclipse.jetty.client.RedirectListener;
 import org.apache.camel.component.salesforce.api.SalesforceException;
 import org.apache.camel.component.salesforce.api.dto.AbstractSObjectBase;
 import org.apache.camel.component.salesforce.internal.OperationName;
 import org.apache.camel.component.salesforce.internal.SalesforceSession;
 import org.apache.camel.component.salesforce.internal.streaming.SubscriptionHelper;
+import org.apache.camel.impl.DefaultComponent;
+import org.apache.camel.util.ObjectHelper;
+import org.apache.camel.util.ServiceHelper;
+import org.eclipse.jetty.client.HttpClient;
+import org.eclipse.jetty.client.RedirectListener;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import java.util.Collections;
-import java.util.HashMap;
-import java.util.Map;
-import java.util.Set;
-
 /**
  * Represents the component that manages {@link SalesforceEndpoint}.
  */
@@ -84,7 +84,7 @@ public class SalesforceComponent extends DefaultComponent {
         setProperties(copy, parameters);
 
         final SalesforceEndpoint endpoint = new SalesforceEndpoint(uri, this, copy,
-            operationName, topicName);
+                operationName, topicName);
 
         // map remaining parameters to endpoint (specifically, synchronous)
         setProperties(endpoint, parameters);
@@ -115,8 +115,8 @@ public class SalesforceComponent extends DefaultComponent {
         // add redirect listener to handle Salesforce redirects
         // this is ok to do since the RedirectListener is in the same classloader as Jetty client
         String listenerClass = RedirectListener.class.getName();
-        if (httpClient.getRegisteredListeners() == null ||
-            !httpClient.getRegisteredListeners().contains(listenerClass)) {
+        if (httpClient.getRegisteredListeners() == null
+                || !httpClient.getRegisteredListeners().contains(listenerClass)) {
             httpClient.registerListener(listenerClass);
         }
         // SalesforceSecurityListener can't be registered the same way

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/SalesforceConsumer.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceConsumer.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceConsumer.java
index 9fa1b91..c3f6a05 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceConsumer.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceConsumer.java
@@ -16,31 +16,32 @@
  */
 package org.apache.camel.component.salesforce;
 
+import java.io.IOException;
+import java.io.StringReader;
+import java.util.HashMap;
+import java.util.Map;
+
 import org.apache.camel.AsyncCallback;
 import org.apache.camel.Exchange;
 import org.apache.camel.Processor;
 import org.apache.camel.RuntimeCamelException;
+import org.apache.camel.component.salesforce.internal.client.DefaultRestClient;
+import org.apache.camel.component.salesforce.internal.client.RestClient;
+import org.apache.camel.component.salesforce.internal.streaming.PushTopicHelper;
+import org.apache.camel.component.salesforce.internal.streaming.SubscriptionHelper;
 import org.apache.camel.impl.DefaultConsumer;
 import org.apache.camel.util.ServiceHelper;
 import org.codehaus.jackson.map.ObjectMapper;
 import org.cometd.bayeux.Message;
 import org.cometd.bayeux.client.ClientSessionChannel;
-import org.apache.camel.component.salesforce.internal.client.DefaultRestClient;
-import org.apache.camel.component.salesforce.internal.streaming.PushTopicHelper;
-import org.apache.camel.component.salesforce.internal.client.RestClient;
-import org.apache.camel.component.salesforce.internal.streaming.SubscriptionHelper;
-
-import java.io.IOException;
-import java.io.StringReader;
-import java.util.HashMap;
-import java.util.Map;
 
 /**
  * The Salesforce consumer.
  */
 public class SalesforceConsumer extends DefaultConsumer {
 
-    private static final ObjectMapper objectMapper = new ObjectMapper();
+
+    private static final ObjectMapper OBJECT_MAPPER = new ObjectMapper();
     private static final String EVENT_PROPERTY = "event";
     private static final String TYPE_PROPERTY = "type";
     private static final String CREATED_DATE_PROPERTY = "createdDate";
@@ -48,12 +49,13 @@ public class SalesforceConsumer extends DefaultConsumer {
     private static final double MINIMUM_VERSION = 24.0;
 
     private final SalesforceEndpoint endpoint;
-    public final SubscriptionHelper subscriptionHelper;
+    private final SubscriptionHelper subscriptionHelper;
 
     private final String topicName;
     private final Class<?> sObjectClass;
     private boolean subscribed;
 
+
     public SalesforceConsumer(SalesforceEndpoint endpoint, Processor processor, SubscriptionHelper helper) {
         super(endpoint, processor);
         this.endpoint = endpoint;
@@ -100,7 +102,7 @@ public class SalesforceConsumer extends DefaultConsumer {
             // create REST client for PushTopic operations
             SalesforceComponent component = endpoint.getComponent();
             RestClient restClient = new DefaultRestClient(component.getConfig().getHttpClient(),
-                endpoint.getConfiguration().getApiVersion(), "json", component.getSession());
+                    endpoint.getConfiguration().getApiVersion(), "json", component.getSession());
             // don't forget to start the client
             ServiceHelper.startService(restClient);
 
@@ -144,7 +146,7 @@ public class SalesforceConsumer extends DefaultConsumer {
         Object createdDate = event.get(CREATED_DATE_PROPERTY);
         if (log.isDebugEnabled()) {
             log.debug(String.format("Received event %s on channel %s created on %s",
-                eventType, channel.getChannelId(), createdDate));
+                    eventType, channel.getChannelId(), createdDate));
         }
 
         in.setHeader("CamelSalesforceEventType", eventType);
@@ -155,7 +157,7 @@ public class SalesforceConsumer extends DefaultConsumer {
         final Map<String, Object> sObject = (Map<String, Object>) data.get(SOBJECT_PROPERTY);
         try {
 
-            final String sObjectString = objectMapper.writeValueAsString(sObject);
+            final String sObjectString = OBJECT_MAPPER.writeValueAsString(sObject);
             log.debug("Received SObject: {}", sObjectString);
 
             if (sObjectClass == null) {
@@ -163,12 +165,12 @@ public class SalesforceConsumer extends DefaultConsumer {
                 in.setBody(sObject);
             } else {
                 // create the expected SObject
-                in.setBody(objectMapper.readValue(
-                    new StringReader(sObjectString), sObjectClass));
+                in.setBody(OBJECT_MAPPER.readValue(
+                        new StringReader(sObjectString), sObjectClass));
             }
         } catch (IOException e) {
             final String msg = String.format("Error parsing message [%s] from Topic %s: %s",
-                message, topicName, e.getMessage());
+                    message, topicName, e.getMessage());
             handleException(msg, new RuntimeCamelException(msg, e));
         }
 
@@ -178,7 +180,7 @@ public class SalesforceConsumer extends DefaultConsumer {
                     // noop
                     if (log.isTraceEnabled()) {
                         log.trace("Done processing event: {} {}", eventType.toString(),
-                            doneSync ? "synchronously" : "asynchronously");
+                                doneSync ? "synchronously" : "asynchronously");
                     }
                 }
             });

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/SalesforceEndpoint.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceEndpoint.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceEndpoint.java
index 24874bb..b7283eb 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceEndpoint.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceEndpoint.java
@@ -19,9 +19,9 @@ package org.apache.camel.component.salesforce;
 import org.apache.camel.Consumer;
 import org.apache.camel.Processor;
 import org.apache.camel.Producer;
+import org.apache.camel.component.salesforce.internal.OperationName;
 import org.apache.camel.impl.DefaultEndpoint;
 import org.apache.camel.impl.SynchronousDelegateProducer;
-import org.apache.camel.component.salesforce.internal.OperationName;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -63,11 +63,11 @@ public class SalesforceEndpoint extends DefaultEndpoint {
         // consumer requires a topicName, operation name must be the invalid topic name
         if (topicName == null) {
             throw new IllegalArgumentException(String.format("Invalid topic name %s, matches a producer operation name",
-                operationName.value()));
+                    operationName.value()));
         }
 
         return new SalesforceConsumer(this, processor,
-            getComponent().getSubscriptionHelper());
+                getComponent().getSubscriptionHelper());
     }
 
     @Override

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/SalesforceEndpointConfig.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceEndpointConfig.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceEndpointConfig.java
index 817871b..78643c0 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceEndpointConfig.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceEndpointConfig.java
@@ -16,22 +16,22 @@
  */
 package org.apache.camel.component.salesforce;
 
+import java.util.Collections;
+import java.util.HashMap;
+import java.util.Map;
+
 import org.apache.camel.RuntimeCamelException;
-import org.eclipse.jetty.client.HttpClient;
 import org.apache.camel.component.salesforce.api.dto.bulk.ContentType;
 import org.apache.camel.component.salesforce.api.dto.bulk.OperationEnum;
 import org.apache.camel.component.salesforce.internal.PayloadFormat;
 import org.apache.camel.component.salesforce.internal.dto.NotifyForFieldsEnum;
 import org.apache.camel.component.salesforce.internal.dto.NotifyForOperationsEnum;
-
-import java.util.Collections;
-import java.util.HashMap;
-import java.util.Map;
+import org.eclipse.jetty.client.HttpClient;
 
 public class SalesforceEndpointConfig implements Cloneable {
 
     // default API version
-    static final String DEFAULT_VERSION = "27.0";
+    public static final String DEFAULT_VERSION = "27.0";
 
     // general parameter
     public static final String API_VERSION = "apiVersion";

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/SalesforceProducer.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceProducer.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceProducer.java
index 5cc4547..a095f6f 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceProducer.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/SalesforceProducer.java
@@ -18,8 +18,6 @@ package org.apache.camel.component.salesforce;
 
 import org.apache.camel.AsyncCallback;
 import org.apache.camel.Exchange;
-import org.apache.camel.impl.DefaultAsyncProducer;
-import org.apache.camel.util.ServiceHelper;
 import org.apache.camel.component.salesforce.api.SalesforceException;
 import org.apache.camel.component.salesforce.internal.OperationName;
 import org.apache.camel.component.salesforce.internal.PayloadFormat;
@@ -27,6 +25,8 @@ import org.apache.camel.component.salesforce.internal.processor.BulkApiProcessor
 import org.apache.camel.component.salesforce.internal.processor.JsonRestProcessor;
 import org.apache.camel.component.salesforce.internal.processor.SalesforceProcessor;
 import org.apache.camel.component.salesforce.internal.processor.XmlRestProcessor;
+import org.apache.camel.impl.DefaultAsyncProducer;
+import org.apache.camel.util.ServiceHelper;
 
 /**
  * The Salesforce producer.
@@ -57,29 +57,28 @@ public class SalesforceProducer extends DefaultAsyncProducer {
 
     private boolean isBulkOperation(OperationName operationName) {
         switch (operationName) {
-            case CREATE_JOB:
-            case GET_JOB:
-            case CLOSE_JOB:
-            case ABORT_JOB:
-            case CREATE_BATCH:
-            case GET_BATCH:
-            case GET_ALL_BATCHES:
-            case GET_REQUEST:
-            case GET_RESULTS:
-            case CREATE_BATCH_QUERY:
-            case GET_QUERY_RESULT_IDS:
-            case GET_QUERY_RESULT:
-                return true;
-
-            default:
-                return false;
+        case CREATE_JOB:
+        case GET_JOB:
+        case CLOSE_JOB:
+        case ABORT_JOB:
+        case CREATE_BATCH:
+        case GET_BATCH:
+        case GET_ALL_BATCHES:
+        case GET_REQUEST:
+        case GET_RESULTS:
+        case CREATE_BATCH_QUERY:
+        case GET_QUERY_RESULT_IDS:
+        case GET_QUERY_RESULT:
+            return true;
+        default:
+            return false;
         }
     }
 
     @Override
     public boolean process(Exchange exchange, AsyncCallback callback) {
         log.debug("Processing {}",
-            ((SalesforceEndpoint) getEndpoint()).getOperationName());
+                ((SalesforceEndpoint) getEndpoint()).getOperationName());
         return processor.process(exchange, callback);
     }
 

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/api/JodaTimeConverter.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/JodaTimeConverter.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/JodaTimeConverter.java
index 372e7a4..8a3296a 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/JodaTimeConverter.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/JodaTimeConverter.java
@@ -16,6 +16,8 @@
  */
 package org.apache.camel.component.salesforce.api;
 
+import java.lang.reflect.Constructor;
+
 import com.thoughtworks.xstream.converters.Converter;
 import com.thoughtworks.xstream.converters.MarshallingContext;
 import com.thoughtworks.xstream.converters.UnmarshallingContext;
@@ -28,8 +30,6 @@ import org.joda.time.format.ISODateTimeFormat;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import java.lang.reflect.Constructor;
-
 public class JodaTimeConverter implements Converter {
     private static final Logger LOG = LoggerFactory.getLogger(JodaTimeConverter.class);
     private final DateTimeFormatter formatter = ISODateTimeFormat.dateTime();
@@ -50,9 +50,9 @@ public class JodaTimeConverter implements Converter {
             return constructor.newInstance(dateTimeStr, DateTimeZone.UTC);
         } catch (Exception e) {
             throw new IllegalArgumentException(
-                String.format("Error reading Joda DateTime from value %s: %s",
-                    dateTimeStr, e.getMessage()),
-                e);
+                    String.format("Error reading Joda DateTime from value %s: %s",
+                            dateTimeStr, e.getMessage()),
+                    e);
         }
     }
 

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/api/PicklistEnumConverter.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/PicklistEnumConverter.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/PicklistEnumConverter.java
index 06d0ca5..6b5c95b 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/PicklistEnumConverter.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/PicklistEnumConverter.java
@@ -16,6 +16,8 @@
  */
 package org.apache.camel.component.salesforce.api;
 
+import java.lang.reflect.Method;
+
 import com.thoughtworks.xstream.converters.Converter;
 import com.thoughtworks.xstream.converters.MarshallingContext;
 import com.thoughtworks.xstream.converters.UnmarshallingContext;
@@ -24,8 +26,6 @@ import com.thoughtworks.xstream.io.HierarchicalStreamWriter;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import java.lang.reflect.Method;
-
 public class PicklistEnumConverter implements Converter {
     private static final Logger LOG = LoggerFactory.getLogger(PicklistEnumConverter.class);
     private static final String FACTORY_METHOD = "fromValue";
@@ -39,9 +39,9 @@ public class PicklistEnumConverter implements Converter {
             writer.setValue((String) getterMethod.invoke(o));
         } catch (ReflectiveOperationException e) {
             throw new IllegalArgumentException(
-                String.format("Exception writing pick list value %s of type %s: %s",
-                    o, o.getClass().getName(), e.getMessage()),
-                e);
+                    String.format("Exception writing pick list value %s of type %s: %s",
+                            o, o.getClass().getName(), e.getMessage()),
+                    e);
         }
     }
 
@@ -55,14 +55,14 @@ public class PicklistEnumConverter implements Converter {
             return factoryMethod.invoke(null, value);
         } catch (ReflectiveOperationException e) {
             throw new IllegalArgumentException(
-                String.format("Exception reading pick list value %s of type %s: %s",
-                    value, context.getRequiredType().getName(), e.getMessage()),
-                e);
+                    String.format("Exception reading pick list value %s of type %s: %s",
+                            value, context.getRequiredType().getName(), e.getMessage()),
+                    e);
         } catch (SecurityException e) {
             throw new IllegalArgumentException(
-                String.format("Security Exception reading pick list value %s of type %s: %s",
-                    value, context.getRequiredType().getName(), e.getMessage()),
-                e);
+                    String.format("Security Exception reading pick list value %s of type %s: %s",
+                            value, context.getRequiredType().getName(), e.getMessage()),
+                    e);
         }
     }
 
@@ -71,7 +71,7 @@ public class PicklistEnumConverter implements Converter {
     public boolean canConvert(Class aClass) {
         try {
             return Enum.class.isAssignableFrom(aClass) &&
-                aClass.getMethod(FACTORY_METHOD, String.class) != null;
+                    aClass.getMethod(FACTORY_METHOD, String.class) != null;
         } catch (NoSuchMethodException e) {
             return false;
         }

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/api/SalesforceException.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/SalesforceException.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/SalesforceException.java
index 760eebe..96d4622 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/SalesforceException.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/SalesforceException.java
@@ -16,13 +16,13 @@
  */
 package org.apache.camel.component.salesforce.api;
 
-import org.apache.camel.CamelException;
-import org.apache.camel.component.salesforce.api.dto.RestError;
-
 import java.util.ArrayList;
 import java.util.Collections;
 import java.util.List;
 
+import org.apache.camel.CamelException;
+import org.apache.camel.component.salesforce.api.dto.RestError;
+
 public class SalesforceException extends CamelException {
 
     private List<RestError> errors;

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/api/dto/AbstractDTOBase.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/AbstractDTOBase.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/AbstractDTOBase.java
index e4723ae..5052921 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/AbstractDTOBase.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/AbstractDTOBase.java
@@ -16,12 +16,12 @@
  */
 package org.apache.camel.component.salesforce.api.dto;
 
-import org.codehaus.jackson.map.ObjectMapper;
-import org.codehaus.jackson.map.annotate.JsonSerialize;
-
 import java.io.IOException;
 import java.io.StringWriter;
 
+import org.codehaus.jackson.map.ObjectMapper;
+import org.codehaus.jackson.map.annotate.JsonSerialize;
+
 // disable null values in json output
 @JsonSerialize(include = JsonSerialize.Inclusion.NON_NULL)
 public abstract class AbstractDTOBase {

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/api/dto/CreateSObjectResult.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/CreateSObjectResult.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/CreateSObjectResult.java
index bc9fdaa..b7e7dd9 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/CreateSObjectResult.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/CreateSObjectResult.java
@@ -16,11 +16,11 @@
  */
 package org.apache.camel.component.salesforce.api.dto;
 
+import java.util.List;
+
 import com.thoughtworks.xstream.annotations.XStreamAlias;
 import com.thoughtworks.xstream.annotations.XStreamImplicit;
 
-import java.util.List;
-
 @XStreamAlias("Result")
 public class CreateSObjectResult extends AbstractDTOBase {
 

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/api/dto/GlobalObjects.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/GlobalObjects.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/GlobalObjects.java
index 302e54e..f11bebe 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/GlobalObjects.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/GlobalObjects.java
@@ -16,11 +16,11 @@
  */
 package org.apache.camel.component.salesforce.api.dto;
 
+import java.util.List;
+
 import com.thoughtworks.xstream.annotations.XStreamAlias;
 import com.thoughtworks.xstream.annotations.XStreamImplicit;
 
-import java.util.List;
-
 @XStreamAlias("DescribeGlobal")
 public class GlobalObjects extends AbstractDTOBase {
 

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/api/dto/RestError.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/RestError.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/RestError.java
index e155f05..6bda6c4 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/RestError.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/RestError.java
@@ -16,10 +16,10 @@
  */
 package org.apache.camel.component.salesforce.api.dto;
 
-import com.thoughtworks.xstream.annotations.XStreamImplicit;
-
 import java.util.List;
 
+import com.thoughtworks.xstream.annotations.XStreamImplicit;
+
 public class RestError extends AbstractDTOBase {
     private String errorCode;
     private String message;

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/api/dto/SObjectBasicInfo.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SObjectBasicInfo.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SObjectBasicInfo.java
index b31708c..88b5e30 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SObjectBasicInfo.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SObjectBasicInfo.java
@@ -16,10 +16,10 @@
  */
 package org.apache.camel.component.salesforce.api.dto;
 
-import com.thoughtworks.xstream.annotations.XStreamImplicit;
-
 import java.util.List;
 
+import com.thoughtworks.xstream.annotations.XStreamImplicit;
+
 public class SObjectBasicInfo extends AbstractDTOBase {
 
     private SObject objectDescribe;

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/api/dto/SObjectDescription.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SObjectDescription.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SObjectDescription.java
index 5177f4a..cd45847 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SObjectDescription.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SObjectDescription.java
@@ -16,10 +16,10 @@
  */
 package org.apache.camel.component.salesforce.api.dto;
 
-import com.thoughtworks.xstream.annotations.XStreamImplicit;
-
 import java.util.List;
 
+import com.thoughtworks.xstream.annotations.XStreamImplicit;
+
 public class SObjectDescription extends SObject {
 
     @XStreamImplicit

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/api/dto/SObjectField.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SObjectField.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SObjectField.java
index 379365d..8664c19 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SObjectField.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SObjectField.java
@@ -16,10 +16,10 @@
  */
 package org.apache.camel.component.salesforce.api.dto;
 
-import com.thoughtworks.xstream.annotations.XStreamImplicit;
-
 import java.util.List;
 
+import com.thoughtworks.xstream.annotations.XStreamImplicit;
+
 public class SObjectField extends AbstractDTOBase {
 
     private Integer length;

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/api/dto/SearchResults.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SearchResults.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SearchResults.java
index 18fb680..6239756 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SearchResults.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/SearchResults.java
@@ -16,11 +16,11 @@
  */
 package org.apache.camel.component.salesforce.api.dto;
 
+import java.util.List;
+
 import com.thoughtworks.xstream.annotations.XStreamAlias;
 import com.thoughtworks.xstream.annotations.XStreamImplicit;
 
-import java.util.List;
-
 /**
  * DTO for Salesforce SOSL Search results.
  */

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/api/dto/Versions.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/Versions.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/Versions.java
index 1349eb8..e104c14 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/Versions.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/Versions.java
@@ -16,11 +16,11 @@
  */
 package org.apache.camel.component.salesforce.api.dto;
 
+import java.util.List;
+
 import com.thoughtworks.xstream.annotations.XStreamAlias;
 import com.thoughtworks.xstream.annotations.XStreamImplicit;
 
-import java.util.List;
-
 /**
  * DTO for Salesforce versions
  */

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/api/dto/bulk/BatchInfo.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchInfo.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchInfo.java
index 2a78b22..d33de87 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchInfo.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchInfo.java
@@ -16,15 +16,19 @@
  */
 package org.apache.camel.component.salesforce.api.dto.bulk;
 
-import javax.xml.bind.annotation.*;
+import javax.xml.bind.annotation.XmlAccessType;
+import javax.xml.bind.annotation.XmlAccessorType;
+import javax.xml.bind.annotation.XmlElement;
+import javax.xml.bind.annotation.XmlSchemaType;
+import javax.xml.bind.annotation.XmlType;
 import javax.xml.datatype.XMLGregorianCalendar;
 
 
 /**
  * <p>Java class for BatchInfo complex type.
- * 
+ * <p/>
  * <p>The following schema fragment specifies the expected content contained within this class.
- * 
+ * <p/>
  * <pre>
  * &lt;complexType name="BatchInfo">
  *   &lt;complexContent>
@@ -46,22 +50,20 @@ import javax.xml.datatype.XMLGregorianCalendar;
  *   &lt;/complexContent>
  * &lt;/complexType>
  * </pre>
- * 
- * 
  */
 @XmlAccessorType(XmlAccessType.FIELD)
 @XmlType(name = "BatchInfo", propOrder = {
-    "id",
-    "jobId",
-    "state",
-    "stateMessage",
-    "createdDate",
-    "systemModstamp",
-    "numberRecordsProcessed",
-    "numberRecordsFailed",
-    "totalProcessingTime",
-    "apiActiveProcessingTime",
-    "apexProcessingTime"
+        "id",
+        "jobId",
+        "state",
+        "stateMessage",
+        "createdDate",
+        "systemModstamp",
+        "numberRecordsProcessed",
+        "numberRecordsFailed",
+        "totalProcessingTime",
+        "apiActiveProcessingTime",
+        "apexProcessingTime"
 })
 public class BatchInfo {
 
@@ -85,11 +87,9 @@ public class BatchInfo {
 
     /**
      * Gets the value of the id property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link String }
-     *     
+     *
+     * @return possible object is
+     *         {@link String }
      */
     public String getId() {
         return id;
@@ -97,11 +97,9 @@ public class BatchInfo {
 
     /**
      * Sets the value of the id property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link String }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link String }
      */
     public void setId(String value) {
         this.id = value;
@@ -109,11 +107,9 @@ public class BatchInfo {
 
     /**
      * Gets the value of the jobId property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link String }
-     *     
+     *
+     * @return possible object is
+     *         {@link String }
      */
     public String getJobId() {
         return jobId;
@@ -121,11 +117,9 @@ public class BatchInfo {
 
     /**
      * Sets the value of the jobId property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link String }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link String }
      */
     public void setJobId(String value) {
         this.jobId = value;
@@ -133,11 +127,9 @@ public class BatchInfo {
 
     /**
      * Gets the value of the state property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link BatchStateEnum }
      *
+     * @return possible object is
+     *         {@link BatchStateEnum }
      */
     public BatchStateEnum getState() {
         return state;
@@ -146,10 +138,8 @@ public class BatchInfo {
     /**
      * Sets the value of the state property.
      *
-     * @param value
-     *     allowed object is
-     *     {@link BatchStateEnum }
-     *
+     * @param value allowed object is
+     *              {@link BatchStateEnum }
      */
     public void setState(BatchStateEnum value) {
         this.state = value;
@@ -158,10 +148,8 @@ public class BatchInfo {
     /**
      * Gets the value of the stateMessage property.
      *
-     * @return
-     *     possible object is
-     *     {@link String }
-     *
+     * @return possible object is
+     *         {@link String }
      */
     public String getStateMessage() {
         return stateMessage;
@@ -170,10 +158,8 @@ public class BatchInfo {
     /**
      * Sets the value of the stateMessage property.
      *
-     * @param value
-     *     allowed object is
-     *     {@link String }
-     *
+     * @param value allowed object is
+     *              {@link String }
      */
     public void setStateMessage(String value) {
         this.stateMessage = value;
@@ -182,10 +168,8 @@ public class BatchInfo {
     /**
      * Gets the value of the createdDate property.
      *
-     * @return
-     *     possible object is
-     *     {@link javax.xml.datatype.XMLGregorianCalendar }
-     *
+     * @return possible object is
+     *         {@link javax.xml.datatype.XMLGregorianCalendar }
      */
     public XMLGregorianCalendar getCreatedDate() {
         return createdDate;
@@ -194,10 +178,8 @@ public class BatchInfo {
     /**
      * Sets the value of the createdDate property.
      *
-     * @param value
-     *     allowed object is
-     *     {@link javax.xml.datatype.XMLGregorianCalendar }
-     *
+     * @param value allowed object is
+     *              {@link javax.xml.datatype.XMLGregorianCalendar }
      */
     public void setCreatedDate(XMLGregorianCalendar value) {
         this.createdDate = value;
@@ -206,10 +188,8 @@ public class BatchInfo {
     /**
      * Gets the value of the systemModstamp property.
      *
-     * @return
-     *     possible object is
-     *     {@link javax.xml.datatype.XMLGregorianCalendar }
-     *
+     * @return possible object is
+     *         {@link javax.xml.datatype.XMLGregorianCalendar }
      */
     public XMLGregorianCalendar getSystemModstamp() {
         return systemModstamp;
@@ -218,10 +198,8 @@ public class BatchInfo {
     /**
      * Sets the value of the systemModstamp property.
      *
-     * @param value
-     *     allowed object is
-     *     {@link javax.xml.datatype.XMLGregorianCalendar }
-     *     
+     * @param value allowed object is
+     *              {@link javax.xml.datatype.XMLGregorianCalendar }
      */
     public void setSystemModstamp(XMLGregorianCalendar value) {
         this.systemModstamp = value;
@@ -229,7 +207,6 @@ public class BatchInfo {
 
     /**
      * Gets the value of the numberRecordsProcessed property.
-     * 
      */
     public int getNumberRecordsProcessed() {
         return numberRecordsProcessed;
@@ -237,7 +214,6 @@ public class BatchInfo {
 
     /**
      * Sets the value of the numberRecordsProcessed property.
-     * 
      */
     public void setNumberRecordsProcessed(int value) {
         this.numberRecordsProcessed = value;
@@ -245,11 +221,9 @@ public class BatchInfo {
 
     /**
      * Gets the value of the numberRecordsFailed property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link Integer }
-     *     
+     *
+     * @return possible object is
+     *         {@link Integer }
      */
     public Integer getNumberRecordsFailed() {
         return numberRecordsFailed;
@@ -257,11 +231,9 @@ public class BatchInfo {
 
     /**
      * Sets the value of the numberRecordsFailed property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link Integer }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link Integer }
      */
     public void setNumberRecordsFailed(Integer value) {
         this.numberRecordsFailed = value;
@@ -269,11 +241,9 @@ public class BatchInfo {
 
     /**
      * Gets the value of the totalProcessingTime property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link Long }
-     *     
+     *
+     * @return possible object is
+     *         {@link Long }
      */
     public Long getTotalProcessingTime() {
         return totalProcessingTime;
@@ -281,11 +251,9 @@ public class BatchInfo {
 
     /**
      * Sets the value of the totalProcessingTime property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link Long }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link Long }
      */
     public void setTotalProcessingTime(Long value) {
         this.totalProcessingTime = value;
@@ -293,11 +261,9 @@ public class BatchInfo {
 
     /**
      * Gets the value of the apiActiveProcessingTime property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link Long }
-     *     
+     *
+     * @return possible object is
+     *         {@link Long }
      */
     public Long getApiActiveProcessingTime() {
         return apiActiveProcessingTime;
@@ -305,11 +271,9 @@ public class BatchInfo {
 
     /**
      * Sets the value of the apiActiveProcessingTime property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link Long }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link Long }
      */
     public void setApiActiveProcessingTime(Long value) {
         this.apiActiveProcessingTime = value;
@@ -317,11 +281,9 @@ public class BatchInfo {
 
     /**
      * Gets the value of the apexProcessingTime property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link Long }
-     *     
+     *
+     * @return possible object is
+     *         {@link Long }
      */
     public Long getApexProcessingTime() {
         return apexProcessingTime;
@@ -329,11 +291,9 @@ public class BatchInfo {
 
     /**
      * Sets the value of the apexProcessingTime property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link Long }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link Long }
      */
     public void setApexProcessingTime(Long value) {
         this.apexProcessingTime = value;

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/api/dto/bulk/BatchInfoList.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchInfoList.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchInfoList.java
index de73632..9c15711 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchInfoList.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchInfoList.java
@@ -16,18 +16,18 @@
  */
 package org.apache.camel.component.salesforce.api.dto.bulk;
 
+import java.util.ArrayList;
+import java.util.List;
 import javax.xml.bind.annotation.XmlAccessType;
 import javax.xml.bind.annotation.XmlAccessorType;
 import javax.xml.bind.annotation.XmlType;
-import java.util.ArrayList;
-import java.util.List;
 
 
 /**
  * <p>Java class for BatchInfoList complex type.
- * 
+ * <p/>
  * <p>The following schema fragment specifies the expected content contained within this class.
- * 
+ * <p/>
  * <pre>
  * &lt;complexType name="BatchInfoList">
  *   &lt;complexContent>
@@ -39,12 +39,10 @@ import java.util.List;
  *   &lt;/complexContent>
  * &lt;/complexType>
  * </pre>
- * 
- * 
  */
 @XmlAccessorType(XmlAccessType.FIELD)
 @XmlType(name = "BatchInfoList", propOrder = {
-    "batchInfo"
+        "batchInfo"
 })
 public class BatchInfoList {
 
@@ -52,25 +50,23 @@ public class BatchInfoList {
 
     /**
      * Gets the value of the batchInfo property.
-     * 
-     * <p>
+     * <p/>
+     * <p/>
      * This accessor method returns a reference to the live list,
      * not a snapshot. Therefore any modification you make to the
      * returned list will be present inside the JAXB object.
      * This is why there is not a <CODE>set</CODE> method for the batchInfo property.
-     * 
-     * <p>
+     * <p/>
+     * <p/>
      * For example, to add a new item, do as follows:
      * <pre>
      *    getBatchInfo().add(newItem);
      * </pre>
-     * 
-     * 
-     * <p>
+     * <p/>
+     * <p/>
+     * <p/>
      * Objects of the following type(s) are allowed in the list
      * {@link BatchInfo }
-     * 
-     * 
      */
     public List<BatchInfo> getBatchInfo() {
         if (batchInfo == null) {

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/api/dto/bulk/BatchResult.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchResult.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchResult.java
index f7a7f72..b223965 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchResult.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchResult.java
@@ -16,18 +16,18 @@
  */
 package org.apache.camel.component.salesforce.api.dto.bulk;
 
+import java.util.ArrayList;
+import java.util.List;
 import javax.xml.bind.annotation.XmlAccessType;
 import javax.xml.bind.annotation.XmlAccessorType;
 import javax.xml.bind.annotation.XmlType;
-import java.util.ArrayList;
-import java.util.List;
 
 
 /**
  * <p>Java class for BatchResult complex type.
- * 
+ * <p/>
  * <p>The following schema fragment specifies the expected content contained within this class.
- * 
+ * <p/>
  * <pre>
  * &lt;complexType name="BatchResult">
  *   &lt;complexContent>
@@ -39,12 +39,10 @@ import java.util.List;
  *   &lt;/complexContent>
  * &lt;/complexType>
  * </pre>
- * 
- * 
  */
 @XmlAccessorType(XmlAccessType.FIELD)
 @XmlType(name = "BatchResult", propOrder = {
-    "result"
+        "result"
 })
 public class BatchResult {
 
@@ -52,25 +50,23 @@ public class BatchResult {
 
     /**
      * Gets the value of the result property.
-     * 
-     * <p>
+     * <p/>
+     * <p/>
      * This accessor method returns a reference to the live list,
      * not a snapshot. Therefore any modification you make to the
      * returned list will be present inside the JAXB object.
      * This is why there is not a <CODE>set</CODE> method for the result property.
-     * 
-     * <p>
+     * <p/>
+     * <p/>
      * For example, to add a new item, do as follows:
      * <pre>
      *    getResult().add(newItem);
      * </pre>
-     * 
-     * 
-     * <p>
+     * <p/>
+     * <p/>
+     * <p/>
      * Objects of the following type(s) are allowed in the list
      * {@link Result }
-     * 
-     * 
      */
     public List<Result> getResult() {
         if (result == null) {

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/api/dto/bulk/BatchStateEnum.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchStateEnum.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchStateEnum.java
index 1914ec0..b6be0d2 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchStateEnum.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/BatchStateEnum.java
@@ -23,9 +23,9 @@ import javax.xml.bind.annotation.XmlType;
 
 /**
  * <p>Java class for BatchStateEnum.
- * 
+ * <p/>
  * <p>The following schema fragment specifies the expected content contained within this class.
- * <p>
+ * <p/>
  * <pre>
  * &lt;simpleType name="BatchStateEnum">
  *   &lt;restriction base="{http://www.w3.org/2001/XMLSchema}string">
@@ -37,7 +37,6 @@ import javax.xml.bind.annotation.XmlType;
  *   &lt;/restriction>
  * &lt;/simpleType>
  * </pre>
- * 
  */
 @XmlType(name = "BatchStateEnum")
 @XmlEnum
@@ -64,7 +63,7 @@ public enum BatchStateEnum {
     }
 
     public static BatchStateEnum fromValue(String v) {
-        for (BatchStateEnum c: BatchStateEnum.values()) {
+        for (BatchStateEnum c : BatchStateEnum.values()) {
             if (c.value.equals(v)) {
                 return c;
             }

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/api/dto/bulk/ConcurrencyModeEnum.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/ConcurrencyModeEnum.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/ConcurrencyModeEnum.java
index 879bb37..2a244ed 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/ConcurrencyModeEnum.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/ConcurrencyModeEnum.java
@@ -23,9 +23,9 @@ import javax.xml.bind.annotation.XmlType;
 
 /**
  * <p>Java class for ConcurrencyModeEnum.
- * 
+ * <p/>
  * <p>The following schema fragment specifies the expected content contained within this class.
- * <p>
+ * <p/>
  * <pre>
  * &lt;simpleType name="ConcurrencyModeEnum">
  *   &lt;restriction base="{http://www.w3.org/2001/XMLSchema}string">
@@ -34,7 +34,6 @@ import javax.xml.bind.annotation.XmlType;
  *   &lt;/restriction>
  * &lt;/simpleType>
  * </pre>
- * 
  */
 @XmlType(name = "ConcurrencyModeEnum")
 @XmlEnum
@@ -55,7 +54,7 @@ public enum ConcurrencyModeEnum {
     }
 
     public static ConcurrencyModeEnum fromValue(String v) {
-        for (ConcurrencyModeEnum c: ConcurrencyModeEnum.values()) {
+        for (ConcurrencyModeEnum c : ConcurrencyModeEnum.values()) {
             if (c.value.equals(v)) {
                 return c;
             }

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/api/dto/bulk/ContentType.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/ContentType.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/ContentType.java
index 1a3c75e..c5b4541 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/ContentType.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/ContentType.java
@@ -22,9 +22,9 @@ import javax.xml.bind.annotation.XmlType;
 
 /**
  * <p>Java class for ContentType.
- * 
+ * <p/>
  * <p>The following schema fragment specifies the expected content contained within this class.
- * <p>
+ * <p/>
  * <pre>
  * &lt;simpleType name="ContentType">
  *   &lt;restriction base="{http://www.w3.org/2001/XMLSchema}string">
@@ -35,7 +35,6 @@ import javax.xml.bind.annotation.XmlType;
  *   &lt;/restriction>
  * &lt;/simpleType>
  * </pre>
- * 
  */
 @XmlType(name = "ContentType")
 @XmlEnum

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/api/dto/bulk/Error.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/Error.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/Error.java
index 4a06fbb..ee4cad1 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/Error.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/Error.java
@@ -24,9 +24,9 @@ import javax.xml.bind.annotation.XmlType;
 
 /**
  * <p>Java class for Error complex type.
- * 
+ * <p/>
  * <p>The following schema fragment specifies the expected content contained within this class.
- * 
+ * <p/>
  * <pre>
  * &lt;complexType name="Error">
  *   &lt;complexContent>
@@ -39,13 +39,11 @@ import javax.xml.bind.annotation.XmlType;
  *   &lt;/complexContent>
  * &lt;/complexType>
  * </pre>
- * 
- * 
  */
 @XmlAccessorType(XmlAccessType.FIELD)
 @XmlType(name = "Error", propOrder = {
-    "exceptionCode",
-    "exceptionMessage"
+        "exceptionCode",
+        "exceptionMessage"
 })
 public class Error {
 
@@ -56,11 +54,9 @@ public class Error {
 
     /**
      * Gets the value of the exceptionCode property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link String }
-     *     
+     *
+     * @return possible object is
+     *         {@link String }
      */
     public String getExceptionCode() {
         return exceptionCode;
@@ -68,11 +64,9 @@ public class Error {
 
     /**
      * Sets the value of the exceptionCode property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link String }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link String }
      */
     public void setExceptionCode(String value) {
         this.exceptionCode = value;
@@ -80,11 +74,9 @@ public class Error {
 
     /**
      * Gets the value of the exceptionMessage property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link String }
-     *     
+     *
+     * @return possible object is
+     *         {@link String }
      */
     public String getExceptionMessage() {
         return exceptionMessage;
@@ -92,11 +84,9 @@ public class Error {
 
     /**
      * Sets the value of the exceptionMessage property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link String }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link String }
      */
     public void setExceptionMessage(String value) {
         this.exceptionMessage = value;

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/api/dto/bulk/JobInfo.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/JobInfo.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/JobInfo.java
index 568138c..f06ad3d 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/JobInfo.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/JobInfo.java
@@ -25,9 +25,9 @@ import javax.xml.datatype.XMLGregorianCalendar;
 
 /**
  * <p>Java class for JobInfo complex type.
- * 
+ * <p/>
  * <p>The following schema fragment specifies the expected content contained within this class.
- * 
+ * <p/>
  * <pre>
  * &lt;complexType name="JobInfo">
  *   &lt;complexContent>
@@ -61,34 +61,32 @@ import javax.xml.datatype.XMLGregorianCalendar;
  *   &lt;/complexContent>
  * &lt;/complexType>
  * </pre>
- * 
- * 
  */
 @XmlAccessorType(XmlAccessType.FIELD)
 @XmlType(name = "JobInfo", propOrder = {
-    "id",
-    "operation",
-    "object",
-    "createdById",
-    "createdDate",
-    "systemModstamp",
-    "state",
-    "externalIdFieldName",
-    "concurrencyMode",
-    "contentType",
-    "numberBatchesQueued",
-    "numberBatchesInProgress",
-    "numberBatchesCompleted",
-    "numberBatchesFailed",
-    "numberBatchesTotal",
-    "numberRecordsProcessed",
-    "numberRetries",
-    "apiVersion",
-    "assignmentRuleId",
-    "numberRecordsFailed",
-    "totalProcessingTime",
-    "apiActiveProcessingTime",
-    "apexProcessingTime"
+        "id",
+        "operation",
+        "object",
+        "createdById",
+        "createdDate",
+        "systemModstamp",
+        "state",
+        "externalIdFieldName",
+        "concurrencyMode",
+        "contentType",
+        "numberBatchesQueued",
+        "numberBatchesInProgress",
+        "numberBatchesCompleted",
+        "numberBatchesFailed",
+        "numberBatchesTotal",
+        "numberRecordsProcessed",
+        "numberRetries",
+        "apiVersion",
+        "assignmentRuleId",
+        "numberRecordsFailed",
+        "totalProcessingTime",
+        "apiActiveProcessingTime",
+        "apexProcessingTime"
 })
 public class JobInfo {
 
@@ -120,11 +118,9 @@ public class JobInfo {
 
     /**
      * Gets the value of the id property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link String }
-     *     
+     *
+     * @return possible object is
+     *         {@link String }
      */
     public String getId() {
         return id;
@@ -132,11 +128,9 @@ public class JobInfo {
 
     /**
      * Sets the value of the id property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link String }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link String }
      */
     public void setId(String value) {
         this.id = value;
@@ -144,11 +138,9 @@ public class JobInfo {
 
     /**
      * Gets the value of the operation property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link OperationEnum }
      *
+     * @return possible object is
+     *         {@link OperationEnum }
      */
     public OperationEnum getOperation() {
         return operation;
@@ -157,10 +149,8 @@ public class JobInfo {
     /**
      * Sets the value of the operation property.
      *
-     * @param value
-     *     allowed object is
-     *     {@link OperationEnum }
-     *
+     * @param value allowed object is
+     *              {@link OperationEnum }
      */
     public void setOperation(OperationEnum value) {
         this.operation = value;
@@ -169,10 +159,8 @@ public class JobInfo {
     /**
      * Gets the value of the object property.
      *
-     * @return
-     *     possible object is
-     *     {@link String }
-     *
+     * @return possible object is
+     *         {@link String }
      */
     public String getObject() {
         return object;
@@ -181,10 +169,8 @@ public class JobInfo {
     /**
      * Sets the value of the object property.
      *
-     * @param value
-     *     allowed object is
-     *     {@link String }
-     *
+     * @param value allowed object is
+     *              {@link String }
      */
     public void setObject(String value) {
         this.object = value;
@@ -193,10 +179,8 @@ public class JobInfo {
     /**
      * Gets the value of the createdById property.
      *
-     * @return
-     *     possible object is
-     *     {@link String }
-     *
+     * @return possible object is
+     *         {@link String }
      */
     public String getCreatedById() {
         return createdById;
@@ -205,10 +189,8 @@ public class JobInfo {
     /**
      * Sets the value of the createdById property.
      *
-     * @param value
-     *     allowed object is
-     *     {@link String }
-     *
+     * @param value allowed object is
+     *              {@link String }
      */
     public void setCreatedById(String value) {
         this.createdById = value;
@@ -217,10 +199,8 @@ public class JobInfo {
     /**
      * Gets the value of the createdDate property.
      *
-     * @return
-     *     possible object is
-     *     {@link javax.xml.datatype.XMLGregorianCalendar }
-     *
+     * @return possible object is
+     *         {@link javax.xml.datatype.XMLGregorianCalendar }
      */
     public XMLGregorianCalendar getCreatedDate() {
         return createdDate;
@@ -229,10 +209,8 @@ public class JobInfo {
     /**
      * Sets the value of the createdDate property.
      *
-     * @param value
-     *     allowed object is
-     *     {@link javax.xml.datatype.XMLGregorianCalendar }
-     *
+     * @param value allowed object is
+     *              {@link javax.xml.datatype.XMLGregorianCalendar }
      */
     public void setCreatedDate(XMLGregorianCalendar value) {
         this.createdDate = value;
@@ -241,10 +219,8 @@ public class JobInfo {
     /**
      * Gets the value of the systemModstamp property.
      *
-     * @return
-     *     possible object is
-     *     {@link javax.xml.datatype.XMLGregorianCalendar }
-     *
+     * @return possible object is
+     *         {@link javax.xml.datatype.XMLGregorianCalendar }
      */
     public XMLGregorianCalendar getSystemModstamp() {
         return systemModstamp;
@@ -253,10 +229,8 @@ public class JobInfo {
     /**
      * Sets the value of the systemModstamp property.
      *
-     * @param value
-     *     allowed object is
-     *     {@link javax.xml.datatype.XMLGregorianCalendar }
-     *
+     * @param value allowed object is
+     *              {@link javax.xml.datatype.XMLGregorianCalendar }
      */
     public void setSystemModstamp(XMLGregorianCalendar value) {
         this.systemModstamp = value;
@@ -265,10 +239,8 @@ public class JobInfo {
     /**
      * Gets the value of the state property.
      *
-     * @return
-     *     possible object is
-     *     {@link JobStateEnum }
-     *
+     * @return possible object is
+     *         {@link JobStateEnum }
      */
     public JobStateEnum getState() {
         return state;
@@ -277,10 +249,8 @@ public class JobInfo {
     /**
      * Sets the value of the state property.
      *
-     * @param value
-     *     allowed object is
-     *     {@link JobStateEnum }
-     *
+     * @param value allowed object is
+     *              {@link JobStateEnum }
      */
     public void setState(JobStateEnum value) {
         this.state = value;
@@ -289,10 +259,8 @@ public class JobInfo {
     /**
      * Gets the value of the externalIdFieldName property.
      *
-     * @return
-     *     possible object is
-     *     {@link String }
-     *
+     * @return possible object is
+     *         {@link String }
      */
     public String getExternalIdFieldName() {
         return externalIdFieldName;
@@ -301,10 +269,8 @@ public class JobInfo {
     /**
      * Sets the value of the externalIdFieldName property.
      *
-     * @param value
-     *     allowed object is
-     *     {@link String }
-     *
+     * @param value allowed object is
+     *              {@link String }
      */
     public void setExternalIdFieldName(String value) {
         this.externalIdFieldName = value;
@@ -313,10 +279,8 @@ public class JobInfo {
     /**
      * Gets the value of the concurrencyMode property.
      *
-     * @return
-     *     possible object is
-     *     {@link ConcurrencyModeEnum }
-     *
+     * @return possible object is
+     *         {@link ConcurrencyModeEnum }
      */
     public ConcurrencyModeEnum getConcurrencyMode() {
         return concurrencyMode;
@@ -325,10 +289,8 @@ public class JobInfo {
     /**
      * Sets the value of the concurrencyMode property.
      *
-     * @param value
-     *     allowed object is
-     *     {@link ConcurrencyModeEnum }
-     *
+     * @param value allowed object is
+     *              {@link ConcurrencyModeEnum }
      */
     public void setConcurrencyMode(ConcurrencyModeEnum value) {
         this.concurrencyMode = value;
@@ -337,10 +299,8 @@ public class JobInfo {
     /**
      * Gets the value of the contentType property.
      *
-     * @return
-     *     possible object is
-     *     {@link ContentType }
-     *
+     * @return possible object is
+     *         {@link ContentType }
      */
     public ContentType getContentType() {
         return contentType;
@@ -349,10 +309,8 @@ public class JobInfo {
     /**
      * Sets the value of the contentType property.
      *
-     * @param value
-     *     allowed object is
-     *     {@link ContentType }
-     *     
+     * @param value allowed object is
+     *              {@link ContentType }
      */
     public void setContentType(ContentType value) {
         this.contentType = value;
@@ -360,11 +318,9 @@ public class JobInfo {
 
     /**
      * Gets the value of the numberBatchesQueued property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link Integer }
-     *     
+     *
+     * @return possible object is
+     *         {@link Integer }
      */
     public Integer getNumberBatchesQueued() {
         return numberBatchesQueued;
@@ -372,11 +328,9 @@ public class JobInfo {
 
     /**
      * Sets the value of the numberBatchesQueued property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link Integer }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link Integer }
      */
     public void setNumberBatchesQueued(Integer value) {
         this.numberBatchesQueued = value;
@@ -384,11 +338,9 @@ public class JobInfo {
 
     /**
      * Gets the value of the numberBatchesInProgress property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link Integer }
-     *     
+     *
+     * @return possible object is
+     *         {@link Integer }
      */
     public Integer getNumberBatchesInProgress() {
         return numberBatchesInProgress;
@@ -396,11 +348,9 @@ public class JobInfo {
 
     /**
      * Sets the value of the numberBatchesInProgress property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link Integer }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link Integer }
      */
     public void setNumberBatchesInProgress(Integer value) {
         this.numberBatchesInProgress = value;
@@ -408,11 +358,9 @@ public class JobInfo {
 
     /**
      * Gets the value of the numberBatchesCompleted property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link Integer }
-     *     
+     *
+     * @return possible object is
+     *         {@link Integer }
      */
     public Integer getNumberBatchesCompleted() {
         return numberBatchesCompleted;
@@ -420,11 +368,9 @@ public class JobInfo {
 
     /**
      * Sets the value of the numberBatchesCompleted property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link Integer }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link Integer }
      */
     public void setNumberBatchesCompleted(Integer value) {
         this.numberBatchesCompleted = value;
@@ -432,11 +378,9 @@ public class JobInfo {
 
     /**
      * Gets the value of the numberBatchesFailed property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link Integer }
-     *     
+     *
+     * @return possible object is
+     *         {@link Integer }
      */
     public Integer getNumberBatchesFailed() {
         return numberBatchesFailed;
@@ -444,11 +388,9 @@ public class JobInfo {
 
     /**
      * Sets the value of the numberBatchesFailed property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link Integer }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link Integer }
      */
     public void setNumberBatchesFailed(Integer value) {
         this.numberBatchesFailed = value;
@@ -456,11 +398,9 @@ public class JobInfo {
 
     /**
      * Gets the value of the numberBatchesTotal property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link Integer }
-     *     
+     *
+     * @return possible object is
+     *         {@link Integer }
      */
     public Integer getNumberBatchesTotal() {
         return numberBatchesTotal;
@@ -468,11 +408,9 @@ public class JobInfo {
 
     /**
      * Sets the value of the numberBatchesTotal property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link Integer }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link Integer }
      */
     public void setNumberBatchesTotal(Integer value) {
         this.numberBatchesTotal = value;
@@ -480,11 +418,9 @@ public class JobInfo {
 
     /**
      * Gets the value of the numberRecordsProcessed property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link Integer }
-     *     
+     *
+     * @return possible object is
+     *         {@link Integer }
      */
     public Integer getNumberRecordsProcessed() {
         return numberRecordsProcessed;
@@ -492,11 +428,9 @@ public class JobInfo {
 
     /**
      * Sets the value of the numberRecordsProcessed property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link Integer }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link Integer }
      */
     public void setNumberRecordsProcessed(Integer value) {
         this.numberRecordsProcessed = value;
@@ -504,11 +438,9 @@ public class JobInfo {
 
     /**
      * Gets the value of the numberRetries property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link Integer }
-     *     
+     *
+     * @return possible object is
+     *         {@link Integer }
      */
     public Integer getNumberRetries() {
         return numberRetries;
@@ -516,11 +448,9 @@ public class JobInfo {
 
     /**
      * Sets the value of the numberRetries property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link Integer }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link Integer }
      */
     public void setNumberRetries(Integer value) {
         this.numberRetries = value;
@@ -528,11 +458,9 @@ public class JobInfo {
 
     /**
      * Gets the value of the apiVersion property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link String }
-     *     
+     *
+     * @return possible object is
+     *         {@link String }
      */
     public String getApiVersion() {
         return apiVersion;
@@ -540,11 +468,9 @@ public class JobInfo {
 
     /**
      * Sets the value of the apiVersion property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link String }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link String }
      */
     public void setApiVersion(String value) {
         this.apiVersion = value;
@@ -552,11 +478,9 @@ public class JobInfo {
 
     /**
      * Gets the value of the assignmentRuleId property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link String }
-     *     
+     *
+     * @return possible object is
+     *         {@link String }
      */
     public String getAssignmentRuleId() {
         return assignmentRuleId;
@@ -564,11 +488,9 @@ public class JobInfo {
 
     /**
      * Sets the value of the assignmentRuleId property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link String }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link String }
      */
     public void setAssignmentRuleId(String value) {
         this.assignmentRuleId = value;
@@ -576,11 +498,9 @@ public class JobInfo {
 
     /**
      * Gets the value of the numberRecordsFailed property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link Integer }
-     *     
+     *
+     * @return possible object is
+     *         {@link Integer }
      */
     public Integer getNumberRecordsFailed() {
         return numberRecordsFailed;
@@ -588,11 +508,9 @@ public class JobInfo {
 
     /**
      * Sets the value of the numberRecordsFailed property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link Integer }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link Integer }
      */
     public void setNumberRecordsFailed(Integer value) {
         this.numberRecordsFailed = value;
@@ -600,11 +518,9 @@ public class JobInfo {
 
     /**
      * Gets the value of the totalProcessingTime property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link Long }
-     *     
+     *
+     * @return possible object is
+     *         {@link Long }
      */
     public Long getTotalProcessingTime() {
         return totalProcessingTime;
@@ -612,11 +528,9 @@ public class JobInfo {
 
     /**
      * Sets the value of the totalProcessingTime property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link Long }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link Long }
      */
     public void setTotalProcessingTime(Long value) {
         this.totalProcessingTime = value;
@@ -624,11 +538,9 @@ public class JobInfo {
 
     /**
      * Gets the value of the apiActiveProcessingTime property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link Long }
-     *     
+     *
+     * @return possible object is
+     *         {@link Long }
      */
     public Long getApiActiveProcessingTime() {
         return apiActiveProcessingTime;
@@ -636,11 +548,9 @@ public class JobInfo {
 
     /**
      * Sets the value of the apiActiveProcessingTime property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link Long }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link Long }
      */
     public void setApiActiveProcessingTime(Long value) {
         this.apiActiveProcessingTime = value;
@@ -648,11 +558,9 @@ public class JobInfo {
 
     /**
      * Gets the value of the apexProcessingTime property.
-     * 
-     * @return
-     *     possible object is
-     *     {@link Long }
-     *     
+     *
+     * @return possible object is
+     *         {@link Long }
      */
     public Long getApexProcessingTime() {
         return apexProcessingTime;
@@ -660,11 +568,9 @@ public class JobInfo {
 
     /**
      * Sets the value of the apexProcessingTime property.
-     * 
-     * @param value
-     *     allowed object is
-     *     {@link Long }
-     *     
+     *
+     * @param value allowed object is
+     *              {@link Long }
      */
     public void setApexProcessingTime(Long value) {
         this.apexProcessingTime = value;

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/api/dto/bulk/JobStateEnum.java
----------------------------------------------------------------------
diff --git a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/JobStateEnum.java b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/JobStateEnum.java
index 474768c..06ca940 100644
--- a/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/JobStateEnum.java
+++ b/components/camel-salesforce/camel-salesforce-component/src/main/java/org/apache/camel/component/salesforce/api/dto/bulk/JobStateEnum.java
@@ -23,9 +23,9 @@ import javax.xml.bind.annotation.XmlType;
 
 /**
  * <p>Java class for JobStateEnum.
- * 
+ * <p/>
  * <p>The following schema fragment specifies the expected content contained within this class.
- * <p>
+ * <p/>
  * <pre>
  * &lt;simpleType name="JobStateEnum">
  *   &lt;restriction base="{http://www.w3.org/2001/XMLSchema}string">
@@ -36,7 +36,6 @@ import javax.xml.bind.annotation.XmlType;
  *   &lt;/restriction>
  * &lt;/simpleType>
  * </pre>
- * 
  */
 @XmlType(name = "JobStateEnum")
 @XmlEnum
@@ -61,7 +60,7 @@ public enum JobStateEnum {
     }
 
     public static JobStateEnum fromValue(String v) {
-        for (JobStateEnum c: JobStateEnum.values()) {
+        for (JobStateEnum c : JobStateEnum.values()) {
             if (c.value.equals(v)) {
                 return c;
             }