Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.codec | |
org.apache.hadoop.hbase.io | |
org.apache.hadoop.hbase.ipc |
Tools to help define network clients and servers.
|
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.wal | |
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.wal |
Modifier and Type | Method and Description |
---|---|
CellScanner |
CellScannable.cellScanner() |
static CellScanner |
CellUtil.createCellScanner(Cell[] cellArray) |
static CellScanner |
CellUtil.createCellScanner(Iterable<Cell> cellIterable) |
static CellScanner |
CellUtil.createCellScanner(Iterator<Cell> cells) |
static CellScanner |
CellUtil.createCellScanner(List<? extends CellScannable> cellScannerables) |
static CellScanner |
CellUtil.createCellScanner(NavigableMap<byte[],List<Cell>> map)
Flatten the map of cells out under the CellScanner
|
Modifier and Type | Class and Description |
---|---|
class |
Result
|
Modifier and Type | Method and Description |
---|---|
CellScanner |
Mutation.cellScanner() |
CellScanner |
Result.cellScanner() |
protected CellScanner |
RegionServerCallable.getRpcControllerCellScanner()
Get the RpcController CellScanner.
|
Modifier and Type | Method and Description |
---|---|
protected void |
RegionServerCallable.setRpcControllerCellScanner(CellScanner cellScanner) |
Modifier and Type | Interface and Description |
---|---|
static interface |
Codec.Decoder
Implementations should implicitly clean up any resources allocated when the
Decoder/CellScanner runs off the end of the cell block.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseDecoder
TODO javadoc
|
(package private) static class |
CellCodec.CellDecoder |
(package private) static class |
CellCodecWithTags.CellDecoder |
static class |
KeyValueCodec.ByteBuffKeyValueDecoder |
static class |
KeyValueCodec.KeyValueDecoder |
static class |
KeyValueCodecWithTags.ByteBuffKeyValueDecoder |
static class |
KeyValueCodecWithTags.KeyValueDecoder |
(package private) static class |
MessageCodec.MessageDecoder |
Modifier and Type | Interface and Description |
---|---|
interface |
SizedCellScanner
A CellScanner that knows its size in memory in bytes.
|
Modifier and Type | Field and Description |
---|---|
(package private) CellScanner |
Call.cells
Optionally has cells when making call.
|
private CellScanner |
HBaseRpcControllerImpl.cellScanner
They are optionally set on construction, cleared after we make the call, and then optionally
set on response with the result.
|
protected CellScanner |
ServerCall.cellScanner |
Modifier and Type | Method and Description |
---|---|
CellScanner |
HBaseRpcControllerImpl.cellScanner() |
CellScanner |
DelegatingHBaseRpcController.cellScanner() |
CellScanner |
CellBlockBuilder.createCellScanner(Codec codec,
org.apache.hadoop.io.compress.CompressionCodec compressor,
byte[] cellBlock) |
CellScanner |
CellBlockBuilder.createCellScannerReusingBuffers(Codec codec,
org.apache.hadoop.io.compress.CompressionCodec compressor,
ByteBuff cellBlock) |
CellScanner |
RpcCall.getCellScanner() |
CellScanner |
ServerCall.getCellScanner() |
Modifier and Type | Method and Description |
---|---|
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
SimpleRpcServer.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long receiveTime,
MonitoredRPCHandler status) |
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
NettyRpcServer.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long receiveTime,
MonitoredRPCHandler status) |
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
RpcServerInterface.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long receiveTime,
MonitoredRPCHandler status)
Deprecated.
As of release 1.3, this will be removed in HBase 3.0
|
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
SimpleRpcServer.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long receiveTime,
MonitoredRPCHandler status,
long startTime,
int timeout) |
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
NettyRpcServer.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long receiveTime,
MonitoredRPCHandler status,
long startTime,
int timeout) |
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
RpcServerInterface.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long receiveTime,
MonitoredRPCHandler status,
long startTime,
int timeout)
Deprecated.
As of release 2.0, this will be removed in HBase 3.0
|
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
RpcServerInterface.call(RpcCall call,
MonitoredRPCHandler status) |
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
RpcServer.call(RpcCall call,
MonitoredRPCHandler status)
This is a server side method, which is invoked over RPC.
|
Modifier and Type | Method and Description |
---|---|
ByteBuffer |
CellBlockBuilder.buildCellBlock(Codec codec,
org.apache.hadoop.io.compress.CompressionCodec compressor,
CellScanner cellScanner)
Puts CellScanner Cells into a cell block using passed in
codec and/or
compressor . |
org.apache.hbase.thirdparty.io.netty.buffer.ByteBuf |
CellBlockBuilder.buildCellBlock(Codec codec,
org.apache.hadoop.io.compress.CompressionCodec compressor,
CellScanner cellScanner,
org.apache.hbase.thirdparty.io.netty.buffer.ByteBufAllocator alloc) |
private boolean |
CellBlockBuilder.buildCellBlock(Codec codec,
org.apache.hadoop.io.compress.CompressionCodec compressor,
CellScanner cellScanner,
CellBlockBuilder.OutputStreamSupplier supplier) |
ByteBufferListOutputStream |
CellBlockBuilder.buildCellBlockStream(Codec codec,
org.apache.hadoop.io.compress.CompressionCodec compressor,
CellScanner cellScanner,
ByteBufferPool pool)
Puts CellScanner Cells into a cell block using passed in
codec and/or
compressor . |
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
SimpleRpcServer.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long receiveTime,
MonitoredRPCHandler status) |
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
NettyRpcServer.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long receiveTime,
MonitoredRPCHandler status) |
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
RpcServerInterface.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long receiveTime,
MonitoredRPCHandler status)
Deprecated.
As of release 1.3, this will be removed in HBase 3.0
|
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
SimpleRpcServer.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long receiveTime,
MonitoredRPCHandler status,
long startTime,
int timeout) |
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
NettyRpcServer.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long receiveTime,
MonitoredRPCHandler status,
long startTime,
int timeout) |
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
RpcServerInterface.call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long receiveTime,
MonitoredRPCHandler status,
long startTime,
int timeout)
Deprecated.
As of release 2.0, this will be removed in HBase 3.0
|
NettyServerCall |
NettyServerRpcConnection.createCall(int id,
org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long size,
InetAddress remoteAddress,
int timeout,
RpcServer.CallCleanup reqCleanup) |
SimpleServerCall |
SimpleServerRpcConnection.createCall(int id,
org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long size,
InetAddress remoteAddress,
int timeout,
RpcServer.CallCleanup reqCleanup) |
abstract ServerCall<?> |
ServerRpcConnection.createCall(int id,
org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long size,
InetAddress remoteAddress,
int timeout,
RpcServer.CallCleanup reqCleanup) |
private void |
CellBlockBuilder.encodeCellsTo(OutputStream os,
CellScanner cellScanner,
Codec codec,
org.apache.hadoop.io.compress.CompressionCodec compressor) |
HBaseRpcController |
RpcControllerFactory.newController(CellScanner cellScanner) |
void |
HBaseRpcControllerImpl.setCellScanner(CellScanner cellScanner) |
void |
DelegatingHBaseRpcController.setCellScanner(CellScanner cellScanner) |
void |
HBaseRpcController.setCellScanner(CellScanner cellScanner)
Only used to send cells to rpc server, the returned cells should be set by
HBaseRpcController.setDone(CellScanner) . |
void |
HBaseRpcControllerImpl.setDone(CellScanner cellScanner) |
void |
DelegatingHBaseRpcController.setDone(CellScanner cellScanner) |
void |
HBaseRpcController.setDone(CellScanner cellScanner)
IMPORTANT: always call this method if the call finished without any exception to tell
the
HBaseRpcController that we are done. |
void |
Call.setResponse(org.apache.hbase.thirdparty.com.google.protobuf.Message response,
CellScanner cells)
Set the return value when there is no error.
|
void |
RpcCall.setResponse(org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cells,
Throwable errorThrowable,
String error)
Set the response resulting from this RPC call.
|
void |
ServerCall.setResponse(org.apache.hbase.thirdparty.com.google.protobuf.Message m,
CellScanner cells,
Throwable t,
String errorMsg) |
Constructor and Description |
---|
Call(int id,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cells,
org.apache.hbase.thirdparty.com.google.protobuf.Message responseDefaultType,
int timeout,
int priority,
org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<Call> callback,
MetricsConnection.CallStats callStats) |
HBaseRpcControllerImpl(CellScanner cellScanner) |
NettyServerCall(int id,
org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
NettyServerRpcConnection connection,
long size,
InetAddress remoteAddress,
long receiveTime,
int timeout,
ByteBufferPool reservoir,
CellBlockBuilder cellBlockBuilder,
RpcServer.CallCleanup reqCleanup) |
ServerCall(int id,
org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
T connection,
long size,
InetAddress remoteAddress,
long receiveTime,
int timeout,
ByteBufferPool reservoir,
CellBlockBuilder cellBlockBuilder,
RpcServer.CallCleanup reqCleanup) |
SimpleServerCall(int id,
org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
SimpleServerRpcConnection connection,
long size,
InetAddress remoteAddress,
long receiveTime,
int timeout,
ByteBufferPool reservoir,
CellBlockBuilder cellBlockBuilder,
RpcServer.CallCleanup reqCleanup,
SimpleRpcServerResponder responder) |
Modifier and Type | Method and Description |
---|---|
private Result |
RSRpcServices.append(HRegion region,
OperationQuota quota,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation,
CellScanner cellScanner,
long nonceGroup,
ActivePolicyEnforcement spaceQuota)
Execute an append mutation.
|
private boolean |
RSRpcServices.checkAndRowMutate(HRegion region,
List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> actions,
CellScanner cellScanner,
byte[] row,
byte[] family,
byte[] qualifier,
CompareOperator op,
ByteArrayComparable comparator,
TimeRange timeRange,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionActionResult.Builder builder,
ActivePolicyEnforcement spaceQuotaEnforcement)
Mutate a list of rows atomically.
|
private void |
RSRpcServices.doAtomicBatchOp(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionActionResult.Builder builder,
HRegion region,
OperationQuota quota,
List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> mutations,
CellScanner cells,
ActivePolicyEnforcement spaceQuotaEnforcement) |
private void |
RSRpcServices.doBatchOp(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionActionResult.Builder builder,
HRegion region,
OperationQuota quota,
List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> mutations,
CellScanner cells,
ActivePolicyEnforcement spaceQuotaEnforcement,
boolean atomic)
Execute a list of Put/Delete mutations.
|
private void |
RSRpcServices.doNonAtomicBatchOp(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionActionResult.Builder builder,
HRegion region,
OperationQuota quota,
List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> mutations,
CellScanner cells,
ActivePolicyEnforcement spaceQuotaEnforcement) |
private List<CellScannable> |
RSRpcServices.doNonAtomicRegionMutation(HRegion region,
OperationQuota quota,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionAction actions,
CellScanner cellScanner,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionActionResult.Builder builder,
List<CellScannable> cellsToReturn,
long nonceGroup,
RSRpcServices.RegionScannersCloseCallBack closeCallBack,
RpcCallContext context,
ActivePolicyEnforcement spaceQuotaEnforcement)
Run through the regionMutation
rm and per Mutation, do the work, and then when
done, add an instance of a ClientProtos.ResultOrException that corresponds to each Mutation. |
private Result |
RSRpcServices.increment(HRegion region,
OperationQuota quota,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation,
CellScanner cells,
long nonceGroup,
ActivePolicyEnforcement spaceQuota)
Execute an increment mutation.
|
void |
ReplicationSinkService.replicateLogEntries(List<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry> entries,
CellScanner cells,
String replicationClusterId,
String sourceBaseNamespaceDirPath,
String sourceHFileArchiveDirPath)
Carry on the list of log entries down to the sink
|
private void |
RSRpcServices.skipCellsForMutation(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action action,
CellScanner cellScanner) |
private void |
RSRpcServices.skipCellsForMutations(List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> actions,
CellScanner cellScanner) |
Modifier and Type | Class and Description |
---|---|
(package private) static class |
SecureWALCellCodec.EncryptedKvDecoder |
(package private) static class |
WALCellCodec.CompressedKvDecoder |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationSink.replicateEntries(List<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry> entries,
CellScanner cells,
String replicationClusterId,
String sourceBaseNamespaceDirPath,
String sourceHFileArchiveDirPath)
Replicate this array of entries directly into the local cluster using the native client.
|
void |
Replication.replicateLogEntries(List<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry> entries,
CellScanner cells,
String replicationClusterId,
String sourceBaseNamespaceDirPath,
String sourceHFileArchiveDirPath)
Carry on the list of log entries down to the sink
|
Modifier and Type | Method and Description |
---|---|
static List<WALSplitUtil.MutationReplay> |
WALSplitUtil.getMutationsFromWALEntry(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry entry,
CellScanner cells,
Pair<WALKey,WALEdit> logEntry,
Durability durability)
This function is used to construct mutations from a WALEntry.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.