Uses of Class
org.apache.hadoop.hbase.client.Get
Packages that use org.apache.hadoop.hbase.client.Get
Package
Description
Provides HBase Client
Table of Contents
-
Uses of org.apache.hadoop.hbase.client.Get in org.apache.hadoop.hbase
Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.client.Get in inModifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.Cell>HBaseTestingUtility.getFromStoreFile(org.apache.hadoop.hbase.regionserver.HStore store, org.apache.hadoop.hbase.client.Get get) Deprecated.Do a small get/scan against one store. -
Uses of org.apache.hadoop.hbase.client.Get in org.apache.hadoop.hbase.client
Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.client.Get in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.GetGet.addColumn(byte[] family, byte[] qualifier) Get the column from the specific family with the specified qualifier.org.apache.hadoop.hbase.client.GetGet.addFamily(byte[] family) Get all columns from the specified family.org.apache.hadoop.hbase.client.GetGet.readAllVersions()Get all available versions.org.apache.hadoop.hbase.client.GetGet.readVersions(int versions) Get up to the specified number of versions of each column.org.apache.hadoop.hbase.client.GetGet.setACL(String user, org.apache.hadoop.hbase.security.access.Permission perms) org.apache.hadoop.hbase.client.Getorg.apache.hadoop.hbase.client.GetGet.setAttribute(String name, byte[] value) org.apache.hadoop.hbase.client.GetGet.setAuthorizations(org.apache.hadoop.hbase.security.visibility.Authorizations authorizations) org.apache.hadoop.hbase.client.GetGet.setCacheBlocks(boolean cacheBlocks) Set whether blocks should be cached for this Get.org.apache.hadoop.hbase.client.GetGet.setCheckExistenceOnly(boolean checkExistenceOnly) org.apache.hadoop.hbase.client.GetGet.setColumnFamilyTimeRange(byte[] cf, long minStamp, long maxStamp) org.apache.hadoop.hbase.client.GetGet.setConsistency(org.apache.hadoop.hbase.client.Consistency consistency) org.apache.hadoop.hbase.client.GetGet.setFilter(org.apache.hadoop.hbase.filter.Filter filter) org.apache.hadoop.hbase.client.GetGet.setId(String id) org.apache.hadoop.hbase.client.GetGet.setIsolationLevel(org.apache.hadoop.hbase.client.IsolationLevel level) org.apache.hadoop.hbase.client.GetGet.setLoadColumnFamiliesOnDemand(boolean value) org.apache.hadoop.hbase.client.GetGet.setMaxResultsPerColumnFamily(int limit) Set the maximum number of values to return per row per Column Familyorg.apache.hadoop.hbase.client.GetGet.setPriority(int priority) org.apache.hadoop.hbase.client.GetGet.setReplicaId(int Id) org.apache.hadoop.hbase.client.GetGet.setRowOffsetPerColumnFamily(int offset) Set offset for the row per Column Family.org.apache.hadoop.hbase.client.GetGet.setTimeRange(long minStamp, long maxStamp) Get versions of columns only within the specified timestamp range, [minStamp, maxStamp).org.apache.hadoop.hbase.client.GetGet.setTimestamp(long timestamp) Get versions of columns with the specified timestamp.Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.client.Get in inModifier and TypeMethodDescriptiondefault CompletableFuture<Boolean>AsyncTable.exists(org.apache.hadoop.hbase.client.Get get) Test for the existence of columns in the table, as specified by the Get.default booleanTable.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.default org.apache.hadoop.hbase.client.ResultTable.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 inModifier and TypeMethodDescriptiondefault List<CompletableFuture<Boolean>>AsyncTable.exists(List<org.apache.hadoop.hbase.client.Get> gets) Test for the existence of columns in the table, as specified by the 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.default CompletableFuture<List<Boolean>>AsyncTable.existsAll(List<org.apache.hadoop.hbase.client.Get> gets) A simple version for batch exists.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.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 inModifierConstructorDescriptionGet(org.apache.hadoop.hbase.client.Get get) Copy-constructorScan(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 inModifier and TypeMethodDescriptiondefault booleanRegionObserver.postExists(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends 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 voidRegionObserver.postGetOp(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends 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 Getdefault booleanRegionObserver.preExists(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends 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 voidRegionObserver.preGetOp(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends 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 Getdefault voidRegionObserver.prePrepareTimeStampForDeleteVersion(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends 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 inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.GetQuotaTableUtil.makeQuotaSnapshotGetForTable(org.apache.hadoop.hbase.TableName tn) Creates aGetwhich returns onlySpaceQuotaSnapshotfrom 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 inModifier and TypeMethodDescriptionprotected static org.apache.hadoop.hbase.client.ResultQuotaTableUtil.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 inModifier and TypeMethodDescriptionprotected static org.apache.hadoop.hbase.client.Result[]QuotaTableUtil.doGet(org.apache.hadoop.hbase.client.Connection connection, List<org.apache.hadoop.hbase.client.Get> gets) -
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 inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.ResultHRegion.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.ResultRegion.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.booleanRegionCoprocessorHost.postExists(org.apache.hadoop.hbase.client.Get get, boolean result) voidRegionCoprocessorHost.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'.booleanRegionCoprocessorHost.preGet(org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> results) Supports Coprocessor 'bypass'.booleanRegionCoprocessorHost.prePrepareTimeStampForDeleteVersion(org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell kv, byte[] byteNow, org.apache.hadoop.hbase.client.Get get) Supports Coprocessor 'bypass'.Constructors in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.client.Get in inModifierConstructorDescriptionInternalScan(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 inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.GetProtobufUtil.toGet(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Get proto) Convert a protocol buffer Get to a client GetMethods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.client.Get in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.GetRequestRequestConverter.buildGetRequest(byte[] regionName, org.apache.hadoop.hbase.client.Get get) Create a protocol buffer GetRequest for a client Getstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.GetProtobufUtil.toGet(org.apache.hadoop.hbase.client.Get get) Create a protocol buffer Get based on a client Get. -
Uses of org.apache.hadoop.hbase.client.Get in org.apache.hadoop.hbase.util
Methods in org.apache.hadoop.hbase.util that return org.apache.hadoop.hbase.client.Get in inModifier and TypeMethodDescriptionprotected org.apache.hadoop.hbase.client.GetMultiThreadedReader.HBaseReaderThread.createGet(long keyToRead) Methods in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.client.Get in inModifier and TypeMethodDescriptionprotected org.apache.hadoop.hbase.client.ResultMultiThreadedUpdater.HBaseUpdaterThread.getRow(org.apache.hadoop.hbase.client.Get get, long rowKeyBase, byte[] cf) protected org.apache.hadoop.hbase.client.ResultMultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL.getRow(org.apache.hadoop.hbase.client.Get get, long rowKeyBase, byte[] cf) voidMultiThreadedReader.HBaseReaderThread.queryKey(org.apache.hadoop.hbase.client.Get[] gets, boolean verify, long[] keysToRead) voidMultiThreadedReader.HBaseReaderThread.queryKey(org.apache.hadoop.hbase.client.Get get, boolean verify, long keyToRead) voidMultiThreadedReaderWithACL.HBaseReaderThreadWithACL.queryKey(org.apache.hadoop.hbase.client.Get get, boolean verify, long keyToRead) protected voidMultiThreadedReader.HBaseReaderThread.verifyResultsAndUpdateMetrics(boolean verify, org.apache.hadoop.hbase.client.Get[] gets, long elapsedNano, org.apache.hadoop.hbase.client.Result[] results, org.apache.hadoop.hbase.client.Table table, boolean isNullExpected) protected voidMultiThreadedReader.HBaseReaderThread.verifyResultsAndUpdateMetrics(boolean verify, org.apache.hadoop.hbase.client.Get get, long elapsedNano, org.apache.hadoop.hbase.client.Result result, org.apache.hadoop.hbase.client.Table table, boolean isNullExpected)