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

[49/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/annotations/Policy.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/annotations/Policy.java b/core/src/main/java/org/apache/cxf/annotations/Policy.java
index 4c39a7d..cc25779 100644
--- a/core/src/main/java/org/apache/cxf/annotations/Policy.java
+++ b/core/src/main/java/org/apache/cxf/annotations/Policy.java
@@ -34,31 +34,31 @@ import java.lang.annotation.Target;
 @Target({ ElementType.TYPE, ElementType.METHOD })
 @Inherited
 public @interface Policy {
-    
+
     String uri();
-    
+
     boolean includeInWSDL() default true;
-    
-    
+
+
     /**
-     * The place to put the PolicyReference.  The Default depends on the 
+     * The place to put the PolicyReference.  The Default depends on the
      * location of the annotation.   On the method in the SEI, it would be
-     * the binding/operation, on the SEI, it would be the binding, on the 
+     * the binding/operation, on the SEI, it would be the binding, on the
      * service impl, the service element.
      * @return location
      */
     Placement placement() default Placement.DEFAULT;
-    
+
     /**
      * If Placement is PORT_TYPE_OPERATION_FAULT, or BINDING_OPERATION_FAULT,
-     * return the fault class associated with this documentation 
+     * return the fault class associated with this documentation
      * @return the fault class
      */
     Class<?> faultClass() default DEFAULT.class;
-    
+
     enum Placement {
         DEFAULT,
-        
+
         PORT_TYPE,
         PORT_TYPE_OPERATION,
         PORT_TYPE_OPERATION_INPUT,
@@ -74,7 +74,7 @@ public @interface Policy {
         SERVICE,
         SERVICE_PORT,
     };
-    
+
     final class DEFAULT { }
 }
 

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/annotations/Provider.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/annotations/Provider.java b/core/src/main/java/org/apache/cxf/annotations/Provider.java
index 4bf751e..6cff9aa 100644
--- a/core/src/main/java/org/apache/cxf/annotations/Provider.java
+++ b/core/src/main/java/org/apache/cxf/annotations/Provider.java
@@ -28,7 +28,7 @@ import java.lang.annotation.Target;
 public @interface Provider {
     enum Type { InInterceptor, OutInterceptor, InFaultInterceptor, OutFaultInterceptor, Feature }
     enum Scope { Server, Client, All }
-    
+
     Type value();
-    Scope scope() default Scope.All; 
+    Scope scope() default Scope.All;
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/annotations/SchemaValidation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/annotations/SchemaValidation.java b/core/src/main/java/org/apache/cxf/annotations/SchemaValidation.java
index 05d72bd..c138fb2 100644
--- a/core/src/main/java/org/apache/cxf/annotations/SchemaValidation.java
+++ b/core/src/main/java/org/apache/cxf/annotations/SchemaValidation.java
@@ -42,7 +42,7 @@ public @interface SchemaValidation {
      * @return validation type
      */
     SchemaValidationType type() default SchemaValidationType.BOTH;
-    
+
     /**
      * Optional list of schema locations
      * @return schema locations

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/annotations/UseAsyncMethod.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/annotations/UseAsyncMethod.java b/core/src/main/java/org/apache/cxf/annotations/UseAsyncMethod.java
index dd48501..a615d0a 100644
--- a/core/src/main/java/org/apache/cxf/annotations/UseAsyncMethod.java
+++ b/core/src/main/java/org/apache/cxf/annotations/UseAsyncMethod.java
@@ -29,12 +29,12 @@ import java.lang.annotation.Target;
  * Instructs the runtime to dispatch using the async method
  * on service if continuations are available.  This only applies
  * to the JAX-WS frontend at this time.
- * 
+ *
  * Instead of calling the "X methodName(Y, Z...) method, it will
  * call the "Future<?> methodName(Y, Z, ... AsyncHandler<MethodResponse>)"
  * method passing in an AsyncHandler that you will need to call when
  * the response is ready.   An example would be:
- * 
+ *
  * <pre>
  * public Future<?> greetMeAsync(final String requestType,
  *                               final AsyncHandler<GreetMeResponse> asyncHandler) {
@@ -45,13 +45,13 @@ import java.lang.annotation.Target;
  *            GreetMeResponse resp = new GreetMeResponse();
  *            resp.setResponseType("Hello " + requestType);
  *            r.set(resp);
- *            asyncHandler.handleResponse(r);                    
+ *            asyncHandler.handleResponse(r);
  *         }
  *    } .start();
  *    return r;
  * }
  * </pre>
- * 
+ *
  * The use of the org.apache.cxf.jaxws.ServerAsyncResponse class for the response
  * as shown above can simplify things and is recommended.
  */
@@ -60,10 +60,10 @@ import java.lang.annotation.Target;
 @Target({ ElementType.METHOD })
 @Inherited
 public @interface UseAsyncMethod {
-    
+
     /**
-     * By default, if continuations are not available, 
-     * it will use the non-async method.  If you ALWAYS 
+     * By default, if continuations are not available,
+     * it will use the non-async method.  If you ALWAYS
      * want the async method called, set this to true.  However,
      * that can cause threads to block.
      */

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/annotations/UseNio.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/annotations/UseNio.java b/core/src/main/java/org/apache/cxf/annotations/UseNio.java
index ca29f97..3079cae 100644
--- a/core/src/main/java/org/apache/cxf/annotations/UseNio.java
+++ b/core/src/main/java/org/apache/cxf/annotations/UseNio.java
@@ -27,7 +27,7 @@ import java.lang.annotation.RetentionPolicy;
 import java.lang.annotation.Target;
 /**
  * Instructs the runtime to copy the input stream to the output stream using NIO.
- * This annotation will have no effect if continuations are not available  
+ * This annotation will have no effect if continuations are not available
  */
 @Documented
 @Retention(RetentionPolicy.RUNTIME)

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/annotations/WSDLDocumentation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/annotations/WSDLDocumentation.java b/core/src/main/java/org/apache/cxf/annotations/WSDLDocumentation.java
index cecc383..0621bef 100644
--- a/core/src/main/java/org/apache/cxf/annotations/WSDLDocumentation.java
+++ b/core/src/main/java/org/apache/cxf/annotations/WSDLDocumentation.java
@@ -41,31 +41,31 @@ public @interface WSDLDocumentation {
      * @return documentation string
      */
     String value();
-    
+
     /**
-     * The place to put the documentation.  The Default depends on the 
+     * The place to put the documentation.  The Default depends on the
      * location of the annotation.   On the method in the SEI, it would be
-     * the portType/operation, on the SEI, it would be the portType, on the 
+     * the portType/operation, on the SEI, it would be the portType, on the
      * service impl, the service element.
      * @return location
      */
     Placement placement() default Placement.DEFAULT;
-    
+
     /**
      * If Placement is FAULT_MESSAGE, PORT_FAULT, or BINDING_FAULT,
-     * return the fault class associated with this documentation 
+     * return the fault class associated with this documentation
      * @return the fault class
      */
     Class<?> faultClass() default DEFAULT.class;
-    
+
     enum Placement {
         DEFAULT,
         TOP,
-        
+
         INPUT_MESSAGE,
         OUTPUT_MESSAGE,
         FAULT_MESSAGE,
-        
+
         PORT_TYPE,
         PORT_TYPE_OPERATION,
         PORT_TYPE_OPERATION_INPUT,
@@ -80,9 +80,9 @@ public @interface WSDLDocumentation {
 
         SERVICE,
         SERVICE_PORT,
-        
+
     };
-    
+
 
     final class DEFAULT { }
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/annotations/WSDLDocumentationCollection.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/annotations/WSDLDocumentationCollection.java b/core/src/main/java/org/apache/cxf/annotations/WSDLDocumentationCollection.java
index be9dd6c..b3a984b 100644
--- a/core/src/main/java/org/apache/cxf/annotations/WSDLDocumentationCollection.java
+++ b/core/src/main/java/org/apache/cxf/annotations/WSDLDocumentationCollection.java
@@ -29,9 +29,9 @@ import java.lang.annotation.Target;
 
 
 /**
- * Used to attach multiple WSDLDocumentation annotations 
+ * Used to attach multiple WSDLDocumentation annotations
  * to a method or type if documentation needs to be added
- * to more than one place in the wsdl. 
+ * to more than one place in the wsdl.
  */
 @Documented
 @Retention(RetentionPolicy.RUNTIME)
@@ -39,5 +39,5 @@ import java.lang.annotation.Target;
 @Inherited
 public @interface WSDLDocumentationCollection {
     WSDLDocumentation[] value();
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/attachment/AttachmentDataSource.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/attachment/AttachmentDataSource.java b/core/src/main/java/org/apache/cxf/attachment/AttachmentDataSource.java
index d1b64b8..b8773c6 100644
--- a/core/src/main/java/org/apache/cxf/attachment/AttachmentDataSource.java
+++ b/core/src/main/java/org/apache/cxf/attachment/AttachmentDataSource.java
@@ -32,14 +32,14 @@ import org.apache.cxf.message.Message;
 
 public class AttachmentDataSource implements DataSource {
 
-    private final String ct;    
+    private final String ct;
     private CachedOutputStream cache;
     private InputStream ins;
     private DelegatingInputStream delegate;
     private String name;
-    
+
     public AttachmentDataSource(String ctParam, InputStream inParam) throws IOException {
-        this.ct = ctParam;        
+        this.ct = ctParam;
         ins = inParam;
     }
 
@@ -66,7 +66,7 @@ public class AttachmentDataSource implements DataSource {
                 throw cee;
             } finally {
                 try {
-                    ins.close();                
+                    ins.close();
                 } catch (Exception ex) {
                     //ignore
                 }
@@ -83,7 +83,7 @@ public class AttachmentDataSource implements DataSource {
             cache.releaseTempFileHold();
         }
     }
-    
+
     public String getContentType() {
         return ct;
     }
@@ -105,7 +105,7 @@ public class AttachmentDataSource implements DataSource {
     public String getName() {
         return name;
     }
-    
+
     public void setName(String name) {
         this.name = name;
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/attachment/AttachmentDeserializer.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/attachment/AttachmentDeserializer.java b/core/src/main/java/org/apache/cxf/attachment/AttachmentDeserializer.java
index c81ce9e..25c75c7 100644
--- a/core/src/main/java/org/apache/cxf/attachment/AttachmentDeserializer.java
+++ b/core/src/main/java/org/apache/cxf/attachment/AttachmentDeserializer.java
@@ -62,7 +62,7 @@ public class AttachmentDeserializer {
 
     private int pbAmount = 2048;
     private PushbackInputStream stream;
-    private int createCount; 
+    private int createCount;
     private int closedCount;
     private boolean closed;
 
@@ -75,7 +75,7 @@ public class AttachmentDeserializer {
     private Message message;
 
     private InputStream body;
-    
+
     private Set<DelegatingInputStream> loaded = new HashSet<>();
     private List<String> supportedTypes;
 
@@ -87,7 +87,7 @@ public class AttachmentDeserializer {
         this.message = message;
         this.supportedTypes = supportedTypes;
     }
-    
+
     public void initializeAttachments() throws IOException {
         initializeRootMessage();
 
@@ -108,7 +108,7 @@ public class AttachmentDeserializer {
 
         if (AttachmentUtil.isTypeSupported(contentType.toLowerCase(), supportedTypes)) {
             String boundaryString = findBoundaryFromContentType(contentType);
-            if (null == boundaryString) {                
+            if (null == boundaryString) {
                 boundaryString = findBoundaryFromInputStream();
             }
             // If a boundary still wasn't found, throw an exception
@@ -154,7 +154,7 @@ public class AttachmentDeserializer {
         int i = in.read(buf);
         String msg = IOUtils.newStringFromBytes(buf, 0, i);
         in.unread(buf, 0, i);
-        
+
         // Reset the input stream since we'll need it again later
         message.setContent(InputStream.class, in);
 
@@ -162,7 +162,7 @@ public class AttachmentDeserializer {
         Matcher m = INPUT_STREAM_BOUNDARY_PATTERN.matcher(msg);
         return m.find() ? "--" + m.group(1) : null;
     }
-    
+
     public AttachmentImpl readNext() throws IOException {
         // Cache any mime parts that are currently being streamed
         cacheStreamedAttachments();
@@ -263,7 +263,7 @@ public class AttachmentDeserializer {
      * @throws IOException
      */
     private Attachment createAttachment(Map<String, List<String>> headers) throws IOException {
-        InputStream partStream = 
+        InputStream partStream =
             new DelegatingInputStream(new MimeBodyPartInputStream(stream, boundary, pbAmount),
                                       this);
         createCount++;
@@ -308,8 +308,8 @@ public class AttachmentDeserializer {
         stream.unread(v);
         return true;
     }
-    
-    
+
+
 
     private Map<String, List<String>> loadPartHeaders(InputStream in) throws IOException {
         StringBuilder buffer = new StringBuilder(128);

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/attachment/AttachmentImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/attachment/AttachmentImpl.java b/core/src/main/java/org/apache/cxf/attachment/AttachmentImpl.java
index 3b69b0d..29c161f 100644
--- a/core/src/main/java/org/apache/cxf/attachment/AttachmentImpl.java
+++ b/core/src/main/java/org/apache/cxf/attachment/AttachmentImpl.java
@@ -37,7 +37,7 @@ public class AttachmentImpl implements Attachment {
     public AttachmentImpl(String idParam) {
         this.id = idParam;
     }
-    
+
     public AttachmentImpl(String idParam, DataHandler handlerParam) {
         this.id = idParam;
         this.dataHandler = handlerParam;
@@ -65,7 +65,7 @@ public class AttachmentImpl implements Attachment {
         String value = headers.get(name);
         return value == null ? headers.get(name.toLowerCase()) : value;
     }
-    
+
     public Iterator<String> getHeaderNames() {
         return headers.keySet().iterator();
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/attachment/AttachmentSerializer.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/attachment/AttachmentSerializer.java b/core/src/main/java/org/apache/cxf/attachment/AttachmentSerializer.java
index c9878f8..8bc20a3 100644
--- a/core/src/main/java/org/apache/cxf/attachment/AttachmentSerializer.java
+++ b/core/src/main/java/org/apache/cxf/attachment/AttachmentSerializer.java
@@ -45,25 +45,25 @@ import org.apache.cxf.message.Message;
 public class AttachmentSerializer {
     // http://tools.ietf.org/html/rfc2387
     private static final String DEFAULT_MULTIPART_TYPE = "multipart/related";
-    
+
     private String contentTransferEncoding = "binary";
-    
+
     private Message message;
     private String bodyBoundary;
     private OutputStream out;
     private String encoding;
-    
+
     private String multipartType;
     private Map<String, List<String>> rootHeaders = Collections.emptyMap();
     private boolean xop = true;
     private boolean writeOptionalTypeParameters = true;
-    
-        
+
+
     public AttachmentSerializer(Message messageParam) {
         message = messageParam;
     }
 
-    public AttachmentSerializer(Message messageParam, 
+    public AttachmentSerializer(Message messageParam,
                                 String multipartType,
                                 boolean writeOptionalTypeParameters,
                                 Map<String, List<String>> headers) {
@@ -72,9 +72,9 @@ public class AttachmentSerializer {
         this.writeOptionalTypeParameters = writeOptionalTypeParameters;
         this.rootHeaders = headers;
     }
-    
+
     /**
-     * Serialize the beginning of the attachment which includes the MIME 
+     * Serialize the beginning of the attachment which includes the MIME
      * beginning and headers for the root message.
      */
     public void writeProlog() throws IOException {
@@ -93,21 +93,21 @@ public class AttachmentSerializer {
             int pos = bodyCt.indexOf(';');
             // get everything from the semi-colon
             bodyCtParams = bodyCt.substring(pos);
-            bodyCtParamsEscaped = escapeQuotes(bodyCtParams); 
+            bodyCtParamsEscaped = escapeQuotes(bodyCtParams);
             // keep the type/subtype part in bodyCt
             bodyCt = bodyCt.substring(0, pos);
         }
         // Set transport mime type
         String requestMimeType = multipartType == null ? DEFAULT_MULTIPART_TYPE : multipartType;
-        
+
         StringBuilder ct = new StringBuilder();
         ct.append(requestMimeType);
-        
+
         // having xop set to true implies multipart/related, but just in case...
-        boolean xopOrMultipartRelated = xop 
+        boolean xopOrMultipartRelated = xop
             || DEFAULT_MULTIPART_TYPE.equalsIgnoreCase(requestMimeType)
             || DEFAULT_MULTIPART_TYPE.startsWith(requestMimeType);
-        
+
         // type is a required parameter for multipart/related only
         if (xopOrMultipartRelated
             && requestMimeType.indexOf("type=") == -1) {
@@ -115,16 +115,16 @@ public class AttachmentSerializer {
                 ct.append("; type=\"application/xop+xml\"");
             } else {
                 ct.append("; type=\"").append(bodyCt).append("\"");
-            }    
+            }
         }
-        
+
         // boundary
         ct.append("; boundary=\"")
             .append(bodyBoundary)
             .append("\"");
-            
+
         String rootContentId = getHeaderValue("Content-ID", AttachmentUtil.BODY_ATTACHMENT_ID);
-        
+
         // 'start' is a required parameter for XOP/MTOM, clearly defined
         // for simpler multipart/related payloads but is not needed for
         // multipart/mixed, multipart/form-data
@@ -133,7 +133,7 @@ public class AttachmentSerializer {
                 .append(checkAngleBrackets(rootContentId))
                 .append(">\"");
         }
-        
+
         // start-info is a required parameter for XOP/MTOM, may be needed for
         // other WS cases but is redundant in simpler multipart/related cases
         // the parameters need to be included within the start-info's value in the escaped form
@@ -145,11 +145,11 @@ public class AttachmentSerializer {
             }
             ct.append("\"");
         }
-        
-        
+
+
         message.put(Message.CONTENT_TYPE, ct.toString());
 
-        
+
         // 2. write headers
         out = message.getContent(OutputStream.class);
         encoding = (String) message.get(Message.ENCODING);
@@ -159,7 +159,7 @@ public class AttachmentSerializer {
         StringWriter writer = new StringWriter();
         writer.write("--");
         writer.write(bodyBoundary);
-        
+
         StringBuilder mimeBodyCt = new StringBuilder();
         String bodyType = getHeaderValue("Content-Type", null);
         if (bodyType == null) {
@@ -177,15 +177,15 @@ public class AttachmentSerializer {
         } else {
             mimeBodyCt.append(bodyType);
         }
-        
+
         writeHeaders(mimeBodyCt.toString(), rootContentId, rootHeaders, writer);
         out.write(writer.getBuffer().toString().getBytes(encoding));
     }
 
     private static String escapeQuotes(String s) {
-        return s.indexOf('"') != 0 ? s.replace("\"", "\\\"") : s;    
+        return s.indexOf('"') != 0 ? s.replace("\"", "\\\"") : s;
     }
-    
+
     public void setContentTransferEncoding(String cte) {
         contentTransferEncoding = cte;
     }
@@ -204,8 +204,8 @@ public class AttachmentSerializer {
         }
         return sb.toString();
     }
-    
-    private void writeHeaders(String contentType, String attachmentId, 
+
+    private void writeHeaders(String contentType, String attachmentId,
                                      Map<String, List<String>> headers, Writer writer) throws IOException {
         writer.write("\r\nContent-Type: ");
         writer.write(contentType);
@@ -235,17 +235,17 @@ public class AttachmentSerializer {
             }
             writer.write("\r\n");
         }
-        
+
         writer.write("\r\n");
     }
 
-    private static String checkAngleBrackets(String value) { 
+    private static String checkAngleBrackets(String value) {
         if (value.charAt(0) == '<' && value.charAt(value.length() - 1) == '>') {
             return value.substring(1, value.length() - 1);
-        }    
+        }
         return value;
     }
-    
+
     /**
      * Write the end of the body boundary and any attachments included.
      * @throws IOException
@@ -253,10 +253,10 @@ public class AttachmentSerializer {
     public void writeAttachments() throws IOException {
         if (message.getAttachments() != null) {
             for (Attachment a : message.getAttachments()) {
-                StringWriter writer = new StringWriter();                
+                StringWriter writer = new StringWriter();
                 writer.write("\r\n--");
                 writer.write(bodyBoundary);
-                
+
                 Map<String, List<String>> headers = null;
                 Iterator<String> it = a.getHeaderNames();
                 if (it.hasNext()) {
@@ -268,11 +268,11 @@ public class AttachmentSerializer {
                 } else {
                     headers = Collections.emptyMap();
                 }
-                
-                
+
+
                 DataHandler handler = a.getDataHandler();
                 handler.setCommandMap(AttachmentUtil.getCommandMap());
-                
+
                 writeHeaders(handler.getContentType(), a.getId(),
                              headers, writer);
                 out.write(writer.getBuffer().toString().getBytes(encoding));
@@ -283,7 +283,7 @@ public class AttachmentSerializer {
                 }
             }
         }
-        StringWriter writer = new StringWriter();                
+        StringWriter writer = new StringWriter();
         writer.write("\r\n--");
         writer.write(bodyBoundary);
         writer.write("--");
@@ -313,7 +313,7 @@ public class AttachmentSerializer {
         }
         return total;
     }
-    
+
     public boolean isXop() {
         return xop;
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/attachment/AttachmentUtil.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/attachment/AttachmentUtil.java b/core/src/main/java/org/apache/cxf/attachment/AttachmentUtil.java
index 037de30..c6dd731 100644
--- a/core/src/main/java/org/apache/cxf/attachment/AttachmentUtil.java
+++ b/core/src/main/java/org/apache/cxf/attachment/AttachmentUtil.java
@@ -62,14 +62,14 @@ import org.apache.cxf.message.MessageUtils;
 
 public final class AttachmentUtil {
     public static final String BODY_ATTACHMENT_ID = "root.message@cxf.apache.org";
-    
+
     private static volatile int counter;
     private static final String ATT_UUID = UUID.randomUUID().toString();
-    
+
     private static final Random BOUND_RANDOM = new Random();
     private static final CommandMap DEFAULT_COMMAND_MAP = CommandMap.getDefaultCommandMap();
     private static final MailcapCommandMap COMMAND_MAP = new EnhancedMailcapCommandMap();
-    
+
     static final class EnhancedMailcapCommandMap extends MailcapCommandMap {
         @Override
         public synchronized DataContentHandler createDataContentHandler(
@@ -96,7 +96,7 @@ public final class AttachmentUtil {
             CommandInfo[] commands = super.getAllCommands(mimeType);
             CommandInfo[] defaultCommands = DEFAULT_COMMAND_MAP.getAllCommands(mimeType);
             List<CommandInfo> cmdList = new ArrayList<>(Arrays.asList(commands));
-            
+
             // Add CommandInfo which does not exist in current command map.
             for (CommandInfo defCmdInfo : defaultCommands) {
                 String defCmdName = defCmdInfo.getCommandName();
@@ -111,7 +111,7 @@ public final class AttachmentUtil {
                     cmdList.add(defCmdInfo);
                 }
             }
-            
+
             CommandInfo[] allCommandArray = new CommandInfo[0];
             return cmdList.toArray(allCommandArray);
         }
@@ -145,22 +145,22 @@ public final class AttachmentUtil {
     private AttachmentUtil() {
 
     }
-    
+
     static {
-        COMMAND_MAP.addMailcap("image/*;;x-java-content-handler=" 
+        COMMAND_MAP.addMailcap("image/*;;x-java-content-handler="
                                + ImageDataContentHandler.class.getName());
     }
 
     public static CommandMap getCommandMap() {
         return COMMAND_MAP;
     }
-    
+
     public static boolean isMtomEnabled(Message message) {
-        Object prop = message.getContextualProperty(Message.MTOM_ENABLED); 
+        Object prop = message.getContextualProperty(Message.MTOM_ENABLED);
         return MessageUtils.isTrue(prop);
     }
-    
-    public static void setStreamedAttachmentProperties(Message message, CachedOutputStream bos) 
+
+    public static void setStreamedAttachmentProperties(Message message, CachedOutputStream bos)
         throws IOException {
         Object directory = message.getContextualProperty(AttachmentDeserializer.ATTACHMENT_DIRECTORY);
         if (directory != null) {
@@ -170,7 +170,7 @@ public final class AttachmentUtil {
                 bos.setOutputDir(new File((String)directory));
             }
         }
-        
+
         Object threshold = message.getContextualProperty(AttachmentDeserializer.ATTACHMENT_MEMORY_THRESHOLD);
         if (threshold != null) {
             if (threshold instanceof Long) {
@@ -191,11 +191,11 @@ public final class AttachmentUtil {
             }
         }
     }
-    
+
     public static String createContentID(String ns) throws UnsupportedEncodingException {
         // tend to change
         String cid = "cxf.apache.org";
-        
+
         String name = ATT_UUID + "-" + String.valueOf(++counter);
         if (ns != null && (ns.length() > 0)) {
             try {
@@ -210,7 +210,7 @@ public final class AttachmentUtil {
                 cid = ns;
             }
         }
-        return URLEncoder.encode(name, StandardCharsets.UTF_8.name()) + "@" 
+        return URLEncoder.encode(name, StandardCharsets.UTF_8.name()) + "@"
             + URLEncoder.encode(cid, StandardCharsets.UTF_8.name());
     }
 
@@ -225,15 +225,15 @@ public final class AttachmentUtil {
             mostSigBits = BOUND_RANDOM.nextLong();
             leastSigBits = BOUND_RANDOM.nextLong();
         }
-        
+
         mostSigBits &= 0xFFFFFFFFFFFF0FFFL;  //clear version
         mostSigBits |= 0x0000000000004000L;  //set version
 
         leastSigBits &= 0x3FFFFFFFFFFFFFFFL; //clear the variant
         leastSigBits |= 0x8000000000000000L; //set to IETF variant
-        
+
         UUID result = new UUID(mostSigBits, leastSigBits);
-        
+
         return "uuid:" + result.toString();
     }
 
@@ -263,7 +263,7 @@ public final class AttachmentUtil {
         }
         return dataHandlers == null ? new LinkedHashMap<String, DataHandler>() : dataHandlers;
     }
-    
+
     static class DHMap extends AbstractMap<String, DataHandler> {
         final Collection<Attachment> list;
         DHMap(Collection<Attachment> l) {
@@ -322,9 +322,9 @@ public final class AttachmentUtil {
             }
             list.add(new AttachmentImpl(key, value));
             return ret;
-        }        
+        }
     }
-    
+
     public static String cleanContentId(String id) {
         if (id != null) {
             if (id.startsWith("<")) {
@@ -348,7 +348,7 @@ public final class AttachmentUtil {
         }
         return id;
     }
-    
+
     static String getHeaderValue(List<String> v) {
         if (v != null && v.size() > 0) {
             return v.get(0);
@@ -374,19 +374,19 @@ public final class AttachmentUtil {
     static String getHeader(Map<String, List<String>> headers, String h, String delim) {
         return getHeaderValue(headers.get(h), delim);
     }
-    public static Attachment createAttachment(InputStream stream, Map<String, List<String>> headers) 
+    public static Attachment createAttachment(InputStream stream, Map<String, List<String>> headers)
         throws IOException {
-     
+
         String id = cleanContentId(getHeader(headers, "Content-ID"));
 
         AttachmentImpl att = new AttachmentImpl(id);
-        
+
         final String ct = getHeader(headers, "Content-Type");
         String cd = getHeader(headers, "Content-Disposition");
         String fileName = getContentDispositionFileName(cd);
-        
+
         String encoding = null;
-        
+
         for (Map.Entry<String, List<String>> e : headers.entrySet()) {
             String name = e.getKey();
             if (name.equalsIgnoreCase("Content-Transfer-Encoding")) {
@@ -400,20 +400,20 @@ public final class AttachmentUtil {
         if (encoding == null) {
             encoding = "binary";
         }
-        DataSource source = new AttachmentDataSource(ct, 
+        DataSource source = new AttachmentDataSource(ct,
                                                      decode(stream, encoding));
         if (!StringUtils.isEmpty(fileName)) {
             ((AttachmentDataSource)source).setName(fileName);
         }
-        att.setDataHandler(new DataHandler(source));        
+        att.setDataHandler(new DataHandler(source));
         return att;
     }
-    
+
     static String getContentDispositionFileName(String cd) {
         if (StringUtils.isEmpty(cd)) {
             return null;
         }
-        //TODO: save ContentDisposition directly 
+        //TODO: save ContentDisposition directly
         ContentDisposition c = new ContentDisposition(cd);
         String s = c.getParameter("filename");
         if (s == null) {
@@ -421,13 +421,13 @@ public final class AttachmentUtil {
         }
         return s;
     }
-    
+
     public static InputStream decode(InputStream in, String encoding) throws IOException {
         encoding = encoding.toLowerCase();
 
         // some encodings are just pass-throughs, with no real decoding.
-        if ("binary".equals(encoding) 
-            || "7bit".equals(encoding) 
+        if ("binary".equals(encoding)
+            || "7bit".equals(encoding)
             || "8bit".equals(encoding)) {
             return in;
         } else if ("base64".equals(encoding)) {
@@ -437,7 +437,7 @@ public final class AttachmentUtil {
         } else {
             throw new IOException("Unknown encoding " + encoding);
         }
-    }    
+    }
     public static boolean isTypeSupported(String contentType, List<String> types) {
         if (contentType == null) {
             return false;
@@ -451,15 +451,15 @@ public final class AttachmentUtil {
         return false;
     }
 
-    public static Attachment createMtomAttachment(boolean isXop, String mimeType, String elementNS, 
+    public static Attachment createMtomAttachment(boolean isXop, String mimeType, String elementNS,
                                                  byte[] data, int offset, int length, int threshold) {
         if (!isXop || length <= threshold) {
             return null;
-        }        
+        }
         if (mimeType == null) {
             mimeType = "application/octet-stream";
         }
-        
+
         ByteDataSource source = new ByteDataSource(data, offset, length);
         source.setContentType(mimeType);
         DataHandler handler = new DataHandler(source);
@@ -474,12 +474,12 @@ public final class AttachmentUtil {
         att.setXOP(isXop);
         return att;
     }
-    
+
     public static Attachment createMtomAttachmentFromDH(
         boolean isXop, DataHandler handler, String elementNS, int threshold) {
         if (!isXop) {
             return null;
-        }        
+        }
 
         // The following is just wrong. Even if the DataHandler has a stream, we should still
         // apply the threshold.
@@ -493,7 +493,7 @@ public final class AttachmentUtil {
                 }
             } else if (ds.getClass().getName().endsWith("ObjectDataSource")) {
                 Object o = handler.getContent();
-                if (o instanceof String 
+                if (o instanceof String
                     && ((String)o).length() < threshold) {
                     return null;
                 } else if (o instanceof byte[] && ((byte[])o).length < threshold) {
@@ -503,7 +503,7 @@ public final class AttachmentUtil {
         } catch (IOException e1) {
         //      ignore, just do the normal attachment thing
         }
-        
+
         String id;
         try {
             id = AttachmentUtil.createContentID(elementNS);
@@ -542,11 +542,11 @@ public final class AttachmentUtil {
                 throw new Fault(e);
             }
         }
-        
+
     }
 
     private static DataSource loadDataSource(String contentId, Collection<Attachment> atts) {
         return new LazyDataSource(contentId, atts);
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/attachment/Base64DecoderStream.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/attachment/Base64DecoderStream.java b/core/src/main/java/org/apache/cxf/attachment/Base64DecoderStream.java
index 6f0a97f..70f24cf 100644
--- a/core/src/main/java/org/apache/cxf/attachment/Base64DecoderStream.java
+++ b/core/src/main/java/org/apache/cxf/attachment/Base64DecoderStream.java
@@ -85,7 +85,7 @@ public class Base64DecoderStream extends FilterInputStream {
             } catch (Base64Exception e) {
                 throw new IOException(e);
             }
-            decodedCount = decodedChars.length; 
+            decodedCount = decodedChars.length;
             return true;
         }
         return false;
@@ -102,7 +102,7 @@ public class Base64DecoderStream extends FilterInputStream {
             return -1;
         }
         decodedCount--;
-        // we need to ensure this doesn't get sign extended 
+        // we need to ensure this doesn't get sign extended
         return decodedChars[decodedIndex++] & 0xff;
     }
 

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/attachment/ContentDisposition.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/attachment/ContentDisposition.java b/core/src/main/java/org/apache/cxf/attachment/ContentDisposition.java
index 2632e57..7cdda31 100644
--- a/core/src/main/java/org/apache/cxf/attachment/ContentDisposition.java
+++ b/core/src/main/java/org/apache/cxf/attachment/ContentDisposition.java
@@ -58,7 +58,7 @@ public class ContentDisposition {
         while (m.find()) {
             String paramName = null;
             String paramValue = "";
-            
+
             String groupValue = m.group().trim();
             int eqIndex = groupValue.indexOf('=');
             if (eqIndex > 0) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/attachment/DelegatingInputStream.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/attachment/DelegatingInputStream.java b/core/src/main/java/org/apache/cxf/attachment/DelegatingInputStream.java
index 4b33aeb..a4e8095 100644
--- a/core/src/main/java/org/apache/cxf/attachment/DelegatingInputStream.java
+++ b/core/src/main/java/org/apache/cxf/attachment/DelegatingInputStream.java
@@ -112,7 +112,7 @@ public class DelegatingInputStream extends InputStream implements Transferable {
         this.is = inputStream;
     }
 
-    
+
     public InputStream getInputStream() {
         return is;
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/attachment/ImageDataContentHandler.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/attachment/ImageDataContentHandler.java b/core/src/main/java/org/apache/cxf/attachment/ImageDataContentHandler.java
index 8bd0223..2b28980 100644
--- a/core/src/main/java/org/apache/cxf/attachment/ImageDataContentHandler.java
+++ b/core/src/main/java/org/apache/cxf/attachment/ImageDataContentHandler.java
@@ -43,7 +43,7 @@ import javax.imageio.stream.ImageOutputStream;
 import org.apache.cxf.helpers.IOUtils;
 
 /**
- * 
+ *
  */
 public class ImageDataContentHandler implements DataContentHandler {
     private static final DataFlavor[] FLAVORS;
@@ -57,9 +57,9 @@ public class ImageDataContentHandler implements DataContentHandler {
     }
 
     public ImageDataContentHandler() {
-        
+
     }
-    
+
     public Object getContent(DataSource ds) throws IOException {
         return ImageIO.read(ds.getInputStream());
     }
@@ -83,9 +83,9 @@ public class ImageDataContentHandler implements DataContentHandler {
             Iterator<ImageWriter> writers = ImageIO.getImageWritersByMIMEType(mimeType);
             if (writers.hasNext()) {
                 ImageWriter writer = writers.next();
-                
+
                 BufferedImage bimg = convertToBufferedImage((Image)obj);
-                ImageOutputStream out = ImageIO.createImageOutputStream(os); 
+                ImageOutputStream out = ImageIO.createImageOutputStream(os);
                 writer.setOutput(out);
                 writer.write(bimg);
                 writer.dispose();
@@ -101,7 +101,7 @@ public class ImageDataContentHandler implements DataContentHandler {
             FileInputStream file = new FileInputStream((File)obj);
             IOUtils.copyAndCloseInput(file, os);
         } else {
-            throw new IOException("Attachment type not spported " + obj.getClass());                    
+            throw new IOException("Attachment type not spported " + obj.getClass());
         }
 
     }
@@ -109,10 +109,10 @@ public class ImageDataContentHandler implements DataContentHandler {
         if (image instanceof BufferedImage) {
             return (BufferedImage)image;
         }
-        
+
         // Wait until the image is completely loaded
         MediaTracker tracker = new MediaTracker(new Component() {
-            private static final long serialVersionUID = 977142547536262901L; 
+            private static final long serialVersionUID = 977142547536262901L;
         });
         tracker.addImage(image, 0);
         try {
@@ -122,7 +122,7 @@ public class ImageDataContentHandler implements DataContentHandler {
             ioe.initCause(e);
             throw ioe;
         }
-        
+
         // Create a BufferedImage so we can write it out later
         BufferedImage bufImage = new BufferedImage(
                 image.getWidth(null),

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/attachment/LazyAttachmentCollection.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/attachment/LazyAttachmentCollection.java b/core/src/main/java/org/apache/cxf/attachment/LazyAttachmentCollection.java
index 85f0364..b9d6ad6 100644
--- a/core/src/main/java/org/apache/cxf/attachment/LazyAttachmentCollection.java
+++ b/core/src/main/java/org/apache/cxf/attachment/LazyAttachmentCollection.java
@@ -32,12 +32,12 @@ import javax.activation.DataHandler;
 
 import org.apache.cxf.message.Attachment;
 
-public class LazyAttachmentCollection 
+public class LazyAttachmentCollection
     implements Collection<Attachment> {
-    
+
     private AttachmentDeserializer deserializer;
     private final List<Attachment> attachments = new ArrayList<>();
-    
+
     public LazyAttachmentCollection(AttachmentDeserializer deserializer) {
         super();
         this.deserializer = deserializer;
@@ -73,7 +73,7 @@ public class LazyAttachmentCollection
                 return true;
             }
             return false;
-        } 
+        }
         return deserializer.hasNext();
     }
 
@@ -84,12 +84,12 @@ public class LazyAttachmentCollection
         return new Iterator<Attachment>() {
             int current;
             boolean removed;
-            
+
             public boolean hasNext() {
                 if (attachments.size() > current) {
                     return true;
                 }
-                
+
                 // check if there is another attachment
                 try {
                     Attachment a = deserializer.readNext();
@@ -118,13 +118,13 @@ public class LazyAttachmentCollection
                 attachments.remove(--current);
                 removed = true;
             }
-            
+
         };
     }
-    
+
     public int size() {
         loadAll();
-        
+
         return attachments.size();
     }
 
@@ -137,7 +137,7 @@ public class LazyAttachmentCollection
     }
 
     public void clear() {
-        attachments.clear();   
+        attachments.clear();
     }
 
     public boolean contains(Object arg0) {
@@ -169,27 +169,27 @@ public class LazyAttachmentCollection
 
     public Object[] toArray() {
         loadAll();
-        
+
         return attachments.toArray();
     }
 
     public <T> T[] toArray(T[] arg0) {
         loadAll();
-        
+
         return attachments.toArray(arg0);
     }
-    
+
     public Map<String, DataHandler> createDataHandlerMap() {
         return new LazyAttachmentMap(this);
     }
 
     private static class LazyAttachmentMap implements Map<String, DataHandler> {
         LazyAttachmentCollection collection;
-        
+
         LazyAttachmentMap(LazyAttachmentCollection c) {
             collection = c;
         }
-        
+
         public void clear() {
             collection.clear();
         }
@@ -233,7 +233,7 @@ public class LazyAttachmentCollection
         public int size() {
             return collection.size();
         }
-        
+
         public DataHandler remove(Object key) {
             Iterator<Attachment> it = collection.iterator();
             while (it.hasNext()) {
@@ -257,7 +257,7 @@ public class LazyAttachmentCollection
             }
         }
 
-        
+
         public Set<Map.Entry<String, DataHandler>> entrySet() {
             return new AbstractSet<Map.Entry<String, DataHandler>>() {
                 public Iterator<Map.Entry<String, DataHandler>> iterator() {
@@ -345,7 +345,7 @@ public class LazyAttachmentCollection
                 }
             };
         }
-        
+
     }
 
 

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/attachment/LazyDataSource.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/attachment/LazyDataSource.java b/core/src/main/java/org/apache/cxf/attachment/LazyDataSource.java
index bfae1e6..3b1c32d 100644
--- a/core/src/main/java/org/apache/cxf/attachment/LazyDataSource.java
+++ b/core/src/main/java/org/apache/cxf/attachment/LazyDataSource.java
@@ -31,7 +31,7 @@ import javax.activation.DataSource;
 import org.apache.cxf.message.Attachment;
 
 /**
- * A DataSource which will search through a Collection of attachments so as to 
+ * A DataSource which will search through a Collection of attachments so as to
  * lazily load the attachment from the collection. This allows streaming attachments
  * with databinding toolkits like JAXB.
  */
@@ -39,7 +39,7 @@ public class LazyDataSource implements DataSource {
     private DataSource dataSource;
     private Collection<Attachment> attachments;
     private String id;
-    
+
     public LazyDataSource(String id, Collection<Attachment> attachments) {
         super();
         this.id = id;
@@ -77,34 +77,34 @@ public class LazyDataSource implements DataSource {
             }
         }
     }
-    
+
     public String getContentType() {
         load();
-        
+
         return dataSource.getContentType();
     }
 
     public InputStream getInputStream() throws IOException {
         load();
-        
+
         return dataSource.getInputStream();
     }
 
     public String getName() {
         load();
-        
+
         return dataSource.getName();
     }
 
     public OutputStream getOutputStream() throws IOException {
         load();
-        
+
         return dataSource.getOutputStream();
     }
 
     public DataSource getDataSource() {
         load();
-        
+
         return dataSource;
     }
 

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/attachment/MimeBodyPartInputStream.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/attachment/MimeBodyPartInputStream.java b/core/src/main/java/org/apache/cxf/attachment/MimeBodyPartInputStream.java
index f8cfc5a..2d9c7da 100644
--- a/core/src/main/java/org/apache/cxf/attachment/MimeBodyPartInputStream.java
+++ b/core/src/main/java/org/apache/cxf/attachment/MimeBodyPartInputStream.java
@@ -34,7 +34,7 @@ public class MimeBodyPartInputStream extends InputStream {
 
     private boolean closed;
 
-    public MimeBodyPartInputStream(PushbackInputStream inStreamParam, 
+    public MimeBodyPartInputStream(PushbackInputStream inStreamParam,
                                    byte[] boundaryParam,
                                    int pbsize) {
         super();
@@ -50,7 +50,7 @@ public class MimeBodyPartInputStream extends InputStream {
         if (boundaryFound || closed) {
             return -1;
         }
-        if ((off < 0) || (off > b.length) || (len < 0) 
+        if ((off < 0) || (off > b.length) || (len < 0)
             || ((off + len) > b.length) || ((off + len) < 0)) {
 
             throw new IndexOutOfBoundsException();
@@ -60,7 +60,7 @@ public class MimeBodyPartInputStream extends InputStream {
         }
         boolean bufferCreated = false;
         if (len < boundary.length * 2) {
-            //buffer is too short to detect boundaries with it.  We'll need to create a larger buffer   
+            //buffer is too short to detect boundaries with it.  We'll need to create a larger buffer
             bufferCreated = true;
             if (boundaryBuffer == null) {
                 boundaryBuffer = new byte[boundary.length * 2];
@@ -85,7 +85,7 @@ public class MimeBodyPartInputStream extends InputStream {
             return -1;
         }
         len = idx;
-        
+
         int i = processBuffer(b, off, len);
         if (bufferCreated && i > 0) {
             // read more than we need, push it back
@@ -99,7 +99,7 @@ public class MimeBodyPartInputStream extends InputStream {
         } else if (i == 0 && boundaryFound) {
             return -1;
         }
-        
+
         return i;
     }
 
@@ -110,7 +110,7 @@ public class MimeBodyPartInputStream extends InputStream {
             return true;
         } else if (pointer >= 1000000000) {
             inStream.unread(b, initialPointer, (off + len) - initialPointer);
-            return false;            
+            return false;
         } else {
             int x = inStream.read();
             if (x != -1) {
@@ -155,7 +155,7 @@ public class MimeBodyPartInputStream extends InputStream {
             while ((boundaryIndex < boundary.length) && (value == boundary[boundaryIndex])) {
                 if (!hasData(buffer, initialI, i + 1, off, len)) {
                     return initialI - off;
-                }                
+                }
                 value = buffer[++i];
                 boundaryIndex++;
             }
@@ -164,7 +164,7 @@ public class MimeBodyPartInputStream extends InputStream {
                 if (initialI != off) {
                     i = 1000000000;
                 }
-                if (initialI - off != 0 
+                if (initialI - off != 0
                     && !hasData(buffer, initialI, i + 1, off, len)) {
                     return initialI - off;
                 }
@@ -265,12 +265,12 @@ public class MimeBodyPartInputStream extends InputStream {
             inStream.unread(10);
             value = 13;
         } else {
-            inStream.unread(boundary, 1, boundaryIndex - 1);                
+            inStream.unread(boundary, 1, boundaryIndex - 1);
             value = boundary[0];
         }
         return value;
     }
-    
+
     public void close() throws IOException {
         this.closed = true;
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/binding/AbstractBindingFactory.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/binding/AbstractBindingFactory.java b/core/src/main/java/org/apache/cxf/binding/AbstractBindingFactory.java
index 8943c22..85fb093 100644
--- a/core/src/main/java/org/apache/cxf/binding/AbstractBindingFactory.java
+++ b/core/src/main/java/org/apache/cxf/binding/AbstractBindingFactory.java
@@ -40,7 +40,7 @@ public abstract class AbstractBindingFactory implements BindingFactory {
 
     public AbstractBindingFactory() {
     }
-    
+
     public AbstractBindingFactory(Collection<String> ns) {
         activationNamespaces = ns;
     }
@@ -48,13 +48,13 @@ public abstract class AbstractBindingFactory implements BindingFactory {
         bus = b;
         registerWithBindingManager();
     }
-    
+
     public AbstractBindingFactory(Bus b, Collection<String> ns) {
         activationNamespaces = ns;
         bus = b;
         registerWithBindingManager();
     }
-    
+
     private void registerWithBindingManager() {
         if (bus != null && activationNamespaces != null) {
             BindingFactoryManager manager = bus.getExtension(BindingFactoryManager.class);

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/binding/Binding.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/binding/Binding.java b/core/src/main/java/org/apache/cxf/binding/Binding.java
index 10989d1..380b450 100644
--- a/core/src/main/java/org/apache/cxf/binding/Binding.java
+++ b/core/src/main/java/org/apache/cxf/binding/Binding.java
@@ -24,29 +24,29 @@ import org.apache.cxf.message.Message;
 import org.apache.cxf.service.model.BindingInfo;
 
 /**
- * A Binding provides interceptors and message creation logic for a 
+ * A Binding provides interceptors and message creation logic for a
  * specific protocol binding.
  */
 public interface Binding extends InterceptorProvider {
-    
+
     /**
      * Create a Message for this Binding.
      * @return the Binding message
      */
     Message createMessage();
-    
+
     /**
      * Create a Message form the message.
-     * 
+     *
      * @param m the message used for creating a binding message
      * @return the Binding message
-     */ 
+     */
     Message createMessage(Message m);
-    
+
     /**
      * Get the BindingInfo for this binding.
      *
-     * @return the BingdingInfo Object     
+     * @return the BingdingInfo Object
      */
     BindingInfo getBindingInfo();
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/binding/BindingFactory.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/binding/BindingFactory.java b/core/src/main/java/org/apache/cxf/binding/BindingFactory.java
index e844c85..990be98 100644
--- a/core/src/main/java/org/apache/cxf/binding/BindingFactory.java
+++ b/core/src/main/java/org/apache/cxf/binding/BindingFactory.java
@@ -28,29 +28,29 @@ import org.apache.cxf.transport.Destination;
  * A factory interface for creating Bindings from BindingInfo metadata.
  */
 public interface BindingFactory {
-    
+
     /**
      * Create a Binding from the BindingInfo metadata.
-     * 
+     *
      * @param binding
      * @return the Binding object
      */
     Binding createBinding(BindingInfo binding);
 
     /**
-     * Create a "default" BindingInfo object for the service. Can return a subclass. 
+     * Create a "default" BindingInfo object for the service. Can return a subclass.
      * @param service
      * @param namespace
      * @param configObject - binding specific configuration object
      * @return the BindingInfo object
      */
     BindingInfo createBindingInfo(Service service, String namespace, Object configObject);
-    
+
     /**
      * Set the destination's message observer which is created by using the endpoint to
      * listen the incoming message
-     * @param d the destination that will be set the MessageObserver 
-     * @param e the endpoint to build up the MessageObserver      
+     * @param d the destination that will be set the MessageObserver
+     * @param e the endpoint to build up the MessageObserver
      */
     void addListener(Destination d, Endpoint e);
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/binding/BindingFactoryManager.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/binding/BindingFactoryManager.java b/core/src/main/java/org/apache/cxf/binding/BindingFactoryManager.java
index a13a37a..361e5da 100644
--- a/core/src/main/java/org/apache/cxf/binding/BindingFactoryManager.java
+++ b/core/src/main/java/org/apache/cxf/binding/BindingFactoryManager.java
@@ -22,7 +22,7 @@ package org.apache.cxf.binding;
 import org.apache.cxf.BusException;
 
 /**
- * The manager interface represents a repository for accessing 
+ * The manager interface represents a repository for accessing
  * <code>BindingFactory</code>s.
  *
  * Provides methods necessary for registering, unregistering or retrieving of
@@ -38,7 +38,7 @@ public interface BindingFactoryManager {
      * BindingFactory interface.
      */
     void registerBindingFactory(String name, BindingFactory binding);
-    
+
     /**
      * Deregisters the BindingFactory with the provided name.
      *

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/bus/CXFBusFactory.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/bus/CXFBusFactory.java b/core/src/main/java/org/apache/cxf/bus/CXFBusFactory.java
index 80524c8..b576621 100644
--- a/core/src/main/java/org/apache/cxf/bus/CXFBusFactory.java
+++ b/core/src/main/java/org/apache/cxf/bus/CXFBusFactory.java
@@ -27,15 +27,15 @@ import org.apache.cxf.BusFactory;
 import org.apache.cxf.bus.extension.ExtensionManagerBus;
 
 public class CXFBusFactory extends BusFactory {
-    
+
     public Bus createBus() {
         return createBus(new HashMap<Class<?>, Object>());
     }
-    
+
     public Bus createBus(Map<Class<?>, Object> e) {
         return createBus(e, new HashMap<String, Object>());
     }
-    
+
     public Bus createBus(Map<Class<?>, Object> e, Map<String, Object> properties) {
         ExtensionManagerBus bus = new ExtensionManagerBus(e, properties);
         possiblySetDefaultBus(bus);
@@ -43,5 +43,5 @@ public class CXFBusFactory extends BusFactory {
         bus.initialize();
         return bus;
     }
- 
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/bus/ManagedBus.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/bus/ManagedBus.java b/core/src/main/java/org/apache/cxf/bus/ManagedBus.java
index b249e4e..7060e00 100644
--- a/core/src/main/java/org/apache/cxf/bus/ManagedBus.java
+++ b/core/src/main/java/org/apache/cxf/bus/ManagedBus.java
@@ -29,23 +29,23 @@ import org.apache.cxf.management.ManagementConstants;
 import org.apache.cxf.management.annotation.ManagedOperation;
 import org.apache.cxf.management.annotation.ManagedResource;
 
-@ManagedResource(componentName = "Bus", 
+@ManagedResource(componentName = "Bus",
                  description = "Responsible for managing services.")
-                 
+
 public class ManagedBus implements ManagedComponent {
     private static final String TYPE_VALUE = "Bus";
     private static final String INSTANCE_ID = "managed.bus.instance.id";
     private final Bus bus;
-    
+
     public ManagedBus(Bus b) {
         bus = b;
     }
-        
-    @ManagedOperation       
+
+    @ManagedOperation
     public void shutdown(boolean wait) {
         bus.shutdown(wait);
     }
-    
+
     public ObjectName getObjectName() throws JMException {
         String busId = bus.getId();
         StringBuilder buffer = new StringBuilder(ManagementConstants.DEFAULT_DOMAIN_NAME).append(':');
@@ -57,7 +57,7 @@ public class ManagedBus implements ManagedComponent {
             instanceId = new StringBuilder().append(bus.hashCode()).toString();
         }
         buffer.append(ManagementConstants.INSTANCE_ID_PROP).append('=').append(instanceId);
-        
+
 
         return new ObjectName(buffer.toString());
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/bus/blueprint/BlueprintBeanLocator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/bus/blueprint/BlueprintBeanLocator.java b/core/src/main/java/org/apache/cxf/bus/blueprint/BlueprintBeanLocator.java
index 1a91eae..be91e3a 100644
--- a/core/src/main/java/org/apache/cxf/bus/blueprint/BlueprintBeanLocator.java
+++ b/core/src/main/java/org/apache/cxf/bus/blueprint/BlueprintBeanLocator.java
@@ -41,16 +41,16 @@ import org.osgi.service.blueprint.reflect.BeanProperty;
 import org.osgi.service.blueprint.reflect.ComponentMetadata;
 
 /**
- * 
+ *
  */
 public class BlueprintBeanLocator implements ConfiguredBeanLocator {
     private static final Logger LOG = LogUtils.getL7dLogger(BlueprintBeanLocator.class);
     ConfiguredBeanLocator orig;
     BlueprintContainer container;
     BundleContext context;
-    
-    public BlueprintBeanLocator(ConfiguredBeanLocator orig, 
-                                BlueprintContainer cont, 
+
+    public BlueprintBeanLocator(ConfiguredBeanLocator orig,
+                                BlueprintContainer cont,
                                 BundleContext context) {
         this.orig = orig;
         this.container = cont;
@@ -60,14 +60,14 @@ public class BlueprintBeanLocator implements ConfiguredBeanLocator {
             ((ExtensionManagerImpl)orig).removeBeansOfNames(names);
         }
     }
-    
+
     static Class<?> getClassForMetaData(BlueprintContainer container, ComponentMetadata cmd) {
         Class<?> cls = null;
         if (cmd instanceof BeanMetadata) {
             BeanMetadata bm = (BeanMetadata)cmd;
             if (bm instanceof ExtendedBeanMetadata) {
                 cls = ((ExtendedBeanMetadata)bm).getRuntimeClass();
-            } 
+            }
             if (cls == null && container instanceof ExtendedBlueprintContainer && bm.getClassName() != null) {
                 try {
                     cls = ((ExtendedBlueprintContainer)container).loadClass(bm.getClassName());
@@ -88,9 +88,9 @@ public class BlueprintBeanLocator implements ConfiguredBeanLocator {
             return null;
         }
     }
-    
+
     public <T> T getBeanOfType(String name, Class<T> type) {
-        
+
         ComponentMetadata cmd = getComponentMetadata(name);
         Class<?> cls = getClassForMetaData(cmd);
         if (cls != null && type.isAssignableFrom(cls)) {
@@ -115,7 +115,7 @@ public class BlueprintBeanLocator implements ConfiguredBeanLocator {
     /** {@inheritDoc}*/
     public <T> Collection<? extends T> getBeansOfType(Class<T> type) {
         List<T> list = new ArrayList<>();
-        
+
         for (String s : container.getComponentIds()) {
             ComponentMetadata cmd = container.getComponentMetadata(s);
             Class<?> cls = getClassForMetaData(cmd);
@@ -133,12 +133,12 @@ public class BlueprintBeanLocator implements ConfiguredBeanLocator {
                 }
             } catch (Exception ex) {
                 //ignore, just don't support the OSGi services
-                LOG.info("Try to find the Bean with type:" + type 
-                    + " from OSGi services and get error: " + ex);  
+                LOG.info("Try to find the Bean with type:" + type
+                    + " from OSGi services and get error: " + ex);
             }
         }
         list.addAll(orig.getBeansOfType(type));
-        
+
         return list;
     }
 
@@ -166,7 +166,7 @@ public class BlueprintBeanLocator implements ConfiguredBeanLocator {
                 loaded = true;
             }
         }
-        
+
         try {
             if (context != null) {
                 ServiceReference refs[] = context.getServiceReferences(type.getName(), null);
@@ -185,9 +185,9 @@ public class BlueprintBeanLocator implements ConfiguredBeanLocator {
             }
         } catch (Exception ex) {
             //ignore, just don't support the OSGi services
-            LOG.info("Try to find the Bean with type:" + type 
-                + " from OSGi services and get error: " + ex);  
-        }        
+            LOG.info("Try to find the Bean with type:" + type
+                + " from OSGi services and get error: " + ex);
+        }
         return orig.loadBeansOfType(type, listener) || loaded;
     }
 
@@ -209,7 +209,7 @@ public class BlueprintBeanLocator implements ConfiguredBeanLocator {
         ComponentMetadata cmd = getComponentMetadata(name);
         if (cmd instanceof BeanMetadata) {
             return true;
-        }        
+        }
         return orig.hasBeanOfName(name);
     }
 

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/bus/blueprint/BlueprintBus.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/bus/blueprint/BlueprintBus.java b/core/src/main/java/org/apache/cxf/bus/blueprint/BlueprintBus.java
index e1aeb7f..4388393 100644
--- a/core/src/main/java/org/apache/cxf/bus/blueprint/BlueprintBus.java
+++ b/core/src/main/java/org/apache/cxf/bus/blueprint/BlueprintBus.java
@@ -31,23 +31,23 @@ import org.osgi.framework.BundleContext;
 import org.osgi.service.blueprint.container.BlueprintContainer;
 
 /**
- * 
+ *
  */
 public class BlueprintBus extends ExtensionManagerBus {
     BundleContext context;
     BlueprintContainer container;
-    
+
     public BlueprintBus() {
         // Using the BlueprintBus Classloader to load the extensions
         super(null, null, BlueprintBus.class.getClassLoader());
     }
-    
+
     public void setBundleContext(final BundleContext c) {
         context = c;
         ClassLoader bundleClassLoader =
             AccessController.doPrivileged(new PrivilegedAction<ClassLoader>() {
                 public ClassLoader run() {
-                    return new BundleDelegatingClassLoader(c.getBundle(), 
+                    return new BundleDelegatingClassLoader(c.getBundle(),
                                                            this.getClass().getClassLoader());
                 }
             });
@@ -69,7 +69,7 @@ public class BlueprintBus extends ExtensionManagerBus {
             if (context == null) {
                 id = super.getId();
             } else {
-                id = context.getBundle().getSymbolicName() + "-" 
+                id = context.getBundle().getSymbolicName() + "-"
                     + DEFAULT_BUS_ID + Integer.toString(this.hashCode());
             }
         }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/bus/blueprint/BlueprintNameSpaceHandlerFactory.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/bus/blueprint/BlueprintNameSpaceHandlerFactory.java b/core/src/main/java/org/apache/cxf/bus/blueprint/BlueprintNameSpaceHandlerFactory.java
index 7f5d27c..ccabfbb 100644
--- a/core/src/main/java/org/apache/cxf/bus/blueprint/BlueprintNameSpaceHandlerFactory.java
+++ b/core/src/main/java/org/apache/cxf/bus/blueprint/BlueprintNameSpaceHandlerFactory.java
@@ -23,7 +23,7 @@ public interface BlueprintNameSpaceHandlerFactory {
      * Creates aries blueprint NamespaceHandler.
      * The return type is untyped as aries blueprint is an
      * optional import
-     *  
+     *
      * @return handler
      */
     Object createNamespaceHandler();

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/bus/blueprint/BundleDelegatingClassLoader.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/bus/blueprint/BundleDelegatingClassLoader.java b/core/src/main/java/org/apache/cxf/bus/blueprint/BundleDelegatingClassLoader.java
index 8314211..acd89df 100644
--- a/core/src/main/java/org/apache/cxf/bus/blueprint/BundleDelegatingClassLoader.java
+++ b/core/src/main/java/org/apache/cxf/bus/blueprint/BundleDelegatingClassLoader.java
@@ -56,13 +56,13 @@ public class BundleDelegatingClassLoader extends ClassLoader {
             });
         } catch (PrivilegedActionException e) {
             Exception cause = e.getException();
-          
+
             if (cause instanceof ClassNotFoundException) {
                 throw (ClassNotFoundException)cause;
             } else {
                 throw (RuntimeException)cause;
             }
-        }    
+        }
     }
 
     protected URL findResource(final String name) {
@@ -70,7 +70,7 @@ public class BundleDelegatingClassLoader extends ClassLoader {
             public URL run() {
                 return bundle.getResource(name);
             }
-        });        
+        });
         if (classLoader != null && resource == null) {
             resource = classLoader.getResource(name);
         }
@@ -85,23 +85,23 @@ public class BundleDelegatingClassLoader extends ClassLoader {
                 public Enumeration<URL> run() throws IOException {
                     return bundle.getResources(name);
                 }
-          
+
             });
         } catch (PrivilegedActionException e) {
             Exception cause = e.getException();
-        
+
             if (cause instanceof IOException) {
                 throw (IOException)cause;
             } else {
                 throw (RuntimeException)cause;
             }
         }
-      
+
         if (urls == null) {
             urls = Collections.enumeration(new ArrayList<>());
         }
-      
-        return urls;    
+
+        return urls;
     }
 
     protected Class<?> loadClass(String name, boolean resolve) throws ClassNotFoundException {
@@ -113,11 +113,11 @@ public class BundleDelegatingClassLoader extends ClassLoader {
                 try {
                     clazz = classLoader.loadClass(name);
                 } catch (ClassNotFoundException e) {
-                    throw new ClassNotFoundException(name + " from bundle " + bundle.getBundleId() 
+                    throw new ClassNotFoundException(name + " from bundle " + bundle.getBundleId()
                                                      + " (" + bundle.getSymbolicName() + ")", cnfe);
                 }
             } else {
-                throw new ClassNotFoundException(name + " from bundle " + bundle.getBundleId() 
+                throw new ClassNotFoundException(name + " from bundle " + bundle.getBundleId()
                                                  + " (" + bundle.getSymbolicName() + ")", cnfe);
             }
         }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/bus/blueprint/BusDefinitionParser.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/bus/blueprint/BusDefinitionParser.java b/core/src/main/java/org/apache/cxf/bus/blueprint/BusDefinitionParser.java
index 2ea3559..57ae5f3 100644
--- a/core/src/main/java/org/apache/cxf/bus/blueprint/BusDefinitionParser.java
+++ b/core/src/main/java/org/apache/cxf/bus/blueprint/BusDefinitionParser.java
@@ -28,12 +28,12 @@ import org.apache.cxf.common.util.StringUtils;
 import org.apache.cxf.configuration.blueprint.AbstractBPBeanDefinitionParser;
 import org.osgi.service.blueprint.reflect.Metadata;
 
-public class BusDefinitionParser 
+public class BusDefinitionParser
     extends AbstractBPBeanDefinitionParser {
 
     public BusDefinitionParser() {
     }
-    
+
     public Metadata parse(Element element, ParserContext context) {
         String bname = element.hasAttribute("bus") ? element.getAttribute("bus") : "cxf";
         String id = element.hasAttribute("id") ? element.getAttribute("id") : null;
@@ -46,7 +46,7 @@ public class BusDefinitionParser
         }
         return cxfBean;
     }
-    protected void processBusAttribute(Element element, ParserContext ctx, 
+    protected void processBusAttribute(Element element, ParserContext ctx,
                                        MutableBeanMetadata bean, String val) {
         //nothing
     }
@@ -61,7 +61,7 @@ public class BusDefinitionParser
             || "outInterceptors".equals(name) || "outFaultInterceptors".equals(name)
             || "features".equals(name)) {
             bean.addProperty(name, parseListData(ctx, bean, el));
-        } else if ("properties".equals(name)) { 
+        } else if ("properties".equals(name)) {
             bean.addProperty(name, parseMapData(ctx, bean, el));
         }
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/bus/blueprint/ConfigurerImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/bus/blueprint/ConfigurerImpl.java b/core/src/main/java/org/apache/cxf/bus/blueprint/ConfigurerImpl.java
index 03a8f17..f90567d 100644
--- a/core/src/main/java/org/apache/cxf/bus/blueprint/ConfigurerImpl.java
+++ b/core/src/main/java/org/apache/cxf/bus/blueprint/ConfigurerImpl.java
@@ -39,12 +39,12 @@ import org.osgi.service.blueprint.reflect.BeanMetadata;
 import org.osgi.service.blueprint.reflect.ComponentMetadata;
 
 /**
- * 
+ *
  */
 public class ConfigurerImpl implements Configurer {
     private static final Logger LOG = LogUtils.getL7dLogger(ConfigurerImpl.class);
     BlueprintContainer container;
-    
+
     private final Map<String, List<MatcherHolder>> wildCardBeanDefinitions
         = new TreeMap<String, List<MatcherHolder>>();
 
@@ -63,8 +63,8 @@ public class ConfigurerImpl implements Configurer {
             return literalCharsLen1.compareTo(literalCharsLen2) * -1;
         }
     }
-    
-    
+
+
     public ConfigurerImpl(BlueprintContainer con) {
         container = con;
         initializeWildcardMap();
@@ -83,7 +83,7 @@ public class ConfigurerImpl implements Configurer {
                     String orig = s;
                     if (s.charAt(0) == '*') {
                         //old wildcard
-                        s = "." + s.replaceAll("\\.", "\\."); 
+                        s = "." + s.replaceAll("\\.", "\\.");
                     }
                     Matcher matcher = Pattern.compile(s).matcher("");
                     List<MatcherHolder> m = wildCardBeanDefinitions.get(cls.getName());
@@ -101,7 +101,7 @@ public class ConfigurerImpl implements Configurer {
     public void configureBean(Object beanInstance) {
         configureBean(null, beanInstance, true);
     }
-    
+
     public void configureBean(String bn, Object beanInstance) {
         configureBean(bn, beanInstance, true);
     }
@@ -109,14 +109,14 @@ public class ConfigurerImpl implements Configurer {
         if (null == bn) {
             bn = getBeanName(beanInstance);
         }
-        
+
         if (null == bn) {
             return;
         }
         if (checkWildcards) {
             configureWithWildCard(bn, beanInstance);
         }
-        
+
         if (container instanceof ExtendedBlueprintContainer) {
             ComponentMetadata cm = null;
             try {
@@ -129,10 +129,10 @@ public class ConfigurerImpl implements Configurer {
             }
         }
     }
-    
+
     private void configureWithWildCard(String bn, Object beanInstance) {
         if (!wildCardBeanDefinitions.isEmpty()) {
-            Class<?> clazz = beanInstance.getClass();            
+            Class<?> clazz = beanInstance.getClass();
             while (!Object.class.equals(clazz)) {
                 String className = clazz.getName();
                 List<MatcherHolder> matchers = wildCardBeanDefinitions.get(className);
@@ -174,13 +174,13 @@ public class ConfigurerImpl implements Configurer {
                 LogUtils.log(LOG, Level.WARNING, "ERROR_DETERMINING_BEAN_NAME_EXC", ex);
             }
         }
-        
+
         if (null == beanName) {
             LogUtils.log(LOG, Level.FINE, "COULD_NOT_DETERMINE_BEAN_NAME_MSG",
                          beanInstance.getClass().getName());
         }
-      
+
         return beanName;
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/bus/extension/Extension.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/bus/extension/Extension.java b/core/src/main/java/org/apache/cxf/bus/extension/Extension.java
index 376869b..644a878 100644
--- a/core/src/main/java/org/apache/cxf/bus/extension/Extension.java
+++ b/core/src/main/java/org/apache/cxf/bus/extension/Extension.java
@@ -34,7 +34,7 @@ import org.apache.cxf.common.util.StringUtils;
 
 public class Extension {
     protected static final Logger LOG = LogUtils.getL7dLogger(Extension.class);
-    
+
     protected String className;
     protected ClassLoader classloader;
     protected volatile Class<?> clazz;
@@ -46,10 +46,10 @@ public class Extension {
     protected volatile Object obj;
     protected boolean optional;
     protected boolean notFound;
-    
+
     public Extension() {
     }
-    
+
     public Extension(Class<?> cls, Class<?> inf) {
         clazz = cls;
         intf = inf;
@@ -65,7 +65,7 @@ public class Extension {
     public Extension(ClassLoader loader) {
         classloader = loader;
     }
-    
+
     public Extension(Extension ext) {
         className = ext.className;
         interfaceName = ext.interfaceName;
@@ -78,21 +78,21 @@ public class Extension {
         args = ext.args;
         optional = ext.optional;
     }
-    
+
     public void setOptional(boolean b) {
         optional = b;
     }
     public boolean isOptional() {
         return optional;
     }
-    
+
     public String getName() {
         return StringUtils.isEmpty(interfaceName) ? className : interfaceName;
     }
     public Object getLoadedObject() {
         return obj;
     }
-    
+
     public Extension cloneNoObject() {
         Extension ext = new Extension(this);
         ext.obj = null;
@@ -100,7 +100,7 @@ public class Extension {
         ext.intf = null;
         return ext;
     }
-    
+
     public String toString() {
         StringBuilder buf = new StringBuilder();
         buf.append("class: ");
@@ -119,19 +119,19 @@ public class Extension {
             n++;
         }
         buf.append(")");
-        return buf.toString();        
+        return buf.toString();
     }
-    
+
     public String getClassname() {
         return className;
     }
-    
+
     public void setClassname(String i) {
         clazz = null;
         notFound = false;
         className = i;
     }
-       
+
     public String getInterfaceName() {
         return interfaceName;
     }
@@ -144,19 +144,19 @@ public class Extension {
     public boolean isDeferred() {
         return deferred;
     }
-    
+
     public void setDeferred(boolean d) {
         deferred = d;
     }
-    
+
     public Collection<String> getNamespaces() {
         return namespaces;
     }
-    
+
     public void setArgs(Object a[]) {
         args = a;
     }
-    
+
     protected Class<?> tryClass(String name, ClassLoader cl) {
         Throwable origEx = null;
         if (classloader != null) {
@@ -167,7 +167,7 @@ public class Extension {
                 //save the exception though as this is likely the important one
                 origEx = nex;
             }
-        }                
+        }
         try {
             return cl.loadClass(name);
         } catch (Throwable ex) {
@@ -186,7 +186,7 @@ public class Extension {
         }
         return null;
     }
-    
+
     public Class<?> getClassObject(ClassLoader cl) {
         if (notFound) {
             return null;
@@ -230,14 +230,14 @@ public class Extension {
                     } else {
                         obj = con.newInstance(b, args);
                     }
-                    return obj;                    
+                    return obj;
                 } else if (args != null) {
                     Constructor<?> con = cls.getConstructor(Object[].class);
                     obj = con.newInstance(args);
-                    return obj;                    
+                    return obj;
                 }
             } catch (InvocationTargetException ex) {
-                throw new ExtensionException(new Message("PROBLEM_CREATING_EXTENSION_CLASS", LOG, cls.getName()), 
+                throw new ExtensionException(new Message("PROBLEM_CREATING_EXTENSION_CLASS", LOG, cls.getName()),
                                              ex.getCause());
             } catch (InstantiationException ex) {
                 throw new ExtensionException(new Message("PROBLEM_CREATING_EXTENSION_CLASS", LOG, cls.getName()), ex);
@@ -257,7 +257,7 @@ public class Extension {
         } catch (InvocationTargetException ex) {
             notFound = true;
             if (!optional) {
-                throw new ExtensionException(new Message("PROBLEM_CREATING_EXTENSION_CLASS", LOG, cls.getName()), 
+                throw new ExtensionException(new Message("PROBLEM_CREATING_EXTENSION_CLASS", LOG, cls.getName()),
                                              ex.getCause());
             } else {
                 LOG.log(Level.FINE, "Could not load optional extension " + getName(), (Throwable)ex);
@@ -287,7 +287,7 @@ public class Extension {
         }
         return obj;
     }
-    
+
     public Class<?> loadInterface(ClassLoader cl) {
         if (intf != null || notFound) {
             return intf;
@@ -299,6 +299,6 @@ public class Extension {
         }
         return intf;
     }
-    
-    
+
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/bus/extension/ExtensionException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/bus/extension/ExtensionException.java b/core/src/main/java/org/apache/cxf/bus/extension/ExtensionException.java
index 7610cfa..7f20145 100644
--- a/core/src/main/java/org/apache/cxf/bus/extension/ExtensionException.java
+++ b/core/src/main/java/org/apache/cxf/bus/extension/ExtensionException.java
@@ -25,7 +25,7 @@ import org.apache.cxf.common.i18n.UncheckedException;
 public class ExtensionException extends UncheckedException {
 
     private static final long serialVersionUID = 1L;
-    
+
     /**
      * Constructs a <code>ExtensionException</code> with the provided detail message.
      */

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/core/src/main/java/org/apache/cxf/bus/extension/ExtensionManager.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/cxf/bus/extension/ExtensionManager.java b/core/src/main/java/org/apache/cxf/bus/extension/ExtensionManager.java
index eb0e6fc..396e784 100644
--- a/core/src/main/java/org/apache/cxf/bus/extension/ExtensionManager.java
+++ b/core/src/main/java/org/apache/cxf/bus/extension/ExtensionManager.java
@@ -21,9 +21,9 @@ package org.apache.cxf.bus.extension;
 
 public interface ExtensionManager {
     void activateAll();
-    
+
     <T> void activateAllByType(Class<T> type);
-    
+
     <T> T getExtension(String ns, Class<T> type);
-    
+
 }