Modifier and Type | Field and Description |
---|---|
private static org.apache.hbase.thirdparty.io.netty.util.concurrent.FastThreadLocal<org.apache.commons.lang3.mutable.MutableInt> |
DEPTH |
(package private) static int |
MAX_DEPTH |
Constructor and Description |
---|
IPCUtil() |
Modifier and Type | Method and Description |
---|---|
(package private) static org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader |
buildRequestHeader(Call call,
org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.CellBlockMeta cellBlockMeta) |
(package private) static org.apache.hadoop.ipc.RemoteException |
createRemoteException(org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.ExceptionResponse e) |
(package private) static void |
execute(org.apache.hbase.thirdparty.io.netty.channel.EventLoop eventLoop,
Runnable action) |
private static String |
getCallTarget(Address addr,
RegionInfo regionInfo) |
static int |
getTotalSizeWhenWrittenDelimited(org.apache.hbase.thirdparty.com.google.protobuf.Message... messages)
Returns Size on the wire when the two messages are written with writeDelimitedTo
|
(package private) static boolean |
isFatalConnectionException(org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.ExceptionResponse e)
Returns True if the exception is a fatal connection exception.
|
(package private) static void |
setCancelled(Call call) |
(package private) static IOException |
toIOE(Throwable t) |
(package private) static IOException |
wrapException(Address addr,
RegionInfo regionInfo,
Throwable error)
Takes an Exception, the address, and if pertinent, the RegionInfo for the Region we were trying
to connect to and returns an IOException with the input exception as the cause.
|
static int |
write(OutputStream dos,
org.apache.hbase.thirdparty.com.google.protobuf.Message header,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
org.apache.hbase.thirdparty.io.netty.buffer.ByteBuf cellBlock)
Write out header, param, and cell block if there is one.
|
private static int |
write(OutputStream dos,
org.apache.hbase.thirdparty.com.google.protobuf.Message header,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
org.apache.hbase.thirdparty.io.netty.buffer.ByteBuf cellBlock,
int totalSize) |
private static final org.apache.hbase.thirdparty.io.netty.util.concurrent.FastThreadLocal<org.apache.commons.lang3.mutable.MutableInt> DEPTH
static final int MAX_DEPTH
IPCUtil()
public static int write(OutputStream dos, org.apache.hbase.thirdparty.com.google.protobuf.Message header, org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hbase.thirdparty.io.netty.buffer.ByteBuf cellBlock) throws IOException
dos
- Stream to write intoheader
- to writeparam
- to writecellBlock
- to writeIOException
- if write action failsprivate static int write(OutputStream dos, org.apache.hbase.thirdparty.com.google.protobuf.Message header, org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hbase.thirdparty.io.netty.buffer.ByteBuf cellBlock, int totalSize) throws IOException
IOException
public static int getTotalSizeWhenWrittenDelimited(org.apache.hbase.thirdparty.com.google.protobuf.Message... messages)
static org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader buildRequestHeader(Call call, org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.CellBlockMeta cellBlockMeta)
static org.apache.hadoop.ipc.RemoteException createRemoteException(org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.ExceptionResponse e)
e
- exception to be wrappede
static boolean isFatalConnectionException(org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.ExceptionResponse e)
static IOException toIOE(Throwable t)
private static String getCallTarget(Address addr, RegionInfo regionInfo)
static IOException wrapException(Address addr, RegionInfo regionInfo, Throwable error)
error
is not an IOException
, an IOException
will be
created.addr
- target addresserror
- the relevant exceptionClientExceptionsUtil.isConnectionException(Throwable)
static void setCancelled(Call call)
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.