public abstract class AbstractTestIPC extends Object
| Modifier and Type | Field and Description |
|---|---|
private static org.apache.hadoop.hbase.KeyValue |
CELL |
private static byte[] |
CELL_BYTES |
protected static org.apache.hadoop.conf.Configuration |
CONF |
private static org.slf4j.Logger |
LOG |
io.opentelemetry.sdk.testing.junit4.OpenTelemetryRule |
traceRule |
| Constructor and Description |
|---|
AbstractTestIPC() |
| Modifier and Type | Method and Description |
|---|---|
private void |
assertRemoteSpan() |
private static org.hamcrest.Matcher<io.opentelemetry.sdk.trace.data.SpanData> |
buildIpcClientSpanAttributesMatcher(String packageAndService,
String methodName,
InetSocketAddress isa) |
private static org.hamcrest.Matcher<io.opentelemetry.sdk.trace.data.SpanData> |
buildIpcClientSpanMatcher(String packageAndService,
String methodName) |
private static org.hamcrest.Matcher<io.opentelemetry.sdk.trace.data.SpanData> |
buildIpcServerSpanAttributesMatcher(String packageAndService,
String methodName) |
private static org.hamcrest.Matcher<io.opentelemetry.sdk.trace.data.SpanData> |
buildIpcServerSpanMatcher(String packageAndService,
String methodName) |
private static String |
buildIpcSpanName(String packageAndService,
String methodName) |
protected abstract org.apache.hadoop.hbase.ipc.AbstractRpcClient<?> |
createRpcClient(org.apache.hadoop.conf.Configuration conf) |
protected abstract org.apache.hadoop.hbase.ipc.AbstractRpcClient<?> |
createRpcClientNoCodec(org.apache.hadoop.conf.Configuration conf) |
protected abstract org.apache.hadoop.hbase.ipc.AbstractRpcClient<?> |
createRpcClientRTEDuringConnectionSetup(org.apache.hadoop.conf.Configuration conf) |
protected abstract org.apache.hadoop.hbase.ipc.RpcServer |
createRpcServer(org.apache.hadoop.hbase.Server server,
String name,
List<org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface> services,
InetSocketAddress bindAddress,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.hbase.ipc.RpcScheduler scheduler) |
protected abstract org.apache.hadoop.hbase.ipc.RpcServer |
createTestFailingRpcServer(org.apache.hadoop.hbase.Server server,
String name,
List<org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface> services,
InetSocketAddress bindAddress,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.hbase.ipc.RpcScheduler scheduler) |
void |
testAsyncEcho() |
void |
testAsyncRemoteError() |
void |
testAsyncTimeout() |
void |
testCompressCellBlock()
It is hard to verify the compression is actually happening under the wraps.
|
void |
testConnectionCloseWithOutstandingRPCs()
Tests that the connection closing is handled by the client with outstanding RPC calls
|
void |
testNoCodec()
Ensure we do not HAVE TO HAVE a codec.
|
void |
testRemoteError() |
void |
testRpcMaxRequestSize()
Tests that the rpc scheduler is called when requests arrive.
|
void |
testRpcScheduler()
Tests that the rpc scheduler is called when requests arrive.
|
void |
testRpcServerForNotNullRemoteAddressInCallObject()
Tests that the RpcServer creates & dispatches CallRunner object to scheduler with non-null
remoteAddress set to its Call Object
|
void |
testRTEDuringConnectionSetup() |
void |
testTimeout() |
void |
testTracingErrorIpc() |
void |
testTracingSuccessIpc() |
private io.opentelemetry.sdk.trace.data.SpanData |
waitSpan(org.hamcrest.Matcher<io.opentelemetry.sdk.trace.data.SpanData> matcher) |
private static final org.slf4j.Logger LOG
private static final byte[] CELL_BYTES
private static final org.apache.hadoop.hbase.KeyValue CELL
protected static final org.apache.hadoop.conf.Configuration CONF
public io.opentelemetry.sdk.testing.junit4.OpenTelemetryRule traceRule
public AbstractTestIPC()
protected abstract org.apache.hadoop.hbase.ipc.RpcServer createRpcServer(org.apache.hadoop.hbase.Server server, String name, List<org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.RpcScheduler scheduler) throws IOException
IOExceptionprotected abstract org.apache.hadoop.hbase.ipc.AbstractRpcClient<?> createRpcClientNoCodec(org.apache.hadoop.conf.Configuration conf)
public void testNoCodec() throws IOException, org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
IOExceptionorg.apache.hbase.thirdparty.com.google.protobuf.ServiceExceptionprotected abstract org.apache.hadoop.hbase.ipc.AbstractRpcClient<?> createRpcClient(org.apache.hadoop.conf.Configuration conf)
public void testCompressCellBlock() throws IOException, org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
IOExceptionorg.apache.hbase.thirdparty.com.google.protobuf.ServiceExceptionprotected abstract org.apache.hadoop.hbase.ipc.AbstractRpcClient<?> createRpcClientRTEDuringConnectionSetup(org.apache.hadoop.conf.Configuration conf) throws IOException
IOExceptionpublic void testRTEDuringConnectionSetup() throws Exception
Exceptionpublic void testRpcScheduler() throws IOException, org.apache.hbase.thirdparty.com.google.protobuf.ServiceException, InterruptedException
IOExceptionorg.apache.hbase.thirdparty.com.google.protobuf.ServiceExceptionInterruptedExceptionpublic void testRpcMaxRequestSize() throws IOException, org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
IOExceptionorg.apache.hbase.thirdparty.com.google.protobuf.ServiceExceptionpublic void testRpcServerForNotNullRemoteAddressInCallObject() throws IOException, org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
IOExceptionorg.apache.hbase.thirdparty.com.google.protobuf.ServiceExceptionpublic void testRemoteError() throws IOException, org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
IOExceptionorg.apache.hbase.thirdparty.com.google.protobuf.ServiceExceptionpublic void testTimeout() throws IOException
IOExceptionprotected abstract org.apache.hadoop.hbase.ipc.RpcServer createTestFailingRpcServer(org.apache.hadoop.hbase.Server server, String name, List<org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.RpcScheduler scheduler) throws IOException
IOExceptionpublic void testConnectionCloseWithOutstandingRPCs() throws InterruptedException, IOException
InterruptedExceptionIOExceptionpublic void testAsyncEcho() throws IOException
IOExceptionpublic void testAsyncRemoteError() throws IOException
IOExceptionpublic void testAsyncTimeout() throws IOException
IOExceptionprivate io.opentelemetry.sdk.trace.data.SpanData waitSpan(org.hamcrest.Matcher<io.opentelemetry.sdk.trace.data.SpanData> matcher)
private static String buildIpcSpanName(String packageAndService, String methodName)
private static org.hamcrest.Matcher<io.opentelemetry.sdk.trace.data.SpanData> buildIpcClientSpanMatcher(String packageAndService, String methodName)
private static org.hamcrest.Matcher<io.opentelemetry.sdk.trace.data.SpanData> buildIpcServerSpanMatcher(String packageAndService, String methodName)
private static org.hamcrest.Matcher<io.opentelemetry.sdk.trace.data.SpanData> buildIpcClientSpanAttributesMatcher(String packageAndService, String methodName, InetSocketAddress isa)
private static org.hamcrest.Matcher<io.opentelemetry.sdk.trace.data.SpanData> buildIpcServerSpanAttributesMatcher(String packageAndService, String methodName)
private void assertRemoteSpan()
public void testTracingSuccessIpc() throws IOException, org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
IOExceptionorg.apache.hbase.thirdparty.com.google.protobuf.ServiceExceptionpublic void testTracingErrorIpc() throws IOException
IOExceptionCopyright © 2007–2020 The Apache Software Foundation. All rights reserved.