Uses of Interface
org.apache.hadoop.hbase.ExtendedCellScanner
Package
Description
Provides HBase Client
Tools to help define network clients and servers.
Multi Cluster Replication
-
Uses of ExtendedCellScanner in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionExtendedCellScannable.cellScanner()
static ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(Iterable<ExtendedCell> cellIterable) Returns ExtendedCellScanner interface overcellIterable
static ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(Iterator<ExtendedCell> cells) Returns ExtendedCellScanner interface overcellIterable
or null ifcells
is nullstatic ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(List<? extends ExtendedCellScannable> cellScannerables) Returns ExtendedCellScanner interface overcellIterables
static ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(NavigableMap<byte[], List<ExtendedCell>> map) Flatten the map of cells out under the ExtendedCellScannerstatic ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(ExtendedCell[] cellArray) Returns CellScanner interface overcellArray
-
Uses of ExtendedCellScanner in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptionMutation.cellScanner()
For client users: You should only use the return value as aCellScanner
,ExtendedCellScanner
is marked as IA.Private which means there is no guarantee about its API stability.Result.cellScanner()
For client users: You should only use the return value as aCellScanner
,ExtendedCellScanner
is marked as IA.Private which means there is no guarantee about its API stability.Modifier and TypeMethodDescriptionprivate <RESP> CompletableFuture<RESP>
AsyncRegionServerAdmin.call
(AsyncRegionServerAdmin.RpcCall<RESP> rpcCall, ExtendedCellScanner cellScanner) CompletableFuture<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse>
AsyncRegionServerAdmin.replay
(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request, ExtendedCellScanner cellScanner) CompletableFuture<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse>
AsyncRegionServerAdmin.replicateWALEntry
(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request, ExtendedCellScanner cellScanner, int timeout) -
Uses of ExtendedCellScanner 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
Base implementation forCodec.Decoder
.(package private) static class
(package private) static class
static class
static class
static class
static class
(package private) static class
-
Uses of ExtendedCellScanner in org.apache.hadoop.hbase.io
Modifier and TypeInterfaceDescriptioninterface
A CellScanner that knows its size in memory in bytes. -
Uses of ExtendedCellScanner in org.apache.hadoop.hbase.ipc
Modifier and TypeFieldDescription(package private) ExtendedCellScanner
Call.cells
Optionally has cells when making call.private ExtendedCellScanner
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 ExtendedCellScanner
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,
ExtendedCellScanner> 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,
ExtendedCellScanner> RpcServerInterface.call
(RpcCall call, MonitoredRPCHandler status) Modifier and TypeMethodDescriptionCellBlockBuilder.buildCellBlock
(Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor, ExtendedCellScanner 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, ExtendedCellScanner cellScanner, CellBlockBuilder.OutputStreamSupplier supplier) org.apache.hbase.thirdparty.io.netty.buffer.ByteBuf
CellBlockBuilder.buildCellBlock
(Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor, ExtendedCellScanner cellScanner, org.apache.hbase.thirdparty.io.netty.buffer.ByteBufAllocator alloc) CellBlockBuilder.buildCellBlockStream
(Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor, ExtendedCellScanner cellScanner, ByteBuffAllocator allocator) Puts CellScanner Cells into a cell block using passed incodec
and/orcompressor
.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, ExtendedCellScanner 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, ExtendedCellScanner 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, ExtendedCellScanner cellScanner, long size, InetAddress remoteAddress, int timeout, RpcServer.CallCleanup reqCleanup) Deprecated.private void
CellBlockBuilder.encodeCellsTo
(OutputStream os, ExtendedCellScanner cellScanner, Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor) RpcControllerFactory.newController
(RegionInfo regionInfo, ExtendedCellScanner cellScanner) RpcControllerFactory.newController
(ExtendedCellScanner cellScanner) void
DelegatingHBaseRpcController.setCellScanner
(ExtendedCellScanner cellScanner) void
HBaseRpcController.setCellScanner
(ExtendedCellScanner cellScanner) Only used to send cells to rpc server, the returned cells should be set byHBaseRpcController.setDone(ExtendedCellScanner)
.void
HBaseRpcControllerImpl.setCellScanner
(ExtendedCellScanner cellScanner) void
DelegatingHBaseRpcController.setDone
(ExtendedCellScanner cellScanner) void
HBaseRpcController.setDone
(ExtendedCellScanner cellScanner) IMPORTANT: always call this method if the call finished without any exception to tell theHBaseRpcController
that we are done.void
HBaseRpcControllerImpl.setDone
(ExtendedCellScanner cellScanner) void
Call.setResponse
(org.apache.hbase.thirdparty.com.google.protobuf.Message response, ExtendedCellScanner cells) Set the return value when there is no error.void
RpcCall.setResponse
(org.apache.hbase.thirdparty.com.google.protobuf.Message param, ExtendedCellScanner 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, ExtendedCellScanner 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, ExtendedCellScanner 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) (package private)
HBaseRpcControllerImpl
(RegionInfo regionInfo, ExtendedCellScanner cellScanner) HBaseRpcControllerImpl
(ExtendedCellScanner cellScanner) Used server-side.(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, ExtendedCellScanner 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, ExtendedCellScanner 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, ExtendedCellScanner cellScanner, SimpleServerRpcConnection connection, long size, InetAddress remoteAddress, long receiveTime, int timeout, ByteBuffAllocator bbAllocator, CellBlockBuilder cellBlockBuilder, RpcServer.CallCleanup reqCleanup, SimpleRpcServerResponder responder) Deprecated. -
Uses of ExtendedCellScanner in org.apache.hadoop.hbase.regionserver
Modifier and TypeMethodDescriptionprivate ExtendedCellScanner
RSRpcServices.getAndReset
(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller) Modifier and TypeMethodDescriptionvoid
ReplicationSinkService.replicateLogEntries
(List<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry> entries, ExtendedCellScanner cells, String replicationClusterId, String sourceBaseNamespaceDirPath, String sourceHFileArchiveDirPath) Carry on the list of log entries down to the sink -
Uses of ExtendedCellScanner in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeClassDescription(package private) static class
(package private) static class
-
Uses of ExtendedCellScanner in org.apache.hadoop.hbase.replication
Modifier and TypeMethodDescriptionvoid
ReplicationSinkServiceImpl.replicateLogEntries
(List<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry> entries, ExtendedCellScanner cells, String replicationClusterId, String sourceBaseNamespaceDirPath, String sourceHFileArchiveDirPath) -
Uses of ExtendedCellScanner in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeMethodDescriptionvoid
ReplicationSink.replicateEntries
(List<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry> entries, ExtendedCellScanner cells, String replicationClusterId, String sourceBaseNamespaceDirPath, String sourceHFileArchiveDirPath) Replicate this array of entries directly into the local cluster using the native client. -
Uses of ExtendedCellScanner in org.apache.hadoop.hbase.wal
Modifier and TypeMethodDescriptionstatic List<WALSplitUtil.MutationReplay>
WALSplitUtil.getMutationsFromWALEntry
(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry entry, ExtendedCellScanner cells, Pair<WALKey, WALEdit> logEntry, Durability durability) Deprecated.Since 3.0.0, will be removed in 4.0.0.