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

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

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-brave/src/main/java/org/apache/cxf/tracing/brave/jaxrs/BraveContextProvider.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-brave/src/main/java/org/apache/cxf/tracing/brave/jaxrs/BraveContextProvider.java b/integration/tracing/tracing-brave/src/main/java/org/apache/cxf/tracing/brave/jaxrs/BraveContextProvider.java
index d75fa9d..4294eda 100644
--- a/integration/tracing/tracing-brave/src/main/java/org/apache/cxf/tracing/brave/jaxrs/BraveContextProvider.java
+++ b/integration/tracing/tracing-brave/src/main/java/org/apache/cxf/tracing/brave/jaxrs/BraveContextProvider.java
@@ -28,7 +28,7 @@ import org.apache.cxf.tracing.brave.BraveTracerContext;
 
 public class BraveContextProvider implements ContextProvider< TracerContext > {
     private final Brave brave;
-    
+
     public BraveContextProvider(final Brave brave) {
         this.brave = brave;
     }
@@ -37,13 +37,13 @@ public class BraveContextProvider implements ContextProvider< TracerContext > {
     public TracerContext createContext(final Message message) {
         // Check if there is a server span passed along with the message
         final ServerSpan continuationSpan = message.get(ServerSpan.class);
-        
-        // If server span is already present, let us check if it is detached 
+
+        // If server span is already present, let us check if it is detached
         // (asynchronous invocation)
         if (continuationSpan != null) {
             return new BraveTracerContext(brave, continuationSpan);
         }
-        
+
         return new BraveTracerContext(brave);
     }
 

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-brave/src/main/java/org/apache/cxf/tracing/brave/jaxrs/BraveFeature.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-brave/src/main/java/org/apache/cxf/tracing/brave/jaxrs/BraveFeature.java b/integration/tracing/tracing-brave/src/main/java/org/apache/cxf/tracing/brave/jaxrs/BraveFeature.java
index 8fdc1da..3ad14b8 100644
--- a/integration/tracing/tracing-brave/src/main/java/org/apache/cxf/tracing/brave/jaxrs/BraveFeature.java
+++ b/integration/tracing/tracing-brave/src/main/java/org/apache/cxf/tracing/brave/jaxrs/BraveFeature.java
@@ -27,11 +27,11 @@ import com.github.kristofa.brave.Brave;
 
 public class BraveFeature implements Feature {
     private final Brave brave;
-    
+
     public BraveFeature() {
         this("cxf-svc-" + UUID.randomUUID().toString());
     }
-    
+
     public BraveFeature(final String name) {
         this(new Brave.Builder(name).build());
     }
@@ -39,7 +39,7 @@ public class BraveFeature implements Feature {
     public BraveFeature(final Brave brave) {
         this.brave = brave;
     }
-    
+
     @Override
     public boolean configure(FeatureContext context) {
         context.register(new BraveProvider(brave));

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-brave/src/main/java/org/apache/cxf/tracing/brave/jaxrs/BraveProvider.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-brave/src/main/java/org/apache/cxf/tracing/brave/jaxrs/BraveProvider.java b/integration/tracing/tracing-brave/src/main/java/org/apache/cxf/tracing/brave/jaxrs/BraveProvider.java
index cfd917a..e4f4f33 100644
--- a/integration/tracing/tracing-brave/src/main/java/org/apache/cxf/tracing/brave/jaxrs/BraveProvider.java
+++ b/integration/tracing/tracing-brave/src/main/java/org/apache/cxf/tracing/brave/jaxrs/BraveProvider.java
@@ -36,36 +36,36 @@ import com.github.kristofa.brave.ServerSpan;
 import org.apache.cxf.tracing.brave.AbstractBraveProvider;
 
 @Provider
-public class BraveProvider extends AbstractBraveProvider 
+public class BraveProvider extends AbstractBraveProvider
     implements ContainerRequestFilter, ContainerResponseFilter {
-    @Context 
+    @Context
     private ResourceInfo resourceInfo;
-    
+
     public BraveProvider(final Brave brave) {
         super(brave);
     }
 
     @Override
     public void filter(final ContainerRequestContext requestContext) throws IOException {
-        final TraceScopeHolder<ServerSpan> holder = super.startTraceSpan(requestContext.getHeaders(), 
+        final TraceScopeHolder<ServerSpan> holder = super.startTraceSpan(requestContext.getHeaders(),
                                                 requestContext.getUriInfo().getRequestUri(),
                                                 requestContext.getMethod());
-        
+
         if (holder != null) {
             requestContext.setProperty(TRACE_SPAN, holder);
         }
     }
-    
+
     @SuppressWarnings("unchecked")
     @Override
     public void filter(final ContainerRequestContext requestContext,
             final ContainerResponseContext responseContext) throws IOException {
-        super.stopTraceSpan(requestContext.getHeaders(), 
-                            responseContext.getHeaders(), 
+        super.stopTraceSpan(requestContext.getHeaders(),
+                            responseContext.getHeaders(),
                             responseContext.getStatus(),
                             (TraceScopeHolder<ServerSpan>)requestContext.getProperty(TRACE_SPAN));
     }
-    
+
     @Override
     protected boolean isAsyncResponse() {
         for (final Annotation[] annotations: resourceInfo.getResourceMethod().getParameterAnnotations()) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-brave/src/test/java/org/apache/cxf/tracing/brave/BraveTraceTest.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-brave/src/test/java/org/apache/cxf/tracing/brave/BraveTraceTest.java b/integration/tracing/tracing-brave/src/test/java/org/apache/cxf/tracing/brave/BraveTraceTest.java
index 7a70a18..af30930 100644
--- a/integration/tracing/tracing-brave/src/test/java/org/apache/cxf/tracing/brave/BraveTraceTest.java
+++ b/integration/tracing/tracing-brave/src/test/java/org/apache/cxf/tracing/brave/BraveTraceTest.java
@@ -36,7 +36,7 @@ import zipkin.Span;
 import zipkin.reporter.Reporter;
 
 public class BraveTraceTest {
-    
+
     private static final String ADDRESS = "http://localhost:8182";
     private Server server;
     private BraveFeature logging;
@@ -61,12 +61,12 @@ public class BraveTraceTest {
         Assert.assertEquals(2, localReporter.spans.size());
 
     }
-    
+
     @After
     public void stopServer() {
         server.destroy();
     }
-    
+
     private static Server createServer(Feature logging) {
         JaxWsServerFactoryBean factory = new JaxWsServerFactoryBean();
         factory.setAddress(ADDRESS);
@@ -74,7 +74,7 @@ public class BraveTraceTest {
         factory.setFeatures(Arrays.asList(logging));
         return factory.create();
     }
-    
+
     private static MyService createProxy(Feature trace) {
         JaxWsProxyFactoryBean factory = new JaxWsProxyFactoryBean();
         factory.setServiceClass(MyService.class);
@@ -87,12 +87,12 @@ public class BraveTraceTest {
         Brave brave = new Brave.Builder("myservice").reporter(reporter).build();
         return new BraveFeature(brave);
     }
-    
+
     private static BraveClientFeature createClientLoggingFeature(Reporter<Span> reporter) {
         Brave brave = new Brave.Builder("myservice").reporter(reporter).build();
         return new BraveClientFeature(brave);
     }
-    
+
     static final class Localreporter implements Reporter<Span> {
         List<Span> spans = new ArrayList<>();
 
@@ -100,7 +100,7 @@ public class BraveTraceTest {
         public void report(Span span) {
             spans.add(span);
         }
-        
+
     }
 
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-brave/src/test/java/org/apache/cxf/tracing/brave/LoggingSpanNameProvider.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-brave/src/test/java/org/apache/cxf/tracing/brave/LoggingSpanNameProvider.java b/integration/tracing/tracing-brave/src/test/java/org/apache/cxf/tracing/brave/LoggingSpanNameProvider.java
index 5751e2c..867d548 100644
--- a/integration/tracing/tracing-brave/src/test/java/org/apache/cxf/tracing/brave/LoggingSpanNameProvider.java
+++ b/integration/tracing/tracing-brave/src/test/java/org/apache/cxf/tracing/brave/LoggingSpanNameProvider.java
@@ -25,7 +25,7 @@ public class LoggingSpanNameProvider implements SpanNameProvider {
 
     @Override
     public String spanName(HttpRequest request) {
-        return (request instanceof SpanNameProvider) ? ((SpanNameProvider)request).spanName(request) : ""; 
+        return (request instanceof SpanNameProvider) ? ((SpanNameProvider)request).spanName(request) : "";
     }
 
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceClientInterceptor.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceClientInterceptor.java b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceClientInterceptor.java
index 1358bd8..b632dd0 100644
--- a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceClientInterceptor.java
+++ b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceClientInterceptor.java
@@ -26,16 +26,16 @@ import org.apache.cxf.message.Message;
 import org.apache.cxf.phase.PhaseInterceptor;
 import org.apache.htrace.core.Tracer;
 
-public abstract class AbstractHTraceClientInterceptor extends AbstractHTraceClientProvider 
+public abstract class AbstractHTraceClientInterceptor extends AbstractHTraceClientProvider
         implements PhaseInterceptor<Message> {
-    
+
     private String phase;
 
     protected AbstractHTraceClientInterceptor(final String phase, final Tracer tracer) {
         super(tracer);
         this.phase = phase;
     }
-    
+
     public Collection<PhaseInterceptor<? extends Message>> getAdditionalInterceptors() {
         return null;
     }
@@ -55,7 +55,7 @@ public abstract class AbstractHTraceClientInterceptor extends AbstractHTraceClie
     public String getPhase() {
         return phase;
     }
-    
+
     public void handleFault(Message message) {
     }
 

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceClientProvider.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceClientProvider.java b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceClientProvider.java
index 5d6e2ac..88dd10b 100644
--- a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceClientProvider.java
+++ b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceClientProvider.java
@@ -30,44 +30,44 @@ import org.apache.htrace.core.Span;
 import org.apache.htrace.core.TraceScope;
 import org.apache.htrace.core.Tracer;
 
-public abstract class AbstractHTraceClientProvider extends AbstractTracingProvider { 
+public abstract class AbstractHTraceClientProvider extends AbstractTracingProvider {
     protected static final Logger LOG = LogUtils.getL7dLogger(AbstractHTraceClientProvider.class);
     protected static final String TRACE_SPAN = "org.apache.cxf.tracing.client.htrace.span";
-        
+
     private final Tracer tracer;
-        
+
     public AbstractHTraceClientProvider(final Tracer tracer) {
         this.tracer = tracer;
     }
 
-    protected TraceScopeHolder<TraceScope> startTraceSpan(final Map<String, List<String>> requestHeaders, 
+    protected TraceScopeHolder<TraceScope> startTraceSpan(final Map<String, List<String>> requestHeaders,
             String path, String method) {
 
         Span span = Tracer.getCurrentSpan();
         TraceScope traceScope = null;
-        
+
         if (span == null) {
             traceScope = tracer.newScope(buildSpanDescription(path, method));
             span = traceScope.getSpan();
         }
-        
+
         if (span != null) {
             final String spanIdHeader = getSpanIdHeader();
             // Transfer tracing headers into the response headers
             requestHeaders.put(spanIdHeader, Collections.singletonList(span.getSpanId().toString()));
         }
-        
-        // In case of asynchronous client invocation, the span should be detached as JAX-RS 
+
+        // In case of asynchronous client invocation, the span should be detached as JAX-RS
         // client request / response filters are going to be executed in different threads.
         boolean detached = false;
         if (isAsyncInvocation() && traceScope != null) {
             traceScope.detach();
             detached = true;
         }
-        
+
         return new TraceScopeHolder<TraceScope>(traceScope, detached);
     }
-    
+
     private boolean isAsyncInvocation() {
         return !JAXRSUtils.getCurrentMessage().getExchange().isSynchronous();
     }
@@ -76,13 +76,13 @@ public abstract class AbstractHTraceClientProvider extends AbstractTracingProvid
         if (holder == null) {
             return;
         }
-        
+
         final TraceScope scope = holder.getScope();
         if (scope != null) {
-            // If the client invocation was asynchronous , the trace scope has been created 
+            // If the client invocation was asynchronous , the trace scope has been created
             // in another thread and should be re-attached to the current one.
             if (holder.isDetached()) {
-                scope.reattach(); 
+                scope.reattach();
                 scope.close();
             } else {
                 scope.close();

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceInterceptor.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceInterceptor.java b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceInterceptor.java
index 04f907e..7e93842 100644
--- a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceInterceptor.java
+++ b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceInterceptor.java
@@ -32,7 +32,7 @@ public abstract class AbstractHTraceInterceptor extends AbstractHTraceProvider i
         super(tracer);
         this.phase = phase;
     }
-    
+
     public Collection<PhaseInterceptor<? extends Message>> getAdditionalInterceptors() {
         return null;
     }
@@ -52,7 +52,7 @@ public abstract class AbstractHTraceInterceptor extends AbstractHTraceProvider i
     public String getPhase() {
         return phase;
     }
-    
+
     public void handleFault(Message message) {
     }
 

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceProvider.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceProvider.java b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceProvider.java
index 0cc179d..df218fb 100644
--- a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceProvider.java
+++ b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/AbstractHTraceProvider.java
@@ -31,29 +31,29 @@ import org.apache.htrace.core.SpanId;
 import org.apache.htrace.core.TraceScope;
 import org.apache.htrace.core.Tracer;
 
-public abstract class AbstractHTraceProvider extends AbstractTracingProvider { 
+public abstract class AbstractHTraceProvider extends AbstractTracingProvider {
     protected static final Logger LOG = LogUtils.getL7dLogger(AbstractHTraceProvider.class);
     protected static final String TRACE_SPAN = "org.apache.cxf.tracing.htrace.span";
-        
+
     private final Tracer tracer;
-        
+
     public AbstractHTraceProvider(final Tracer tracer) {
         this.tracer = tracer;
     }
 
-    protected TraceScopeHolder<TraceScope> startTraceSpan(final Map<String, List<String>> requestHeaders, 
+    protected TraceScopeHolder<TraceScope> startTraceSpan(final Map<String, List<String>> requestHeaders,
             String path, String method) {
-        
+
         // Try to extract the Span Id value from the request header
-        final SpanId spanId = getFirstValueOrDefault(requestHeaders, getSpanIdHeader(), SpanId.INVALID); 
-        
+        final SpanId spanId = getFirstValueOrDefault(requestHeaders, getSpanIdHeader(), SpanId.INVALID);
+
         TraceScope traceScope = null;
         if (SpanId.INVALID.equals(spanId)) {
             traceScope = tracer.newScope(buildSpanDescription(path, method));
         } else {
             traceScope = tracer.newScope(buildSpanDescription(path, method), spanId);
         }
-        
+
         // If the service resource is using asynchronous processing mode, the trace
         // scope will be closed in another thread and as such should be detached.
         boolean detached = false;
@@ -62,7 +62,7 @@ public abstract class AbstractHTraceProvider extends AbstractTracingProvider {
             propagateContinuationSpan(traceScope);
             detached = true;
         }
-        
+
         return new TraceScopeHolder<TraceScope>(traceScope, detached);
     }
 
@@ -75,34 +75,34 @@ public abstract class AbstractHTraceProvider extends AbstractTracingProvider {
         if (requestHeaders.containsKey(spanIdHeader)) {
             responseHeaders.put(spanIdHeader, CastUtils.cast(requestHeaders.get(spanIdHeader)));
         }
-        
+
         if (holder == null) {
             return;
         }
-        
+
         final TraceScope span = holder.getScope();
         if (span != null) {
             // If the service resource is using asynchronous processing mode, the trace
-            // scope has been created in another thread and should be re-attached to the current 
+            // scope has been created in another thread and should be re-attached to the current
             // one.
             if (holder.isDetached()) {
-                span.reattach(); 
+                span.reattach();
                 span.close();
-            } else {            
+            } else {
                 span.close();
             }
         }
     }
-    
+
     private void propagateContinuationSpan(final TraceScope continuationScope) {
         PhaseInterceptorChain.getCurrentMessage().put(TraceScope.class, continuationScope);
     }
-    
+
     protected boolean isAsyncResponse() {
         return !PhaseInterceptorChain.getCurrentMessage().getExchange().isSynchronous();
     }
-    
-    private static SpanId getFirstValueOrDefault(final Map<String, List<String>> headers, 
+
+    private static SpanId getFirstValueOrDefault(final Map<String, List<String>> headers,
             final String header, final SpanId defaultValue) {
         List<String> value = headers.get(header);
         if (value != null && !value.isEmpty()) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceClientStartInterceptor.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceClientStartInterceptor.java b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceClientStartInterceptor.java
index 8af55ff..716a6d9 100644
--- a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceClientStartInterceptor.java
+++ b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceClientStartInterceptor.java
@@ -40,13 +40,13 @@ public class HTraceClientStartInterceptor extends AbstractHTraceClientIntercepto
     @Override
     public void handleMessage(Message message) throws Fault {
         final Map<String, List<String>> headers = CastUtils.cast((Map<?, ?>)message.get(Message.PROTOCOL_HEADERS));
-        final TraceScopeHolder<TraceScope> holder = super.startTraceSpan(headers, 
-            (String)message.get(Message.ENDPOINT_ADDRESS), 
+        final TraceScopeHolder<TraceScope> holder = super.startTraceSpan(headers,
+            (String)message.get(Message.ENDPOINT_ADDRESS),
             (String)message.get(Message.HTTP_REQUEST_METHOD));
-        
+
         if (holder != null) {
             message.getExchange().put(TRACE_SPAN, holder);
         }
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceClientStopInterceptor.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceClientStopInterceptor.java b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceClientStopInterceptor.java
index e58f529..a469d0e 100644
--- a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceClientStopInterceptor.java
+++ b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceClientStopInterceptor.java
@@ -27,7 +27,7 @@ public class HTraceClientStopInterceptor extends AbstractHTraceClientInterceptor
     public HTraceClientStopInterceptor() {
         this(Phase.RECEIVE);
     }
-    
+
     public HTraceClientStopInterceptor(final String phase) {
         super(phase, null);
     }
@@ -35,7 +35,7 @@ public class HTraceClientStopInterceptor extends AbstractHTraceClientInterceptor
     @Override
     public void handleMessage(Message message) throws Fault {
         @SuppressWarnings("unchecked")
-        final TraceScopeHolder<TraceScope> holder = 
+        final TraceScopeHolder<TraceScope> holder =
             (TraceScopeHolder<TraceScope>)message.getExchange().get(TRACE_SPAN);
         super.stopTraceSpan(holder);
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceStartInterceptor.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceStartInterceptor.java b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceStartInterceptor.java
index 5301c4a..644ca03 100644
--- a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceStartInterceptor.java
+++ b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceStartInterceptor.java
@@ -35,13 +35,13 @@ public class HTraceStartInterceptor extends AbstractHTraceInterceptor {
     @Override
     public void handleMessage(Message message) throws Fault {
         final Map<String, List<String>> headers = CastUtils.cast((Map<?, ?>)message.get(Message.PROTOCOL_HEADERS));
-        final TraceScopeHolder<TraceScope> holder = super.startTraceSpan(headers, 
-            (String)message.get(Message.REQUEST_URI), 
+        final TraceScopeHolder<TraceScope> holder = super.startTraceSpan(headers,
+            (String)message.get(Message.REQUEST_URI),
             (String)message.get(Message.HTTP_REQUEST_METHOD));
-        
+
         if (holder != null) {
             message.getExchange().put(TRACE_SPAN, holder);
         }
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceStopInterceptor.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceStopInterceptor.java b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceStopInterceptor.java
index 75be08b..92f3aba 100644
--- a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceStopInterceptor.java
+++ b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceStopInterceptor.java
@@ -36,23 +36,23 @@ public class HTraceStopInterceptor extends AbstractHTraceInterceptor {
     @Override
     public void handleMessage(Message message) throws Fault {
         Map<String, List<Object>> responseHeaders = CastUtils.cast((Map<?, ?>)message.get(Message.PROTOCOL_HEADERS));
-        
+
         if (responseHeaders == null) {
             responseHeaders = new HashMap<String, List<Object>>();
             message.put(Message.PROTOCOL_HEADERS, responseHeaders);
         }
-        
+
         boolean isRequestor = MessageUtils.isRequestor(message);
-        Message requestMessage = isRequestor ? message.getExchange().getOutMessage() 
+        Message requestMessage = isRequestor ? message.getExchange().getOutMessage()
             : message.getExchange().getInMessage();
-        Map<String, List<String>> requestHeaders =  
+        Map<String, List<String>> requestHeaders =
             CastUtils.cast((Map<?, ?>)requestMessage.get(Message.PROTOCOL_HEADERS));
-        
+
         @SuppressWarnings("unchecked")
-        final TraceScopeHolder<TraceScope> holder = 
+        final TraceScopeHolder<TraceScope> holder =
             (TraceScopeHolder<TraceScope>)message.getExchange().get(TRACE_SPAN);
-        
+
         super.stopTraceSpan(requestHeaders, responseHeaders, holder);
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceTracerContext.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceTracerContext.java b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceTracerContext.java
index 52a43f9..0c53f78 100644
--- a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceTracerContext.java
+++ b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/HTraceTracerContext.java
@@ -38,13 +38,13 @@ public class HTraceTracerContext implements TracerContext {
         this.tracer = tracer;
         this.continuationScope = continuationScope;
     }
-        
+
     @Override
     @SuppressWarnings("unchecked")
     public TraceScope startSpan(final String description) {
         return tracer.newScope(description);
     }
-    
+
     @Override
     public <T> T continueSpan(final Traceable<T> traceable) throws Exception {
         boolean attached = false;
@@ -52,7 +52,7 @@ public class HTraceTracerContext implements TracerContext {
             continuationScope.reattach();
             attached = true;
         }
-        
+
         try {
             return traceable.call(new HTraceTracerContext(tracer));
         } finally {
@@ -61,7 +61,7 @@ public class HTraceTracerContext implements TracerContext {
             }
         }
     }
-    
+
     @Override
     public <T> Callable<T> wrap(final String description, final Traceable<T> traceable) {
         final Callable<T> callable = new Callable<T>() {
@@ -70,10 +70,10 @@ public class HTraceTracerContext implements TracerContext {
                 return traceable.call(new HTraceTracerContext(tracer));
             }
         };
-        
+
         return tracer.wrap(callable, description);
     }
-    
+
     @Override
     public void annotate(String key, String value) {
         final Span currentSpan = Tracer.getCurrentSpan();
@@ -81,7 +81,7 @@ public class HTraceTracerContext implements TracerContext {
             currentSpan.addKVAnnotation(key, value);
         }
     }
-    
+
     @Override
     public void timeline(String message) {
         final Span currentSpan = Tracer.getCurrentSpan();
@@ -89,7 +89,7 @@ public class HTraceTracerContext implements TracerContext {
             currentSpan.addTimelineAnnotation(message);
         }
     }
-    
+
     private boolean isTracing() {
         return Tracer.getCurrentSpan() != null;
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceClientProvider.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceClientProvider.java b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceClientProvider.java
index 0c7c238..8ead3d4 100644
--- a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceClientProvider.java
+++ b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceClientProvider.java
@@ -31,7 +31,7 @@ import org.apache.htrace.core.TraceScope;
 import org.apache.htrace.core.Tracer;
 
 @Provider
-public class HTraceClientProvider extends AbstractHTraceClientProvider 
+public class HTraceClientProvider extends AbstractHTraceClientProvider
         implements ClientRequestFilter, ClientResponseFilter {
 
     public HTraceClientProvider(final Tracer tracer) {
@@ -40,19 +40,19 @@ public class HTraceClientProvider extends AbstractHTraceClientProvider
 
     @Override
     public void filter(final ClientRequestContext requestContext) throws IOException {
-        final TraceScopeHolder<TraceScope> holder = super.startTraceSpan(requestContext.getStringHeaders(), 
+        final TraceScopeHolder<TraceScope> holder = super.startTraceSpan(requestContext.getStringHeaders(),
             requestContext.getUri().toString(), requestContext.getMethod());
 
         if (holder != null) {
             requestContext.setProperty(TRACE_SPAN, holder);
         }
     }
-    
+
     @SuppressWarnings("unchecked")
     @Override
     public void filter(final ClientRequestContext requestContext,
             final ClientResponseContext responseContext) throws IOException {
-        final TraceScopeHolder<TraceScope> holder = 
+        final TraceScopeHolder<TraceScope> holder =
             (TraceScopeHolder<TraceScope>)requestContext.getProperty(TRACE_SPAN);
         super.stopTraceSpan(holder);
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceContextProvider.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceContextProvider.java b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceContextProvider.java
index 73be373..a706f9d 100644
--- a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceContextProvider.java
+++ b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceContextProvider.java
@@ -30,7 +30,7 @@ import org.apache.htrace.core.Tracer;
 @Provider
 public class HTraceContextProvider implements ContextProvider< TracerContext > {
     private final Tracer tracer;
-    
+
     public HTraceContextProvider(final Tracer tracer) {
         this.tracer = tracer;
     }
@@ -39,13 +39,13 @@ public class HTraceContextProvider implements ContextProvider< TracerContext > {
     public TracerContext createContext(final Message message) {
         // Check if there is a trace scope passed along with the message
         final TraceScope continuationScope = message.get(TraceScope.class);
-        
-        // If trace scope is already present, let us check if it is detached 
+
+        // If trace scope is already present, let us check if it is detached
         // (asynchronous invocation)
         if (continuationScope != null) {
             return new HTraceTracerContext(tracer, continuationScope);
         }
-        
+
         return new HTraceTracerContext(tracer);
     }
 }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceFeature.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceFeature.java b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceFeature.java
index d9b8623..c891b65 100644
--- a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceFeature.java
+++ b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceFeature.java
@@ -30,7 +30,7 @@ import org.apache.htrace.core.Tracer;
 public class HTraceFeature extends AbstractFeature {
     private HTraceConfiguration configuration;
     private String name;
-    
+
     public HTraceFeature() {
         this(HTraceConfiguration.EMPTY, "");
     }
@@ -49,25 +49,25 @@ public class HTraceFeature extends AbstractFeature {
         final Tracer tracer = new Tracer.Builder(name)
             .conf(configuration)
             .build();
-        
+
         if (providerFactory != null) {
-            providerFactory.setUserProviders(Arrays.asList(new HTraceProvider(tracer), 
+            providerFactory.setUserProviders(Arrays.asList(new HTraceProvider(tracer),
                 new HTraceContextProvider(tracer)));
         }
     }
-    
+
     public void setConfiguration(final HTraceConfiguration configuration) {
         this.configuration = configuration;
     }
-    
+
     public HTraceConfiguration getConfiguration() {
         return configuration;
     }
-    
+
     public void setName(String name) {
         this.name = name;
     }
-    
+
     public String getName() {
         return name;
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceProvider.java
----------------------------------------------------------------------
diff --git a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceProvider.java b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceProvider.java
index 47c4d74..504df2c 100644
--- a/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceProvider.java
+++ b/integration/tracing/tracing-htrace/src/main/java/org/apache/cxf/tracing/htrace/jaxrs/HTraceProvider.java
@@ -35,35 +35,35 @@ import org.apache.htrace.core.TraceScope;
 import org.apache.htrace.core.Tracer;
 
 @Provider
-public class HTraceProvider extends AbstractHTraceProvider 
+public class HTraceProvider extends AbstractHTraceProvider
     implements ContainerRequestFilter, ContainerResponseFilter {
-    @Context 
+    @Context
     private ResourceInfo resourceInfo;
-    
+
     public HTraceProvider(final Tracer tracer) {
         super(tracer);
     }
 
     @Override
     public void filter(final ContainerRequestContext requestContext) throws IOException {
-        final TraceScopeHolder<TraceScope> holder = super.startTraceSpan(requestContext.getHeaders(), 
+        final TraceScopeHolder<TraceScope> holder = super.startTraceSpan(requestContext.getHeaders(),
                                                 requestContext.getUriInfo().getPath(),
                                                 requestContext.getMethod());
-        
+
         if (holder != null) {
             requestContext.setProperty(TRACE_SPAN, holder);
         }
     }
-    
+
     @SuppressWarnings("unchecked")
     @Override
     public void filter(final ContainerRequestContext requestContext,
             final ContainerResponseContext responseContext) throws IOException {
-        super.stopTraceSpan(requestContext.getHeaders(), 
-                            responseContext.getHeaders(), 
+        super.stopTraceSpan(requestContext.getHeaders(),
+                            responseContext.getHeaders(),
                             (TraceScopeHolder<TraceScope>)requestContext.getProperty(TRACE_SPAN));
     }
-    
+
     @Override
     protected boolean isAsyncResponse() {
         for (final Annotation[] annotations: resourceInfo.getResourceMethod().getParameterAnnotations()) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/maven-plugins/archetypes/cxf-jaxws-javafirst/src/main/resources/archetype-resources/src/main/java/HelloWorld.java
----------------------------------------------------------------------
diff --git a/maven-plugins/archetypes/cxf-jaxws-javafirst/src/main/resources/archetype-resources/src/main/java/HelloWorld.java b/maven-plugins/archetypes/cxf-jaxws-javafirst/src/main/resources/archetype-resources/src/main/java/HelloWorld.java
index e20d7d0..7570279 100644
--- a/maven-plugins/archetypes/cxf-jaxws-javafirst/src/main/resources/archetype-resources/src/main/java/HelloWorld.java
+++ b/maven-plugins/archetypes/cxf-jaxws-javafirst/src/main/resources/archetype-resources/src/main/java/HelloWorld.java
@@ -5,9 +5,9 @@
 ##    to you under the Apache License, Version 2.0 (the
 ##    "License"); you may not use this file except in compliance
 ##    with the License. You may obtain a copy of the License at
-##    
+##
 ##    http://www.apache.org/licenses/LICENSE-2.0
-##    
+##
 ##    Unless required by applicable law or agreed to in writing,
 ##    software distributed under the License is distributed on an
 ##    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/maven-plugins/archetypes/cxf-jaxws-javafirst/src/main/resources/archetype-resources/src/main/java/HelloWorldImpl.java
----------------------------------------------------------------------
diff --git a/maven-plugins/archetypes/cxf-jaxws-javafirst/src/main/resources/archetype-resources/src/main/java/HelloWorldImpl.java b/maven-plugins/archetypes/cxf-jaxws-javafirst/src/main/resources/archetype-resources/src/main/java/HelloWorldImpl.java
index ee938f0..efb9820 100644
--- a/maven-plugins/archetypes/cxf-jaxws-javafirst/src/main/resources/archetype-resources/src/main/java/HelloWorldImpl.java
+++ b/maven-plugins/archetypes/cxf-jaxws-javafirst/src/main/resources/archetype-resources/src/main/java/HelloWorldImpl.java
@@ -5,9 +5,9 @@
 ##    to you under the Apache License, Version 2.0 (the
 ##    "License"); you may not use this file except in compliance
 ##    with the License. You may obtain a copy of the License at
-##    
+##
 ##    http://www.apache.org/licenses/LICENSE-2.0
-##    
+##
 ##    Unless required by applicable law or agreed to in writing,
 ##    software distributed under the License is distributed on an
 ##    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/maven-plugins/archetypes/cxf-jaxws-javafirst/src/main/resources/archetype-resources/src/test/java/HelloWorldImplTest.java
----------------------------------------------------------------------
diff --git a/maven-plugins/archetypes/cxf-jaxws-javafirst/src/main/resources/archetype-resources/src/test/java/HelloWorldImplTest.java b/maven-plugins/archetypes/cxf-jaxws-javafirst/src/main/resources/archetype-resources/src/test/java/HelloWorldImplTest.java
index 182ec5f..d49207a 100644
--- a/maven-plugins/archetypes/cxf-jaxws-javafirst/src/main/resources/archetype-resources/src/test/java/HelloWorldImplTest.java
+++ b/maven-plugins/archetypes/cxf-jaxws-javafirst/src/main/resources/archetype-resources/src/test/java/HelloWorldImplTest.java
@@ -5,9 +5,9 @@
 ##    to you under the Apache License, Version 2.0 (the
 ##    "License"); you may not use this file except in compliance
 ##    with the License. You may obtain a copy of the License at
-##    
+##
 ##    http://www.apache.org/licenses/LICENSE-2.0
-##    
+##
 ##    Unless required by applicable law or agreed to in writing,
 ##    software distributed under the License is distributed on an
 ##    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/maven-plugins/archetypes/cxf-jaxws-wsdlfirst/src/main/resources/archetype-resources/src/main/java/HelloWorldPortTypeImpl.java
----------------------------------------------------------------------
diff --git a/maven-plugins/archetypes/cxf-jaxws-wsdlfirst/src/main/resources/archetype-resources/src/main/java/HelloWorldPortTypeImpl.java b/maven-plugins/archetypes/cxf-jaxws-wsdlfirst/src/main/resources/archetype-resources/src/main/java/HelloWorldPortTypeImpl.java
index d075820..e9e3446 100644
--- a/maven-plugins/archetypes/cxf-jaxws-wsdlfirst/src/main/resources/archetype-resources/src/main/java/HelloWorldPortTypeImpl.java
+++ b/maven-plugins/archetypes/cxf-jaxws-wsdlfirst/src/main/resources/archetype-resources/src/main/java/HelloWorldPortTypeImpl.java
@@ -5,9 +5,9 @@
 ##    to you under the Apache License, Version 2.0 (the
 ##    "License"); you may not use this file except in compliance
 ##    with the License. You may obtain a copy of the License at
-##    
+##
 ##    http://www.apache.org/licenses/LICENSE-2.0
-##    
+##
 ##    Unless required by applicable law or agreed to in writing,
 ##    software distributed under the License is distributed on an
 ##    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
@@ -19,9 +19,9 @@ package ${package};
 import javax.jws.WebService;
 import org.apache.contract.helloworld.HelloWorldPortType;
 
-@WebService(targetNamespace = "http://www.apache.org/contract/HelloWorld", 
+@WebService(targetNamespace = "http://www.apache.org/contract/HelloWorld",
     portName="HelloWorldPort",
-    serviceName="HelloWorldService", 
+    serviceName="HelloWorldService",
     endpointInterface = "org.apache.contract.helloworld.HelloWorldPortType")
 public class HelloWorldPortTypeImpl implements HelloWorldPortType {
 

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/maven-plugins/archetypes/cxf-jaxws-wsdlfirst/src/main/resources/archetype-resources/src/test/java/HelloWorldPortTypeImplTest.java
----------------------------------------------------------------------
diff --git a/maven-plugins/archetypes/cxf-jaxws-wsdlfirst/src/main/resources/archetype-resources/src/test/java/HelloWorldPortTypeImplTest.java b/maven-plugins/archetypes/cxf-jaxws-wsdlfirst/src/main/resources/archetype-resources/src/test/java/HelloWorldPortTypeImplTest.java
index b03ee82..1a27a5e 100644
--- a/maven-plugins/archetypes/cxf-jaxws-wsdlfirst/src/main/resources/archetype-resources/src/test/java/HelloWorldPortTypeImplTest.java
+++ b/maven-plugins/archetypes/cxf-jaxws-wsdlfirst/src/main/resources/archetype-resources/src/test/java/HelloWorldPortTypeImplTest.java
@@ -5,9 +5,9 @@
 ##    to you under the Apache License, Version 2.0 (the
 ##    "License"); you may not use this file except in compliance
 ##    with the License. You may obtain a copy of the License at
-##    
+##
 ##    http://www.apache.org/licenses/LICENSE-2.0
-##    
+##
 ##    Unless required by applicable law or agreed to in writing,
 ##    software distributed under the License is distributed on an
 ##    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
@@ -23,7 +23,7 @@ public class HelloWorldPortTypeImplTest {
 
     @Test
 	public void testSayHi() {
-        HelloWorldPortTypeImpl helloWorldPortTypeImpl = new HelloWorldPortTypeImpl();            	
+        HelloWorldPortTypeImpl helloWorldPortTypeImpl = new HelloWorldPortTypeImpl();
         String response = helloWorldPortTypeImpl.sayHi("Sam");
         assertEquals("HelloWorldPortTypeImpl not properly saying hi", "Hello Sam", response);
     }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/AbstractCodegenMoho.java
----------------------------------------------------------------------
diff --git a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/AbstractCodegenMoho.java b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/AbstractCodegenMoho.java
index 51269ed..1bfa6b0 100644
--- a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/AbstractCodegenMoho.java
+++ b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/AbstractCodegenMoho.java
@@ -68,7 +68,7 @@ import org.codehaus.plexus.util.cli.StreamConsumer;
 import org.sonatype.plexus.build.incremental.BuildContext;
 
 public abstract class AbstractCodegenMoho extends AbstractMojo {
-    
+
     /**
      * JVM/System property name holding the hostname of the http proxy.
      */
@@ -84,28 +84,28 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
      * should not use the proxy configuration.
      */
     private static final String HTTP_NON_PROXY_HOSTS = "http.nonProxyHosts";
-    
+
     /**
      * JVM/System property name holding the username of the http proxy.
      */
     private static final String HTTP_PROXY_USER = "http.proxyUser";
-    
+
     /**
      * JVM/System property name holding the password of the http proxy.
      */
     private static final String HTTP_PROXY_PASSWORD = "http.proxyPassword";
-    
+
 
     @Parameter(property = "project.build.outputDirectory", required = true)
     protected String classesDirectory;
-   
+
     /**
      * By default all maven dependencies of type "wsdl" are added to the effective wsdlOptions. Setting this
      * parameter to true disables this functionality
      */
     @Parameter(property = "cxf.disableDependencyScan", defaultValue = "false")
     protected boolean disableDependencyScan;
-    
+
     /**
      * Disables the scanning of the wsdlRoot/testWsdlRoot directories.
      * By default, we scan for *.wsdl (see include/exclude params as well) in the wsdlRoot
@@ -114,14 +114,14 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
      */
     @Parameter(property = "cxf.disableDirectoryScan", defaultValue = "false")
     protected boolean disableDirectoryScan;
-    
+
     /**
      * Allows running the JavaToWs in a separate process. Valid values are "false", "always", and "once" The
      * value of "true" is equal to "once"
      */
     @Parameter(defaultValue = "false")
     protected String fork;
-    
+
     /**
      * A list of wsdl files to include. Can contain ant-style wildcards and double wildcards. Defaults to
      * *.wsdl
@@ -133,39 +133,39 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
      */
     @Parameter(property = "cxf.markerDirectory", defaultValue = "${project.build.directory}/cxf-codegen-plugin-markers")
     protected File markerDirectory;
-    
+
     /**
      * The plugin dependencies, needed for the fork mode
      */
     @Parameter(required = true, readonly = true, property = "plugin.artifacts")
     protected List<Artifact> pluginArtifacts;
-    
+
     @Parameter(required = true, property = "project")
     protected MavenProject project;
-    
+
     /**
      * Use the compile classpath rather than the test classpath for execution useful if the test dependencies
      * clash with those of wsdl2java
      */
     @Parameter(property = "cxf.useCompileClasspath", defaultValue = "false")
     protected boolean useCompileClasspath;
-    
+
     /**
      * A list of wsdl files to exclude. Can contain ant-style wildcards and double wildcards.
      */
     @Parameter
     protected String excludes[];
-    
+
     @Parameter(property = "cxf.testWsdlRoot", defaultValue = "${basedir}/src/test/resources/wsdl")
     protected File testWsdlRoot;
-   
+
     @Parameter(property = "cxf.wsdlRoot", defaultValue = "${basedir}/src/main/resources/wsdl")
     protected File wsdlRoot;
-    
+
     @Component
     protected BuildContext buildContext;
-    
-    
+
+
     /**
      * Sets the JVM arguments (i.e. <code>-Xms128m -Xmx128m</code>) if fork is set to <code>true</code>.
      */
@@ -189,13 +189,13 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
      */
     @Parameter(readonly = true, required = true, property = "session")
     private MavenSession mavenSession;
-    
+
     @Component
     private ProjectDependenciesResolver projectDependencyResolver;
-    
+
     @Component
     private RepositorySystem repositorySystem;
-    
+
 
     public AbstractCodegenMoho() {
         super();
@@ -211,7 +211,7 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
             project.addTestCompileSourceRoot(getGeneratedTestRoot().getAbsolutePath());
         }
         checkResources();
-        
+
         // if this is an m2e configuration build then return immediately without doing any work
         if (project != null && buildContext.isIncremental() && !buildContext.hasDelta(project.getBasedir())) {
             return;
@@ -228,7 +228,7 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
                 "*.wsdl"
             };
         }
-       
+
         markerDirectory.mkdirs();
 
         String originalProxyHost = SystemPropertyAction.getProperty(HTTP_PROXY_HOST);
@@ -236,7 +236,7 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
         String originalNonProxyHosts = SystemPropertyAction.getProperty(HTTP_NON_PROXY_HOSTS);
         String originalProxyUser = SystemPropertyAction.getProperty(HTTP_PROXY_USER);
         String originalProxyPassword = SystemPropertyAction.getProperty(HTTP_PROXY_PASSWORD);
-                
+
         configureProxyServerSettings();
 
         List<GenericWsdlOption> effectiveWsdlOptions = createWsdlOptionsFromScansAndExplicitWsdlOptions();
@@ -258,7 +258,7 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
             } else {
                 for (GenericWsdlOption o : effectiveWsdlOptions) {
                     bus = generate(o, bus, cp);
-    
+
                     File dirs[] = o.getDeleteDirs();
                     if (dirs != null) {
                         for (int idx = 0; idx < dirs.length; ++idx) {
@@ -295,13 +295,13 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
 
         File genroot = getGeneratedSourceRoot();
         if (genroot != null) {
-            
+
             List<Resource> resources = project.getBuild().getResources();
             for (Resource r : resources) {
                 File d = new File(root, r.getDirectory());
                 if (d.equals(genroot)) {
                     sourceRoot = r;
-                } 
+                }
             }
             Resource r2 = scanForResources(genroot, sourceRoot);
             if (r2 != sourceRoot) {
@@ -316,7 +316,7 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
                 File d = new File(root, r.getDirectory());
                 if (d.equals(genroot)) {
                     testRoot = r;
-                } 
+                }
             }
             Resource r2 = scanForResources(genroot, testRoot);
             if (r2 != testRoot) {
@@ -381,13 +381,13 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
             System.getProperties().remove(HTTP_PROXY_PASSWORD);
         }
         Proxy proxy = mavenSession.getSettings().getActiveProxy();
-        if (proxy != null && !StringUtils.isEmpty(proxy.getUsername()) 
+        if (proxy != null && !StringUtils.isEmpty(proxy.getUsername())
             && !StringUtils.isEmpty(proxy.getPassword())) {
             Authenticator.setDefault(null);
         }
     }
 
-    protected abstract Bus generate(GenericWsdlOption o, 
+    protected abstract Bus generate(GenericWsdlOption o,
                                     Bus bus, Set<URI> cp) throws MojoExecutionException;
 
     protected void addPluginArtifact(Set<URI> artifactsPath) {
@@ -438,7 +438,7 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
                 if (proxy.getNonProxyHosts() != null) {
                     System.setProperty(HTTP_NON_PROXY_HOSTS, proxy.getNonProxyHosts());
                 }
-                if (!StringUtils.isEmpty(proxy.getUsername()) 
+                if (!StringUtils.isEmpty(proxy.getUsername())
                     && !StringUtils.isEmpty(proxy.getPassword())) {
                     final String authUser = proxy.getUsername();
                     final String authPassword = proxy.getPassword();
@@ -455,13 +455,13 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
 
         }
     }
-    
-    protected abstract List<GenericWsdlOption> createWsdlOptionsFromScansAndExplicitWsdlOptions() 
+
+    protected abstract List<GenericWsdlOption> createWsdlOptionsFromScansAndExplicitWsdlOptions()
         throws MojoExecutionException;
 
     /**
      * Recursively delete the given directory
-     * 
+     *
      * @param f
      * @return
      */
@@ -482,12 +482,12 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
 
         return true;
     }
-    
+
     protected abstract String getMarkerSuffix();
-    
+
     protected List<String> generateCommandLine(GenericWsdlOption wsdlOption)
         throws MojoExecutionException {
-        
+
         File outputDirFile = wsdlOption.getOutputDir();
         outputDirFile.mkdirs();
         URI basedir = project.getBasedir().toURI();
@@ -495,7 +495,7 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
         return wsdlOption.generateCommandLine(outputDirFile, basedir, wsdlURI,
                                               getLog().isDebugEnabled());
     }
-    
+
     protected void forkOnce(Set<URI> classPath, List<GenericWsdlOption> effectiveWsdlOptions)
         throws MojoExecutionException {
         List<GenericWsdlOption> toDo = new LinkedList<GenericWsdlOption>();
@@ -553,9 +553,9 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
             }
         }
     }
-    
+
     protected abstract Class<?> getForkClass();
-    
+
     protected File getDoneFile(URI basedir, URI wsdlURI, String mojo) {
         String doneFileName = wsdlURI.toString();
 
@@ -567,7 +567,7 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
             doneFileName = new javax.xml.bind.annotation.adapters.HexBinaryAdapter().marshal(cript.digest());
         } catch (Exception e) {
             //ignore,we'll try and fake it based on the wsdl
-            
+
             // Strip the basedir from the doneFileName
             if (doneFileName.startsWith(basedir.toString())) {
                 doneFileName = doneFileName.substring(basedir.toString().length());
@@ -578,16 +578,16 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
                 .replace(':', '_');
             doneFileName += ".DONE";
         }
-        
+
         return new File(markerDirectory, "." + doneFileName);
     }
 
     protected abstract File getGeneratedSourceRoot();
 
     protected abstract File getGeneratedTestRoot();
-    
-    protected void runForked(Set<URI> classPath, 
-                             String mainClassName, 
+
+    protected void runForked(Set<URI> classPath,
+                             String mainClassName,
                              String[] args) throws MojoExecutionException {
         getLog().info("Running code generation in fork mode...");
         getLog().debug("Running code generation in fork mode with args " + Arrays.asList(args));
@@ -631,7 +631,7 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
             jar.createArchive();
 
             cmd.createArg().setValue("-jar");
-            
+
             String tmpFilePath = file.getAbsolutePath();
             if (tmpFilePath.contains(" ")) {
                 //ensure the path is in double quotation marks if the path contain space
@@ -664,7 +664,7 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
             getLog().debug(e);
             throw new MojoExecutionException(e.getMessage(), e);
         }
-        
+
 
         String cmdLine = CommandLineUtils.toString(cmd.getCommandline());
 
@@ -687,10 +687,10 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
         }
 
     }
-    
+
     /**
      * Determine if code should be generated from the given wsdl
-     * 
+     *
      * @param wsdlOption
      * @param doneFile
      * @param wsdlURI
@@ -701,7 +701,7 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
     protected void createMarkerFile(GenericWsdlOption wsdlOption, File doneFile, URI wsdlURI) throws IOException {
         doneFile.createNewFile();
     }
-   
+
     private String[] createForkOnceArgs(List<List<String>> wargs) throws MojoExecutionException {
         try {
             File f = FileUtils.createTempFile("cxf-w2j", "args");
@@ -721,11 +721,11 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
             throw new MojoExecutionException("Could not create argument file", ex);
         }
     }
-    
+
     /**
      * Try to find a file matching the wsdl path (either absolutely, relatively to the current dir or to
      * the project base dir)
-     * 
+     *
      * @return wsdl file
      */
     public File getWsdlFile(GenericWsdlOption option, File baseDir) {
@@ -749,18 +749,18 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
         }
         return file;
     }
-    
+
     public URI getWsdlURI(GenericWsdlOption option, URI baseURI) throws MojoExecutionException {
         String wsdlLocation = option.getUri();
         if (wsdlLocation == null) {
             throw new MojoExecutionException("No wsdl available for base URI " + baseURI);
         }
         File wsdlFile = new File(wsdlLocation);
-        return wsdlFile.exists() ? wsdlFile.toURI() 
+        return wsdlFile.exists() ? wsdlFile.toURI()
             : baseURI.resolve(URIParserUtil.escapeChars(wsdlLocation));
     }
 
-    protected void downloadRemoteWsdls(List<GenericWsdlOption> effectiveWsdlOptions) 
+    protected void downloadRemoteWsdls(List<GenericWsdlOption> effectiveWsdlOptions)
         throws MojoExecutionException {
 
         for (GenericWsdlOption wsdlOption : effectiveWsdlOptions) {
@@ -770,7 +770,7 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
             }
             Artifact wsdlArtifact = repositorySystem.createArtifactWithClassifier(wsdlA.getGroupId(),
                                                                         wsdlA.getArtifactId(),
-                                                                        wsdlA.getVersion(), 
+                                                                        wsdlA.getVersion(),
                                                                         wsdlA.getType(),
                                                                         wsdlA.getClassifier());
             wsdlArtifact = resolveRemoteWsdlArtifact(wsdlArtifact);
@@ -807,13 +807,13 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
             throw new IOException(
                                   "The java executable '"
                                       + javaExe
-                                      + "' doesn't exist or is not a file." 
+                                      + "' doesn't exist or is not a file."
                                       + "Verify the <javaExecutable/> parameter or toolchain configuration.");
         }
         getLog().info("The java executable is " + javaExe.getAbsolutePath());
         return javaExe;
     }
-    
+
     private Artifact resolveRemoteWsdlArtifact(Artifact artifact) throws MojoExecutionException {
         Artifact remoteWsdl = resolveDependentWsdl(artifact);
         if (remoteWsdl == null) {
@@ -861,9 +861,9 @@ public abstract class AbstractCodegenMoho extends AbstractMojo {
         request.setMirrors(mavenSession.getRequest().getMirrors());
         request.setProxies(mavenSession.getRequest().getProxies());
         request.setLocalRepository(mavenSession.getLocalRepository());
-        request.setRemoteRepositories(mavenSession.getRequest().getRemoteRepositories());            
+        request.setRemoteRepositories(mavenSession.getRequest().getRemoteRepositories());
         ArtifactResolutionResult result = repositorySystem.resolve(request);
-            
+
         return result.getOriginatingArtifact();
     }
 

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/ClassLoaderSwitcher.java
----------------------------------------------------------------------
diff --git a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/ClassLoaderSwitcher.java b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/ClassLoaderSwitcher.java
index 8b24b43..4457860 100644
--- a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/ClassLoaderSwitcher.java
+++ b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/ClassLoaderSwitcher.java
@@ -53,7 +53,7 @@ public class ClassLoaderSwitcher {
 
     /**
      * Create and set the classloader that is needed for creating the java sources from wsdl
-     * 
+     *
      * @param project
      * @param useCompileClasspath
      * @param classesDir
@@ -64,7 +64,7 @@ public class ClassLoaderSwitcher {
         List<URL> urlList = new ArrayList<>();
         StringBuilder buf = new StringBuilder();
         Set<URI> ret = new LinkedHashSet<URI>();
-        
+
         try {
             urlList.add(classesDir.toURI().toURL());
             if (!useCompileClasspath) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/WsdlArtifact.java
----------------------------------------------------------------------
diff --git a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/WsdlArtifact.java b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/WsdlArtifact.java
index 610b2de..58d420f 100644
--- a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/WsdlArtifact.java
+++ b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/WsdlArtifact.java
@@ -28,11 +28,11 @@ public class WsdlArtifact {
     private String version;
     private String classifier;
     private String type;
-    
+
     public WsdlArtifact() {
         type = "wsdl";
     }
-    
+
     public String getGroupId() {
         return groupId;
     }
@@ -57,9 +57,9 @@ public class WsdlArtifact {
     public void setType(String type) {
         this.type = type;
     }
-    
+
     /**
-     * Not quite the same as equals: null in version 
+     * Not quite the same as equals: null in version
      * matches anything.
      * @param artifact
      * @return
@@ -73,7 +73,7 @@ public class WsdlArtifact {
         }
         return ((classifier == null && artifact.classifier == null)
                   || classifier != null && classifier.equals(artifact.classifier))
-              && artifactId.equals(artifact.getArtifactId()) 
+              && artifactId.equals(artifact.getArtifactId())
               && (version == null || version.equals(artifact.getVersion()));
     }
 

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/WsdlUtilities.java
----------------------------------------------------------------------
diff --git a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/WsdlUtilities.java b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/WsdlUtilities.java
index c49aebf..399de26 100644
--- a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/WsdlUtilities.java
+++ b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/WsdlUtilities.java
@@ -34,9 +34,9 @@ public final class WsdlUtilities {
 
     private WsdlUtilities() {
     }
-    
-    public static boolean fillWsdlOptionFromArtifact(GenericWsdlOption option, 
-                                                        Artifact artifact, 
+
+    public static boolean fillWsdlOptionFromArtifact(GenericWsdlOption option,
+                                                        Artifact artifact,
                                                         File outputDir) {
         if (!WSDL_TYPE.equals(artifact.getType())) {
             return false;

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/ForkOnceWSDL2Java.java
----------------------------------------------------------------------
diff --git a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/ForkOnceWSDL2Java.java b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/ForkOnceWSDL2Java.java
index 92902c5..3103621 100644
--- a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/ForkOnceWSDL2Java.java
+++ b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/ForkOnceWSDL2Java.java
@@ -27,7 +27,7 @@ import org.apache.cxf.tools.common.ToolContext;
 import org.apache.cxf.tools.wsdlto.WSDLToJava;
 
 /**
- * 
+ *
  */
 public final class ForkOnceWSDL2Java {
     private ForkOnceWSDL2Java() {
@@ -47,9 +47,9 @@ public final class ForkOnceWSDL2Java {
             for (int x = 0; x < i; x++) {
                 wargs[x] = reader.readLine();
             }
-            
+
             new WSDLToJava(wargs).run(new ToolContext());
-            
+
             line = reader.readLine();
         }
         reader.close();

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/Option.java
----------------------------------------------------------------------
diff --git a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/Option.java b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/Option.java
index a99abdc..f9b04d1 100644
--- a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/Option.java
+++ b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/Option.java
@@ -34,13 +34,13 @@ public class Option {
 
     /**
      * As maven will set null for an empty parameter we need
-     * this horrid initial value to tell if it has been 
+     * this horrid initial value to tell if it has been
      * configured or not yet.
      */
     private static final String DEFAULT_WSDL_LOCATION = "DEFAULTWSDLLOCATION - WORKAROUND";
 
     /**
-     * 
+     *
      */
     protected List<String> packagenames = new ArrayList<>();
 
@@ -55,7 +55,7 @@ public class Option {
      * For compatibility as well as to specify any extra flags not addressed by other parameters
      */
     protected List<String> xjcargs = new ArrayList<>();
-    
+
     protected String[] asyncMethods;
     protected String[] bareMethods;
     protected String[] mimeMethods;
@@ -67,7 +67,7 @@ public class Option {
 
     /**
      * Ignore the specified WSDL schema namespace when generating code.
-     * Also, optionally specifies the Java package name used by types described in the excluded 
+     * Also, optionally specifies the Java package name used by types described in the excluded
      * namespace(s) using schema-namespace[=java-packagename]
      */
     List<String> namespaceExcludes = new ArrayList<>();
@@ -78,15 +78,15 @@ public class Option {
     Boolean defaultExcludesNamespace;
 
     /**
-     * Enables or disables the loading of the default namespace package name mapping. Default is true and 
+     * Enables or disables the loading of the default namespace package name mapping. Default is true and
      * <a href=""http://www.w3.org/2005/08/addressing">
-     * http://www.w3.org/2005/08/addressing=org.apache.cxf.ws.addressingnamespace</a> 
+     * http://www.w3.org/2005/08/addressing=org.apache.cxf.ws.addressingnamespace</a>
      * package mapping will be enabled.
      */
     Boolean defaultNamespacePackageMapping;
 
     /**
-     * A set of dependent files used to detect that the generator must process WSDL, even 
+     * A set of dependent files used to detect that the generator must process WSDL, even
      * if generator marker files are up to date.
      */
     String dependencies[];
@@ -102,7 +102,7 @@ public class Option {
     Set<String> bindingFiles = new HashSet<>();
 
     /**
-     * Specifies the value of the @WebServiceClient annotation's wsdlLocation property. 
+     * Specifies the value of the @WebServiceClient annotation's wsdlLocation property.
      */
     String wsdlLocation = DEFAULT_WSDL_LOCATION;
 
@@ -133,17 +133,17 @@ public class Option {
     String catalog;
 
     /**
-     * Enables or disables processing of implicit SOAP headers (i.e. SOAP headers defined in the 
+     * Enables or disables processing of implicit SOAP headers (i.e. SOAP headers defined in the
      * wsdl:binding but not wsdl:portType section.) Default is false.
      */
     Boolean extendedSoapHeaders;
 
     /**
-     * Enables validating the WSDL before generating the code. 
+     * Enables validating the WSDL before generating the code.
      */
     String validateWsdl;
-    
-    
+
+
     /**
      * Enables or disables generation of the type classes. Default value is false.
      */
@@ -183,9 +183,9 @@ public class Option {
      * Disable generation of service address binding in the generated Java classes
      */
     Boolean noAddressBinding;
-    
+
     /**
-     * Allow element references when determining if an operation can be unwrapped or not 
+     * Allow element references when determining if an operation can be unwrapped or not
      */
     Boolean allowElementRefs;
 
@@ -229,7 +229,7 @@ public class Option {
     public String[] getBareMethods() {
         return bareMethods;
     }
-    
+
 
     public List<String> getPackagenames() {
         return packagenames;
@@ -282,7 +282,7 @@ public class Option {
     public void setOutputDir(File f) {
         outputDir = f;
     }
-    
+
     public void setBindingFiles(Set<String> files) {
         bindingFiles = files;
     }
@@ -292,7 +292,7 @@ public class Option {
     public void addBindingFile(File file) {
         bindingFiles.add(file.getAbsolutePath());
     }
-    
+
     public void addDefaultBindingFileIfExists(File baseDir) {
         File defaultBindingFile = new File(baseDir, DEFAULT_BINDING_FILE_PATH);
         if (defaultBindingFile.exists()) {
@@ -370,11 +370,11 @@ public class Option {
     public void setValidate(String v) {
         this.validateWsdl = v;
     }
-    
+
     public boolean isNoTypes() {
         return noTypes == null ? false : noTypes;
     }
-    
+
     public void setNoTypes(boolean noTypes) {
         this.noTypes = noTypes;
     }
@@ -386,18 +386,18 @@ public class Option {
     public void setFaultSerialVersionUID(String faultSerialVersionUID) {
         this.faultSerialVersionUID = faultSerialVersionUID;
     }
-    
+
     public String getExceptionSuper() {
         return exceptionSuper;
     }
-    
+
     public void setExceptionSuper(String exceptionSuper) {
         this.exceptionSuper = exceptionSuper;
     }
     public List<String> getSeiSuper() {
         return seiSuper;
     }
-    
+
     public void setSeiSuper(List<String> seiSuper) {
         this.seiSuper.clear();
         this.seiSuper.addAll(seiSuper);
@@ -491,14 +491,14 @@ public class Option {
         destination.setBareMethods(getBareMethods());
         destination.setExceptionSuper(getExceptionSuper());
     }
-    
+
     private <T> T setIfNull(T dest, T source) {
         if (dest == null) {
             dest = source;
         }
         return dest;
     }
-    
+
     public void merge(Option defaultOptions) {
         wsdlList = setIfNull(wsdlList, defaultOptions.wsdlList);
         exceptionSuper = setIfNull(exceptionSuper, defaultOptions.exceptionSuper);
@@ -512,7 +512,7 @@ public class Option {
         autoNameResolution = setIfNull(autoNameResolution, defaultOptions.autoNameResolution);
         noAddressBinding = setIfNull(noAddressBinding, defaultOptions.noAddressBinding);
         allowElementRefs = setIfNull(allowElementRefs, defaultOptions.allowElementRefs);
-        defaultExcludesNamespace = setIfNull(defaultExcludesNamespace, 
+        defaultExcludesNamespace = setIfNull(defaultExcludesNamespace,
                                              defaultOptions.defaultExcludesNamespace);
         defaultNamespacePackageMapping = setIfNull(defaultNamespacePackageMapping,
                                                    defaultOptions.defaultNamespacePackageMapping);
@@ -536,7 +536,7 @@ public class Option {
             wsdlLocation = defaultOptions.getWsdlLocation();
         }
     }
-    
+
     @SuppressWarnings("unchecked")
     private <T> T[] mergeList(T[] l1, T[] l2, Class<T> cls) {
         if (l1 == null) {

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/WSDL2JavaMojo.java
----------------------------------------------------------------------
diff --git a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/WSDL2JavaMojo.java b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/WSDL2JavaMojo.java
index 07d9935..5c483f8 100644
--- a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/WSDL2JavaMojo.java
+++ b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/WSDL2JavaMojo.java
@@ -66,9 +66,9 @@ public class WSDL2JavaMojo extends AbstractCodegenMoho {
 
         public void addError(final String file, int line, int column, String message, Throwable t) {
             super.addError(file, line, column, message, t);
-            
+
             File f = mapFile(file);
-            
+
             if (f != null && !errorfiles.contains(f)) {
                 buildContext.removeMessages(f);
                 errorfiles.add(f);
@@ -129,16 +129,16 @@ public class WSDL2JavaMojo extends AbstractCodegenMoho {
 
     /**
      * Path where the generated sources should be placed
-     * 
+     *
      */
     @Parameter(required = true, defaultValue = "${project.build.directory}/generated-sources/cxf",
                property = "cxf.sourceRoot")
     File sourceRoot;
 
     /**
-     * Options that specify WSDLs to process and/or control the processing of wsdls. 
+     * Options that specify WSDLs to process and/or control the processing of wsdls.
      * If you have enabled wsdl scanning, these elements attach options to particular wsdls.
-     * If you have not enabled wsdl scanning, these options call out the wsdls to process. 
+     * If you have not enabled wsdl scanning, these options call out the wsdls to process.
      */
     @Parameter
     WsdlOption wsdlOptions[];
@@ -158,12 +158,12 @@ public class WSDL2JavaMojo extends AbstractCodegenMoho {
     /**
      * Merge WsdlOptions that point to the same file by adding the extraargs to the first option and deleting
      * the second from the options list
-     * 
+     *
      * @param options
      */
     protected void mergeOptions(List<GenericWsdlOption> effectiveWsdlOptions) {
 
-        File outputDirFile = getGeneratedTestRoot() == null 
+        File outputDirFile = getGeneratedTestRoot() == null
                              ? getGeneratedSourceRoot() : getGeneratedTestRoot();
 
         List<GenericWsdlOption> newList = new ArrayList<>();
@@ -206,13 +206,13 @@ public class WSDL2JavaMojo extends AbstractCodegenMoho {
 
     /**
      * Determine if code should be generated from the given wsdl
-     * 
+     *
      * @param wsdlOption
      * @param doneFile
      * @param wsdlURI
      * @return
      */
-    protected boolean shouldRun(GenericWsdlOption genericWsdlOption, 
+    protected boolean shouldRun(GenericWsdlOption genericWsdlOption,
                                 File doneFile, URI wsdlURI) {
         WsdlOption wsdlOption = (WsdlOption) genericWsdlOption;
         long timestamp = getTimestamp(wsdlURI);
@@ -260,7 +260,7 @@ public class WSDL2JavaMojo extends AbstractCodegenMoho {
         }
         return doWork;
     }
-    
+
     protected void createMarkerFile(GenericWsdlOption wsdlOption, File doneFile, URI wsdlURI) throws IOException {
         doneFile.createNewFile();
         URI basedir = project.getBasedir().toURI();
@@ -270,12 +270,12 @@ public class WSDL2JavaMojo extends AbstractCodegenMoho {
             writer.flush();
         }
     }
-    
+
 
     /**
      * Finds the timestamp for a given URI. Calls {@link #getBaseFileURI(URI)} prior to the timestamp
      * check in order to handle "classpath" and "jar" URIs.
-     * 
+     *
      * @param uri the URI to timestamp
      * @return a timestamp
      */
@@ -298,7 +298,7 @@ public class WSDL2JavaMojo extends AbstractCodegenMoho {
      * Finds the base file URI that 'contains' the given URI. If the URI can not be resolved to a file URI
      * then the original URI is returned. This method currently attempts to resolve only "classpath" and
      * "jar" URIs.
-     * 
+     *
      * @param uri the URI to resolve
      * @return uri a file URI if the original URI is contained in a file, otherwise the original URI
      */
@@ -338,7 +338,7 @@ public class WSDL2JavaMojo extends AbstractCodegenMoho {
     }
 
     @Override
-    protected Bus generate(GenericWsdlOption genericWsdlOption, 
+    protected Bus generate(GenericWsdlOption genericWsdlOption,
                            Bus bus,
                            Set<URI> classPath) throws MojoExecutionException {
         WsdlOption wsdlOption = (WsdlOption) genericWsdlOption;
@@ -370,8 +370,8 @@ public class WSDL2JavaMojo extends AbstractCodegenMoho {
                 }
             }
         }
-        
-        List<String> list = wsdlOption.generateCommandLine(outputDirFile, basedir, wsdlURI, 
+
+        List<String> list = wsdlOption.generateCommandLine(outputDirFile, basedir, wsdlURI,
                                                            getLog().isDebugEnabled());
         if (encoding != null) {
             list.add(0, "-encoding");
@@ -403,8 +403,8 @@ public class WSDL2JavaMojo extends AbstractCodegenMoho {
             }
             try {
                 ToolContext ctx = new ToolContext();
-                final List<File> files = new ArrayList<>();                
-                final List<File> errorfiles = new ArrayList<>();                
+                final List<File> files = new ArrayList<>();
+                final List<File> errorfiles = new ArrayList<>();
                 ctx.put(OutputStreamCreator.class, new OutputStreamCreator() {
                     public OutputStream createOutputStream(File file) throws IOException {
                         files.add(file);
@@ -413,7 +413,7 @@ public class WSDL2JavaMojo extends AbstractCodegenMoho {
                 });
                 ctx.setErrorListener(new MavenToolErrorListener(errorfiles));
                 new WSDLToJava(args).run(ctx);
-                
+
                 List<File> oldFiles = CastUtils.cast((List<?>)buildContext
                                                      .getValue("cxf.file.list." + doneFile.getName()));
                 if (oldFiles != null) {
@@ -482,7 +482,7 @@ public class WSDL2JavaMojo extends AbstractCodegenMoho {
             effectiveWsdlOptions.addAll(temp);
         }
         if (!disableDependencyScan) {
-            temp = WsdlOptionLoader.loadWsdlOptionsFromDependencies(project, 
+            temp = WsdlOptionLoader.loadWsdlOptionsFromDependencies(project,
                                                                     getGeneratedSourceRoot());
             effectiveWsdlOptions.addAll(temp);
         }

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/WsdlOption.java
----------------------------------------------------------------------
diff --git a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/WsdlOption.java b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/WsdlOption.java
index 8d74931..77d141b 100644
--- a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/WsdlOption.java
+++ b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/WsdlOption.java
@@ -52,7 +52,7 @@ public class WsdlOption extends Option implements org.apache.cxf.maven_plugin.Ge
     public WsdlArtifact getWsdlArtifact() {
         return wsdlArtifact;
     }
-    
+
     public void setArtifact(WsdlArtifact artifact) {
         wsdlArtifact = artifact;
     }
@@ -60,11 +60,11 @@ public class WsdlOption extends Option implements org.apache.cxf.maven_plugin.Ge
     public void setWsdlArtifact(WsdlArtifact wsdlArtifact) {
         this.wsdlArtifact = wsdlArtifact;
     }
-    
+
     /**
      * Try to find a file matching the wsdl path (either absolutely, relatively to the current dir or to
      * the project base dir)
-     * 
+     *
      * @return wsdl file
      */
     public File getWsdlFile(File baseDir) {
@@ -88,14 +88,14 @@ public class WsdlOption extends Option implements org.apache.cxf.maven_plugin.Ge
         }
         return file;
     }
-    
+
     public URI getWsdlURI(URI baseURI) throws MojoExecutionException {
         String wsdlLocation = getWsdl();
         if (wsdlLocation == null) {
             throw new MojoExecutionException("No wsdl available for base URI " + baseURI);
         }
         File wsdlFile = new File(wsdlLocation);
-        return wsdlFile.exists() ? wsdlFile.toURI() 
+        return wsdlFile.exists() ? wsdlFile.toURI()
             : baseURI.resolve(URIParserUtil.escapeChars(wsdlLocation));
     }
 
@@ -179,10 +179,10 @@ public class WsdlOption extends Option implements org.apache.cxf.maven_plugin.Ge
                      + ToolConstants.CFG_EXCEPTION_SUPER);
         addList(list, "-" + ToolConstants.CFG_SEI_SUPER, true,
                 getSeiSuper());
-        
-        addIfTrue(list, isAutoNameResolution(), "-" 
+
+        addIfTrue(list, isAutoNameResolution(), "-"
                      + ToolConstants.CFG_AUTORESOLVE);
-        addIfTrue(list, isNoAddressBinding(), "-" 
+        addIfTrue(list, isNoAddressBinding(), "-"
                   + ToolConstants.CFG_NO_ADDRESS_BINDING);
         addList(list, "-xjc", false, getXJCargs());
         addList(list, "", false, getExtraargs());
@@ -196,7 +196,7 @@ public class WsdlOption extends Option implements org.apache.cxf.maven_plugin.Ge
         addEqualsArray(list, "-bareMethods", getBareMethods());
         addEqualsArray(list, "-mimeMethods", getMimeMethods());
         list.add(wsdlURI.toString());
-        
+
         return list;
     }
 
@@ -229,8 +229,8 @@ public class WsdlOption extends Option implements org.apache.cxf.maven_plugin.Ge
             }
         }
     }
-    private static void addEqualsArray(List<String> destList, 
-                                      String key, 
+    private static void addEqualsArray(List<String> destList,
+                                      String key,
                                       String[] sourceList) {
         if (sourceList == null) {
             return;

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/WsdlOptionLoader.java
----------------------------------------------------------------------
diff --git a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/WsdlOptionLoader.java b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/WsdlOptionLoader.java
index 616617b..4262c77 100644
--- a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/WsdlOptionLoader.java
+++ b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2java/WsdlOptionLoader.java
@@ -37,11 +37,11 @@ import org.apache.maven.project.MavenProject;
 public final class WsdlOptionLoader {
     private static final String WSDL_OPTIONS = "-options$";
     private static final String WSDL_BINDINGS = "-binding-?\\d*.xml$";
-    
+
     private WsdlOptionLoader() {
     }
-    
-    public static List<GenericWsdlOption> loadWsdlOptionsFromDependencies(MavenProject project, 
+
+    public static List<GenericWsdlOption> loadWsdlOptionsFromDependencies(MavenProject project,
                                                                           File outputDir) {
         List<GenericWsdlOption> options = new ArrayList<>();
         Set<Artifact> dependencies = CastUtils.cast(project.getDependencyArtifacts());
@@ -67,7 +67,7 @@ public final class WsdlOptionLoader {
      * Scan files in a directory and generate one wsdlOption per file found. Extra args for code generation
      * can be defined in a file that is named like the wsdl file and ends in -options. Binding files can be
      * defined in files named like the wsdl file and end in -binding-*.xml
-     * 
+     *
      * @param wsdlBasedir
      * @param includes file name patterns to include
      * @param excludes file name patterns to exclude
@@ -75,7 +75,7 @@ public final class WsdlOptionLoader {
      * @return list of one WsdlOption object for each wsdl found
      * @throws MojoExecutionException
      */
-    public static List<GenericWsdlOption> loadWsdlOptionsFromFiles(File wsdlBasedir, 
+    public static List<GenericWsdlOption> loadWsdlOptionsFromFiles(File wsdlBasedir,
                                                                    String includes[],
                                                                    String excludes[],
                                                                    File defaultOutputDir)
@@ -90,7 +90,7 @@ public final class WsdlOptionLoader {
         }
 
         List<File> wsdlFiles = WsdlUtilities.getWsdlFiles(wsdlBasedir, includes, excludes);
-        List<GenericWsdlOption> wsdlOptions 
+        List<GenericWsdlOption> wsdlOptions
             = new ArrayList<>();
         for (File wsdl : wsdlFiles) {
             WsdlOption wsdlOption = generateWsdlOptionFromFile(wsdl, defaultOutputDir);
@@ -123,7 +123,7 @@ public final class WsdlOptionLoader {
         }
     }
 
-    protected static WsdlOption generateWsdlOptionFromFile(final File wsdl, 
+    protected static WsdlOption generateWsdlOptionFromFile(final File wsdl,
                                                            File defaultOutputDir)
         throws MojoExecutionException {
 

http://git-wip-us.apache.org/repos/asf/cxf/blob/8cea7c87/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2js/ForkOnceWSDL2Javascript.java
----------------------------------------------------------------------
diff --git a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2js/ForkOnceWSDL2Javascript.java b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2js/ForkOnceWSDL2Javascript.java
index 19c2224..148b64a 100644
--- a/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2js/ForkOnceWSDL2Javascript.java
+++ b/maven-plugins/codegen-plugin/src/main/java/org/apache/cxf/maven_plugin/wsdl2js/ForkOnceWSDL2Javascript.java
@@ -27,7 +27,7 @@ import org.apache.cxf.tools.common.ToolContext;
 import org.apache.cxf.tools.wsdlto.javascript.WSDLToJavaScript;
 
 /**
- * 
+ *
  */
 public final class ForkOnceWSDL2Javascript {
     private ForkOnceWSDL2Javascript() {
@@ -47,9 +47,9 @@ public final class ForkOnceWSDL2Javascript {
             for (int x = 0; x < i; x++) {
                 wargs[x] = reader.readLine();
             }
-            
+
             new WSDLToJavaScript(wargs).run(new ToolContext());
-            
+
             line = reader.readLine();
         }
         reader.close();