Uses of Class
org.apache.hadoop.hbase.client.Get
Packages that use Get
-
Uses of Get in org.apache.hadoop.hbase
Methods in org.apache.hadoop.hbase with parameters of type Get -
Uses of Get in org.apache.hadoop.hbase.backup.impl
Methods in org.apache.hadoop.hbase.backup.impl that return GetModifier and TypeMethodDescriptionprivate GetBackupSystemTable.createGetForBackupInfo(String backupId) Creates Get operation for a given backup idprivate GetBackupSystemTable.createGetForBackupSet(String name) Creates Get operation to load backup set contentprivate GetBackupSystemTable.createGetForDeleteOperation()private GetBackupSystemTable.createGetForIncrBackupTableSet(String backupRoot) Creates Get to retrieve incremental backup table set from backup system tableprivate GetBackupSystemTable.createGetForMergeOperation()private GetBackupSystemTable.createGetForStartCode(String rootPath) Creates Get operation to retrieve start code from backup system table -
Uses of Get in org.apache.hadoop.hbase.client
Fields in org.apache.hadoop.hbase.client declared as GetMethods in org.apache.hadoop.hbase.client that return GetModifier 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 GetConnectionUtils.toCheckExistenceOnly(Get get) Methods in org.apache.hadoop.hbase.client that return types with arguments of type GetMethods in org.apache.hadoop.hbase.client with parameters of type GetModifier and TypeMethodDescriptiondefault CompletableFuture<Boolean>Test for the existence of columns in the table, as specified by the Get.booleandefault booleanTest for the existence of columns in the table, as specified by the Get.Extracts certain cells from a given row.private Resultprivate CompletableFuture<Result>default ResultExtracts certain cells from a given row.(package private) static GetConnectionUtils.toCheckExistenceOnly(Get get) Method parameters in org.apache.hadoop.hbase.client with type arguments of type GetModifier 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) Constructors in org.apache.hadoop.hbase.client with parameters of type GetModifierConstructorDescriptionCopy-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
Methods in org.apache.hadoop.hbase.coprocessor with parameters of type GetModifier and TypeMethodDescriptiondefault booleanRegionObserver.postExists(ObserverContext<RegionCoprocessorEnvironment> c, Get get, boolean exists) Called after the client tests for existence using a Get.default voidRegionObserver.postGetOp(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) Called after the client performs a Getdefault booleanRegionObserver.preExists(ObserverContext<RegionCoprocessorEnvironment> c, Get get, boolean exists) Called before the client tests for existence using a Get.voidMetaTableMetrics.ExampleRegionObserverMeta.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) default voidRegionObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) Called before the client performs a Getdefault voidRegionObserver.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
Methods in org.apache.hadoop.hbase.coprocessor.example with parameters of type GetModifier and TypeMethodDescriptionvoidExampleRegionObserverWithMetrics.ExampleRegionObserver.postGetOp(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) voidExampleRegionObserverWithMetrics.ExampleRegionObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) voidWriteHeavyIncrementObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) -
Uses of Get in org.apache.hadoop.hbase.mapreduce.replication
Methods in org.apache.hadoop.hbase.mapreduce.replication with parameters of type GetModifier and TypeMethodDescriptionprivate booleanVerifyReplicationRecompareRunnable.fetchLatestRows(Get get) -
Uses of Get in org.apache.hadoop.hbase.master.region
Methods in org.apache.hadoop.hbase.master.region with parameters of type Get -
Uses of Get in org.apache.hadoop.hbase.quotas
Methods in org.apache.hadoop.hbase.quotas that return GetModifier and TypeMethodDescription(package private) static GetQuotaTableUtil.createGetNamespaceSnapshotSize(String namespace) Creates aGetto fetch the namespace's total snapshot size.static GetQuotaTableUtil.makeGetForNamespaceQuotas(String namespace) static GetQuotaTableUtil.makeGetForRegionServerQuotas(String regionServer) (package private) static GetQuotaTableUtil.makeGetForSnapshotSize(TableName tn, String snapshot) Creates aGetfor the HBase snapshot's size against the given table.static GetQuotaTableUtil.makeGetForTableQuotas(TableName table) static GetQuotaTableUtil.makeGetForUserQuotas(String user, Iterable<TableName> tables, Iterable<String> namespaces) static GetQuotaTableUtil.makeQuotaSnapshotGetForTable(TableName tn) Creates aGetwhich returns onlySpaceQuotaSnapshotfrom the quota table for a specific table.Methods in org.apache.hadoop.hbase.quotas with parameters of type GetModifier and TypeMethodDescriptionprotected static ResultQuotaTableUtil.doGet(Connection connection, Get get) Method parameters in org.apache.hadoop.hbase.quotas with type arguments of type GetModifier 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
Methods in org.apache.hadoop.hbase.regionserver that return GetMethods in org.apache.hadoop.hbase.regionserver with parameters of type GetModifier and TypeMethodDescriptionDo a get based on the get parameter.Do a get based on the get parameter.private ResultRSRpcServices.get(Get get, HRegion region, RSRpcServices.RegionScannersCloseCallBack closeCallBack, RpcCallContext context) HRegion.getInternal(Get get, boolean withCoprocessor, long nonceGroup, long nonce) booleanRegionCoprocessorHost.postExists(Get get, boolean result) voidSupports Coprocessor 'bypass'.booleanSupports Coprocessor 'bypass'.(package private) voidHRegion.prepareGet(Get get) booleanRegionCoprocessorHost.prePrepareTimeStampForDeleteVersion(Mutation mutation, Cell kv, byte[] byteNow, Get get) Deprecated.In hbase-2.0.0.private voidHRegion.updateDeleteLatestVersionTimestamp(Cell cell, Get get, int count, byte[] byteNow) Constructors in org.apache.hadoop.hbase.regionserver with parameters of type Get -
Uses of Get in org.apache.hadoop.hbase.security.access
Methods in org.apache.hadoop.hbase.security.access with parameters of type GetModifier and TypeMethodDescriptionbooleanAccessController.preExists(ObserverContext<RegionCoprocessorEnvironment> c, Get get, boolean exists) voidAccessController.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) -
Uses of Get in org.apache.hadoop.hbase.security.visibility
Methods in org.apache.hadoop.hbase.security.visibility with parameters of type GetModifier and TypeMethodDescriptionvoidVisibilityController.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) voidVisibilityController.prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation delete, Cell cell, byte[] byteNow, Get get) -
Uses of Get in org.apache.hadoop.hbase.thrift2
Methods in org.apache.hadoop.hbase.thrift2 that return GetModifier and TypeMethodDescriptionstatic GetThriftUtilities.getFromThrift(org.apache.hadoop.hbase.thrift2.generated.TGet in) Creates aGet(HBase) from aTGet(Thrift).Methods in org.apache.hadoop.hbase.thrift2 that return types with arguments of type GetModifier and TypeMethodDescriptionThriftUtilities.getsFromThrift(List<org.apache.hadoop.hbase.thrift2.generated.TGet> in) Converts multipleTGets (Thrift) into a list ofGets (HBase).Methods in org.apache.hadoop.hbase.thrift2 with parameters of type GetModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.thrift2.generated.TGetThriftUtilities.getFromHBase(Get in) Method parameters in org.apache.hadoop.hbase.thrift2 with type arguments of type GetModifier 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
Methods in org.apache.hadoop.hbase.thrift2.client with parameters of type GetModifier and TypeMethodDescriptionbooleanMethod parameters in org.apache.hadoop.hbase.thrift2.client with type arguments of type Get