Author: olegk
Date: Wed Feb 20 22:11:34 2013
New Revision: 1448439
URL: http://svn.apache.org/r1448439
Log:
HTTPCORE-334: https request to a non-responsive but alive port results in a busy loop in one
of I/O dispatch threads
Contributed by Scott Stanton <snstanton at gmail.com>
Added:
httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpsAsyncTimeout.java
(with props)
Modified:
httpcomponents/httpcore/branches/4.2.x/RELEASE_NOTES.txt
httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/main/java/org/apache/http/nio/reactor/ssl/SSLIOSession.java
httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/test/java/org/apache/http/HttpCoreNIOTestBase.java
Modified: httpcomponents/httpcore/branches/4.2.x/RELEASE_NOTES.txt
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/branches/4.2.x/RELEASE_NOTES.txt?rev=1448439&r1=1448438&r2=1448439&view=diff
==============================================================================
--- httpcomponents/httpcore/branches/4.2.x/RELEASE_NOTES.txt (original)
+++ httpcomponents/httpcore/branches/4.2.x/RELEASE_NOTES.txt Wed Feb 20 22:11:34 2013
@@ -1,5 +1,9 @@
Changes since 4.2.3
+* [HTTPCORE-334] https request to a non-responsive but alive port results in a busy loop
+ in one of I/O dispatch threads.
+ Contributed by Scott Stanton <snstanton at gmail.com>
+
* [HTTPCORE-331] BasicFuture no longer executes notification callbacks inside a synchronized
block.
Contributed by Oleg Kalnichevski <olegk at apache.org>
Modified: httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/main/java/org/apache/http/nio/reactor/ssl/SSLIOSession.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/main/java/org/apache/http/nio/reactor/ssl/SSLIOSession.java?rev=1448439&r1=1448438&r2=1448439&view=diff
==============================================================================
--- httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/main/java/org/apache/http/nio/reactor/ssl/SSLIOSession.java
(original)
+++ httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/main/java/org/apache/http/nio/reactor/ssl/SSLIOSession.java
Wed Feb 20 22:11:34 2013
@@ -310,7 +310,7 @@ public class SSLIOSession implements IOS
newMask = EventMask.READ_WRITE;
break;
case NEED_UNWRAP:
- newMask = EventMask.READ | (this.appEventMask & EventMask.WRITE);
+ newMask = EventMask.READ;
break;
case NOT_HANDSHAKING:
newMask = this.appEventMask;
Modified: httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/test/java/org/apache/http/HttpCoreNIOTestBase.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/test/java/org/apache/http/HttpCoreNIOTestBase.java?rev=1448439&r1=1448438&r2=1448439&view=diff
==============================================================================
--- httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/test/java/org/apache/http/HttpCoreNIOTestBase.java
(original)
+++ httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/test/java/org/apache/http/HttpCoreNIOTestBase.java
Wed Feb 20 22:11:34 2013
@@ -55,7 +55,6 @@ import org.junit.After;
/**
* Base class for all HttpCore NIO tests
- *
*/
public abstract class HttpCoreNIOTestBase {
@@ -74,6 +73,11 @@ public abstract class HttpCoreNIOTestBas
protected abstract NHttpConnectionFactory<DefaultNHttpClientConnection> createClientConnectionFactory(
HttpParams params) throws Exception;
+ protected NHttpConnectionFactory<DefaultNHttpClientConnection> createClientSSLConnectionFactory(
+ HttpParams params) throws Exception {
+ return null;
+ }
+
public void initServer() throws Exception {
this.serverParams = new SyncBasicHttpParams();
this.serverParams
@@ -115,7 +119,8 @@ public abstract class HttpCoreNIOTestBas
public void initConnPool() throws Exception {
this.connpool = new BasicNIOConnPool(
this.client.getIoReactor(),
- new BasicNIOConnFactory(createClientConnectionFactory(this.clientParams)),
+ new BasicNIOConnFactory(createClientConnectionFactory(this.clientParams),
+ createClientSSLConnectionFactory(this.clientParams)),
this.clientParams);
this.executor = new HttpAsyncRequester(
this.clientHttpProc,
Added: httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpsAsyncTimeout.java
URL: http://svn.apache.org/viewvc/httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpsAsyncTimeout.java?rev=1448439&view=auto
==============================================================================
--- httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpsAsyncTimeout.java
(added)
+++ httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpsAsyncTimeout.java
Wed Feb 20 22:11:34 2013
@@ -0,0 +1,146 @@
+/*
+ * ====================================================================
+ * 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.http.nio.integration;
+
+import org.apache.http.HttpCoreNIOTestBase;
+import org.apache.http.HttpHost;
+import org.apache.http.HttpRequest;
+import org.apache.http.HttpResponse;
+import org.apache.http.LoggingClientConnectionFactory;
+import org.apache.http.LoggingSSLClientConnectionFactory;
+import org.apache.http.SSLTestContexts;
+import org.apache.http.concurrent.FutureCallback;
+import org.apache.http.impl.nio.DefaultNHttpClientConnection;
+import org.apache.http.impl.nio.DefaultNHttpServerConnection;
+import org.apache.http.message.BasicHttpRequest;
+import org.apache.http.nio.NHttpConnectionFactory;
+import org.apache.http.nio.protocol.BasicAsyncRequestProducer;
+import org.apache.http.nio.protocol.BasicAsyncResponseConsumer;
+import org.apache.http.nio.protocol.HttpAsyncRequestExecutor;
+import org.apache.http.params.CoreConnectionPNames;
+import org.apache.http.params.HttpParams;
+import org.apache.http.protocol.BasicHttpContext;
+import org.apache.http.protocol.HttpContext;
+import org.junit.After;
+import org.junit.Assert;
+import org.junit.Before;
+import org.junit.Test;
+
+import java.net.InetSocketAddress;
+import java.net.ServerSocket;
+import java.net.Socket;
+import java.util.concurrent.CountDownLatch;
+import java.util.concurrent.TimeUnit;
+
+public class TestHttpsAsyncTimeout extends HttpCoreNIOTestBase {
+
+ private ServerSocket serverSocket;
+
+ @Before
+ public void setUp() throws Exception {
+ initClient();
+ initConnPool();
+ }
+
+ @After
+ public void tearDown() throws Exception {
+ serverSocket.close();
+ shutDownClient();
+ }
+
+ @Override
+ protected NHttpConnectionFactory<DefaultNHttpServerConnection> createServerConnectionFactory(
+ final HttpParams params) throws Exception {
+ return null;
+ }
+
+ @Override
+ protected NHttpConnectionFactory<DefaultNHttpClientConnection> createClientConnectionFactory(
+ final HttpParams params) throws Exception {
+ return new LoggingClientConnectionFactory(params);
+ }
+
+ @Override
+ protected NHttpConnectionFactory<DefaultNHttpClientConnection> createClientSSLConnectionFactory(
+ final HttpParams params) throws Exception {
+
+ return new LoggingSSLClientConnectionFactory(SSLTestContexts.createClientSSLContext(),
params);
+ }
+
+ private InetSocketAddress start() throws Exception {
+
+ HttpAsyncRequestExecutor clientHandler = new HttpAsyncRequestExecutor();
+ this.client.start(clientHandler);
+ serverSocket = new ServerSocket(0);
+ return new InetSocketAddress(serverSocket.getInetAddress(), serverSocket.getLocalPort());
+ }
+
+ @Test
+ public void testHandshakeTimeout() throws Exception {
+ // This test creates a server socket and accepts the incoming
+ // socket connection without reading any data. The client should
+ // connect, be unable to progress through the handshake, and then
+ // time out when SO_TIMEOUT has elapsed.
+
+ InetSocketAddress address = start();
+ HttpHost target = new HttpHost("localhost", address.getPort(), "https");
+
+ final CountDownLatch latch = new CountDownLatch(1);
+
+ FutureCallback<HttpResponse> callback = new FutureCallback<HttpResponse>()
{
+
+ public void cancelled() {
+ latch.countDown();
+ }
+
+ public void failed(final Exception ex) {
+ latch.countDown();
+ }
+
+ public void completed(final HttpResponse response) {
+ Assert.fail();
+ }
+
+ };
+
+ HttpRequest request = new BasicHttpRequest("GET", "/");
+ HttpContext context = new BasicHttpContext();
+ this.clientParams.setParameter(CoreConnectionPNames.SO_TIMEOUT, 2000);
+ this.executor.execute(
+ new BasicAsyncRequestProducer(target, request),
+ new BasicAsyncResponseConsumer(),
+ this.connpool, context, callback);
+ Socket accepted = serverSocket.accept();
+ try {
+ Assert.assertTrue(latch.await(10, TimeUnit.SECONDS));
+ } finally {
+ accepted.close();
+ }
+ }
+
+}
Propchange: httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpsAsyncTimeout.java
------------------------------------------------------------------------------
svn:eol-style = native
Propchange: httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpsAsyncTimeout.java
------------------------------------------------------------------------------
svn:keywords = Date Revision
Propchange: httpcomponents/httpcore/branches/4.2.x/httpcore-nio/src/test/java/org/apache/http/nio/integration/TestHttpsAsyncTimeout.java
------------------------------------------------------------------------------
svn:mime-type = text/plain
|