Uses of Class
org.apache.hadoop.hbase.client.Get

Packages that use org.apache.hadoop.hbase.client.Get
  • Uses of org.apache.hadoop.hbase.client.Get in org.apache.hadoop.hbase.client

    Fields in org.apache.hadoop.hbase.client declared as org.apache.hadoop.hbase.client.Get in in
    Modifier and Type
    Field
    Description
    protected final org.apache.hadoop.hbase.client.Get
    RpcRetryingCallerWithReadReplicas.get
     
    Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.client.Get in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.Get
    Get.addColumn(byte[] family, byte[] qualifier)
    Get the column from the specific family with the specified qualifier.
    org.apache.hadoop.hbase.client.Get
    Get.addFamily(byte[] family)
    Get all columns from the specified family.
    org.apache.hadoop.hbase.client.Get
    Get.readAllVersions()
    Get all available versions.
    org.apache.hadoop.hbase.client.Get
    Get.readVersions(int versions)
    Get up to the specified number of versions of each column.
    org.apache.hadoop.hbase.client.Get
    Get.setACL(String user, org.apache.hadoop.hbase.security.access.Permission perms)
     
    org.apache.hadoop.hbase.client.Get
    Get.setACL(Map<String,org.apache.hadoop.hbase.security.access.Permission> perms)
     
    org.apache.hadoop.hbase.client.Get
    Get.setAttribute(String name, byte[] value)
     
    org.apache.hadoop.hbase.client.Get
    Get.setAuthorizations(org.apache.hadoop.hbase.security.visibility.Authorizations authorizations)
     
    org.apache.hadoop.hbase.client.Get
    Get.setCacheBlocks(boolean cacheBlocks)
    Set whether blocks should be cached for this Get.
    org.apache.hadoop.hbase.client.Get
    Get.setCheckExistenceOnly(boolean checkExistenceOnly)
     
    org.apache.hadoop.hbase.client.Get
    Get.setClosestRowBefore(boolean closestRowBefore)
    Deprecated.
    since 2.0.0 and will be removed in 3.0.0
    org.apache.hadoop.hbase.client.Get
    Get.setColumnFamilyTimeRange(byte[] cf, long minStamp, long maxStamp)
     
    org.apache.hadoop.hbase.client.Get
    Get.setConsistency(org.apache.hadoop.hbase.client.Consistency consistency)
     
    org.apache.hadoop.hbase.client.Get
    Get.setFilter(org.apache.hadoop.hbase.filter.Filter filter)
     
    org.apache.hadoop.hbase.client.Get
    Get.setId(String id)
     
    org.apache.hadoop.hbase.client.Get
    Get.setIsolationLevel(org.apache.hadoop.hbase.client.IsolationLevel level)
     
    org.apache.hadoop.hbase.client.Get
    Get.setLoadColumnFamiliesOnDemand(boolean value)
     
    org.apache.hadoop.hbase.client.Get
    Get.setMaxResultsPerColumnFamily(int limit)
    Set the maximum number of values to return per row per Column Family
    org.apache.hadoop.hbase.client.Get
    Get.setMaxVersions()
    Deprecated.
    It is easy to misunderstand with column family's max versions, so use readAllVersions() instead.
    org.apache.hadoop.hbase.client.Get
    Get.setMaxVersions(int maxVersions)
    Deprecated.
    It is easy to misunderstand with column family's max versions, so use readVersions(int) instead.
    org.apache.hadoop.hbase.client.Get
    Get.setPriority(int priority)
     
    org.apache.hadoop.hbase.client.Get
    Get.setReplicaId(int Id)
     
    org.apache.hadoop.hbase.client.Get
    Get.setRowOffsetPerColumnFamily(int offset)
    Set offset for the row per Column Family.
    org.apache.hadoop.hbase.client.Get
    Get.setTimeRange(long minStamp, long maxStamp)
    Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).
    org.apache.hadoop.hbase.client.Get
    Get.setTimestamp(long timestamp)
    Get versions of columns with the specified timestamp.
    org.apache.hadoop.hbase.client.Get
    Get.setTimeStamp(long timestamp)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.Get in in
    Modifier and Type
    Method
    Description
    AsyncTable.exists(org.apache.hadoop.hbase.client.Get get)
    Test for the existence of columns in the table, as specified by the Get.
    boolean
    HTable.exists(org.apache.hadoop.hbase.client.Get get)
     
    default boolean
    Table.exists(org.apache.hadoop.hbase.client.Get get)
    Test for the existence of columns in the table, as specified by the Get.
    CompletableFuture<org.apache.hadoop.hbase.client.Result>
    AsyncTable.get(org.apache.hadoop.hbase.client.Get get)
    Extracts certain cells from a given row.
    org.apache.hadoop.hbase.client.Result
    HTable.get(org.apache.hadoop.hbase.client.Get get)
     
    default org.apache.hadoop.hbase.client.Result
    Table.get(org.apache.hadoop.hbase.client.Get get)
    Extracts certain cells from a given row.
    Method parameters in org.apache.hadoop.hbase.client with type arguments of type org.apache.hadoop.hbase.client.Get in in
    Modifier and Type
    Method
    Description
    AsyncTable.exists(List<org.apache.hadoop.hbase.client.Get> gets)
    Test for the existence of columns in the table, as specified by the Gets.
    boolean[]
    HTable.exists(List<org.apache.hadoop.hbase.client.Get> gets)
     
    default boolean[]
    Table.exists(List<org.apache.hadoop.hbase.client.Get> gets)
    Test for the existence of columns in the table, as specified by the Gets.
    AsyncTable.existsAll(List<org.apache.hadoop.hbase.client.Get> gets)
    A simple version for batch exists.
    default boolean[]
    Table.existsAll(List<org.apache.hadoop.hbase.client.Get> gets)
    Deprecated.
    since 2.0 version and will be removed in 3.0 version.
    List<CompletableFuture<org.apache.hadoop.hbase.client.Result>>
    AsyncTable.get(List<org.apache.hadoop.hbase.client.Get> gets)
    Extracts certain cells from the given rows, in batch.
    org.apache.hadoop.hbase.client.Result[]
    HTable.get(List<org.apache.hadoop.hbase.client.Get> gets)
     
    default org.apache.hadoop.hbase.client.Result[]
    Table.get(List<org.apache.hadoop.hbase.client.Get> gets)
    Extracts specified cells from the given rows, as a batch.
    default CompletableFuture<List<org.apache.hadoop.hbase.client.Result>>
    AsyncTable.getAll(List<org.apache.hadoop.hbase.client.Get> gets)
    A simple version for batch get.
    Constructors in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.Get in in
    Modifier
    Constructor
    Description
     
    Get(org.apache.hadoop.hbase.client.Get get)
    Copy-constructor
     
    RpcRetryingCallerWithReadReplicas(org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.ClusterConnection cConnection, org.apache.hadoop.hbase.client.Get get, ExecutorService pool, int retries, int operationTimeout, int rpcTimeout, int timeBeforeReplicas, Map<String,byte[]> requestAttributes)
     
     
    Scan(org.apache.hadoop.hbase.client.Get get)
    Builds a scan object with the same specs as get.
  • Uses of org.apache.hadoop.hbase.client.Get in org.apache.hadoop.hbase.coprocessor

    Methods in org.apache.hadoop.hbase.coprocessor with parameters of type org.apache.hadoop.hbase.client.Get in in
    Modifier and Type
    Method
    Description
    default boolean
    RegionObserver.postExists(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Get get, boolean exists)
    Called after the client tests for existence using a Get.
    default void
    RegionObserver.postGetOp(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> result)
    Called after the client performs a Get
    default boolean
    RegionObserver.preExists(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Get get, boolean exists)
    Called before the client tests for existence using a Get.
    default void
    RegionObserver.preGetOp(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> result)
    Called before the client performs a Get
    default void
    RegionObserver.prePrepareTimeStampForDeleteVersion(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell cell, byte[] byteNow, org.apache.hadoop.hbase.client.Get get)
    Deprecated.
    Since hbase-2.0.0.
  • Uses of org.apache.hadoop.hbase.client.Get in org.apache.hadoop.hbase.quotas

    Methods in org.apache.hadoop.hbase.quotas that return org.apache.hadoop.hbase.client.Get in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.client.Get
    QuotaTableUtil.makeGetForNamespaceQuotas(String namespace)
     
    static org.apache.hadoop.hbase.client.Get
    QuotaTableUtil.makeGetForRegionServerQuotas(String regionServer)
     
    static org.apache.hadoop.hbase.client.Get
    QuotaTableUtil.makeGetForTableQuotas(org.apache.hadoop.hbase.TableName table)
     
    static org.apache.hadoop.hbase.client.Get
    QuotaTableUtil.makeGetForUserQuotas(String user, Iterable<org.apache.hadoop.hbase.TableName> tables, Iterable<String> namespaces)
     
    static org.apache.hadoop.hbase.client.Get
    QuotaTableUtil.makeQuotaSnapshotGetForTable(org.apache.hadoop.hbase.TableName tn)
    Creates a Get which returns only SpaceQuotaSnapshot from the quota table for a specific table.
    Methods in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.client.Get in in
    Modifier and Type
    Method
    Description
    protected static org.apache.hadoop.hbase.client.Result
    QuotaTableUtil.doGet(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.Get get)
     
    Method parameters in org.apache.hadoop.hbase.quotas with type arguments of type org.apache.hadoop.hbase.client.Get in in
    Modifier and Type
    Method
    Description
    protected static org.apache.hadoop.hbase.client.Result[]
    QuotaTableUtil.doGet(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets)
     
    static <K> Map<K,org.apache.hadoop.hbase.quotas.QuotaState>
    QuotaUtil.fetchGlobalQuotas(String type, org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets, org.apache.hadoop.hbase.quotas.QuotaUtil.KeyFromRow<K> kfr)
     
    static Map<String,org.apache.hadoop.hbase.quotas.QuotaState>
    QuotaUtil.fetchNamespaceQuotas(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets, double factor)
     
    static Map<String,org.apache.hadoop.hbase.quotas.QuotaState>
    QuotaUtil.fetchRegionServerQuotas(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets)
     
    static Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.QuotaState>
    QuotaUtil.fetchTableQuotas(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets, Map<org.apache.hadoop.hbase.TableName,Double> tableMachineFactors)
     
    static Map<String,org.apache.hadoop.hbase.quotas.UserQuotaState>
    QuotaUtil.fetchUserQuotas(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets, Map<org.apache.hadoop.hbase.TableName,Double> tableMachineQuotaFactors, double factor)
     
  • Uses of org.apache.hadoop.hbase.client.Get in org.apache.hadoop.hbase.regionserver

    Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.client.Get in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.Result
    HRegion.get(org.apache.hadoop.hbase.client.Get get)
     
    List<org.apache.hadoop.hbase.Cell>
    HRegion.get(org.apache.hadoop.hbase.client.Get get, boolean withCoprocessor)
     
    org.apache.hadoop.hbase.client.Result
    Region.get(org.apache.hadoop.hbase.client.Get get)
    Do a get based on the get parameter.
    List<org.apache.hadoop.hbase.Cell>
    Region.get(org.apache.hadoop.hbase.client.Get get, boolean withCoprocessor)
    Do a get based on the get parameter.
    boolean
    RegionCoprocessorHost.postExists(org.apache.hadoop.hbase.client.Get get, boolean result)
     
    void
    RegionCoprocessorHost.postGet(org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> results)
     
    RegionCoprocessorHost.preExists(org.apache.hadoop.hbase.client.Get get)
    Supports Coprocessor 'bypass'.
    boolean
    RegionCoprocessorHost.preGet(org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> results)
    Supports Coprocessor 'bypass'.
    boolean
    RegionCoprocessorHost.prePrepareTimeStampForDeleteVersion(org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell kv, byte[] byteNow, org.apache.hadoop.hbase.client.Get get)
    Deprecated.
    In hbase-2.0.0.
    Constructors in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.client.Get in in
    Modifier
    Constructor
    Description
     
    InternalScan(org.apache.hadoop.hbase.client.Get get)
     
  • Uses of org.apache.hadoop.hbase.client.Get in org.apache.hadoop.hbase.shaded.protobuf

    Methods in org.apache.hadoop.hbase.shaded.protobuf that return org.apache.hadoop.hbase.client.Get in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.client.Get
    ProtobufUtil.toGet(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Get proto)
    Convert a protocol buffer Get to a client Get
    Methods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.client.Get in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.GetRequest
    RequestConverter.buildGetRequest(byte[] regionName, org.apache.hadoop.hbase.client.Get get)
    Create a protocol buffer GetRequest for a client Get
    static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Get
    ProtobufUtil.toGet(org.apache.hadoop.hbase.client.Get get)
    Create a protocol buffer Get based on a client Get.