Uses of Interface
org.apache.hadoop.hbase.CellScanner

Packages that use org.apache.hadoop.hbase.CellScanner
  • 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 in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.CellScanner
    CellScannable.cellScanner()
    Returns A CellScanner over the contained Cells
    static org.apache.hadoop.hbase.CellScanner
    CellUtil.createCellScanner(Iterable<org.apache.hadoop.hbase.Cell> cellIterable)
    Returns CellScanner interface over cellIterable
    static org.apache.hadoop.hbase.CellScanner
    CellUtil.createCellScanner(Iterator<org.apache.hadoop.hbase.Cell> cells)
    Returns CellScanner interface over cellIterable or null if cells is null
    static org.apache.hadoop.hbase.CellScanner
    CellUtil.createCellScanner(List<? extends org.apache.hadoop.hbase.CellScannable> cellScannerables)
    Returns CellScanner interface over cellIterables
    static org.apache.hadoop.hbase.CellScanner
    CellUtil.createCellScanner(NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>> map)
    Flatten the map of cells out under the CellScanner
    static org.apache.hadoop.hbase.CellScanner
    CellUtil.createCellScanner(org.apache.hadoop.hbase.Cell[] cellArray)
    Returns CellScanner interface over cellArray
  • 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 in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.client.Result
    Single row result of a Get or Scan query.
    Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.CellScanner in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.CellScanner
    Mutation.cellScanner()
     
    org.apache.hadoop.hbase.CellScanner
    Result.cellScanner()
     
    protected org.apache.hadoop.hbase.CellScanner
    RegionServerCallable.getRpcControllerCellScanner()
    Get the RpcController CellScanner.
    Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.CellScanner in in
    Modifier and Type
    Method
    Description
    protected void
    RegionServerCallable.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.codec
    Modifier and Type
    Interface
    Description
    static 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.CellScanner in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.codec.BaseDecoder
    TODO javadoc
    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.CellScanner in org.apache.hadoop.hbase.io

    Subinterfaces of org.apache.hadoop.hbase.CellScanner in in org.apache.hadoop.hbase.io
    Modifier and Type
    Interface
    Description
    interface 
    org.apache.hadoop.hbase.io.SizedCellScanner
    A 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 in
    Modifier and Type
    Field
    Description
    protected final org.apache.hadoop.hbase.CellScanner
    ServerCall.cellScanner
     
    Methods in org.apache.hadoop.hbase.ipc that return org.apache.hadoop.hbase.CellScanner in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.CellScanner
    DelegatingHBaseRpcController.cellScanner()
     
    org.apache.hadoop.hbase.CellScanner
    HBaseRpcControllerImpl.cellScanner()
    Returns One-shot cell scanner (you cannot back it up and restart)
    org.apache.hadoop.hbase.CellScanner
    RpcCall.getCellScanner()
    Returns The CellScanner that can carry input and result payload.
    org.apache.hadoop.hbase.CellScanner
    ServerCall.getCellScanner()
     
    Methods in org.apache.hadoop.hbase.ipc that return types with arguments of type org.apache.hadoop.hbase.CellScanner in in
    Modifier and Type
    Method
    Description
    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)
     
    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.0
    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, long startTime, int timeout)
    Deprecated.
    As of release 2.0, this will be removed in HBase 3.0
    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)
    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 in
    Modifier and Type
    Method
    Description
    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)
     
    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.0
    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, long startTime, int timeout)
    Deprecated.
    As of release 2.0, this will be removed in HBase 3.0
    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)
    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.HBaseRpcController
    RpcControllerFactory.newController(org.apache.hadoop.hbase.CellScanner cellScanner)
     
    org.apache.hadoop.hbase.ipc.HBaseRpcController
    RpcControllerFactory.newController(org.apache.hadoop.hbase.client.RegionInfo regionInfo, org.apache.hadoop.hbase.CellScanner cellScanner)
     
    void
    DelegatingHBaseRpcController.setCellScanner(org.apache.hadoop.hbase.CellScanner cellScanner)
     
    void
    HBaseRpcController.setCellScanner(org.apache.hadoop.hbase.CellScanner cellScanner)
    Only used to send cells to rpc server, the returned cells should be set by HBaseRpcController.setDone(CellScanner).
    void
    HBaseRpcControllerImpl.setCellScanner(org.apache.hadoop.hbase.CellScanner cellScanner)
     
    void
    DelegatingHBaseRpcController.setDone(org.apache.hadoop.hbase.CellScanner cellScanner)
     
    void
    HBaseRpcController.setDone(org.apache.hadoop.hbase.CellScanner cellScanner)
    IMPORTANT: always call this method if the call finished without any exception to tell the HBaseRpcController that we are done.
    void
    HBaseRpcControllerImpl.setDone(org.apache.hadoop.hbase.CellScanner cellScanner)
     
    void
    RpcCall.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.
    void
    ServerCall.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 in
    Modifier
    Constructor
    Description
     
    HBaseRpcControllerImpl(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 in
    Modifier and Type
    Method
    Description
    void
    ReplicationSinkService.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 in
    Modifier and Type
    Method
    Description
    void
    ReplicationSinkServiceImpl.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 in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.client.CheckAndMutateResult
    ResponseConverter.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 MutateResponse
    static org.apache.hadoop.hbase.client.SingleResponse
    ResponseConverter.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.MultiResponse
    ResponseConverter.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 MultiResponse
    static org.apache.hadoop.hbase.client.MultiResponse
    ResponseConverter.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 MultiResponse
    static org.apache.hadoop.hbase.client.Append
    ProtobufUtil.toAppend(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto proto, org.apache.hadoop.hbase.CellScanner cellScanner)
    Convert a protocol buffer Mutate to an Append
    ProtobufUtil.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.Delete
    ProtobufUtil.toDelete(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto proto, org.apache.hadoop.hbase.CellScanner cellScanner)
    Convert a protocol buffer Mutate to a Delete
    static org.apache.hadoop.hbase.client.Increment
    ProtobufUtil.toIncrement(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto proto, org.apache.hadoop.hbase.CellScanner cellScanner)
    Convert a protocol buffer Mutate to an Increment
    static org.apache.hadoop.hbase.client.Put
    ProtobufUtil.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.Result
    ProtobufUtil.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 in
    Modifier and Type
    Method
    Description
    static 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.