Uses of Interface
org.apache.hadoop.hbase.ExtendedCellScanner
Packages that use 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
Methods in org.apache.hadoop.hbase that return ExtendedCellScannerModifier and TypeMethodDescriptionExtendedCellScannable.cellScanner()static ExtendedCellScannerPrivateCellUtil.createExtendedCellScanner(Iterable<ExtendedCell> cellIterable) Returns ExtendedCellScanner interface overcellIterablestatic ExtendedCellScannerPrivateCellUtil.createExtendedCellScanner(Iterator<ExtendedCell> cells) Returns ExtendedCellScanner interface overcellIterableor null ifcellsis nullstatic ExtendedCellScannerPrivateCellUtil.createExtendedCellScanner(List<? extends ExtendedCellScannable> cellScannerables) Returns ExtendedCellScanner interface overcellIterablesstatic ExtendedCellScannerPrivateCellUtil.createExtendedCellScanner(NavigableMap<byte[], List<ExtendedCell>> map) Flatten the map of cells out under the ExtendedCellScannerstatic ExtendedCellScannerPrivateCellUtil.createExtendedCellScanner(ExtendedCell[] cellArray) Returns CellScanner interface overcellArray -
Uses of ExtendedCellScanner in org.apache.hadoop.hbase.client
Classes in org.apache.hadoop.hbase.client that implement ExtendedCellScannerMethods in org.apache.hadoop.hbase.client that return ExtendedCellScannerModifier and TypeMethodDescriptionMutation.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.Result.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 ExtendedCellScannerModifier 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
Subinterfaces of ExtendedCellScanner in org.apache.hadoop.hbase.codecModifier and TypeInterfaceDescriptionstatic interfaceImplementations 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 ExtendedCellScannerModifier and TypeClassDescriptionclassBase implementation forCodec.Decoder.(package private) static class(package private) static classstatic classstatic classstatic classstatic class(package private) static class -
Uses of ExtendedCellScanner in org.apache.hadoop.hbase.io
Subinterfaces of ExtendedCellScanner in org.apache.hadoop.hbase.ioModifier and TypeInterfaceDescriptioninterfaceA CellScanner that knows its size in memory in bytes. -
Uses of ExtendedCellScanner in org.apache.hadoop.hbase.ipc
Fields in org.apache.hadoop.hbase.ipc declared as ExtendedCellScannerModifier and TypeFieldDescription(package private) ExtendedCellScannerCall.cellsOptionally has cells when making call.private ExtendedCellScannerHBaseRpcControllerImpl.cellScannerThey are optionally set on construction, cleared after we make the call, and then optionally set on response with the result.protected final ExtendedCellScannerServerCall.cellScannerMethods in org.apache.hadoop.hbase.ipc that return ExtendedCellScannerModifier 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()Methods in org.apache.hadoop.hbase.ipc that return types with arguments of type ExtendedCellScannerModifier 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) Methods in org.apache.hadoop.hbase.ipc with parameters of type ExtendedCellScannerModifier and TypeMethodDescriptionCellBlockBuilder.buildCellBlock(Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor, ExtendedCellScanner cellScanner) Puts CellScanner Cells into a cell block using passed incodecand/orcompressor.private booleanCellBlockBuilder.buildCellBlock(Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor, ExtendedCellScanner cellScanner, CellBlockBuilder.OutputStreamSupplier supplier) org.apache.hbase.thirdparty.io.netty.buffer.ByteBufCellBlockBuilder.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 incodecand/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 voidCellBlockBuilder.encodeCellsTo(OutputStream os, ExtendedCellScanner cellScanner, Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor) RpcControllerFactory.newController(RegionInfo regionInfo, ExtendedCellScanner cellScanner) RpcControllerFactory.newController(ExtendedCellScanner cellScanner) voidDelegatingHBaseRpcController.setCellScanner(ExtendedCellScanner cellScanner) voidHBaseRpcController.setCellScanner(ExtendedCellScanner cellScanner) Only used to send cells to rpc server, the returned cells should be set byHBaseRpcController.setDone(ExtendedCellScanner).voidHBaseRpcControllerImpl.setCellScanner(ExtendedCellScanner cellScanner) voidDelegatingHBaseRpcController.setDone(ExtendedCellScanner cellScanner) voidHBaseRpcController.setDone(ExtendedCellScanner cellScanner) IMPORTANT: always call this method if the call finished without any exception to tell theHBaseRpcControllerthat we are done.voidHBaseRpcControllerImpl.setDone(ExtendedCellScanner cellScanner) voidCall.setResponse(org.apache.hbase.thirdparty.com.google.protobuf.Message response, ExtendedCellScanner cells) Set the return value when there is no error.voidRpcCall.setResponse(org.apache.hbase.thirdparty.com.google.protobuf.Message param, 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, ExtendedCellScanner cells, Throwable t, String errorMsg) Constructors in org.apache.hadoop.hbase.ipc with parameters of type ExtendedCellScannerModifierConstructorDescription(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
Methods in org.apache.hadoop.hbase.regionserver that return ExtendedCellScannerModifier and TypeMethodDescriptionprivate ExtendedCellScannerRSRpcServices.getAndReset(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller) Methods in org.apache.hadoop.hbase.regionserver with parameters of type ExtendedCellScannerModifier and TypeMethodDescriptionvoidReplicationSinkService.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
Classes in org.apache.hadoop.hbase.regionserver.wal that implement ExtendedCellScannerModifier and TypeClassDescription(package private) static class(package private) static class -
Uses of ExtendedCellScanner in org.apache.hadoop.hbase.replication
Methods in org.apache.hadoop.hbase.replication with parameters of type ExtendedCellScannerModifier and TypeMethodDescriptionvoidReplicationSinkServiceImpl.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
Methods in org.apache.hadoop.hbase.replication.regionserver with parameters of type ExtendedCellScannerModifier and TypeMethodDescriptionvoidReplicationSink.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
Methods in org.apache.hadoop.hbase.wal with parameters of type ExtendedCellScannerModifier 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.