Uses of Class
org.apache.hadoop.hbase.client.Get
-
Uses of Get in org.apache.hadoop.hbase
-
Uses of Get in org.apache.hadoop.hbase.backup.impl
Modifier and TypeMethodDescriptionprivate Get
BackupSystemTable.createGetForBackupInfo
(String backupId) Creates Get operation for a given backup idprivate Get
BackupSystemTable.createGetForBackupSet
(String name) Creates Get operation to load backup set contentprivate Get
BackupSystemTable.createGetForDeleteOperation()
private Get
BackupSystemTable.createGetForIncrBackupTableSet
(String backupRoot) Creates Get to retrieve incremental backup table set from backup system tableprivate Get
BackupSystemTable.createGetForMergeOperation()
private Get
BackupSystemTable.createGetForStartCode
(String rootPath) Creates Get operation to retrieve start code from backup system table -
Uses of Get in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptionGet.addColumn
(byte[] family, byte[] qualifier) Get the column from the specific family with the specified qualifier.Get.addFamily
(byte[] family) Get all columns from the specified family.Get.readAllVersions()
Get all available versions.Get.readVersions
(int versions) Get up to the specified number of versions of each column.Get.setACL
(String user, Permission perms) Get.setACL
(Map<String, Permission> perms) Get.setAttribute
(String name, byte[] value) Get.setAuthorizations
(Authorizations authorizations) Get.setCacheBlocks
(boolean cacheBlocks) Set whether blocks should be cached for this Get.Get.setCheckExistenceOnly
(boolean checkExistenceOnly) Get.setClosestRowBefore
(boolean closestRowBefore) Deprecated.since 2.0.0 and will be removed in 3.0.0Get.setColumnFamilyTimeRange
(byte[] cf, long minStamp, long maxStamp) Get.setConsistency
(Consistency consistency) Get.setIsolationLevel
(IsolationLevel level) Get.setLoadColumnFamiliesOnDemand
(boolean value) Get.setMaxResultsPerColumnFamily
(int limit) Set the maximum number of values to return per row per Column FamilyGet.setMaxVersions()
Deprecated.It is easy to misunderstand with column family's max versions, so usereadAllVersions()
instead.Get.setMaxVersions
(int maxVersions) Deprecated.It is easy to misunderstand with column family's max versions, so usereadVersions(int)
instead.Get.setPriority
(int priority) Get.setReplicaId
(int Id) Get.setRowOffsetPerColumnFamily
(int offset) Set offset for the row per Column Family.Get.setTimeRange
(long minStamp, long maxStamp) Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).Get.setTimestamp
(long timestamp) Get versions of columns with the specified timestamp.Get.setTimeStamp
(long timestamp) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.(package private) static Get
ConnectionUtils.toCheckExistenceOnly
(Get get) Modifier and TypeMethodDescriptiondefault CompletableFuture<Boolean>
Test for the existence of columns in the table, as specified by the Get.boolean
default boolean
Test for the existence of columns in the table, as specified by the Get.Extracts certain cells from a given row.private Result
private CompletableFuture<Result>
default Result
Extracts certain cells from a given row.(package private) static Get
ConnectionUtils.toCheckExistenceOnly
(Get get) Modifier and TypeMethodDescriptiondefault List<CompletableFuture<Boolean>>
Test for the existence of columns in the table, as specified by the Gets.boolean[]
default boolean[]
Test for the existence of columns in the table, as specified by the Gets.default CompletableFuture<List<Boolean>>
A simple version for batch exists.default boolean[]
Deprecated.since 2.0 version and will be removed in 3.0 version.Extracts certain cells from the given rows, in batch.Result[]
default Result[]
Extracts specified cells from the given rows, as a batch.default CompletableFuture<List<Result>>
A simple version for batch get.ConnectionUtils.toCheckExistenceOnly
(List<Get> gets) ModifierConstructorDescriptionCopy-constructorRpcRetryingCallerWithReadReplicas
(RpcControllerFactory rpcControllerFactory, TableName tableName, ClusterConnection cConnection, Get get, ExecutorService pool, int retries, int operationTimeout, int rpcTimeout, int timeBeforeReplicas, Map<String, byte[]> requestAttributes) Builds a scan object with the same specs as get. -
Uses of Get in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault boolean
RegionObserver.postExists
(ObserverContext<RegionCoprocessorEnvironment> c, Get get, boolean exists) Called after the client tests for existence using a Get.default void
RegionObserver.postGetOp
(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) Called after the client performs a Getdefault boolean
RegionObserver.preExists
(ObserverContext<RegionCoprocessorEnvironment> c, Get get, boolean exists) Called before the client tests for existence using a Get.void
MetaTableMetrics.ExampleRegionObserverMeta.preGetOp
(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) default void
RegionObserver.preGetOp
(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) Called before the client performs a Getdefault void
RegionObserver.prePrepareTimeStampForDeleteVersion
(ObserverContext<RegionCoprocessorEnvironment> c, Mutation mutation, Cell cell, byte[] byteNow, Get get) Deprecated.Since hbase-2.0.0. -
Uses of Get in org.apache.hadoop.hbase.coprocessor.example
Modifier and TypeMethodDescriptionvoid
ExampleRegionObserverWithMetrics.ExampleRegionObserver.postGetOp
(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) void
ExampleRegionObserverWithMetrics.ExampleRegionObserver.preGetOp
(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) void
WriteHeavyIncrementObserver.preGetOp
(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) -
Uses of Get in org.apache.hadoop.hbase.mapreduce.replication
Modifier and TypeMethodDescriptionprivate boolean
VerifyReplicationRecompareRunnable.fetchLatestRows
(Get get) -
Uses of Get in org.apache.hadoop.hbase.master.region
-
Uses of Get in org.apache.hadoop.hbase.quotas
Modifier and TypeMethodDescription(package private) static Get
QuotaTableUtil.createGetNamespaceSnapshotSize
(String namespace) Creates aGet
to fetch the namespace's total snapshot size.static Get
QuotaTableUtil.makeGetForNamespaceQuotas
(String namespace) static Get
QuotaTableUtil.makeGetForRegionServerQuotas
(String regionServer) (package private) static Get
QuotaTableUtil.makeGetForSnapshotSize
(TableName tn, String snapshot) Creates aGet
for the HBase snapshot's size against the given table.static Get
QuotaTableUtil.makeGetForTableQuotas
(TableName table) static Get
QuotaTableUtil.makeGetForUserQuotas
(String user, Iterable<TableName> tables, Iterable<String> namespaces) static Get
QuotaTableUtil.makeQuotaSnapshotGetForTable
(TableName tn) Creates aGet
which returns onlySpaceQuotaSnapshot
from the quota table for a specific table.Modifier and TypeMethodDescriptionprotected static Result
QuotaTableUtil.doGet
(Connection connection, Get get) Modifier and TypeMethodDescriptionprotected static Result[]
QuotaTableUtil.doGet
(Connection connection, List<Get> gets) QuotaCache.Fetcher.fetchEntries
(List<Get> gets) static <K> Map<K,
QuotaState> QuotaUtil.fetchGlobalQuotas
(String type, Connection connection, List<Get> gets, QuotaUtil.KeyFromRow<K> kfr) static Map<String,
QuotaState> QuotaUtil.fetchNamespaceQuotas
(Connection connection, List<Get> gets, double factor) static Map<String,
QuotaState> QuotaUtil.fetchRegionServerQuotas
(Connection connection, List<Get> gets) static Map<TableName,
QuotaState> QuotaUtil.fetchTableQuotas
(Connection connection, List<Get> gets, Map<TableName, Double> tableMachineFactors) static Map<String,
UserQuotaState> QuotaUtil.fetchUserQuotas
(Connection connection, List<Get> gets, Map<TableName, Double> tableMachineQuotaFactors, double factor) -
Uses of Get in org.apache.hadoop.hbase.regionserver
Modifier and TypeMethodDescriptionDo a get based on the get parameter.Do a get based on the get parameter.private Result
RSRpcServices.get
(Get get, HRegion region, RSRpcServices.RegionScannersCloseCallBack closeCallBack, RpcCallContext context) HRegion.getInternal
(Get get, boolean withCoprocessor, long nonceGroup, long nonce) boolean
RegionCoprocessorHost.postExists
(Get get, boolean result) void
Supports Coprocessor 'bypass'.boolean
Supports Coprocessor 'bypass'.(package private) void
HRegion.prepareGet
(Get get) boolean
RegionCoprocessorHost.prePrepareTimeStampForDeleteVersion
(Mutation mutation, Cell kv, byte[] byteNow, Get get) Deprecated.In hbase-2.0.0.private void
HRegion.updateDeleteLatestVersionTimestamp
(Cell cell, Get get, int count, byte[] byteNow) -
Uses of Get in org.apache.hadoop.hbase.security.access
Modifier and TypeMethodDescriptionboolean
AccessController.preExists
(ObserverContext<RegionCoprocessorEnvironment> c, Get get, boolean exists) void
AccessController.preGetOp
(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) -
Uses of Get in org.apache.hadoop.hbase.security.visibility
Modifier and TypeMethodDescriptionvoid
VisibilityController.preGetOp
(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) void
VisibilityController.prePrepareTimeStampForDeleteVersion
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation delete, Cell cell, byte[] byteNow, Get get) -
Uses of Get in org.apache.hadoop.hbase.thrift2
Modifier and TypeMethodDescriptionstatic Get
ThriftUtilities.getFromThrift
(org.apache.hadoop.hbase.thrift2.generated.TGet in) Creates aGet
(HBase) from aTGet
(Thrift).Modifier and TypeMethodDescriptionThriftUtilities.getsFromThrift
(List<org.apache.hadoop.hbase.thrift2.generated.TGet> in) Converts multipleTGet
s (Thrift) into a list ofGet
s (HBase).Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.thrift2.generated.TGet
ThriftUtilities.getFromHBase
(Get in) Modifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.thrift2.generated.TGet>
ThriftUtilities.getsFromHBase
(List<Get> in) -
Uses of Get in org.apache.hadoop.hbase.thrift2.client
Modifier and TypeMethodDescriptionboolean