Uses of Interface
org.apache.hadoop.hbase.CellScanner
Packages that use org.apache.hadoop.hbase.CellScanner
Package
Description
Provides HBase Client
Tools to help define network clients and servers.
Multi Cluster Replication
-
Uses of org.apache.hadoop.hbase.CellScanner in org.apache.hadoop.hbase
Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.CellScanner in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellScannerCellScannable.cellScanner()Returns A CellScanner over the containedCellsstatic org.apache.hadoop.hbase.CellScannerCellUtil.createCellScanner(Iterable<org.apache.hadoop.hbase.Cell> cellIterable) Returns CellScanner interface overcellIterablestatic org.apache.hadoop.hbase.CellScannerCellUtil.createCellScanner(Iterator<org.apache.hadoop.hbase.Cell> cells) Returns CellScanner interface overcellIterableor null ifcellsis nullstatic org.apache.hadoop.hbase.CellScannerCellUtil.createCellScanner(List<? extends org.apache.hadoop.hbase.CellScannable> cellScannerables) Returns CellScanner interface overcellIterablesstatic org.apache.hadoop.hbase.CellScannerCellUtil.createCellScanner(NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> map) Flatten the map of cells out under the CellScannerstatic org.apache.hadoop.hbase.CellScannerCellUtil.createCellScanner(org.apache.hadoop.hbase.Cell[] cellArray) Returns CellScanner interface overcellArray -
Uses of org.apache.hadoop.hbase.CellScanner in org.apache.hadoop.hbase.client
Classes in org.apache.hadoop.hbase.client that implement org.apache.hadoop.hbase.CellScanner 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.CellScanner in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellScannerMutation.cellScanner()org.apache.hadoop.hbase.CellScannerResult.cellScanner()protected org.apache.hadoop.hbase.CellScannerRegionServerCallable.getRpcControllerCellScanner()Get the RpcController CellScanner.Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.CellScanner in inModifier and TypeMethodDescriptionprotected voidRegionServerCallable.setRpcControllerCellScanner(org.apache.hadoop.hbase.CellScanner cellScanner) -
Uses of org.apache.hadoop.hbase.CellScanner in org.apache.hadoop.hbase.codec
Subinterfaces of org.apache.hadoop.hbase.CellScanner 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.CellScanner in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.codec.BaseDecoderTODO javadocstatic 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.CellScanner in org.apache.hadoop.hbase.io
Subinterfaces of org.apache.hadoop.hbase.CellScanner in in org.apache.hadoop.hbase.ioModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.io.SizedCellScannerA CellScanner that knows its size in memory in bytes. -
Uses of org.apache.hadoop.hbase.CellScanner in org.apache.hadoop.hbase.ipc
Fields in org.apache.hadoop.hbase.ipc declared as org.apache.hadoop.hbase.CellScanner in inModifier and TypeFieldDescriptionprotected final org.apache.hadoop.hbase.CellScannerServerCall.cellScannerMethods in org.apache.hadoop.hbase.ipc that return org.apache.hadoop.hbase.CellScanner in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellScannerDelegatingHBaseRpcController.cellScanner()org.apache.hadoop.hbase.CellScannerHBaseRpcControllerImpl.cellScanner()Returns One-shot cell scanner (you cannot back it up and restart)org.apache.hadoop.hbase.CellScannerRpcCall.getCellScanner()Returns The CellScanner that can carry input and result payload.org.apache.hadoop.hbase.CellScannerServerCall.getCellScanner()Methods in org.apache.hadoop.hbase.ipc that return types with arguments of type org.apache.hadoop.hbase.CellScanner in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status) org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status, long startTime, int timeout) org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.CellScanner> 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.CellScanner> RpcServerInterface.call(org.apache.hadoop.hbase.ipc.RpcCall call, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status) org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status) Deprecated.As of release 1.3, this will be removed in HBase 3.0org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status, long startTime, int timeout) Deprecated.As of release 2.0, this will be removed in HBase 3.0org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status) Deprecated.org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status, long startTime, int timeout) Deprecated.Methods in org.apache.hadoop.hbase.ipc with parameters of type org.apache.hadoop.hbase.CellScanner in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status) org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status, long startTime, int timeout) org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status) Deprecated.As of release 1.3, this will be removed in HBase 3.0org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status, long startTime, int timeout) Deprecated.As of release 2.0, this will be removed in HBase 3.0org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status) Deprecated.org.apache.hadoop.hbase.util.Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.CellScanner cellScanner, long receiveTime, org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler status, long startTime, int timeout) Deprecated.org.apache.hadoop.hbase.ipc.HBaseRpcControllerRpcControllerFactory.newController(org.apache.hadoop.hbase.CellScanner cellScanner) org.apache.hadoop.hbase.ipc.HBaseRpcControllerRpcControllerFactory.newController(org.apache.hadoop.hbase.client.RegionInfo regionInfo, org.apache.hadoop.hbase.CellScanner cellScanner) voidDelegatingHBaseRpcController.setCellScanner(org.apache.hadoop.hbase.CellScanner cellScanner) voidHBaseRpcController.setCellScanner(org.apache.hadoop.hbase.CellScanner cellScanner) Only used to send cells to rpc server, the returned cells should be set byHBaseRpcController.setDone(CellScanner).voidHBaseRpcControllerImpl.setCellScanner(org.apache.hadoop.hbase.CellScanner cellScanner) voidDelegatingHBaseRpcController.setDone(org.apache.hadoop.hbase.CellScanner cellScanner) voidHBaseRpcController.setDone(org.apache.hadoop.hbase.CellScanner 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.CellScanner cellScanner) voidRpcCall.setResponse(org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.CellScanner cells, Throwable t, String errorMsg) Constructors in org.apache.hadoop.hbase.ipc with parameters of type org.apache.hadoop.hbase.CellScanner in inModifierConstructorDescriptionHBaseRpcControllerImpl(org.apache.hadoop.hbase.CellScanner cellScanner) Used server-side. -
Uses of org.apache.hadoop.hbase.CellScanner in org.apache.hadoop.hbase.regionserver
Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.CellScanner in inModifier and TypeMethodDescriptionvoidReplicationSinkService.replicateLogEntries(List<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry> entries, org.apache.hadoop.hbase.CellScanner cells, String replicationClusterId, String sourceBaseNamespaceDirPath, String sourceHFileArchiveDirPath) Carry on the list of log entries down to the sink -
Uses of org.apache.hadoop.hbase.CellScanner in org.apache.hadoop.hbase.replication
Methods in org.apache.hadoop.hbase.replication with parameters of type org.apache.hadoop.hbase.CellScanner in inModifier and TypeMethodDescriptionvoidReplicationSinkServiceImpl.replicateLogEntries(List<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry> entries, org.apache.hadoop.hbase.CellScanner cells, String replicationClusterId, String sourceBaseNamespaceDirPath, String sourceHFileArchiveDirPath) -
Uses of org.apache.hadoop.hbase.CellScanner in org.apache.hadoop.hbase.shaded.protobuf
Methods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.CellScanner in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.CheckAndMutateResultResponseConverter.getCheckAndMutateResult(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateResponse mutateResponse, org.apache.hadoop.hbase.CellScanner cells) Create a CheckAndMutateResult object from a protocol buffer MutateResponsestatic org.apache.hadoop.hbase.client.SingleResponseResponseConverter.getResult(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest request, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateResponse response, org.apache.hadoop.hbase.CellScanner cells) static org.apache.hadoop.hbase.client.Result[]ResponseConverter.getResults(org.apache.hadoop.hbase.CellScanner cellScanner, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse response) Create Results from the cells using the cells meta data.static org.apache.hadoop.hbase.client.MultiResponseResponseConverter.getResults(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest request, Map<Integer, Integer> indexMap, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiResponse response, org.apache.hadoop.hbase.CellScanner cells) Get the results from a protocol buffer MultiResponsestatic org.apache.hadoop.hbase.client.MultiResponseResponseConverter.getResults(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest request, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiResponse response, org.apache.hadoop.hbase.CellScanner cells) Get the results from a protocol buffer MultiResponsestatic org.apache.hadoop.hbase.client.AppendProtobufUtil.toAppend(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto proto, org.apache.hadoop.hbase.CellScanner cellScanner) Convert a protocol buffer Mutate to an Appendstatic CheckAndMutateProtobufUtil.toCheckAndMutate(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Condition condition, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto mutation, org.apache.hadoop.hbase.CellScanner cellScanner) static org.apache.hadoop.hbase.client.DeleteProtobufUtil.toDelete(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto proto, org.apache.hadoop.hbase.CellScanner cellScanner) Convert a protocol buffer Mutate to a Deletestatic org.apache.hadoop.hbase.client.IncrementProtobufUtil.toIncrement(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto proto, org.apache.hadoop.hbase.CellScanner cellScanner) Convert a protocol buffer Mutate to an Incrementstatic org.apache.hadoop.hbase.client.PutProtobufUtil.toPut(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto proto, org.apache.hadoop.hbase.CellScanner cellScanner) Convert a protocol buffer Mutate to a Put.static org.apache.hadoop.hbase.client.ResultProtobufUtil.toResult(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Result proto, org.apache.hadoop.hbase.CellScanner scanner) Convert a protocol buffer Result to a client Result -
Uses of org.apache.hadoop.hbase.CellScanner in org.apache.hadoop.hbase.wal
Methods in org.apache.hadoop.hbase.wal with parameters of type org.apache.hadoop.hbase.CellScanner 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.CellScanner 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) This function is used to construct mutations from a WALEntry.