You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hc.apache.org by gg...@apache.org on 2013/01/15 19:30:06 UTC

svn commit: r1433569 [10/12] - in /httpcomponents: benchmark/httpcore/trunk/src/main/java/org/apache/http/benchmark/ benchmark/httpcore/trunk/src/main/java/org/apache/http/benchmark/httpcore/ benchmark/httpcore/trunk/src/main/java/org/apache/http/bench...

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/main/java/org/apache/http/nio/util/SimpleOutputBuffer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/main/java/org/apache/http/nio/util/SimpleOutputBuffer.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/main/java/org/apache/http/nio/util/SimpleOutputBuffer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/main/java/org/apache/http/nio/util/SimpleOutputBuffer.java Tue Jan 15 18:29:58 2013
@@ -43,7 +43,7 @@ public class SimpleOutputBuffer extends 
 
     private boolean endOfStream;
 
-    public SimpleOutputBuffer(int buffersize, final ByteBufferAllocator allocator) {
+    public SimpleOutputBuffer(final int buffersize, final ByteBufferAllocator allocator) {
         super(buffersize, allocator);
         this.endOfStream = false;
     }
@@ -51,7 +51,7 @@ public class SimpleOutputBuffer extends 
     /**
      * @since 4.3
      */
-    public SimpleOutputBuffer(int buffersize) {
+    public SimpleOutputBuffer(final int buffersize) {
         this(buffersize, HeapByteBufferAllocator.INSTANCE);
     }
 
@@ -64,7 +64,7 @@ public class SimpleOutputBuffer extends 
         return bytesWritten;
     }
 
-    public void write(final byte[] b, int off, int len) throws IOException {
+    public void write(final byte[] b, final int off, final int len) throws IOException {
         if (b == null) {
             return;
         }
@@ -86,7 +86,7 @@ public class SimpleOutputBuffer extends 
         write(b, 0, b.length);
     }
 
-    public void write(int b) throws IOException {
+    public void write(final int b) throws IOException {
         if (this.endOfStream) {
             return;
         }

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/codecs/TestChunkEncoder.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/codecs/TestChunkEncoder.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/codecs/TestChunkEncoder.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/codecs/TestChunkEncoder.java Tue Jan 15 18:29:58 2013
@@ -245,11 +245,11 @@ public class TestChunkEncoder {
         private final ByteArrayOutputStream baos = new ByteArrayOutputStream();
         private final ByteBuffer buffer;
 
-        public FixedByteChannel(int size) {
+        public FixedByteChannel(final int size) {
             this.buffer = ByteBuffer.allocate(size);
         }
 
-        public int write(ByteBuffer src) throws IOException {
+        public int write(final ByteBuffer src) throws IOException {
             // copy bytes into baos for result evaluation
             final int start = src.position();
             int count = 0;
@@ -280,7 +280,7 @@ public class TestChunkEncoder {
             buffer.clear();
         }
 
-        public String toString(String encoding) throws UnsupportedEncodingException {
+        public String toString(final String encoding) throws UnsupportedEncodingException {
             return baos.toString(encoding);
         }
     }

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/codecs/TestIdentityDecoder.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/codecs/TestIdentityDecoder.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/codecs/TestIdentityDecoder.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/codecs/TestIdentityDecoder.java Tue Jan 15 18:29:58 2013
@@ -185,7 +185,7 @@ public class TestIdentityDecoder {
         deleteWithCheck(fileHandle);
     }
 
-    private void deleteWithCheck(File handle){
+    private void deleteWithCheck(final File handle){
         if (!handle.delete() && handle.exists()){
             System.err.println("Failed to delete: "+handle.getPath());
         }

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/codecs/TestLengthDelimitedEncoder.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/codecs/TestLengthDelimitedEncoder.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/codecs/TestLengthDelimitedEncoder.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/codecs/TestLengthDelimitedEncoder.java Tue Jan 15 18:29:58 2013
@@ -172,7 +172,7 @@ public class TestLengthDelimitedEncoder 
         deleteWithCheck(tmpFile);
     }
 
-    private void deleteWithCheck(File handle){
+    private void deleteWithCheck(final File handle){
         if (!handle.delete() && handle.exists()){
             System.err.println("Failed to delete: "+handle.getPath());
         }

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/reactor/TestBaseIOReactorSSL.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/reactor/TestBaseIOReactorSSL.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/reactor/TestBaseIOReactorSSL.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/reactor/TestBaseIOReactorSSL.java Tue Jan 15 18:29:58 2013
@@ -120,8 +120,8 @@ public class TestBaseIOReactorSSL extend
     public void testBufferedInput() throws Exception {
         final int[] result = new int[1];
         HttpRequestHandler requestHandler = new HttpRequestHandler() {
-            public void handle(HttpRequest request, HttpResponse response,
-                    HttpContext context) throws HttpException, IOException {
+            public void handle(final HttpRequest request, final HttpResponse response,
+                    final HttpContext context) throws HttpException, IOException {
                 result[0]++;
                 synchronized (result) {
                     result.notify();

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/reactor/TestSessionInOutBuffers.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/reactor/TestSessionInOutBuffers.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/reactor/TestSessionInOutBuffers.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/impl/nio/reactor/TestSessionInOutBuffers.java Tue Jan 15 18:29:58 2013
@@ -410,7 +410,7 @@ public class TestSessionInOutBuffers {
         0x432, 0x435, 0x442
     };
 
-    private static String constructString(int [] unicodeChars) {
+    private static String constructString(final int [] unicodeChars) {
         StringBuilder buffer = new StringBuilder();
         if (unicodeChars != null) {
             for (int unicodeChar : unicodeChars) {

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/Job.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/Job.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/Job.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/Job.java Tue Jan 15 18:29:58 2013
@@ -44,7 +44,7 @@ public class Job {
     private volatile String failureMessage;
     private volatile Exception ex;
 
-    public Job(int maxCount) {
+    public Job(final int maxCount) {
         super();
         this.count = RND.nextInt(maxCount - 1) + 1;
         StringBuilder buffer = new StringBuilder();
@@ -59,7 +59,7 @@ public class Job {
         this(1000);
     }
 
-    public Job(final String pattern, int count) {
+    public Job(final String pattern, final int count) {
         super();
         this.count = count;
         this.pattern = pattern;
@@ -105,7 +105,7 @@ public class Job {
         return this.completed;
     }
 
-    public synchronized void setResult(int statusCode, final String result) {
+    public synchronized void setResult(final int statusCode, final String result) {
         if (this.completed) {
             return;
         }

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/RequestHandler.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/RequestHandler.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/RequestHandler.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/RequestHandler.java Tue Jan 15 18:29:58 2013
@@ -54,7 +54,7 @@ final class RequestHandler extends Simpl
         this(false);
     }
 
-    RequestHandler(boolean chunking) {
+    RequestHandler(final boolean chunking) {
         super();
         this.chunking = chunking;
     }

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/RndTestPatternGenerator.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/RndTestPatternGenerator.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/RndTestPatternGenerator.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/RndTestPatternGenerator.java Tue Jan 15 18:29:58 2013
@@ -43,7 +43,7 @@ final class RndTestPatternGenerator {
         return buffer.toString();
     }
 
-    public static int generateCount(int max) {
+    public static int generateCount(final int max) {
         return RND.nextInt(max - 1) + 1;
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/SimpleRequestHandler.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/SimpleRequestHandler.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/SimpleRequestHandler.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/SimpleRequestHandler.java Tue Jan 15 18:29:58 2013
@@ -49,7 +49,7 @@ final class SimpleRequestHandler impleme
         this(false);
     }
 
-    SimpleRequestHandler(boolean chunking) {
+    SimpleRequestHandler(final boolean chunking) {
         super();
         this.chunking = chunking;
     }

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestAsyncNHttpHandlers.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestAsyncNHttpHandlers.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestAsyncNHttpHandlers.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestAsyncNHttpHandlers.java Tue Jan 15 18:29:58 2013
@@ -203,7 +203,7 @@ public class TestAsyncNHttpHandlers exte
         NHttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 return new BasicHttpRequest("GET", s);
             }
@@ -222,7 +222,7 @@ public class TestAsyncNHttpHandlers exte
         NHttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 HttpEntityEnclosingRequest r = new BasicHttpEntityEnclosingRequest("POST", s);
                 NStringEntity entity = null;
@@ -249,7 +249,7 @@ public class TestAsyncNHttpHandlers exte
         NHttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 HttpEntityEnclosingRequest r = new BasicHttpEntityEnclosingRequest("POST", s);
                 NStringEntity entity = null;
@@ -276,7 +276,7 @@ public class TestAsyncNHttpHandlers exte
         NHttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 HttpEntityEnclosingRequest r = new BasicHttpEntityEnclosingRequest("POST", s,
                         HttpVersion.HTTP_1_0);
@@ -303,7 +303,7 @@ public class TestAsyncNHttpHandlers exte
         NHttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 HttpEntityEnclosingRequest r = new BasicHttpEntityEnclosingRequest("POST", s);
                 NStringEntity entity = null;
@@ -356,7 +356,7 @@ public class TestAsyncNHttpHandlers exte
         NHttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 HttpEntityEnclosingRequest r = new BasicHttpEntityEnclosingRequest("POST", s);
                 NStringEntity entity = null;
@@ -461,7 +461,7 @@ public class TestAsyncNHttpHandlers exte
         NHttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 return new BasicHttpRequest("HEAD", s);
             }
@@ -594,7 +594,7 @@ public class TestAsyncNHttpHandlers exte
         NHttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 return new BasicHttpRequest("GET", s);
             }
@@ -630,7 +630,7 @@ public class TestAsyncNHttpHandlers exte
         NHttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 return new BasicHttpRequest("GET", s);
             }
@@ -733,8 +733,8 @@ public class TestAsyncNHttpHandlers exte
                     final HttpContext context) {
                 return null;
             }
-            public void handle(final HttpRequest request, HttpResponse response,
-                    final NHttpResponseTrigger trigger, HttpContext context)
+            public void handle(final HttpRequest request, final HttpResponse response,
+                    final NHttpResponseTrigger trigger, final HttpContext context)
                     throws HttpException, IOException {
                 new Thread() {
                     @Override
@@ -751,7 +751,7 @@ public class TestAsyncNHttpHandlers exte
         NHttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 return new BasicHttpRequest("GET", s);
             }
@@ -849,7 +849,7 @@ public class TestAsyncNHttpHandlers exte
         NHttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 return new BasicHttpRequest("GET", s);
             }
@@ -946,7 +946,7 @@ public class TestAsyncNHttpHandlers exte
         NHttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 HttpEntityEnclosingRequest r = new BasicHttpEntityEnclosingRequest("POST", s);
                 r.setEntity(null);
@@ -1043,7 +1043,7 @@ public class TestAsyncNHttpHandlers exte
         NHttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 HttpEntityEnclosingRequest r = new BasicHttpEntityEnclosingRequest("POST", s);
                 NByteArrayEntity entity = new NByteArrayEntity(new byte[] {1,2,3,4,5} );

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpAsyncHandlers.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpAsyncHandlers.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpAsyncHandlers.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpAsyncHandlers.java Tue Jan 15 18:29:58 2013
@@ -127,11 +127,11 @@ public class TestHttpAsyncHandlers exten
         return start(null, null, requestHandlerResolver, expectationVerifier);
     }
 
-    private static String createRequestUri(final String pattern, int count) {
+    private static String createRequestUri(final String pattern, final int count) {
         return pattern + "x" + count;
     }
 
-    private static String createExpectedString(final String pattern, int count) {
+    private static String createExpectedString(final String pattern, final int count) {
         StringBuilder buffer = new StringBuilder();
         for (int i = 0; i < count; i++) {
             buffer.append(pattern);

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestThrottlingNHttpHandlers.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestThrottlingNHttpHandlers.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestThrottlingNHttpHandlers.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestThrottlingNHttpHandlers.java Tue Jan 15 18:29:58 2013
@@ -225,7 +225,7 @@ public class TestThrottlingNHttpHandlers
         HttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 return new BasicHttpRequest("GET", s);
             }
@@ -243,7 +243,7 @@ public class TestThrottlingNHttpHandlers
         HttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 HttpEntityEnclosingRequest r = new BasicHttpEntityEnclosingRequest("POST", s);
                 NStringEntity entity = null;
@@ -269,7 +269,7 @@ public class TestThrottlingNHttpHandlers
         HttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 HttpEntityEnclosingRequest r = new BasicHttpEntityEnclosingRequest("POST", s);
                 NStringEntity entity = null;
@@ -295,7 +295,7 @@ public class TestThrottlingNHttpHandlers
         HttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 HttpEntityEnclosingRequest r = new BasicHttpEntityEnclosingRequest("POST", s,
                         HttpVersion.HTTP_1_0);
@@ -321,7 +321,7 @@ public class TestThrottlingNHttpHandlers
         HttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 HttpEntityEnclosingRequest r = new BasicHttpEntityEnclosingRequest("POST", s);
                 NStringEntity entity = null;
@@ -373,7 +373,7 @@ public class TestThrottlingNHttpHandlers
         HttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 HttpEntityEnclosingRequest r = new BasicHttpEntityEnclosingRequest("POST", s);
                 NStringEntity entity = null;
@@ -481,7 +481,7 @@ public class TestThrottlingNHttpHandlers
         HttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 return new BasicHttpRequest("HEAD", s);
             }
@@ -584,7 +584,7 @@ public class TestThrottlingNHttpHandlers
         HttpRequestExecutionHandler requestExecutionHandler = new RequestExecutionHandler() {
 
             @Override
-            protected HttpRequest generateRequest(Job testjob) {
+            protected HttpRequest generateRequest(final Job testjob) {
                 String s = testjob.getPattern() + "x" + testjob.getCount();
                 HttpEntityEnclosingRequest r = new BasicHttpEntityEnclosingRequest("POST", s);
                 NStringEntity entity = null;

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestTruncatedChunks.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestTruncatedChunks.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestTruncatedChunks.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestTruncatedChunks.java Tue Jan 15 18:29:58 2013
@@ -122,7 +122,7 @@ public class TestTruncatedChunks extends
             this.completed = true;
         }
 
-        public int write(ByteBuffer src) throws IOException {
+        public int write(final ByteBuffer src) throws IOException {
             int chunk;
             if (!this.done) {
                 this.lineBuffer.clear();

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/pool/TestNIOConnPool.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/pool/TestNIOConnPool.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/pool/TestNIOConnPool.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/pool/TestNIOConnPool.java Tue Jan 15 18:29:58 2013
@@ -68,7 +68,7 @@ public class TestNIOConnPool {
 
     static class LocalConnFactory implements NIOConnFactory<String, IOSession> {
 
-        public IOSession create(String route, IOSession session) throws IOException {
+        public IOSession create(final String route, final IOSession session) throws IOException {
             return session;
         }
 
@@ -77,7 +77,7 @@ public class TestNIOConnPool {
     static class LocalSessionPool extends AbstractNIOConnPool<String, IOSession, LocalPoolEntry> {
 
         public LocalSessionPool(
-                final ConnectingIOReactor ioreactor, int defaultMaxPerRoute, int maxTotal) {
+                final ConnectingIOReactor ioreactor, final int defaultMaxPerRoute, final int maxTotal) {
             super(ioreactor, new LocalConnFactory(), defaultMaxPerRoute, maxTotal);
         }
 

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/HttpClientNio.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/HttpClientNio.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/HttpClientNio.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/HttpClientNio.java Tue Jan 15 18:29:58 2013
@@ -102,15 +102,15 @@ public class HttpClientNio {
         return this.timeout;
     }
 
-    public void setTimeout(int timeout) {
+    public void setTimeout(final int timeout) {
         this.timeout = timeout;
     }
 
-    public void setMaxTotal(int max) {
+    public void setMaxTotal(final int max) {
         this.connpool.setMaxTotal(max);
     }
 
-    public void setMaxPerRoute(int max) {
+    public void setMaxPerRoute(final int max) {
         this.connpool.setDefaultMaxPerRoute(max);
     }
 
@@ -120,7 +120,7 @@ public class HttpClientNio {
         return this.connpool.lease(host, null, this.timeout, TimeUnit.MILLISECONDS, callback);
     }
 
-    public void release(final BasicNIOPoolEntry poolEntry, boolean reusable) {
+    public void release(final BasicNIOPoolEntry poolEntry, final boolean reusable) {
         this.connpool.release(poolEntry, reusable);
     }
 
@@ -201,7 +201,7 @@ public class HttpClientNio {
         IOEventDispatch ioEventDispatch = new DefaultHttpClientIODispatch(clientHandler, this.connFactory) {
 
             @Override
-            protected DefaultNHttpClientConnection createConnection(IOSession session) {
+            protected DefaultNHttpClientConnection createConnection(final IOSession session) {
                 DefaultNHttpClientConnection conn = super.createConnection(session);
                 conn.setSocketTimeout(timeout);
                 return conn;
@@ -257,7 +257,7 @@ public class HttpClientNio {
         return this.ioReactor.getAuditLog();
     }
 
-    public void join(long timeout) throws InterruptedException {
+    public void join(final long timeout) throws InterruptedException {
         if (this.thread != null) {
             this.thread.join(timeout);
         }

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/HttpServerNio.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/HttpServerNio.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/HttpServerNio.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/HttpServerNio.java Tue Jan 15 18:29:58 2013
@@ -83,7 +83,7 @@ public class HttpServerNio {
         return this.timeout;
     }
 
-    public void setTimeout(int timeout) {
+    public void setTimeout(final int timeout) {
         this.timeout = timeout;
     }
 
@@ -95,7 +95,7 @@ public class HttpServerNio {
         IOEventDispatch ioEventDispatch = new DefaultHttpServerIODispatch(serviceHandler, this.connFactory) {
 
             @Override
-            protected DefaultNHttpServerConnection createConnection(IOSession session) {
+            protected DefaultNHttpServerConnection createConnection(final IOSession session) {
                 DefaultNHttpServerConnection conn = super.createConnection(session);
                 conn.setSocketTimeout(timeout);
                 return conn;
@@ -109,7 +109,7 @@ public class HttpServerNio {
         return this.endpoint;
     }
 
-    public void setEndpoint(ListenerEndpoint endpoint) {
+    public void setEndpoint(final ListenerEndpoint endpoint) {
         this.endpoint = endpoint;
     }
 
@@ -155,7 +155,7 @@ public class HttpServerNio {
         return this.ioReactor.getAuditLog();
     }
 
-    public void join(long timeout) throws InterruptedException {
+    public void join(final long timeout) throws InterruptedException {
         if (this.thread != null) {
             this.thread.join(timeout);
         }

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/LoggingIOSession.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/LoggingIOSession.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/LoggingIOSession.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/LoggingIOSession.java Tue Jan 15 18:29:58 2013
@@ -75,7 +75,7 @@ public class LoggingIOSession implements
         return this.session.getEventMask();
     }
 
-    private static String formatOps(int ops) {
+    private static String formatOps(final int ops) {
         StringBuilder buffer = new StringBuilder(6);
         buffer.append('[');
         if ((ops & SelectionKey.OP_READ) > 0) {
@@ -94,21 +94,21 @@ public class LoggingIOSession implements
         return buffer.toString();
     }
 
-    public void setEventMask(int ops) {
+    public void setEventMask(final int ops) {
         this.session.setEventMask(ops);
         if (this.log.isDebugEnabled()) {
             this.log.debug(this.id + " " + this.session + ": Event mask set " + formatOps(ops));
         }
     }
 
-    public void setEvent(int op) {
+    public void setEvent(final int op) {
         this.session.setEvent(op);
         if (this.log.isDebugEnabled()) {
             this.log.debug(this.id + " " + this.session + ": Event set " + formatOps(op));
         }
     }
 
-    public void clearEvent(int op) {
+    public void clearEvent(final int op) {
         this.session.clearEvent(op);
         if (this.log.isDebugEnabled()) {
             this.log.debug(this.id + " " + this.session + ": Event cleared " + formatOps(op));
@@ -141,7 +141,7 @@ public class LoggingIOSession implements
         return this.session.getSocketTimeout();
     }
 
-    public void setSocketTimeout(int timeout) {
+    public void setSocketTimeout(final int timeout) {
         if (this.log.isDebugEnabled()) {
             this.log.debug(this.id + " " + this.session + ": Set timeout " + timeout);
         }

Modified: httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/Wire.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/Wire.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/Wire.java (original)
+++ httpcomponents/httpcore/trunk/httpcore-nio/src/test/java/org/apache/http/nio/testserver/Wire.java Tue Jan 15 18:29:58 2013
@@ -42,7 +42,7 @@ class Wire {
         this.id = id;
     }
 
-    private void wire(final String header, final byte[] b, int pos, int off) {
+    private void wire(final String header, final byte[] b, final int pos, final int off) {
         StringBuilder buffer = new StringBuilder();
         for (int i = 0; i < off; i++) {
             int ch = b[pos + i];
@@ -75,27 +75,27 @@ class Wire {
         return this.log.isDebugEnabled();
     }
 
-    public void output(final byte[] b, int pos, int off) {
+    public void output(final byte[] b, final int pos, final int off) {
         wire("<< ", b, pos, off);
     }
 
-    public void input(final byte[] b, int pos, int off) {
+    public void input(final byte[] b, final int pos, final int off) {
         wire(">> ", b, pos, off);
     }
 
-    public void output(byte[] b) {
+    public void output(final byte[] b) {
         output(b, 0, b.length);
     }
 
-    public void input(byte[] b) {
+    public void input(final byte[] b) {
         input(b, 0, b.length);
     }
 
-    public void output(int b) {
+    public void output(final int b) {
         output(new byte[] {(byte) b});
     }
 
-    public void input(int b) {
+    public void input(final int b) {
         input(new byte[] {(byte) b});
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ContentTooLongException.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ContentTooLongException.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ContentTooLongException.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ContentTooLongException.java Tue Jan 15 18:29:58 2013
@@ -43,7 +43,7 @@ public class ContentTooLongException ext
      *
      * @param message exception message
      */
-    public ContentTooLongException(String message) {
+    public ContentTooLongException(final String message) {
         super(message);
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/HttpHost.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/HttpHost.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/HttpHost.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/HttpHost.java Tue Jan 15 18:29:58 2013
@@ -74,7 +74,7 @@ public final class HttpHost implements C
      *                  <code>null</code> indicates the
      *                  {@link #DEFAULT_SCHEME_NAME default scheme}
      */
-    public HttpHost(final String hostname, int port, final String scheme) {
+    public HttpHost(final String hostname, final int port, final String scheme) {
         super();
         this.hostname   = Args.notNull(hostname, "Host name");
         this.lcHostname = hostname.toLowerCase(Locale.ENGLISH);
@@ -93,7 +93,7 @@ public final class HttpHost implements C
      * @param port      the port number.
      *                  <code>-1</code> indicates the scheme default port.
      */
-    public HttpHost(final String hostname, int port) {
+    public HttpHost(final String hostname, final int port) {
         this(hostname, port, null);
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/HttpVersion.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/HttpVersion.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/HttpVersion.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/HttpVersion.java Tue Jan 15 18:29:58 2013
@@ -71,7 +71,7 @@ public final class HttpVersion extends P
      *
      * @throws IllegalArgumentException if either major or minor version number is negative
      */
-    public HttpVersion(int major, int minor) {
+    public HttpVersion(final int major, final int minor) {
         super(HTTP, major, minor);
     }
 
@@ -85,7 +85,7 @@ public final class HttpVersion extends P
      * @return  an instance of {@link HttpVersion} with the argument version
      */
     @Override
-    public ProtocolVersion forVersion(int major, int minor) {
+    public ProtocolVersion forVersion(final int major, final int minor) {
 
         if ((major == this.major) && (minor == this.minor)) {
             return this;

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/NoHttpResponseException.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/NoHttpResponseException.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/NoHttpResponseException.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/NoHttpResponseException.java Tue Jan 15 18:29:58 2013
@@ -43,7 +43,7 @@ public class NoHttpResponseException ext
      *
      * @param message exception message
      */
-    public NoHttpResponseException(String message) {
+    public NoHttpResponseException(final String message) {
         super(message);
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ParseException.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ParseException.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ParseException.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ParseException.java Tue Jan 15 18:29:58 2013
@@ -54,7 +54,7 @@ public class ParseException extends Runt
      *
      * @param message the exception detail message, or <code>null</code>
      */
-    public ParseException(String message) {
+    public ParseException(final String message) {
         super(message);
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ProtocolException.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ProtocolException.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ProtocolException.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ProtocolException.java Tue Jan 15 18:29:58 2013
@@ -50,7 +50,7 @@ public class ProtocolException extends H
      *
      * @param message The exception detail message
      */
-    public ProtocolException(String message) {
+    public ProtocolException(final String message) {
         super(message);
     }
 
@@ -61,7 +61,7 @@ public class ProtocolException extends H
      * @param cause the <tt>Throwable</tt> that caused this exception, or <tt>null</tt>
      * if the cause is unavailable, unknown, or not a <tt>Throwable</tt>
      */
-    public ProtocolException(String message, Throwable cause) {
+    public ProtocolException(final String message, final Throwable cause) {
         super(message, cause);
     }
 }

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ProtocolVersion.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ProtocolVersion.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ProtocolVersion.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/ProtocolVersion.java Tue Jan 15 18:29:58 2013
@@ -67,7 +67,7 @@ public class ProtocolVersion implements 
      * @param major      the major version number of the protocol
      * @param minor      the minor version number of the protocol
      */
-    public ProtocolVersion(String protocol, int major, int minor) {
+    public ProtocolVersion(final String protocol, final int major, final int minor) {
         this.protocol = Args.notNull(protocol, "Protocol name");
         this.major = Args.notNegative(major, "Protocol minor version");
         this.minor = Args.notNegative(minor, "Protocol minor version");;
@@ -116,7 +116,7 @@ public class ProtocolVersion implements 
      * @return  a protocol version with the same protocol name
      *          and the argument version
      */
-    public ProtocolVersion forVersion(int major, int minor) {
+    public ProtocolVersion forVersion(final int major, final int minor) {
 
         if ((major == this.major) && (minor == this.minor)) {
             return this;
@@ -152,7 +152,7 @@ public class ProtocolVersion implements 
      *          <code>false</code> otherwise
      */
     @Override
-    public final boolean equals(Object obj) {
+    public final boolean equals(final Object obj) {
         if (this == obj) {
             return true;
         }
@@ -177,7 +177,7 @@ public class ProtocolVersion implements 
      * @return  <code>true</code> if {@link #compareToVersion compareToVersion}
      *          can be called with the argument, <code>false</code> otherwise
      */
-    public boolean isComparable(ProtocolVersion that) {
+    public boolean isComparable(final ProtocolVersion that) {
         return (that != null) && this.protocol.equals(that.protocol);
     }
 
@@ -198,7 +198,7 @@ public class ProtocolVersion implements 
      *         if the argument has a different protocol name than this object,
      *         or if the argument is <code>null</code>
      */
-    public int compareToVersion(ProtocolVersion that) {
+    public int compareToVersion(final ProtocolVersion that) {
         Args.notNull(that, "Protocol version");
         Args.check(this.protocol.equals(that.protocol),
                 "Versions for different protocols cannot be compared: %s %s", this, that);
@@ -220,7 +220,7 @@ public class ProtocolVersion implements 
      *          and {@link #compareToVersion compares} as greater or equal,
      *          <code>false</code> otherwise
      */
-    public final boolean greaterEquals(ProtocolVersion version) {
+    public final boolean greaterEquals(final ProtocolVersion version) {
         return isComparable(version) && (compareToVersion(version) >= 0);
     }
 
@@ -235,7 +235,7 @@ public class ProtocolVersion implements 
      *          and {@link #compareToVersion compares} as less or equal,
      *          <code>false</code> otherwise
      */
-    public final boolean lessEquals(ProtocolVersion version) {
+    public final boolean lessEquals(final ProtocolVersion version) {
         return isComparable(version) && (compareToVersion(version) <= 0);
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/concurrent/BasicFuture.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/concurrent/BasicFuture.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/concurrent/BasicFuture.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/concurrent/BasicFuture.java Tue Jan 15 18:29:58 2013
@@ -75,7 +75,7 @@ public class BasicFuture<T> implements F
         return getResult();
     }
 
-    public synchronized T get(long timeout, final TimeUnit unit)
+    public synchronized T get(final long timeout, final TimeUnit unit)
             throws InterruptedException, ExecutionException, TimeoutException {
         long msecs = unit.toMillis(timeout);
         long startTime = (msecs <= 0) ? 0 : System.currentTimeMillis();
@@ -125,7 +125,7 @@ public class BasicFuture<T> implements F
         return true;
     }
 
-    public synchronized boolean cancel(boolean mayInterruptIfRunning) {
+    public synchronized boolean cancel(final boolean mayInterruptIfRunning) {
         if (this.completed) {
             return false;
         }

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/config/MessageConstraints.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/config/MessageConstraints.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/config/MessageConstraints.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/config/MessageConstraints.java Tue Jan 15 18:29:58 2013
@@ -41,7 +41,7 @@ public class MessageConstraints implemen
     private final int maxLineLength;
     private final int maxHeaderCount;
 
-    MessageConstraints(int maxLineLength, int maxHeaderCount) {
+    MessageConstraints(final int maxLineLength, final int maxHeaderCount) {
         super();
         this.maxLineLength = maxLineLength;
         this.maxHeaderCount = maxHeaderCount;
@@ -69,7 +69,7 @@ public class MessageConstraints implemen
         return builder.toString();
     }
 
-    public static MessageConstraints lineLen(int max) {
+    public static MessageConstraints lineLen(final int max) {
         return new MessageConstraints(Args.notNegative(max, "Max line length"), -1);
     }
 
@@ -94,12 +94,12 @@ public class MessageConstraints implemen
             this.maxHeaderCount = -1;
         }
 
-        public Builder setMaxLineLength(int maxLineLength) {
+        public Builder setMaxLineLength(final int maxLineLength) {
             this.maxLineLength = maxLineLength;
             return this;
         }
 
-        public Builder setMaxHeaderCount(int maxHeaderCount) {
+        public Builder setMaxHeaderCount(final int maxHeaderCount) {
             this.maxHeaderCount = maxHeaderCount;
             return this;
         }

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/config/SocketConfig.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/config/SocketConfig.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/config/SocketConfig.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/config/SocketConfig.java Tue Jan 15 18:29:58 2013
@@ -49,11 +49,11 @@ public class SocketConfig implements Clo
     private final boolean tcpNoDelay;
 
     SocketConfig(
-            int soTimeout,
-            boolean soReuseAddress,
-            int soLinger,
-            boolean soKeepAlive,
-            boolean tcpNoDelay) {
+            final int soTimeout,
+            final boolean soReuseAddress,
+            final int soLinger,
+            final boolean soKeepAlive,
+            final boolean tcpNoDelay) {
         super();
         this.soTimeout = soTimeout;
         this.soReuseAddress = soReuseAddress;
@@ -165,27 +165,27 @@ public class SocketConfig implements Clo
             this.tcpNoDelay = true;
         }
 
-        public Builder setSoTimeout(int soTimeout) {
+        public Builder setSoTimeout(final int soTimeout) {
             this.soTimeout = soTimeout;
             return this;
         }
 
-        public Builder setSoReuseAddress(boolean soReuseAddress) {
+        public Builder setSoReuseAddress(final boolean soReuseAddress) {
             this.soReuseAddress = soReuseAddress;
             return this;
         }
 
-        public Builder setSoLinger(int soLinger) {
+        public Builder setSoLinger(final int soLinger) {
             this.soLinger = soLinger;
             return this;
         }
 
-        public Builder setSoKeepAlive(boolean soKeepAlive) {
+        public Builder setSoKeepAlive(final boolean soKeepAlive) {
             this.soKeepAlive = soKeepAlive;
             return this;
         }
 
-        public Builder setTcpNoDelay(boolean tcpNoDelay) {
+        public Builder setTcpNoDelay(final boolean tcpNoDelay) {
             this.tcpNoDelay = tcpNoDelay;
             return this;
         }

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/AbstractHttpEntity.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/AbstractHttpEntity.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/AbstractHttpEntity.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/AbstractHttpEntity.java Tue Jan 15 18:29:58 2013
@@ -167,7 +167,7 @@ public abstract class AbstractHttpEntity
      *
      * @param b         the new 'chunked' flag
      */
-    public void setChunked(boolean b) {
+    public void setChunked(final boolean b) {
         this.chunked = b;
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/BasicHttpEntity.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/BasicHttpEntity.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/BasicHttpEntity.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/BasicHttpEntity.java Tue Jan 15 18:29:58 2013
@@ -90,7 +90,7 @@ public class BasicHttpEntity extends Abs
      * @param len       the number of bytes in the content, or
      *                  a negative number to indicate an unknown length
      */
-    public void setContentLength(long len) {
+    public void setContentLength(final long len) {
         this.length = len;
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/ByteArrayEntity.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/ByteArrayEntity.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/ByteArrayEntity.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/ByteArrayEntity.java Tue Jan 15 18:29:58 2013
@@ -69,7 +69,7 @@ public class ByteArrayEntity extends Abs
     /**
      * @since 4.2
      */
-    public ByteArrayEntity(final byte[] b, int off, int len, final ContentType contentType) {
+    public ByteArrayEntity(final byte[] b, final int off, final int len, final ContentType contentType) {
         super();
         Args.notNull(b, "Source byte array");
         if ((off < 0) || (off > b.length) || (len < 0) ||
@@ -89,7 +89,7 @@ public class ByteArrayEntity extends Abs
         this(b, null);
     }
 
-    public ByteArrayEntity(final byte[] b, int off, int len) {
+    public ByteArrayEntity(final byte[] b, final int off, final int len) {
         this(b, off, len, null);
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/ContentType.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/ContentType.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/ContentType.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/ContentType.java Tue Jan 15 18:29:58 2013
@@ -258,7 +258,7 @@ public final class ContentType implement
      * @return a new instance with this MIME type and the given Charset.
      * @since 4.3
      */
-    public ContentType withCharset(Charset charset) {
+    public ContentType withCharset(final Charset charset) {
         return create(this.getMimeType(), charset);
     }
 
@@ -271,7 +271,7 @@ public final class ContentType implement
      * this instance of the Java virtual machine
      * @since 4.3
      */
-    public ContentType withCharset(String charset) {
+    public ContentType withCharset(final String charset) {
         return create(this.getMimeType(), charset);
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/HttpEntityWrapper.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/HttpEntityWrapper.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/HttpEntityWrapper.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/HttpEntityWrapper.java Tue Jan 15 18:29:58 2013
@@ -54,7 +54,7 @@ public class HttpEntityWrapper implement
     /**
      * Creates a new entity wrapper.
      */
-    public HttpEntityWrapper(HttpEntity wrappedEntity) {
+    public HttpEntityWrapper(final HttpEntity wrappedEntity) {
         super();
         this.wrappedEntity = Args.notNull(wrappedEntity, "Wrapped entity");
     } // constructor
@@ -84,7 +84,7 @@ public class HttpEntityWrapper implement
         return wrappedEntity.getContent();
     }
 
-    public void writeTo(OutputStream outstream)
+    public void writeTo(final OutputStream outstream)
         throws IOException {
         wrappedEntity.writeTo(outstream);
     }

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/InputStreamEntity.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/InputStreamEntity.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/InputStreamEntity.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/InputStreamEntity.java Tue Jan 15 18:29:58 2013
@@ -48,14 +48,14 @@ public class InputStreamEntity extends A
     private final InputStream content;
     private final long length;
 
-    public InputStreamEntity(final InputStream instream, long length) {
+    public InputStreamEntity(final InputStream instream, final long length) {
         this(instream, length, null);
     }
 
     /**
      * @since 4.2
      */
-    public InputStreamEntity(final InputStream instream, long length, final ContentType contentType) {
+    public InputStreamEntity(final InputStream instream, final long length, final ContentType contentType) {
         super();
         this.content = Args.notNull(instream, "Source input stream");
         this.length = length;

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/SerializableEntity.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/SerializableEntity.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/SerializableEntity.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/entity/SerializableEntity.java Tue Jan 15 18:29:58 2013
@@ -61,7 +61,7 @@ public class SerializableEntity extends 
      *        stored in an internal buffer
      * @throws IOException in case of an I/O error
      */
-    public SerializableEntity(Serializable ser, boolean bufferize) throws IOException {
+    public SerializableEntity(final Serializable ser, final boolean bufferize) throws IOException {
         super();
         Args.notNull(ser, "Source object");
         if (bufferize) {
@@ -74,13 +74,13 @@ public class SerializableEntity extends 
     /**
      * @since 4.3
      */
-    public SerializableEntity(Serializable ser) {
+    public SerializableEntity(final Serializable ser) {
         super();
         Args.notNull(ser, "Source object");
         this.objRef = ser;
     }
 
-    private void createBytes(Serializable ser) throws IOException {
+    private void createBytes(final Serializable ser) throws IOException {
         ByteArrayOutputStream baos = new ByteArrayOutputStream();
         ObjectOutputStream out = new ObjectOutputStream(baos);
         out.writeObject(ser);
@@ -111,7 +111,7 @@ public class SerializableEntity extends 
         return this.objSer == null;
     }
 
-    public void writeTo(OutputStream outstream) throws IOException {
+    public void writeTo(final OutputStream outstream) throws IOException {
         Args.notNull(outstream, "Output stream");
         if (this.objSer == null) {
             ObjectOutputStream out = new ObjectOutputStream(outstream);

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/AbstractHttpClientConnection.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/AbstractHttpClientConnection.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/AbstractHttpClientConnection.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/AbstractHttpClientConnection.java Tue Jan 15 18:29:58 2013
@@ -238,7 +238,7 @@ public abstract class AbstractHttpClient
                 outbuffer.getMetrics());
     }
 
-    public boolean isResponseAvailable(int timeout) throws IOException {
+    public boolean isResponseAvailable(final int timeout) throws IOException {
         assertOpen();
         try {
             return this.inbuffer.isDataAvailable(timeout);

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/BHttpConnectionBase.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/BHttpConnectionBase.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/BHttpConnectionBase.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/BHttpConnectionBase.java Tue Jan 15 18:29:58 2013
@@ -101,7 +101,7 @@ public class BHttpConnectionBase impleme
      *   {@link StrictContentLengthStrategy#INSTANCE} will be used.
      */
     protected BHttpConnectionBase(
-            int buffersize,
+            final int buffersize,
             final CharsetDecoder chardecoder,
             final CharsetEncoder charencoder,
             final MessageConstraints constraints,
@@ -269,7 +269,7 @@ public class BHttpConnectionBase impleme
         }
     }
 
-    public void setSocketTimeout(int timeout) {
+    public void setSocketTimeout(final int timeout) {
         if (this.socket != null) {
             try {
                 this.socket.setSoTimeout(timeout);
@@ -326,7 +326,7 @@ public class BHttpConnectionBase impleme
         }
     }
 
-    protected boolean awaitInput(int timeout) throws IOException {
+    protected boolean awaitInput(final int timeout) throws IOException {
         if (this.inbuffer.hasBufferedData()) {
             return true;
         }

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultBHttpClientConnection.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultBHttpClientConnection.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultBHttpClientConnection.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultBHttpClientConnection.java Tue Jan 15 18:29:58 2013
@@ -85,7 +85,7 @@ public class DefaultBHttpClientConnectio
      *   {@link DefaultHttpResponseParserFactory#INSTANCE} will be used.
      */
     public DefaultBHttpClientConnection(
-            int buffersize,
+            final int buffersize,
             final CharsetDecoder chardecoder,
             final CharsetEncoder charencoder,
             final MessageConstraints constraints,
@@ -102,14 +102,14 @@ public class DefaultBHttpClientConnectio
     }
 
     public DefaultBHttpClientConnection(
-            int buffersize,
+            final int buffersize,
             final CharsetDecoder chardecoder,
             final CharsetEncoder charencoder,
             final MessageConstraints constraints) {
         this(buffersize, chardecoder, charencoder, constraints, null, null, null, null);
     }
 
-    public DefaultBHttpClientConnection(int buffersize) {
+    public DefaultBHttpClientConnection(final int buffersize) {
         this(buffersize, null, null, null, null, null, null, null);
     }
 
@@ -124,7 +124,7 @@ public class DefaultBHttpClientConnectio
         super.bind(socket);
     }
 
-    public boolean isResponseAvailable(int timeout) throws IOException {
+    public boolean isResponseAvailable(final int timeout) throws IOException {
         ensureOpen();
         try {
             return awaitInput(timeout);

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultBHttpServerConnection.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultBHttpServerConnection.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultBHttpServerConnection.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultBHttpServerConnection.java Tue Jan 15 18:29:58 2013
@@ -84,7 +84,7 @@ public class DefaultBHttpServerConnectio
      *   {@link DefaultHttpResponseWriterFactory#INSTANCE} will be used.
      */
     public DefaultBHttpServerConnection(
-            int buffersize,
+            final int buffersize,
             final CharsetDecoder chardecoder,
             final CharsetEncoder charencoder,
             final MessageConstraints constraints,
@@ -102,14 +102,14 @@ public class DefaultBHttpServerConnectio
     }
 
     public DefaultBHttpServerConnection(
-            int buffersize,
+            final int buffersize,
             final CharsetDecoder chardecoder,
             final CharsetEncoder charencoder,
             final MessageConstraints constraints) {
         this(buffersize, chardecoder, charencoder, constraints, null, null, null, null);
     }
 
-    public DefaultBHttpServerConnection(int buffersize) {
+    public DefaultBHttpServerConnection(final int buffersize) {
         this(buffersize, null, null, null, null, null, null, null);
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultConnectionReuseStrategy.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultConnectionReuseStrategy.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultConnectionReuseStrategy.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultConnectionReuseStrategy.java Tue Jan 15 18:29:58 2013
@@ -174,7 +174,7 @@ public class DefaultConnectionReuseStrat
      *
      * @return  the token iterator
      */
-    protected TokenIterator createTokenIterator(HeaderIterator hit) {
+    protected TokenIterator createTokenIterator(final HeaderIterator hit) {
         return new BasicTokenIterator(hit);
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultHttpResponseFactory.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultHttpResponseFactory.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultHttpResponseFactory.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/DefaultHttpResponseFactory.java Tue Jan 15 18:29:58 2013
@@ -59,7 +59,7 @@ public class DefaultHttpResponseFactory 
      *
      * @param catalog   the catalog of reason phrases
      */
-    public DefaultHttpResponseFactory(ReasonPhraseCatalog catalog) {
+    public DefaultHttpResponseFactory(final ReasonPhraseCatalog catalog) {
         this.reasonCatalog = Args.notNull(catalog, "Reason phrase catalog");
     }
 
@@ -102,7 +102,7 @@ public class DefaultHttpResponseFactory 
      *
      * @return  the locale for the response, never <code>null</code>
      */
-    protected Locale determineLocale(HttpContext context) {
+    protected Locale determineLocale(final HttpContext context) {
         return Locale.getDefault();
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/EnglishReasonPhraseCatalog.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/EnglishReasonPhraseCatalog.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/EnglishReasonPhraseCatalog.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/EnglishReasonPhraseCatalog.java Tue Jan 15 18:29:58 2013
@@ -72,7 +72,7 @@ public class EnglishReasonPhraseCatalog 
      *
      * @return  the reason phrase, or <code>null</code>
      */
-    public String getReason(int status, Locale loc) {
+    public String getReason(final int status, final Locale loc) {
         Args.check(status >= 100 && status < 600, "Unknown category for status code " + status);
         int category = status / 100;
         int subcode  = status - 100*category;
@@ -105,7 +105,7 @@ public class EnglishReasonPhraseCatalog 
      * @param status    the status code for which to define the phrase
      * @param reason    the reason phrase for this status code
      */
-    private static void setReason(int status, String reason) {
+    private static void setReason(final int status, final String reason) {
         final int category = status / 100;
         final int subcode  = status - 100*category;
         REASON_PHRASES[category][subcode] = reason;

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/HttpConnectionMetricsImpl.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/HttpConnectionMetricsImpl.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/HttpConnectionMetricsImpl.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/HttpConnectionMetricsImpl.java Tue Jan 15 18:29:58 2013
@@ -126,7 +126,7 @@ public class HttpConnectionMetricsImpl i
         return value;
     }
 
-    public void setMetric(final String metricName, Object obj) {
+    public void setMetric(final String metricName, final Object obj) {
         if (this.metricsCache == null) {
             this.metricsCache = new HashMap<String, Object>();
         }

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/SocketHttpClientConnection.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/SocketHttpClientConnection.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/SocketHttpClientConnection.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/SocketHttpClientConnection.java Tue Jan 15 18:29:58 2013
@@ -92,7 +92,7 @@ public class SocketHttpClientConnection
      */
     protected SessionInputBuffer createSessionInputBuffer(
             final Socket socket,
-            int buffersize,
+            final int buffersize,
             final HttpParams params) throws IOException {
         return new SocketInputBuffer(socket, buffersize, params);
     }
@@ -114,7 +114,7 @@ public class SocketHttpClientConnection
      */
     protected SessionOutputBuffer createSessionOutputBuffer(
             final Socket socket,
-            int buffersize,
+            final int buffersize,
             final HttpParams params) throws IOException {
         return new SocketOutputBuffer(socket, buffersize, params);
     }
@@ -193,7 +193,7 @@ public class SocketHttpClientConnection
         }
     }
 
-    public void setSocketTimeout(int timeout) {
+    public void setSocketTimeout(final int timeout) {
         assertOpen();
         if (this.socket != null) {
             try {

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/SocketHttpServerConnection.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/SocketHttpServerConnection.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/SocketHttpServerConnection.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/SocketHttpServerConnection.java Tue Jan 15 18:29:58 2013
@@ -91,7 +91,7 @@ public class SocketHttpServerConnection 
      */
     protected SessionInputBuffer createSessionInputBuffer(
             final Socket socket,
-            int buffersize,
+            final int buffersize,
             final HttpParams params) throws IOException {
         return new SocketInputBuffer(socket, buffersize, params);
     }
@@ -113,7 +113,7 @@ public class SocketHttpServerConnection 
      */
     protected SessionOutputBuffer createSessionOutputBuffer(
             final Socket socket,
-            int buffersize,
+            final int buffersize,
             final HttpParams params) throws IOException {
         return new SocketOutputBuffer(socket, buffersize, params);
     }
@@ -190,7 +190,7 @@ public class SocketHttpServerConnection 
         }
     }
 
-    public void setSocketTimeout(int timeout) {
+    public void setSocketTimeout(final int timeout) {
         assertOpen();
         if (this.socket != null) {
             try {

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/entity/LaxContentLengthStrategy.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/entity/LaxContentLengthStrategy.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/entity/LaxContentLengthStrategy.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/entity/LaxContentLengthStrategy.java Tue Jan 15 18:29:58 2013
@@ -62,7 +62,7 @@ public class LaxContentLengthStrategy im
      *
      * @since 4.2
      */
-    public LaxContentLengthStrategy(int implicitLen) {
+    public LaxContentLengthStrategy(final int implicitLen) {
         super();
         this.implicitLen = implicitLen;
     }

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/entity/StrictContentLengthStrategy.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/entity/StrictContentLengthStrategy.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/entity/StrictContentLengthStrategy.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/entity/StrictContentLengthStrategy.java Tue Jan 15 18:29:58 2013
@@ -62,7 +62,7 @@ public class StrictContentLengthStrategy
      *
      * @since 4.2
      */
-    public StrictContentLengthStrategy(int implicitLen) {
+    public StrictContentLengthStrategy(final int implicitLen) {
         super();
         this.implicitLen = implicitLen;
     }

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/AbstractMessageParser.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/AbstractMessageParser.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/AbstractMessageParser.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/AbstractMessageParser.java Tue Jan 15 18:29:58 2013
@@ -138,8 +138,8 @@ public abstract class AbstractMessagePar
      */
     public static Header[] parseHeaders(
             final SessionInputBuffer inbuffer,
-            int maxHeaderCount,
-            int maxLineLen,
+            final int maxHeaderCount,
+            final int maxLineLen,
             LineParser parser)
         throws HttpException, IOException {
         if (parser == null) {
@@ -175,8 +175,8 @@ public abstract class AbstractMessagePar
      */
     public static Header[] parseHeaders(
             final SessionInputBuffer inbuffer,
-            int maxHeaderCount,
-            int maxLineLen,
+            final int maxHeaderCount,
+            final int maxLineLen,
             final LineParser parser,
             final List<CharArrayBuffer> headerLines) throws HttpException, IOException {
         Args.notNull(inbuffer, "Session input buffer");

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/AbstractSessionInputBuffer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/AbstractSessionInputBuffer.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/AbstractSessionInputBuffer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/AbstractSessionInputBuffer.java Tue Jan 15 18:29:58 2013
@@ -92,7 +92,7 @@ public abstract class AbstractSessionInp
      * @param buffersize the size of the internal buffer.
      * @param params HTTP parameters.
      */
-    protected void init(final InputStream instream, int buffersize, final HttpParams params) {
+    protected void init(final InputStream instream, final int buffersize, final HttpParams params) {
         Args.notNull(instream, "Input stream");
         Args.notNegative(buffersize, "Buffer size");
         Args.notNull(params, "HTTP parameters");
@@ -182,7 +182,7 @@ public abstract class AbstractSessionInp
         return this.buffer[this.bufferpos++] & 0xff;
     }
 
-    public int read(final byte[] b, int off, int len) throws IOException {
+    public int read(final byte[] b, final int off, final int len) throws IOException {
         if (b == null) {
             return 0;
         }

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/AbstractSessionOutputBuffer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/AbstractSessionOutputBuffer.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/AbstractSessionOutputBuffer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/AbstractSessionOutputBuffer.java Tue Jan 15 18:29:58 2013
@@ -81,9 +81,9 @@ public abstract class AbstractSessionOut
 
     protected AbstractSessionOutputBuffer(
             final OutputStream outstream,
-            int buffersize,
+            final int buffersize,
             final Charset charset,
-            int minChunkLimit,
+            final int minChunkLimit,
             final CodingErrorAction malformedCharAction,
             final CodingErrorAction unmappableCharAction) {
         super();
@@ -105,7 +105,7 @@ public abstract class AbstractSessionOut
     public AbstractSessionOutputBuffer() {
     }
 
-    protected void init(final OutputStream outstream, int buffersize, final HttpParams params) {
+    protected void init(final OutputStream outstream, final int buffersize, final HttpParams params) {
         Args.notNull(outstream, "Input stream");
         Args.notNegative(buffersize, "Buffer size");
         Args.notNull(params, "HTTP parameters");
@@ -167,7 +167,7 @@ public abstract class AbstractSessionOut
         this.outstream.flush();
     }
 
-    public void write(final byte[] b, int off, int len) throws IOException {
+    public void write(final byte[] b, final int off, final int len) throws IOException {
         if (b == null) {
             return;
         }
@@ -199,7 +199,7 @@ public abstract class AbstractSessionOut
         write(b, 0, b.length);
     }
 
-    public void write(int b) throws IOException {
+    public void write(final int b) throws IOException {
         if (this.buffer.isFull()) {
             flushBuffer();
         }

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/ChunkedInputStream.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/ChunkedInputStream.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/ChunkedInputStream.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/ChunkedInputStream.java Tue Jan 15 18:29:58 2013
@@ -156,7 +156,7 @@ public class ChunkedInputStream extends 
      * @throws IOException in case of an I/O error
      */
     @Override
-    public int read (byte[] b, int off, int len) throws IOException {
+    public int read (final byte[] b, final int off, int len) throws IOException {
 
         if (closed) {
             throw new IOException("Attempted read from closed stream.");
@@ -195,7 +195,7 @@ public class ChunkedInputStream extends 
      * @throws IOException in case of an I/O error
      */
     @Override
-    public int read (byte[] b) throws IOException {
+    public int read (final byte[] b) throws IOException {
         return read(b, 0, b.length);
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/ChunkedOutputStream.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/ChunkedOutputStream.java?rev=1433569&r1=1433568&r2=1433569&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/ChunkedOutputStream.java (original)
+++ httpcomponents/httpcore/trunk/httpcore/src/main/java/org/apache/http/impl/io/ChunkedOutputStream.java Tue Jan 15 18:29:58 2013
@@ -70,7 +70,7 @@ public class ChunkedOutputStream extends
      * @deprecated (4.3) use {@link ChunkedOutputStream#ChunkedOutputStream(int, SessionOutputBuffer)}
      */
     @Deprecated
-    public ChunkedOutputStream(final SessionOutputBuffer out, int bufferSize)
+    public ChunkedOutputStream(final SessionOutputBuffer out, final int bufferSize)
             throws IOException {
         this(bufferSize, out);
     }
@@ -96,7 +96,7 @@ public class ChunkedOutputStream extends
      * @param bufferSize The minimum chunk size (excluding last chunk)
      * @param out The session output buffer
      */
-    public ChunkedOutputStream(int bufferSize, final SessionOutputBuffer out) {
+    public ChunkedOutputStream(final int bufferSize, final SessionOutputBuffer out) {
         super();
         this.cache = new byte[bufferSize];
         this.out = out;
@@ -118,7 +118,7 @@ public class ChunkedOutputStream extends
      * Writes the cache and bufferToAppend to the underlying stream
      * as one large chunk
      */
-    protected void flushCacheWithAppend(byte bufferToAppend[], int off, int len) throws IOException {
+    protected void flushCacheWithAppend(final byte bufferToAppend[], final int off, final int len) throws IOException {
         this.out.writeLine(Integer.toHexString(this.cachePosition + len));
         this.out.write(this.cache, 0, this.cachePosition);
         this.out.write(bufferToAppend, off, len);
@@ -148,7 +148,7 @@ public class ChunkedOutputStream extends
 
     // -------------------------------------------- OutputStream Methods
     @Override
-    public void write(int b) throws IOException {
+    public void write(final int b) throws IOException {
         if (this.closed) {
             throw new IOException("Attempted write to closed stream.");
         }
@@ -164,7 +164,7 @@ public class ChunkedOutputStream extends
      * not split, but rather written out as one large chunk.
      */
     @Override
-    public void write(byte b[]) throws IOException {
+    public void write(final byte b[]) throws IOException {
         write(b, 0, b.length);
     }
 
@@ -173,7 +173,7 @@ public class ChunkedOutputStream extends
      * not split, but rather written out as one large chunk.
      */
     @Override
-    public void write(byte src[], int off, int len) throws IOException {
+    public void write(final byte src[], final int off, final int len) throws IOException {
         if (this.closed) {
             throw new IOException("Attempted write to closed stream.");
         }