Uses of Interface
org.apache.hadoop.hbase.ExtendedCellScanner
Packages that use org.apache.hadoop.hbase.ExtendedCellScanner
Package
Description
Provides HBase Client
Tools to help define network clients and servers.
Multi Cluster Replication
-
Uses of org.apache.hadoop.hbase.ExtendedCellScanner in org.apache.hadoop.hbase
Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.ExtendedCellScanner in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ExtendedCellScanner
ExtendedCellScannable.cellScanner()
static org.apache.hadoop.hbase.ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(Iterable<org.apache.hadoop.hbase.ExtendedCell> cellIterable) Returns ExtendedCellScanner interface overcellIterable
static org.apache.hadoop.hbase.ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(Iterator<org.apache.hadoop.hbase.ExtendedCell> cells) Returns ExtendedCellScanner interface overcellIterable
or null ifcells
is nullstatic org.apache.hadoop.hbase.ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(List<? extends org.apache.hadoop.hbase.ExtendedCellScannable> cellScannerables) Returns ExtendedCellScanner interface overcellIterables
static org.apache.hadoop.hbase.ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(NavigableMap<byte[], List<org.apache.hadoop.hbase.ExtendedCell>> map) Flatten the map of cells out under the ExtendedCellScannerstatic org.apache.hadoop.hbase.ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(org.apache.hadoop.hbase.ExtendedCell[] cellArray) Returns CellScanner interface overcellArray
-
Uses of org.apache.hadoop.hbase.ExtendedCellScanner in org.apache.hadoop.hbase.client
Classes in org.apache.hadoop.hbase.client that implement org.apache.hadoop.hbase.ExtendedCellScanner in inModifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.client.Result
Single row result of aGet
orScan
query.Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.ExtendedCellScanner in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ExtendedCellScanner
Mutation.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.org.apache.hadoop.hbase.ExtendedCellScanner
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.Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.ExtendedCellScanner in inModifier and TypeMethodDescriptionCompletableFuture<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse>
AsyncRegionServerAdmin.replay
(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request, org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) CompletableFuture<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse>
AsyncRegionServerAdmin.replicateWALEntry
(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request, org.apache.hadoop.hbase.ExtendedCellScanner cellScanner, int timeout) -
Uses of org.apache.hadoop.hbase.ExtendedCellScanner in org.apache.hadoop.hbase.codec
Subinterfaces of org.apache.hadoop.hbase.ExtendedCellScanner in in org.apache.hadoop.hbase.codecModifier and TypeInterfaceDescriptionstatic interface
org.apache.hadoop.hbase.codec.Codec.Decoder
Implementations should implicitly clean up any resources allocated when the Decoder/CellScanner runs off the end of the cell block.Classes in org.apache.hadoop.hbase.codec that implement org.apache.hadoop.hbase.ExtendedCellScanner in inModifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.codec.BaseDecoder
Base implementation forCodec.Decoder
.static class
org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder
static class
org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueDecoder
static class
org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.ByteBuffKeyValueDecoder
static class
org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueDecoder
-
Uses of org.apache.hadoop.hbase.ExtendedCellScanner in org.apache.hadoop.hbase.io
Subinterfaces of org.apache.hadoop.hbase.ExtendedCellScanner in in org.apache.hadoop.hbase.ioModifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.io.SizedExtendedCellScanner
A CellScanner that knows its size in memory in bytes. -
Uses of org.apache.hadoop.hbase.ExtendedCellScanner in org.apache.hadoop.hbase.ipc
Fields in org.apache.hadoop.hbase.ipc declared as org.apache.hadoop.hbase.ExtendedCellScanner in inModifier and TypeFieldDescriptionprotected final org.apache.hadoop.hbase.ExtendedCellScanner
ServerCall.cellScanner
Methods in org.apache.hadoop.hbase.ipc that return org.apache.hadoop.hbase.ExtendedCellScanner in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ExtendedCellScanner
DelegatingHBaseRpcController.cellScanner()
org.apache.hadoop.hbase.ExtendedCellScanner
HBaseRpcControllerImpl.cellScanner()
Returns One-shot cell scanner (you cannot back it up and restart)org.apache.hadoop.hbase.ExtendedCellScanner
RpcCall.getCellScanner()
Returns The CellScanner that can carry input and result payload.org.apache.hadoop.hbase.ExtendedCellScanner
ServerCall.getCellScanner()
Methods in org.apache.hadoop.hbase.ipc that return types with arguments of type org.apache.hadoop.hbase.ExtendedCellScanner in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,
org.apache.hadoop.hbase.ExtendedCellScanner> RpcServer.call
(org.apache.hadoop.hbase.ipc.RpcCall call, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status) This is a server side method, which is invoked over RPC.org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,
org.apache.hadoop.hbase.ExtendedCellScanner> RpcServerInterface.call
(org.apache.hadoop.hbase.ipc.RpcCall call, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status) Methods in org.apache.hadoop.hbase.ipc with parameters of type org.apache.hadoop.hbase.ExtendedCellScanner in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ipc.HBaseRpcController
RpcControllerFactory.newController
(org.apache.hadoop.hbase.client.RegionInfo regionInfo, org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) org.apache.hadoop.hbase.ipc.HBaseRpcController
RpcControllerFactory.newController
(org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) void
DelegatingHBaseRpcController.setCellScanner
(org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) void
HBaseRpcController.setCellScanner
(org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) Only used to send cells to rpc server, the returned cells should be set byHBaseRpcController.setDone(ExtendedCellScanner)
.void
HBaseRpcControllerImpl.setCellScanner
(org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) void
DelegatingHBaseRpcController.setDone
(org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) void
HBaseRpcController.setDone
(org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) IMPORTANT: always call this method if the call finished without any exception to tell theHBaseRpcController
that we are done.void
HBaseRpcControllerImpl.setDone
(org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) void
RpcCall.setResponse
(org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.ExtendedCellScanner cells, Throwable t, String errorMsg) Constructors in org.apache.hadoop.hbase.ipc with parameters of type org.apache.hadoop.hbase.ExtendedCellScanner in inModifierConstructorDescriptionHBaseRpcControllerImpl
(org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) Used server-side. -
Uses of org.apache.hadoop.hbase.ExtendedCellScanner in org.apache.hadoop.hbase.regionserver
Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.ExtendedCellScanner in inModifier and TypeMethodDescriptionvoid
ReplicationSinkService.replicateLogEntries
(List<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry> entries, org.apache.hadoop.hbase.ExtendedCellScanner cells, String replicationClusterId, String sourceBaseNamespaceDirPath, String sourceHFileArchiveDirPath) Carry on the list of log entries down to the sink -
Uses of org.apache.hadoop.hbase.ExtendedCellScanner in org.apache.hadoop.hbase.replication
Methods in org.apache.hadoop.hbase.replication with parameters of type org.apache.hadoop.hbase.ExtendedCellScanner in inModifier and TypeMethodDescriptionvoid
ReplicationSinkServiceImpl.replicateLogEntries
(List<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry> entries, org.apache.hadoop.hbase.ExtendedCellScanner cells, String replicationClusterId, String sourceBaseNamespaceDirPath, String sourceHFileArchiveDirPath) -
Uses of org.apache.hadoop.hbase.ExtendedCellScanner in org.apache.hadoop.hbase.wal
Methods in org.apache.hadoop.hbase.wal with parameters of type org.apache.hadoop.hbase.ExtendedCellScanner in inModifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay>
WALSplitUtil.getMutationsFromWALEntry
(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry entry, org.apache.hadoop.hbase.ExtendedCellScanner cells, org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.wal.WALKey, org.apache.hadoop.hbase.wal.WALEdit> logEntry, org.apache.hadoop.hbase.client.Durability durability) Deprecated.Since 3.0.0, will be removed in 4.0.0.