You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hc.apache.org by ol...@apache.org on 2010/04/23 21:13:01 UTC

svn commit: r937478 - in /httpcomponents/httpcore/trunk: httpcore-ab/src/main/java/org/apache/http/benchmark/ httpcore-benchmark/src/main/java/org/apache/http/benchmark/ httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/ httpcore-benc...

Author: olegk
Date: Fri Apr 23 19:12:59 2010
New Revision: 937478

URL: http://svn.apache.org/viewvc?rev=937478&view=rev
Log:
TABS -> SPACES

Modified:
    httpcomponents/httpcore/trunk/httpcore-ab/src/main/java/org/apache/http/benchmark/HttpBenchmark.java
    httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/Benchmark.java
    httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/HttpServer.java
    httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpCoreNIOServer.java
    httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpCoreServer.java
    httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpListener.java
    httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpWorker.java
    httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpWorkerCallback.java
    httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/NHttpListener.java
    httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/NRandomDataHandler.java
    httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/RandomDataHandler.java
    httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/StdHttpWorkerCallback.java
    httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/jetty/JettyNIOServer.java
    httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/jetty/JettyServer.java
    httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/jetty/RandomDataHandler.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/GzipCompressingEntity.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/GzipDecompressingEntity.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/RequestAcceptEncoding.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/ResponseGzipCompress.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/ResponseGzipUncompress.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingClientIOEventDispatch.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingIOSession.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingNHttpClientHandler.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingNHttpServiceHandler.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingServerIOEventDispatch.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/Wire.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/BasicCompactHeader.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/BasicCompactHeaderMapper.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/BufferedCompactHeader.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/CompactHeader.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/CompactHeaderMapper.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/EnglishSipReasonPhraseCatalog.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/SipException.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/SipStatus.java
    httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/SipVersion.java

Modified: httpcomponents/httpcore/trunk/httpcore-ab/src/main/java/org/apache/http/benchmark/HttpBenchmark.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-ab/src/main/java/org/apache/http/benchmark/HttpBenchmark.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-ab/src/main/java/org/apache/http/benchmark/HttpBenchmark.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-ab/src/main/java/org/apache/http/benchmark/HttpBenchmark.java Fri Apr 23 19:12:59 2010
@@ -185,17 +185,17 @@ public class HttpBenchmark {
                 public Thread newThread(Runnable r) {
                     return new Thread(r, "ClientPool");
                 }
-                
+
             });
         workerPool.prestartAllCoreThreads();
 
         BenchmarkWorker[] workers = new BenchmarkWorker[config.getThreads()];
         for (int i = 0; i < workers.length; i++) {
             workers[i] = new BenchmarkWorker(
-                    params, 
+                    params,
                     config.getVerbosity(),
-                    request[i], 
-                    host, 
+                    request[i],
+                    host,
                     config.getRequests(),
                     config.isKeepAlive(),
                     config.isDisableSSLVerification(),

Modified: httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/Benchmark.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/Benchmark.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/Benchmark.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/Benchmark.java Fri Apr 23 19:12:59 2010
@@ -44,9 +44,9 @@ import org.apache.http.benchmark.HttpBen
 public class Benchmark {
 
     private static final int PORT = 8989;
-    
+
     public static void main(String[] args) throws Exception {
-        
+
         Config config = new Config();
         if (args.length > 0) {
             Options options = CommandLineUtils.getOptions();
@@ -63,10 +63,10 @@ public class Benchmark {
             config.setRequests(20000);
             config.setThreads(25);
         }
-        
+
         URL target = new URL("http", "localhost", PORT, "/rnd?c=2048");
         config.setUrl(target);
-        
+
         Benchmark benchmark = new Benchmark();
         benchmark.run(new JettyServer(PORT), config);
         benchmark.run(new HttpCoreServer(PORT), config);
@@ -77,20 +77,20 @@ public class Benchmark {
     public Benchmark() {
         super();
     }
-    
+
     public void run(final HttpServer server, final Config config) throws Exception {
         server.start();
         try {
             System.out.println("---------------------------------------------------------------");
             System.out.println(server.getName() + "; version: " + server.getVersion());
             System.out.println("---------------------------------------------------------------");
-            
+
             HttpBenchmark ab = new HttpBenchmark(config);
             ab.execute();
             System.out.println("---------------------------------------------------------------");
         } finally {
-            server.shutdown();            
+            server.shutdown();
         }
     }
-    
+
 }

Modified: httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/HttpServer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/HttpServer.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/HttpServer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/HttpServer.java Fri Apr 23 19:12:59 2010
@@ -30,11 +30,11 @@ package org.apache.http.benchmark;
 public interface HttpServer {
 
     String getName();
-    
+
     String getVersion();
-    
+
     void start() throws Exception;
-    
+
     void shutdown();
-    
+
 }

Modified: httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpCoreNIOServer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpCoreNIOServer.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpCoreNIOServer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpCoreNIOServer.java Fri Apr 23 19:12:59 2010
@@ -55,13 +55,13 @@ public class HttpCoreNIOServer implement
 
     private final int port;
     private final NHttpListener listener;
-    
+
     public HttpCoreNIOServer(int port) throws IOException {
         if (port <= 0) {
             throw new IllegalArgumentException("Server port may not be negative or null");
         }
         this.port = port;
-        
+
         HttpParams params = new SyncBasicHttpParams();
         params
             .setIntParameter(CoreConnectionPNames.SO_TIMEOUT, 10000)
@@ -75,7 +75,7 @@ public class HttpCoreNIOServer implement
                 new ResponseContent(),
                 new ResponseConnControl()
         });
-        
+
         AsyncNHttpServiceHandler handler = new AsyncNHttpServiceHandler(
                 httpproc,
                 new DefaultHttpResponseFactory(),
@@ -96,7 +96,7 @@ public class HttpCoreNIOServer implement
     }
 
     public String getVersion() {
-        VersionInfo vinfo = VersionInfo.loadVersionInfo("org.apache.http", 
+        VersionInfo vinfo = VersionInfo.loadVersionInfo("org.apache.http",
                 Thread.currentThread().getContextClassLoader());
         return vinfo.getRelease();
     }
@@ -105,7 +105,7 @@ public class HttpCoreNIOServer implement
         this.listener.start();
         this.listener.listen(new InetSocketAddress(this.port));
     }
-    
+
     public void shutdown() {
         this.listener.terminate();
         try {
@@ -127,15 +127,15 @@ public class HttpCoreNIOServer implement
         final HttpCoreNIOServer server = new HttpCoreNIOServer(port);
         System.out.println("Listening on port: " + port);
         server.start();
-        
+
         Runtime.getRuntime().addShutdownHook(new Thread() {
 
             @Override
             public void run() {
                 server.shutdown();
             }
-            
+
         });
     }
-    
+
 }

Modified: httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpCoreServer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpCoreServer.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpCoreServer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpCoreServer.java Fri Apr 23 19:12:59 2010
@@ -54,13 +54,13 @@ public class HttpCoreServer implements H
 
     private final Queue<HttpWorker> workers;
     private final HttpListener listener;
-    
+
     public HttpCoreServer(int port) throws IOException {
         super();
         if (port <= 0) {
             throw new IllegalArgumentException("Server port may not be negative or null");
         }
-        
+
         HttpParams params = new SyncBasicHttpParams();
         params
             .setIntParameter(CoreConnectionPNames.SO_TIMEOUT, 10000)
@@ -75,30 +75,30 @@ public class HttpCoreServer implements H
                 new ResponseContent(),
                 new ResponseConnControl()
         });
-        
+
         HttpRequestHandlerRegistry reqistry = new HttpRequestHandlerRegistry();
         reqistry.register("/rnd", new RandomDataHandler());
-        
+
         HttpService httpservice = new HttpService(
-                httpproc, 
-                new DefaultConnectionReuseStrategy(), 
+                httpproc,
+                new DefaultConnectionReuseStrategy(),
                 new DefaultHttpResponseFactory(),
-                reqistry, 
+                reqistry,
                 params);
-        
+
         this.workers = new ConcurrentLinkedQueue<HttpWorker>();
         this.listener = new HttpListener(
-                new ServerSocket(port), 
+                new ServerSocket(port),
                 httpservice,
                 new StdHttpWorkerCallback(this.workers));
     }
-    
+
     public String getName() {
         return "HttpCore (blocking I/O)";
     }
 
     public String getVersion() {
-        VersionInfo vinfo = VersionInfo.loadVersionInfo("org.apache.http", 
+        VersionInfo vinfo = VersionInfo.loadVersionInfo("org.apache.http",
                 Thread.currentThread().getContextClassLoader());
         return vinfo.getRelease();
     }
@@ -106,7 +106,7 @@ public class HttpCoreServer implements H
     public void start() {
         this.listener.start();
     }
-    
+
     public void shutdown() {
         this.listener.terminate();
         try {
@@ -130,7 +130,7 @@ public class HttpCoreServer implements H
             }
         }
     }
-    
+
     public static void main(String[] args) throws Exception {
         if (args.length != 1) {
             System.out.println("Usage: <port>");
@@ -140,15 +140,15 @@ public class HttpCoreServer implements H
         final HttpCoreServer server = new HttpCoreServer(port);
         System.out.println("Listening on port: " + port);
         server.start();
-        
+
         Runtime.getRuntime().addShutdownHook(new Thread() {
 
             @Override
             public void run() {
                 server.shutdown();
             }
-            
+
         });
     }
-    
+
 }

Modified: httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpListener.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpListener.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpListener.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpListener.java Fri Apr 23 19:12:59 2010
@@ -40,12 +40,12 @@ class HttpListener extends Thread {
     private final ServerSocket serversocket;
     private final HttpService httpservice;
     private final HttpWorkerCallback workercallback;
-    
+
     private volatile boolean shutdown;
     private volatile Exception exception;
-    
+
     public HttpListener(
-            final ServerSocket serversocket, 
+            final ServerSocket serversocket,
             final HttpService httpservice,
             final HttpWorkerCallback workercallback) {
         super();
@@ -53,7 +53,7 @@ class HttpListener extends Thread {
         this.httpservice = httpservice;
         this.workercallback = workercallback;
     }
-    
+
     public boolean isShutdown() {
         return this.shutdown;
     }
@@ -61,7 +61,7 @@ class HttpListener extends Thread {
     public Exception getException() {
         return this.exception;
     }
-    
+
     public void run() {
         while (!Thread.interrupted() && !this.shutdown) {
             try {
@@ -81,7 +81,7 @@ class HttpListener extends Thread {
             }
         }
     }
-    
+
     public void terminate() {
         if (this.shutdown) {
             return;

Modified: httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpWorker.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpWorker.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpWorker.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpWorker.java Fri Apr 23 19:12:59 2010
@@ -38,12 +38,12 @@ class HttpWorker extends Thread {
     private final HttpService httpservice;
     private final HttpServerConnection conn;
     private final HttpWorkerCallback workercallback;
-    
+
     private volatile boolean shutdown;
     private volatile Exception exception;
-    
+
     public HttpWorker(
-            final HttpService httpservice, 
+            final HttpService httpservice,
             final HttpServerConnection conn,
             final HttpWorkerCallback workercallback) {
         super();
@@ -51,7 +51,7 @@ class HttpWorker extends Thread {
         this.conn = conn;
         this.workercallback = workercallback;
     }
-    
+
     public boolean isShutdown() {
         return this.shutdown;
     }
@@ -59,7 +59,7 @@ class HttpWorker extends Thread {
     public Exception getException() {
         return this.exception;
     }
-    
+
     public void run() {
         this.workercallback.started(this);
         try {
@@ -74,7 +74,7 @@ class HttpWorker extends Thread {
             this.workercallback.shutdown(this);
         }
     }
-    
+
     public void terminate() {
         if (this.shutdown) {
             return;

Modified: httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpWorkerCallback.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpWorkerCallback.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpWorkerCallback.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/HttpWorkerCallback.java Fri Apr 23 19:12:59 2010
@@ -31,5 +31,5 @@ interface HttpWorkerCallback {
     void started(HttpWorker worker);
 
     void shutdown(HttpWorker worker);
-    
+
 }
\ No newline at end of file

Modified: httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/NHttpListener.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/NHttpListener.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/NHttpListener.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/NHttpListener.java Fri Apr 23 19:12:59 2010
@@ -37,11 +37,11 @@ public class NHttpListener extends Threa
 
     private final ListeningIOReactor ioreactor;
     private final IOEventDispatch ioEventDispatch;
-    
+
     private volatile Exception exception;
-    
+
     public NHttpListener(
-            final ListeningIOReactor ioreactor, 
+            final ListeningIOReactor ioreactor,
             final IOEventDispatch ioEventDispatch) throws IOException {
         super();
         this.ioreactor = ioreactor;
@@ -61,18 +61,18 @@ public class NHttpListener extends Threa
         ListenerEndpoint endpoint = this.ioreactor.listen(address);
         endpoint.waitFor();
     }
-    
+
     public void terminate() {
         try {
             this.ioreactor.shutdown();
         } catch (IOException ex) {
         }
     }
-    
+
     public Exception getException() {
         return this.exception;
     }
-    
+
     public void awaitTermination(long millis) throws InterruptedException {
         this.join(millis);
     }

Modified: httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/NRandomDataHandler.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/NRandomDataHandler.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/NRandomDataHandler.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/NRandomDataHandler.java Fri Apr 23 19:12:59 2010
@@ -53,11 +53,11 @@ import org.apache.http.protocol.HttpCont
 import org.apache.http.util.EntityUtils;
 
 class NRandomDataHandler implements NHttpRequestHandler  {
-    
+
     public NRandomDataHandler() {
         super();
     }
-    
+
     public ConsumingNHttpEntity entityRequest(
             final HttpEntityEnclosingRequest request,
             final HttpContext context) throws HttpException, IOException {
@@ -66,13 +66,13 @@ class NRandomDataHandler implements NHtt
     }
 
     public void handle(
-            final HttpRequest request, 
-            final HttpResponse response, 
+            final HttpRequest request,
+            final HttpResponse response,
             final NHttpResponseTrigger trigger,
             final HttpContext context) throws HttpException, IOException {
         String method = request.getRequestLine().getMethod().toUpperCase(Locale.ENGLISH);
         if (!method.equals("GET") && !method.equals("HEAD") && !method.equals("POST")) {
-            throw new MethodNotSupportedException(method + " method not supported"); 
+            throw new MethodNotSupportedException(method + " method not supported");
         }
         if (request instanceof HttpEntityEnclosingRequest) {
             HttpEntity entity = ((HttpEntityEnclosingRequest) request).getEntity();
@@ -81,7 +81,7 @@ class NRandomDataHandler implements NHtt
         String target = request.getRequestLine().getUri();
 
         int count = 100;
-        
+
         int idx = target.indexOf('?');
         if (idx != -1) {
             String s = target.substring(idx + 1);
@@ -91,7 +91,7 @@ class NRandomDataHandler implements NHtt
                     count = Integer.parseInt(s);
                 } catch (NumberFormatException ex) {
                     response.setStatusCode(HttpStatus.SC_BAD_REQUEST);
-                    response.setEntity(new StringEntity("Invalid query format: " + s, 
+                    response.setEntity(new StringEntity("Invalid query format: " + s,
                             "text/plain", "ASCII"));
                     return;
                 }
@@ -106,12 +106,12 @@ class NRandomDataHandler implements NHtt
 
 
     public void handle(
-            final HttpRequest request, 
+            final HttpRequest request,
             final HttpResponse response,
             final HttpContext context) throws HttpException, IOException {
         String method = request.getRequestLine().getMethod().toUpperCase(Locale.ENGLISH);
         if (!method.equals("GET") && !method.equals("HEAD") && !method.equals("POST")) {
-            throw new MethodNotSupportedException(method + " method not supported"); 
+            throw new MethodNotSupportedException(method + " method not supported");
         }
         if (request instanceof HttpEntityEnclosingRequest) {
             HttpEntity entity = ((HttpEntityEnclosingRequest) request).getEntity();
@@ -120,7 +120,7 @@ class NRandomDataHandler implements NHtt
         String target = request.getRequestLine().getUri();
 
         int count = 100;
-        
+
         int idx = target.indexOf('?');
         if (idx != -1) {
             String s = target.substring(idx + 1);
@@ -130,7 +130,7 @@ class NRandomDataHandler implements NHtt
                     count = Integer.parseInt(s);
                 } catch (NumberFormatException ex) {
                     response.setStatusCode(HttpStatus.SC_BAD_REQUEST);
-                    response.setEntity(new StringEntity("Invalid query format: " + s, 
+                    response.setEntity(new StringEntity("Invalid query format: " + s,
                             "text/plain", "ASCII"));
                     return;
                 }
@@ -140,14 +140,14 @@ class NRandomDataHandler implements NHtt
         RandomEntity body = new RandomEntity(count);
         response.setEntity(body);
     }
- 
+
     static class RandomEntity extends AbstractHttpEntity implements ProducingNHttpEntity {
 
         private final int count;
         private final ByteBuffer buf;
-        
+
         private int remaining;
-        
+
         public RandomEntity(int count) {
             super();
             this.count = count;
@@ -155,7 +155,7 @@ class NRandomDataHandler implements NHtt
             this.buf = ByteBuffer.allocate(1024);
             setContentType("text/plain");
         }
-        
+
         public InputStream getContent() throws IOException, IllegalStateException {
             throw new IllegalStateException("Method not supported");
         }
@@ -194,11 +194,11 @@ class NRandomDataHandler implements NHtt
             }
             this.buf.compact();
         }
-        
+
         public void finish() throws IOException {
             this.remaining = this.count;
         }
 
     }
-    
+
 }
\ No newline at end of file

Modified: httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/RandomDataHandler.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/RandomDataHandler.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/RandomDataHandler.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/RandomDataHandler.java Fri Apr 23 19:12:59 2010
@@ -45,18 +45,18 @@ import org.apache.http.protocol.HttpRequ
 import org.apache.http.util.EntityUtils;
 
 class RandomDataHandler implements HttpRequestHandler  {
-    
+
     public RandomDataHandler() {
         super();
     }
-    
+
     public void handle(
-            final HttpRequest request, 
+            final HttpRequest request,
             final HttpResponse response,
             final HttpContext context) throws HttpException, IOException {
         String method = request.getRequestLine().getMethod().toUpperCase(Locale.ENGLISH);
         if (!method.equals("GET") && !method.equals("HEAD") && !method.equals("POST")) {
-            throw new MethodNotSupportedException(method + " method not supported"); 
+            throw new MethodNotSupportedException(method + " method not supported");
         }
         if (request instanceof HttpEntityEnclosingRequest) {
             HttpEntity entity = ((HttpEntityEnclosingRequest) request).getEntity();
@@ -65,7 +65,7 @@ class RandomDataHandler implements HttpR
         String target = request.getRequestLine().getUri();
 
         int count = 100;
-        
+
         int idx = target.indexOf('?');
         if (idx != -1) {
             String s = target.substring(idx + 1);
@@ -75,7 +75,7 @@ class RandomDataHandler implements HttpR
                     count = Integer.parseInt(s);
                 } catch (NumberFormatException ex) {
                     response.setStatusCode(HttpStatus.SC_BAD_REQUEST);
-                    response.setEntity(new StringEntity("Invalid query format: " + s, 
+                    response.setEntity(new StringEntity("Invalid query format: " + s,
                             "text/plain", "ASCII"));
                     return;
                 }
@@ -85,19 +85,19 @@ class RandomDataHandler implements HttpR
         RandomEntity body = new RandomEntity(count);
         response.setEntity(body);
     }
- 
+
     static class RandomEntity extends AbstractHttpEntity {
 
         private int count;
         private final byte[] buf;
-        
+
         public RandomEntity(int count) {
             super();
             this.count = count;
             this.buf = new byte[1024];
             setContentType("text/plain");
         }
-        
+
         public InputStream getContent() throws IOException, IllegalStateException {
             throw new IllegalStateException("Method not supported");
         }
@@ -126,7 +126,7 @@ class RandomDataHandler implements HttpR
                 remaining -= chunk;
             }
         }
-        
+
     }
-    
+
 }
\ No newline at end of file

Modified: httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/StdHttpWorkerCallback.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/StdHttpWorkerCallback.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/StdHttpWorkerCallback.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/httpcore/StdHttpWorkerCallback.java Fri Apr 23 19:12:59 2010
@@ -36,7 +36,7 @@ import org.apache.http.HttpException;
 class StdHttpWorkerCallback implements HttpWorkerCallback {
 
     private final Queue<HttpWorker> queue;
-    
+
     public StdHttpWorkerCallback(final Queue<HttpWorker> queue) {
         super();
         this.queue = queue;
@@ -45,7 +45,7 @@ class StdHttpWorkerCallback implements H
     public void started(final HttpWorker worker) {
         this.queue.add(worker);
     }
-    
+
     public void shutdown(final HttpWorker worker) {
         this.queue.remove(worker);
         Exception ex = worker.getException();

Modified: httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/jetty/JettyNIOServer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/jetty/JettyNIOServer.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/jetty/JettyNIOServer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/jetty/JettyNIOServer.java Fri Apr 23 19:12:59 2010
@@ -37,29 +37,29 @@ import org.eclipse.jetty.util.thread.Que
 public class JettyNIOServer implements HttpServer {
 
     private final Server server;
-    
+
     public JettyNIOServer(int port) throws IOException {
         super();
         if (port <= 0) {
             throw new IllegalArgumentException("Server port may not be negative or null");
         }
-        
+
         SelectChannelConnector connector = new SelectChannelConnector();
         connector.setPort(port);
         connector.setRequestBufferSize(12 * 1024);
         connector.setResponseBufferSize(12 * 1024);
         connector.setAcceptors(2);
-        
+
         QueuedThreadPool threadpool = new QueuedThreadPool();
         threadpool.setMinThreads(25);
         threadpool.setMaxThreads(200);
-        
+
         this.server = new Server();
         this.server.addConnector(connector);
         this.server.setThreadPool(threadpool);
         this.server.setHandler(new RandomDataHandler());
     }
-    
+
     public String getName() {
         return "Jetty (NIO)";
     }
@@ -71,7 +71,7 @@ public class JettyNIOServer implements H
     public void start() throws Exception {
         this.server.start();
     }
-    
+
     public void shutdown() {
         try {
             this.server.stop();
@@ -82,7 +82,7 @@ public class JettyNIOServer implements H
         } catch (InterruptedException ex) {
         }
     }
-    
+
     public static void main(String[] args) throws Exception {
         if (args.length != 1) {
             System.out.println("Usage: <port>");
@@ -92,15 +92,15 @@ public class JettyNIOServer implements H
         final JettyNIOServer server = new JettyNIOServer(port);
         System.out.println("Listening on port: " + port);
         server.start();
-        
+
         Runtime.getRuntime().addShutdownHook(new Thread() {
 
             @Override
             public void run() {
                 server.shutdown();
             }
-            
+
         });
     }
-    
+
 }

Modified: httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/jetty/JettyServer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/jetty/JettyServer.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/jetty/JettyServer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/jetty/JettyServer.java Fri Apr 23 19:12:59 2010
@@ -37,29 +37,29 @@ import org.eclipse.jetty.util.thread.Que
 public class JettyServer implements HttpServer {
 
     private final Server server;
-    
+
     public JettyServer(int port) throws IOException {
         super();
         if (port <= 0) {
             throw new IllegalArgumentException("Server port may not be negative or null");
         }
-        
+
         SocketConnector connector = new SocketConnector();
         connector.setPort(port);
         connector.setRequestBufferSize(12 * 1024);
         connector.setResponseBufferSize(12 * 1024);
         connector.setAcceptors(2);
-        
+
         QueuedThreadPool threadpool = new QueuedThreadPool();
         threadpool.setMinThreads(25);
         threadpool.setMaxThreads(200);
-        
+
         this.server = new Server();
         this.server.addConnector(connector);
         this.server.setThreadPool(threadpool);
         this.server.setHandler(new RandomDataHandler());
     }
-    
+
     public String getName() {
         return "Jetty (blocking I/O)";
     }
@@ -71,7 +71,7 @@ public class JettyServer implements Http
     public void start() throws Exception {
         this.server.start();
     }
-    
+
     public void shutdown() {
         try {
             this.server.stop();
@@ -82,7 +82,7 @@ public class JettyServer implements Http
         } catch (InterruptedException ex) {
         }
     }
-    
+
     public static void main(String[] args) throws Exception {
         if (args.length != 1) {
             System.out.println("Usage: <port>");
@@ -92,15 +92,15 @@ public class JettyServer implements Http
         final JettyServer server = new JettyServer(port);
         System.out.println("Listening on port: " + port);
         server.start();
-        
+
         Runtime.getRuntime().addShutdownHook(new Thread() {
 
             @Override
             public void run() {
                 server.shutdown();
             }
-            
+
         });
     }
-    
+
 }

Modified: httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/jetty/RandomDataHandler.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/jetty/RandomDataHandler.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/jetty/RandomDataHandler.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-benchmark/src/main/java/org/apache/http/benchmark/jetty/RandomDataHandler.java Fri Apr 23 19:12:59 2010
@@ -39,15 +39,15 @@ import org.eclipse.jetty.server.Request;
 import org.eclipse.jetty.server.handler.AbstractHandler;
 
 class RandomDataHandler extends AbstractHandler {
-    
+
     public RandomDataHandler() {
         super();
     }
-    
+
     public void handle(
-            final String target, 
-            final Request baseRequest, 
-            final HttpServletRequest request, 
+            final String target,
+            final Request baseRequest,
+            final HttpServletRequest request,
             final HttpServletResponse response) throws IOException, ServletException {
         if (target.equals("/rnd")) {
             rnd(request, response);
@@ -60,7 +60,7 @@ class RandomDataHandler extends Abstract
     }
 
     private void rnd(
-            final HttpServletRequest request, 
+            final HttpServletRequest request,
             final HttpServletResponse response) throws IOException, ServletException {
         int count = 100;
         String s = request.getParameter("c");
@@ -73,10 +73,10 @@ class RandomDataHandler extends Abstract
             writer.flush();
             return;
         }
-        
+
         response.setStatus(200);
         response.setContentLength(count);
-        
+
         OutputStream outstream = response.getOutputStream();
         byte[] tmp = new byte[1024];
         int r = Math.abs(tmp.hashCode());
@@ -91,5 +91,5 @@ class RandomDataHandler extends Abstract
         }
         outstream.flush();
     }
-    
+
 }
\ No newline at end of file

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/GzipCompressingEntity.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/GzipCompressingEntity.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/GzipCompressingEntity.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/GzipCompressingEntity.java Fri Apr 23 19:12:59 2010
@@ -45,7 +45,7 @@ import org.apache.http.protocol.HTTP;
  * @since 4.0
  */
 public class GzipCompressingEntity extends HttpEntityWrapper {
-    
+
     private static final String GZIP_CODEC = "gzip";
 
     public GzipCompressingEntity(final HttpEntity entity) {

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/GzipDecompressingEntity.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/GzipDecompressingEntity.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/GzipDecompressingEntity.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/GzipDecompressingEntity.java Fri Apr 23 19:12:59 2010
@@ -45,7 +45,7 @@ public class GzipDecompressingEntity ext
       public GzipDecompressingEntity(final HttpEntity entity) {
           super(entity);
       }
-  
+
       public InputStream getContent()
           throws IOException, IllegalStateException {
 

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/RequestAcceptEncoding.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/RequestAcceptEncoding.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/RequestAcceptEncoding.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/RequestAcceptEncoding.java Fri Apr 23 19:12:59 2010
@@ -44,12 +44,12 @@ public class RequestAcceptEncoding imple
 
     private static final String ACCEPT_ENCODING = "Accept-Encoding";
     private static final String GZIP_CODEC = "gzip";
-    
-    public void process(final HttpRequest request, final HttpContext context) 
+
+    public void process(final HttpRequest request, final HttpContext context)
             throws HttpException, IOException {
         if (!request.containsHeader(ACCEPT_ENCODING)) {
             request.addHeader(ACCEPT_ENCODING, GZIP_CODEC);
         }
     }
-    
+
 }

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/ResponseGzipCompress.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/ResponseGzipCompress.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/ResponseGzipCompress.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/ResponseGzipCompress.java Fri Apr 23 19:12:59 2010
@@ -48,8 +48,8 @@ public class ResponseGzipCompress implem
 
     private static final String ACCEPT_ENCODING = "Accept-Encoding";
     private static final String GZIP_CODEC = "gzip";
-    
-    public void process(final HttpResponse response, final HttpContext context) 
+
+    public void process(final HttpResponse response, final HttpContext context)
             throws HttpException, IOException {
         if (context == null) {
             throw new IllegalArgumentException("HTTP context may not be null");
@@ -61,11 +61,11 @@ public class ResponseGzipCompress implem
             HeaderElement[] codecs = aeheader.getElements();
             for (int i = 0; i < codecs.length; i++) {
                 if (codecs[i].getName().equalsIgnoreCase(GZIP_CODEC)) {
-                    response.setEntity(new GzipCompressingEntity(response.getEntity())); 
+                    response.setEntity(new GzipCompressingEntity(response.getEntity()));
                     return;
                 }
             }
         }
     }
-    
+
 }

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/ResponseGzipUncompress.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/ResponseGzipUncompress.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/ResponseGzipUncompress.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/compress/ResponseGzipUncompress.java Fri Apr 23 19:12:59 2010
@@ -46,8 +46,8 @@ import org.apache.http.protocol.HttpCont
 public class ResponseGzipUncompress implements HttpResponseInterceptor {
 
     private static final String GZIP_CODEC = "gzip";
-    
-    public void process(final HttpResponse response, final HttpContext context) 
+
+    public void process(final HttpResponse response, final HttpContext context)
             throws HttpException, IOException {
         if (context == null) {
             throw new IllegalArgumentException("HTTP context may not be null");
@@ -58,11 +58,11 @@ public class ResponseGzipUncompress impl
             HeaderElement[] codecs = ceheader.getElements();
             for (int i = 0; i < codecs.length; i++) {
                 if (codecs[i].getName().equalsIgnoreCase(GZIP_CODEC)) {
-                    response.setEntity(new GzipDecompressingEntity(response.getEntity())); 
+                    response.setEntity(new GzipDecompressingEntity(response.getEntity()));
                     return;
                 }
             }
         }
     }
-    
+
 }

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingClientIOEventDispatch.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingClientIOEventDispatch.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingClientIOEventDispatch.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingClientIOEventDispatch.java Fri Apr 23 19:12:59 2010
@@ -36,7 +36,7 @@ import org.apache.http.params.HttpParams
 public class LoggingClientIOEventDispatch extends DefaultClientIOEventDispatch {
 
     public LoggingClientIOEventDispatch(
-            final NHttpClientHandler handler, 
+            final NHttpClientHandler handler,
             final HttpParams params) {
         super(new LoggingNHttpClientHandler(handler), params);
     }
@@ -49,5 +49,5 @@ public class LoggingClientIOEventDispatc
             this.allocator,
             this.params);
     }
-    
+
 }

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingIOSession.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingIOSession.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingIOSession.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingIOSession.java Fri Apr 23 19:12:59 2010
@@ -40,20 +40,20 @@ import org.apache.http.nio.reactor.IOSes
 import org.apache.http.nio.reactor.SessionBufferStatus;
 
 /**
- * Decorator class intended to transparently extend an {@link IOSession} 
- * with basic event logging capabilities using Commons Logging. 
- * 
+ * Decorator class intended to transparently extend an {@link IOSession}
+ * with basic event logging capabilities using Commons Logging.
+ *
  */
 public class LoggingIOSession implements IOSession {
 
     private static AtomicLong COUNT = new AtomicLong(0);
-    
+
     private final Log log;
     private final Wire wirelog;
     private final IOSession session;
     private final ByteChannel channel;
     private final String id;
-    
+
     public LoggingIOSession(final IOSession session, final String id) {
         super();
         if (session == null) {
@@ -100,10 +100,10 @@ public class LoggingIOSession implements
         buffer.append(']');
         return buffer.toString();
     }
-    
+
     public void setEventMask(int ops) {
         if (this.log.isDebugEnabled()) {
-            this.log.debug("I/O session " + this.id + " " + this.session + ": Set event mask " 
+            this.log.debug("I/O session " + this.id + " " + this.session + ": Set event mask "
                     + formatOps(ops));
         }
         this.session.setEventMask(ops);
@@ -111,7 +111,7 @@ public class LoggingIOSession implements
 
     public void setEvent(int op) {
         if (this.log.isDebugEnabled()) {
-            this.log.debug("I/O session " + this.id + " " + this.session + ": Set event " 
+            this.log.debug("I/O session " + this.id + " " + this.session + ": Set event "
                     + formatOps(op));
         }
         this.session.setEvent(op);
@@ -119,7 +119,7 @@ public class LoggingIOSession implements
 
     public void clearEvent(int op) {
         if (this.log.isDebugEnabled()) {
-            this.log.debug("I/O session " + this.id + " " + this.session + ": Clear event " 
+            this.log.debug("I/O session " + this.id + " " + this.session + ": Clear event "
                     + formatOps(op));
         }
         this.session.clearEvent(op);
@@ -153,7 +153,7 @@ public class LoggingIOSession implements
 
     public void setSocketTimeout(int timeout) {
         if (this.log.isDebugEnabled()) {
-            this.log.debug("I/O session " + this.id + " " + this.session + ": Set timeout " 
+            this.log.debug("I/O session " + this.id + " " + this.session + ": Set timeout "
                     + timeout);
         }
         this.session.setSocketTimeout(timeout);
@@ -177,7 +177,7 @@ public class LoggingIOSession implements
 
     public void setAttribute(final String name, final Object obj) {
         if (this.log.isDebugEnabled()) {
-            this.log.debug("I/O session " + this.id + " " + this.session + ": Set attribute " 
+            this.log.debug("I/O session " + this.id + " " + this.session + ": Set attribute "
                     + name);
         }
         this.session.setAttribute(name, obj);
@@ -185,7 +185,7 @@ public class LoggingIOSession implements
 
     public Object removeAttribute(final String name) {
         if (this.log.isDebugEnabled()) {
-            this.log.debug("I/O session " + this.id + " " + this.session + ": Remove attribute " 
+            this.log.debug("I/O session " + this.id + " " + this.session + ": Remove attribute "
                     + name);
         }
         return this.session.removeAttribute(name);
@@ -233,7 +233,7 @@ public class LoggingIOSession implements
         public boolean isOpen() {
             return session.channel().isOpen();
         }
-        
-    }    
-    
+
+    }
+
 }
\ No newline at end of file

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingNHttpClientHandler.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingNHttpClientHandler.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingNHttpClientHandler.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingNHttpClientHandler.java Fri Apr 23 19:12:59 2010
@@ -40,16 +40,16 @@ import org.apache.http.nio.NHttpClientCo
 import org.apache.http.nio.NHttpClientHandler;
 
 /**
- * Decorator class intended to transparently extend an {@link NHttpClientHandler} 
- * with basic event logging capabilities using Commons Logging. 
- * 
+ * Decorator class intended to transparently extend an {@link NHttpClientHandler}
+ * with basic event logging capabilities using Commons Logging.
+ *
  */
 public class LoggingNHttpClientHandler implements NHttpClientHandler {
 
     private final Log log;
     private final Log headerlog;
     private final NHttpClientHandler handler;
-    
+
     public LoggingNHttpClientHandler(final NHttpClientHandler handler) {
         super();
         if (handler == null) {
@@ -59,7 +59,7 @@ public class LoggingNHttpClientHandler i
         this.log = LogFactory.getLog(handler.getClass());
         this.headerlog = LogFactory.getLog("org.apache.http.headers");
     }
-    
+
     public void connected(final NHttpClientConnection conn, final Object attachment) {
         if (this.log.isDebugEnabled()) {
             this.log.debug("HTTP connection " + conn + ": Connected (" + attachment + ")");

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingNHttpServiceHandler.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingNHttpServiceHandler.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingNHttpServiceHandler.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingNHttpServiceHandler.java Fri Apr 23 19:12:59 2010
@@ -40,16 +40,16 @@ import org.apache.http.nio.NHttpServerCo
 import org.apache.http.nio.NHttpServiceHandler;
 
 /**
- * Decorator class intended to transparently extend an {@link NHttpServiceHandler} 
- * with basic event logging capabilities using Commons Logging. 
- * 
+ * Decorator class intended to transparently extend an {@link NHttpServiceHandler}
+ * with basic event logging capabilities using Commons Logging.
+ *
  */
 public class LoggingNHttpServiceHandler implements NHttpServiceHandler {
 
     private final Log log;
     private final Log headerlog;
     private final NHttpServiceHandler handler;
-    
+
     public LoggingNHttpServiceHandler(final NHttpServiceHandler handler) {
         super();
         if (handler == null) {
@@ -59,7 +59,7 @@ public class LoggingNHttpServiceHandler 
         this.log = LogFactory.getLog(handler.getClass());
         this.headerlog = LogFactory.getLog("org.apache.http.headers");
     }
-    
+
     public void connected(final NHttpServerConnection conn) {
         if (this.log.isDebugEnabled()) {
             this.log.debug("HTTP connection " + conn + ": Connected");

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingServerIOEventDispatch.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingServerIOEventDispatch.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingServerIOEventDispatch.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/LoggingServerIOEventDispatch.java Fri Apr 23 19:12:59 2010
@@ -36,18 +36,18 @@ import org.apache.http.params.HttpParams
 public class LoggingServerIOEventDispatch extends DefaultServerIOEventDispatch {
 
     public LoggingServerIOEventDispatch(
-            final NHttpServiceHandler handler, 
+            final NHttpServiceHandler handler,
             final HttpParams params) {
         super(new LoggingNHttpServiceHandler(handler), params);
     }
 
     @Override
     protected NHttpServerIOTarget createConnection(final IOSession session) {
-        return new LoggingNHttpServerConnection(            
+        return new LoggingNHttpServerConnection(
             new LoggingIOSession(session, "server"),
             createHttpRequestFactory(),
             this.allocator,
             this.params);
     }
-    
+
 }

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/Wire.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/Wire.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/Wire.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/logging/Wire.java Fri Apr 23 19:12:59 2010
@@ -33,12 +33,12 @@ import org.apache.commons.logging.Log;
 class Wire {
 
     private final Log log;
-    
+
     public Wire(final Log log) {
         super();
         this.log = log;
     }
-    
+
     private void wire(final String header, final byte[] b, int pos, int off) {
         StringBuilder buffer = new StringBuilder();
         for (int i = 0; i < off; i++) {
@@ -58,7 +58,7 @@ class Wire {
             } else {
                 buffer.append((char) ch);
             }
-        } 
+        }
         if (buffer.length() > 0) {
             buffer.append('\"');
             buffer.insert(0, '\"');
@@ -70,8 +70,8 @@ class Wire {
 
     public boolean isEnabled() {
         return this.log.isDebugEnabled();
-    }    
-    
+    }
+
     public void output(final byte[] b, int pos, int off) {
         wire("<< ", b, pos, off);
     }

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/BasicCompactHeader.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/BasicCompactHeader.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/BasicCompactHeader.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/BasicCompactHeader.java Fri Apr 23 19:12:59 2010
@@ -32,7 +32,7 @@ import org.apache.http.message.BasicHead
 
 /**
  * Represents a SIP (or HTTP) header field with optional compact name.
- * 
+ *
  *
  */
 public class BasicCompactHeader extends BasicHeader

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/BasicCompactHeaderMapper.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/BasicCompactHeaderMapper.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/BasicCompactHeaderMapper.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/BasicCompactHeaderMapper.java Fri Apr 23 19:12:59 2010
@@ -36,7 +36,7 @@ import java.util.Collections;
 /**
  * Basic implementation of a {@link CompactHeaderMapper}.
  * Header names are assumed to be case insensitive.
- * 
+ *
  *
  */
 public class BasicCompactHeaderMapper implements CompactHeaderMapper {
@@ -177,7 +177,7 @@ public class BasicCompactHeaderMapper im
 
         return result;
     }
-    
+
 
     // initializes the default mapper and switches it to read-only mode
     static {

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/BufferedCompactHeader.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/BufferedCompactHeader.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/BufferedCompactHeader.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/BufferedCompactHeader.java Fri Apr 23 19:12:59 2010
@@ -39,7 +39,7 @@ import org.apache.http.message.BasicHead
  * Represents a SIP (or HTTP) header field parsed 'on demand'.
  * The name of the header will be parsed and mapped immediately,
  * the value only when accessed
- * 
+ *
  *
  */
 public class BufferedCompactHeader
@@ -55,7 +55,7 @@ public class BufferedCompactHeader
      * The buffer containing the entire header line.
      */
     private final CharArrayBuffer buffer;
-    
+
     /**
      * The beginning of the header value in the buffer
      */
@@ -158,7 +158,7 @@ public class BufferedCompactHeader
         // no need to make a copy of it
         return super.clone();
     }
- 
+
 }
 
 

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/CompactHeader.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/CompactHeader.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/CompactHeader.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/CompactHeader.java Fri Apr 23 19:12:59 2010
@@ -43,7 +43,7 @@ import org.apache.http.Header;
  * While all compact names defined so far are single-character names,
  * RFC 3261 does not mandate that. This interface therefore allows for
  * strings as the compact name.
- * 
+ *
  *
  */
 public interface CompactHeader extends Header {

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/CompactHeaderMapper.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/CompactHeaderMapper.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/CompactHeaderMapper.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/CompactHeaderMapper.java Fri Apr 23 19:12:59 2010
@@ -41,7 +41,7 @@ package org.apache.http.contrib.sip;
  * While all compact names defined so far are single-character names,
  * RFC 3261 does not mandate that. This interface therefore allows for
  * strings as the compact name.
- * 
+ *
  *
  */
 public interface CompactHeaderMapper {

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/EnglishSipReasonPhraseCatalog.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/EnglishSipReasonPhraseCatalog.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/EnglishSipReasonPhraseCatalog.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/EnglishSipReasonPhraseCatalog.java Fri Apr 23 19:12:59 2010
@@ -41,8 +41,8 @@ import org.apache.http.ReasonPhraseCatal
  * http://www.iana.org/assignments/sip-parameters
  * </a>
  * for a full list of registered SIP status codes and the defining RFCs.
- * 
- * 
+ *
+ *
  */
 public class EnglishSipReasonPhraseCatalog
     implements ReasonPhraseCatalog {

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/SipException.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/SipException.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/SipException.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/SipException.java Fri Apr 23 19:12:59 2010
@@ -35,8 +35,8 @@ import org.apache.http.HttpException;
  * Signals that an SIP exception has occurred.
  * This is for protocol errors specific to SIP,
  * as opposed to protocol errors shared with HTTP.
- * 
- * 
+ *
+ *
  */
 public class SipException extends HttpException {
 
@@ -60,7 +60,7 @@ public class SipException extends HttpEx
 
     /**
      * Creates a new SipException with the specified detail message and cause.
-     * 
+     *
      * @param message the exception detail message
      * @param cause   the <tt>Throwable</tt> that caused this exception, or
      *                <tt>null</tt> if the cause is unavailable, unknown, or

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/SipStatus.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/SipStatus.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/SipStatus.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/SipStatus.java Fri Apr 23 19:12:59 2010
@@ -39,8 +39,8 @@ package org.apache.http.contrib.sip;
  * RFC 4412 (Communications Resource Priority for SIP),
  * RFC 4474 (Enhancements for Authenticated Identity Management in SIP),
  * and others.
- * 
- * 
+ *
+ *
  */
 public interface SipStatus {
 

Modified: httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/SipVersion.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/SipVersion.java?rev=937478&r1=937477&r2=937478&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/SipVersion.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-contrib/src/main/java/org/apache/http/contrib/sip/SipVersion.java Fri Apr 23 19:12:59 2010
@@ -34,8 +34,8 @@ import org.apache.http.ProtocolVersion;
 
 /**
  * Represents an SIP version, as specified in RFC 3261.
- * 
- * 
+ *
+ *
  */
 public final class SipVersion extends ProtocolVersion
     implements Serializable {
@@ -44,17 +44,17 @@ public final class SipVersion extends Pr
 
     /** The protocol name. */
     public static final String SIP = "SIP";
-    
+
     /** SIP protocol version 2.0 */
     public static final SipVersion SIP_2_0 = new SipVersion(2, 0);
 
-    
+
     /**
      * Create a SIP protocol version designator.
      *
      * @param major   the major version number of the SIP protocol
      * @param minor   the minor version number of the SIP protocol
-     * 
+     *
      * @throws IllegalArgumentException
      *         if either major or minor version number is negative
      */