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

[45/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/common/util/Base64OutputStream.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/Base64OutputStream.java b/core/src/main/java/org/apache/cxf/common/util/Base64OutputStream.java
index 61724d8..3b28ec5 100644
--- a/core/src/main/java/org/apache/cxf/common/util/Base64OutputStream.java
+++ b/core/src/main/java/org/apache/cxf/common/util/Base64OutputStream.java
@@ -37,12 +37,12 @@ public class Base64OutputStream extends FilterOutputStream {
         byte[] bytes = ByteBuffer.allocate(Integer.SIZE / 8).putInt(value).array();
         write(bytes, 0, bytes.length);
     }
-    
+
     @Override
     public void write(byte b[], int off, int len) throws IOException {
         encodeAndWrite(b, off, len, false);
     }
-    
+
     private void encodeAndWrite(byte[] b, int off, int len, boolean finalWrite) throws IOException {
         byte[] theChunk = lastChunk;
         int lenToEncode = len;
@@ -53,16 +53,16 @@ public class Base64OutputStream extends FilterOutputStream {
         } else {
             theChunk = b;
         }
-        int rem = finalWrite ? 0 : lenToEncode % 3; 
+        int rem = finalWrite ? 0 : lenToEncode % 3;
         Base64Utility.encodeAndStream(theChunk, off, lenToEncode - rem, urlSafe, out);
-        
+
         if (rem > 0) {
             lastChunk = newArray(theChunk, lenToEncode - rem, rem);
         } else {
             lastChunk = null;
         }
     }
-    
+
     @Override
     public void flush() throws IOException {
         if (flushed || lastChunk == null) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/Base64UrlUtility.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/Base64UrlUtility.java b/core/src/main/java/org/apache/cxf/common/util/Base64UrlUtility.java
index cde9701..3436208 100644
--- a/core/src/main/java/org/apache/cxf/common/util/Base64UrlUtility.java
+++ b/core/src/main/java/org/apache/cxf/common/util/Base64UrlUtility.java
@@ -21,10 +21,10 @@ package org.apache.cxf.common.util;
 
 /**
  * Base64 URL Encoding/Decoding utility.
- *  
+ *
  * Character 62 ('+') is '-', Character 63 ('/') is '_';
- * Padding characters are dropped after the encoding.   
- *                  
+ * Padding characters are dropped after the encoding.
+ *
  */
 
 import java.io.IOException;
@@ -36,7 +36,7 @@ public final class Base64UrlUtility {
     private Base64UrlUtility() {
         //utility class, never constructed
     }
-    
+
     public static byte[] decode(String encoded) throws Base64Exception {
         return Base64Utility.decode(encoded, true);
     }
@@ -44,7 +44,7 @@ public final class Base64UrlUtility {
     public static String encode(String str) {
         return encode(str.getBytes(StandardCharsets.UTF_8));
     }
-    
+
     public static String encode(byte[] id) {
         return encodeChunk(id, 0, id.length);
     }
@@ -57,7 +57,7 @@ public final class Base64UrlUtility {
             return null;
         }
     }
-     
+
     public static void encodeAndStream(byte[] id,
                                        int o,
                                        int l,

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/Base64Utility.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/Base64Utility.java b/core/src/main/java/org/apache/cxf/common/util/Base64Utility.java
index d101b39..0096358 100644
--- a/core/src/main/java/org/apache/cxf/common/util/Base64Utility.java
+++ b/core/src/main/java/org/apache/cxf/common/util/Base64Utility.java
@@ -20,7 +20,7 @@
 package org.apache.cxf.common.util;
 
 /**
- * Base64Utility - this static class provides useful base64 
+ * Base64Utility - this static class provides useful base64
  *                 encoding utilities.
  */
 
@@ -46,45 +46,45 @@ import org.apache.cxf.common.logging.LogUtils;
  *    byte[]     into OutStream
  *    byte[]     into Writer
  * decode:
- *    char[]     into byte[] 
+ *    char[]     into byte[]
  *    String     into byte[]
  *    char[]     into OutStream
  *    String     into OutStream
- * 
+ *
  */
 public final class Base64Utility {
-    
+
     private static final Logger LOG = LogUtils.getL7dLogger(Base64Utility.class);
 
-    
+
     // base 64 character set
     //
     private static final char[] BCS = {
-        'A', 'B', 'C', 'D', 'E', 'F', 'G', 'H', 'I', 'J', 
-        'K', 'L', 'M', 'N', 'O', 'P', 'Q', 'R', 'S', 'T', 
-        'U', 'V', 'W', 'X', 'Y', 'Z', 'a', 'b', 'c', 'd', 
-        'e', 'f', 'g', 'h', 'i', 'j', 'k', 'l', 'm', 'n', 
-        'o', 'p', 'q', 'r', 's', 't', 'u', 'v', 'w', 'x', 
-        'y', 'z', '0', '1', '2', '3', '4', '5', '6', '7', 
+        'A', 'B', 'C', 'D', 'E', 'F', 'G', 'H', 'I', 'J',
+        'K', 'L', 'M', 'N', 'O', 'P', 'Q', 'R', 'S', 'T',
+        'U', 'V', 'W', 'X', 'Y', 'Z', 'a', 'b', 'c', 'd',
+        'e', 'f', 'g', 'h', 'i', 'j', 'k', 'l', 'm', 'n',
+        'o', 'p', 'q', 'r', 's', 't', 'u', 'v', 'w', 'x',
+        'y', 'z', '0', '1', '2', '3', '4', '5', '6', '7',
         '8', '9', '+', '/'
     };
 
     private static final char[] BCS_URL_SAFE = Arrays.copyOf(BCS, BCS.length);
-    
+
     // base 64 padding
     private static final char PAD = '=';
 
     // size of base 64 decode table
     private static final int BDTSIZE = 128;
 
-    // base 64 decode table  
+    // base 64 decode table
     private static final byte[] BDT = new byte[128];
 
-    
+
     private static final int PAD_SIZE0 = 1;
     private static final int PAD_SIZE4 = 2;
     private static final int PAD_SIZE8 = 3;
-    
+
     // class static initializer for building decode table
     static {
         for (int i = 0;  i < BDTSIZE;  i++) {
@@ -94,18 +94,18 @@ public final class Base64Utility {
         for (int i = 0;  i < BCS.length;  i++) {
             BDT[BCS[i]] = (byte)i;
         }
-        
+
         BCS_URL_SAFE[62] = '-';
         BCS_URL_SAFE[63] = '_';
     }
-    
-    
+
+
     private Base64Utility() {
         //utility class, never constructed
     }
-    
-    
-    
+
+
+
     /**
      * The <code>decode_chunk</code> routine decodes a chunk of data
      * into its native encoding.
@@ -115,21 +115,21 @@ public final class Base64Utility {
      * 24 bits which are then split into 4 x 6bit values. Each 6 bit
      * value is then used as an index into the 64 character table of
      * base64 chars. If the total data length is not a 3 octet multiple
-     * the '=' char is used as padding for the final 4 char group, 
+     * the '=' char is used as padding for the final 4 char group,
      * either 1 octet + '==' or 2 octets + '='.
      *
      * @param   id  The input data to be processed
      * @param   o   The offset from which to begin processing
      * @param   l   The length (bound) at which processing is to end
-     * @return  The decoded data   
+     * @return  The decoded data
      * @exception   Base64Exception Thrown is processing fails due to
-     * formatting exceptions in the encoded data 
+     * formatting exceptions in the encoded data
      */
     public static byte[] decodeChunk(char[] id,
                                      int o,
-                                     int l) 
+                                     int l)
         throws Base64Exception {
-        
+
         // Keep it simple - must be >= 4. Unpadded
         // base64 data contain < 3 octets is invalid.
         //
@@ -141,7 +141,7 @@ public final class Base64Utility {
         int ibcount = 0;
 
         // cryan. Calc the num of octets. Each 4 chars of base64 chars
-        // (representing 24 bits) encodes 3 octets. 
+        // (representing 24 bits) encodes 3 octets.
         //
         int octetCount = 3 * (l / 4);
 
@@ -161,7 +161,7 @@ public final class Base64Utility {
             if (id[i] == PAD
                 || id[i] < BDT.length
                 && BDT[id[i]] != Byte.MAX_VALUE) {
-                
+
                 ib[ibcount++] = id[i];
 
                 // Decode each 4 char sequence.
@@ -172,7 +172,7 @@ public final class Base64Utility {
                 }
             }
         }
-        
+
         if (obcount != ob.length) {
             byte []tmp = new byte[obcount];
             System.arraycopy(ob, 0, tmp, 0, obcount);
@@ -185,21 +185,21 @@ public final class Base64Utility {
     public static byte[] decode(String id) throws Base64Exception {
         return decode(id, false);
     }
-    
+
     public static byte[] decode(String id, boolean urlSafe) throws Base64Exception {
         if (urlSafe) {
             //TODO: optimize further
             id = id.replace("-", "+").replace('_', '/');
             switch (id.length() % 4) {
-            case 0: 
-                break; 
-            case 2: 
-                id += "=="; 
-                break; 
-            case 3: 
-                id += "="; 
-                break; 
-            default: 
+            case 0:
+                break;
+            case 2:
+                id += "==";
+                break;
+            case 3:
+                id += "=";
+                break;
+            default:
                 throw new Base64Exception(new Message("BASE64_RUNTIME_EXCEPTION", LOG));
             }
         }
@@ -215,7 +215,7 @@ public final class Base64Utility {
     public static void decode(char[] id,
                              int o,
                              int l,
-                             OutputStream ostream) 
+                             OutputStream ostream)
         throws Base64Exception {
 
         try {
@@ -227,9 +227,9 @@ public final class Base64Utility {
     }
 
     public static void decode(String id,
-                              OutputStream ostream) 
+                              OutputStream ostream)
         throws Base64Exception {
-        
+
         try {
             char[] cd = id.toCharArray();
             ostream.write(decodeChunk(cd, 0, cd.length));
@@ -246,7 +246,7 @@ public final class Base64Utility {
     public static String encode(byte[] id) {
         return encode(id, false);
     }
-    
+
     public static String encode(byte[] id, boolean urlSafe) {
         char[] cd = encodeChunk(id, 0, id.length);
         return new String(cd, 0, cd.length);
@@ -259,7 +259,7 @@ public final class Base64Utility {
                                      int l) {
         return encodeChunk(id, o, l, false);
     }
-    
+
     public static char[] encodeChunk(byte[] id,
                                      int o,
                                      int l,
@@ -317,14 +317,14 @@ public final class Base64Utility {
         }
         return out;
     }
-    
+
     public static void encodeAndStream(byte[] id,
                                        int o,
                                        int l,
                                        OutputStream os) throws IOException {
         encodeAndStream(id, o, l, false, os);
     }
-    
+
     public static void encodeAndStream(byte[] id,
                                            int o,
                                            int l,
@@ -337,13 +337,13 @@ public final class Base64Utility {
         int rindex = o;
         int rest = l;
         final char[] base64Table = urlSafe ? BCS_URL_SAFE : BCS;
-        
+
         char[] chunk = new char[4];
         while (rest >= 3) {
             int i = ((id[rindex] & 0xff) << 16)
                     + ((id[rindex + 1] & 0xff) << 8)
                     + (id[rindex + 2] & 0xff);
-            chunk[0] = base64Table[i >> 18]; 
+            chunk[0] = base64Table[i >> 18];
             chunk[1] = base64Table[(i >> 12) & 0x3f];
             chunk[2] = base64Table[(i >> 6) & 0x3f];
             chunk[3] = base64Table[i & 0x3f];
@@ -380,9 +380,9 @@ public final class Base64Utility {
         byte[] bytes = StandardCharsets.UTF_8.encode(CharBuffer.wrap(chunk, 0, len)).array();
         os.write(bytes);
     }
-    
+
     //
-    // Outputs base64 representation of the specified byte array 
+    // Outputs base64 representation of the specified byte array
     // to a byte stream.
     //
     public static void encodeChunk(byte[] id,
@@ -395,8 +395,8 @@ public final class Base64Utility {
             throw new Base64Exception(new Message("BASE64_ENCODE_IOEXCEPTION", LOG), e);
         }
     }
-    
-    // Outputs base64 representation of the specified byte 
+
+    // Outputs base64 representation of the specified byte
     // array to a character stream.
     //
     public static void encode(byte[] id,
@@ -422,15 +422,15 @@ public final class Base64Utility {
      * @param   p   Pointer to the encodeme of interest
      * @return  The decoded encodeme
      * @exception   Base64Exception Thrown is processing fails due to
-     * formatting exceptions in the encoded data 
-     */ 
+     * formatting exceptions in the encoded data
+     */
     private static int processEncodeme(char[] ib,
                                        byte[] ob,
-                                       int p) 
+                                       int p)
         throws Base64Exception {
-        
 
-        int spad = PAD_SIZE8;        
+
+        int spad = PAD_SIZE8;
         if (ib[3] == PAD) {
             spad = PAD_SIZE4;
         }
@@ -459,11 +459,11 @@ public final class Base64Utility {
         default:
             // We should never get here
             throw new IllegalStateException();
-        } 
+        }
     }
 
     public static boolean isValidBase64(int ch) {
         return ch == PAD || BDT[ch] != Byte.MAX_VALUE;
-    } 
+    }
 
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/CacheMap.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/CacheMap.java b/core/src/main/java/org/apache/cxf/common/util/CacheMap.java
index 4f0a98c..9a6b112 100644
--- a/core/src/main/java/org/apache/cxf/common/util/CacheMap.java
+++ b/core/src/main/java/org/apache/cxf/common/util/CacheMap.java
@@ -25,20 +25,20 @@ import java.util.WeakHashMap;
 
 
 /**
- * Implements a useful caching map. It weakly references the keys, 
+ * Implements a useful caching map. It weakly references the keys,
  * but strongly references the data. It works much like the WeakHashMap,
- * in that when the keys are garbage collected, the data is removed from 
+ * in that when the keys are garbage collected, the data is removed from
  * the map.
- * 
+ *
  * The main difference is that keys used for lookups don't have to be "=="
- * the same to maintain the data in the cache.  Basically, lookups in this 
- * map use a ".equals" compare, but the keys are then stored with a "==" 
+ * the same to maintain the data in the cache.  Basically, lookups in this
+ * map use a ".equals" compare, but the keys are then stored with a "=="
  * compare so if the original key is garbage collected, the other keys that
  * may reference the data keep the data in the cache.
  *
  * <b>
- * Note that this implementation is not synchronized. Not even a little. 
- * 'Read-only' operations can trigger internal modifications. If you share this 
+ * Note that this implementation is not synchronized. Not even a little.
+ * 'Read-only' operations can trigger internal modifications. If you share this
  * class between threads, you must protect every operation.
  * </b>
  */
@@ -47,16 +47,16 @@ public class CacheMap<K, V> implements Map<K, V> {
     Map<K, V> extraKeyMap = new WeakIdentityHashMap<K, V>();
 
     public CacheMap() {
-        
+
     }
-    
+
     public void clear() {
         mainDataMap.clear();
         extraKeyMap.clear();
     }
 
     private void updateMainDataMap() {
-        //if the singleton in the mainDataMap has been garbage collected, 
+        //if the singleton in the mainDataMap has been garbage collected,
         //we'll copy another version of it from the extraKeyMap
         for (Map.Entry<K, V> entry : extraKeyMap.entrySet()) {
             if (!mainDataMap.containsKey(entry.getKey())) {
@@ -64,7 +64,7 @@ public class CacheMap<K, V> implements Map<K, V> {
             }
         }
     }
-    
+
     public boolean containsKey(Object key) {
         if (!mainDataMap.containsKey(key)) {
             updateMainDataMap();
@@ -132,7 +132,7 @@ public class CacheMap<K, V> implements Map<K, V> {
         updateMainDataMap();
         return mainDataMap.values();
     }
-    
+
     public String toString() {
         updateMainDataMap();
         return mainDataMap.toString();

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/CglibProxyHelper.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/CglibProxyHelper.java b/core/src/main/java/org/apache/cxf/common/util/CglibProxyHelper.java
index 8e1b6fe..a3fa1ea 100644
--- a/core/src/main/java/org/apache/cxf/common/util/CglibProxyHelper.java
+++ b/core/src/main/java/org/apache/cxf/common/util/CglibProxyHelper.java
@@ -29,7 +29,7 @@ import net.sf.cglib.proxy.MethodProxy;
 
 
 /**
- * 
+ *
  */
 class CglibProxyHelper extends ProxyHelper {
     CglibProxyHelper() throws Exception {
@@ -37,20 +37,20 @@ class CglibProxyHelper extends ProxyHelper {
         Class.forName("net.sf.cglib.proxy.MethodInterceptor");
         Class.forName("net.sf.cglib.proxy.MethodProxy");
     }
-    
+
     @Override
-    protected Object getProxyInternal(ClassLoader loader, Class<?>[] interfaces, 
+    protected Object getProxyInternal(ClassLoader loader, Class<?>[] interfaces,
                                       final java.lang.reflect.InvocationHandler h) {
-        
+
         Class<?> superClass = null;
         List<Class<?>> theInterfaces = new ArrayList<Class<?>>();
-        
+
         for (Class<?> c : interfaces) {
             if (!c.isInterface()) {
                 if (superClass != null) {
                     throw new IllegalArgumentException("Only a single superclass is supported");
                 }
-                superClass = c; 
+                superClass = c;
             } else {
                 theInterfaces.add(c);
             }
@@ -62,17 +62,17 @@ class CglibProxyHelper extends ProxyHelper {
             enhancer.setInterfaces(theInterfaces.toArray(new Class[theInterfaces.size()]));
             enhancer.setCallback(new MethodInterceptor() {
 
-                public Object intercept(Object obj, Method method, Object[] args, MethodProxy proxy) 
+                public Object intercept(Object obj, Method method, Object[] args, MethodProxy proxy)
                     throws Throwable {
                     return h.invoke(obj, method, args);
                 }
-                
+
             });
             return enhancer.create();
         } else {
             return super.getProxyInternal(loader, interfaces, h);
         }
     }
-    
-    
+
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/ClassHelper.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/ClassHelper.java b/core/src/main/java/org/apache/cxf/common/util/ClassHelper.java
index 461c84a..02b6832 100644
--- a/core/src/main/java/org/apache/cxf/common/util/ClassHelper.java
+++ b/core/src/main/java/org/apache/cxf/common/util/ClassHelper.java
@@ -25,19 +25,19 @@ import org.apache.cxf.Bus;
 import org.apache.cxf.BusFactory;
 
 /**
- * 
+ *
  */
 public class ClassHelper {
     static final ClassHelper HELPER;
     static {
         HELPER = getClassHelper();
     }
-    
-    
+
+
     protected ClassHelper() {
     }
-    
-    private static ClassHelper getClassHelper() { 
+
+    private static ClassHelper getClassHelper() {
         boolean useSpring = true;
         String s = SystemPropertyAction.getPropertyOrNull("org.apache.cxf.useSpringClassHelpers");
         if (!StringUtils.isEmpty(s)) {
@@ -52,26 +52,26 @@ public class ClassHelper {
         }
         return new ClassHelper();
     }
-    
+
     protected Class<?> getRealClassInternal(Object o) {
         return getRealObjectInternal(o).getClass();
     }
-    
+
     protected Class<?> getRealClassFromClassInternal(Class<?> cls) {
         return cls;
     }
     protected Object getRealObjectInternal(Object o) {
         return o instanceof Proxy ? Proxy.getInvocationHandler(o) : o;
     }
-    
+
     public static Class<?> getRealClass(Object o) {
         return getRealClass(null, o);
     }
-    
+
     public static Class<?> getRealClassFromClass(Class<?> cls) {
         return HELPER.getRealClassFromClassInternal(cls);
     }
-    
+
     public static Object getRealObject(Object o) {
         return HELPER.getRealObjectInternal(o);
     }
@@ -87,7 +87,7 @@ public class ClassHelper {
     }
     public static double getJavaVersion() {
         String version = System.getProperty("java.version");
-        return Double.parseDouble(version.substring(0, 3));    
+        return Double.parseDouble(version.substring(0, 3));
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/ClasspathScanner.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/ClasspathScanner.java b/core/src/main/java/org/apache/cxf/common/util/ClasspathScanner.java
index 86b7827..6b76e1c 100644
--- a/core/src/main/java/org/apache/cxf/common/util/ClasspathScanner.java
+++ b/core/src/main/java/org/apache/cxf/common/util/ClasspathScanner.java
@@ -34,20 +34,20 @@ public class ClasspathScanner {
     public static final String ALL_CLASS_FILES = ALL_FILES + ".class";
     public static final String WILDCARD = "*";
     public static final String CLASSPATH_URL_SCHEME = "classpath:";
-    
+
     static final ClasspathScanner HELPER;
     static {
         HELPER = getClasspathScanner();
     }
-    
-    // Default packages list to ignore during classpath scanning 
-    static final String[] PACKAGES_TO_SKIP = {"org.apache.cxf"}; 
 
-    
+    // Default packages list to ignore during classpath scanning
+    static final String[] PACKAGES_TO_SKIP = {"org.apache.cxf"};
+
+
     protected ClasspathScanner() {
-    }    
+    }
 
-    private static ClasspathScanner getClasspathScanner() { 
+    private static ClasspathScanner getClasspathScanner() {
         boolean useSpring = true;
         String s = SystemPropertyAction.getPropertyOrNull("org.apache.cxf.useSpringClassHelpers");
         if (!StringUtils.isEmpty(s)) {
@@ -62,111 +62,111 @@ public class ClasspathScanner {
         }
         return new ClasspathScanner();
     }
-    
+
     /**
-     * Scans list of base packages for all classes marked with specific annotations. 
-     * @param basePackage base package 
+     * Scans list of base packages for all classes marked with specific annotations.
+     * @param basePackage base package
      * @param annotations annotations to discover
-     * @return all discovered classes grouped by annotations they belong too 
-     * @throws IOException class metadata is not readable 
+     * @return all discovered classes grouped by annotations they belong too
+     * @throws IOException class metadata is not readable
      * @throws ClassNotFoundException class not found
      */
     @SafeVarargs
     public static Map< Class< ? extends Annotation >, Collection< Class< ? > > > findClasses(
-        String basePackage, Class< ? extends Annotation > ... annotations) 
+        String basePackage, Class< ? extends Annotation > ... annotations)
         throws IOException, ClassNotFoundException {
-        return findClasses(parsePackages(basePackage), 
+        return findClasses(parsePackages(basePackage),
                            Collections.unmodifiableList(Arrays.asList(annotations)));
     }
-    
+
     /**
-     * Scans list of base packages for all classes marked with specific annotations. 
-     * @param basePackages list of base packages 
+     * Scans list of base packages for all classes marked with specific annotations.
+     * @param basePackages list of base packages
      * @param annotations annotations to discover
-     * @return all discovered classes grouped by annotations they belong too 
-     * @throws IOException class metadata is not readable 
+     * @return all discovered classes grouped by annotations they belong too
+     * @throws IOException class metadata is not readable
      * @throws ClassNotFoundException class not found
      */
     @SafeVarargs
     public static Map< Class< ? extends Annotation >, Collection< Class< ? > > > findClasses(
-        Collection< String > basePackages, Class< ? extends Annotation > ... annotations) 
+        Collection< String > basePackages, Class< ? extends Annotation > ... annotations)
         throws IOException, ClassNotFoundException {
         return findClasses(basePackages, Collections.unmodifiableList(Arrays.asList(annotations)));
     }
-    
+
     /**
-     * Scans list of base packages for all classes marked with specific annotations. 
-     * @param basePackages list of base packages 
+     * Scans list of base packages for all classes marked with specific annotations.
+     * @param basePackages list of base packages
      * @param annotations annotations to discover
-     * @return all discovered classes grouped by annotations they belong too 
-     * @throws IOException class metadata is not readable 
+     * @return all discovered classes grouped by annotations they belong too
+     * @throws IOException class metadata is not readable
      * @throws ClassNotFoundException class not found
      */
     public static Map< Class< ? extends Annotation >, Collection< Class< ? > > > findClasses(
-        Collection< String > basePackages, List<Class< ? extends Annotation > > annotations) 
+        Collection< String > basePackages, List<Class< ? extends Annotation > > annotations)
         throws IOException, ClassNotFoundException {
         return findClasses(basePackages, annotations, null);
-        
+
     }
 
     public static Map< Class< ? extends Annotation >, Collection< Class< ? > > > findClasses(
-        Collection< String > basePackages, 
+        Collection< String > basePackages,
         List<Class< ? extends Annotation > > annotations,
         ClassLoader loader) throws IOException, ClassNotFoundException {
         return HELPER.findClassesInternal(basePackages, annotations, loader);
     }
-    
+
     protected Map< Class< ? extends Annotation >, Collection< Class< ? > > > findClassesInternal(
-        Collection< String > basePackages, 
+        Collection< String > basePackages,
         List<Class< ? extends Annotation > > annotations,
-        ClassLoader loader) 
+        ClassLoader loader)
         throws IOException, ClassNotFoundException {
         return Collections.emptyMap();
     }
-    
+
     /**
-     * Scans list of base packages for all resources with the given extension. 
-     * @param basePackage base package 
+     * Scans list of base packages for all resources with the given extension.
+     * @param basePackage base package
      * @param extension the extension matching resources needs to have
-     * @return list of all discovered resource URLs 
+     * @return list of all discovered resource URLs
      * @throws IOException resource is not accessible
      */
-    public static List<URL> findResources(String basePackage, String extension) 
+    public static List<URL> findResources(String basePackage, String extension)
         throws IOException {
         return findResources(basePackage, extension, null);
     }
-    
+
     /**
-     * Scans list of base packages for all resources with the given extension. 
-     * @param basePackage base package 
+     * Scans list of base packages for all resources with the given extension.
+     * @param basePackage base package
      * @param extension the extension matching resources needs to have
-     * @return list of all discovered resource URLs 
+     * @return list of all discovered resource URLs
      * @throws IOException resource is not accessible
      */
-    public static List<URL> findResources(String basePackage, String extension, ClassLoader loader) 
+    public static List<URL> findResources(String basePackage, String extension, ClassLoader loader)
         throws IOException {
         return findResources(Collections.singletonList(basePackage), extension, loader);
     }
-    
+
     /**
-     * Scans list of base packages for all resources with the given extension. 
-     * @param basePackages list of base packages 
+     * Scans list of base packages for all resources with the given extension.
+     * @param basePackages list of base packages
      * @param extension the extension matching resources needs to have
-     * @return list of all discovered resource URLs 
+     * @return list of all discovered resource URLs
      * @throws IOException resource is not accessible
      */
-    public static List<URL> findResources(Collection<String> basePackages, String extension) 
+    public static List<URL> findResources(Collection<String> basePackages, String extension)
         throws IOException {
         return findResources(basePackages, extension, null);
     }
-    
+
     public static List<URL> findResources(Collection<String> basePackages, String extension,
-                                          ClassLoader loader) 
+                                          ClassLoader loader)
         throws IOException {
         return HELPER.findResourcesInternal(basePackages, extension, loader);
     }
-    
-    public static Set<String> parsePackages(final String packagesAsCsv) {        
+
+    public static Set<String> parsePackages(final String packagesAsCsv) {
         final String[] values = StringUtils.split(packagesAsCsv, ",");
         final Set<String> basePackages = new HashSet<>(values.length);
         for (final String value : values) {
@@ -179,15 +179,15 @@ public class ClasspathScanner {
                 basePackages.add(trimmed);
             }
         }
-        
+
         return basePackages;
     }
-    
-    protected List<URL> findResourcesInternal(Collection<String> basePackages, 
+
+    protected List<URL> findResourcesInternal(Collection<String> basePackages,
                                               String extension,
-                                              ClassLoader loader) 
+                                              ClassLoader loader)
         throws IOException {
         return Collections.emptyList();
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/CollectionUtils.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/CollectionUtils.java b/core/src/main/java/org/apache/cxf/common/util/CollectionUtils.java
index c6b2acd..9e7a3d4 100644
--- a/core/src/main/java/org/apache/cxf/common/util/CollectionUtils.java
+++ b/core/src/main/java/org/apache/cxf/common/util/CollectionUtils.java
@@ -25,9 +25,9 @@ import java.util.Iterator;
 
 public final class CollectionUtils {
     private CollectionUtils() {
-        
+
     }
-    
+
     public static <T> Collection<T> diff(Collection<T> c1, Collection<T> c2) {
         if (c1 == null || c1.size() == 0 || c2 == null || c2.size() == 0) {
             return c1;
@@ -40,7 +40,7 @@ public final class CollectionUtils {
         }
         return difference;
     }
-    
+
     public static <T> boolean isEmpty(Collection<T> c) {
         if (c == null || c.size() == 0) {
             return true;
@@ -52,5 +52,5 @@ public final class CollectionUtils {
         }
         return true;
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/Compiler.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/Compiler.java b/core/src/main/java/org/apache/cxf/common/util/Compiler.java
index 855eaad..b0eccae 100644
--- a/core/src/main/java/org/apache/cxf/common/util/Compiler.java
+++ b/core/src/main/java/org/apache/cxf/common/util/Compiler.java
@@ -50,17 +50,17 @@ public class Compiler {
     private File classpathTmpFile;
     private List<String> errors = new LinkedList<String>();
     private List<String> warnings = new LinkedList<String>();
-    
+
     public Compiler() {
     }
-    
+
     public List<String> getErrors() {
         return errors;
     }
     public List<String> getWarnings() {
         return warnings;
     }
-    
+
     public void setMaxMemory(long l) {
         maxMemory = l;
     }
@@ -83,7 +83,7 @@ public class Compiler {
     public void setClassPath(String s) {
         classPath = StringUtils.isEmpty(s) ? null : s;
     }
-    
+
     protected void addArgs(List<String> list) {
         if (!StringUtils.isEmpty(encoding)) {
             list.add("-encoding");
@@ -100,7 +100,7 @@ public class Compiler {
             list.add("-d");
             list.add(outputDir);
         }
-        
+
         if (StringUtils.isEmpty(classPath)) {
             String javaClasspath = SystemPropertyAction.getProperty("java.class.path");
             boolean classpathSetted = javaClasspath != null ? true : false;
@@ -109,7 +109,7 @@ public class Compiler {
                 f = new File(f, "../lib");
                 if (f.exists() && f.isDirectory()) {
                     list.add("-extdirs");
-                    list.add(f.toString());                    
+                    list.add(f.toString());
                 }
             } else {
                 list.add("-classpath");
@@ -140,7 +140,7 @@ public class Compiler {
         if (!forceFork) {
             return useJava6Compiler(files);
         }
-        
+
         List<String> list = new ArrayList<>();
 
         // Start of honoring java.home for used javac
@@ -176,7 +176,7 @@ public class Compiler {
 
         //fix for CXF-2081, set maximum heap of this VM to javac.
         list.add("-J-Xmx" + maxMemory);
-        
+
         if (System.getProperty("java.version").startsWith("9")) {
             list.add("--add-modules");
             list.add("java.activation,java.annotations.common,java.corba,java.transaction,java.xml.bind,java.xml.ws");
@@ -205,11 +205,11 @@ public class Compiler {
         return internalJava6Compile(compiler, wrapJavaFileManager(fileManager), setupDiagnosticListener(),
                                     fileList);
     }
-    
+
     protected JavaFileManager wrapJavaFileManager(StandardJavaFileManager standardJavaFileManger) {
         return standardJavaFileManger;
     }
-    
+
     protected DiagnosticListener<JavaFileObject> setupDiagnosticListener() {
         return new DiagnosticListener<JavaFileObject>() {
             public void report(Diagnostic<? extends JavaFileObject> diagnostic) {
@@ -229,11 +229,11 @@ public class Compiler {
                     break;
                 default:
                     break;
-                }   
+                }
             }
         };
     }
-    
+
     protected boolean internalJava6Compile(JavaCompiler compiler, JavaFileManager fileManager,
                                            DiagnosticListener<JavaFileObject> listener,
                                            Iterable<? extends JavaFileObject> fileList) {
@@ -336,11 +336,11 @@ public class Compiler {
         }
         return strBuffer.toString().length() > 4096 ? true : false;
     }
-    
+
     private boolean isLongClasspath(String classpath) {
         return classpath.length() > 2048 ? true : false;
-    }   
-    
+    }
+
     private void checkLongClasspath(String classpath, List<String> list, int classpathIdx) {
         if (isLongClasspath(classpath)) {
             PrintWriter out = null;
@@ -354,12 +354,12 @@ public class Compiler {
             } catch (IOException e) {
                 System.err.print("[ERROR] can't write long classpath to @argfile");
             }
-        } 
+        }
     }
 
     public void setEncoding(String string) {
         encoding = string;
     }
 
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/CompressionUtils.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/CompressionUtils.java b/core/src/main/java/org/apache/cxf/common/util/CompressionUtils.java
index 6fbf2a4..769614c 100644
--- a/core/src/main/java/org/apache/cxf/common/util/CompressionUtils.java
+++ b/core/src/main/java/org/apache/cxf/common/util/CompressionUtils.java
@@ -27,13 +27,13 @@ import java.util.zip.Inflater;
 
 public final class CompressionUtils {
     private CompressionUtils() {
-        
+
     }
-    public static InputStream inflate(byte[] deflatedToken) 
+    public static InputStream inflate(byte[] deflatedToken)
         throws DataFormatException {
         return inflate(deflatedToken, true);
     }
-    public static InputStream inflate(byte[] deflatedToken, boolean nowrap) 
+    public static InputStream inflate(byte[] deflatedToken, boolean nowrap)
         throws DataFormatException {
         Inflater inflater = new Inflater(true);
         inflater.setInput(deflatedToken);
@@ -50,31 +50,31 @@ public final class CompressionUtils {
                     break;
                 }
             }
-            
+
             inflatedToken.write(buffer, 0, inflateLen);
         }
 
         return new ByteArrayInputStream(inflatedToken.toByteArray());
     }
-    
+
     public static byte[] deflate(byte[] tokenBytes) {
         return deflate(tokenBytes, true);
     }
-    
+
     public static byte[] deflate(byte[] tokenBytes, boolean nowrap) {
         return deflate(tokenBytes, Deflater.DEFLATED, nowrap);
     }
-    
+
     public static byte[] deflate(byte[] tokenBytes, int level, boolean nowrap) {
         Deflater compresser = new Deflater(level, nowrap);
-        
+
         compresser.setInput(tokenBytes);
         compresser.finish();
-        
+
         byte[] output = new byte[tokenBytes.length * 2];
-        
+
         int compressedDataLength = compresser.deflate(output);
-        
+
         byte[] result = new byte[compressedDataLength];
         System.arraycopy(output, 0, result, 0, compressedDataLength);
         return result;

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/MessageDigestInputStream.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/MessageDigestInputStream.java b/core/src/main/java/org/apache/cxf/common/util/MessageDigestInputStream.java
index d089403..1217ee5 100644
--- a/core/src/main/java/org/apache/cxf/common/util/MessageDigestInputStream.java
+++ b/core/src/main/java/org/apache/cxf/common/util/MessageDigestInputStream.java
@@ -24,11 +24,11 @@ import java.security.NoSuchAlgorithmException;
 
 public class MessageDigestInputStream extends java.security.DigestInputStream {
     public static final String ALGO_SHA_256 = "SHA-256";
-    
+
     public MessageDigestInputStream(InputStream is) {
         super(is, getDigestInstance(ALGO_SHA_256));
     }
-    
+
     private static MessageDigest getDigestInstance(String algo)  {
         try {
             return MessageDigest.getInstance(algo);

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/ModCountCopyOnWriteArrayList.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/ModCountCopyOnWriteArrayList.java b/core/src/main/java/org/apache/cxf/common/util/ModCountCopyOnWriteArrayList.java
index 7a0c3aa..9fc055e 100644
--- a/core/src/main/java/org/apache/cxf/common/util/ModCountCopyOnWriteArrayList.java
+++ b/core/src/main/java/org/apache/cxf/common/util/ModCountCopyOnWriteArrayList.java
@@ -26,7 +26,7 @@ import java.util.concurrent.atomic.AtomicInteger;
 public final class ModCountCopyOnWriteArrayList<T> extends CopyOnWriteArrayList<T> {
     private static final long serialVersionUID = 1783937035760941219L;
     private AtomicInteger modCount = new AtomicInteger();
-    
+
     public ModCountCopyOnWriteArrayList() {
         super();
     }
@@ -36,15 +36,15 @@ public final class ModCountCopyOnWriteArrayList<T> extends CopyOnWriteArrayList<
             modCount.set(((ModCountCopyOnWriteArrayList<?>)c).getModCount());
         }
     }
-    
+
     public int getModCount() {
         return modCount.get();
     }
-    
+
     public void setModCount(int i) {
         modCount.set(i);
     }
-    
+
     @Override
     public void add(int index, T element) {
         super.add(index, element);
@@ -137,14 +137,14 @@ public final class ModCountCopyOnWriteArrayList<T> extends CopyOnWriteArrayList<
         }
         return false;
     }
-    
+
     public int hashCode() {
         return super.hashCode() + modCount.get();
     }
-    
+
     public boolean equals(Object o) {
         if (o instanceof ModCountCopyOnWriteArrayList) {
-            return super.equals(o) && modCount.get() 
+            return super.equals(o) && modCount.get()
                 == ((ModCountCopyOnWriteArrayList<?>)o).getModCount();
         }
         return false;

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/PackageUtils.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/PackageUtils.java b/core/src/main/java/org/apache/cxf/common/util/PackageUtils.java
index 1d8d6ed..a970e81 100644
--- a/core/src/main/java/org/apache/cxf/common/util/PackageUtils.java
+++ b/core/src/main/java/org/apache/cxf/common/util/PackageUtils.java
@@ -27,11 +27,11 @@ import org.apache.cxf.helpers.JavaUtils;
 
 
 public final class PackageUtils {
-      
+
     private PackageUtils() {
-        
+
     }
-    
+
     static String getPackageName(String className) {
         int pos = className.lastIndexOf('.');
         if (pos != -1) {
@@ -40,7 +40,7 @@ public final class PackageUtils {
             return "";
         }
     }
-    
+
     public static String getPackageName(Class<?> clazz) {
         String className = clazz.getName();
         if (className.startsWith("[L")) {
@@ -48,7 +48,7 @@ public final class PackageUtils {
         }
         return getPackageName(className);
     }
-    
+
     public static String getSharedPackageName(List<Class<?>> classes) {
         if (classes.isEmpty()) {
             return "";
@@ -63,7 +63,7 @@ public final class PackageUtils {
             for (; j < lParts.size(); j++) {
                 if (i > (lParts.get(j).size() - 1) || !lParts.get(j).get(i).equals(lParts.get(0).get(i))) {
                     break;
-                }  
+                }
             }
             if (j == lParts.size()) {
                 currentParts.add(lParts.get(j - 1).get(i));
@@ -80,7 +80,7 @@ public final class PackageUtils {
         }
         return sb.toString();
     }
-    
+
     public static String parsePackageName(String namespace, String defaultPackageName) {
         String packageName = (defaultPackageName != null && defaultPackageName.trim().length() > 0)
             ? defaultPackageName : null;
@@ -90,7 +90,7 @@ public final class PackageUtils {
         }
         return packageName;
     }
-    
+
     public static String getPackageNameByNameSpaceURI(String nameSpaceURI) {
         int idx = nameSpaceURI.indexOf(':');
         String scheme = "";
@@ -227,5 +227,5 @@ public final class PackageUtils {
         namespace.append('/');
         return namespace.toString();
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/PrimitiveUtils.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/PrimitiveUtils.java b/core/src/main/java/org/apache/cxf/common/util/PrimitiveUtils.java
index dc131de..3889443 100644
--- a/core/src/main/java/org/apache/cxf/common/util/PrimitiveUtils.java
+++ b/core/src/main/java/org/apache/cxf/common/util/PrimitiveUtils.java
@@ -35,17 +35,17 @@ public final class PrimitiveUtils {
         AUTOBOXED_PRIMITIVES_MAP.put(boolean.class, Boolean.class);
         AUTOBOXED_PRIMITIVES_MAP.put(void.class, Void.class);
     }
-    
+
     private PrimitiveUtils() {
-        
+
     }
-    
+
     public static boolean canPrimitiveTypeBeAutoboxed(Class<?> primitiveClass, Class<?> type) {
         return primitiveClass.isPrimitive() && type == AUTOBOXED_PRIMITIVES_MAP.get(primitiveClass);
     }
-    
+
     public static Class<?> getClass(String value) {
-        Class<?> clz = null;        
+        Class<?> clz = null;
         if ("int".equals(value)) {
             clz = int.class;
         }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/PropertiesLoaderUtils.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/PropertiesLoaderUtils.java b/core/src/main/java/org/apache/cxf/common/util/PropertiesLoaderUtils.java
index 5afb1fd..3dbd9a1 100644
--- a/core/src/main/java/org/apache/cxf/common/util/PropertiesLoaderUtils.java
+++ b/core/src/main/java/org/apache/cxf/common/util/PropertiesLoaderUtils.java
@@ -33,13 +33,13 @@ import java.util.logging.Logger;
  * when moving to Spring 2.0.
  *
  */
-    
+
 public final class PropertiesLoaderUtils {
-    
+
     /**
      * Prevents instantiation.
      */
-    private PropertiesLoaderUtils() {        
+    private PropertiesLoaderUtils() {
     }
 
     /**
@@ -48,7 +48,7 @@ public final class PropertiesLoaderUtils {
      * <p>
      * Merges properties if more than one resource of the same name found in the
      * class path.
-     * 
+     *
      * @param resourceName the name of the class path resource
      * @param classLoader the ClassLoader to use for loading (or
      *            <code>null</code> to use the default class loader)
@@ -58,7 +58,7 @@ public final class PropertiesLoaderUtils {
     public static Properties loadAllProperties(String resourceName, ClassLoader classLoader)
         throws IOException {
         return loadAllProperties(resourceName, classLoader, null, null, null);
-    }        
+    }
     public static Properties loadAllProperties(String resourceName, ClassLoader classLoader,
                                                Logger logger, Level level, String msg)
         throws IOException {
@@ -74,7 +74,7 @@ public final class PropertiesLoaderUtils {
             if (logger != null) {
                 logger.log(level, msg, url.toString());
             }
-            
+
             try (InputStream is = url.openStream()) {
                 properties.loadFromXML(new BufferedInputStream(is));
             }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/PropertyUtils.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/PropertyUtils.java b/core/src/main/java/org/apache/cxf/common/util/PropertyUtils.java
index ded47cd..7646002 100644
--- a/core/src/main/java/org/apache/cxf/common/util/PropertyUtils.java
+++ b/core/src/main/java/org/apache/cxf/common/util/PropertyUtils.java
@@ -29,7 +29,7 @@ import org.apache.cxf.message.Message;
 public final class PropertyUtils {
     private PropertyUtils() {
     }
-    
+
     public static boolean isTrue(Map<String, Object> props, String key) {
         if (props == null || key == null) {
             return false;
@@ -37,11 +37,11 @@ public final class PropertyUtils {
             return isTrue(props.get(key));
         }
     }
-    
+
     /**
      * It might seem odd to return 'true' if a property == FALSE, but it
      * is required sometimes.
-     * 
+     *
      * @param props
      * @param key
      * @return false if value is either the String "false" or Boolean.FALSE.  Otherwise returns
@@ -54,7 +54,7 @@ public final class PropertyUtils {
             return isFalse(props.get(key));
         }
     }
-    
+
     /**
      * Returns true if a value is either the String "true" (regardless of case)  or Boolean.TRUE.
      * @param property
@@ -67,10 +67,10 @@ public final class PropertyUtils {
 
         return Boolean.TRUE.equals(property) || "true".equalsIgnoreCase(property.toString());
     }
-    
+
     /**
      * It might seem odd to return 'true' if a property == FALSE, but it is required sometimes.
-     * 
+     *
      * Returns false if a value is either the String "false" (regardless of case)  or Boolean.FALSE.
      * @param property
      * @return false if value is either the String "false" or Boolean.FALSE.  Otherwise returns
@@ -83,7 +83,7 @@ public final class PropertyUtils {
 
         return Boolean.FALSE.equals(property) || "false".equalsIgnoreCase(property.toString());
     }
-    
+
     public static Long getLong(Message message, String key) {
         Object o = message.getContextualProperty(key);
         if (o instanceof Long) {
@@ -95,7 +95,7 @@ public final class PropertyUtils {
         }
         return null;
     }
-    
+
     public static Integer getInteger(Message message, String key) {
         Object o = message.getContextualProperty(key);
         if (o instanceof Integer) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/ProxyClassLoader.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/ProxyClassLoader.java b/core/src/main/java/org/apache/cxf/common/util/ProxyClassLoader.java
index 5075653..974fef0 100644
--- a/core/src/main/java/org/apache/cxf/common/util/ProxyClassLoader.java
+++ b/core/src/main/java/org/apache/cxf/common/util/ProxyClassLoader.java
@@ -25,7 +25,7 @@ import java.util.Set;
 /**
  * Utility class loader that can be used to create proxies in cases where
  * the the client classes are not visible to the loader of the
- * service class.    
+ * service class.
  */
 public class ProxyClassLoader extends ClassLoader {
     private final Class<?> classes[];
@@ -78,7 +78,7 @@ public class ProxyClassLoader extends ClassLoader {
         }
         throw new ClassNotFoundException(name);
     }
-    
+
     public URL findResource(String name) {
         for (ClassLoader loader : loaders) {
             URL url = loader.getResource(name);

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/ProxyHelper.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/ProxyHelper.java b/core/src/main/java/org/apache/cxf/common/util/ProxyHelper.java
index 413098c..931d3ac 100644
--- a/core/src/main/java/org/apache/cxf/common/util/ProxyHelper.java
+++ b/core/src/main/java/org/apache/cxf/common/util/ProxyHelper.java
@@ -24,7 +24,7 @@ import java.lang.reflect.Method;
 import java.lang.reflect.Proxy;
 
 /**
- * 
+ *
  */
 public class ProxyHelper {
     static final ProxyHelper HELPER;
@@ -37,11 +37,11 @@ public class ProxyHelper {
         }
         HELPER = theHelper;
     }
-    
-    
+
+
     protected ProxyHelper() {
     }
-    
+
     protected Object getProxyInternal(ClassLoader loader, Class<?>[] interfaces, InvocationHandler handler) {
         ClassLoader combinedLoader = getClassLoaderForInterfaces(loader, interfaces);
         return Proxy.newProxyInstance(combinedLoader, interfaces, handler);
@@ -50,7 +50,7 @@ public class ProxyHelper {
     /**
      * Return a classloader that can see all the given interfaces If the given loader can see all interfaces
      * then it is used. If not then a combined classloader of all interface classloaders is returned.
-     * 
+     *
      * @param loader use supplied class loader
      * @param interfaces
      * @return classloader that sees all interfaces
@@ -74,7 +74,7 @@ public class ProxyHelper {
                 if (ifClass != currentInterface) {
                     return false;
                 }
-                //we need to check all the params/returns as well as the Proxy creation 
+                //we need to check all the params/returns as well as the Proxy creation
                 //will try to create methods for all of this even if they aren't used
                 //by the client and not available in the clients classloader
                 for (Method m : ifClass.getMethods()) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/ReflectionInvokationHandler.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/ReflectionInvokationHandler.java b/core/src/main/java/org/apache/cxf/common/util/ReflectionInvokationHandler.java
index ed2c396..893eae1 100644
--- a/core/src/main/java/org/apache/cxf/common/util/ReflectionInvokationHandler.java
+++ b/core/src/main/java/org/apache/cxf/common/util/ReflectionInvokationHandler.java
@@ -32,19 +32,19 @@ import java.lang.reflect.Proxy;
 import java.util.Iterator;
 
 /**
- * 
+ *
  */
 public class ReflectionInvokationHandler implements InvocationHandler {
     private Object target;
-    
+
     public ReflectionInvokationHandler(Object obj) {
         target = obj;
     }
-    
+
     public Object getTarget() {
-        return target;        
+        return target;
     }
-    
+
     /** {@inheritDoc}*/
     public Object invoke(Object proxy, Method method, Object[] args) throws Throwable {
         WrapReturn wr = method.getAnnotation(WrapReturn.class);
@@ -55,7 +55,7 @@ public class ReflectionInvokationHandler implements InvocationHandler {
             try {
                 m = targetClass.getMethod(method.getName(), parameterTypes);
             } catch (NoSuchMethodException nsme) {
-                
+
                 boolean[] optionals = new boolean[method.getParameterTypes().length];
                 int i = 0;
                 int optionalNumber = 0;
@@ -70,7 +70,7 @@ public class ReflectionInvokationHandler implements InvocationHandler {
                     }
                     i++;
                 }
-                
+
                 Class<?>[] newParams = new Class<?>[args.length - optionalNumber];
                 Object[] newArgs = new Object[args.length - optionalNumber];
                 int argI = 0;
@@ -96,14 +96,14 @@ public class ReflectionInvokationHandler implements InvocationHandler {
                     && m2.getParameterTypes().length == method.getParameterTypes().length) {
                     boolean found = true;
                     for (int x = 0; x < m2.getParameterTypes().length; x++) {
-                        if (args[x] != null 
+                        if (args[x] != null
                             && !m2.getParameterTypes()[x].isInstance(args[x])) {
                             found = false;
                         }
                     }
                     if (found) {
                         ReflectionUtil.setAccessible(m2);
-                        return wrapReturn(wr, m2.invoke(target, args));                            
+                        return wrapReturn(wr, m2.invoke(target, args));
                     }
                 }
             }
@@ -153,7 +153,7 @@ public class ReflectionInvokationHandler implements InvocationHandler {
         }
         return createProxyWrapper(t, wr.value());
     }
-    
+
     public static <T> T createProxyWrapper(Object target, Class<T> inf) {
         InvocationHandler h = new ReflectionInvokationHandler(target);
         return inf.cast(Proxy.newProxyInstance(inf.getClassLoader(), new Class[] {inf}, h));
@@ -170,14 +170,14 @@ public class ReflectionInvokationHandler implements InvocationHandler {
         Class<?> value();
         boolean iterator() default false;
     }
-    
+
     @Target(ElementType.PARAMETER)
     @Retention(RetentionPolicy.RUNTIME)
     public static @interface UnwrapParam {
         String methodName() default "getValue";
         String typeMethodName() default "#default";
     }
-    
+
     private static class WrapperIterator implements Iterator<Object> {
         Class<?> cls;
         Iterator<?> internal;

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/ReflectionUtil.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/ReflectionUtil.java b/core/src/main/java/org/apache/cxf/common/util/ReflectionUtil.java
index 39f9b71..5e3bea4 100644
--- a/core/src/main/java/org/apache/cxf/common/util/ReflectionUtil.java
+++ b/core/src/main/java/org/apache/cxf/common/util/ReflectionUtil.java
@@ -37,14 +37,14 @@ import java.util.List;
 import org.apache.cxf.common.classloader.ClassLoaderUtils;
 
 public final class ReflectionUtil {
-    
-    private static Method springBeanUtilsDescriptorFetcher; 
+
+    private static Method springBeanUtilsDescriptorFetcher;
     private static boolean springChecked;
-    
+
     private ReflectionUtil() {
         // intentionally empty
     }
-    
+
     public static <T> T accessDeclaredField(final Field f, final Object o, final Class<T> responseClass) {
         return AccessController.doPrivileged(new PrivilegedAction<T>() {
             public T run() {
@@ -64,7 +64,7 @@ public final class ReflectionUtil {
     }
     public static <T> T accessDeclaredField(final String fieldName,
                                             final Class<?> cls,
-                                            final Object o, 
+                                            final Object o,
                                             final Class<T> responseClass) {
         return AccessController.doPrivileged(new PrivilegedAction<T>() {
             public T run() {
@@ -83,7 +83,7 @@ public final class ReflectionUtil {
             }
         });
     }
-    
+
     public static Field getDeclaredField(final Class<?> cls, final String name) {
         return AccessController.doPrivileged(new PrivilegedAction<Field>() {
             public Field run() {
@@ -110,7 +110,7 @@ public final class ReflectionUtil {
                 }
             }
         });
-        
+
     }
     public static <T> Constructor<T> getConstructor(final Class<T> cls, final Class<?> ... args) {
         return AccessController.doPrivileged(new PrivilegedAction<Constructor<T>>() {
@@ -123,9 +123,9 @@ public final class ReflectionUtil {
                     return null;
                 }
             }
-        });      
+        });
     }
-    
+
     public static <T> Constructor<T>[] getDeclaredConstructors(final Class<T> cls) {
         return AccessController.doPrivileged(new PrivilegedAction<Constructor<T>[]>() {
             @SuppressWarnings("unchecked")
@@ -134,11 +134,11 @@ public final class ReflectionUtil {
                     return (Constructor<T>[])cls.getDeclaredConstructors();
                 } catch (SecurityException e) {
                     return null;
-                } 
+                }
             }
-        });      
+        });
     }
-    
+
     public static Method[] getDeclaredMethods(final Class<?> cls) {
         return AccessController.doPrivileged(new PrivilegedAction<Method[]>() {
             public Method[] run() {
@@ -189,7 +189,7 @@ public final class ReflectionUtil {
             }
         });
     }
-    
+
     /**
      *  create own array of property descriptors to:
      *  <pre>
@@ -204,7 +204,7 @@ public final class ReflectionUtil {
      * @param beanClass class for bean in question
      * @param propertyDescriptors raw descriptors
      */
-    public static PropertyDescriptor[] getPropertyDescriptorsAvoidSunBug(Class<?> refClass, 
+    public static PropertyDescriptor[] getPropertyDescriptorsAvoidSunBug(Class<?> refClass,
                                                                   BeanInfo beanInfo,
                                                                   Class<?> beanClass,
                                                                   PropertyDescriptor[] propertyDescriptors) {
@@ -213,13 +213,13 @@ public final class ReflectionUtil {
                 springChecked = true;
                 Class<?> cls = ClassLoaderUtils
                     .loadClass("org.springframework.beans.BeanUtils", refClass);
-                springBeanUtilsDescriptorFetcher 
+                springBeanUtilsDescriptorFetcher
                     = cls.getMethod("getPropertyDescriptor", new Class[] {Class.class, String.class});
             } catch (Exception e) {
                 //ignore - just assume it's an unsupported/unknown annotation
             }
         }
-        
+
         if (springBeanUtilsDescriptorFetcher != null) {
             if (propertyDescriptors != null) {
                 List<PropertyDescriptor> descriptors = new ArrayList<>(propertyDescriptors.length);
@@ -227,7 +227,7 @@ public final class ReflectionUtil {
                     PropertyDescriptor propertyDescriptor = propertyDescriptors[i];
                     try {
                         propertyDescriptor = (PropertyDescriptor)springBeanUtilsDescriptorFetcher.invoke(null,
-                                                                                     beanClass, 
+                                                                                     beanClass,
                                                                                      propertyDescriptor.getName());
                         if (propertyDescriptor != null) {
                             descriptors.add(propertyDescriptor);
@@ -238,7 +238,7 @@ public final class ReflectionUtil {
                         throw new RuntimeException(e);
                     } catch (InvocationTargetException e) {
                         throw new RuntimeException(e.getCause());
-                    } 
+                    }
                 }
                 return descriptors.toArray(new PropertyDescriptor[descriptors.size()]);
             }
@@ -251,7 +251,7 @@ public final class ReflectionUtil {
     /**
      * Look for a specified annotation on a method. If there, return it. If not, search it's containing class.
      * Assume that the annotation is marked @Inherited.
-     * 
+     *
      * @param m method to examine
      * @param annotationType the annotation type to look for.
      */

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/SortedArraySet.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/SortedArraySet.java b/core/src/main/java/org/apache/cxf/common/util/SortedArraySet.java
index 2d59f40..54d846d 100644
--- a/core/src/main/java/org/apache/cxf/common/util/SortedArraySet.java
+++ b/core/src/main/java/org/apache/cxf/common/util/SortedArraySet.java
@@ -28,20 +28,20 @@ import java.util.concurrent.atomic.AtomicReference;
 
 
 /**
- * This class implements most of the <tt>Set</tt> interface, backed by a 
+ * This class implements most of the <tt>Set</tt> interface, backed by a
  * sorted Array.  This makes iterators very fast, lookups are log(n), but
  * adds are fairly expensive.
- * 
+ *
  * This class is also threadsafe, but without synchronizations.   Lookups
  * and iterators will iterate over the state of the Set when the iterator
  * was created.
  *
  * If no data is stored in the Set, it uses very little memory.  The backing
  * array is created on demand.
- * 
+ *
  * This class is primarly useful for stuff that will be setup at startup, but
  * then iterated over MANY times during runtime.
- *   
+ *
  * @param <T>
  */
 public final class SortedArraySet<T> implements SortedSet<T> {
@@ -64,12 +64,12 @@ public final class SortedArraySet<T> implements SortedSet<T> {
         T[] tmp = data.get();
         return tmp == null ? 0 : tmp.length;
     }
-    
+
     @SuppressWarnings("unchecked")
     private T[] newArray(int size) {
         return (T[])new Object[size];
     }
-    
+
     public boolean add(T o) {
         if (!contains(o)) {
             T[] tmp = data.get();
@@ -83,7 +83,7 @@ public final class SortedArraySet<T> implements SortedSet<T> {
                 tmp2[tmp2.length - 1] = o;
                 Arrays.sort(tmp2);
             }
-            
+
             if (!data.compareAndSet(tmp, tmp2)) {
                 return add(o);
             }
@@ -133,13 +133,13 @@ public final class SortedArraySet<T> implements SortedSet<T> {
 
     public boolean remove(Object o) {
         T[] tmp = data.get();
-        
+
         if (tmp == null) {
             return false;
         }
         int idx = Arrays.binarySearch(tmp, o);
         if (idx != -1) {
-            if (tmp.length == 1 
+            if (tmp.length == 1
                 && !data.compareAndSet(tmp, null)) {
                 return remove(o);
             }
@@ -175,7 +175,7 @@ public final class SortedArraySet<T> implements SortedSet<T> {
             }
             return a;
         }
-        
+
         if (a.length < tmp.length) {
             a = (X[])java.lang.reflect.Array.
                 newInstance(a.getClass().getComponentType(), tmp.length);
@@ -199,18 +199,18 @@ public final class SortedArraySet<T> implements SortedSet<T> {
         return Arrays.toString(data.get());
     }
     public int hashCode() {
-        return Arrays.hashCode(data.get()); 
+        return Arrays.hashCode(data.get());
     }
-    
+
 
     private class SASIterator<X> implements Iterator<X> {
         final X[] data;
         int idx;
-        
+
         SASIterator(X[] d) {
             data = d;
         }
-        
+
         public boolean hasNext() {
             return data != null && idx != data.length;
         }
@@ -241,7 +241,7 @@ public final class SortedArraySet<T> implements SortedSet<T> {
         }
         return tmp[0];
     }
-    
+
     public T last() {
         T[] tmp = data.get();
         if (tmp == null || tmp.length == 0) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/SpringAopClassHelper.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/SpringAopClassHelper.java b/core/src/main/java/org/apache/cxf/common/util/SpringAopClassHelper.java
index 7282f01..495d3d1 100644
--- a/core/src/main/java/org/apache/cxf/common/util/SpringAopClassHelper.java
+++ b/core/src/main/java/org/apache/cxf/common/util/SpringAopClassHelper.java
@@ -26,14 +26,14 @@ import org.springframework.beans.factory.BeanCreationException;
 import org.springframework.util.ClassUtils;
 
 /**
- * 
+ *
  */
 class SpringAopClassHelper extends ClassHelper {
     SpringAopClassHelper() throws Exception {
         Class.forName("org.springframework.aop.support.AopUtils");
         Class.forName("org.springframework.aop.framework.Advised");
     }
-    
+
     protected Class<?> getRealClassFromClassInternal(Class<?> cls) {
         if (ClassUtils.isCglibProxyClass(cls)) {
             return getRealClassFromClassInternal(cls.getSuperclass());
@@ -46,7 +46,7 @@ class SpringAopClassHelper extends ClassHelper {
 
                 Advised advised = (Advised)o;
                 Object target = advised.getTargetSource().getTarget();
-                //could be a proxy of a proxy.....   
+                //could be a proxy of a proxy.....
                 return getRealObjectInternal(target);
             } catch (Exception ex) {
                 // ignore
@@ -60,33 +60,33 @@ class SpringAopClassHelper extends ClassHelper {
             Advised advised = (Advised)o;
             try {
                 TargetSource targetSource = advised.getTargetSource();
-                
+
                 Object target = null;
-                
+
                 try {
                     target = targetSource.getTarget();
                 } catch (BeanCreationException ex) {
-                    // some scopes such as 'request' may not 
+                    // some scopes such as 'request' may not
                     // be active on the current thread yet
                     return getRealClassFromClassInternal(targetSource.getTargetClass());
                 }
-                
+
                 if (target == null) {
                     Class<?> targetClass = AopUtils.getTargetClass(o);
                     if (targetClass != null) {
                         return getRealClassFromClassInternal(targetClass);
                     }
                 } else {
-                    return getRealClassInternal(target); 
+                    return getRealClassInternal(target);
                 }
             } catch (Exception ex) {
                 // ignore
             }
-            
+
         } else if (ClassUtils.isCglibProxyClass(o.getClass())) {
             return getRealClassFromClassInternal(AopUtils.getTargetClass(o));
         }
         return o.getClass();
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/SpringClasspathScanner.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/SpringClasspathScanner.java b/core/src/main/java/org/apache/cxf/common/util/SpringClasspathScanner.java
index a18a8db..b4308ea 100644
--- a/core/src/main/java/org/apache/cxf/common/util/SpringClasspathScanner.java
+++ b/core/src/main/java/org/apache/cxf/common/util/SpringClasspathScanner.java
@@ -39,7 +39,7 @@ import org.springframework.core.type.classreading.MetadataReaderFactory;
 import org.springframework.util.ClassUtils;
 
 class SpringClasspathScanner extends ClasspathScanner {
-    
+
     private static final Boolean IN_OSGI;
     static {
         IN_OSGI = isSpringInOsgi();
@@ -55,57 +55,57 @@ class SpringClasspathScanner extends ClasspathScanner {
             return true;
         } catch (Throwable ex) {
             return false;
-        }    
+        }
     }
-    
+
     protected Map< Class< ? extends Annotation >, Collection< Class< ? > > > findClassesInternal(
-        Collection< String > basePackages, 
+        Collection< String > basePackages,
         List<Class< ? extends Annotation > > annotations,
-        ClassLoader loader) 
+        ClassLoader loader)
         throws IOException, ClassNotFoundException {
-    
+
         ResourcePatternResolver resolver = getResolver(loader);
         MetadataReaderFactory factory = new CachingMetadataReaderFactory(resolver);
-        
-        final Map< Class< ? extends Annotation >, Collection< Class< ? > > > classes = 
+
+        final Map< Class< ? extends Annotation >, Collection< Class< ? > > > classes =
             new HashMap< Class< ? extends Annotation >, Collection< Class< ? > > >();
-        final Map< Class< ? extends Annotation >, Collection< String > > matchingInterfaces = 
+        final Map< Class< ? extends Annotation >, Collection< String > > matchingInterfaces =
             new HashMap< Class< ? extends Annotation >, Collection< String > >();
         final Map<String, String[]> nonMatchingClasses = new HashMap<String, String[]>();
-        
+
         for (Class< ? extends Annotation > annotation: annotations) {
             classes.put(annotation, new HashSet< Class < ? > >());
             matchingInterfaces.put(annotation, new HashSet< String >());
         }
-        
+
         if (basePackages == null || basePackages.isEmpty()) {
             return classes;
         }
-        
+
         for (final String basePackage: basePackages) {
             final boolean scanAllPackages = basePackage.equals(WILDCARD);
-            final String packageSearchPath = ResourcePatternResolver.CLASSPATH_ALL_URL_PREFIX 
-                + (scanAllPackages ? "" : ClassUtils.convertClassNameToResourcePath(basePackage)) 
+            final String packageSearchPath = ResourcePatternResolver.CLASSPATH_ALL_URL_PREFIX
+                + (scanAllPackages ? "" : ClassUtils.convertClassNameToResourcePath(basePackage))
                 + ALL_CLASS_FILES;
-            
-            final Resource[] resources = resolver.getResources(packageSearchPath);    
-            
-            
+
+            final Resource[] resources = resolver.getResources(packageSearchPath);
+
+
             for (final Resource resource: resources) {
                 final MetadataReader reader = factory.getMetadataReader(resource);
                 final AnnotationMetadata metadata = reader.getAnnotationMetadata();
-                
+
                 if (scanAllPackages && shouldSkip(metadata.getClassName())) {
                     continue;
                 }
-                
+
                 for (Class< ? extends Annotation > annotation: annotations) {
                     boolean concreteClass = !metadata.isInterface() && !metadata.isAbstract();
                     if (metadata.isAnnotated(annotation.getName())) {
                         if (concreteClass) {
                             classes.get(annotation).add(loadClass(metadata.getClassName(), loader));
                         } else {
-                            matchingInterfaces.get(annotation).add(metadata.getClassName());    
+                            matchingInterfaces.get(annotation).add(metadata.getClassName());
                         }
                     } else if (concreteClass && metadata.getInterfaceNames().length > 0) {
                         nonMatchingClasses.put(metadata.getClassName(), metadata.getInterfaceNames());
@@ -125,7 +125,7 @@ class SpringClasspathScanner extends ClasspathScanner {
                 }
             }
         }
-        
+
         for (Map.Entry<Class<? extends Annotation>, Collection<String>> e : matchingInterfaces.entrySet()) {
             if (classes.get(e.getKey()).isEmpty()) {
                 for (String intName : e.getValue()) {
@@ -133,64 +133,64 @@ class SpringClasspathScanner extends ClasspathScanner {
                 }
             }
         }
-        
+
         return classes;
     }
-    
-    protected List<URL> findResourcesInternal(Collection<String> basePackages, 
+
+    protected List<URL> findResourcesInternal(Collection<String> basePackages,
                                               String extension,
-                                              ClassLoader loader) 
+                                              ClassLoader loader)
         throws IOException {
         final List<URL> resourceURLs = new ArrayList<>();
         if (basePackages == null || basePackages.isEmpty()) {
             return resourceURLs;
         }
         ResourcePatternResolver resolver = getResolver(loader);
-        
+
         for (final String basePackage: basePackages) {
             final boolean scanAllPackages = basePackage.equals(WILDCARD);
-            
+
             String theBasePackage = basePackage;
             if (theBasePackage.startsWith(CLASSPATH_URL_SCHEME)) {
                 theBasePackage = theBasePackage.substring(CLASSPATH_URL_SCHEME.length());
             }
-            
-            final String packageSearchPath = ResourcePatternResolver.CLASSPATH_ALL_URL_PREFIX 
-                + (scanAllPackages ? "" : basePackage.contains(WILDCARD) ? basePackage 
+
+            final String packageSearchPath = ResourcePatternResolver.CLASSPATH_ALL_URL_PREFIX
+                + (scanAllPackages ? "" : basePackage.contains(WILDCARD) ? basePackage
                     : ClassUtils.convertClassNameToResourcePath(theBasePackage)) + ALL_FILES + "." + extension;
-            
-            final Resource[] resources = resolver.getResources(packageSearchPath);                        
+
+            final Resource[] resources = resolver.getResources(packageSearchPath);
             for (final Resource resource: resources) {
                 resourceURLs.add(resource.getURL());
-            }                        
+            }
         }
-        
+
         return resourceURLs;
     }
-    
+
     private ResourcePatternResolver getResolver(ClassLoader loader) {
         ResourcePatternResolver resolver = null;
         if (IN_OSGI) {
             resolver = SpringOsgiUtil.getResolver(loader);
-        } 
+        }
         if (resolver == null) {
-            resolver = loader != null 
+            resolver = loader != null
                 ? new PathMatchingResourcePatternResolver(loader) : new PathMatchingResourcePatternResolver();
         }
         return resolver;
     }
-       
+
     private boolean shouldSkip(final String classname) {
         for (String packageToSkip: PACKAGES_TO_SKIP) {
             if (classname.startsWith(packageToSkip)) {
                 return true;
             }
         }
-        
+
         return false;
     }
-    
-    private Class<?> loadClass(String className, ClassLoader loader) 
+
+    private Class<?> loadClass(String className, ClassLoader loader)
         throws ClassNotFoundException {
         if (loader == null) {
             return ClassLoaderUtils.loadClass(className, getClass());

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/SpringOsgiUtil.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/SpringOsgiUtil.java b/core/src/main/java/org/apache/cxf/common/util/SpringOsgiUtil.java
index 26b54b1..e340a10 100644
--- a/core/src/main/java/org/apache/cxf/common/util/SpringOsgiUtil.java
+++ b/core/src/main/java/org/apache/cxf/common/util/SpringOsgiUtil.java
@@ -28,7 +28,7 @@ final class SpringOsgiUtil {
 
     private SpringOsgiUtil() {
     }
-    
+
     public static ResourcePatternResolver getResolver(ClassLoader loader) {
         Bundle bundle = null;
         if (loader == null) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/StringUtils.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/StringUtils.java b/core/src/main/java/org/apache/cxf/common/util/StringUtils.java
index 7b895e2..8fd86a1 100644
--- a/core/src/main/java/org/apache/cxf/common/util/StringUtils.java
+++ b/core/src/main/java/org/apache/cxf/common/util/StringUtils.java
@@ -35,15 +35,15 @@ import java.util.regex.Pattern;
 public final class StringUtils {
     public static final Map<String, Pattern> PATTERN_MAP = new HashMap<String, Pattern>();
     static {
-        String patterns[] = {"/", " ", ":", ",", ";", "=", "\\.", "\\+"}; 
+        String patterns[] = {"/", " ", ":", ",", ";", "=", "\\.", "\\+"};
         for (String p : patterns) {
             PATTERN_MAP.put(p, Pattern.compile(p));
         }
     }
-        
+
     private StringUtils() {
     }
-    
+
     public static String[] split(String s, String regex) {
         Pattern p = PATTERN_MAP.get(regex);
         if (p != null) {
@@ -74,14 +74,14 @@ public final class StringUtils {
         }
         return true;
     }
-    
+
     public static boolean isEmpty(List<String> list) {
         if (list == null || list.size() == 0) {
             return true;
         }
         return list.size() == 1 && isEmpty(list.get(0));
     }
-   
+
     public static String diff(String str1, String str2) {
         int index = str1.lastIndexOf(str2);
         if (index > -1) {
@@ -89,7 +89,7 @@ public final class StringUtils {
         }
         return str1;
     }
-    
+
     public static List<String> getParts(String str, String separator) {
         String[] parts = split(str, separator);
         List<String> ret = new ArrayList<>(parts.length);
@@ -100,7 +100,7 @@ public final class StringUtils {
         }
         return ret;
     }
-    
+
     public static String getFirstNotEmpty(String str, String separator) {
         List<String> parts = Arrays.asList(split(str, separator));
         for (String part : parts) {
@@ -110,7 +110,7 @@ public final class StringUtils {
         }
         return str;
     }
-    
+
     public static String getFirstNotEmpty(List<String> list) {
         if (isEmpty(list)) {
             return null;
@@ -118,11 +118,11 @@ public final class StringUtils {
         for (String item : list) {
             if (!isEmpty(item)) {
                 return item;
-            }       
+            }
         }
         return null;
     }
-    
+
     public static List<String> getFound(String contents, String regex) {
         if (isEmpty(regex) || isEmpty(contents)) {
             return null;
@@ -130,7 +130,7 @@ public final class StringUtils {
         List<String> results = new ArrayList<>();
         Pattern pattern = Pattern.compile(regex, Pattern.UNICODE_CASE);
         Matcher matcher = pattern.matcher(contents);
-        
+
         while (matcher.find()) {
             if (matcher.groupCount() > 0) {
                 results.add(matcher.group(1));
@@ -139,8 +139,8 @@ public final class StringUtils {
             }
         }
         return results;
-    } 
-    
+    }
+
     public static String getFirstFound(String contents, String regex) {
         List<String> founds = getFound(contents, regex);
         if (isEmpty(founds)) {
@@ -148,11 +148,11 @@ public final class StringUtils {
         }
         return founds.get(0);
     }
-    
+
     public static String addDefaultPortIfMissing(String urlString) {
         return addDefaultPortIfMissing(urlString, "80");
     }
-    
+
     public static String addDefaultPortIfMissing(String urlString, String defaultPort) {
         URL url = null;
         try {
@@ -163,16 +163,16 @@ public final class StringUtils {
         if (url.getPort() != -1) {
             return urlString;
         }
-        String regex = "http://([^/]+)";        
+        String regex = "http://([^/]+)";
         String found = StringUtils.getFirstFound(urlString, regex);
         String replacer = "http://" + found + ":" + defaultPort;
-        
+
         if (!StringUtils.isEmpty(found)) {
             urlString = urlString.replaceFirst(regex, replacer);
-        }                
+        }
         return urlString;
     }
- 
+
     /**
      * Return input string with first character in upper case.
      * @param name input string.
@@ -186,7 +186,7 @@ public final class StringUtils {
         chars[0] = Character.toUpperCase(chars[0]);
         return new String(chars);
     }
-    
+
     public static String uncapitalize(String str) {
         if (str == null || str.length() == 0) {
             return str;
@@ -195,8 +195,8 @@ public final class StringUtils {
             .append(Character.toLowerCase(str.charAt(0)))
             .append(str.substring(1))
             .toString();
-    }    
-    
+    }
+
     public static byte[] toBytesUTF8(String str) {
         return toBytes(str, StandardCharsets.UTF_8.name());
     }
@@ -206,7 +206,7 @@ public final class StringUtils {
     public static byte[] toBytes(String str, String enc) {
         try {
             return str.getBytes(enc);
-        } catch (UnsupportedEncodingException ex) { 
+        } catch (UnsupportedEncodingException ex) {
             throw new RuntimeException(ex);
         }
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/SystemPropertyAction.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/SystemPropertyAction.java b/core/src/main/java/org/apache/cxf/common/util/SystemPropertyAction.java
index c2b6cb0..378dee0 100644
--- a/core/src/main/java/org/apache/cxf/common/util/SystemPropertyAction.java
+++ b/core/src/main/java/org/apache/cxf/common/util/SystemPropertyAction.java
@@ -27,7 +27,7 @@ import java.util.logging.Logger;
 import org.apache.cxf.common.logging.LogUtils;
 
 /**
- * 
+ *
  */
 public final class SystemPropertyAction implements PrivilegedAction<String> {
     private static final Logger LOG = LogUtils.getL7dLogger(SystemPropertyAction.class);
@@ -41,7 +41,7 @@ public final class SystemPropertyAction implements PrivilegedAction<String> {
         property = name;
         def = d;
     }
-    
+
     /* (non-Javadoc)
      * @see java.security.PrivilegedAction#run()
      */
@@ -51,11 +51,11 @@ public final class SystemPropertyAction implements PrivilegedAction<String> {
         }
         return System.getProperty(property);
     }
-    
+
     public static String getProperty(String name) {
         return AccessController.doPrivileged(new SystemPropertyAction(name));
     }
-    
+
     public static String getProperty(String name, String def) {
         try {
             return AccessController.doPrivileged(new SystemPropertyAction(name, def));
@@ -66,7 +66,7 @@ public final class SystemPropertyAction implements PrivilegedAction<String> {
     }
 
     /**
-     * Get the system property via the AccessController, but if a SecurityException is 
+     * Get the system property via the AccessController, but if a SecurityException is
      * raised, just return null;
      * @param name
      */

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/common/util/URIParserUtil.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/common/util/URIParserUtil.java b/core/src/main/java/org/apache/cxf/common/util/URIParserUtil.java
index 214e71a..24122f1 100644
--- a/core/src/main/java/org/apache/cxf/common/util/URIParserUtil.java
+++ b/core/src/main/java/org/apache/cxf/common/util/URIParserUtil.java
@@ -90,7 +90,7 @@ public final class URIParserUtil {
 
         List<String> tokens = tokenize(nameSpaceURI, "/: ");
         if (tokens.size() == 0) {
-            return "cxf"; 
+            return "cxf";
         }
 
         if (tokens.size() > 1) {
@@ -218,7 +218,7 @@ public final class URIParserUtil {
 
     public static String escapeChars(String s) {
         StringBuilder b = new StringBuilder(s.length());
-        
+
         for (int x = 0; x < s.length(); x++) {
             char ch = s.charAt(x);
             if (isExcluded(ch)) {
@@ -242,7 +242,7 @@ public final class URIParserUtil {
             result = escapeChars(url.toURI().normalize().toString().replace("\\", "/"));
         } catch (MalformedURLException e1) {
             try {
-                if (uri.startsWith("classpath:")) {                  
+                if (uri.startsWith("classpath:")) {
                     url = ClassLoaderUtils.getResource(uri.substring(10), URIParserUtil.class);
                     return url != null ? url.toExternalForm() : uri;
                 }
@@ -286,7 +286,7 @@ public final class URIParserUtil {
             return normalize(arg);
         }
     }
-    
+
     public static String relativize(String base, String toBeRelativized) throws URISyntaxException {
         if (base == null || toBeRelativized == null) {
             return null;
@@ -298,7 +298,7 @@ public final class URIParserUtil {
      * This is a custom implementation for doing what URI.relativize(URI uri) should be
      * doing but is not actually doing when URI roots do not fully match.
      * See http://bugs.java.com/bugdatabase/view_bug.do?bug_id=6226081
-     * 
+     *
      * @param base              The base URI
      * @param toBeRelativized   The URI to be realivized
      * @return                  The string value of the URI you'd expect to get as result