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 2018/08/14 16:57:57 UTC

svn commit: r1838035 [2/2] - in /httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src: examples/org/apache/http/examples/nio/client/ main/java-deprecated/org/apache/http/impl/nio/client/ main/java-deprecated/org/apache/http/impl/nio/conn/ ...

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/AsyncByteConsumer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/AsyncByteConsumer.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/AsyncByteConsumer.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/AsyncByteConsumer.java Tue Aug 14 16:57:56 2018
@@ -62,11 +62,11 @@ public abstract class AsyncByteConsumer<
      * if the consumer is temporarily unable to consume more content.
      *
      * @param buf chunk of content.
-     * @param ioctrl I/O control of the underlying connection.
+     * @param ioControl I/O control of the underlying connection.
      * @throws IOException in case of an I/O error
      */
     protected abstract void onByteReceived(
-            ByteBuffer buf, IOControl ioctrl) throws IOException;
+            ByteBuffer buf, IOControl ioControl) throws IOException;
 
     @Override
     protected final void onEntityEnclosed(
@@ -75,14 +75,14 @@ public abstract class AsyncByteConsumer<
 
     @Override
     protected final void onContentReceived(
-            final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
+            final ContentDecoder decoder, final IOControl ioControl) throws IOException {
         Asserts.notNull(this.bbuf, "Byte buffer");
         final int bytesRead = decoder.read(this.bbuf);
         if (bytesRead <= 0) {
             return;
         }
         this.bbuf.flip();
-        onByteReceived(this.bbuf, ioctrl);
+        onByteReceived(this.bbuf, ioControl);
         this.bbuf.clear();
     }
 

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/AsyncCharConsumer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/AsyncCharConsumer.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/AsyncCharConsumer.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/AsyncCharConsumer.java Tue Aug 14 16:57:56 2018
@@ -53,7 +53,7 @@ public abstract class AsyncCharConsumer<
     private final ByteBuffer bbuf;
     private final CharBuffer cbuf;
 
-    private CharsetDecoder chardecoder;
+    private CharsetDecoder charDecoder;
 
     public AsyncCharConsumer(final int bufSize) {
         super();
@@ -71,11 +71,11 @@ public abstract class AsyncCharConsumer<
      * if the consumer is temporarily unable to consume more content.
      *
      * @param buf chunk of content.
-     * @param ioctrl I/O control of the underlying connection.
+     * @param ioControl I/O control of the underlying connection.
      * @throws IOException in case of an I/O error
      */
     protected abstract void onCharReceived(
-            CharBuffer buf, IOControl ioctrl) throws IOException;
+            CharBuffer buf, IOControl ioControl) throws IOException;
 
     /**
      * Invoked to create a @{link CharsetDecoder} for contentType.
@@ -98,12 +98,12 @@ public abstract class AsyncCharConsumer<
     @Override
     protected final void onEntityEnclosed(
             final HttpEntity entity, final ContentType contentType) throws IOException {
-        this.chardecoder = createDecoder(contentType != null ? contentType : ContentType.DEFAULT_TEXT);
+        this.charDecoder = createDecoder(contentType != null ? contentType : ContentType.DEFAULT_TEXT);
     }
 
     @Override
     protected final void onContentReceived(
-            final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
+            final ContentDecoder decoder, final IOControl ioControl) throws IOException {
         Asserts.notNull(this.bbuf, "Byte buffer");
 
         final int bytesRead = decoder.read(this.bbuf);
@@ -112,23 +112,23 @@ public abstract class AsyncCharConsumer<
         }
         this.bbuf.flip();
         final boolean completed = decoder.isCompleted();
-        CoderResult result = this.chardecoder.decode(this.bbuf, this.cbuf, completed);
-        handleDecodingResult(result, ioctrl);
+        CoderResult result = this.charDecoder.decode(this.bbuf, this.cbuf, completed);
+        handleDecodingResult(result, ioControl);
         this.bbuf.compact();
         if (completed) {
-            result = this.chardecoder.flush(this.cbuf);
-            handleDecodingResult(result, ioctrl);
+            result = this.charDecoder.flush(this.cbuf);
+            handleDecodingResult(result, ioControl);
         }
     }
 
     private void handleDecodingResult(
-            final CoderResult result, final IOControl ioctrl) throws IOException {
+            final CoderResult result, final IOControl ioControl) throws IOException {
         if (result.isError()) {
             result.throwException();
         }
         this.cbuf.flip();
         if (this.cbuf.hasRemaining()) {
-            onCharReceived(this.cbuf, ioctrl);
+            onCharReceived(this.cbuf, ioControl);
         }
         this.cbuf.clear();
     }

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/BaseZeroCopyRequestProducer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/BaseZeroCopyRequestProducer.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/BaseZeroCopyRequestProducer.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/BaseZeroCopyRequestProducer.java Tue Aug 14 16:57:56 2018
@@ -98,7 +98,7 @@ abstract class BaseZeroCopyRequestProduc
 
     @Override
     public synchronized void produceContent(
-            final ContentEncoder encoder, final IOControl ioctrl) throws IOException {
+            final ContentEncoder encoder, final IOControl ioControl) throws IOException {
         if (this.fileChannel == null) {
             this.fileChannel = this.accessfile.getChannel();
             this.idx = 0;

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/ZeroCopyConsumer.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/ZeroCopyConsumer.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/ZeroCopyConsumer.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/client/methods/ZeroCopyConsumer.java Tue Aug 14 16:57:56 2018
@@ -90,7 +90,7 @@ public abstract class ZeroCopyConsumer<T
 
     @Override
     protected void onContentReceived(
-            final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
+            final ContentDecoder decoder, final IOControl ioControl) throws IOException {
         Asserts.notNull(this.fileChannel, "File channel");
         final long transferred;
         if (decoder instanceof FileContentDecoder) {

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/ManagedNHttpClientConnection.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/ManagedNHttpClientConnection.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/ManagedNHttpClientConnection.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/ManagedNHttpClientConnection.java Tue Aug 14 16:57:56 2018
@@ -51,7 +51,7 @@ public interface ManagedNHttpClientConne
     /**
      * Binds connection to the given I/O session.
      */
-    void bind(IOSession iosession);
+    void bind(IOSession ioSession);
 
     /**
      * Returns the underlying I/O session.

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/NHttpClientConnectionManager.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/NHttpClientConnectionManager.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/NHttpClientConnectionManager.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/NHttpClientConnectionManager.java Tue Aug 14 16:57:56 2018
@@ -165,11 +165,11 @@ public interface NHttpClientConnectionMa
      * All expired connections will also be closed.
      *
      * @param idletime  the idle time of connections to be closed
-     * @param tunit     the unit for the {@code idletime}
+     * @param timeUnit     the unit for the {@code idletime}
      *
      * @see #closeExpiredConnections()
      */
-    void closeIdleConnections(long idletime, TimeUnit tunit);
+    void closeIdleConnections(long idletime, TimeUnit timeUnit);
 
     /**
      * Closes all expired connections in the pool.

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/NHttpConnectionFactory.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/NHttpConnectionFactory.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/NHttpConnectionFactory.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/NHttpConnectionFactory.java Tue Aug 14 16:57:56 2018
@@ -37,6 +37,6 @@ import org.apache.http.nio.reactor.IOSes
  */
 public interface NHttpConnectionFactory<T extends NHttpConnection> {
 
-    T create(IOSession iosession, ConnectionConfig config);
+    T create(IOSession ioSession, ConnectionConfig config);
 
 }

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/NoopIOSessionStrategy.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/NoopIOSessionStrategy.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/NoopIOSessionStrategy.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/NoopIOSessionStrategy.java Tue Aug 14 16:57:56 2018
@@ -40,8 +40,8 @@ public class NoopIOSessionStrategy imple
     public static final NoopIOSessionStrategy INSTANCE = new NoopIOSessionStrategy();
 
     @Override
-    public IOSession upgrade(final HttpHost host, final IOSession iosession) {
-        return iosession;
+    public IOSession upgrade(final HttpHost host, final IOSession ioSession) {
+        return ioSession;
     }
 
     @Override

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/SchemeIOSessionStrategy.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/SchemeIOSessionStrategy.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/SchemeIOSessionStrategy.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/SchemeIOSessionStrategy.java Tue Aug 14 16:57:56 2018
@@ -53,9 +53,9 @@ public interface SchemeIOSessionStrategy
      * Decorates the original {@link IOSession} with a transport level security
      * protocol implementation.
      * @param host the target host.
-     * @param iosession the I/O session.
+     * @param ioSession the I/O session.
      * @return upgraded I/O session.
      */
-    IOSession upgrade(HttpHost host, IOSession iosession) throws IOException;
+    IOSession upgrade(HttpHost host, IOSession ioSession) throws IOException;
 
 }

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/ssl/SSLIOSessionStrategy.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/ssl/SSLIOSessionStrategy.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/ssl/SSLIOSessionStrategy.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/main/java/org/apache/http/nio/conn/ssl/SSLIOSessionStrategy.java Tue Aug 14 16:57:56 2018
@@ -160,10 +160,10 @@ public class SSLIOSessionStrategy implem
     }
 
     @Override
-    public SSLIOSession upgrade(final HttpHost host, final IOSession iosession) throws IOException {
-        Asserts.check(!(iosession instanceof SSLIOSession), "I/O session is already upgraded to TLS/SSL");
-        final SSLIOSession ssliosession = new SSLIOSession(
-            iosession,
+    public SSLIOSession upgrade(final HttpHost host, final IOSession ioSession) throws IOException {
+        Asserts.check(!(ioSession instanceof SSLIOSession), "I/O session is already upgraded to TLS/SSL");
+        final SSLIOSession sslioSession = new SSLIOSession(
+            ioSession,
             SSLMode.CLIENT,
             host,
             this.sslContext,
@@ -183,15 +183,15 @@ public class SSLIOSessionStrategy implem
 
                 @Override
                 public void verify(
-                        final IOSession iosession,
+                        final IOSession ioSession,
                         final SSLSession sslsession) throws SSLException {
-                    verifySession(host, iosession, sslsession);
+                    verifySession(host, ioSession, sslsession);
                 }
 
         });
-        iosession.setAttribute(SSLIOSession.SESSION_KEY, ssliosession);
-        ssliosession.initialize();
-        return ssliosession;
+        ioSession.setAttribute(SSLIOSession.SESSION_KEY, sslioSession);
+        sslioSession.initialize();
+        return sslioSession;
     }
 
     protected void initializeEngine(final SSLEngine engine) {
@@ -199,7 +199,7 @@ public class SSLIOSessionStrategy implem
 
     protected void verifySession(
             final HttpHost host,
-            final IOSession iosession,
+            final IOSession ioSession,
             final SSLSession sslsession) throws SSLException {
         if (!this.hostnameVerifier.verify(host.getHostName(), sslsession)) {
             final Certificate[] certs = sslsession.getPeerCertificates();

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/impl/nio/conn/TestPoolingHttpClientAsyncConnectionManager.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/impl/nio/conn/TestPoolingHttpClientAsyncConnectionManager.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/impl/nio/conn/TestPoolingHttpClientAsyncConnectionManager.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/impl/nio/conn/TestPoolingHttpClientAsyncConnectionManager.java Tue Aug 14 16:57:56 2018
@@ -69,7 +69,7 @@ import org.mockito.MockitoAnnotations;
 public class TestPoolingHttpClientAsyncConnectionManager {
 
     @Mock
-    private ConnectingIOReactor ioreactor;
+    private ConnectingIOReactor ioReactor;
     @Mock
     private CPool pool;
     @Mock
@@ -91,7 +91,7 @@ public class TestPoolingHttpClientAsyncC
     @Mock
     private SessionRequest sessionRequest;
     @Mock
-    private IOSession iosession;
+    private IOSession ioSession;
 
     private Registry<SchemeIOSessionStrategy> layeringStrategyRegistry;
     private PoolingNHttpClientConnectionManager connman;
@@ -106,7 +106,7 @@ public class TestPoolingHttpClientAsyncC
             .register("https", sslStrategy)
             .build();
         connman = new PoolingNHttpClientConnectionManager(
-            ioreactor, pool, layeringStrategyRegistry);
+            ioReactor, pool, layeringStrategyRegistry);
     }
 
     @Test
@@ -269,13 +269,13 @@ public class TestPoolingHttpClientAsyncC
         final CPoolEntry poolentry = new CPoolEntry(log, "some-id", route, conn, -1, TimeUnit.MILLISECONDS);
         final NHttpClientConnection managedConn = CPoolProxy.newProxy(poolentry);
 
-        Mockito.when(conn.getIOSession()).thenReturn(iosession);
-        Mockito.when(sslStrategy.upgrade(target, iosession)).thenReturn(iosession);
+        Mockito.when(conn.getIOSession()).thenReturn(ioSession);
+        Mockito.when(sslStrategy.upgrade(target, ioSession)).thenReturn(ioSession);
 
         connman.startRoute(managedConn, route, context);
 
-        Mockito.verify(noopStrategy, Mockito.never()).upgrade(target, iosession);
-        Mockito.verify(conn, Mockito.never()).bind(iosession);
+        Mockito.verify(noopStrategy, Mockito.never()).upgrade(target, ioSession);
+        Mockito.verify(conn, Mockito.never()).bind(ioSession);
 
         Assert.assertFalse(connman.isRouteComplete(managedConn));
     }
@@ -291,13 +291,13 @@ public class TestPoolingHttpClientAsyncC
         poolentry.markRouteComplete();
         final NHttpClientConnection managedConn = CPoolProxy.newProxy(poolentry);
 
-        Mockito.when(conn.getIOSession()).thenReturn(iosession);
-        Mockito.when(sslStrategy.upgrade(target, iosession)).thenReturn(iosession);
+        Mockito.when(conn.getIOSession()).thenReturn(ioSession);
+        Mockito.when(sslStrategy.upgrade(target, ioSession)).thenReturn(ioSession);
 
         connman.startRoute(managedConn, route, context);
 
-        Mockito.verify(sslStrategy).upgrade(target, iosession);
-        Mockito.verify(conn).bind(iosession);
+        Mockito.verify(sslStrategy).upgrade(target, ioSession);
+        Mockito.verify(conn).bind(ioSession);
     }
 
     @Test
@@ -315,13 +315,13 @@ public class TestPoolingHttpClientAsyncC
         final CPoolEntry poolentry = new CPoolEntry(log, "some-id", route, conn, -1, TimeUnit.MILLISECONDS);
         final NHttpClientConnection managedConn = CPoolProxy.newProxy(poolentry);
 
-        Mockito.when(conn.getIOSession()).thenReturn(iosession);
-        Mockito.when(sslStrategy.upgrade(target, iosession)).thenReturn(iosession);
+        Mockito.when(conn.getIOSession()).thenReturn(ioSession);
+        Mockito.when(sslStrategy.upgrade(target, ioSession)).thenReturn(ioSession);
 
         connman.startRoute(managedConn, route, context);
 
-        Mockito.verify(noopStrategy, Mockito.never()).upgrade(target, iosession);
-        Mockito.verify(conn, Mockito.never()).bind(iosession);
+        Mockito.verify(noopStrategy, Mockito.never()).upgrade(target, ioSession);
+        Mockito.verify(conn, Mockito.never()).bind(ioSession);
 
         Assert.assertFalse(connman.isRouteComplete(managedConn));
     }
@@ -337,8 +337,8 @@ public class TestPoolingHttpClientAsyncC
         poolentry.markRouteComplete();
         final NHttpClientConnection managedConn = CPoolProxy.newProxy(poolentry);
 
-        Mockito.when(conn.getIOSession()).thenReturn(iosession);
-        Mockito.when(sslStrategy.upgrade(target, iosession)).thenReturn(iosession);
+        Mockito.when(conn.getIOSession()).thenReturn(ioSession);
+        Mockito.when(sslStrategy.upgrade(target, ioSession)).thenReturn(ioSession);
 
         connman.startRoute(managedConn, route, context);
     }
@@ -354,13 +354,13 @@ public class TestPoolingHttpClientAsyncC
         poolentry.markRouteComplete();
         final NHttpClientConnection managedConn = CPoolProxy.newProxy(poolentry);
 
-        Mockito.when(conn.getIOSession()).thenReturn(iosession);
-        Mockito.when(sslStrategy.upgrade(target, iosession)).thenReturn(iosession);
+        Mockito.when(conn.getIOSession()).thenReturn(ioSession);
+        Mockito.when(sslStrategy.upgrade(target, ioSession)).thenReturn(ioSession);
 
         connman.upgrade(managedConn, route, context);
 
-        Mockito.verify(sslStrategy).upgrade(target, iosession);
-        Mockito.verify(conn).bind(iosession);
+        Mockito.verify(sslStrategy).upgrade(target, ioSession);
+        Mockito.verify(conn).bind(ioSession);
     }
 
     @Test(expected=UnsupportedSchemeException.class)
@@ -374,8 +374,8 @@ public class TestPoolingHttpClientAsyncC
         poolentry.markRouteComplete();
         final NHttpClientConnection managedConn = CPoolProxy.newProxy(poolentry);
 
-        Mockito.when(conn.getIOSession()).thenReturn(iosession);
-        Mockito.when(sslStrategy.upgrade(target, iosession)).thenReturn(iosession);
+        Mockito.when(conn.getIOSession()).thenReturn(ioSession);
+        Mockito.when(sslStrategy.upgrade(target, ioSession)).thenReturn(ioSession);
 
         connman.upgrade(managedConn, route, context);
     }
@@ -391,8 +391,8 @@ public class TestPoolingHttpClientAsyncC
         poolentry.markRouteComplete();
         final NHttpClientConnection managedConn = CPoolProxy.newProxy(poolentry);
 
-        Mockito.when(conn.getIOSession()).thenReturn(iosession);
-        Mockito.when(sslStrategy.upgrade(target, iosession)).thenReturn(iosession);
+        Mockito.when(conn.getIOSession()).thenReturn(ioSession);
+        Mockito.when(sslStrategy.upgrade(target, ioSession)).thenReturn(ioSession);
 
         connman.upgrade(managedConn, route, context);
     }
@@ -408,8 +408,8 @@ public class TestPoolingHttpClientAsyncC
         poolentry.markRouteComplete();
         final NHttpClientConnection managedConn = CPoolProxy.newProxy(poolentry);
 
-        Mockito.when(conn.getIOSession()).thenReturn(iosession);
-        Mockito.when(sslStrategy.upgrade(target, iosession)).thenReturn(iosession);
+        Mockito.when(conn.getIOSession()).thenReturn(ioSession);
+        Mockito.when(sslStrategy.upgrade(target, ioSession)).thenReturn(ioSession);
 
         connman.startRoute(managedConn, route, context);
         connman.routeComplete(managedConn, route, context);
@@ -458,11 +458,11 @@ public class TestPoolingHttpClientAsyncC
             configData, connFactory);
 
         final HttpRoute route = new HttpRoute(new HttpHost("somehost", 80));
-        internalConnFactory.create(route, iosession);
+        internalConnFactory.create(route, ioSession);
 
         Mockito.verify(sslStrategy, Mockito.never()).upgrade(Matchers.eq(new HttpHost("somehost", 80)),
                 Matchers.<IOSession>any());
-        Mockito.verify(connFactory).create(Matchers.same(iosession), Matchers.<ConnectionConfig>any());
+        Mockito.verify(connFactory).create(Matchers.same(ioSession), Matchers.<ConnectionConfig>any());
     }
 
     @Test
@@ -478,9 +478,9 @@ public class TestPoolingHttpClientAsyncC
         final ConnectionConfig config = ConnectionConfig.custom().build();
         configData.setConnectionConfig(proxy, config);
 
-        internalConnFactory.create(route, iosession);
+        internalConnFactory.create(route, ioSession);
 
-        Mockito.verify(connFactory).create(iosession, config);
+        Mockito.verify(connFactory).create(ioSession, config);
     }
 
     @Test
@@ -495,9 +495,9 @@ public class TestPoolingHttpClientAsyncC
         final ConnectionConfig config = ConnectionConfig.custom().build();
         configData.setConnectionConfig(target, config);
 
-        internalConnFactory.create(route, iosession);
+        internalConnFactory.create(route, ioSession);
 
-        Mockito.verify(connFactory).create(iosession, config);
+        Mockito.verify(connFactory).create(ioSession, config);
     }
 
     @Test
@@ -512,9 +512,9 @@ public class TestPoolingHttpClientAsyncC
         final ConnectionConfig config = ConnectionConfig.custom().build();
         configData.setDefaultConnectionConfig(config);
 
-        internalConnFactory.create(route, iosession);
+        internalConnFactory.create(route, ioSession);
 
-        Mockito.verify(connFactory).create(iosession, config);
+        Mockito.verify(connFactory).create(ioSession, config);
     }
 
     @Test
@@ -528,9 +528,9 @@ public class TestPoolingHttpClientAsyncC
 
         configData.setDefaultConnectionConfig(null);
 
-        internalConnFactory.create(route, iosession);
+        internalConnFactory.create(route, ioSession);
 
-        Mockito.verify(connFactory).create(iosession, ConnectionConfig.DEFAULT);
+        Mockito.verify(connFactory).create(ioSession, ConnectionConfig.DEFAULT);
     }
 
     @Test

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/integration/TestHttpAsync.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/integration/TestHttpAsync.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/integration/TestHttpAsync.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/integration/TestHttpAsync.java Tue Aug 14 16:57:56 2018
@@ -217,7 +217,7 @@ public class TestHttpAsync extends HttpA
         final BasicAsyncResponseConsumer responseConsumer = new BasicAsyncResponseConsumer() {
 
             @Override
-            public void onContentReceived(final ContentDecoder decoder, final IOControl ioctrl)
+            public void onContentReceived(final ContentDecoder decoder, final IOControl ioControl)
                     throws IOException {
                 throw new IOException("Kaboom");
             }

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/integration/TestHttpAsyncPrematureTermination.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/integration/TestHttpAsyncPrematureTermination.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/integration/TestHttpAsyncPrematureTermination.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/integration/TestHttpAsyncPrematureTermination.java Tue Aug 14 16:57:56 2018
@@ -200,8 +200,8 @@ public class TestHttpAsyncPrematureTermi
                     @Override
                     public synchronized void produceContent(
                             final ContentEncoder encoder,
-                            final IOControl ioctrl) throws IOException {
-                        ioctrl.shutdown();
+                            final IOControl ioControl) throws IOException {
+                        ioControl.shutdown();
                     }
 
                 });
@@ -277,7 +277,7 @@ public class TestHttpAsyncPrematureTermi
 
             @Override
             public void consumeContent(
-                    final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
+                    final ContentDecoder decoder, final IOControl ioControl) throws IOException {
                 throw new IllegalStateException();
             }
 
@@ -359,7 +359,7 @@ public class TestHttpAsyncPrematureTermi
 
             @Override
             public void consumeContent(
-                    final ContentDecoder decoder, final IOControl ioctrl) throws IOException {
+                    final ContentDecoder decoder, final IOControl ioControl) throws IOException {
             }
 
             @Override

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/integration/TestStatefulConnManagement.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/integration/TestStatefulConnManagement.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/integration/TestStatefulConnManagement.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/integration/TestStatefulConnManagement.java Tue Aug 14 16:57:56 2018
@@ -182,7 +182,7 @@ public class TestStatefulConnManagement
                                 @Override
                                 protected void onContentReceived(
                                         final ContentDecoder decoder,
-                                        final IOControl ioctrl) throws IOException {
+                                        final IOControl ioControl) throws IOException {
                                     final ByteBuffer buf = ByteBuffer.allocate(2048);
                                     decoder.read(buf);
                                 }

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/methods/TestAsyncConsumers.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/methods/TestAsyncConsumers.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/methods/TestAsyncConsumers.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/methods/TestAsyncConsumers.java Tue Aug 14 16:57:56 2018
@@ -77,7 +77,7 @@ public class TestAsyncConsumers extends
         }
 
         @Override
-        protected void onByteReceived(final ByteBuffer buf, final IOControl ioctrl) {
+        protected void onByteReceived(final ByteBuffer buf, final IOControl ioControl) {
             this.count.addAndGet(buf.remaining());
         }
 
@@ -129,7 +129,7 @@ public class TestAsyncConsumers extends
         }
 
         @Override
-        protected void onCharReceived(final CharBuffer buf, final IOControl ioctrl) throws IOException {
+        protected void onCharReceived(final CharBuffer buf, final IOControl ioControl) throws IOException {
             while (buf.hasRemaining()) {
                 this.sb.append(buf.get());
             }

Modified: httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/methods/TestZeroCopy.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/methods/TestZeroCopy.java?rev=1838035&r1=1838034&r2=1838035&view=diff
==============================================================================
--- httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/methods/TestZeroCopy.java (original)
+++ httpcomponents/httpasyncclient/branches/4.1.x/httpasyncclient/src/test/java/org/apache/http/nio/client/methods/TestZeroCopy.java Tue Aug 14 16:57:56 2018
@@ -174,14 +174,14 @@ public class TestZeroCopy extends HttpAs
 
             boolean ok = true;
 
-            final InputStream instream = requestEntity.getContent();
+            final InputStream inStream = requestEntity.getContent();
             try {
                 final ContentType contentType = ContentType.getOrDefault(requestEntity);
                 Charset charset = contentType.getCharset();
                 if (charset == null) {
                     charset = Consts.ISO_8859_1;
                 }
-                final LineIterator it = IOUtils.lineIterator(instream, charset.name());
+                final LineIterator it = IOUtils.lineIterator(inStream, charset.name());
                 int count = 0;
                 while (it.hasNext()) {
                     final String line = it.next();
@@ -194,7 +194,7 @@ public class TestZeroCopy extends HttpAs
                     count++;
                 }
             } finally {
-                instream.close();
+                inStream.close();
             }
             if (ok) {
                 final NFileEntity responseEntity = new NFileEntity(TEST_FILE,
@@ -222,9 +222,9 @@ public class TestZeroCopy extends HttpAs
         final Integer status = future.get();
         Assert.assertNotNull(status);
         Assert.assertEquals(HttpStatus.SC_OK, status.intValue());
-        final InputStream instream = new FileInputStream(this.tmpfile);
+        final InputStream inStream = new FileInputStream(this.tmpfile);
         try {
-            final LineIterator it = IOUtils.lineIterator(instream, ASCII.name());
+            final LineIterator it = IOUtils.lineIterator(inStream, ASCII.name());
             int count = 0;
             while (it.hasNext()) {
                 final String line = it.next();
@@ -234,7 +234,7 @@ public class TestZeroCopy extends HttpAs
                 count++;
             }
         } finally {
-            instream.close();
+            inStream.close();
         }
     }
 
@@ -250,9 +250,9 @@ public class TestZeroCopy extends HttpAs
         final Integer status = future.get();
         Assert.assertNotNull(status);
         Assert.assertEquals(HttpStatus.SC_OK, status.intValue());
-        final InputStream instream = new FileInputStream(this.tmpfile);
+        final InputStream inStream = new FileInputStream(this.tmpfile);
         try {
-            final LineIterator it = IOUtils.lineIterator(instream, ASCII.name());
+            final LineIterator it = IOUtils.lineIterator(inStream, ASCII.name());
             int count = 0;
             while (it.hasNext()) {
                 final String line = it.next();
@@ -262,7 +262,7 @@ public class TestZeroCopy extends HttpAs
                 count++;
             }
         } finally {
-            instream.close();
+            inStream.close();
         }
     }