Uses of Interface
org.apache.hadoop.hbase.CellScanner
Packages that use 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
Methods in org.apache.hadoop.hbase that return CellScannerModifier and TypeMethodDescriptionCellScannable.cellScanner()Returns A CellScanner over the containedCellsstatic CellScannerCellUtil.createCellScanner(Iterable<Cell> cellIterable) Returns CellScanner interface overcellIterablestatic CellScannerCellUtil.createCellScanner(Iterator<Cell> cells) Returns CellScanner interface overcellIterableor null ifcellsis nullstatic CellScannerCellUtil.createCellScanner(List<? extends CellScannable> cellScannerables) Returns CellScanner interface overcellIterablesstatic CellScannerCellUtil.createCellScanner(NavigableMap<byte[], List<Cell>> map) Flatten the map of cells out under the CellScannerstatic CellScannerCellUtil.createCellScanner(Cell[] cellArray) Returns CellScanner interface overcellArray -
Uses of CellScanner in org.apache.hadoop.hbase.client
Classes in org.apache.hadoop.hbase.client that implement CellScannerMethods in org.apache.hadoop.hbase.client that return CellScannerModifier and TypeMethodDescriptionMutation.cellScanner()Result.cellScanner()protected CellScannerRegionServerCallable.getRpcControllerCellScanner()Get the RpcController CellScanner.Methods in org.apache.hadoop.hbase.client with parameters of type CellScannerModifier and TypeMethodDescriptionprotected voidRegionServerCallable.setRpcControllerCellScanner(CellScanner cellScanner) -
Uses of CellScanner in org.apache.hadoop.hbase.codec
Subinterfaces of CellScanner 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 CellScannerModifier and TypeClassDescriptionclassTODO javadoc(package private) static class(package private) static classstatic classstatic classstatic classstatic class(package private) static class -
Uses of CellScanner in org.apache.hadoop.hbase.io
Subinterfaces of CellScanner in org.apache.hadoop.hbase.ioModifier and TypeInterfaceDescriptioninterfaceA CellScanner that knows its size in memory in bytes. -
Uses of CellScanner in org.apache.hadoop.hbase.ipc
Fields in org.apache.hadoop.hbase.ipc declared as CellScannerModifier and TypeFieldDescription(package private) CellScannerCall.cellsOptionally has cells when making call.private CellScannerHBaseRpcControllerImpl.cellScannerThey are optionally set on construction, cleared after we make the call, and then optionally set on response with the result.protected final CellScannerServerCall.cellScannerMethods in org.apache.hadoop.hbase.ipc that return CellScannerModifier 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 CellScannerModifier 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.Methods in org.apache.hadoop.hbase.ipc with parameters of type CellScannerModifier and TypeMethodDescriptionCellBlockBuilder.buildCellBlock(Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor, CellScanner cellScanner) Puts CellScanner Cells into a cell block using passed incodecand/orcompressor.private booleanCellBlockBuilder.buildCellBlock(Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor, CellScanner cellScanner, CellBlockBuilder.OutputStreamSupplier supplier) org.apache.hbase.thirdparty.io.netty.buffer.ByteBufCellBlockBuilder.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 incodecand/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 voidCellBlockBuilder.encodeCellsTo(OutputStream os, CellScanner cellScanner, Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor) RpcControllerFactory.newController(CellScanner cellScanner) RpcControllerFactory.newController(RegionInfo regionInfo, CellScanner cellScanner) voidDelegatingHBaseRpcController.setCellScanner(CellScanner cellScanner) voidHBaseRpcController.setCellScanner(CellScanner cellScanner) Only used to send cells to rpc server, the returned cells should be set byHBaseRpcController.setDone(CellScanner).voidHBaseRpcControllerImpl.setCellScanner(CellScanner cellScanner) voidDelegatingHBaseRpcController.setDone(CellScanner cellScanner) voidHBaseRpcController.setDone(CellScanner cellScanner) IMPORTANT: always call this method if the call finished without any exception to tell theHBaseRpcControllerthat we are done.voidHBaseRpcControllerImpl.setDone(CellScanner cellScanner) voidCall.setResponse(org.apache.hbase.thirdparty.com.google.protobuf.Message response, CellScanner cells) Set the return value when there is no error.voidRpcCall.setResponse(org.apache.hbase.thirdparty.com.google.protobuf.Message param, CellScanner cells, Throwable errorThrowable, String error) Set the response resulting from this RPC call.voidServerCall.setResponse(org.apache.hbase.thirdparty.com.google.protobuf.Message m, CellScanner cells, Throwable t, String errorMsg) Constructors in org.apache.hadoop.hbase.ipc with parameters of type CellScannerModifierConstructorDescription(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
Methods in org.apache.hadoop.hbase.regionserver with parameters of type CellScannerModifier and TypeMethodDescriptionprivate ResultRSRpcServices.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 CheckAndMutateResultRSRpcServices.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 CheckAndMutateResultRSRpcServices.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 voidRSRpcServices.delete(HRegion region, OperationQuota quota, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation, CellScanner cellScanner, ActivePolicyEnforcement spaceQuota) private voidRSRpcServices.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 voidRSRpcServices.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 voidRSRpcServices.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 regionMutationrmand per Mutation, do the work, and then when done, add an instance of aClientProtos.ResultOrExceptionthat corresponds to each Mutation.private voidRSRpcServices.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 ResultRSRpcServices.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 voidRSRpcServices.put(HRegion region, OperationQuota quota, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation, CellScanner cellScanner, ActivePolicyEnforcement spaceQuota) voidReplicationSinkService.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 voidRSRpcServices.skipCellsForMutation(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action action, CellScanner cellScanner) private voidRSRpcServices.skipCellsForMutations(List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> actions, CellScanner cellScanner) -
Uses of CellScanner in org.apache.hadoop.hbase.regionserver.wal
Classes in org.apache.hadoop.hbase.regionserver.wal that implement CellScannerModifier and TypeClassDescription(package private) static class(package private) static class -
Uses of CellScanner in org.apache.hadoop.hbase.replication
Methods in org.apache.hadoop.hbase.replication with parameters of type CellScannerModifier and TypeMethodDescriptionvoidReplicationSinkServiceImpl.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
Methods in org.apache.hadoop.hbase.replication.regionserver with parameters of type CellScannerModifier and TypeMethodDescriptionvoidReplicationSink.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.voidReplication.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
Methods in org.apache.hadoop.hbase.wal with parameters of type CellScannerModifier 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.