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 2017/03/26 02:43:05 UTC

svn commit: r1788709 [5/5] - in /httpcomponents: httpclient/trunk/httpclient5-cache/src/main/java/org/apache/hc/client5/http/impl/cache/ httpclient/trunk/httpclient5-fluent/src/main/java/org/apache/hc/client5/http/fluent/ httpclient/trunk/httpclient5-o...

Modified: httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/framework/TestTestingFrameworkRequestHandler.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/framework/TestTestingFrameworkRequestHandler.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/framework/TestTestingFrameworkRequestHandler.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/framework/TestTestingFrameworkRequestHandler.java Sun Mar 26 02:43:03 2017
@@ -1,79 +1,79 @@
-/*
- * ====================================================================
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- * ====================================================================
- *
- * This software consists of voluntary contributions made by many
- * individuals on behalf of the Apache Software Foundation.  For more
- * information on the Apache Software Foundation, please see
- * <http://www.apache.org/>.
- *
- */
-
-package org.apache.hc.core5.testing.framework;
-
-import java.io.IOException;
-
-import org.apache.hc.core5.http.ClassicHttpRequest;
-import org.apache.hc.core5.http.ClassicHttpResponse;
-import org.apache.hc.core5.http.HttpException;
-import org.apache.hc.core5.http.protocol.HttpContext;
-import org.junit.Assert;
-import org.junit.Test;
-
-public class TestTestingFrameworkRequestHandler {
-    @Test
-    public void assertNothingThrown() throws Exception {
-        final TestingFrameworkRequestHandler handler = new TestingFrameworkRequestHandler() {
-
-            @Override
-            public void handle(final ClassicHttpRequest request, final ClassicHttpResponse response, final HttpContext context)
-                throws HttpException, IOException {
-            }
-        };
-
-        handler.assertNothingThrown();
-    }
-
-    @Test
-    public void assertNothingThrownThrows() throws Exception {
-        final String errorMessage = "thrown intentionally";
-
-        final TestingFrameworkRequestHandler handler = new TestingFrameworkRequestHandler() {
-
-            @Override
-            public void handle(final ClassicHttpRequest request, final ClassicHttpResponse response, final HttpContext context)
-                    throws HttpException, IOException {
-                thrown = new TestingFrameworkException(errorMessage);
-            }
-        };
-
-        handler.handle(null, null, null);
-        try {
-            handler.assertNothingThrown();
-            Assert.fail("WebServerTestingFrameworkException should have been thrown");
-        } catch (TestingFrameworkException e) {
-            // expected
-            Assert.assertEquals("Unexpected message", errorMessage, e.getMessage());
-        }
-
-        // a second call should not throw
-        handler.assertNothingThrown();
-    }
-
-}
+/*
+ * ====================================================================
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ * ====================================================================
+ *
+ * This software consists of voluntary contributions made by many
+ * individuals on behalf of the Apache Software Foundation.  For more
+ * information on the Apache Software Foundation, please see
+ * <http://www.apache.org/>.
+ *
+ */
+
+package org.apache.hc.core5.testing.framework;
+
+import java.io.IOException;
+
+import org.apache.hc.core5.http.ClassicHttpRequest;
+import org.apache.hc.core5.http.ClassicHttpResponse;
+import org.apache.hc.core5.http.HttpException;
+import org.apache.hc.core5.http.protocol.HttpContext;
+import org.junit.Assert;
+import org.junit.Test;
+
+public class TestTestingFrameworkRequestHandler {
+    @Test
+    public void assertNothingThrown() throws Exception {
+        final TestingFrameworkRequestHandler handler = new TestingFrameworkRequestHandler() {
+
+            @Override
+            public void handle(final ClassicHttpRequest request, final ClassicHttpResponse response, final HttpContext context)
+                throws HttpException, IOException {
+            }
+        };
+
+        handler.assertNothingThrown();
+    }
+
+    @Test
+    public void assertNothingThrownThrows() throws Exception {
+        final String errorMessage = "thrown intentionally";
+
+        final TestingFrameworkRequestHandler handler = new TestingFrameworkRequestHandler() {
+
+            @Override
+            public void handle(final ClassicHttpRequest request, final ClassicHttpResponse response, final HttpContext context)
+                    throws HttpException, IOException {
+                thrown = new TestingFrameworkException(errorMessage);
+            }
+        };
+
+        handler.handle(null, null, null);
+        try {
+            handler.assertNothingThrown();
+            Assert.fail("WebServerTestingFrameworkException should have been thrown");
+        } catch (final TestingFrameworkException e) {
+            // expected
+            Assert.assertEquals("Unexpected message", errorMessage, e.getMessage());
+        }
+
+        // a second call should not throw
+        handler.assertNothingThrown();
+    }
+
+}

Modified: httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http/Http1IntegrationTest.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http/Http1IntegrationTest.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http/Http1IntegrationTest.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http/Http1IntegrationTest.java Sun Mar 26 02:43:03 2017
@@ -169,7 +169,7 @@ public class Http1IntegrationTest extend
     private URI createRequestURI(final InetSocketAddress serverEndpoint, final String path) {
         try {
             return new URI("http", null, "localhost", serverEndpoint.getPort(), path, null, null);
-        } catch (URISyntaxException e) {
+        } catch (final URISyntaxException e) {
             throw new IllegalStateException();
         }
     }
@@ -805,7 +805,7 @@ public class Http1IntegrationTest extend
                                         final HttpResponse response = new BasicHttpResponse(200);
                                         responseChannel.sendResponse(response, entityProducer);
                                     }
-                                } catch (Exception ignore) {
+                                } catch (final Exception ignore) {
                                 }
                             }
                         });
@@ -998,7 +998,7 @@ public class Http1IntegrationTest extend
                                 buffer.append(charset.decode(ByteBuffer.wrap(tmp, 0, l)));
                                 Thread.sleep(50);
                             }
-                        } catch (InterruptedException ex) {
+                        } catch (final InterruptedException ex) {
                             Thread.currentThread().interrupt();
                             throw new InterruptedIOException(ex.getMessage());
                         }
@@ -1055,7 +1055,7 @@ public class Http1IntegrationTest extend
                                 }
                                 writer.write("0123456789abcdef\r\n");
                             }
-                        } catch (InterruptedException ex) {
+                        } catch (final InterruptedException ex) {
                             Thread.currentThread().interrupt();
                             throw new InterruptedIOException(ex.getMessage());
                         }
@@ -1125,7 +1125,7 @@ public class Http1IntegrationTest extend
                                     }
                                 }
                                 writer.flush();
-                            } catch (InterruptedException ex) {
+                            } catch (final InterruptedException ex) {
                                 Thread.currentThread().interrupt();
                                 throw new InterruptedIOException(ex.getMessage());
                             }
@@ -1212,7 +1212,7 @@ public class Http1IntegrationTest extend
             final Message<HttpResponse, String> result3 = future3.get(TIMEOUT, TimeUnit.SECONDS);
             Assert.assertNull(result3);
             Assert.assertTrue(future3.isCancelled());
-        } catch (ExecutionException ignore) {
+        } catch (final ExecutionException ignore) {
         }
 
         final Future<Message<HttpResponse, String>> future4 = streamEndpoint.execute(
@@ -1276,7 +1276,7 @@ public class Http1IntegrationTest extend
             final Message<HttpResponse, String> result3 = future3.get(TIMEOUT, TimeUnit.SECONDS);
             Assert.assertNull(result3);
             Assert.assertTrue(future3.isCancelled());
-        } catch (ExecutionException ignore) {
+        } catch (final ExecutionException ignore) {
         }
     }
 
@@ -1602,7 +1602,7 @@ public class Http1IntegrationTest extend
         Assert.assertNotNull(trailers);
         Assert.assertEquals(2, trailers.size());
         final Map<String, String> map = new HashMap<>();
-        for (Header header: trailers) {
+        for (final Header header: trailers) {
             map.put(header.getName().toLowerCase(Locale.ROOT), header.getValue());
         }
         final String digest = TextUtils.toHexString(entityConsumer.getDigest());

Modified: httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http/InternalServerTestBase.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http/InternalServerTestBase.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http/InternalServerTestBase.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http/InternalServerTestBase.java Sun Mar 26 02:43:03 2017
@@ -68,7 +68,7 @@ public abstract class InternalServerTest
                 try {
                     server.shutdown(3, TimeUnit.SECONDS);
                     server = null;
-                } catch (Exception ignore) {
+                } catch (final Exception ignore) {
                 }
             }
         }

Modified: httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http2/Http2IntegrationTest.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http2/Http2IntegrationTest.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http2/Http2IntegrationTest.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http2/Http2IntegrationTest.java Sun Mar 26 02:43:03 2017
@@ -153,7 +153,7 @@ public class Http2IntegrationTest extend
     private URI createRequestURI(final InetSocketAddress serverEndpoint, final String path) {
         try {
             return new URI("http", null, "localhost", serverEndpoint.getPort(), path, null, null);
-        } catch (URISyntaxException e) {
+        } catch (final URISyntaxException e) {
             throw new IllegalStateException();
         }
     }
@@ -352,7 +352,7 @@ public class Http2IntegrationTest extend
                                 buffer.append(charset.decode(ByteBuffer.wrap(tmp, 0, l)));
                                 Thread.sleep(500);
                             }
-                        } catch (InterruptedException ex) {
+                        } catch (final InterruptedException ex) {
                             Thread.currentThread().interrupt();
                             throw new InterruptedIOException(ex.getMessage());
                         }
@@ -409,7 +409,7 @@ public class Http2IntegrationTest extend
                                 }
                                 writer.write("0123456789abcdef\r\n");
                             }
-                        } catch (InterruptedException ex) {
+                        } catch (final InterruptedException ex) {
                             Thread.currentThread().interrupt();
                             throw new InterruptedIOException(ex.getMessage());
                         }
@@ -479,7 +479,7 @@ public class Http2IntegrationTest extend
                                     }
                                 }
                                 writer.flush();
-                            } catch (InterruptedException ex) {
+                            } catch (final InterruptedException ex) {
                                 Thread.currentThread().interrupt();
                                 throw new InterruptedIOException(ex.getMessage());
                             }
@@ -557,7 +557,7 @@ public class Http2IntegrationTest extend
                             final Message<HttpResponse, String> responseMessage) throws IOException, HttpException {
                         try {
                             pushMessageQueue.put(responseMessage);
-                        } catch (InterruptedException ex) {
+                        } catch (final InterruptedException ex) {
                             Thread.currentThread().interrupt();
                             throw new InterruptedIOException(ex.getMessage());
                         }
@@ -904,7 +904,7 @@ public class Http2IntegrationTest extend
         Assert.assertNotNull(trailers);
         Assert.assertEquals(2, trailers.size());
         final Map<String, String> map = new HashMap<>();
-        for (Header header: trailers) {
+        for (final Header header: trailers) {
             map.put(header.getName().toLowerCase(Locale.ROOT), header.getValue());
         }
         final String digest = TextUtils.toHexString(entityConsumer.getDigest());

Modified: httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http2/InternalServerTestBase.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http2/InternalServerTestBase.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http2/InternalServerTestBase.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5-testing/src/test/java/org/apache/hc/core5/testing/nio/http2/InternalServerTestBase.java Sun Mar 26 02:43:03 2017
@@ -67,7 +67,7 @@ public abstract class InternalServerTest
                 try {
                     server.shutdown(3, TimeUnit.SECONDS);
                     server = null;
-                } catch (Exception ignore) {
+                } catch (final Exception ignore) {
                 }
             }
         }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/ContentType.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/ContentType.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/ContentType.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/ContentType.java Sun Mar 26 02:43:03 2017
@@ -105,7 +105,7 @@ public final class ContentType implement
             TEXT_PLAIN,
             TEXT_XML };
         final HashMap<String, ContentType> map = new HashMap<String, ContentType>();
-        for (ContentType contentType: contentTypes) {
+        for (final ContentType contentType: contentTypes) {
             map.put(contentType.getMimeType(), contentType);
         }
         CONTENT_TYPE_MAP = Collections.unmodifiableMap(map);

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/AsyncRequesterBootstrap.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/AsyncRequesterBootstrap.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/AsyncRequesterBootstrap.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/AsyncRequesterBootstrap.java Sun Mar 26 02:43:03 2017
@@ -197,7 +197,7 @@ public class AsyncRequesterBootstrap {
                     connPool,
                     tlsStrategy != null ? tlsStrategy : new BasicClientTlsStrategy(),
                     exceptionListener);
-        } catch (IOReactorException ex) {
+        } catch (final IOReactorException ex) {
             throw new IllegalStateException(ex);
         }
     }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/AsyncServerBootstrap.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/AsyncServerBootstrap.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/AsyncServerBootstrap.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/AsyncServerBootstrap.java Sun Mar 26 02:43:03 2017
@@ -202,7 +202,7 @@ public class AsyncServerBootstrap {
     public HttpAsyncServer create() {
         final AsyncServerExchangeHandlerRegistry exchangeHandlerFactory = new AsyncServerExchangeHandlerRegistry(
                 canonicalHostName != null ? canonicalHostName : InetAddressUtils.getCanonicalLocalHostName());
-        for (HandlerEntry entry: handlerList) {
+        for (final HandlerEntry entry: handlerList) {
             exchangeHandlerFactory.register(entry.hostname, entry.uriPattern, entry.supplier);
         }
         final ServerHttp1IOEventHandlerFactory ioEventHandlerFactory = new ServerHttp1IOEventHandlerFactory(
@@ -222,7 +222,7 @@ public class AsyncServerBootstrap {
                     ioEventHandlerFactory,
                     ioReactorConfig,
                     exceptionListener);
-        } catch (IOReactorException ex) {
+        } catch (final IOReactorException ex) {
             throw new IllegalStateException(ex);
         }
     }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/HttpRequester.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/HttpRequester.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/HttpRequester.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/HttpRequester.java Sun Mar 26 02:43:03 2017
@@ -179,11 +179,11 @@ public class HttpRequester implements Au
         final PoolEntry<HttpHost, HttpClientConnection> poolEntry;
         try {
             poolEntry = leaseFuture.get(socketConfig.getConnectTimeout(), TimeUnit.MILLISECONDS);
-        } catch (InterruptedException ex) {
+        } catch (final InterruptedException ex) {
             throw new InterruptedIOException(ex.getMessage());
-        } catch (ExecutionException ex) {
+        } catch (final ExecutionException ex) {
             throw new HttpException("Unexpected failure leasing connection", ex);
-        } catch (TimeoutException ex) {
+        } catch (final TimeoutException ex) {
             throw new ConnectionRequestTimeoutException("Connection request timeout");
         }
         final PoolEntryHolder<HttpHost, HttpClientConnection> connectionHolder = new PoolEntryHolder<>(
@@ -195,7 +195,7 @@ public class HttpRequester implements Au
                     public void execute(final HttpClientConnection conn) {
                         try {
                             conn.shutdown();
-                        } catch (IOException ignore) {
+                        } catch (final IOException ignore) {
                         }
                     }
                 });

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/HttpServer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/HttpServer.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/HttpServer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/HttpServer.java Sun Mar 26 02:43:03 2017
@@ -165,11 +165,11 @@ public class HttpServer implements AutoC
             }
         }
         final Set<Worker> workers = this.workerExecutorService.getWorkers();
-        for (Worker worker: workers) {
+        for (final Worker worker: workers) {
             final HttpServerConnection conn = worker.getConnection();
             try {
                 conn.shutdown();
-            } catch (IOException ex) {
+            } catch (final IOException ex) {
                 this.exceptionListener.onError(ex);
             }
         }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/IOReactorExecutor.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/IOReactorExecutor.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/IOReactorExecutor.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/bootstrap/IOReactorExecutor.java Sun Mar 26 02:43:03 2017
@@ -67,7 +67,7 @@ abstract class IOReactorExecutor<T exten
                 public void run() {
                     try {
                         ioReactor.execute();
-                    } catch (Exception ex) {
+                    } catch (final Exception ex) {
                         if (exceptionListener != null) {
                             exceptionListener.onError(ex);
                         }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/AbstractClassicServerExchangeHandler.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/AbstractClassicServerExchangeHandler.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/AbstractClassicServerExchangeHandler.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/AbstractClassicServerExchangeHandler.java Sun Mar 26 02:43:03 2017
@@ -201,7 +201,7 @@ public abstract class AbstractClassicSer
 
                         });
                     }
-                } catch (HttpException ex) {
+                } catch (final HttpException ex) {
                     throw new IOException(ex.getMessage(), ex);
                 }
             }
@@ -243,7 +243,7 @@ public abstract class AbstractClassicSer
                             inputStream.close();
                         }
                         outputStream.close();
-                    } catch (Exception ex) {
+                    } catch (final Exception ex) {
                         exception.compareAndSet(null, ex);
                         if (inputBuffer != null) {
                             inputBuffer.abort();

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/ServerHttp1StreamHandler.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/ServerHttp1StreamHandler.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/ServerHttp1StreamHandler.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/ServerHttp1StreamHandler.java Sun Mar 26 02:43:03 2017
@@ -232,9 +232,9 @@ class ServerHttp1StreamHandler implement
         AsyncServerExchangeHandler handler;
         try {
             handler = exchangeHandlerFactory.create(request);
-        } catch (MisdirectedRequestException ex) {
+        } catch (final MisdirectedRequestException ex) {
             handler =  new ImmediateResponseExchangeHandler(HttpStatus.SC_MISDIRECTED_REQUEST, ex.getMessage());
-        } catch (HttpException ex) {
+        } catch (final HttpException ex) {
             handler =  new ImmediateResponseExchangeHandler(HttpStatus.SC_INTERNAL_SERVER_ERROR, ex.getMessage());
         }
         if (handler == null) {
@@ -257,7 +257,7 @@ class ServerHttp1StreamHandler implement
         final EntityDetails requestEntityDetails = requestEndStream ? null : new LazyEntityDetails(request);
         try {
             httpProcessor.process(request, requestEntityDetails, context);
-        } catch (HttpException ex) {
+        } catch (final HttpException ex) {
             final AsyncResponseProducer responseProducer = handleException(ex);
             exchangeHandler = new ImmediateResponseExchangeHandler(responseProducer);
         }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/AbstractClassicEntityConsumer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/AbstractClassicEntityConsumer.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/AbstractClassicEntityConsumer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/AbstractClassicEntityConsumer.java Sun Mar 26 02:43:03 2017
@@ -78,7 +78,7 @@ public abstract class AbstractClassicEnt
         final ContentType contentType;
         try {
             contentType = ContentType.parse(entityDetails.getContentType());
-        } catch (UnsupportedCharsetException ex) {
+        } catch (final UnsupportedCharsetException ex) {
             throw new UnsupportedEncodingException(ex.getMessage());
         }
         if (state.compareAndSet(State.IDLE, State.ACTIVE)) {
@@ -90,7 +90,7 @@ public abstract class AbstractClassicEnt
                         final T result = consumeData(contentType, new ContentInputStream(buffer));
                         resultRef.set(result);
                         resultCallback.completed(result);
-                    } catch (Exception ex) {
+                    } catch (final Exception ex) {
                         buffer.abort();
                         resultCallback.failed(ex);
                     } finally {

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/AbstractClassicEntityProducer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/AbstractClassicEntityProducer.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/AbstractClassicEntityProducer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/AbstractClassicEntityProducer.java Sun Mar 26 02:43:03 2017
@@ -76,7 +76,7 @@ public abstract class AbstractClassicEnt
                     try {
                         produceData(contentType, new ContentOutputStream(buffer));
                         buffer.writeCompleted();
-                    } catch (Exception ex) {
+                    } catch (final Exception ex) {
                         buffer.abort();
                     } finally {
                         state.set(State.COMPLETED);

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/SharedInputBuffer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/SharedInputBuffer.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/SharedInputBuffer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/SharedInputBuffer.java Sun Mar 26 02:43:03 2017
@@ -85,7 +85,7 @@ public final class SharedInputBuffer ext
             while (buffer().position() == 0 && !endStream && !aborted) {
                 try {
                     condition.await();
-                } catch (InterruptedException ex) {
+                } catch (final InterruptedException ex) {
                     Thread.currentThread().interrupt();
                     throw new InterruptedIOException(ex.getMessage());
                 }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/SharedOutputBuffer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/SharedOutputBuffer.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/SharedOutputBuffer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/impl/nio/entity/SharedOutputBuffer.java Sun Mar 26 02:43:03 2017
@@ -154,7 +154,7 @@ public final class SharedOutputBuffer ex
         while (buffer().hasRemaining() || !hasCapacity) {
             try {
                 condition.await();
-            } catch (InterruptedException ex) {
+            } catch (final InterruptedException ex) {
                 Thread.currentThread().interrupt();
                 throw new InterruptedIOException(ex.getMessage());
             }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/AbstractBinAsyncEntityConsumer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/AbstractBinAsyncEntityConsumer.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/AbstractBinAsyncEntityConsumer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/AbstractBinAsyncEntityConsumer.java Sun Mar 26 02:43:03 2017
@@ -52,7 +52,7 @@ public abstract class AbstractBinAsyncEn
             if (entityDetails == null) {
                 completed();
             }
-        } catch (UnsupportedCharsetException ex) {
+        } catch (final UnsupportedCharsetException ex) {
             throw new UnsupportedEncodingException(ex.getMessage());
         }
     }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/AbstractCharAsyncEntityConsumer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/AbstractCharAsyncEntityConsumer.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/AbstractCharAsyncEntityConsumer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/AbstractCharAsyncEntityConsumer.java Sun Mar 26 02:43:03 2017
@@ -62,7 +62,7 @@ public abstract class AbstractCharAsyncE
             if (entityDetails == null) {
                 completed();
             }
-        } catch (UnsupportedCharsetException ex) {
+        } catch (final UnsupportedCharsetException ex) {
             throw new UnsupportedEncodingException(ex.getMessage());
         }
     }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/DigestingEntityProducer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/DigestingEntityProducer.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/DigestingEntityProducer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/DigestingEntityProducer.java Sun Mar 26 02:43:03 2017
@@ -58,7 +58,7 @@ public class DigestingEntityProducer imp
         this.wrapped = Args.notNull(wrapped, "Entity consumer");
         try {
             this.digester = MessageDigest.getInstance(algo);
-        } catch (NoSuchAlgorithmException ex) {
+        } catch (final NoSuchAlgorithmException ex) {
             throw new IllegalArgumentException("Unsupported digest algorithm: " + algo);
         }
     }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/FileEntityProducer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/FileEntityProducer.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/FileEntityProducer.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/entity/FileEntityProducer.java Sun Mar 26 02:43:03 2017
@@ -136,7 +136,7 @@ public class FileEntityProducer implemen
         if (accessFile != null) {
             try {
                 accessFile.close();
-            } catch (IOException ignore) {
+            } catch (final IOException ignore) {
             }
             accessFile = null;
         }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/ssl/BasicServerTlsStrategy.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/ssl/BasicServerTlsStrategy.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/ssl/BasicServerTlsStrategy.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/ssl/BasicServerTlsStrategy.java Sun Mar 26 02:43:03 2017
@@ -98,7 +98,7 @@ public class BasicServerTlsStrategy impl
             final SocketAddress remoteAddress,
             final String... parameters) {
         final int port = ((InetSocketAddress) localAddress).getPort();
-        for (int securePort: securePorts) {
+        for (final int securePort: securePorts) {
             if (port == securePort) {
                 tlsSession.start(sslContext, sslBufferManagement, initializer, verifier);
                 break;

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/support/AbstractServerExchangeHandler.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/support/AbstractServerExchangeHandler.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/support/AbstractServerExchangeHandler.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/support/AbstractServerExchangeHandler.java Sun Mar 26 02:43:03 2017
@@ -141,14 +141,14 @@ public abstract class AbstractServerExch
             public void completed(final T result) {
                 try {
                     handle(result, responseTrigger, context);
-                } catch (HttpException ex) {
+                } catch (final HttpException ex) {
                     try {
                         responseTrigger.submitResponse(
                                 new BasicResponseProducer(HttpStatus.SC_INTERNAL_SERVER_ERROR, ex.getMessage()));
                     } catch (HttpException | IOException ex2) {
                         failed(ex2);
                     }
-                } catch (IOException ex) {
+                } catch (final IOException ex) {
                     failed(ex);
                 }
             }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/support/BasicAsyncPushHandler.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/support/BasicAsyncPushHandler.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/support/BasicAsyncPushHandler.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/nio/support/BasicAsyncPushHandler.java Sun Mar 26 02:43:03 2017
@@ -71,7 +71,7 @@ public class BasicAsyncPushHandler<T> im
             public void completed(final Message<HttpResponse, T> result) {
                 try {
                     handleResponse(promise, result);
-                } catch (Exception ex) {
+                } catch (final Exception ex) {
                     failed(ex);
                 }
             }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/protocol/RequestValidateHost.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/protocol/RequestValidateHost.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/protocol/RequestValidateHost.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/http/protocol/RequestValidateHost.java Sun Mar 26 02:43:03 2017
@@ -68,7 +68,7 @@ public class RequestValidateHost impleme
             final URIAuthority authority;
             try {
                 authority = URIAuthority.create(header.getValue());
-            } catch (URISyntaxException ex) {
+            } catch (final URISyntaxException ex) {
                 throw new ProtocolException(ex.getMessage(), ex);
             }
             request.setAuthority(authority);

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/net/InetAddressUtils.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/net/InetAddressUtils.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/net/InetAddressUtils.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/net/InetAddressUtils.java Sun Mar 26 02:43:03 2017
@@ -155,7 +155,7 @@ public class InetAddressUtils {
         try {
             final InetAddress localHost = InetAddress.getLocalHost();
             return localHost.getCanonicalHostName();
-        } catch (UnknownHostException ex) {
+        } catch (final UnknownHostException ex) {
             return "localhost";
         }
     }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/pool/PoolEntry.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/pool/PoolEntry.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/pool/PoolEntry.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/pool/PoolEntry.java Sun Mar 26 02:43:03 2017
@@ -146,7 +146,7 @@ public final class PoolEntry<T, C extend
             } else {
                 try {
                     connection.close();
-                } catch (IOException ignore) {
+                } catch (final IOException ignore) {
                 }
             }
             this.state = null;

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/pool/StrictConnPool.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/pool/StrictConnPool.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/pool/StrictConnPool.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/pool/StrictConnPool.java Sun Mar 26 02:43:03 2017
@@ -486,7 +486,7 @@ public class StrictConnPool<T, C extends
         try {
             final RoutePool<T, C> pool = getPool(route);
             int pendingCount = 0;
-            for (LeaseRequest<T, C> request: leasingRequests) {
+            for (final LeaseRequest<T, C> request: leasingRequests) {
                 if (LangUtils.equals(route, request.getRoute())) {
                     pendingCount++;
                 }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/AbstractMultiworkerIOReactor.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/AbstractMultiworkerIOReactor.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/AbstractMultiworkerIOReactor.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/AbstractMultiworkerIOReactor.java Sun Mar 26 02:43:03 2017
@@ -467,7 +467,7 @@ public abstract class AbstractMultiworke
         try {
             awaitShutdown(graceTime, timeUnit);
             forceShutdown();
-        } catch (InterruptedException e) {
+        } catch (final InterruptedException e) {
             Thread.currentThread().interrupt();
         }
     }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/IOReactorImpl.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/IOReactorImpl.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/IOReactorImpl.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/IOReactorImpl.java Sun Mar 26 02:43:03 2017
@@ -389,7 +389,7 @@ class IOReactorImpl implements IOReactor
         try {
             awaitShutdown(graceTime, timeUnit);
             forceShutdown();
-        } catch (InterruptedException e) {
+        } catch (final InterruptedException e) {
             Thread.currentThread().interrupt();
         }
     }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/ManagedIOSession.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/ManagedIOSession.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/ManagedIOSession.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/ManagedIOSession.java Sun Mar 26 02:43:03 2017
@@ -112,13 +112,13 @@ class ManagedIOSession implements IOSess
                         tlsSession.initialize();
                     }
                     handler.connected(this);
-                } catch (Exception ex) {
+                } catch (final Exception ex) {
                     handler.exception(tlsSession, ex);
                 }
             } else {
                 handler.connected(this);
             }
-        } catch (RuntimeException ex) {
+        } catch (final RuntimeException ex) {
             shutdown();
             throw ex;
         }
@@ -146,7 +146,7 @@ class ManagedIOSession implements IOSess
             } else {
                 handler.inputReady(this);
             }
-        } catch (RuntimeException ex) {
+        } catch (final RuntimeException ex) {
             shutdown();
             throw ex;
         }
@@ -172,7 +172,7 @@ class ManagedIOSession implements IOSess
             } else {
                 handler.outputReady(this);
             }
-        } catch (RuntimeException ex) {
+        } catch (final RuntimeException ex) {
             shutdown();
             throw ex;
         }
@@ -189,7 +189,7 @@ class ManagedIOSession implements IOSess
                     tlsSession.shutdown();
                 }
             }
-        } catch (RuntimeException ex) {
+        } catch (final RuntimeException ex) {
             shutdown();
             throw ex;
         }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/ssl/SSLIOSession.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/ssl/SSLIOSession.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/ssl/SSLIOSession.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/main/java/org/apache/hc/core5/reactor/ssl/SSLIOSession.java Sun Mar 26 02:43:03 2017
@@ -629,7 +629,7 @@ public class SSLIOSession implements IOS
         }
         try {
             updateEventMask();
-        } catch (CancelledKeyException ex) {
+        } catch (final CancelledKeyException ex) {
             shutdown();
         }
     }

Modified: httpcomponents/httpcore/trunk/httpcore5/src/test/java/org/apache/hc/core5/http/impl/io/TestIdentityInputStream.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/test/java/org/apache/hc/core5/http/impl/io/TestIdentityInputStream.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/test/java/org/apache/hc/core5/http/impl/io/TestIdentityInputStream.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/test/java/org/apache/hc/core5/http/impl/io/TestIdentityInputStream.java Sun Mar 26 02:43:03 2017
@@ -73,12 +73,12 @@ public class TestIdentityInputStream {
         try {
             in.read(tmp, 0, tmp.length);
             Assert.fail("StreamClosedException expected");
-        } catch (StreamClosedException expected) {
+        } catch (final StreamClosedException expected) {
         }
         try {
             in.read();
             Assert.fail("StreamClosedException expected");
-        } catch (StreamClosedException expected) {
+        } catch (final StreamClosedException expected) {
         }
     }
 

Modified: httpcomponents/httpcore/trunk/httpcore5/src/test/java/org/apache/hc/core5/http/message/TestMessageSupport.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/trunk/httpcore5/src/test/java/org/apache/hc/core5/http/message/TestMessageSupport.java?rev=1788709&r1=1788708&r2=1788709&view=diff
==============================================================================
--- httpcomponents/httpcore/trunk/httpcore5/src/test/java/org/apache/hc/core5/http/message/TestMessageSupport.java (original)
+++ httpcomponents/httpcore/trunk/httpcore5/src/test/java/org/apache/hc/core5/http/message/TestMessageSupport.java Sun Mar 26 02:43:03 2017
@@ -47,7 +47,7 @@ public class TestMessageSupport {
             return null;
         }
         final Set<String> set = new LinkedHashSet<>();
-        for (String token: tokens) {
+        for (final String token: tokens) {
             set.add(token);
         }
         return set;