Add test for CopyBytesSocketChannel (#46031)
Currently we use a custom CopyBytesSocketChannel for interfacing with netty. We have integration tests that use this channel, however we never verify the read and write behavior in the face of potential partial writes. This commit adds a test for this behavior.
This commit is contained in:
parent
8228a218b4
commit
ad233e3e38
|
@ -40,6 +40,7 @@ import io.netty.channel.RecvByteBufAllocator;
|
|||
import io.netty.channel.socket.nio.NioSocketChannel;
|
||||
import org.elasticsearch.common.SuppressForbidden;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.nio.ByteBuffer;
|
||||
import java.nio.channels.SocketChannel;
|
||||
|
||||
|
@ -74,7 +75,6 @@ public class CopyBytesSocketChannel extends NioSocketChannel {
|
|||
|
||||
@Override
|
||||
protected void doWrite(ChannelOutboundBuffer in) throws Exception {
|
||||
SocketChannel ch = javaChannel();
|
||||
int writeSpinCount = config().getWriteSpinCount();
|
||||
do {
|
||||
if (in.isEmpty()) {
|
||||
|
@ -99,7 +99,7 @@ public class CopyBytesSocketChannel extends NioSocketChannel {
|
|||
ioBuffer.flip();
|
||||
|
||||
int attemptedBytes = ioBuffer.remaining();
|
||||
final int localWrittenBytes = ch.write(ioBuffer);
|
||||
final int localWrittenBytes = writeToSocketChannel(javaChannel(), ioBuffer);
|
||||
if (localWrittenBytes <= 0) {
|
||||
incompleteWrite(true);
|
||||
return;
|
||||
|
@ -119,7 +119,7 @@ public class CopyBytesSocketChannel extends NioSocketChannel {
|
|||
final RecvByteBufAllocator.Handle allocHandle = unsafe().recvBufAllocHandle();
|
||||
allocHandle.attemptedBytesRead(byteBuf.writableBytes());
|
||||
ByteBuffer ioBuffer = getIoBuffer();
|
||||
int bytesRead = javaChannel().read(ioBuffer);
|
||||
int bytesRead = readFromSocketChannel(javaChannel(), ioBuffer);
|
||||
ioBuffer.flip();
|
||||
if (bytesRead > 0) {
|
||||
byteBuf.writeBytes(ioBuffer);
|
||||
|
@ -127,6 +127,16 @@ public class CopyBytesSocketChannel extends NioSocketChannel {
|
|||
return bytesRead;
|
||||
}
|
||||
|
||||
// Protected so that tests can verify behavior and simulate partial writes
|
||||
protected int writeToSocketChannel(SocketChannel socketChannel, ByteBuffer ioBuffer) throws IOException {
|
||||
return socketChannel.write(ioBuffer);
|
||||
}
|
||||
|
||||
// Protected so that tests can verify behavior
|
||||
protected int readFromSocketChannel(SocketChannel socketChannel, ByteBuffer ioBuffer) throws IOException {
|
||||
return socketChannel.read(ioBuffer);
|
||||
}
|
||||
|
||||
private static ByteBuffer getIoBuffer() {
|
||||
ByteBuffer ioBuffer = CopyBytesSocketChannel.ioBuffer.get();
|
||||
ioBuffer.clear();
|
||||
|
|
|
@ -0,0 +1,185 @@
|
|||
/*
|
||||
* Licensed to Elasticsearch under one or more contributor
|
||||
* license agreements. See the NOTICE file distributed with
|
||||
* this work for additional information regarding copyright
|
||||
* ownership. Elasticsearch 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 org.elasticsearch.transport;
|
||||
|
||||
import io.netty.bootstrap.Bootstrap;
|
||||
import io.netty.bootstrap.ServerBootstrap;
|
||||
import io.netty.buffer.ByteBuf;
|
||||
import io.netty.buffer.Unpooled;
|
||||
import io.netty.buffer.UnpooledByteBufAllocator;
|
||||
import io.netty.channel.Channel;
|
||||
import io.netty.channel.ChannelFuture;
|
||||
import io.netty.channel.ChannelHandlerContext;
|
||||
import io.netty.channel.ChannelInitializer;
|
||||
import io.netty.channel.ChannelOption;
|
||||
import io.netty.channel.SimpleChannelInboundHandler;
|
||||
import io.netty.channel.nio.NioEventLoopGroup;
|
||||
import org.elasticsearch.common.SuppressForbidden;
|
||||
import org.elasticsearch.test.ESTestCase;
|
||||
|
||||
import java.io.IOException;
|
||||
import java.net.InetAddress;
|
||||
import java.net.InetSocketAddress;
|
||||
import java.nio.ByteBuffer;
|
||||
import java.nio.channels.SocketChannel;
|
||||
import java.nio.charset.StandardCharsets;
|
||||
import java.util.concurrent.ConcurrentLinkedQueue;
|
||||
import java.util.concurrent.TimeUnit;
|
||||
import java.util.concurrent.atomic.AtomicInteger;
|
||||
import java.util.concurrent.atomic.AtomicReference;
|
||||
|
||||
public class CopyBytesSocketChannelTests extends ESTestCase {
|
||||
|
||||
private final UnpooledByteBufAllocator alloc = new UnpooledByteBufAllocator(false);
|
||||
private final AtomicReference<CopyBytesSocketChannel> accepted = new AtomicReference<>();
|
||||
private final AtomicInteger serverBytesReceived = new AtomicInteger();
|
||||
private final AtomicInteger clientBytesReceived = new AtomicInteger();
|
||||
private final ConcurrentLinkedQueue<ByteBuf> serverReceived = new ConcurrentLinkedQueue<>();
|
||||
private final ConcurrentLinkedQueue<ByteBuf> clientReceived = new ConcurrentLinkedQueue<>();
|
||||
private NioEventLoopGroup eventLoopGroup;
|
||||
private InetSocketAddress serverAddress;
|
||||
private Channel serverChannel;
|
||||
|
||||
@Override
|
||||
@SuppressForbidden(reason = "calls getLocalHost")
|
||||
public void setUp() throws Exception {
|
||||
super.setUp();
|
||||
eventLoopGroup = new NioEventLoopGroup(1);
|
||||
ServerBootstrap serverBootstrap = new ServerBootstrap();
|
||||
serverBootstrap.channel(CopyBytesServerSocketChannel.class);
|
||||
serverBootstrap.group(eventLoopGroup);
|
||||
serverBootstrap.option(ChannelOption.ALLOCATOR, alloc);
|
||||
serverBootstrap.childOption(ChannelOption.ALLOCATOR, alloc);
|
||||
serverBootstrap.childHandler(new ChannelInitializer<Channel>() {
|
||||
@Override
|
||||
protected void initChannel(Channel ch) {
|
||||
accepted.set((CopyBytesSocketChannel) ch);
|
||||
ch.pipeline().addLast(new SimpleChannelInboundHandler<Object>() {
|
||||
@Override
|
||||
protected void channelRead0(ChannelHandlerContext ctx, Object msg) {
|
||||
ByteBuf buffer = (ByteBuf) msg;
|
||||
serverBytesReceived.addAndGet(buffer.readableBytes());
|
||||
serverReceived.add(buffer.retain());
|
||||
}
|
||||
});
|
||||
}
|
||||
});
|
||||
|
||||
ChannelFuture bindFuture = serverBootstrap.bind(new InetSocketAddress(InetAddress.getLocalHost(), 0));
|
||||
assertTrue(bindFuture.await(10, TimeUnit.SECONDS));
|
||||
serverAddress = (InetSocketAddress) bindFuture.channel().localAddress();
|
||||
bindFuture.isSuccess();
|
||||
serverChannel = bindFuture.channel();
|
||||
}
|
||||
|
||||
@Override
|
||||
public void tearDown() throws Exception {
|
||||
super.tearDown();
|
||||
try {
|
||||
assertTrue(serverChannel.close().await(10, TimeUnit.SECONDS));
|
||||
} finally {
|
||||
eventLoopGroup.shutdownGracefully().await(10, TimeUnit.SECONDS);
|
||||
}
|
||||
}
|
||||
|
||||
public void testSendAndReceive() throws Exception {
|
||||
final Bootstrap bootstrap = new Bootstrap();
|
||||
bootstrap.group(eventLoopGroup);
|
||||
bootstrap.channel(VerifyingCopyChannel.class);
|
||||
bootstrap.option(ChannelOption.ALLOCATOR, alloc);
|
||||
bootstrap.handler(new ChannelInitializer<Channel>() {
|
||||
@Override
|
||||
protected void initChannel(Channel ch) {
|
||||
ch.pipeline().addLast(new SimpleChannelInboundHandler<Object>() {
|
||||
@Override
|
||||
protected void channelRead0(ChannelHandlerContext ctx, Object msg) {
|
||||
ByteBuf buffer = (ByteBuf) msg;
|
||||
clientBytesReceived.addAndGet(buffer.readableBytes());
|
||||
clientReceived.add(buffer.retain());
|
||||
}
|
||||
});
|
||||
}
|
||||
});
|
||||
|
||||
ChannelFuture connectFuture = bootstrap.connect(serverAddress);
|
||||
connectFuture.await(10, TimeUnit.SECONDS);
|
||||
assertTrue(connectFuture.isSuccess());
|
||||
CopyBytesSocketChannel copyChannel = (CopyBytesSocketChannel) connectFuture.channel();
|
||||
ByteBuf clientData = generateData();
|
||||
ByteBuf serverData = generateData();
|
||||
|
||||
try {
|
||||
assertBusy(() -> assertNotNull(accepted.get()));
|
||||
int clientBytesToWrite = clientData.readableBytes();
|
||||
ChannelFuture clientWriteFuture = copyChannel.writeAndFlush(clientData.retainedSlice());
|
||||
clientWriteFuture.await(10, TimeUnit.SECONDS);
|
||||
assertBusy(() -> assertEquals(clientBytesToWrite, serverBytesReceived.get()));
|
||||
|
||||
int serverBytesToWrite = serverData.readableBytes();
|
||||
ChannelFuture serverWriteFuture = accepted.get().writeAndFlush(serverData.retainedSlice());
|
||||
assertTrue(serverWriteFuture.await(10, TimeUnit.SECONDS));
|
||||
assertBusy(() -> assertEquals(serverBytesToWrite, clientBytesReceived.get()));
|
||||
|
||||
ByteBuf compositeServerReceived = Unpooled.wrappedBuffer(serverReceived.toArray(new ByteBuf[0]));
|
||||
assertEquals(clientData, compositeServerReceived);
|
||||
ByteBuf compositeClientReceived = Unpooled.wrappedBuffer(clientReceived.toArray(new ByteBuf[0]));
|
||||
assertEquals(serverData, compositeClientReceived);
|
||||
} finally {
|
||||
clientData.release();
|
||||
serverData.release();
|
||||
serverReceived.forEach(ByteBuf::release);
|
||||
clientReceived.forEach(ByteBuf::release);
|
||||
assertTrue(copyChannel.close().await(10, TimeUnit.SECONDS));
|
||||
}
|
||||
}
|
||||
|
||||
private ByteBuf generateData() {
|
||||
return Unpooled.wrappedBuffer(randomAlphaOfLength(randomIntBetween(1 << 22, 1 << 23)).getBytes(StandardCharsets.UTF_8));
|
||||
}
|
||||
|
||||
public static class VerifyingCopyChannel extends CopyBytesSocketChannel {
|
||||
|
||||
public VerifyingCopyChannel() {
|
||||
super();
|
||||
}
|
||||
|
||||
@Override
|
||||
protected int writeToSocketChannel(SocketChannel socketChannel, ByteBuffer ioBuffer) throws IOException {
|
||||
assertTrue("IO Buffer must be a direct byte buffer", ioBuffer.isDirect());
|
||||
int remaining = ioBuffer.remaining();
|
||||
int originalLimit = ioBuffer.limit();
|
||||
// If greater than a KB, possibly invoke a partial write.
|
||||
if (remaining > 1024) {
|
||||
if (randomBoolean()) {
|
||||
int bytes = randomIntBetween(remaining / 2, remaining);
|
||||
ioBuffer.limit(ioBuffer.position() + bytes);
|
||||
}
|
||||
}
|
||||
int written = socketChannel.write(ioBuffer);
|
||||
ioBuffer.limit(originalLimit);
|
||||
return written;
|
||||
}
|
||||
|
||||
@Override
|
||||
protected int readFromSocketChannel(SocketChannel socketChannel, ByteBuffer ioBuffer) throws IOException {
|
||||
assertTrue("IO Buffer must be a direct byte buffer", ioBuffer.isDirect());
|
||||
return socketChannel.read(ioBuffer);
|
||||
}
|
||||
}
|
||||
}
|
Loading…
Reference in New Issue