Merge branch 'master' of github.com:netty/netty
This commit is contained in:
commit
b0c6b701e4
@ -72,6 +72,8 @@ public class ServerSocketSuspendTest extends AbstractServerSocketTest {
|
|||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
|
Thread.sleep(TIMEOUT / 1000000);
|
||||||
|
|
||||||
try {
|
try {
|
||||||
long startTime = System.nanoTime();
|
long startTime = System.nanoTime();
|
||||||
for (int i = 0; i < NUM_CHANNELS; i ++) {
|
for (int i = 0; i < NUM_CHANNELS; i ++) {
|
||||||
|
@ -17,17 +17,16 @@ package io.netty.bootstrap;
|
|||||||
|
|
||||||
import io.netty.buffer.MessageBuf;
|
import io.netty.buffer.MessageBuf;
|
||||||
import io.netty.buffer.Unpooled;
|
import io.netty.buffer.Unpooled;
|
||||||
|
|
||||||
import io.netty.channel.Channel;
|
import io.netty.channel.Channel;
|
||||||
|
import io.netty.channel.ChannelFuture;
|
||||||
|
import io.netty.channel.ChannelFutureListener;
|
||||||
import io.netty.channel.ChannelHandler;
|
import io.netty.channel.ChannelHandler;
|
||||||
import io.netty.channel.ChannelHandlerContext;
|
import io.netty.channel.ChannelHandlerContext;
|
||||||
import io.netty.channel.ChannelPipeline;
|
|
||||||
import io.netty.channel.ChannelFutureListener;
|
|
||||||
import io.netty.channel.ChannelFuture;
|
|
||||||
import io.netty.channel.ChannelInboundMessageHandler;
|
|
||||||
import io.netty.channel.ChannelInboundHandlerAdapter;
|
import io.netty.channel.ChannelInboundHandlerAdapter;
|
||||||
|
import io.netty.channel.ChannelInboundMessageHandler;
|
||||||
import io.netty.channel.ChannelInitializer;
|
import io.netty.channel.ChannelInitializer;
|
||||||
import io.netty.channel.ChannelOption;
|
import io.netty.channel.ChannelOption;
|
||||||
|
import io.netty.channel.ChannelPipeline;
|
||||||
import io.netty.channel.EventLoopGroup;
|
import io.netty.channel.EventLoopGroup;
|
||||||
import io.netty.channel.ServerChannel;
|
import io.netty.channel.ServerChannel;
|
||||||
import io.netty.channel.socket.SocketChannel;
|
import io.netty.channel.socket.SocketChannel;
|
||||||
@ -232,6 +231,7 @@ public class ServerBootstrap extends AbstractBootstrap<ServerBootstrap> {
|
|||||||
try {
|
try {
|
||||||
childGroup.register(child);
|
childGroup.register(child);
|
||||||
} catch (Throwable t) {
|
} catch (Throwable t) {
|
||||||
|
child.unsafe().closeForcibly();
|
||||||
logger.warn("Failed to register an accepted channel: " + child, t);
|
logger.warn("Failed to register an accepted channel: " + child, t);
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
@ -547,6 +547,15 @@ public abstract class AbstractChannel extends DefaultAttributeMap implements Cha
|
|||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@Override
|
||||||
|
public final void closeForcibly() {
|
||||||
|
try {
|
||||||
|
doClose();
|
||||||
|
} catch (Exception e) {
|
||||||
|
logger.warn("Failed to close a channel.", e);
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
@Override
|
@Override
|
||||||
public final void deregister(final ChannelFuture future) {
|
public final void deregister(final ChannelFuture future) {
|
||||||
if (eventLoop().inEventLoop()) {
|
if (eventLoop().inEventLoop()) {
|
||||||
|
@ -248,6 +248,12 @@ public interface Channel extends AttributeMap, ChannelOutboundInvoker, ChannelFu
|
|||||||
*/
|
*/
|
||||||
void close(ChannelFuture future);
|
void close(ChannelFuture future);
|
||||||
|
|
||||||
|
/**
|
||||||
|
* Closes the {@link Channel} immediately without firing any events. Probably only useful
|
||||||
|
* when registration attempt failed.
|
||||||
|
*/
|
||||||
|
void closeForcibly();
|
||||||
|
|
||||||
/**
|
/**
|
||||||
* Deregister the {@link Channel} of the {@link ChannelFuture} from {@link EventLoop} and notify the
|
* Deregister the {@link Channel} of the {@link ChannelFuture} from {@link EventLoop} and notify the
|
||||||
* {@link ChannelFuture} once the operation was complete.
|
* {@link ChannelFuture} once the operation was complete.
|
||||||
|
@ -23,6 +23,7 @@ import io.netty.channel.ChannelConfig;
|
|||||||
import io.netty.channel.ChannelException;
|
import io.netty.channel.ChannelException;
|
||||||
import io.netty.channel.ChannelFuture;
|
import io.netty.channel.ChannelFuture;
|
||||||
import io.netty.channel.ChannelMetadata;
|
import io.netty.channel.ChannelMetadata;
|
||||||
|
import io.netty.channel.ChannelPipeline;
|
||||||
import io.netty.channel.DefaultChannelConfig;
|
import io.netty.channel.DefaultChannelConfig;
|
||||||
import io.netty.channel.EventLoop;
|
import io.netty.channel.EventLoop;
|
||||||
import io.netty.channel.SingleThreadEventExecutor;
|
import io.netty.channel.SingleThreadEventExecutor;
|
||||||
@ -215,17 +216,27 @@ public class LocalChannel extends AbstractChannel {
|
|||||||
}
|
}
|
||||||
|
|
||||||
final LocalChannel peer = this.peer;
|
final LocalChannel peer = this.peer;
|
||||||
assert peer != null;
|
final ChannelPipeline peerPipeline = peer.pipeline();
|
||||||
|
final EventLoop peerLoop = peer.eventLoop();
|
||||||
|
|
||||||
buf.drainTo(peer.pipeline().inboundMessageBuffer());
|
if (peerLoop == eventLoop()) {
|
||||||
|
buf.drainTo(peerPipeline.inboundMessageBuffer());
|
||||||
peer.eventLoop().execute(new Runnable() {
|
peerPipeline.fireInboundBufferUpdated();
|
||||||
|
} else {
|
||||||
|
final Object[] msgs = buf.toArray();
|
||||||
|
buf.clear();
|
||||||
|
peerLoop.execute(new Runnable() {
|
||||||
@Override
|
@Override
|
||||||
public void run() {
|
public void run() {
|
||||||
peer.pipeline().fireInboundBufferUpdated();
|
MessageBuf<Object> buf = peerPipeline.inboundMessageBuffer();
|
||||||
|
for (Object m: msgs) {
|
||||||
|
buf.add(m);
|
||||||
|
}
|
||||||
|
peerPipeline.fireInboundBufferUpdated();
|
||||||
}
|
}
|
||||||
});
|
});
|
||||||
}
|
}
|
||||||
|
}
|
||||||
|
|
||||||
@Override
|
@Override
|
||||||
protected boolean isFlushPending() {
|
protected boolean isFlushPending() {
|
||||||
|
@ -19,9 +19,9 @@ package io.netty.channel.socket.oio;
|
|||||||
import io.netty.channel.Channel;
|
import io.netty.channel.Channel;
|
||||||
import io.netty.channel.ChannelException;
|
import io.netty.channel.ChannelException;
|
||||||
import io.netty.channel.ChannelFuture;
|
import io.netty.channel.ChannelFuture;
|
||||||
|
import io.netty.channel.ChannelTaskScheduler;
|
||||||
import io.netty.channel.EventLoop;
|
import io.netty.channel.EventLoop;
|
||||||
import io.netty.channel.EventLoopGroup;
|
import io.netty.channel.EventLoopGroup;
|
||||||
import io.netty.channel.ChannelTaskScheduler;
|
|
||||||
|
|
||||||
import java.util.Collections;
|
import java.util.Collections;
|
||||||
import java.util.Queue;
|
import java.util.Queue;
|
||||||
|
@ -0,0 +1,153 @@
|
|||||||
|
/*
|
||||||
|
* Copyright 2012 The Netty Project
|
||||||
|
*
|
||||||
|
* The Netty Project 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.
|
||||||
|
*/
|
||||||
|
package io.netty.channel.local;
|
||||||
|
|
||||||
|
import static org.junit.Assert.*;
|
||||||
|
import io.netty.bootstrap.Bootstrap;
|
||||||
|
import io.netty.bootstrap.ServerBootstrap;
|
||||||
|
import io.netty.buffer.MessageBuf;
|
||||||
|
import io.netty.channel.Channel;
|
||||||
|
import io.netty.channel.ChannelFuture;
|
||||||
|
import io.netty.channel.ChannelHandler.Sharable;
|
||||||
|
import io.netty.channel.ChannelHandlerContext;
|
||||||
|
import io.netty.channel.ChannelInboundMessageHandlerAdapter;
|
||||||
|
|
||||||
|
import java.util.Iterator;
|
||||||
|
import java.util.concurrent.atomic.AtomicInteger;
|
||||||
|
|
||||||
|
import org.junit.Test;
|
||||||
|
|
||||||
|
public class LocalTransportThreadModelTest2 {
|
||||||
|
|
||||||
|
private static final String LOCAL_CHANNEL = LocalTransportThreadModelTest2.class.getName();
|
||||||
|
|
||||||
|
static final int messageCountPerRun = 4;
|
||||||
|
|
||||||
|
@Test(timeout = 15000)
|
||||||
|
public void testSocketReuse() throws InterruptedException {
|
||||||
|
ServerBootstrap serverBootstrap = new ServerBootstrap();
|
||||||
|
LocalHander serverHandler = new LocalHander("SERVER");
|
||||||
|
serverBootstrap
|
||||||
|
.group(new LocalEventLoopGroup(), new LocalEventLoopGroup())
|
||||||
|
.channel(LocalServerChannel.class)
|
||||||
|
.localAddress(new LocalAddress(LOCAL_CHANNEL))
|
||||||
|
.childHandler(serverHandler);
|
||||||
|
|
||||||
|
Bootstrap clientBootstrap = new Bootstrap();
|
||||||
|
LocalHander clientHandler = new LocalHander("CLIENT");
|
||||||
|
clientBootstrap
|
||||||
|
.group(new LocalEventLoopGroup())
|
||||||
|
.channel(LocalChannel.class)
|
||||||
|
.remoteAddress(new LocalAddress(LOCAL_CHANNEL)).handler(clientHandler);
|
||||||
|
|
||||||
|
serverBootstrap.bind().sync();
|
||||||
|
|
||||||
|
int count = 100;
|
||||||
|
for (int i = 1; i < count + 1; i ++) {
|
||||||
|
Channel ch = clientBootstrap.connect().sync().channel();
|
||||||
|
|
||||||
|
// SPIN until we get what we are looking for.
|
||||||
|
int target = i * messageCountPerRun;
|
||||||
|
while (serverHandler.count.get() != target || clientHandler.count.get() != target) {
|
||||||
|
Thread.sleep(50);
|
||||||
|
}
|
||||||
|
close(ch, clientHandler);
|
||||||
|
}
|
||||||
|
|
||||||
|
assertEquals(count * 2 * messageCountPerRun, serverHandler.count.get() +
|
||||||
|
clientHandler.count.get());
|
||||||
|
}
|
||||||
|
|
||||||
|
public void close(final Channel localChannel, final LocalHander localRegistrationHandler) {
|
||||||
|
// we want to make sure we actually shutdown IN the event loop
|
||||||
|
if (localChannel.eventLoop().inEventLoop()) {
|
||||||
|
MessageBuf<Object> outboundMessageBuffer =
|
||||||
|
localChannel.pipeline().outboundMessageBuffer();
|
||||||
|
if (!outboundMessageBuffer.isEmpty()) {
|
||||||
|
System.err.println("NOT EMPTY TO SEND!");
|
||||||
|
}
|
||||||
|
|
||||||
|
// Wait until all messages are flushed before closing the channel.
|
||||||
|
if (localRegistrationHandler.lastWriteFuture != null) {
|
||||||
|
localRegistrationHandler.lastWriteFuture.awaitUninterruptibly();
|
||||||
|
}
|
||||||
|
|
||||||
|
MessageBuf<Object> inboundMessageBuffer =
|
||||||
|
localChannel.pipeline().inboundMessageBuffer();
|
||||||
|
if (!inboundMessageBuffer.isEmpty()) {
|
||||||
|
// sometimes we close the pipeline before everything on it has been notified/received.
|
||||||
|
// we want these messages, since they are in our queue.
|
||||||
|
Iterator<Object> iterator = inboundMessageBuffer.iterator();
|
||||||
|
while (iterator.hasNext()) {
|
||||||
|
Object next = iterator.next();
|
||||||
|
System.err.println("DEFERRED on close: " + next);
|
||||||
|
iterator.remove();
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
localChannel.close();
|
||||||
|
return;
|
||||||
|
} else {
|
||||||
|
localChannel.eventLoop().execute(new Runnable() {
|
||||||
|
@Override
|
||||||
|
public void run() {
|
||||||
|
close(localChannel, localRegistrationHandler);
|
||||||
|
}
|
||||||
|
});
|
||||||
|
}
|
||||||
|
|
||||||
|
// Wait until the connection is closed or the connection attempt fails.
|
||||||
|
localChannel.closeFuture().awaitUninterruptibly();
|
||||||
|
|
||||||
|
MessageBuf<Object> inboundMessageBuffer = localChannel.pipeline().inboundMessageBuffer();
|
||||||
|
if (!inboundMessageBuffer.isEmpty()) {
|
||||||
|
// sometimes we close the pipeline before everything on it has been notified/received.
|
||||||
|
// we want these messages, since they are in our queue.
|
||||||
|
Iterator<Object> iterator = inboundMessageBuffer.iterator();
|
||||||
|
while (iterator.hasNext()) {
|
||||||
|
Object next = iterator.next();
|
||||||
|
System.err.println("DEFERRED on close: " + next);
|
||||||
|
iterator.remove();
|
||||||
|
}
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
@Sharable
|
||||||
|
class LocalHander extends ChannelInboundMessageHandlerAdapter<Object> {
|
||||||
|
private final String name;
|
||||||
|
|
||||||
|
public volatile ChannelFuture lastWriteFuture = null;
|
||||||
|
|
||||||
|
public AtomicInteger count = new AtomicInteger(0);
|
||||||
|
|
||||||
|
public LocalHander(String name) {
|
||||||
|
this.name = name;
|
||||||
|
|
||||||
|
}
|
||||||
|
|
||||||
|
@Override
|
||||||
|
public void channelActive(ChannelHandlerContext ctx) throws Exception {
|
||||||
|
for (int i = 0; i < messageCountPerRun; i ++) {
|
||||||
|
lastWriteFuture = ctx.channel().write(name + " " + i);
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
@Override
|
||||||
|
public void messageReceived(ChannelHandlerContext ctx, Object msg) throws Exception {
|
||||||
|
count.incrementAndGet();
|
||||||
|
}
|
||||||
|
}
|
||||||
|
}
|
Loading…
Reference in New Issue
Block a user