Uses of Interface
org.apache.hadoop.hbase.CellScanner
Package
Description
Provides HBase Client
Tools to help define network clients and servers.
Multi Cluster Replication
-
Uses of CellScanner in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionCellScannable.cellScanner()
Returns A CellScanner over the containedCell
sstatic CellScanner
CellUtil.createCellScanner
(Iterable<Cell> cellIterable) Returns CellScanner interface overcellIterable
static CellScanner
CellUtil.createCellScanner
(Iterator<Cell> cells) Returns CellScanner interface overcellIterable
or null ifcells
is nullstatic CellScanner
CellUtil.createCellScanner
(List<? extends CellScannable> cellScannerables) Returns CellScanner interface overcellIterables
static CellScanner
CellUtil.createCellScanner
(NavigableMap<byte[], List<Cell>> map) Flatten the map of cells out under the CellScannerstatic CellScanner
CellUtil.createCellScanner
(Cell[] cellArray) Returns CellScanner interface overcellArray
-
Uses of CellScanner in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptionMutation.cellScanner()
Result.cellScanner()
protected CellScanner
RegionServerCallable.getRpcControllerCellScanner()
Get the RpcController CellScanner.Modifier and TypeMethodDescriptionprotected void
RegionServerCallable.setRpcControllerCellScanner
(CellScanner cellScanner) -
Uses of CellScanner in org.apache.hadoop.hbase.codec
Modifier and TypeInterfaceDescriptionstatic interface
Implementations should implicitly clean up any resources allocated when the Decoder/CellScanner runs off the end of the cell block.Modifier and TypeClassDescriptionclass
TODO javadoc(package private) static class
(package private) static class
static class
static class
static class
static class
(package private) static class
-
Uses of CellScanner in org.apache.hadoop.hbase.io
Modifier and TypeInterfaceDescriptioninterface
A CellScanner that knows its size in memory in bytes. -
Uses of CellScanner in org.apache.hadoop.hbase.ipc
Modifier and TypeFieldDescription(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 final CellScanner
ServerCall.cellScanner
Modifier and TypeMethodDescriptionDelegatingHBaseRpcController.cellScanner()
HBaseRpcControllerImpl.cellScanner()
Returns One-shot cell scanner (you cannot back it up and restart)CellBlockBuilder.createCellScanner
(Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor, byte[] cellBlock) Create a cell scanner.CellBlockBuilder.createCellScannerReusingBuffers
(Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor, ByteBuff cellBlock) Create a cell scanner using an existing bytebuff.RpcCall.getCellScanner()
Returns The CellScanner that can carry input and result payload.ServerCall.getCellScanner()
Modifier and TypeMethodDescriptionPair<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> 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> RpcServer.call
(RpcCall call, MonitoredRPCHandler status) This is a server side method, which is invoked over RPC.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> 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.0Pair<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.0Pair<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) Deprecated.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) Deprecated.Modifier and TypeMethodDescriptionCellBlockBuilder.buildCellBlock
(Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor, CellScanner cellScanner) Puts CellScanner Cells into a cell block using passed incodec
and/orcompressor
.private boolean
CellBlockBuilder.buildCellBlock
(Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor, CellScanner cellScanner, CellBlockBuilder.OutputStreamSupplier supplier) 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) CellBlockBuilder.buildCellBlockStream
(Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor, CellScanner cellScanner, ByteBuffAllocator allocator) Puts CellScanner Cells into a cell block using passed incodec
and/orcompressor
.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> 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) Deprecated.As of release 1.3, this will be removed in HBase 3.0Pair<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.0Pair<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) Deprecated.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) Deprecated.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) 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) 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) Deprecated.private void
CellBlockBuilder.encodeCellsTo
(OutputStream os, CellScanner cellScanner, Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor) RpcControllerFactory.newController
(CellScanner cellScanner) RpcControllerFactory.newController
(RegionInfo regionInfo, 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 byHBaseRpcController.setDone(CellScanner)
.void
HBaseRpcControllerImpl.setCellScanner
(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 theHBaseRpcController
that we are done.void
HBaseRpcControllerImpl.setDone
(CellScanner cellScanner) 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) ModifierConstructorDescription(package private)
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, Map<String, byte[]> attributes, org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<Call> callback, MetricsConnection.CallStats callStats) HBaseRpcControllerImpl
(CellScanner cellScanner) Used server-side.(package private)
HBaseRpcControllerImpl
(RegionInfo regionInfo, CellScanner cellScanner) (package private)
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, ByteBuffAllocator bbAllocator, CellBlockBuilder cellBlockBuilder, RpcServer.CallCleanup reqCleanup) (package private)
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, ByteBuffAllocator byteBuffAllocator, CellBlockBuilder cellBlockBuilder, RpcServer.CallCleanup reqCleanup) (package private)
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, ByteBuffAllocator bbAllocator, CellBlockBuilder cellBlockBuilder, RpcServer.CallCleanup reqCleanup, SimpleRpcServerResponder responder) Deprecated. -
Uses of CellScanner in org.apache.hadoop.hbase.regionserver
Modifier and TypeMethodDescriptionprivate Result
RSRpcServices.append
(HRegion region, OperationQuota quota, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation, CellScanner cellScanner, long nonceGroup, ActivePolicyEnforcement spaceQuota, RpcCallContext context) Execute an append mutation.private CheckAndMutateResult
RSRpcServices.checkAndMutate
(HRegion region, List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> actions, CellScanner cellScanner, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Condition condition, long nonceGroup, ActivePolicyEnforcement spaceQuotaEnforcement) private CheckAndMutateResult
RSRpcServices.checkAndMutate
(HRegion region, OperationQuota quota, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation, CellScanner cellScanner, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Condition condition, long nonceGroup, ActivePolicyEnforcement spaceQuota, RpcCallContext context) private void
RSRpcServices.delete
(HRegion region, OperationQuota quota, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation, CellScanner cellScanner, ActivePolicyEnforcement spaceQuota) 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, long nonceGroup, 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, long nonceGroup, ActivePolicyEnforcement spaceQuotaEnforcement, boolean atomic) Execute a list of 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 regionMutationrm
and per Mutation, do the work, and then when done, add an instance of aClientProtos.ResultOrException
that corresponds to each Mutation.private void
RSRpcServices.failRegionAction
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiResponse.Builder responseBuilder, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionActionResult.Builder regionActionResultBuilder, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.RegionAction regionAction, CellScanner cellScanner, Throwable error) private Result
RSRpcServices.increment
(HRegion region, OperationQuota quota, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation, CellScanner cells, long nonceGroup, ActivePolicyEnforcement spaceQuota, RpcCallContext context) Execute an increment mutation.private void
RSRpcServices.put
(HRegion region, OperationQuota quota, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation, CellScanner cellScanner, ActivePolicyEnforcement spaceQuota) 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 sinkprivate 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) -
Uses of CellScanner in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeClassDescription(package private) static class
(package private) static class
-
Uses of CellScanner in org.apache.hadoop.hbase.replication
Modifier and TypeMethodDescriptionvoid
ReplicationSinkServiceImpl.replicateLogEntries
(List<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry> entries, CellScanner cells, String replicationClusterId, String sourceBaseNamespaceDirPath, String sourceHFileArchiveDirPath) -
Uses of CellScanner in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeMethodDescriptionvoid
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 -
Uses of CellScanner in org.apache.hadoop.hbase.wal
Modifier and TypeMethodDescriptionstatic 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.