You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cxf.apache.org by co...@apache.org on 2017/02/14 09:49:48 UTC

[43/51] [partial] cxf git commit: Remove all trailing whitespaces

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/configuration/spring/ConfigurerImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/configuration/spring/ConfigurerImpl.java b/core/src/main/java/org/apache/cxf/configuration/spring/ConfigurerImpl.java
index c993624..dce13d1 100644
--- a/core/src/main/java/org/apache/cxf/configuration/spring/ConfigurerImpl.java
+++ b/core/src/main/java/org/apache/cxf/configuration/spring/ConfigurerImpl.java
@@ -52,16 +52,16 @@ import org.springframework.context.ApplicationContextAware;
 import org.springframework.context.ConfigurableApplicationContext;
 
 @NoJSR250Annotations
-public class ConfigurerImpl extends BeanConfigurerSupport 
+public class ConfigurerImpl extends BeanConfigurerSupport
     implements Configurer, ApplicationContextAware, BusExtension {
-    
+
     private static final Logger LOG = LogUtils.getL7dLogger(ConfigurerImpl.class);
 
     private Set<ApplicationContext> appContexts;
     private final Map<String, List<MatcherHolder>> wildCardBeanDefinitions
         = new TreeMap<String, List<MatcherHolder>>();
     private BeanFactory beanFactory;
-    
+
     static class MatcherHolder implements Comparable<MatcherHolder> {
         Matcher matcher;
         String wildCardId;
@@ -77,20 +77,20 @@ public class ConfigurerImpl extends BeanConfigurerSupport
             return literalCharsLen1.compareTo(literalCharsLen2) * -1;
         }
     }
-    
+
     public ConfigurerImpl() {
         // complete
     }
-    
+
     public ConfigurerImpl(ApplicationContext ac) {
         setApplicationContext(ac);
     }
-        
+
     public void setBeanFactory(BeanFactory beanFactory) {
         this.beanFactory = beanFactory;
         super.setBeanFactory(beanFactory);
     }
-    
+
     private void initWildcardDefinitionMap() {
         if (null != appContexts) {
             for (ApplicationContext appContext : appContexts) {
@@ -104,7 +104,7 @@ public class ConfigurerImpl extends BeanConfigurerSupport
                             String orig = n;
                             if (n.charAt(0) == '*') {
                                 //old wildcard
-                                n = "." + n.replaceAll("\\.", "\\."); 
+                                n = "." + n.replaceAll("\\.", "\\.");
                             }
                             try {
                                 Matcher matcher = Pattern.compile(n).matcher("");
@@ -115,11 +115,11 @@ public class ConfigurerImpl extends BeanConfigurerSupport
                                 }
                                 MatcherHolder holder = new MatcherHolder(orig, matcher);
                                 m.add(holder);
-                            } catch (PatternSyntaxException npe) { 
+                            } catch (PatternSyntaxException npe) {
                                 //not a valid patter, we'll ignore
                             }
                         } else {
-                            LogUtils.log(LOG, Level.WARNING, "WILDCARD_BEAN_ID_WITH_NO_CLASS_MSG", n); 
+                            LogUtils.log(LOG, Level.WARNING, "WILDCARD_BEAN_ID_WITH_NO_CLASS_MSG", n);
                         }
                     }
                 }
@@ -130,7 +130,7 @@ public class ConfigurerImpl extends BeanConfigurerSupport
     public void configureBean(Object beanInstance) {
         configureBean(null, beanInstance, true);
     }
-    
+
     public void configureBean(String bn, Object beanInstance) {
         configureBean(bn, beanInstance, true);
     }
@@ -139,18 +139,18 @@ public class ConfigurerImpl extends BeanConfigurerSupport
         if (null == appContexts) {
             return;
         }
-        
+
         if (null == bn) {
             bn = getBeanName(beanInstance);
         }
-        
+
         if (null == bn) {
             return;
         }
         if (checkWildcards) {
             configureWithWildCard(bn, beanInstance);
         }
-        
+
         final String beanName = bn;
         setBeanWiringInfoResolver(new BeanWiringInfoResolver() {
             public BeanWiringInfo resolveWiringInfo(Object instance) {
@@ -160,13 +160,13 @@ public class ConfigurerImpl extends BeanConfigurerSupport
                 return null;
             }
         });
-        
+
         for (ApplicationContext appContext : appContexts) {
             if (appContext.containsBean(bn)) {
                 this.setBeanFactory(appContext.getAutowireCapableBeanFactory());
             }
         }
-        
+
         try {
             //this will prevent a call into the AbstractBeanFactory.markBeanAsCreated(...)
             //which saves ALL the names into a HashSet.  For URL based configuration,
@@ -187,10 +187,10 @@ public class ConfigurerImpl extends BeanConfigurerSupport
             }
         }
     }
-    
+
     private void configureWithWildCard(String bn, Object beanInstance) {
         if (!wildCardBeanDefinitions.isEmpty()) {
-            Class<?> clazz = beanInstance.getClass();            
+            Class<?> clazz = beanInstance.getClass();
             while (!Object.class.equals(clazz)) {
                 String className = clazz.getName();
                 List<MatcherHolder> matchers = wildCardBeanDefinitions.get(className);
@@ -237,22 +237,22 @@ public class ConfigurerImpl extends BeanConfigurerSupport
                 LogUtils.log(LOG, Level.WARNING, "ERROR_DETERMINING_BEAN_NAME_EXC", ex);
             }
         }
-        
+
         if (null == beanName) {
             LogUtils.log(LOG, Level.FINE, "COULD_NOT_DETERMINE_BEAN_NAME_MSG",
                          beanInstance.getClass().getName());
         }
-      
+
         return beanName;
     }
-    
+
     public final void setApplicationContext(ApplicationContext ac) {
         appContexts = new CopyOnWriteArraySet<ApplicationContext>();
         addApplicationContext(ac);
         this.beanFactory = ac.getAutowireCapableBeanFactory();
         super.setBeanFactory(this.beanFactory);
     }
-    
+
     public final void addApplicationContext(ApplicationContext ac) {
         if (!appContexts.contains(ac)) {
             appContexts.add(ac);
@@ -272,18 +272,18 @@ public class ConfigurerImpl extends BeanConfigurerSupport
             initWildcardDefinitionMap();
         }
     }
-    
+
     public void destroy() {
-        super.destroy();       
+        super.destroy();
         appContexts.clear();
     }
 
     public Class<?> getRegistrationType() {
         return Configurer.class;
     }
-    
+
     protected Set<ApplicationContext> getAppContexts() {
         return appContexts;
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/configuration/spring/JAXBBeanFactory.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/configuration/spring/JAXBBeanFactory.java b/core/src/main/java/org/apache/cxf/configuration/spring/JAXBBeanFactory.java
index 9c606df..7c0801b 100644
--- a/core/src/main/java/org/apache/cxf/configuration/spring/JAXBBeanFactory.java
+++ b/core/src/main/java/org/apache/cxf/configuration/spring/JAXBBeanFactory.java
@@ -31,21 +31,21 @@ import org.apache.cxf.common.jaxb.JAXBUtils;
 import org.apache.cxf.staxutils.StaxUtils;
 
 /**
- * 
+ *
  */
 public final class JAXBBeanFactory {
     private JAXBBeanFactory() {
         //nothing
     }
-    
-    public static <T> T createJAXBBean(JAXBContext context, 
+
+    public static <T> T createJAXBBean(JAXBContext context,
                                         String s,
                                         Class<T> c) {
-        
+
         StringReader reader = new StringReader(s);
         XMLStreamReader data = StaxUtils.createXMLStreamReader(reader);
         try {
-            
+
             T obj = null;
             if (c != null) {
                 obj = JAXBUtils.unmarshall(context, data, c).getValue();
@@ -56,7 +56,7 @@ public final class JAXBBeanFactory {
                     @SuppressWarnings("unchecked")
                     T ot = (T)el.getValue();
                     obj = ot;
-                }                
+                }
             }
             return obj;
         } catch (JAXBException e) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/configuration/spring/MappingBeanDefinitionParser.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/configuration/spring/MappingBeanDefinitionParser.java b/core/src/main/java/org/apache/cxf/configuration/spring/MappingBeanDefinitionParser.java
index 776edc5..a2bea7c 100644
--- a/core/src/main/java/org/apache/cxf/configuration/spring/MappingBeanDefinitionParser.java
+++ b/core/src/main/java/org/apache/cxf/configuration/spring/MappingBeanDefinitionParser.java
@@ -31,21 +31,21 @@ import org.apache.cxf.staxutils.transform.OutTransformWriter;
 import org.springframework.beans.factory.support.AbstractBeanDefinition;
 import org.springframework.beans.factory.xml.ParserContext;
 
-public class MappingBeanDefinitionParser 
+public class MappingBeanDefinitionParser
     extends org.springframework.beans.factory.xml.AbstractBeanDefinitionParser {
-    
+
     private final Map<String, String> transformMap;
     public MappingBeanDefinitionParser(String oldns, String newns) {
         transformMap = Collections.singletonMap("{" + oldns + "}*", "{" + newns + "}*");
     }
-    
+
     @Override
     protected AbstractBeanDefinition parseInternal(Element element, ParserContext parserContext) {
         element = transformElement(element);
         return (AbstractBeanDefinition)parserContext.getDelegate().parseCustomElement(element);
     }
     private Element transformElement(Element element) {
-        
+
         W3CDOMStreamWriter domWriter = new W3CDOMStreamWriter();
         OutTransformWriter transformWriter = new OutTransformWriter(domWriter, transformMap);
         try {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/continuations/Continuation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/continuations/Continuation.java b/core/src/main/java/org/apache/cxf/continuations/Continuation.java
index b3be6fd..687d3b6 100644
--- a/core/src/main/java/org/apache/cxf/continuations/Continuation.java
+++ b/core/src/main/java/org/apache/cxf/continuations/Continuation.java
@@ -20,62 +20,62 @@
 package org.apache.cxf.continuations;
 
 /**
- * Represents transport-neutral suspended invocation instances 
+ * Represents transport-neutral suspended invocation instances
  * or continuations
  */
 public interface Continuation {
-    
-    /** 
+
+    /**
      * This method will suspend the request for the timeout or until resume is
      * called
-     * 
+     *
      * @param timeout A timeout of < 0 will cause an immediate return.
      * A timeout of 0 will wait indefinitely.
      * @return True if resume called or false if timeout.
      */
     boolean suspend(long timeout);
-    
-    /** 
-     * Resume a suspended request  
+
+    /**
+     * Resume a suspended request
      */
     void resume();
-    
-    /** 
+
+    /**
      * Reset the continuation
      */
     void reset();
-    
-    /** 
+
+    /**
      * Is this a newly created Continuation.
      * @return True if the continuation has just been created and has not yet suspended the request.
      */
     boolean isNew();
-    
-    /** 
+
+    /**
      * Get the pending status
      * @return True if the continuation has been suspended.
      */
     boolean isPending();
-    
-    /** 
+
+    /**
      * Get the resumed status
      * @return True if the continuation is has been resumed.
      */
     boolean isResumed();
-    
-    /** 
+
+    /**
      * Get arbitrary object associated with the continuation for context
-     * 
+     *
      * @return An arbitrary object associated with the continuation
      */
     Object getObject();
-    
-    /** 
+
+    /**
      * Sets arbitrary object associated with the continuation for context
-     * 
+     *
      * @param o An arbitrary object to associate with the continuation
      */
     void setObject(Object o);
-    
+
     boolean isReadyForWrite();
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/continuations/ContinuationCallback.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/continuations/ContinuationCallback.java b/core/src/main/java/org/apache/cxf/continuations/ContinuationCallback.java
index 810e14f..dacc332 100644
--- a/core/src/main/java/org/apache/cxf/continuations/ContinuationCallback.java
+++ b/core/src/main/java/org/apache/cxf/continuations/ContinuationCallback.java
@@ -23,18 +23,18 @@ package org.apache.cxf.continuations;
  * Callback that receives continuation status updates.
  */
 public interface ContinuationCallback {
-    
+
     /**
-     * This method is called when the container completes writing the response to the client  
+     * This method is called when the container completes writing the response to the client
      */
     void onComplete();
-    
+
     /**
-     * This method is called when the exception gets propagated to the container  
+     * This method is called when the exception gets propagated to the container
      * @param error the propagated exception instance
      */
     void onError(Throwable error);
-    
+
     /**
      * This method may be called if the container detects that the client has disconnected
      */

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/continuations/ContinuationProvider.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/continuations/ContinuationProvider.java b/core/src/main/java/org/apache/cxf/continuations/ContinuationProvider.java
index 5285336b..471f48f 100644
--- a/core/src/main/java/org/apache/cxf/continuations/ContinuationProvider.java
+++ b/core/src/main/java/org/apache/cxf/continuations/ContinuationProvider.java
@@ -21,16 +21,16 @@ package org.apache.cxf.continuations;
 
 /**
  * Provides transport-neutral support for creating suspended invocation primitives
- * or continuations   
+ * or continuations
  */
 public interface ContinuationProvider {
-    
+
     /**
      * Creates a new continuation or retrieves the existing one
      * @return transport-neutral ContinuationWrapper
      */
     Continuation getContinuation();
-    
+
     /**
      * Let the provider know that the exchange is complete
      */

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/continuations/SuspendedInvocationException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/continuations/SuspendedInvocationException.java b/core/src/main/java/org/apache/cxf/continuations/SuspendedInvocationException.java
index 20977df..cbe5507 100644
--- a/core/src/main/java/org/apache/cxf/continuations/SuspendedInvocationException.java
+++ b/core/src/main/java/org/apache/cxf/continuations/SuspendedInvocationException.java
@@ -24,21 +24,21 @@ package org.apache.cxf.continuations;
  * a given invocation was suspended
  */
 public class SuspendedInvocationException extends RuntimeException {
-    
+
     private static final long serialVersionUID = 6889545463301144757L;
 
 
     public SuspendedInvocationException(Throwable cause) {
         super(cause);
     }
-    
+
     public SuspendedInvocationException() {
     }
-    
-   
+
+
     /**
      * Returns a transport-specific runtime exception
-     * @return RuntimeException the transport-specific runtime exception, 
+     * @return RuntimeException the transport-specific runtime exception,
      *         can be null for asynchronous transports
      */
     public RuntimeException getRuntimeException() {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/AbstractDataBinding.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/AbstractDataBinding.java b/core/src/main/java/org/apache/cxf/databinding/AbstractDataBinding.java
index ab375fd..c2ba64e 100644
--- a/core/src/main/java/org/apache/cxf/databinding/AbstractDataBinding.java
+++ b/core/src/main/java/org/apache/cxf/databinding/AbstractDataBinding.java
@@ -95,8 +95,8 @@ public abstract class AbstractDataBinding implements DataBinding {
                                        String systemId) {
         return addSchemaDocument(serviceInfo, col, d, systemId, null);
     }
-    public XmlSchema addSchemaDocument(ServiceInfo serviceInfo, 
-                                       SchemaCollection col, 
+    public XmlSchema addSchemaDocument(ServiceInfo serviceInfo,
+                                       SchemaCollection col,
                                        Document d,
                                        String systemId,
                                        Collection<String> ids) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/AbstractInterceptorProvidingDataBinding.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/AbstractInterceptorProvidingDataBinding.java b/core/src/main/java/org/apache/cxf/databinding/AbstractInterceptorProvidingDataBinding.java
index 8af4df2..5d38e2d 100644
--- a/core/src/main/java/org/apache/cxf/databinding/AbstractInterceptorProvidingDataBinding.java
+++ b/core/src/main/java/org/apache/cxf/databinding/AbstractInterceptorProvidingDataBinding.java
@@ -27,11 +27,11 @@ import org.apache.cxf.interceptor.InterceptorProvider;
 import org.apache.cxf.message.Message;
 
 /**
- * 
+ *
  */
-public abstract class AbstractInterceptorProvidingDataBinding 
+public abstract class AbstractInterceptorProvidingDataBinding
     extends AbstractDataBinding implements InterceptorProvider {
-    
+
     protected ModCountCopyOnWriteArrayList<Interceptor<? extends Message>> inInterceptors
         = new ModCountCopyOnWriteArrayList<Interceptor<? extends Message>>();
     protected ModCountCopyOnWriteArrayList<Interceptor<? extends Message>> outInterceptors

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/AbstractWrapperHelper.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/AbstractWrapperHelper.java b/core/src/main/java/org/apache/cxf/databinding/AbstractWrapperHelper.java
index 30dcd7d..566f20a 100644
--- a/core/src/main/java/org/apache/cxf/databinding/AbstractWrapperHelper.java
+++ b/core/src/main/java/org/apache/cxf/databinding/AbstractWrapperHelper.java
@@ -31,31 +31,31 @@ import org.apache.cxf.interceptor.Fault;
  *  This wrapper helper will use reflection to handle the wrapped message
  */
 public abstract class AbstractWrapperHelper implements WrapperHelper {
-    
+
     public static final Class<?> NO_CLASSES[] = new Class[0];
     public static final Object NO_PARAMS[] = new Object[0];
-        
+
     protected final Class<?> wrapperType;
     protected final Method setMethods[];
-    protected final Method getMethods[];    
-    protected final Field fields[];   
+    protected final Method getMethods[];
+    protected final Field fields[];
     protected boolean validate;
-    
-                 
+
+
     protected AbstractWrapperHelper(Class<?> wt,
                   Method sets[],
-                  Method gets[],                  
+                  Method gets[],
                   Field f[]) {
         setMethods = sets;
         getMethods = gets;
-        fields = f;        
-        wrapperType = wt;        
+        fields = f;
+        wrapperType = wt;
     }
-    
+
     /**
      * WrapperClassOutInterceptor may call this if the wrapper class needs to be validated.
      * Implementations may choose to ignore this as the SchemaValidation that occurs later
-     * may catch the errors, but this allows quicker failures if the databinding 
+     * may catch the errors, but this allows quicker failures if the databinding
      * can support it.
      */
     public void setValidate(boolean v) {
@@ -64,39 +64,39 @@ public abstract class AbstractWrapperHelper implements WrapperHelper {
     public boolean getValidate() {
         return validate;
     }
-    
+
     public String getSignature() {
         return "" + System.identityHashCode(this);
     }
-    
+
     protected abstract Object createWrapperObject(Class<?> typeClass) throws Exception;
-    
+
     protected abstract Object getWrapperObject(Object object) throws Exception;
-    
+
     protected Object getPartObject(int index, Object object) throws Exception {
         return object;
     }
-    
+
     protected Object getValue(Method method, Object in) throws IllegalAccessException,
-        InvocationTargetException {        
-        return method.invoke(in);    
+        InvocationTargetException {
+        return method.invoke(in);
     }
-    
-    public Object createWrapperObject(List<?> lst) 
+
+    public Object createWrapperObject(List<?> lst)
         throws Fault {
         try {
             Object wrapperObject = createWrapperObject(wrapperType);
-            
+
             for (int x = 0; x < setMethods.length; x++) {
                 if (getMethods[x] == null
-                    && setMethods[x] == null 
+                    && setMethods[x] == null
                     && fields[x] == null) {
                     //this part is a header or something
                     //that is not part of the wrapper.
                     continue;
                 }
                 Object o = lst.get(x);
-                o = getPartObject(x, o);                
+                o = getPartObject(x, o);
                 if (o instanceof List && getMethods[x] != null) {
                     List<Object> col = CastUtils.cast((List<?>)getMethods[x].invoke(wrapperObject));
                     if (col == null) {
@@ -110,7 +110,7 @@ public abstract class AbstractWrapperHelper implements WrapperHelper {
                         List<Object> olst = CastUtils.cast((List<?>)o);
                         col.addAll(olst);
                     }
-                } else if (setMethods[x] != null) {                        
+                } else if (setMethods[x] != null) {
                     setMethods[x].invoke(wrapperObject, o);
                 } else if (fields[x] != null) {
                     fields[x].set(wrapperObject, lst.get(x));
@@ -122,14 +122,14 @@ public abstract class AbstractWrapperHelper implements WrapperHelper {
             throw new Fault(ex.getCause());
         }
     }
-    
+
     public List<Object> getWrapperParts(Object o) throws Fault {
         try {
-            Object wrapperObject = getWrapperObject(o);                          
+            Object wrapperObject = getWrapperObject(o);
             List<Object> ret = new ArrayList<>(getMethods.length);
             for (int x = 0; x < getMethods.length; x++) {
                 if (getMethods[x] != null) {
-                    ret.add(getValue(getMethods[x], wrapperObject));                        
+                    ret.add(getValue(getMethods[x], wrapperObject));
                 } else if (fields[x] != null) {
                     ret.add(fields[x].get(wrapperObject));
                 } else {
@@ -137,7 +137,7 @@ public abstract class AbstractWrapperHelper implements WrapperHelper {
                     ret.add(null);
                 }
             }
-            
+
             return ret;
         } catch (Exception ex) {
             if (ex.getCause() == null) {
@@ -146,8 +146,8 @@ public abstract class AbstractWrapperHelper implements WrapperHelper {
             throw new Fault(ex.getCause());
         }
     }
-    
-   
+
+
 }
 
 

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/DataReader.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/DataReader.java b/core/src/main/java/org/apache/cxf/databinding/DataReader.java
index 6865a1d..37a1acd 100644
--- a/core/src/main/java/org/apache/cxf/databinding/DataReader.java
+++ b/core/src/main/java/org/apache/cxf/databinding/DataReader.java
@@ -28,12 +28,12 @@ import org.apache.cxf.message.Attachment;
 import org.apache.cxf.service.model.MessagePartInfo;
 
 /**
- * The 'read' side of the data binding abstraction of CXF. A DataReader&lt;T&gt; reads objects 
+ * The 'read' side of the data binding abstraction of CXF. A DataReader&lt;T&gt; reads objects
  * from a source of type T.
  * @param <T> The type of the source. Each data binding defines the set of source types that it supports.
  */
 public interface DataReader<T> {
-    
+
     String FAULT = DataReader.class.getName() + "Fault";
     String ENDPOINT = DataReader.class.getName() + "Endpoint";
     /**
@@ -43,14 +43,14 @@ public interface DataReader<T> {
      * @param s
      */
     void setSchema(Schema s);
-    
+
     /**
      * Attach a collection of attachments to a binding. This permits a binding to process the contents
      * of one or more attachments as part of reading from this reader.
      * @param attachments attachments.
-     */    
+     */
     void setAttachments(Collection<Attachment> attachments);
-    
+
     /**
      * Set an arbitrary property on the reader.
      * {@link #FAULT} and {@link #ENDPOINT} specify two common properties: the Fault object being read
@@ -58,8 +58,8 @@ public interface DataReader<T> {
      * @param prop Name of the property.
      * @param value Value of the property.
      */
-    void setProperty(String prop, Object value);    
-    
+    void setProperty(String prop, Object value);
+
     /**
      * Read an object from the input.
      * @param input input source object.
@@ -80,7 +80,7 @@ public interface DataReader<T> {
      * this API, and those that do ignore the element QName parameter.
      * @param elementQName expected element. Generally ignored.
      * @param input input source object.
-     * @param type the type of object required/requested. This is generally used 
+     * @param type the type of object required/requested. This is generally used
      * when the caller wants to receive a raw source object and avoid any binding processing.
      * For example, passing javax.xml.transform.Source. The bindings do not necessarily throw
      * if they cannot provide an object of the requested type, and will apply their normal

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/DataWriter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/DataWriter.java b/core/src/main/java/org/apache/cxf/databinding/DataWriter.java
index 3f57705..8cec948 100644
--- a/core/src/main/java/org/apache/cxf/databinding/DataWriter.java
+++ b/core/src/main/java/org/apache/cxf/databinding/DataWriter.java
@@ -33,10 +33,10 @@ import org.apache.cxf.service.model.MessagePartInfo;
  */
 public interface DataWriter<T> {
     String ENDPOINT = DataWriter.class.getName() + "Endpoint";
-    
+
     /**
      * Attach a schema to the writer. If the binding supports validation, it will
-     * validate the XML that it produces (assuming that it produces XML). 
+     * validate the XML that it produces (assuming that it produces XML).
      * @param s the schema.
      */
     void setSchema(Schema s);
@@ -47,11 +47,11 @@ public interface DataWriter<T> {
     void setAttachments(Collection<Attachment> attachments);
     /**
      * Set a property for the writer.
-     * @param key property key 
+     * @param key property key
      * @param value property value.
      */
     void setProperty(String key, Object value);
-    
+
     /**
      * Write an object to an output sink.
      * @param obj the object to write.
@@ -59,10 +59,10 @@ public interface DataWriter<T> {
      */
     void write(Object obj, T output);
     /**
-     * Write an object to an output sink, including extra processing based on the WSDL 
+     * Write an object to an output sink, including extra processing based on the WSDL
      * service model for a particular message part.
      * @param obj The object to write.
-     * @param part the message part. 
+     * @param part the message part.
      * @param output the output sink.
      */
     void write(Object obj, MessagePartInfo part, T output);

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/WrapperCapableDatabinding.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/WrapperCapableDatabinding.java b/core/src/main/java/org/apache/cxf/databinding/WrapperCapableDatabinding.java
index 0696d0d..cc01147 100644
--- a/core/src/main/java/org/apache/cxf/databinding/WrapperCapableDatabinding.java
+++ b/core/src/main/java/org/apache/cxf/databinding/WrapperCapableDatabinding.java
@@ -26,7 +26,7 @@ import javax.xml.namespace.QName;
  *  To create the WrapperHelper instance for the wrapper capable data binding
  */
 public interface WrapperCapableDatabinding {
-        
+
     WrapperHelper createWrapperHelper(Class<?> wrapperType,
                                       QName typeName,
                                       List<String> partNames,

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/WrapperHelper.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/WrapperHelper.java b/core/src/main/java/org/apache/cxf/databinding/WrapperHelper.java
index 7321ff0..01c87e3 100644
--- a/core/src/main/java/org/apache/cxf/databinding/WrapperHelper.java
+++ b/core/src/main/java/org/apache/cxf/databinding/WrapperHelper.java
@@ -24,16 +24,16 @@ import java.util.List;
 import org.apache.cxf.interceptor.Fault;
 
 /**
- *  This wrapper helper will help to create a wrapper object with part elements or 
+ *  This wrapper helper will help to create a wrapper object with part elements or
  *  get a list of part elements from a wrapper object.
  */
-public interface WrapperHelper {    
-    
+public interface WrapperHelper {
+
     Object createWrapperObject(List<?> lst) throws Fault;
-    
+
     List<Object> getWrapperParts(Object o) throws Fault;
 
     String getSignature();
-    
+
 
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/source/NodeDataReader.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/source/NodeDataReader.java b/core/src/main/java/org/apache/cxf/databinding/source/NodeDataReader.java
index bd5969d..04a3acc 100644
--- a/core/src/main/java/org/apache/cxf/databinding/source/NodeDataReader.java
+++ b/core/src/main/java/org/apache/cxf/databinding/source/NodeDataReader.java
@@ -66,15 +66,15 @@ public class NodeDataReader implements DataReader<Node> {
             } catch (XMLStreamException e) {
                 throw new Fault("COULD_NOT_READ_XML_STREAM_CAUSED_BY", LOG, e,
                                 e.getClass().getCanonicalName(), e.getMessage());
-            } 
-        }  
+            }
+        }
         return read(input);
     }
 
     public Object read(Node n) {
         return new DOMSource(n);
     }
-    
+
     public void setSchema(Schema s) {
         // TODO Auto-generated method stub
 
@@ -82,12 +82,12 @@ public class NodeDataReader implements DataReader<Node> {
 
     public void setAttachments(Collection<Attachment> attachments) {
         // TODO Auto-generated method stub
-        
+
     }
 
     public void setProperty(String prop, Object value) {
         // TODO Auto-generated method stub
-        
+
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/source/NodeDataWriter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/source/NodeDataWriter.java b/core/src/main/java/org/apache/cxf/databinding/source/NodeDataWriter.java
index 662aa68..f999311 100644
--- a/core/src/main/java/org/apache/cxf/databinding/source/NodeDataWriter.java
+++ b/core/src/main/java/org/apache/cxf/databinding/source/NodeDataWriter.java
@@ -52,7 +52,7 @@ public class NodeDataWriter implements DataWriter<Node> {
                     && ((DOMSource) s).getNode() == null) {
                 return;
             }
-            
+
             XMLStreamWriter writer = new W3CDOMStreamWriter((Element)n);
             StaxUtils.copy(s, writer);
         } catch (XMLStreamException e) {
@@ -65,10 +65,10 @@ public class NodeDataWriter implements DataWriter<Node> {
     }
 
     public void setAttachments(Collection<Attachment> attachments) {
- 
+
     }
 
     public void setProperty(String key, Object value) {
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/source/SourceDataBinding.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/source/SourceDataBinding.java b/core/src/main/java/org/apache/cxf/databinding/source/SourceDataBinding.java
index 4d83e38..4e71968 100644
--- a/core/src/main/java/org/apache/cxf/databinding/source/SourceDataBinding.java
+++ b/core/src/main/java/org/apache/cxf/databinding/source/SourceDataBinding.java
@@ -38,11 +38,11 @@ import org.apache.ws.commons.schema.constants.Constants;
  * A simple databinding implementation which reads and writes Source objects.
  */
 public class SourceDataBinding extends org.apache.cxf.databinding.AbstractDataBinding {
-    
+
     public static final String PREFERRED_FORMAT = "source-preferred-format";
 
     final Class<?> preferred;
-    
+
     public SourceDataBinding() {
         super();
         preferred = null;
@@ -69,7 +69,7 @@ public class SourceDataBinding extends org.apache.cxf.databinding.AbstractDataBi
             } .walk();
         }
     }
-    
+
 
     @SuppressWarnings("unchecked")
     public <T> DataReader<T> createReader(Class<T> cls) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/source/XMLStreamDataReader.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/source/XMLStreamDataReader.java b/core/src/main/java/org/apache/cxf/databinding/source/XMLStreamDataReader.java
index 5e1a056..7d7248b 100644
--- a/core/src/main/java/org/apache/cxf/databinding/source/XMLStreamDataReader.java
+++ b/core/src/main/java/org/apache/cxf/databinding/source/XMLStreamDataReader.java
@@ -71,14 +71,14 @@ public class XMLStreamDataReader implements DataReader<XMLStreamReader> {
     private final Class<?> preferred;
     private Schema schema;
     private Message message;
-    
+
     public XMLStreamDataReader() {
         preferred = null;
     }
     public XMLStreamDataReader(Class<?> cls) {
         preferred = cls;
     }
-    
+
     public Object read(MessagePartInfo part, XMLStreamReader input) {
         return read(null, input, part.getTypeClass());
     }
@@ -161,9 +161,9 @@ public class XMLStreamDataReader implements DataReader<XMLStreamReader> {
         } catch (XMLStreamException e) {
             throw new Fault("COULD_NOT_READ_XML_STREAM_CAUSED_BY", LOG, e,
                             e.getClass().getCanonicalName(), e.getMessage());
-        } 
+        }
     }
-    
+
     private Object createStaxSource(XMLStreamReader input, Class<?> type) {
         try {
             return type.getConstructor(XMLStreamReader.class).newInstance(input);
@@ -180,11 +180,11 @@ public class XMLStreamDataReader implements DataReader<XMLStreamReader> {
                 message.getInterceptorChain().remove(StaxInEndingInterceptor.INSTANCE);
                 message.getInterceptorChain().add(new StaxInEndingInterceptor(Phase.POST_INVOKE));
             }
-            
+
             message.removeContent(XMLStreamReader.class);
             final InputStream ins = message.getContent(InputStream.class);
             message.removeContent(InputStream.class);
-            
+
             input = new FragmentStreamReader(input, true) {
                 boolean closed;
                 public boolean hasNext() throws XMLStreamException {
@@ -233,14 +233,14 @@ public class XMLStreamDataReader implements DataReader<XMLStreamReader> {
         }
         //check if the impl can still validate after the setup, possible issue loading schemas or similar
         if (impl.canValidate()) {
-            //Can use the MSV libs and woodstox to handle the schema validation during 
+            //Can use the MSV libs and woodstox to handle the schema validation during
             //parsing and processing.   Much faster and single traversal
             //filter xop node
             XMLStreamReader reader = StaxUtils.createXMLStreamReader(ds);
-            XMLStreamReader filteredReader = 
-                StaxUtils.createFilteredReader(reader, 
+            XMLStreamReader filteredReader =
+                StaxUtils.createFilteredReader(reader,
                                                new StaxStreamFilter(new QName[] {XOP}));
-            
+
             StaxUtils.copy(filteredReader, nullWriter);
         } else {
             //MSV not available, use a slower method of cloning the data, replace the xop's, validate
@@ -248,7 +248,7 @@ public class XMLStreamDataReader implements DataReader<XMLStreamReader> {
             Element newElement = rootElement;
             if (DOMUtils.hasElementWithName(rootElement, "http://www.w3.org/2004/08/xop/include", "Include")) {
                 newElement = (Element)rootElement.cloneNode(true);
-                List<Element> elems = DOMUtils.findAllElementsByTagNameNS(newElement, 
+                List<Element> elems = DOMUtils.findAllElementsByTagNameNS(newElement,
                                                                           "http://www.w3.org/2004/08/xop/include",
                                                                           "Include");
                 for (Element include : elems) {
@@ -265,19 +265,19 @@ public class XMLStreamDataReader implements DataReader<XMLStreamReader> {
                 throw new XMLStreamException(e.getMessage(), e);
             }
         }
-        return rootElement;        
+        return rootElement;
     }
 
-    private InputStream getInputStream(XMLStreamReader input) 
+    private InputStream getInputStream(XMLStreamReader input)
         throws XMLStreamException, IOException {
-        
+
         try (CachedOutputStream out = new CachedOutputStream()) {
             StaxUtils.copy(input, out);
             return out.getInputStream();
         }
     }
     public DOMSource read(XMLStreamReader reader) {
-        // Use a DOMSource for now, we should really use a StaxSource/SAXSource though for 
+        // Use a DOMSource for now, we should really use a StaxSource/SAXSource though for
         // performance reasons
         try {
             XMLStreamReader reader2 = reader;
@@ -302,7 +302,7 @@ public class XMLStreamDataReader implements DataReader<XMLStreamReader> {
                             e.getClass().getCanonicalName(), e.getMessage());
         }
     }
-    
+
     public void setSchema(Schema s) {
         schema = s;
     }
@@ -315,7 +315,7 @@ public class XMLStreamDataReader implements DataReader<XMLStreamReader> {
             message = (Message)value;
         }
     }
-    
+
     static class NUllOutputStream extends OutputStream {
         public void write(byte[] b, int off, int len) {
         }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/source/XMLStreamDataWriter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/source/XMLStreamDataWriter.java b/core/src/main/java/org/apache/cxf/databinding/source/XMLStreamDataWriter.java
index c0938d5..8bd9b71 100644
--- a/core/src/main/java/org/apache/cxf/databinding/source/XMLStreamDataWriter.java
+++ b/core/src/main/java/org/apache/cxf/databinding/source/XMLStreamDataWriter.java
@@ -49,7 +49,7 @@ public class XMLStreamDataWriter implements DataWriter<XMLStreamWriter> {
     private static final Logger LOG = LogUtils.getL7dLogger(XMLStreamDataWriter.class);
 
     private Schema schema;
-    
+
     public void write(Object obj, MessagePartInfo part, XMLStreamWriter output) {
         write(obj, output);
     }
@@ -68,7 +68,7 @@ public class XMLStreamDataWriter implements DataWriter<XMLStreamWriter> {
                     StaxUtils.copy(reader, writer);
                     reader.close();
                 }
-                
+
             } else if (obj instanceof Node) {
                 if (schema != null) {
                     schema.newValidator().validate(new DOMSource((Node)obj));
@@ -104,7 +104,7 @@ public class XMLStreamDataWriter implements DataWriter<XMLStreamWriter> {
     private void writeNode(Node nd, XMLStreamWriter writer) throws XMLStreamException {
         if (writer instanceof W3CDOMStreamWriter) {
             W3CDOMStreamWriter dw = (W3CDOMStreamWriter)writer;
-            
+
             if (dw.getCurrentNode() != null) {
                 if (nd instanceof DocumentFragment
                     && nd.getOwnerDocument() == dw.getCurrentNode().getOwnerDocument()) {
@@ -137,7 +137,7 @@ public class XMLStreamDataWriter implements DataWriter<XMLStreamWriter> {
             StaxUtils.writeDocument((Document)nd,
                                     writer, false, true);
         } else {
-            StaxUtils.writeNode(nd, writer, true);                    
+            StaxUtils.writeNode(nd, writer, true);
         }
 
     }
@@ -148,9 +148,9 @@ public class XMLStreamDataWriter implements DataWriter<XMLStreamWriter> {
 
     public void setAttachments(Collection<Attachment> attachments) {
 
-    }   
+    }
 
     public void setProperty(String key, Object value) {
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/source/mime/MimeAttribute.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/source/mime/MimeAttribute.java b/core/src/main/java/org/apache/cxf/databinding/source/mime/MimeAttribute.java
index a824a0d..822f6cc 100644
--- a/core/src/main/java/org/apache/cxf/databinding/source/mime/MimeAttribute.java
+++ b/core/src/main/java/org/apache/cxf/databinding/source/mime/MimeAttribute.java
@@ -21,15 +21,15 @@ package org.apache.cxf.databinding.source.mime;
 import javax.xml.namespace.QName;
 
 public final class MimeAttribute {
-    public static final QName MIME_QNAME = new QName("http://www.w3.org/2005/05/xmlmime", 
+    public static final QName MIME_QNAME = new QName("http://www.w3.org/2005/05/xmlmime",
                                                      "expectedContentTypes");
 
     private String value;
-    
+
     public void setValue(String v) {
         this.value = v;
     }
-    
+
     public String getValue() {
         return this.value;
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/source/mime/MimeSerializer.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/source/mime/MimeSerializer.java b/core/src/main/java/org/apache/cxf/databinding/source/mime/MimeSerializer.java
index 719680e..7356fe9 100644
--- a/core/src/main/java/org/apache/cxf/databinding/source/mime/MimeSerializer.java
+++ b/core/src/main/java/org/apache/cxf/databinding/source/mime/MimeSerializer.java
@@ -29,8 +29,8 @@ import org.apache.ws.commons.schema.XmlSchemaObject;
 import org.apache.ws.commons.schema.extensions.ExtensionSerializer;
 
 public class MimeSerializer implements ExtensionSerializer {
-    
-    public void serialize(XmlSchemaObject schemaObject, 
+
+    public void serialize(XmlSchemaObject schemaObject,
                           @SuppressWarnings("rawtypes") Class classOfType, Node domNode) {
         Map<Object, Object> metaInfoMap = schemaObject.getMetaInfoMap();
         MimeAttribute mimeType = (MimeAttribute)metaInfoMap.get(MimeAttribute.MIME_QNAME);

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/stax/StaxDataBinding.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/stax/StaxDataBinding.java b/core/src/main/java/org/apache/cxf/databinding/stax/StaxDataBinding.java
index a6f0c3a..f2a65a8 100644
--- a/core/src/main/java/org/apache/cxf/databinding/stax/StaxDataBinding.java
+++ b/core/src/main/java/org/apache/cxf/databinding/stax/StaxDataBinding.java
@@ -67,10 +67,10 @@ public class StaxDataBinding extends AbstractInterceptorProvidingDataBinding {
         inInterceptors.add(RemoveStaxInEndingInterceptor.INSTANCE);
         inFaultInterceptors.add(RemoveStaxInEndingInterceptor.INSTANCE);
     }
-    
+
     static class RemoveStaxInEndingInterceptor extends AbstractPhaseInterceptor<Message> {
         static final RemoveStaxInEndingInterceptor INSTANCE = new RemoveStaxInEndingInterceptor();
-        
+
         RemoveStaxInEndingInterceptor() {
             super(Phase.PRE_INVOKE);
             addBefore(StaxInEndingInterceptor.class.getName());
@@ -80,7 +80,7 @@ public class StaxDataBinding extends AbstractInterceptorProvidingDataBinding {
             message.getInterceptorChain().remove(StaxInEndingInterceptor.INSTANCE);
         }
     }
-    
+
 
     public void initialize(Service service) {
         for (ServiceInfo serviceInfo : service.getServiceInfos()) {
@@ -139,14 +139,14 @@ public class StaxDataBinding extends AbstractInterceptorProvidingDataBinding {
         public Object read(XMLStreamReader reader) {
             return reader;
         }
-        
+
         public void setSchema(Schema s) {
         }
 
         public void setAttachments(Collection<Attachment> attachments) {
         }
 
-        public void setProperty(String prop, Object value) {   
+        public void setProperty(String prop, Object value) {
         }
     }
 
@@ -166,7 +166,7 @@ public class StaxDataBinding extends AbstractInterceptorProvidingDataBinding {
                 } else if (obj instanceof XMLStreamWriterCallback) {
                     ((XMLStreamWriterCallback) obj).write(writer);
                 } else {
-                    throw new UnsupportedOperationException("Data types of " 
+                    throw new UnsupportedOperationException("Data types of "
                                                             + obj.getClass() + " are not supported.");
                 }
             } catch (XMLStreamException e) {
@@ -182,6 +182,6 @@ public class StaxDataBinding extends AbstractInterceptorProvidingDataBinding {
 
         public void setProperty(String key, Object value) {
         }
-        
+
     }
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/stax/StaxDataBindingFeature.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/stax/StaxDataBindingFeature.java b/core/src/main/java/org/apache/cxf/databinding/stax/StaxDataBindingFeature.java
index d70e2ea..aef966f 100644
--- a/core/src/main/java/org/apache/cxf/databinding/stax/StaxDataBindingFeature.java
+++ b/core/src/main/java/org/apache/cxf/databinding/stax/StaxDataBindingFeature.java
@@ -31,7 +31,7 @@ import org.apache.cxf.message.Message;
 
 public class StaxDataBindingFeature extends AbstractFeature {
 
-    
+
     @Override
     public void initialize(Client client, Bus bus) {
         removeDatabindingInterceptor(client.getEndpoint().getBinding().getInInterceptors());

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/databinding/stax/StaxDataBindingInterceptor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/databinding/stax/StaxDataBindingInterceptor.java b/core/src/main/java/org/apache/cxf/databinding/stax/StaxDataBindingInterceptor.java
index 2f36557..580afac 100644
--- a/core/src/main/java/org/apache/cxf/databinding/stax/StaxDataBindingInterceptor.java
+++ b/core/src/main/java/org/apache/cxf/databinding/stax/StaxDataBindingInterceptor.java
@@ -48,7 +48,7 @@ public class StaxDataBindingInterceptor extends AbstractInDatabindingInterceptor
             LOG.fine("StaxDataBindingInterceptor skipped in HTTP GET method");
             return;
         }
-        
+
         DepthXMLStreamReader xmlReader = getXMLStreamReader(message);
         DataReader<XMLStreamReader> dr = getDataReader(message);
         MessageContentsList parameters = new MessageContentsList();
@@ -56,27 +56,27 @@ public class StaxDataBindingInterceptor extends AbstractInDatabindingInterceptor
         Exchange exchange = message.getExchange();
         BindingOperationInfo bop = exchange.getBindingOperationInfo();
 
-        //if body is empty and we have BindingOperationInfo, we do not need to match 
+        //if body is empty and we have BindingOperationInfo, we do not need to match
         //operation anymore, just return
         if (!StaxUtils.toNextElement(xmlReader) && bop != null) {
             // body may be empty for partial response to decoupled request
             return;
         }
-        
+
         if (bop == null) {
             Endpoint ep = exchange.getEndpoint();
             bop = ep.getBinding().getBindingInfo().getOperations().iterator().next();
         }
-        
+
         message.getExchange().put(BindingOperationInfo.class, bop);
-        
+
         if (isRequestor(message)) {
-            parameters.put(bop.getOutput().getMessageParts().get(0), dr.read(xmlReader));            
+            parameters.put(bop.getOutput().getMessageParts().get(0), dr.read(xmlReader));
         } else {
-            parameters.put(bop.getInput().getMessageParts().get(0), dr.read(xmlReader));            
+            parameters.put(bop.getInput().getMessageParts().get(0), dr.read(xmlReader));
         }
 
-        
+
         if (parameters.size() > 0) {
             message.setContent(List.class, parameters);
         }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/endpoint/AbstractConduitSelector.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/endpoint/AbstractConduitSelector.java b/core/src/main/java/org/apache/cxf/endpoint/AbstractConduitSelector.java
index 1a9ed0f..47c6687 100644
--- a/core/src/main/java/org/apache/cxf/endpoint/AbstractConduitSelector.java
+++ b/core/src/main/java/org/apache/cxf/endpoint/AbstractConduitSelector.java
@@ -45,24 +45,24 @@ import org.apache.cxf.ws.addressing.EndpointReferenceType;
  * that retrieves a Conduit from the ConduitInitiator.
  */
 public abstract class AbstractConduitSelector implements ConduitSelector, Closeable {
-    public static final String CONDUIT_COMPARE_FULL_URL 
+    public static final String CONDUIT_COMPARE_FULL_URL
         = "org.apache.cxf.ConduitSelector.compareFullUrl";
     protected static final String KEEP_CONDUIT_ALIVE = "KeepConduitAlive";
-    
-    
+
+
     //collection of conduits that were created so we can close them all at the end
     protected List<Conduit> conduits = new CopyOnWriteArrayList<Conduit>();
-    
+
     //protected Conduit selectedConduit;
     protected Endpoint endpoint;
 
-    
+
     public AbstractConduitSelector() {
     }
-    
+
     /**
      * Constructor, allowing a specific conduit to override normal selection.
-     * 
+     *
      * @param c specific conduit
      */
     public AbstractConduitSelector(Conduit c) {
@@ -70,25 +70,25 @@ public abstract class AbstractConduitSelector implements ConduitSelector, Closea
             conduits.add(c);
         }
     }
-        
+
     public void close() {
         for (Conduit c : conduits) {
             c.close();
         }
         conduits.clear();
     }
-    
+
     protected void removeConduit(Conduit conduit) {
         if (conduit != null) {
             conduit.close();
             conduits.remove(conduit);
         }
     }
-    
+
     /**
      * Mechanics to actually get the Conduit from the ConduitInitiator
      * if necessary.
-     * 
+     *
      * @param message the current Message
      */
     protected Conduit getSelectedConduit(Message message) {
@@ -117,17 +117,17 @@ public abstract class AbstractConduitSelector implements ConduitSelector, Closea
             } catch (IOException ex) {
                 throw new Fault(ex);
             }
-        } 
+        }
         if (c != null && c.getTarget() != null && c.getTarget().getAddress() != null) {
             replaceEndpointAddressPropertyIfNeeded(message, c.getTarget().getAddress().getValue(), c);
         }
-        //the search for the conduit could cause extra properties to be reset/loaded. 
+        //the search for the conduit could cause extra properties to be reset/loaded.
         message.resetContextCache();
         message.put(Conduit.class, c);
         return c;
     }
-    
-    protected Conduit createConduit(Message message, Exchange exchange, ConduitInitiator conduitInitiator) 
+
+    protected Conduit createConduit(Message message, Exchange exchange, ConduitInitiator conduitInitiator)
         throws IOException {
         Conduit c = null;
         synchronized (endpoint) {
@@ -151,7 +151,7 @@ public abstract class AbstractConduitSelector implements ConduitSelector, Closea
                 epr.setAddress(ad);
                 c = conduitInitiator.getConduit(ei, epr, exchange.getBus());
             }
-            MessageObserver observer = 
+            MessageObserver observer =
                 exchange.get(MessageObserver.class);
             if (observer != null) {
                 c.setMessageObserver(observer);
@@ -165,14 +165,14 @@ public abstract class AbstractConduitSelector implements ConduitSelector, Closea
 
     // Some conduits may replace the endpoint address after it has already been prepared
     // but before the invocation has been done (ex, org.apache.cxf.clustering.LoadDistributorTargetSelector)
-    // which may affect JAX-RS clients where actual endpoint address property may include additional path 
-    // segments.  
-    protected boolean replaceEndpointAddressPropertyIfNeeded(Message message, 
+    // which may affect JAX-RS clients where actual endpoint address property may include additional path
+    // segments.
+    protected boolean replaceEndpointAddressPropertyIfNeeded(Message message,
                                                              String endpointAddress,
                                                              Conduit cond) {
         return false;
     }
-    
+
     /**
      * @return the encapsulated Endpoint
      */
@@ -186,17 +186,17 @@ public abstract class AbstractConduitSelector implements ConduitSelector, Closea
     public void setEndpoint(Endpoint ep) {
         endpoint = ep;
     }
-    
+
     /**
      * Called on completion of the MEP for which the Conduit was required.
-     * 
+     *
      * @param exchange represents the completed MEP
      */
     public void complete(Exchange exchange) {
         // Clients expecting explicit InputStream responses
         // will need to keep low level conduits operating on InputStreams open
         // and will be responsible for closing the streams
-        
+
         if (MessageUtils.isTrue(exchange.get(KEEP_CONDUIT_ALIVE))) {
             return;
         }
@@ -212,7 +212,7 @@ public abstract class AbstractConduitSelector implements ConduitSelector, Closea
         } catch (IOException e) {
             //IGNORE
         }
-    }    
+    }
     /**
      * @return the logger to use
      */
@@ -220,12 +220,12 @@ public abstract class AbstractConduitSelector implements ConduitSelector, Closea
 
     /**
      * If address protocol was changed, conduit should be re-initialised
-     * 
+     *
      * @param message the current Message
      */
     protected Conduit findCompatibleConduit(Message message) {
         Conduit c = message.get(Conduit.class);
-        if (c == null 
+        if (c == null
             && message.getExchange() != null
             && message.getExchange().getOutMessage() != null
             && message.getExchange().getOutMessage() != message) {
@@ -236,7 +236,7 @@ public abstract class AbstractConduitSelector implements ConduitSelector, Closea
         }
         ContextualBooleanGetter cbg = new ContextualBooleanGetter(message);
         for (Conduit c2 : conduits) {
-            if (c2.getTarget() == null 
+            if (c2.getTarget() == null
                 || c2.getTarget().getAddress() == null
                 || c2.getTarget().getAddress().getValue() == null) {
                 continue;
@@ -256,7 +256,7 @@ public abstract class AbstractConduitSelector implements ConduitSelector, Closea
             }
         }
         for (Conduit c2 : conduits) {
-            if (c2.getTarget() == null 
+            if (c2.getTarget() == null
                 || c2.getTarget().getAddress() == null
                 || c2.getTarget().getAddress().getValue() == null) {
                 return c2;
@@ -264,7 +264,7 @@ public abstract class AbstractConduitSelector implements ConduitSelector, Closea
         }
         return null;
     }
-    
+
     private boolean matchAddresses(String conduitAddress, String actualAddress, ContextualBooleanGetter cbg) {
         if (conduitAddress.length() == actualAddress.length()) {
             //let's be optimistic and try full comparison first, regardless of CONDUIT_COMPARE_FULL_URL value,
@@ -280,7 +280,7 @@ public abstract class AbstractConduitSelector implements ConduitSelector, Closea
         }
     }
 
-    //smart address substring comparison that tries to avoid building and comparing substrings unless strictly required 
+    //smart address substring comparison that tries to avoid building and comparing substrings unless strictly required
     private boolean matchAddressSubstrings(String conduitAddress, String actualAddress) {
         int idx = conduitAddress.indexOf(':');
         if (idx == actualAddress.indexOf(':')) {
@@ -291,19 +291,19 @@ public abstract class AbstractConduitSelector implements ConduitSelector, Closea
             actualAddress = actualAddress.substring(0, idx);
             return conduitAddress.equalsIgnoreCase(actualAddress);
         } else {
-            //no possible match as for sure the substrings before idx will be different 
+            //no possible match as for sure the substrings before idx will be different
             return false;
         }
     }
-    
+
     private static final class ContextualBooleanGetter {
         private Boolean value;
         private final Message message;
-        
+
         ContextualBooleanGetter(Message message) {
             this.message = message;
         }
-        
+
         public boolean isFullComparison() {
             if (value == null) {
                 value = MessageUtils.getContextualBoolean(message, CONDUIT_COMPARE_FULL_URL, false);

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/endpoint/AbstractEndpointFactory.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/endpoint/AbstractEndpointFactory.java b/core/src/main/java/org/apache/cxf/endpoint/AbstractEndpointFactory.java
index 17745e3..8be3bfa 100644
--- a/core/src/main/java/org/apache/cxf/endpoint/AbstractEndpointFactory.java
+++ b/core/src/main/java/org/apache/cxf/endpoint/AbstractEndpointFactory.java
@@ -48,7 +48,7 @@ public abstract class AbstractEndpointFactory extends AbstractBasicInterceptorPr
     private static final Logger LOG = LogUtils.getL7dLogger(AbstractEndpointFactory.class);
     private static final String PRIVATE_ENDPOINT = "org.apache.cxf.endpoint.private";
     private static final String PRIVATE_ENDPOINTS = "org.apache.cxf.private.endpoints";
-    
+
     protected Bus bus;
     protected String address;
     protected String transportId;
@@ -80,14 +80,14 @@ public abstract class AbstractEndpointFactory extends AbstractBasicInterceptorPr
     public Bus getBus() {
         return getBus(true);
     }
-    
+
     public Bus getBus(boolean createIfNeeded) {
         if (bus == null && createIfNeeded) {
             bus = BusFactory.getThreadDefaultBus();
         }
         return bus;
     }
-    
+
     public void setBus(Bus bus) {
         this.bus = bus;
     }
@@ -139,15 +139,15 @@ public abstract class AbstractEndpointFactory extends AbstractBasicInterceptorPr
     public void setEndpointName(QName endpointName) {
         this.endpointName = endpointName;
     }
-    
+
     public void setServiceName(QName name) {
         serviceName = name;
     }
-    
+
     public QName getServiceName() {
         return serviceName;
     }
-    
+
     public void setEndpointReference(EndpointReferenceType epr) {
         endpointReference = epr;
     }
@@ -180,7 +180,7 @@ public abstract class AbstractEndpointFactory extends AbstractBasicInterceptorPr
     public BindingFactory getBindingFactory() {
         return bindingFactory;
     }
-    
+
     public void setBindingFactory(BindingFactory bf) {
         this.bindingFactory  = bf;
     }
@@ -204,7 +204,7 @@ public abstract class AbstractEndpointFactory extends AbstractBasicInterceptorPr
     /**
      * Checks if a given endpoint has been marked as private.
      * If yes then its address will be added to a bus list property
-     * Note that client factories might also check the endpoint, ex, 
+     * Note that client factories might also check the endpoint, ex,
      * if the endpoint if private then it is likely no service contract
      * will be available if requested from the remote address hence it has to
      * be availbale locally or generated from the local source
@@ -213,7 +213,7 @@ public abstract class AbstractEndpointFactory extends AbstractBasicInterceptorPr
     @SuppressWarnings("unchecked")
     protected boolean checkPrivateEndpoint(Endpoint ep) {
         if (MessageUtils.isTrue(ep.get(PRIVATE_ENDPOINT))) {
-            List<String> addresses = 
+            List<String> addresses =
                 (List<String>)getBus().getProperty(PRIVATE_ENDPOINTS);
             if (addresses == null) {
                 addresses = new LinkedList<String>();
@@ -240,8 +240,8 @@ public abstract class AbstractEndpointFactory extends AbstractBasicInterceptorPr
         if (initializeAnnotationInterceptors(provider, ep)) {
             LOG.fine("Added annotation based interceptors and features");
         }
-    }    
-    
+    }
+
     protected static void addToBeans(Collection<Object> beans, Object o) {
         if (o instanceof Collection) {
             for (Object o2: (Collection<?>)o) {
@@ -251,7 +251,7 @@ public abstract class AbstractEndpointFactory extends AbstractBasicInterceptorPr
             beans.add(o);
         }
     }
-    
+
     protected boolean initializeAnnotationInterceptors(AnnotationInterceptors provider, Endpoint ep) {
         boolean hasAnnotation = false;
         if (provider.getInFaultInterceptors() != null) {
@@ -274,7 +274,7 @@ public abstract class AbstractEndpointFactory extends AbstractBasicInterceptorPr
             getFeatures().addAll(provider.getFeatures());
             hasAnnotation = true;
         }
-        
+
         return hasAnnotation;
     }
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/endpoint/Client.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/endpoint/Client.java b/core/src/main/java/org/apache/cxf/endpoint/Client.java
index 8a2a06f..6ff2940 100644
--- a/core/src/main/java/org/apache/cxf/endpoint/Client.java
+++ b/core/src/main/java/org/apache/cxf/endpoint/Client.java
@@ -40,19 +40,19 @@ public interface Client extends InterceptorProvider, MessageObserver, ConduitSel
      * Invokes an operation synchronously
      * @param operationName The name of the operation to be invoked. The service namespace will be used
      * when looking up the BindingOperationInfo.
-     * @param params  The params that matches the parts of the input message of the operation.  If the 
-     * BindingOperationInfo supports unwrapping, it assumes the params are in the "unwrapped" form.  If 
+     * @param params  The params that matches the parts of the input message of the operation.  If the
+     * BindingOperationInfo supports unwrapping, it assumes the params are in the "unwrapped" form.  If
      * params are in the wrapped form, use invokeWrapped
      * @return The return values that matche the parts of the output message of the operation
      */
     Object[] invoke(String operationName,
                     Object... params) throws Exception;
-    
+
     /**
      * Invokes an operation synchronously
      * @param operationName The name of the operation to be invoked
-     * @param params  The params that matches the parts of the input message of the operation.  If the 
-     * BindingOperationInfo supports unwrapping, it assumes the params are in the "unwrapped" form.  If 
+     * @param params  The params that matches the parts of the input message of the operation.  If the
+     * BindingOperationInfo supports unwrapping, it assumes the params are in the "unwrapped" form.  If
      * params are in the wrapped form, use invokeWrapped
      * @return The return values that matche the parts of the output message of the operation
      */
@@ -69,7 +69,7 @@ public interface Client extends InterceptorProvider, MessageObserver, ConduitSel
      */
     Object[] invokeWrapped(String operationName,
                     Object... params) throws Exception;
-    
+
     /**
      * Invokes an operation synchronously
      * @param operationName The name of the operation to be invoked
@@ -78,7 +78,7 @@ public interface Client extends InterceptorProvider, MessageObserver, ConduitSel
      */
     Object[] invokeWrapped(QName operationName,
                     Object... params) throws Exception;
-    
+
     /**
      * Invokes an operation synchronously
      * @param oi  The operation to be invoked
@@ -92,48 +92,48 @@ public interface Client extends InterceptorProvider, MessageObserver, ConduitSel
      * Invokes an operation synchronously
      * @param oi  The operation to be invoked
      * @param params  The params that matches the parts of the input message of the operation
-     * @param context  Optional (can be null) contextual information for the invocation     
+     * @param context  Optional (can be null) contextual information for the invocation
      * @return The return values that matche the parts of the output message of the operation
      */
     Object[] invoke(BindingOperationInfo oi,
                     Object[] params,
                     Map<String, Object> context) throws Exception;
-    
+
     /**
      * Invokes an operation synchronously
      * @param oi  The operation to be invoked
      * @param params  The params that matches the parts of the input message of the operation
      * @param context  Optional (can be null) contextual information for the invocation
-     * @param exchange The Exchange to be used for the invocation     
+     * @param exchange The Exchange to be used for the invocation
      * @return The return values that matche the parts of the output message of the operation
      */
     Object[] invoke(BindingOperationInfo oi,
-            Object[] params, 
+            Object[] params,
             Map<String, Object> context,
             Exchange exchange) throws Exception;
-    
+
     /**
      * Invokes an operation asynchronously
      * @param callback The callback that is called when the response is ready
      * @param operationName The name of the operation to be invoked. The service namespace will be used
      * when looking up the BindingOperationInfo.
-     * @param params  The params that matches the parts of the input message of the operation.  If the 
-     * BindingOperationInfo supports unwrapping, it assumes the params are in the "unwrapped" form.  If 
+     * @param params  The params that matches the parts of the input message of the operation.  If the
+     * BindingOperationInfo supports unwrapping, it assumes the params are in the "unwrapped" form.  If
      * params are in the wrapped form, use invokeWrapped
-     * 
+     *
      */
     void invoke(ClientCallback callback,
                     String operationName,
                     Object... params) throws Exception;
-    
+
     /**
      * Invokes an operation asynchronously
      * @param callback The callback that is called when the response is ready
      * @param operationName The name of the operation to be invoked
-     * @param params  The params that matches the parts of the input message of the operation.  If the 
-     * BindingOperationInfo supports unwrapping, it assumes the params are in the "unwrapped" form.  If 
+     * @param params  The params that matches the parts of the input message of the operation.  If the
+     * BindingOperationInfo supports unwrapping, it assumes the params are in the "unwrapped" form.  If
      * params are in the wrapped form, use invokeWrapped
-     * 
+     *
      */
     void invoke(ClientCallback callback,
                     QName operationName,
@@ -151,18 +151,18 @@ public interface Client extends InterceptorProvider, MessageObserver, ConduitSel
     void invokeWrapped(ClientCallback callback,
                            String operationName,
                     Object... params) throws Exception;
-    
+
     /**
      * Invokes an operation asynchronously
      * @param callback The callback that is called when the response is ready
      * @param operationName The name of the operation to be invoked
      * @param params  The params that matches the parts of the input message of the operation
-     * 
+     *
      */
     void invokeWrapped(ClientCallback callback,
                            QName operationName,
-                    Object... params) throws Exception;    
-    
+                    Object... params) throws Exception;
+
     /**
      * Invokes an operation asynchronously
      * @param callback The callback that is called when the response is ready
@@ -173,7 +173,7 @@ public interface Client extends InterceptorProvider, MessageObserver, ConduitSel
     void invoke(ClientCallback callback,
                 BindingOperationInfo oi,
                 Object... params) throws Exception;
-    
+
     /**
      * Invokes an operation asynchronously
      * @param callback The callback that is called when the response is ready
@@ -184,8 +184,8 @@ public interface Client extends InterceptorProvider, MessageObserver, ConduitSel
     void invoke(ClientCallback callback,
                 BindingOperationInfo oi,
                 Object[] params,
-                Map<String, Object> context) throws Exception;  
-    
+                Map<String, Object> context) throws Exception;
+
     /**
      * Invokes an operation asynchronously
      * @param callback The callback that is called when the response is ready
@@ -197,23 +197,23 @@ public interface Client extends InterceptorProvider, MessageObserver, ConduitSel
     void invoke(ClientCallback callback,
                 BindingOperationInfo oi,
                 Object[] params,
-                Exchange exchange) throws Exception;  
-    
+                Exchange exchange) throws Exception;
+
     /**
      * Invokes an operation asynchronously
      * @param callback The callback that is called when the response is ready
      * @param oi  The operation to be invoked
      * @param params  The params that matches the parts of the input message of the operation
      * @param context  Optional (can be null) contextual information for the invocation
-     * @param exchange Optional (can be null) The Exchange to be used for the invocation  
+     * @param exchange Optional (can be null) The Exchange to be used for the invocation
      */
     void invoke(ClientCallback callback,
                 BindingOperationInfo oi,
                 Object[] params,
                 Map<String, Object> context,
-                Exchange exchange) throws Exception;  
-    
-    
+                Exchange exchange) throws Exception;
+
+
     /**
      * Gets the request context used for future invocations
      * @return context The context
@@ -224,16 +224,16 @@ public interface Client extends InterceptorProvider, MessageObserver, ConduitSel
      * @return context The context
      */
     Map<String, Object> getResponseContext();
-    
+
     /**
-     * Sets whether the request context is thread local or global to this client.  By 
+     * Sets whether the request context is thread local or global to this client.  By
      * default, the request context is "global" in that any values set in the context
-     * are seen by all threads using this client.  If set to true, the context is changed 
+     * are seen by all threads using this client.  If set to true, the context is changed
      * to be a ThreadLocal and values set are not seen by other threads.
      * @param b
      */
     void setThreadLocalRequestContext(boolean b);
-    
+
     /**
      * Checks if the Request context is thread local or global.
      * @return true if the request context is a thread local
@@ -248,36 +248,36 @@ public interface Client extends InterceptorProvider, MessageObserver, ConduitSel
      * @return Conduit
      */
     Conduit getConduit();
-    
+
     /**
      * Get the ConduitSelector responsible for retreiving the Conduit.
-     * 
+     *
      * @return the current ConduitSelector
      */
     ConduitSelector getConduitSelector();
 
     /**
      * Set the ConduitSelector responsible for retreiving the Conduit.
-     * 
+     *
      * @param selector the ConduitSelector to use
      */
     void setConduitSelector(ConduitSelector selector);
-    
+
     /**
      * Indicates that the client is no longer needed and that any resources it holds
      * can now be freed.
      *
      */
     void destroy();
-    
+
     /**
      * Sets the executor which is used to process Asynchronous responses.  The default
-     * is to use the threads provided by the transport.  (example: the JMS listener threads) 
+     * is to use the threads provided by the transport.  (example: the JMS listener threads)
      * @param executor
      */
     void setExecutor(Executor executor);
-    
-    
+
+
     /**
      * Retrieves the Bus that was used to create the Client
      * @return the Bus

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/endpoint/ClientImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/endpoint/ClientImpl.java b/core/src/main/java/org/apache/cxf/endpoint/ClientImpl.java
index 282eeb0..3641d82 100644
--- a/core/src/main/java/org/apache/cxf/endpoint/ClientImpl.java
+++ b/core/src/main/java/org/apache/cxf/endpoint/ClientImpl.java
@@ -78,7 +78,7 @@ public class ClientImpl
     public static final String THREAD_LOCAL_REQUEST_CONTEXT = "thread.local.request.context";
     /**
      * When a synchronous request/response invoke is done using an asynchronous transport mechanism,
-     * this is the timeout used for waiting for the response.  Default is 60 seconds. 
+     * this is the timeout used for waiting for the response.  Default is 60 seconds.
      */
     public static final String SYNC_TIMEOUT = "cxf.synchronous.timeout";
 
@@ -95,10 +95,10 @@ public class ClientImpl
     protected PhaseChainCache inboundChainCache = new PhaseChainCache();
 
     protected Map<String, Object> currentRequestContext = new ConcurrentHashMap<String, Object>(8, 0.75f, 4);
-    protected Map<Thread, EchoContext> requestContext 
+    protected Map<Thread, EchoContext> requestContext
         = Collections.synchronizedMap(new WeakHashMap<Thread, EchoContext>());
 
-    protected Map<Thread, Map<String, Object>> responseContext 
+    protected Map<Thread, Map<String, Object>> responseContext
         = Collections.synchronizedMap(new WeakHashMap<Thread, Map<String, Object>>());
 
     protected Executor executor;
@@ -117,7 +117,7 @@ public class ClientImpl
         getConduitSelector(sc).setEndpoint(e);
         notifyLifecycleManager();
     }
-    
+
     /**
      * Create a Client that uses a specific EndpointImpl.
      * @param bus
@@ -142,7 +142,7 @@ public class ClientImpl
         }
         notifyLifecycleManager();
     }
-    
+
     public Bus getBus() {
         return bus;
     }
@@ -174,7 +174,7 @@ public class ClientImpl
                 getConduit().close();
             }
         }
-        
+
         bus = null;
         conduitSelector = null;
         outFaultObserver = null;
@@ -186,7 +186,7 @@ public class ClientImpl
         requestContext = null;
         responseContext.clear();
         responseContext = null;
-        executor = null;            
+        executor = null;
     }
 
     private void notifyLifecycleManager() {
@@ -393,14 +393,14 @@ public class ClientImpl
                        Object... params) throws Exception {
         invoke(callback, oi, params, null, null);
     }
-    
+
     public void invoke(ClientCallback callback,
                        BindingOperationInfo oi,
                        Object[] params,
                        Map<String, Object> context) throws Exception {
         invoke(callback, oi, params, context, null);
     }
-    
+
     public void invoke(ClientCallback callback,
                        BindingOperationInfo oi,
                        Object[] params,
@@ -444,7 +444,7 @@ public class ClientImpl
                 LOG.fine("Invoke, operation info: " + oi + ", params: " + Arrays.toString(params));
             }
             Message message = endpoint.getBinding().createMessage();
-            
+
             // Make sure INVOCATION CONTEXT, REQUEST_CONTEXT and RESPONSE_CONTEXT are present
             // on message
             Map<String, Object> reqContext = null;
@@ -454,7 +454,7 @@ public class ClientImpl
             }
             reqContext = CastUtils.cast((Map<?, ?>)context.get(REQUEST_CONTEXT));
             resContext = CastUtils.cast((Map<?, ?>)context.get(RESPONSE_CONTEXT));
-            if (reqContext == null) { 
+            if (reqContext == null) {
                 reqContext = new HashMap<String, Object>(getRequestContext());
                 context.put(REQUEST_CONTEXT, reqContext);
             }
@@ -462,11 +462,11 @@ public class ClientImpl
                 resContext = new HashMap<String, Object>();
                 context.put(RESPONSE_CONTEXT, resContext);
             }
-            
+
             message.put(Message.INVOCATION_CONTEXT, context);
             setContext(reqContext, message);
             exchange.putAll(reqContext);
-            
+
             setParameters(params, message);
 
             if (null != oi) {
@@ -475,7 +475,7 @@ public class ClientImpl
 
             exchange.setOutMessage(message);
             exchange.put(ClientCallback.class, callback);
-            
+
             setOutMessageProperties(message, oi);
             setExchangeProperties(exchange, endpoint, oi);
 
@@ -516,7 +516,7 @@ public class ClientImpl
                 enrichFault(fault);
                 throw fault;
             }
-            
+
             if (callback != null) {
                 return null;
             } else {
@@ -536,11 +536,11 @@ public class ClientImpl
         getConduitSelector().complete(exchange);
         Message outMessage = exchange.getOutMessage();
         if (outMessage != null && outMessage.get("transport.retransmit.url") != null) {
-            //FIXME: target address has been updated at the transport level, 
+            //FIXME: target address has been updated at the transport level,
             //       update the the current client accordingly
         }
     }
-    
+
     /**
      * TODO This is SOAP specific code and should not be in cxf core
      * @param fault
@@ -551,8 +551,8 @@ public class ClientImpl
             String soap11NS = "http://schemas.xmlsoap.org/soap/envelope/";
             String soap12NS = "http://www.w3.org/2003/05/soap-envelope";
             QName faultCode = fault.getFaultCode();
-            //for SoapFault, if it's underlying cause is IOException, 
-            //it means something like server is down or can't create 
+            //for SoapFault, if it's underlying cause is IOException,
+            //it means something like server is down or can't create
             //connection, according to soap spec we should set fault as
             //Server Fault
             if (faultCode.getNamespaceURI().equals(
@@ -594,10 +594,10 @@ public class ClientImpl
             }
             throw ex;
         }
-        
-        //REVISIT 
+
+        //REVISIT
         // - use a protocol neutral no-content marker instead of 202?
-        // - move the decoupled destination property name into api 
+        // - move the decoupled destination property name into api
         Integer responseCode = (Integer)exchange.get(Message.RESPONSE_CODE);
         if (null != responseCode && 202 == responseCode) {
             Endpoint ep = exchange.getEndpoint();
@@ -749,7 +749,7 @@ public class ClientImpl
         chain.setFaultObserver(outFaultObserver);
         modifyChain(chain, message, true);
         modifyChain(chain, message.getExchange().getOutMessage(), true);
-        
+
         Bus origBus = BusFactory.getAndSetThreadDefaultBus(bus);
         // execute chain
         ClientCallback callback = message.getExchange().get(ClientCallback.class);
@@ -779,7 +779,7 @@ public class ClientImpl
                     try {
                         chain.doIntercept(message);
                     } catch (Throwable error) {
-                        //so that asyn callback handler get chance to 
+                        //so that asyn callback handler get chance to
                         //handle non-runtime exceptions
                         message.getExchange().setInMessage(message);
                         Map<String, Object> resCtx = CastUtils
@@ -800,7 +800,7 @@ public class ClientImpl
                 } else {
                     chain.doIntercept(message);
                 }
-                 
+
             }
 
             callback = message.getExchange().get(ClientCallback.class);
@@ -834,7 +834,7 @@ public class ClientImpl
                 BusFactory.setThreadDefaultBus(origBus);
             }
             synchronized (message.getExchange()) {
-                if (!isPartialResponse(message) 
+                if (!isPartialResponse(message)
                     || message.getContent(Exception.class) != null) {
                     message.getExchange().put(FINISHED, Boolean.TRUE);
                     message.getExchange().setInMessage(message);
@@ -887,7 +887,7 @@ public class ClientImpl
                 public void onMessage(final Message message) {
                     if (!message.getExchange()
                         .containsKey(Executor.class.getName() + ".USING_SPECIFIED")) {
-                        
+
                         executor.execute(new Runnable() {
                             public void run() {
                                 ClientImpl.this.onMessage(message);
@@ -968,7 +968,7 @@ public class ClientImpl
         if (ctx == null) {
             return;
         }
-        Collection<InterceptorProvider> providers 
+        Collection<InterceptorProvider> providers
             = CastUtils.cast((Collection<?>)ctx.get(Message.INTERCEPTOR_PROVIDERS));
         if (providers != null) {
             for (InterceptorProvider p : providers) {
@@ -980,7 +980,7 @@ public class ClientImpl
             }
         }
         String key = in ? Message.IN_INTERCEPTORS : Message.OUT_INTERCEPTORS;
-        Collection<Interceptor<? extends Message>> is 
+        Collection<Interceptor<? extends Message>> is
             = CastUtils.cast((Collection<?>)ctx.get(key));
         if (is != null) {
             chain.add(is);

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/endpoint/ClientLifeCycleListener.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/endpoint/ClientLifeCycleListener.java b/core/src/main/java/org/apache/cxf/endpoint/ClientLifeCycleListener.java
index f4c5433..77279e3 100644
--- a/core/src/main/java/org/apache/cxf/endpoint/ClientLifeCycleListener.java
+++ b/core/src/main/java/org/apache/cxf/endpoint/ClientLifeCycleListener.java
@@ -21,5 +21,5 @@ package org.apache.cxf.endpoint;
 
 public interface ClientLifeCycleListener {
     void clientCreated(Client client);
-    void clientDestroyed(Client client); 
+    void clientDestroyed(Client client);
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/endpoint/ClientLifeCycleManager.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/endpoint/ClientLifeCycleManager.java b/core/src/main/java/org/apache/cxf/endpoint/ClientLifeCycleManager.java
index a1f0226..53acdf7 100644
--- a/core/src/main/java/org/apache/cxf/endpoint/ClientLifeCycleManager.java
+++ b/core/src/main/java/org/apache/cxf/endpoint/ClientLifeCycleManager.java
@@ -20,7 +20,7 @@
 package org.apache.cxf.endpoint;
 
 
-public interface ClientLifeCycleManager { 
+public interface ClientLifeCycleManager {
     void clientCreated(Client client);
     void clientDestroyed(Client client);
     void registerListener(ClientLifeCycleListener listener);

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/endpoint/ConduitSelector.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/endpoint/ConduitSelector.java b/core/src/main/java/org/apache/cxf/endpoint/ConduitSelector.java
index 1ca3c7d..e4d3063 100644
--- a/core/src/main/java/org/apache/cxf/endpoint/ConduitSelector.java
+++ b/core/src/main/java/org/apache/cxf/endpoint/ConduitSelector.java
@@ -30,12 +30,12 @@ import org.apache.cxf.transport.Conduit;
  * into the Client via config.
  */
 public interface ConduitSelector {
-        
+
     /**
      * Called prior to the interceptor chain being traversed.
      * This is the point at which an eager strategy would retrieve
      * a Conduit.
-     * 
+     *
      * @param message the current Message
      */
     void prepare(Message message);
@@ -44,17 +44,17 @@ public interface ConduitSelector {
      * Called when a Conduit is actually required.
      * This is the point at which a lazy strategy would retrieve
      * a Conduit.
-     * 
+     *
      * @param message
      * @return the Conduit to use for mediation of the message
      */
     Conduit selectConduit(Message message);
-    
+
     /**
      * Called on completion of the MEP for which the Conduit was required.
      * This is the point at which a one-shot strategy would dispose of
      * the Conduit.
-     * 
+     *
      * @param exchange represents the completed MEP
      */
     void complete(Exchange exchange);

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/endpoint/ConduitSelectorHolder.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/endpoint/ConduitSelectorHolder.java b/core/src/main/java/org/apache/cxf/endpoint/ConduitSelectorHolder.java
index f650039..c8ff4db 100644
--- a/core/src/main/java/org/apache/cxf/endpoint/ConduitSelectorHolder.java
+++ b/core/src/main/java/org/apache/cxf/endpoint/ConduitSelectorHolder.java
@@ -20,6 +20,6 @@ package org.apache.cxf.endpoint;
 
 public interface ConduitSelectorHolder {
     ConduitSelector getConduitSelector();
-    
+
     void setConduitSelector(ConduitSelector conduitSelector);
 }