Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.coprocessor.example | |
org.apache.hadoop.hbase.quotas | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.rest.client | |
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.security.visibility | |
org.apache.hadoop.hbase.thrift2 |
Provides an HBase Thrift
service.
|
org.apache.hadoop.hbase.thrift2.client |
Modifier and Type | Method and Description |
---|---|
private static Result |
MetaTableAccessor.get(Table t,
Get g) |
Modifier and Type | Field and Description |
---|---|
protected Get |
RpcRetryingCallerWithReadReplicas.get |
Modifier and Type | Method and Description |
---|---|
Get |
Get.addColumn(byte[] family,
byte[] qualifier)
Get the column from the specific family with the specified qualifier.
|
Get |
Get.addFamily(byte[] family)
Get all columns from the specified family.
|
Get |
Get.readAllVersions()
Get all available versions.
|
Get |
Get.readVersions(int versions)
Get up to the specified number of versions of each column.
|
Get |
Get.setACL(Map<String,Permission> perms) |
Get |
Get.setACL(String user,
Permission perms) |
Get |
Get.setAttribute(String name,
byte[] value) |
Get |
Get.setAuthorizations(Authorizations authorizations) |
Get |
Get.setCacheBlocks(boolean cacheBlocks)
Set whether blocks should be cached for this Get.
|
Get |
Get.setCheckExistenceOnly(boolean checkExistenceOnly) |
Get |
Get.setClosestRowBefore(boolean closestRowBefore)
Deprecated.
since 2.0.0 and will be removed in 3.0.0
|
Get |
Get.setColumnFamilyTimeRange(byte[] cf,
long minStamp,
long maxStamp) |
Get |
Get.setConsistency(Consistency consistency) |
Get |
Get.setFilter(Filter filter) |
Get |
Get.setId(String id) |
Get |
Get.setIsolationLevel(IsolationLevel level) |
Get |
Get.setLoadColumnFamiliesOnDemand(boolean value) |
Get |
Get.setMaxResultsPerColumnFamily(int limit)
Set the maximum number of values to return per row per Column Family
|
Get |
Get.setMaxVersions()
Deprecated.
It is easy to misunderstand with column family's max versions, so use
readAllVersions() instead. |
Get |
Get.setMaxVersions(int maxVersions)
Deprecated.
It is easy to misunderstand with column family's max versions, so use
readVersions(int) instead. |
Get |
Get.setPriority(int priority) |
Get |
Get.setReplicaId(int Id) |
Get |
Get.setRowOffsetPerColumnFamily(int offset)
Set offset for the row per Column Family.
|
Get |
Get.setTimeRange(long minStamp,
long maxStamp)
Get versions of columns only within the specified timestamp range,
[minStamp, maxStamp).
|
Get |
Get.setTimestamp(long timestamp)
Get versions of columns with the specified timestamp.
|
Get |
Get.setTimeStamp(long timestamp)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
setTimestamp(long) instead |
(package private) static Get |
ConnectionUtils.toCheckExistenceOnly(Get get) |
Modifier and Type | Method and Description |
---|---|
(package private) static List<Get> |
ConnectionUtils.toCheckExistenceOnly(List<Get> gets) |
Modifier and Type | Method and Description |
---|---|
boolean |
HTable.exists(Get get) |
default CompletableFuture<Boolean> |
AsyncTable.exists(Get get)
Test for the existence of columns in the table, as specified by the Get.
|
default boolean |
Table.exists(Get get)
Test for the existence of columns in the table, as specified by the Get.
|
Result |
HTable.get(Get get) |
CompletableFuture<Result> |
AsyncTable.get(Get get)
Extracts certain cells from a given row.
|
default Result |
Table.get(Get get)
Extracts certain cells from a given row.
|
CompletableFuture<Result> |
RawAsyncTableImpl.get(Get get) |
CompletableFuture<Result> |
AsyncTableImpl.get(Get get) |
private Result |
HTable.get(Get get,
boolean checkExistenceOnly) |
private CompletableFuture<Result> |
RawAsyncTableImpl.get(Get get,
int replicaId) |
(package private) static Get |
ConnectionUtils.toCheckExistenceOnly(Get get) |
Modifier and Type | Method and Description |
---|---|
boolean[] |
HTable.exists(List<Get> gets) |
default List<CompletableFuture<Boolean>> |
AsyncTable.exists(List<Get> gets)
Test for the existence of columns in the table, as specified by the Gets.
|
default boolean[] |
Table.exists(List<Get> gets)
Test for the existence of columns in the table, as specified by the Gets.
|
default CompletableFuture<List<Boolean>> |
AsyncTable.existsAll(List<Get> gets)
A simple version for batch exists.
|
default boolean[] |
Table.existsAll(List<Get> gets)
Deprecated.
since 2.0 version and will be removed in 3.0 version.
use
Table.exists(List) |
Result[] |
HTable.get(List<Get> gets) |
List<CompletableFuture<Result>> |
AsyncTable.get(List<Get> gets)
Extracts certain cells from the given rows, in batch.
|
default Result[] |
Table.get(List<Get> gets)
Extracts specified cells from the given rows, as a batch.
|
List<CompletableFuture<Result>> |
RawAsyncTableImpl.get(List<Get> gets) |
List<CompletableFuture<Result>> |
AsyncTableImpl.get(List<Get> gets) |
default CompletableFuture<List<Result>> |
AsyncTable.getAll(List<Get> gets)
A simple version for batch get.
|
(package private) static List<Get> |
ConnectionUtils.toCheckExistenceOnly(List<Get> gets) |
Constructor and Description |
---|
Get(Get get)
Copy-constructor
|
RpcRetryingCallerWithReadReplicas(RpcControllerFactory rpcControllerFactory,
TableName tableName,
ClusterConnection cConnection,
Get get,
ExecutorService pool,
int retries,
int operationTimeout,
int rpcTimeout,
int timeBeforeReplicas) |
Scan(Get get)
Builds a scan object with the same specs as get.
|
Modifier and Type | Method and Description |
---|---|
default 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 Get
|
default boolean |
RegionObserver.preExists(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
boolean exists)
Called before the client tests for existence using a Get.
|
default void |
RegionObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result)
Called before the client performs a Get
|
void |
MetaTableMetrics.ExampleRegionObserverMeta.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
default void |
RegionObserver.prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> c,
Mutation mutation,
Cell cell,
byte[] byteNow,
Get get)
Deprecated.
Since hbase-2.0.0. No replacement. To be removed in hbase-3.0.0 and replaced
with something that doesn't expose IntefaceAudience.Private classes.
|
Modifier and Type | Method and Description |
---|---|
void |
ExampleRegionObserverWithMetrics.ExampleRegionObserver.postGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
void |
WriteHeavyIncrementObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result) |
void |
ExampleRegionObserverWithMetrics.ExampleRegionObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
Modifier and Type | Method and Description |
---|---|
(package private) static Get |
QuotaTableUtil.createGetNamespaceSnapshotSize(String namespace)
Creates a
Get to fetch the namespace's total snapshot size. |
Get |
QuotaCache.Fetcher.makeGet(Map.Entry<Key,Value> entry) |
static Get |
QuotaTableUtil.makeGetForNamespaceQuotas(String namespace) |
static Get |
QuotaTableUtil.makeGetForRegionServerQuotas(String regionServer) |
(package private) static Get |
QuotaTableUtil.makeGetForSnapshotSize(TableName tn,
String snapshot)
Creates a
Get 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 a
Get which returns only SpaceQuotaSnapshot from the quota table for a
specific table. |
Modifier and Type | Method and Description |
---|---|
protected static Result |
QuotaTableUtil.doGet(Connection connection,
Get get) |
Modifier and Type | Method and Description |
---|---|
protected static Result[] |
QuotaTableUtil.doGet(Connection connection,
List<Get> gets) |
Map<Key,Value> |
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) |
Modifier and Type | Method and Description |
---|---|
Result |
Region.get(Get get)
Do a get based on the get parameter.
|
Result |
HRegion.get(Get get) |
List<Cell> |
Region.get(Get get,
boolean withCoprocessor)
Do a get based on the get parameter.
|
List<Cell> |
HRegion.get(Get get,
boolean withCoprocessor) |
List<Cell> |
HRegion.get(Get get,
boolean withCoprocessor,
long nonceGroup,
long nonce) |
private Result |
RSRpcServices.get(Get get,
HRegion region,
RSRpcServices.RegionScannersCloseCallBack closeCallBack,
RpcCallContext context) |
boolean |
RegionCoprocessorHost.postExists(Get get,
boolean result) |
void |
RegionCoprocessorHost.postGet(Get get,
List<Cell> results) |
Boolean |
RegionCoprocessorHost.preExists(Get get)
Supports Coprocessor 'bypass'.
|
boolean |
RegionCoprocessorHost.preGet(Get get,
List<Cell> results)
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. Will be removed in hbase-3.0.0. Added explicitly for a single
Coprocessor for its needs only. Will be removed.
|
(package private) void |
HRegion.updateDeleteLatestVersionTimestamp(Cell cell,
Get get,
int count,
byte[] byteNow) |
Constructor and Description |
---|
InternalScan(Get get) |
Modifier and Type | Method and Description |
---|---|
boolean |
RemoteHTable.exists(Get get) |
Result |
RemoteHTable.get(Get get) |
Modifier and Type | Method and Description |
---|---|
boolean[] |
RemoteHTable.exists(List<Get> gets) |
Result[] |
RemoteHTable.get(List<Get> gets) |
Modifier and Type | Method and Description |
---|---|
boolean |
AccessController.preExists(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
boolean exists) |
void |
AccessController.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result) |
Modifier and Type | Method and Description |
---|---|
void |
VisibilityController.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
void |
VisibilityController.prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation delete,
Cell cell,
byte[] byteNow,
Get get) |
Modifier and Type | Method and Description |
---|---|
static Get |
ThriftUtilities.getFromThrift(org.apache.hadoop.hbase.thrift2.generated.TGet in)
Creates a
Get (HBase) from a TGet (Thrift). |
Modifier and Type | Method and Description |
---|---|
static List<Get> |
ThriftUtilities.getsFromThrift(List<org.apache.hadoop.hbase.thrift2.generated.TGet> in)
Converts multiple
TGet s (Thrift) into a list of Get s (HBase). |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hbase.thrift2.generated.TGet |
ThriftUtilities.getFromHBase(Get in) |
Modifier and Type | Method and Description |
---|---|
static List<org.apache.hadoop.hbase.thrift2.generated.TGet> |
ThriftUtilities.getsFromHBase(List<Get> in) |
Modifier and Type | Method and Description |
---|---|
boolean |
ThriftTable.exists(Get get) |
Result |
ThriftTable.get(Get get) |
Modifier and Type | Method and Description |
---|---|
boolean[] |
ThriftTable.exists(List<Get> gets) |
Result[] |
ThriftTable.get(List<Get> gets) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.