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

[39/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/interceptor/security/OperationInfoAuthorizingInterceptor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/interceptor/security/OperationInfoAuthorizingInterceptor.java b/core/src/main/java/org/apache/cxf/interceptor/security/OperationInfoAuthorizingInterceptor.java
index 73cb9f6..b6e2da7 100755
--- a/core/src/main/java/org/apache/cxf/interceptor/security/OperationInfoAuthorizingInterceptor.java
+++ b/core/src/main/java/org/apache/cxf/interceptor/security/OperationInfoAuthorizingInterceptor.java
@@ -1,96 +1,96 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-package org.apache.cxf.interceptor.security;
-
-import java.util.Collections;
-import java.util.List;
-import java.util.logging.Level;
-import java.util.logging.Logger;
-
-import org.apache.cxf.common.logging.LogUtils;
-import org.apache.cxf.interceptor.Fault;
-import org.apache.cxf.message.Message;
-import org.apache.cxf.security.SecurityContext;
-import org.apache.cxf.service.model.BindingOperationInfo;
-import org.apache.cxf.service.model.OperationInfo;
-
-/**
- * 
- */
-public class OperationInfoAuthorizingInterceptor extends SimpleAuthorizingInterceptor {
-    private static final Logger LOG = LogUtils.getL7dLogger(OperationInfoAuthorizingInterceptor.class);
-
-    @Override
-    public void handleMessage(Message message) throws Fault {
-        OperationInfo opinfo = getTargetOperationInfo(message);
-        SecurityContext sc = message.get(SecurityContext.class);
-        if (sc != null && sc.getUserPrincipal() != null) {
-            if (opinfo.getName() != null
-                && authorize(sc, opinfo.getName().getLocalPart())) {
-                return;
-            }
-        } else if (!isMethodProtected(opinfo.getName().getLocalPart()) && isAllowAnonymousUsers()) {
-            return;
-        }
-        
-        throw new AccessDeniedException("Unauthorized");
-
-    }
-
-    protected boolean authorize(SecurityContext sc, String key) {
-        List<String> expectedRoles = getExpectedRoles(key);
-        if (expectedRoles.isEmpty()) {
-            List<String> denyRoles = getDenyRoles(key);
-            return denyRoles.isEmpty() ? true : isUserInRole(sc, denyRoles, true);
-        }
-        
-        if (isUserInRole(sc, expectedRoles, false)) {
-            return true;
-        }
-        if (LOG.isLoggable(Level.FINE)) {
-            LOG.fine(sc.getUserPrincipal().getName() + " is not authorized");
-        }
-        return false;
-    }
-
-    protected OperationInfo getTargetOperationInfo(Message message) {
-        BindingOperationInfo bop = message.getExchange().getBindingOperationInfo();
-        if (bop != null) {
-            return bop.getOperationInfo();
-        }
-        throw new AccessDeniedException("OperationInfo is not available : Unauthorized");
-    }
-
-    protected List<String> getExpectedRoles(String key) {
-        List<String> roles = methodRolesMap.get(key);
-        if (roles != null) {
-            return roles;
-        }
-        return globalRoles;
-    }
-
-    protected List<String> getDenyRoles(String key) {
-        return Collections.emptyList();    
-    }
-    
-    protected boolean isMethodProtected(String key) {
-        return !getExpectedRoles(key).isEmpty() || !getDenyRoles(key).isEmpty();
-    }
-}
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements. See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership. The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License. You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied. See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.cxf.interceptor.security;
+
+import java.util.Collections;
+import java.util.List;
+import java.util.logging.Level;
+import java.util.logging.Logger;
+
+import org.apache.cxf.common.logging.LogUtils;
+import org.apache.cxf.interceptor.Fault;
+import org.apache.cxf.message.Message;
+import org.apache.cxf.security.SecurityContext;
+import org.apache.cxf.service.model.BindingOperationInfo;
+import org.apache.cxf.service.model.OperationInfo;
+
+/**
+ *
+ */
+public class OperationInfoAuthorizingInterceptor extends SimpleAuthorizingInterceptor {
+    private static final Logger LOG = LogUtils.getL7dLogger(OperationInfoAuthorizingInterceptor.class);
+
+    @Override
+    public void handleMessage(Message message) throws Fault {
+        OperationInfo opinfo = getTargetOperationInfo(message);
+        SecurityContext sc = message.get(SecurityContext.class);
+        if (sc != null && sc.getUserPrincipal() != null) {
+            if (opinfo.getName() != null
+                && authorize(sc, opinfo.getName().getLocalPart())) {
+                return;
+            }
+        } else if (!isMethodProtected(opinfo.getName().getLocalPart()) && isAllowAnonymousUsers()) {
+            return;
+        }
+
+        throw new AccessDeniedException("Unauthorized");
+
+    }
+
+    protected boolean authorize(SecurityContext sc, String key) {
+        List<String> expectedRoles = getExpectedRoles(key);
+        if (expectedRoles.isEmpty()) {
+            List<String> denyRoles = getDenyRoles(key);
+            return denyRoles.isEmpty() ? true : isUserInRole(sc, denyRoles, true);
+        }
+
+        if (isUserInRole(sc, expectedRoles, false)) {
+            return true;
+        }
+        if (LOG.isLoggable(Level.FINE)) {
+            LOG.fine(sc.getUserPrincipal().getName() + " is not authorized");
+        }
+        return false;
+    }
+
+    protected OperationInfo getTargetOperationInfo(Message message) {
+        BindingOperationInfo bop = message.getExchange().getBindingOperationInfo();
+        if (bop != null) {
+            return bop.getOperationInfo();
+        }
+        throw new AccessDeniedException("OperationInfo is not available : Unauthorized");
+    }
+
+    protected List<String> getExpectedRoles(String key) {
+        List<String> roles = methodRolesMap.get(key);
+        if (roles != null) {
+            return roles;
+        }
+        return globalRoles;
+    }
+
+    protected List<String> getDenyRoles(String key) {
+        return Collections.emptyList();
+    }
+
+    protected boolean isMethodProtected(String key) {
+        return !getExpectedRoles(key).isEmpty() || !getDenyRoles(key).isEmpty();
+    }
+}

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/interceptor/security/RolePrefixSecurityContextImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/interceptor/security/RolePrefixSecurityContextImpl.java b/core/src/main/java/org/apache/cxf/interceptor/security/RolePrefixSecurityContextImpl.java
index 7b6baa3..125d6e0 100644
--- a/core/src/main/java/org/apache/cxf/interceptor/security/RolePrefixSecurityContextImpl.java
+++ b/core/src/main/java/org/apache/cxf/interceptor/security/RolePrefixSecurityContextImpl.java
@@ -30,20 +30,20 @@ import org.apache.cxf.security.LoginSecurityContext;
 
 public class RolePrefixSecurityContextImpl implements LoginSecurityContext {
     private Principal p;
-    private Set<Principal> roles; 
+    private Set<Principal> roles;
     private Subject theSubject;
-    
+
     public RolePrefixSecurityContextImpl(Subject subject, String rolePrefix) {
         this(subject, rolePrefix, JAASLoginInterceptor.ROLE_CLASSIFIER_PREFIX);
     }
-    
+
     public RolePrefixSecurityContextImpl(Subject subject, String roleClassifier,
                                          String roleClassifierType) {
         this.p = findPrincipal(subject, roleClassifier, roleClassifierType);
         this.roles = findRoles(subject, roleClassifier, roleClassifierType);
         this.theSubject = subject;
     }
-    
+
     public Principal getUserPrincipal() {
         return p;
     }
@@ -58,8 +58,8 @@ public class RolePrefixSecurityContextImpl implements LoginSecurityContext {
         }
         return false;
     }
-    
-    private static Principal findPrincipal(Subject subject, 
+
+    private static Principal findPrincipal(Subject subject,
         String roleClassifier, String roleClassifierType) {
         for (Principal p : subject.getPrincipals()) {
             if (!isRole(p, roleClassifier, roleClassifierType)) {
@@ -68,8 +68,8 @@ public class RolePrefixSecurityContextImpl implements LoginSecurityContext {
         }
         return null;
     }
-    
-    private static Set<Principal> findRoles(Subject subject, 
+
+    private static Set<Principal> findRoles(Subject subject,
         String roleClassifier, String roleClassifierType) {
         Set<Principal> set = new HashSet<>();
         for (Principal p : subject.getPrincipals()) {
@@ -87,7 +87,7 @@ public class RolePrefixSecurityContextImpl implements LoginSecurityContext {
             return p.getClass().getName().endsWith(roleClassifier);
         }
     }
-    
+
     public Subject getSubject() {
         return theSubject;
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/interceptor/security/SecureAnnotationsInterceptor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/interceptor/security/SecureAnnotationsInterceptor.java b/core/src/main/java/org/apache/cxf/interceptor/security/SecureAnnotationsInterceptor.java
index 0ff02dd..41b1bd5 100644
--- a/core/src/main/java/org/apache/cxf/interceptor/security/SecureAnnotationsInterceptor.java
+++ b/core/src/main/java/org/apache/cxf/interceptor/security/SecureAnnotationsInterceptor.java
@@ -37,24 +37,24 @@ public class SecureAnnotationsInterceptor extends SimpleAuthorizingInterceptor {
 
     private static final Logger LOG = LogUtils.getL7dLogger(SecureAnnotationsInterceptor.class);
     private static final String DEFAULT_ANNOTATION_CLASS_NAME = "javax.annotation.security.RolesAllowed";
-    
+
     private static final Set<String> SKIP_METHODS;
     static {
         SKIP_METHODS = new HashSet<>();
         SKIP_METHODS.addAll(Arrays.asList(
-            new String[] {"wait", "notify", "notifyAll", 
+            new String[] {"wait", "notify", "notifyAll",
                           "equals", "toString", "hashCode"}));
     }
-    
+
     private String annotationClassName = DEFAULT_ANNOTATION_CLASS_NAME;
-    
+
     public SecureAnnotationsInterceptor() {
         this(true);
     }
     public SecureAnnotationsInterceptor(boolean uniqueId) {
         super(uniqueId);
     }
-    
+
     public void setAnnotationClassName(String name) {
         try {
             ClassLoaderUtils.loadClass(name, SecureAnnotationsInterceptor.class);
@@ -64,7 +64,7 @@ public class SecureAnnotationsInterceptor extends SimpleAuthorizingInterceptor {
             throw new IllegalArgumentException("Annotation class " + name + " is not available");
         }
     }
-    
+
     public void setSecuredObject(Object object) {
         Class<?> cls = ClassHelper.getRealClass(object);
         Map<String, String> rolesMap = new HashMap<String, String>();
@@ -98,18 +98,18 @@ public class SecureAnnotationsInterceptor extends SimpleAuthorizingInterceptor {
         if (!rolesMap.isEmpty()) {
             return;
         }
-        
+
         findRoles(cls.getSuperclass(), rolesMap);
-        
+
         if (!rolesMap.isEmpty()) {
             return;
         }
-        
+
         for (Class<?> interfaceCls : cls.getInterfaces()) {
             findRoles(interfaceCls, rolesMap);
         }
     }
-    
+
     private String getRoles(Annotation[] anns, String annName) {
         for (Annotation ann : anns) {
             if (ann.annotationType().getName().equals(annName)) {
@@ -125,7 +125,7 @@ public class SecureAnnotationsInterceptor extends SimpleAuthorizingInterceptor {
                     }
                     return sb.toString();
                 } catch (Exception ex) {
-                    // ignore    
+                    // ignore
                 }
                 break;
             }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/interceptor/security/SimpleAuthorizingInterceptor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/interceptor/security/SimpleAuthorizingInterceptor.java b/core/src/main/java/org/apache/cxf/interceptor/security/SimpleAuthorizingInterceptor.java
index a3e6079..45c0a94 100644
--- a/core/src/main/java/org/apache/cxf/interceptor/security/SimpleAuthorizingInterceptor.java
+++ b/core/src/main/java/org/apache/cxf/interceptor/security/SimpleAuthorizingInterceptor.java
@@ -35,22 +35,22 @@ public class SimpleAuthorizingInterceptor extends AbstractAuthorizingInIntercept
     protected Map<String, List<String>> userRolesMap = Collections.emptyMap();
     protected List<String> globalRoles = Collections.emptyList();
     private boolean checkConfiguredRolesOnly;
-    
+
     public SimpleAuthorizingInterceptor() {
         this(true);
     }
     public SimpleAuthorizingInterceptor(boolean uniqueId) {
         super(uniqueId);
     }
-    
-    @Override 
+
+    @Override
     protected boolean isUserInRole(SecurityContext sc, List<String> roles, boolean deny) {
         if (!checkConfiguredRolesOnly && !super.isUserInRole(sc, roles, deny)) {
             return false;
         }
         // Additional check.
         if (!userRolesMap.isEmpty()) {
-            List<String> userRoles = userRolesMap.get(sc.getUserPrincipal().getName());    
+            List<String> userRoles = userRolesMap.get(sc.getUserPrincipal().getName());
             if (userRoles == null) {
                 return false;
             }
@@ -64,7 +64,7 @@ public class SimpleAuthorizingInterceptor extends AbstractAuthorizingInIntercept
             return !checkConfiguredRolesOnly;
         }
     }
-    
+
     protected String createMethodSig(Method method) {
         StringBuilder b = new StringBuilder(method.getReturnType().getName());
         b.append(' ').append(method.getName()).append('(');
@@ -79,7 +79,7 @@ public class SimpleAuthorizingInterceptor extends AbstractAuthorizingInIntercept
         b.append(')');
         return b.toString();
     }
-    
+
     @Override
     protected List<String> getExpectedRoles(Method method) {
         List<String> roles = methodRolesMap.get(createMethodSig(method));
@@ -94,21 +94,21 @@ public class SimpleAuthorizingInterceptor extends AbstractAuthorizingInIntercept
 
 
     public void setMethodRolesMap(Map<String, String> rolesMap) {
-        methodRolesMap.putAll(parseRolesMap(rolesMap)); 
+        methodRolesMap.putAll(parseRolesMap(rolesMap));
     }
-    
+
     public void setUserRolesMap(Map<String, String> rolesMap) {
         userRolesMap = parseRolesMap(rolesMap);
     }
-    
+
     public void setGlobalRoles(String roles) {
         globalRoles = Arrays.asList(StringUtils.split(roles, " "));
     }
-    
+
     public void setCheckConfiguredRolesOnly(boolean checkConfiguredRolesOnly) {
         this.checkConfiguredRolesOnly = checkConfiguredRolesOnly;
     }
-    
+
     private static Map<String, List<String>> parseRolesMap(Map<String, String> rolesMap) {
         Map<String, List<String>> map = new HashMap<String, List<String>>();
         for (Map.Entry<String, String> entry : rolesMap.entrySet()) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/interceptor/security/callback/CallbackHandlerProviderUsernameToken.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/interceptor/security/callback/CallbackHandlerProviderUsernameToken.java b/core/src/main/java/org/apache/cxf/interceptor/security/callback/CallbackHandlerProviderUsernameToken.java
index 7e6e284..de66c49 100644
--- a/core/src/main/java/org/apache/cxf/interceptor/security/callback/CallbackHandlerProviderUsernameToken.java
+++ b/core/src/main/java/org/apache/cxf/interceptor/security/callback/CallbackHandlerProviderUsernameToken.java
@@ -36,7 +36,7 @@ public class CallbackHandlerProviderUsernameToken implements CallbackHandlerProv
         }
         UsernameToken ut = (UsernameToken)token;
         if (ut.getPasswordType().endsWith("PasswordDigest")) {
-            return new NameDigestPasswordCallbackHandler(ut.getName(), 
+            return new NameDigestPasswordCallbackHandler(ut.getName(),
                                                          ut.getPassword(),
                                                          ut.getNonce(),
                                                          ut.getCreatedTime());

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/interceptor/security/callback/CallbackHandlerTlsCert.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/interceptor/security/callback/CallbackHandlerTlsCert.java b/core/src/main/java/org/apache/cxf/interceptor/security/callback/CallbackHandlerTlsCert.java
index cfb95ce..02f3f1a 100644
--- a/core/src/main/java/org/apache/cxf/interceptor/security/callback/CallbackHandlerTlsCert.java
+++ b/core/src/main/java/org/apache/cxf/interceptor/security/callback/CallbackHandlerTlsCert.java
@@ -31,7 +31,7 @@ public class CallbackHandlerTlsCert implements CallbackHandlerProvider {
     private CertificateToNameMapper certMapper;
     private NameToPasswordMapper nameToPasswordMapper;
     private String fixedPassword;
-    
+
     public CallbackHandlerTlsCert() {
         // By default use subjectDN as userName
         this.certMapper = new CertificateToNameMapper() {
@@ -39,7 +39,7 @@ public class CallbackHandlerTlsCert implements CallbackHandlerProvider {
                 return ((X509Certificate)cert).getSubjectDN().getName();
             }
         };
-        // By default use fixed password 
+        // By default use fixed password
         this.nameToPasswordMapper = new NameToPasswordMapper() {
             public String getPassword(String userName) {
                 return fixedPassword;
@@ -58,7 +58,7 @@ public class CallbackHandlerTlsCert implements CallbackHandlerProvider {
         String password = nameToPasswordMapper.getPassword(name);
         return new NamePasswordCallbackHandler(name, password);
     }
-    
+
     /**
      * Extracts certificate from message, expecting to find TLSSessionInfo inside.
      *
@@ -78,7 +78,7 @@ public class CallbackHandlerTlsCert implements CallbackHandlerProvider {
         // Due to RFC5246, senders certificates always comes 1st
         return certificates[0];
     }
-    
+
     public void setCertMapper(CertificateToNameMapper certMapper) {
         this.certMapper = certMapper;
     }
@@ -90,5 +90,5 @@ public class CallbackHandlerTlsCert implements CallbackHandlerProvider {
     public void setNameToPasswordMapper(NameToPasswordMapper nameToPasswordMapper) {
         this.nameToPasswordMapper = nameToPasswordMapper;
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/interceptor/security/callback/CertKeyToUserNameMapper.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/interceptor/security/callback/CertKeyToUserNameMapper.java b/core/src/main/java/org/apache/cxf/interceptor/security/callback/CertKeyToUserNameMapper.java
index 7952faa..3a826e9 100644
--- a/core/src/main/java/org/apache/cxf/interceptor/security/callback/CertKeyToUserNameMapper.java
+++ b/core/src/main/java/org/apache/cxf/interceptor/security/callback/CertKeyToUserNameMapper.java
@@ -27,7 +27,7 @@ import javax.naming.ldap.Rdn;
 
 public class CertKeyToUserNameMapper implements CertificateToNameMapper {
     private String key;
-    
+
     /**
      * Returns Subject DN from X509Certificate
      *

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/interceptor/transform/TransformInInterceptor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/interceptor/transform/TransformInInterceptor.java b/core/src/main/java/org/apache/cxf/interceptor/transform/TransformInInterceptor.java
index fab2026..1c0eb84 100644
--- a/core/src/main/java/org/apache/cxf/interceptor/transform/TransformInInterceptor.java
+++ b/core/src/main/java/org/apache/cxf/interceptor/transform/TransformInInterceptor.java
@@ -38,50 +38,50 @@ import org.apache.cxf.staxutils.transform.TransformUtils;
  * Creates an XMLStreamReader from the InputStream on the Message.
  */
 public class TransformInInterceptor extends AbstractPhaseInterceptor<Message> {
-    
+
     private List<String> inDropElements;
     private Map<String, String> inElementsMap;
     private Map<String, String> inAppendMap;
     private Map<String, String> inAttributesMap;
     private boolean blockOriginalReader = true;
     private String contextPropertyName;
-    
+
     public TransformInInterceptor() {
         this(Phase.POST_STREAM);
         addBefore(StaxInInterceptor.class.getName());
     }
-    
+
     public TransformInInterceptor(String phase) {
         super(phase);
     }
-    
+
     public TransformInInterceptor(String phase, List<String> after) {
         super(phase);
         if (after != null) {
             addAfter(after);
         }
     }
-    
+
     public TransformInInterceptor(String phase, List<String> before, List<String> after) {
         this(phase, after);
         if (before != null) {
             addBefore(before);
         }
     }
-    
+
     public void handleMessage(Message message) {
-        if (contextPropertyName != null 
+        if (contextPropertyName != null
             && !MessageUtils.getContextualBoolean(message, contextPropertyName, false)) {
             return;
         }
         XMLStreamReader reader = message.getContent(XMLStreamReader.class);
         InputStream is = message.getContent(InputStream.class);
-        
+
         XMLStreamReader transformReader = createTransformReaderIfNeeded(reader, is);
         if (transformReader != null) {
             message.setContent(XMLStreamReader.class, transformReader);
         }
-         
+
     }
 
     protected XMLStreamReader createTransformReaderIfNeeded(XMLStreamReader reader, InputStream is) {
@@ -96,11 +96,11 @@ public class TransformInInterceptor extends AbstractPhaseInterceptor<Message> {
     public void setInAppendElements(Map<String, String> inElements) {
         this.inAppendMap = inElements;
     }
-    
+
     public void setInDropElements(List<String> dropElementsSet) {
         this.inDropElements = dropElementsSet;
     }
-    
+
     public void setInTransformElements(Map<String, String> inElements) {
         this.inElementsMap = inElements;
     }
@@ -112,7 +112,7 @@ public class TransformInInterceptor extends AbstractPhaseInterceptor<Message> {
     public void setBlockOriginalReader(boolean blockOriginalReader) {
         this.blockOriginalReader = blockOriginalReader;
     }
-    
+
     public void setContextPropertyName(String propertyName) {
         contextPropertyName = propertyName;
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/interceptor/transform/TransformOutInterceptor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/interceptor/transform/TransformOutInterceptor.java b/core/src/main/java/org/apache/cxf/interceptor/transform/TransformOutInterceptor.java
index c1901bf..cb37ef5 100644
--- a/core/src/main/java/org/apache/cxf/interceptor/transform/TransformOutInterceptor.java
+++ b/core/src/main/java/org/apache/cxf/interceptor/transform/TransformOutInterceptor.java
@@ -40,12 +40,12 @@ import org.apache.cxf.staxutils.transform.TransformUtils;
  * Creates an XMLStreamReader from the InputStream on the Message.
  */
 public class TransformOutInterceptor extends AbstractPhaseInterceptor<Message> {
-    
-    private static final String OUTPUT_STREAM_HOLDER = 
+
+    private static final String OUTPUT_STREAM_HOLDER =
         TransformOutInterceptor.class.getName() + ".outputstream";
     private static final String TRANSFORM_SKIP = "transform.skip";
     private static final StaxOutEndingInterceptor ENDING = new StaxOutEndingInterceptor(OUTPUT_STREAM_HOLDER);
-    
+
     private Map<String, String> outElementsMap;
     private Map<String, String> outAppendMap;
     private List<String> outDropElements;
@@ -54,18 +54,18 @@ public class TransformOutInterceptor extends AbstractPhaseInterceptor<Message> {
     private boolean skipOnFault;
     private String contextPropertyName;
     private String defaultNamespace;
-    
+
     public TransformOutInterceptor() {
         this(Phase.PRE_STREAM);
     }
-    
+
     public TransformOutInterceptor(String phase) {
         super(phase);
         addBefore(StaxOutInterceptor.class.getName());
         addAfter("org.apache.cxf.interceptor.LoggingOutInterceptor");
         addAfter("org.apache.cxf.ext.logging.LoggingOutInterceptor");
     }
-    
+
     @Override
     public void handleFault(Message message) {
         super.handleFault(message);
@@ -74,27 +74,27 @@ public class TransformOutInterceptor extends AbstractPhaseInterceptor<Message> {
             message.setContent(OutputStream.class, os);
         }
     }
-    
+
     public void handleMessage(Message message) {
         if (!isHttpVerbSupported(message)) {
             return;
         }
-        
-        if (contextPropertyName != null 
+
+        if (contextPropertyName != null
             && !MessageUtils.getContextualBoolean(message.getExchange().getInMessage(),
-                                               contextPropertyName, 
+                                               contextPropertyName,
                                                false)) {
             return;
         }
-        
+
         if (skipOnFault && null != message.getContent(Exception.class)
             || MessageUtils.isTrue(message.getContextualProperty(TRANSFORM_SKIP))) {
             return;
         }
-        
+
         XMLStreamWriter writer = message.getContent(XMLStreamWriter.class);
         OutputStream out = message.getContent(OutputStream.class);
-        
+
         XMLStreamWriter transformWriter = createTransformWriterIfNeeded(writer, out);
         if (transformWriter != null) {
             message.setContent(XMLStreamWriter.class, transformWriter);
@@ -107,9 +107,9 @@ public class TransformOutInterceptor extends AbstractPhaseInterceptor<Message> {
             }
         }
     }
-   
+
     protected XMLStreamWriter createTransformWriterIfNeeded(XMLStreamWriter writer, OutputStream os) {
-        return TransformUtils.createTransformWriterIfNeeded(writer, os, 
+        return TransformUtils.createTransformWriterIfNeeded(writer, os,
                                                       outElementsMap,
                                                       outDropElements,
                                                       outAppendMap,
@@ -117,11 +117,11 @@ public class TransformOutInterceptor extends AbstractPhaseInterceptor<Message> {
                                                       attributesToElements,
                                                       defaultNamespace);
     }
-    
+
     public void setOutTransformElements(Map<String, String> outElements) {
         this.outElementsMap = outElements;
     }
-    
+
     public void setOutAppendElements(Map<String, String> map) {
         this.outAppendMap = map;
     }
@@ -137,15 +137,15 @@ public class TransformOutInterceptor extends AbstractPhaseInterceptor<Message> {
     public void setAttributesToElements(boolean value) {
         this.attributesToElements = value;
     }
-    
+
     public void setSkipOnFault(boolean value) {
         this.skipOnFault = value;
     }
-    
+
     protected boolean isHttpVerbSupported(Message message) {
         return  isRequestor(message) && isGET(message) ? false : true;
     }
-    
+
     public void setContextPropertyName(String propertyName) {
         contextPropertyName = propertyName;
     }
@@ -153,5 +153,5 @@ public class TransformOutInterceptor extends AbstractPhaseInterceptor<Message> {
     public void setDefaultNamespace(String defaultNamespace) {
         this.defaultNamespace = defaultNamespace;
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/internal/CXFAPINamespaceHandler.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/internal/CXFAPINamespaceHandler.java b/core/src/main/java/org/apache/cxf/internal/CXFAPINamespaceHandler.java
index 6e416e4..d76d0f8 100644
--- a/core/src/main/java/org/apache/cxf/internal/CXFAPINamespaceHandler.java
+++ b/core/src/main/java/org/apache/cxf/internal/CXFAPINamespaceHandler.java
@@ -44,8 +44,8 @@ import org.osgi.service.blueprint.reflect.Metadata;
              "http://schemas.xmlsoap.org/wsdl/",
              "http://www.w3.org/2005/08/addressing",
              "http://schemas.xmlsoap.org/ws/2004/08/addressing"})
-public class CXFAPINamespaceHandler implements NamespaceHandler {    
-    
+public class CXFAPINamespaceHandler implements NamespaceHandler {
+
     public URL getSchemaLocation(String namespace) {
         String location = null;
 
@@ -55,7 +55,7 @@ public class CXFAPINamespaceHandler implements NamespaceHandler {
 
         if ("http://cxf.apache.org/configuration/beans".equals(namespace)
                 || "http://cxf.apache.org/schemas/configuration/cxf-beans.xsd".equals(namespace)) {
-            location = "schemas/configuration/cxf-beans.xsd";           
+            location = "schemas/configuration/cxf-beans.xsd";
         } else if ("http://cxf.apache.org/configuration/parameterized-types".equals(namespace)
                 || "http://cxf.apache.org/schemas/configuration/parameterized-types.xsd".equals(namespace)) {
             location = "schemas/configuration/parameterized-types.xsd";
@@ -96,7 +96,7 @@ public class CXFAPINamespaceHandler implements NamespaceHandler {
                 public String getId(Element element, ParserContext context) {
                     String id = element.hasAttribute("id") ? element.getAttribute("id") : null;
                     if (id == null) {
-                        id = "cxf.workqueue."; 
+                        id = "cxf.workqueue.";
                         id += element.hasAttribute("name") ? element.getAttribute("name") : "def";
                     }
                     return id;
@@ -119,5 +119,5 @@ public class CXFAPINamespaceHandler implements NamespaceHandler {
     public ComponentMetadata decorate(Node node, ComponentMetadata component, ParserContext context) {
         return null;
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/io/AbstractThresholdOutputStream.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/io/AbstractThresholdOutputStream.java b/core/src/main/java/org/apache/cxf/io/AbstractThresholdOutputStream.java
index 3d8bbab..6cbc799 100644
--- a/core/src/main/java/org/apache/cxf/io/AbstractThresholdOutputStream.java
+++ b/core/src/main/java/org/apache/cxf/io/AbstractThresholdOutputStream.java
@@ -27,26 +27,26 @@ import org.apache.cxf.helpers.LoadingByteArrayOutputStream;
  * Outputstream that will buffer a certain amount before writing anything to the underlying
  * stream.   When the threshold is reached, provides a callback point to allow the
  * subclass to update headers, replace/set the output stream, etc...
- * 
+ *
  * Also provides a callback for when the stream is closed without it reaching the threshold.
  */
 public abstract class AbstractThresholdOutputStream extends AbstractWrappedOutputStream {
-    
+
     protected int threshold;
     protected LoadingByteArrayOutputStream buffer;
-    
+
     public AbstractThresholdOutputStream(int threshold) {
         this.threshold = threshold;
         if (threshold >= 0) {
             buffer = new LoadingByteArrayOutputStream(threshold + 1);
         }
     }
-    
-    
+
+
     public abstract void thresholdReached() throws IOException;
     public abstract void thresholdNotReached() throws IOException;
-    
-    
+
+
     @Override
     public void write(byte[] b, int off, int len) throws IOException {
         if (buffer != null) {
@@ -57,7 +57,7 @@ public abstract class AbstractThresholdOutputStream extends AbstractWrappedOutpu
             buffer.write(b, off, space);
             len -= space;
             off += space;
-            
+
             if (buffer.size() >= threshold) {
                 thresholdReached();
                 unBuffer();
@@ -89,7 +89,7 @@ public abstract class AbstractThresholdOutputStream extends AbstractWrappedOutpu
                 super.write(buffer.getRawBytes(), 0, buffer.size());
             }
             buffer = null;
-        }  
+        }
     }
 
 

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/io/AbstractWrappedOutputStream.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/io/AbstractWrappedOutputStream.java b/core/src/main/java/org/apache/cxf/io/AbstractWrappedOutputStream.java
index 2962b4c..084f624 100644
--- a/core/src/main/java/org/apache/cxf/io/AbstractWrappedOutputStream.java
+++ b/core/src/main/java/org/apache/cxf/io/AbstractWrappedOutputStream.java
@@ -32,7 +32,7 @@ public abstract class AbstractWrappedOutputStream extends OutputStream {
     protected OutputStream wrappedStream;
     protected boolean written;
     protected boolean allowFlush = true;
-    
+
     protected AbstractWrappedOutputStream() {
         super();
     }
@@ -70,7 +70,7 @@ public abstract class AbstractWrappedOutputStream extends OutputStream {
             wrappedStream.write(b);
         }
     }
-    
+
     @Override
     public void close() throws IOException {
         if (wrappedStream != null) {
@@ -84,7 +84,7 @@ public abstract class AbstractWrappedOutputStream extends OutputStream {
             wrappedStream.flush();
         }
     }
-    
+
     public void allowFlush(boolean b) {
         this.allowFlush = b;
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/io/CacheAndWriteOutputStream.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/io/CacheAndWriteOutputStream.java b/core/src/main/java/org/apache/cxf/io/CacheAndWriteOutputStream.java
index f34fcd9..0af9145 100644
--- a/core/src/main/java/org/apache/cxf/io/CacheAndWriteOutputStream.java
+++ b/core/src/main/java/org/apache/cxf/io/CacheAndWriteOutputStream.java
@@ -33,7 +33,7 @@ public class CacheAndWriteOutputStream extends CachedOutputStream {
     OutputStream flowThroughStream;
     long count;
     long limit = Long.MAX_VALUE;
-    
+
     public CacheAndWriteOutputStream(OutputStream stream) {
         super();
         if (stream == null) {
@@ -41,7 +41,7 @@ public class CacheAndWriteOutputStream extends CachedOutputStream {
         }
         flowThroughStream = stream;
     }
-    
+
     public void setCacheLimit(long l) {
         limit = l;
     }
@@ -50,17 +50,17 @@ public class CacheAndWriteOutputStream extends CachedOutputStream {
         flowThroughStream.flush();
         flowThroughStream.close();
     }
-   
+
     protected void postClose() throws IOException {
         flowThroughStream.flush();
         flowThroughStream.close();
     }
-    
+
     public OutputStream getFlowThroughStream() {
         return flowThroughStream;
     }
-    
-    
+
+
     @Override
     protected void onWrite() throws IOException {
         // does nothing
@@ -74,7 +74,7 @@ public class CacheAndWriteOutputStream extends CachedOutputStream {
         }
         count++;
     }
-    
+
     @Override
     public void write(byte[] b, int off, int len) throws IOException {
         flowThroughStream.write(b, off, len);
@@ -83,7 +83,7 @@ public class CacheAndWriteOutputStream extends CachedOutputStream {
         }
         count += len;
     }
-    
+
     @Override
     public void write(byte[] b) throws IOException {
         flowThroughStream.write(b);

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/io/CachedOutputStream.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/io/CachedOutputStream.java b/core/src/main/java/org/apache/cxf/io/CachedOutputStream.java
index d261984..5adc875 100644
--- a/core/src/main/java/org/apache/cxf/io/CachedOutputStream.java
+++ b/core/src/main/java/org/apache/cxf/io/CachedOutputStream.java
@@ -53,7 +53,7 @@ public class CachedOutputStream extends OutputStream {
     private static long defaultMaxSize;
     private static String defaultCipherTransformation;
     static {
-        
+
         String s = SystemPropertyAction.getPropertyOrNull("org.apache.cxf.io.CachedOutputStream.OutputDirectory");
         if (s != null) {
             File f = new File(s);
@@ -89,7 +89,7 @@ public class CachedOutputStream extends OutputStream {
     private CipherPair ciphers;
 
     private List<CachedOutputStreamCallback> callbacks;
-    
+
     private List<Object> streamList = new ArrayList<>();
 
     public CachedOutputStream() {
@@ -97,7 +97,7 @@ public class CachedOutputStream extends OutputStream {
     }
 
     public CachedOutputStream(long threshold) {
-        this.threshold = threshold; 
+        this.threshold = threshold;
         currentStream = new LoadingByteArrayOutputStream(2048);
         inmem = true;
         readBusProperties();
@@ -132,14 +132,14 @@ public class CachedOutputStream extends OutputStream {
     public void releaseTempFileHold() {
         allowDeleteOfFile = true;
     }
-    
+
     public void registerCallback(CachedOutputStreamCallback cb) {
         if (null == callbacks) {
             callbacks = new ArrayList<>();
         }
         callbacks.add(cb);
     }
-    
+
     public void deregisterCallback(CachedOutputStreamCallback cb) {
         if (null != callbacks) {
             callbacks.remove(cb);
@@ -155,7 +155,7 @@ public class CachedOutputStream extends OutputStream {
      * output stream ... etc.)
      */
     protected void doFlush() throws IOException {
-        
+
     }
 
     public void flush() throws IOException {
@@ -172,14 +172,14 @@ public class CachedOutputStream extends OutputStream {
      * Perform any actions required on stream closure (handle response etc.)
      */
     protected void doClose() throws IOException {
-        
+
     }
-    
+
     /**
      * Perform any actions required after stream closure (close the other related stream etc.)
      */
     protected void postClose() throws IOException {
-        
+
     }
 
     /**
@@ -201,7 +201,7 @@ public class CachedOutputStream extends OutputStream {
         doClose();
         streamList.remove(currentStream);
     }
-    
+
     public void close() throws IOException {
         currentStream.flush();
         outputLocked = true;
@@ -233,7 +233,7 @@ public class CachedOutputStream extends OutputStream {
      * When with Attachment, needs to replace the xml writer stream with the stream used by
      * AttachmentSerializer or copy the cached output stream to the "real"
      * output stream, i.e. onto the wire.
-     * 
+     *
      * @param out the new output stream
      * @param copyOldContent flag indicating if the old content should be copied
      * @throws IOException
@@ -314,11 +314,11 @@ public class CachedOutputStream extends OutputStream {
             IOUtils.copyAndCloseInput(fin, out);
         }
     }
-    
+
     public void writeCacheTo(StringBuilder out, long limit) throws IOException {
         writeCacheTo(out, StandardCharsets.UTF_8.name(), limit);
     }
-    
+
     public void writeCacheTo(StringBuilder out, String charsetName, long limit) throws IOException {
         flush();
         if (totalLength < limit
@@ -360,11 +360,11 @@ public class CachedOutputStream extends OutputStream {
             }
         }
     }
-    
+
     public void writeCacheTo(StringBuilder out) throws IOException {
         writeCacheTo(out, StandardCharsets.UTF_8.name());
     }
-    
+
     public void writeCacheTo(StringBuilder out, String charsetName) throws IOException {
         flush();
         if (inmem) {
@@ -425,7 +425,7 @@ public class CachedOutputStream extends OutputStream {
         }
         if (inmem && totalLength > threshold && currentStream instanceof ByteArrayOutputStream) {
             createFileOutputStream();
-        }       
+        }
     }
 
     public void write(byte[] b, int off, int len) throws IOException {
@@ -466,7 +466,7 @@ public class CachedOutputStream extends OutputStream {
             } else {
                 tempFile = FileUtils.createTempFile("cos", "tmp", outputDir, false);
             }
-            
+
             currentStream = createOutputStream(tempFile);
             bout.writeTo(currentStream);
             inmem = false;
@@ -513,14 +513,14 @@ public class CachedOutputStream extends OutputStream {
                         }
                     };
                 }
-                
+
                 return fileInputStream;
             } catch (FileNotFoundException e) {
                 throw new IOException("Cached file was deleted, " + e.toString());
             }
         }
     }
-    
+
     private synchronized void deleteTempFile() {
         if (tempFile != null) {
             File file = tempFile;
@@ -551,7 +551,7 @@ public class CachedOutputStream extends OutputStream {
     public void setOutputDir(File outputDir) throws IOException {
         this.outputDir = outputDir;
     }
-    
+
     public long getThreshold() {
         return threshold;
     }
@@ -566,7 +566,7 @@ public class CachedOutputStream extends OutputStream {
     public void setCipherTransformation(String cipherTransformation) {
         this.cipherTransformation = cipherTransformation;
     }
-    
+
     public static void setDefaultMaxSize(long l) {
         if (l == -1) {
             String s = System.getProperty("org.apache.cxf.io.CachedOutputStream.MaxSize",
@@ -585,7 +585,7 @@ public class CachedOutputStream extends OutputStream {
             }
         }
         defaultThreshold = i;
-        
+
     }
     public static void setDefaultCipherTransformation(String n) {
         if (n == null) {
@@ -636,12 +636,12 @@ public class CachedOutputStream extends OutputStream {
     private class TransferableFileInputStream extends FileInputStream implements Transferable {
         private boolean closed;
         private File sourceFile;
-        
+
         TransferableFileInputStream(File sourceFile) throws FileNotFoundException {
             super(sourceFile);
             this.sourceFile = sourceFile;
         }
-        
+
         public void close() throws IOException {
             if (!closed) {
                 super.close();

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/io/CachedWriter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/io/CachedWriter.java b/core/src/main/java/org/apache/cxf/io/CachedWriter.java
index 66c9df8..8b0fc43 100644
--- a/core/src/main/java/org/apache/cxf/io/CachedWriter.java
+++ b/core/src/main/java/org/apache/cxf/io/CachedWriter.java
@@ -53,9 +53,9 @@ public class CachedWriter extends Writer {
     private static int defaultThreshold;
     private static long defaultMaxSize;
     private static String defaultCipherTransformation;
-    
+
     static {
-        
+
         String s = SystemPropertyAction.getPropertyOrNull("org.apache.cxf.io.CachedOutputStream.OutputDirectory");
         if (s == null) {
             // lookup the deprecated property
@@ -96,10 +96,10 @@ public class CachedWriter extends Writer {
     private CipherPair ciphers;
 
     private List<CachedWriterCallback> callbacks;
-    
+
     private List<Object> streamList = new ArrayList<>();
 
-    
+
     static class LoadingCharArrayWriter extends CharArrayWriter {
         LoadingCharArrayWriter() {
             super(1024);
@@ -108,7 +108,7 @@ public class CachedWriter extends Writer {
             return super.buf;
         }
     }
-    
+
 
     public CachedWriter() {
         this(defaultThreshold);
@@ -152,14 +152,14 @@ public class CachedWriter extends Writer {
     public void releaseTempFileHold() {
         allowDeleteOfFile = true;
     }
-    
+
     public void registerCallback(CachedWriterCallback cb) {
         if (null == callbacks) {
             callbacks = new ArrayList<>();
         }
         callbacks.add(cb);
     }
-    
+
     public void deregisterCallback(CachedWriterCallback cb) {
         if (null != callbacks) {
             callbacks.remove(cb);
@@ -175,14 +175,14 @@ public class CachedWriter extends Writer {
      * output stream ... etc.)
      */
     protected void doFlush() throws IOException {
-        
+
     }
 
     public void flush() throws IOException {
         if (!cosClosed) {
             currentStream.flush();
         }
-        
+
         if (null != callbacks) {
             for (CachedWriterCallback cb : callbacks) {
                 cb.onFlush(this);
@@ -195,14 +195,14 @@ public class CachedWriter extends Writer {
      * Perform any actions required on stream closure (handle response etc.)
      */
     protected void doClose() throws IOException {
-        
+
     }
-    
+
     /**
      * Perform any actions required after stream closure (close the other related stream etc.)
      */
     protected void postClose() throws IOException {
-        
+
     }
 
     /**
@@ -224,7 +224,7 @@ public class CachedWriter extends Writer {
         doClose();
         streamList.remove(currentStream);
     }
-    
+
     public void close() throws IOException {
         if (!cosClosed) {
             currentStream.flush();
@@ -257,7 +257,7 @@ public class CachedWriter extends Writer {
      * When with Attachment, needs to replace the xml writer stream with the stream used by
      * AttachmentSerializer or copy the cached output stream to the "real"
      * output stream, i.e. onto the wire.
-     * 
+     *
      * @param out the new output stream
      * @param copyOldContent flag indicating if the old content should be copied
      * @throws IOException
@@ -345,7 +345,7 @@ public class CachedWriter extends Writer {
             }
         }
     }
-    
+
     public void writeCacheTo(StringBuilder out, long limit) throws IOException {
         flush();
         if (totalLength < limit
@@ -383,7 +383,7 @@ public class CachedWriter extends Writer {
             }
         }
     }
-    
+
     public void writeCacheTo(StringBuilder out) throws IOException {
         flush();
         if (inmem) {
@@ -440,10 +440,10 @@ public class CachedWriter extends Writer {
         }
         if (inmem && totalLength > threshold && currentStream instanceof LoadingCharArrayWriter) {
             createFileOutputStream();
-        }       
+        }
     }
 
-    
+
     public void write(char[] cbuf, int off, int len) throws IOException {
         if (!outputLocked) {
             onWrite();
@@ -524,7 +524,7 @@ public class CachedWriter extends Writer {
             }
         }
     }
-    
+
     private synchronized void deleteTempFile() {
         if (tempFile != null) {
             File file = tempFile;
@@ -563,7 +563,7 @@ public class CachedWriter extends Writer {
     public void setCipherTransformation(String cipherTransformation) {
         this.cipherTransformation = cipherTransformation;
     }
-    
+
     public static void setDefaultMaxSize(long l) {
         if (l == -1) {
             String s = System.getProperty("org.apache.cxf.io.CachedOutputStream.MaxSize");
@@ -588,7 +588,7 @@ public class CachedWriter extends Writer {
             }
         }
         defaultThreshold = i;
-        
+
     }
 
     public static void setDefaultCipherTransformation(String n) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/io/CipherPair.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/io/CipherPair.java b/core/src/main/java/org/apache/cxf/io/CipherPair.java
index 8237221..525c1fe 100644
--- a/core/src/main/java/org/apache/cxf/io/CipherPair.java
+++ b/core/src/main/java/org/apache/cxf/io/CipherPair.java
@@ -35,10 +35,10 @@ public class CipherPair {
     private Cipher enccipher;
     private Key key;
     private byte[] ivp;
-    
+
     public CipherPair(String transformation) throws GeneralSecurityException {
         this.transformation = transformation;
-        
+
         int d = transformation.indexOf('/');
         String a;
         if (d > 0) {
@@ -58,15 +58,15 @@ public class CipherPair {
             throw e;
         }
     }
-    
+
     public String getTransformation() {
         return transformation;
     }
-    
+
     public Cipher getEncryptor() {
         return enccipher;
     }
-    
+
     public Cipher getDecryptor() {
         Cipher deccipher = null;
         try {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/io/CopyingOutputStream.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/io/CopyingOutputStream.java b/core/src/main/java/org/apache/cxf/io/CopyingOutputStream.java
index 9625187..d9a1c46 100644
--- a/core/src/main/java/org/apache/cxf/io/CopyingOutputStream.java
+++ b/core/src/main/java/org/apache/cxf/io/CopyingOutputStream.java
@@ -23,7 +23,7 @@ import java.io.IOException;
 import java.io.InputStream;
 
 /**
- * Marker interface for OutputStreams that can directly support 
+ * Marker interface for OutputStreams that can directly support
  * copying from an input stream.  OutputStreams that maintain their
  * own byte buffer or similar may be able to optimize the copy
  * instead of using the read/write into a temporary buffer that
@@ -32,5 +32,5 @@ import java.io.InputStream;
 public interface CopyingOutputStream {
 
     int copyFrom(InputStream in) throws IOException;
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/io/DelegatingInputStream.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/io/DelegatingInputStream.java b/core/src/main/java/org/apache/cxf/io/DelegatingInputStream.java
index 92b5e0d..331a714 100644
--- a/core/src/main/java/org/apache/cxf/io/DelegatingInputStream.java
+++ b/core/src/main/java/org/apache/cxf/io/DelegatingInputStream.java
@@ -28,7 +28,7 @@ import org.apache.cxf.helpers.IOUtils;
 
 public class DelegatingInputStream extends FilterInputStream {
     protected boolean cached;
-    
+
     public DelegatingInputStream(InputStream is) {
         super(is);
     }
@@ -40,7 +40,7 @@ public class DelegatingInputStream extends FilterInputStream {
     public InputStream getInputStream() {
         return in;
     }
-    
+
     /**
      * Read the entire original input stream and cache it.  Useful
      * if switching threads or doing something where the original
@@ -65,5 +65,5 @@ public class DelegatingInputStream extends FilterInputStream {
             cached = true;
         }
     }
-    
+
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/io/WriteOnCloseOutputStream.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/io/WriteOnCloseOutputStream.java b/core/src/main/java/org/apache/cxf/io/WriteOnCloseOutputStream.java
index c746bd7..2d5d168 100644
--- a/core/src/main/java/org/apache/cxf/io/WriteOnCloseOutputStream.java
+++ b/core/src/main/java/org/apache/cxf/io/WriteOnCloseOutputStream.java
@@ -30,16 +30,16 @@ import java.io.OutputStream;
 public class WriteOnCloseOutputStream extends CachedOutputStream {
 
     OutputStream flowThroughStream;
-    
+
     public WriteOnCloseOutputStream(OutputStream stream) {
         super();
         flowThroughStream = stream;
     }
 
-    
+
     protected void doClose() throws IOException {
         resetOut(flowThroughStream, true);
         flowThroughStream.flush();
-    }    
-    
+    }
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/logging/FaultListener.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/logging/FaultListener.java b/core/src/main/java/org/apache/cxf/logging/FaultListener.java
index d536fd5..528ecb2 100644
--- a/core/src/main/java/org/apache/cxf/logging/FaultListener.java
+++ b/core/src/main/java/org/apache/cxf/logging/FaultListener.java
@@ -38,7 +38,7 @@ public interface FaultListener {
      * the exception occurred.
      * @param message the message processed while the exception occurred.
      * @return <code>true</code> if CXF should use default handling for this
-     * exception which normally is just logging the exception, <code>false</code> 
+     * exception which normally is just logging the exception, <code>false</code>
      * if CXF not should do any logging.
      */
     boolean faultOccurred(Exception exception, String description, Message message);

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/management/InstrumentationManager.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/management/InstrumentationManager.java b/core/src/main/java/org/apache/cxf/management/InstrumentationManager.java
index 111a6e6..d03acb7 100644
--- a/core/src/main/java/org/apache/cxf/management/InstrumentationManager.java
+++ b/core/src/main/java/org/apache/cxf/management/InstrumentationManager.java
@@ -23,8 +23,8 @@ import javax.management.JMException;
 import javax.management.MBeanServer;
 import javax.management.ObjectName;
 
-/** 
- *  InstrumentationManager interface for the instrumentations query, register 
+/**
+ *  InstrumentationManager interface for the instrumentations query, register
  *  and unregister
  */
 public interface InstrumentationManager {
@@ -35,7 +35,7 @@ public interface InstrumentationManager {
      * @throws JMException
      */
     ObjectName register(ManagedComponent component) throws JMException;
-    
+
     /**
      * Register a component with management infrastructure. Component will supply registration name.
      * @param component
@@ -46,16 +46,16 @@ public interface InstrumentationManager {
     ObjectName register(ManagedComponent component, boolean forceRegistration) throws JMException;
 
     /**
-     * Registers object with management infrastructure with a specific name. Object must be annotated or 
+     * Registers object with management infrastructure with a specific name. Object must be annotated or
      * implement standard MBean interface.
      * @param obj
      * @param name
      * @throws JMException
      */
     void register(Object obj, ObjectName name) throws JMException;
-    
+
     /**
-     * Registers object with management infrastructure with a specific name. Object must be annotated or 
+     * Registers object with management infrastructure with a specific name. Object must be annotated or
      * implement standard MBean interface.
      * @param obj
      * @param name
@@ -63,14 +63,14 @@ public interface InstrumentationManager {
      * @throws JMException
      */
     void register(Object obj, ObjectName name, boolean forceRegistration) throws JMException;
-    
+
     /**
      * Unregisters component with management infrastructure
      * @param component
      * @throws JMException
      */
     void unregister(ManagedComponent component) throws JMException;
-    
+
     /**
      * Unregisters component based upon registered name
      * @param name
@@ -82,16 +82,16 @@ public interface InstrumentationManager {
      * Cleans up and shutsdown management infrastructure.
      */
     void shutdown();
-    
+
     /**
      * Get the MBeanServer which hosts managed components
      * NOTE: if the configuration is not set the JMXEnabled to be true, this method
      * will return null
-     * @return the MBeanServer 
+     * @return the MBeanServer
      */
     MBeanServer getMBeanServer();
 
     String getPersistentBusId();
-    
+
     void setPersistentBusId(String id);
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/management/ManagedComponent.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/management/ManagedComponent.java b/core/src/main/java/org/apache/cxf/management/ManagedComponent.java
index 5836ea6..4f3bfd8 100644
--- a/core/src/main/java/org/apache/cxf/management/ManagedComponent.java
+++ b/core/src/main/java/org/apache/cxf/management/ManagedComponent.java
@@ -23,10 +23,10 @@ import javax.management.JMException;
 import javax.management.ObjectName;
 /**
  * Basic interface for representing a Instrumented object.
- * 
+ *
  */
 public interface ManagedComponent {
-    
+
     ObjectName getObjectName() throws JMException;
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/management/ManagementConstants.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/management/ManagementConstants.java b/core/src/main/java/org/apache/cxf/management/ManagementConstants.java
index c753e14..e10bf78 100644
--- a/core/src/main/java/org/apache/cxf/management/ManagementConstants.java
+++ b/core/src/main/java/org/apache/cxf/management/ManagementConstants.java
@@ -20,7 +20,7 @@
 package org.apache.cxf.management;
 
 public final class ManagementConstants {
-    
+
     public static final String DEFAULT_DOMAIN_NAME = "org.apache.cxf";
     public static final String BUS_ID_PROP = "bus.id";
     public static final String NAME_PROP = "name";
@@ -30,8 +30,8 @@ public final class ManagementConstants {
     public static final String OPERATION_NAME_PROP = "operation";
     public static final String PORT_NAME_PROP = "port";
     public static final String INSTANCE_ID_PROP = "instance.id";
-    
+
     private ManagementConstants() {
-        
+
     }
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/management/annotation/ManagedResource.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/management/annotation/ManagedResource.java b/core/src/main/java/org/apache/cxf/management/annotation/ManagedResource.java
index dd89d54..902eb71 100644
--- a/core/src/main/java/org/apache/cxf/management/annotation/ManagedResource.java
+++ b/core/src/main/java/org/apache/cxf/management/annotation/ManagedResource.java
@@ -47,6 +47,6 @@ public @interface ManagedResource {
 
     String persistName() default "";
 
-    String persistLocation() default "";        
+    String persistLocation() default "";
 
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/message/AbstractWrappedMessage.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/message/AbstractWrappedMessage.java b/core/src/main/java/org/apache/cxf/message/AbstractWrappedMessage.java
index 094e432..0312c09 100644
--- a/core/src/main/java/org/apache/cxf/message/AbstractWrappedMessage.java
+++ b/core/src/main/java/org/apache/cxf/message/AbstractWrappedMessage.java
@@ -30,7 +30,7 @@ import org.apache.cxf.transport.Destination;
  * A base class to build your own message implementations on.
  */
 public abstract class AbstractWrappedMessage implements Message {
-    
+
     private Message message;
 
     protected AbstractWrappedMessage(Message msg) {
@@ -76,7 +76,7 @@ public abstract class AbstractWrappedMessage implements Message {
     public void setMessage(Message message) {
         this.message = message;
     }
-    
+
     public Destination getDestination() {
         return message.getDestination();
     }
@@ -96,7 +96,7 @@ public abstract class AbstractWrappedMessage implements Message {
     public void setId(String id) {
         message.setId(id);
     }
-    
+
     public InterceptorChain getInterceptorChain() {
         return message.getInterceptorChain();
     }
@@ -150,7 +150,7 @@ public abstract class AbstractWrappedMessage implements Message {
     public Collection<Object> values() {
         return message.values();
     }
-    
+
     public <T> T get(Class<T> key) {
         return message.get(key);
     }
@@ -163,7 +163,7 @@ public abstract class AbstractWrappedMessage implements Message {
 
     public Object getContextualProperty(String key) {
         return message.getContextualProperty(key);
-    }  
+    }
     void setContextualProperty(String key, Object v) {
         if (message instanceof MessageImpl) {
             ((MessageImpl)message).setContextualProperty(key, v);
@@ -172,9 +172,9 @@ public abstract class AbstractWrappedMessage implements Message {
         } else {
             //cannot set directly.  Just invalidate the cache.
             message.resetContextCache();
-        }        
+        }
     }
-    
+
     public Set<String> getContextualPropertyKeys() {
         return message.getContextualPropertyKeys();
     }
@@ -182,5 +182,5 @@ public abstract class AbstractWrappedMessage implements Message {
     public void resetContextCache() {
         message.resetContextCache();
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/message/Attachment.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/message/Attachment.java b/core/src/main/java/org/apache/cxf/message/Attachment.java
index e163382..e86e67c 100644
--- a/core/src/main/java/org/apache/cxf/message/Attachment.java
+++ b/core/src/main/java/org/apache/cxf/message/Attachment.java
@@ -30,16 +30,16 @@ public interface Attachment {
      * @return The attachment id.
      */
     String getId();
-    
+
     String getHeader(String name);
-    
+
     Iterator<String> getHeaderNames();
-    
+
     /**
-     * Whether or not this is an XOP package. This will affect the 
+     * Whether or not this is an XOP package. This will affect the
      * serialization of the attachment. If true, it will be serialized
      * as binary data, and not Base64Binary.
-     * 
+     *
      * @return true if this attachment is an XOP package
      */
     boolean isXOP();

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/message/Exchange.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/message/Exchange.java b/core/src/main/java/org/apache/cxf/message/Exchange.java
index 593d5e4..7fdd9f5 100644
--- a/core/src/main/java/org/apache/cxf/message/Exchange.java
+++ b/core/src/main/java/org/apache/cxf/message/Exchange.java
@@ -29,42 +29,42 @@ import org.apache.cxf.transport.Destination;
 import org.apache.cxf.transport.Session;
 
 public interface Exchange extends StringMap {
-    
+
     /**
-     * Returns the inbound message for the exchange. On the client-side, this 
+     * Returns the inbound message for the exchange. On the client-side, this
      * is the response. On the server-side, this is the request.
-     * 
+     *
      * @return the inboubnd message
      */
     Message getInMessage();
     void setInMessage(Message m);
-    
+
     /**
-     * Returns the outbound message for the exchange. On the client-side, this 
-     * is the request. On the server-side, this is the response. During the 
+     * Returns the outbound message for the exchange. On the client-side, this
+     * is the request. On the server-side, this is the response. During the
      * inbound message processing, the outbound message is null.
-     * 
+     *
      * @return the outbound message
      */
     Message getOutMessage();
     void setOutMessage(Message m);
-    
+
     Message getInFaultMessage();
     void setInFaultMessage(Message m);
 
     Message getOutFaultMessage();
     void setOutFaultMessage(Message m);
-    
+
     Session getSession();
-    
+
     /**
      * @return the associated incoming Destination (may be anonymous)
      */
     Destination getDestination();
-    
+
     /**
      * @param destination the associated incoming Destination
-     */    
+     */
     void setDestination(Destination destination);
 
     /**
@@ -74,42 +74,42 @@ public interface Exchange extends StringMap {
     Conduit getConduit(Message message);
 
     /**
-     * @param conduit the associated outgoing Conduit 
+     * @param conduit the associated outgoing Conduit
      */
     void setConduit(Conduit conduit);
-    
+
     /**
      * Determines if the exchange is one-way.
-     * 
+     *
      * @return true if the exchange is known to be a one-way exchange
      */
     boolean isOneWay();
-    
+
     /**
-     * Determines if the exchange requires the frontend to wait for a 
-     * response. Transports can then optimize themselves to process the 
+     * Determines if the exchange requires the frontend to wait for a
+     * response. Transports can then optimize themselves to process the
      * response immediately instead of using a background thread or similar.
-     * 
+     *
      * @return true if the frontend will wait for the response
      */
     boolean isSynchronous();
     void setSynchronous(boolean b);
 
     /**
-     * 
+     *
      * @param b true if the exchange is known to be a one-way exchange
      */
     void setOneWay(boolean b);
-    
+
     /**
      * {@inheritDoc}
      */
     void clear();
-    
+
     Bus getBus();
     Service getService();
     Endpoint getEndpoint();
     Binding getBinding();
     BindingOperationInfo getBindingOperationInfo();
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/message/ExchangeImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/message/ExchangeImpl.java b/core/src/main/java/org/apache/cxf/message/ExchangeImpl.java
index 4798827..618667e 100644
--- a/core/src/main/java/org/apache/cxf/message/ExchangeImpl.java
+++ b/core/src/main/java/org/apache/cxf/message/ExchangeImpl.java
@@ -38,19 +38,19 @@ import org.apache.cxf.transport.Destination;
 import org.apache.cxf.transport.Session;
 
 public class ExchangeImpl extends ConcurrentHashMap<String, Object>  implements Exchange {
-    
+
     private static final long serialVersionUID = -3112077559217623594L;
     private Destination destination;
     private boolean oneWay;
     private boolean synchronous = true;
-    
+
     private Message inMessage;
     private Message outMessage;
     private Message inFaultMessage;
     private Message outFaultMessage;
-    
+
     private Session session;
-    
+
     private Bus bus;
     private Endpoint endpoint;
     private Service service;
@@ -90,10 +90,10 @@ public class ExchangeImpl extends ConcurrentHashMap<String, Object>  implements
             outFaultMessage.resetContextCache();
         }
     }
-    
+
     public <T> T get(Class<T> key) {
         T t = key.cast(get(key.getName()));
-        
+
         if (t == null) {
             if (key == Bus.class) {
                 t = key.cast(bus);
@@ -147,7 +147,7 @@ public class ExchangeImpl extends ConcurrentHashMap<String, Object>  implements
             super.put(key.getName(), value);
         }
     }
-    
+
     public Object put(String key, Object value) {
         setMessageContextProperty(inMessage, key, value);
         setMessageContextProperty(outMessage, key, value);
@@ -176,7 +176,7 @@ public class ExchangeImpl extends ConcurrentHashMap<String, Object>  implements
             m.resetContextCache();
         }
     }
-    
+
     public Destination getDestination() {
         return destination;
     }
@@ -247,7 +247,7 @@ public class ExchangeImpl extends ConcurrentHashMap<String, Object>  implements
     public void setOneWay(boolean b) {
         oneWay = b;
     }
-    
+
     public boolean isSynchronous() {
         return synchronous;
     }
@@ -263,7 +263,7 @@ public class ExchangeImpl extends ConcurrentHashMap<String, Object>  implements
     public void setSession(Session session) {
         this.session = session;
     }
-    
+
     public void clear() {
         super.clear();
         resetContextCaches();

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/message/FaultMode.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/message/FaultMode.java b/core/src/main/java/org/apache/cxf/message/FaultMode.java
index eef678f..2dfe2fe 100644
--- a/core/src/main/java/org/apache/cxf/message/FaultMode.java
+++ b/core/src/main/java/org/apache/cxf/message/FaultMode.java
@@ -20,13 +20,13 @@
 package org.apache.cxf.message;
 
 /**
- * 
+ *
  */
 public enum FaultMode {
-    
+
     RUNTIME_FAULT,
     LOGICAL_RUNTIME_FAULT,
     CHECKED_APPLICATION_FAULT,
     UNCHECKED_APPLICATION_FAULT,
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/message/Message.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/message/Message.java b/core/src/main/java/org/apache/cxf/message/Message.java
index a3d0251..ed7be5b 100644
--- a/core/src/main/java/org/apache/cxf/message/Message.java
+++ b/core/src/main/java/org/apache/cxf/message/Message.java
@@ -26,13 +26,13 @@ import org.apache.cxf.interceptor.InterceptorChain;
 import org.apache.cxf.transport.Destination;
 
 /**
- * The base interface for all all message implementations. 
+ * The base interface for all all message implementations.
  * All message objects passed to interceptors use this interface.
  */
 public interface Message extends StringMap {
-    
+
     String TRANSPORT = "org.apache.cxf.transport";
-    
+
     /*
      * Boolean property which can be used to check that the current request
      * is part of the SOAP (JAX-WS) or non-SOAP/REST (JAX-RS) execution context.
@@ -48,32 +48,32 @@ public interface Message extends StringMap {
      * Boolean property specifying if the message is inbound.
      */
     String INBOUND_MESSAGE = "org.apache.cxf.message.inbound";
-    
+
     /**
-     * A Map keyed by a string that stores optional context information 
+     * A Map keyed by a string that stores optional context information
      * associated with the invocation that spawned the message.
      */
     String INVOCATION_CONTEXT = "org.apache.cxf.invocation.context";
-    
+
     /**
      *  Current Service Object
      */
     String SERVICE_OBJECT = "org.apache.cxf.service.object";
-    
+
     /**
      * A Map containing the MIME headers for a SOAP message.
      */
     String MIME_HEADERS = "org.apache.cxf.mime.headers";
-    
+
     /**
-     * Boolean property specifying if the server should send the response 
+     * Boolean property specifying if the server should send the response
      * asynchronously.
      */
     String ASYNC_POST_RESPONSE_DISPATCH =
         "org.apache.cxf.async.post.response.dispatch";
 
     /**
-     * Boolean property specifying if this message arrived via a 
+     * Boolean property specifying if this message arrived via a
      * decoupled endpoint.
      */
     String DECOUPLED_CHANNEL_MESSAGE = "decoupled.channel.message";
@@ -85,20 +85,20 @@ public interface Message extends StringMap {
      * Boolean property specifying if oneWay response must be processed.
      */
     String PROCESS_ONEWAY_RESPONSE = "org.apache.cxf.transport.processOneWayResponse";
-    
+
     /**
-     * Boolean property specifying if the thread which runs a request is 
+     * Boolean property specifying if the thread which runs a request is
      * different to the thread which created this Message.
      */
     String THREAD_CONTEXT_SWITCHED = "thread.context.switched";
-    
-    
+
+
     String ROBUST_ONEWAY = "org.apache.cxf.oneway.robust";
-    
+
     String HTTP_REQUEST_METHOD = "org.apache.cxf.request.method";
     String REQUEST_URI = "org.apache.cxf.request.uri";
     String REQUEST_URL = "org.apache.cxf.request.url";
-    
+
     String PROTOCOL_HEADERS = Message.class.getName() + ".PROTOCOL_HEADERS";
     String RESPONSE_CODE = Message.class.getName() + ".RESPONSE_CODE";
     String ERROR_MESSAGE = Message.class.getName() + ".ERROR_MESSAGE";
@@ -108,41 +108,41 @@ public interface Message extends StringMap {
 
     String PROPOGATE_EXCEPTION = Message.class.getName() + ".PROPOGATE_EXCEPTION";
     /**
-     * Boolean property specifying in the runtime is configured to process 
+     * Boolean property specifying in the runtime is configured to process
      * MTOM attachments.
      */
     String MTOM_ENABLED = "mtom-enabled";
     String MTOM_THRESHOLD = "mtom-threshold";
-        
+
     /**
      * Runtime schema validation property
      */
     String SCHEMA_VALIDATION_ENABLED = "schema-validation-enabled";
-    
+
     /**
      * The default values for schema validation will be set in the service model using this property
      */
     String SCHEMA_VALIDATION_TYPE = "schema-validation-type";
-     
+
     /**
-     * Boolean property specifying if the Java stack trace is returned as a  
+     * Boolean property specifying if the Java stack trace is returned as a
      * SOAP fault message.
      */
     String FAULT_STACKTRACE_ENABLED = "faultStackTraceEnabled";
     /**
-     * Boolean property specifying if the name of the exception that caused 
+     * Boolean property specifying if the name of the exception that caused
      * the Java stack trace is returned.
      */
     String EXCEPTION_MESSAGE_CAUSE_ENABLED = "exceptionMessageCauseEnabled";
-    
+
     /**
-     * A very unique delimiter used for exception with FAULT_STACKTRACE_ENABLED enable, 
-     * which is easy for client to differentiate the cause and stacktrace when unmarsall 
-     * a fault message 
+     * A very unique delimiter used for exception with FAULT_STACKTRACE_ENABLED enable,
+     * which is easy for client to differentiate the cause and stacktrace when unmarsall
+     * a fault message
      */
     String EXCEPTION_CAUSE_SUFFIX = "#*#";
 
-    String CONTENT_TYPE = "Content-Type";    
+    String CONTENT_TYPE = "Content-Type";
     String ACCEPT_CONTENT_TYPE = "Accept";
     String BASE_PATH = Message.class.getName() + ".BASE_PATH";
     String ENCODING = Message.class.getName() + ".ENCODING";
@@ -158,7 +158,7 @@ public interface Message extends StringMap {
 
     /**
      * Some properties to allow adding interceptors to the chain
-     * on a per-request basis.  All are a Collection<Interceptor> 
+     * on a per-request basis.  All are a Collection<Interceptor>
      * These are NOT contextual properties (ie: not searched outside the message).
      * They must exist on the message itself at time of Chain creation
      */
@@ -167,30 +167,30 @@ public interface Message extends StringMap {
     String FAULT_IN_INTERCEPTORS = Message.class.getName() + ".FAULT_IN_INTERCEPTORS";
     String FAULT_OUT_INTERCEPTORS = Message.class.getName() + ".FAULT_OUT_INTERCEPTORS";
     /**
-     * As above, but Collection<InterceptorProvider> 
+     * As above, but Collection<InterceptorProvider>
      */
     String INTERCEPTOR_PROVIDERS = Message.class.getName() + ".INTERCEPTOR_PROVIDER";
-    
+
     /**
      * Content-Transfer-Encoding used for MTOM attachment
      * binary, base64, etc
      */
     String CONTENT_TRANSFER_ENCODING = Message.class.getName() + ".CONTENT_TRANSFER_ENCODING";
-    
+
     /*
      * The properties to allow configure the client timeout
      */
     String CONNECTION_TIMEOUT = "javax.xml.ws.client.connectionTimeout";
     String RECEIVE_TIMEOUT = "javax.xml.ws.client.receiveTimeout";
-    
+
     String getId();
     void setId(String id);
-    
+
     /**
-     * Returns a live copy of the messages interceptor chain. This is 
-     * useful when an interceptor wants to modify the interceptor chain on the 
+     * Returns a live copy of the messages interceptor chain. This is
+     * useful when an interceptor wants to modify the interceptor chain on the
      * fly.
-     * 
+     *
      * @return the interceptor chain used to process the message
      */
     InterceptorChain getInterceptorChain();
@@ -200,67 +200,67 @@ public interface Message extends StringMap {
      * @return the associated Destination if message is inbound, null otherwise
      */
     Destination getDestination();
-    
+
     Exchange getExchange();
 
     void setExchange(Exchange exchange);
-    
+
     /**
      * Retrieve any binary attachments associated with the message.
-     *  
+     *
      * @return a collection containing the attachments
      */
     Collection<Attachment> getAttachments();
 
     void setAttachments(Collection<Attachment> attachments);
-    
+
     /**
-     * Retrieve the encapsulated content as a particular type. The content is 
-     * available as a result type if the message is outbound. The content 
-     * is available as a source type if message is inbound. If the content is 
+     * Retrieve the encapsulated content as a particular type. The content is
+     * available as a result type if the message is outbound. The content
+     * is available as a source type if message is inbound. If the content is
      * not available as the specified type null is returned.
-     * 
-     * @param format the expected content format 
+     *
+     * @param format the expected content format
      * @return the encapsulated content
-     */    
+     */
     <T> T getContent(Class<T> format);
 
     /**
      * Provide the encapsulated content as a particular type (a result type
      * if message is outbound, a source type if message is inbound)
-     * 
-     * @param format the provided content format 
+     *
+     * @param format the provided content format
      * @param content the content to be encapsulated
-     */    
+     */
     <T> void setContent(Class<T> format, Object content);
-    
+
     /**
      * @return the set of currently encapsulated content formats
      */
     Set<Class<?>> getContentFormats();
-    
+
     /**
      * Removes a content from a message.  If some contents are completely consumed,
      * removing them is a good idea
      * @param format the format to remove
      */
     <T> void removeContent(Class<T> format);
-    
+
     /**
      * Queries the Message object's metadata for a specific property.
-     * 
-     * @param key the Message interface's property strings that 
-     * correlates to the desired property 
+     *
+     * @param key the Message interface's property strings that
+     * correlates to the desired property
      * @return the property's value
      */
-    Object getContextualProperty(String key);   
-    
+    Object getContextualProperty(String key);
+
     /**
      * Resets the cache of contextual properties that messages may contain.  Subsequent
      * calls to getContextualProperty will likely recalculate the cache.
      */
     void resetContextCache();
-    
+
     /**
      * @return set of defined contextual property keys
      */

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/message/MessageContentsList.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/message/MessageContentsList.java b/core/src/main/java/org/apache/cxf/message/MessageContentsList.java
index a61cc66..a1f4d1a 100644
--- a/core/src/main/java/org/apache/cxf/message/MessageContentsList.java
+++ b/core/src/main/java/org/apache/cxf/message/MessageContentsList.java
@@ -39,7 +39,7 @@ public class MessageContentsList extends ArrayList<Object> {
     public MessageContentsList(List<?> values) {
         super(values);
     }
-    
+
     public static MessageContentsList getContentsList(Message msg) {
         List<Object> o = CastUtils.cast(msg.getContent(List.class));
         if (o == null) {
@@ -52,30 +52,30 @@ public class MessageContentsList extends ArrayList<Object> {
         }
         return (MessageContentsList)o;
     }
-    
+
     public Object set(int idx, Object value) {
         ensureSize(idx);
         return super.set(idx, value);
     }
-    
+
     private void ensureSize(int idx) {
         while (idx >= size()) {
             add(REMOVED_MARKER);
         }
     }
-    
+
     public Object put(MessagePartInfo key, Object value) {
         ensureSize(key.getIndex());
         return super.set(key.getIndex(), value);
     }
-    
+
     public boolean hasValue(MessagePartInfo key) {
         if (key.getIndex() >= size()) {
             return false;
         }
         return super.get(key.getIndex()) != REMOVED_MARKER;
     }
-    
+
     public Object get(MessagePartInfo key) {
         Object o = super.get(key.getIndex());
         return o == REMOVED_MARKER ? null : o;

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/message/MessageImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/message/MessageImpl.java b/core/src/main/java/org/apache/cxf/message/MessageImpl.java
index b08b0c5..1b3691b 100644
--- a/core/src/main/java/org/apache/cxf/message/MessageImpl.java
+++ b/core/src/main/java/org/apache/cxf/message/MessageImpl.java
@@ -35,19 +35,19 @@ import org.apache.cxf.transport.Destination;
 
 public class MessageImpl extends StringMapImpl implements Message {
     private static final long serialVersionUID = -3020763696429459865L;
-    
-    
+
+
     private Exchange exchange;
     private String id;
     private InterceptorChain interceptorChain;
-    
-    // array of Class<T>/T pairs for contents 
+
+    // array of Class<T>/T pairs for contents
     private Object[] contents = new Object[20];
     private int index;
-    
+
     private Map<String, Object> contextCache;
-    
-    
+
+
     public MessageImpl() {
         //nothing
     }
@@ -65,7 +65,7 @@ public class MessageImpl extends StringMapImpl implements Message {
             throw new RuntimeException("Not a MessageImpl! " + m.getClass());
         }
     }
-    
+
     public Collection<Attachment> getAttachments() {
         return CastUtils.cast((Collection<?>)get(ATTACHMENTS));
     }
@@ -78,7 +78,7 @@ public class MessageImpl extends StringMapImpl implements Message {
         //for sub class overriding
         return null;
     }
-    
+
     public Destination getDestination() {
         return get(Destination.class);
     }
@@ -113,7 +113,7 @@ public class MessageImpl extends StringMapImpl implements Message {
             }
         }
         if (index >= contents.length) {
-            //very unlikely to happen.   Haven't seen more than about 6, 
+            //very unlikely to happen.   Haven't seen more than about 6,
             //but just in case we'll add a few more
             Object tmp[] = new Object[contents.length + 10];
             System.arraycopy(contents, 0, tmp, 0, contents.length);
@@ -123,7 +123,7 @@ public class MessageImpl extends StringMapImpl implements Message {
         contents[index + 1] = content;
         index += 2;
     }
-    
+
     public <T> void removeContent(Class<T> format) {
         for (int x = 0; x < index; x += 2) {
             if (contents[x] == format) {
@@ -140,7 +140,7 @@ public class MessageImpl extends StringMapImpl implements Message {
     }
 
     public Set<Class<?>> getContentFormats() {
-        
+
         Set<Class<?>> c = new HashSet<Class<?>>();
         for (int x = 0; x < index; x += 2) {
             c.add((Class<?>)contents[x]);
@@ -178,7 +178,7 @@ public class MessageImpl extends StringMapImpl implements Message {
     public Set<String> getContextualPropertyKeys() {
         return contextCache.keySet();
     }
-    
+
     private void calcContextCache() {
         Map<String, Object> o = new HashMap<String, Object>() {
             private static final long serialVersionUID = 7067290677790419348L;
@@ -195,11 +195,11 @@ public class MessageImpl extends StringMapImpl implements Message {
             if (b != null) {
                 o.putAll(b.getProperties());
             }
-            Service sv = ex.getService(); 
+            Service sv = ex.getService();
             if (sv != null) {
                 o.putAll(sv);
             }
-            Endpoint ep = ex.getEndpoint(); 
+            Endpoint ep = ex.getEndpoint();
             if (ep != null) {
                 EndpointInfo ei = ep.getEndpointInfo();
                 if (ei != null) {