@InterfaceAudience.Private public class FlushRegionCallable extends RegionAdminServiceCallable<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionResponse>
Modifier and Type | Field and Description |
---|---|
private static org.slf4j.Logger |
LOG |
private byte[] |
regionName |
private boolean |
reload |
private boolean |
writeFlushWalMarker |
connection, location, replicaId, row, rpcControllerFactory, stub, tableName
Constructor and Description |
---|
FlushRegionCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
RegionInfo regionInfo,
boolean writeFlushWalMarker) |
FlushRegionCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
byte[] regionName,
byte[] regionStartKey,
boolean writeFlushWalMarker) |
Modifier and Type | Method and Description |
---|---|
protected org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionResponse |
call(HBaseRpcController controller)
Run RPC call.
|
void |
prepare(boolean reload)
Prepare by setting up any connections to servers, etc., ahead of call invocation.
|
call, getConnection, getCurrentPayloadCarryingRpcController, getExceptionMessage, getExceptionMessageAdditionalDetail, getLocation, getRegionLocations, setStub, sleep, throwable
private static final org.slf4j.Logger LOG
private final byte[] regionName
private final boolean writeFlushWalMarker
private boolean reload
public FlushRegionCallable(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, TableName tableName, byte[] regionName, byte[] regionStartKey, boolean writeFlushWalMarker)
public FlushRegionCallable(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, RegionInfo regionInfo, boolean writeFlushWalMarker)
public void prepare(boolean reload) throws IOException
RetryingCallable
prepare
in interface RetryingCallable<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionResponse>
prepare
in class RegionAdminServiceCallable<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionResponse>
reload
- Set this to true if need to requery locationsIOException
- eprotected org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionResponse call(HBaseRpcController controller) throws Exception
RegionAdminServiceCallable
call
in class RegionAdminServiceCallable<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionResponse>
controller
- PayloadCarryingRpcController is a mouthful but it at a minimum is a
facade on protobuf so we don't have to put protobuf everywhere; we can keep it behind this
class.Exception
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.