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.ExtendedCellScannerExtendedCellScannable.cellScanner()static org.apache.hadoop.hbase.ExtendedCellScannerPrivateCellUtil.createExtendedCellScanner(Iterable<org.apache.hadoop.hbase.ExtendedCell> cellIterable) Returns ExtendedCellScanner interface overcellIterablestatic org.apache.hadoop.hbase.ExtendedCellScannerPrivateCellUtil.createExtendedCellScanner(Iterator<org.apache.hadoop.hbase.ExtendedCell> cells) Returns ExtendedCellScanner interface overcellIterableor null ifcellsis nullstatic org.apache.hadoop.hbase.ExtendedCellScannerPrivateCellUtil.createExtendedCellScanner(List<? extends org.apache.hadoop.hbase.ExtendedCellScannable> cellScannerables) Returns ExtendedCellScanner interface overcellIterablesstatic org.apache.hadoop.hbase.ExtendedCellScannerPrivateCellUtil.createExtendedCellScanner(NavigableMap<byte[], List<org.apache.hadoop.hbase.ExtendedCell>> map) Flatten the map of cells out under the ExtendedCellScannerstatic org.apache.hadoop.hbase.ExtendedCellScannerPrivateCellUtil.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 TypeClassDescriptionclassorg.apache.hadoop.hbase.client.ResultSingle row result of aGetorScanquery.Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.ExtendedCellScanner in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ExtendedCellScannerMutation.cellScanner()For client users: You should only use the return value as aCellScanner,ExtendedCellScanneris marked as IA.Private which means there is no guarantee about its API stability.org.apache.hadoop.hbase.ExtendedCellScannerResult.cellScanner()For client users: You should only use the return value as aCellScanner,ExtendedCellScanneris 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 interfaceorg.apache.hadoop.hbase.codec.Codec.DecoderImplementations 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 TypeClassDescriptionclassorg.apache.hadoop.hbase.codec.BaseDecoderBase implementation forCodec.Decoder.static classorg.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoderstatic classorg.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueDecoderstatic classorg.apache.hadoop.hbase.codec.KeyValueCodecWithTags.ByteBuffKeyValueDecoderstatic classorg.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 TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.io.SizedExtendedCellScannerA 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.ExtendedCellScannerServerCall.cellScannerMethods in org.apache.hadoop.hbase.ipc that return org.apache.hadoop.hbase.ExtendedCellScanner in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ExtendedCellScannerDelegatingHBaseRpcController.cellScanner()org.apache.hadoop.hbase.ExtendedCellScannerHBaseRpcControllerImpl.cellScanner()Returns One-shot cell scanner (you cannot back it up and restart)org.apache.hadoop.hbase.ExtendedCellScannerRpcCall.getCellScanner()Returns The CellScanner that can carry input and result payload.org.apache.hadoop.hbase.ExtendedCellScannerServerCall.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.HBaseRpcControllerRpcControllerFactory.newController(org.apache.hadoop.hbase.client.RegionInfo regionInfo, org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) org.apache.hadoop.hbase.ipc.HBaseRpcControllerRpcControllerFactory.newController(org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) voidDelegatingHBaseRpcController.setCellScanner(org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) voidHBaseRpcController.setCellScanner(org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) Only used to send cells to rpc server, the returned cells should be set byHBaseRpcController.setDone(ExtendedCellScanner).voidHBaseRpcControllerImpl.setCellScanner(org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) voidDelegatingHBaseRpcController.setDone(org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) voidHBaseRpcController.setDone(org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) IMPORTANT: always call this method if the call finished without any exception to tell theHBaseRpcControllerthat we are done.voidHBaseRpcControllerImpl.setDone(org.apache.hadoop.hbase.ExtendedCellScanner cellScanner) voidRpcCall.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.voidServerCall.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 TypeMethodDescriptionvoidReplicationSinkService.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 TypeMethodDescriptionvoidReplicationSinkServiceImpl.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.