| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.client | 
 Provides HBase Client 
 | 
| org.apache.hadoop.hbase.quotas | |
| org.apache.hadoop.hbase.thrift2.client | 
| Modifier and Type | Method and Description | 
|---|---|
List<QuotaSettings> | 
Admin.getQuota(QuotaFilter filter)
List the quotas based on the filter. 
 | 
CompletableFuture<List<QuotaSettings>> | 
AsyncAdmin.getQuota(QuotaFilter filter)
List the quotas based on the filter. 
 | 
CompletableFuture<List<QuotaSettings>> | 
RawAsyncHBaseAdmin.getQuota(QuotaFilter filter)  | 
CompletableFuture<List<QuotaSettings>> | 
AsyncHBaseAdmin.getQuota(QuotaFilter filter)  | 
List<QuotaSettings> | 
HBaseAdmin.getQuota(QuotaFilter filter)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
Admin.setQuota(QuotaSettings quota)
Apply the new quota settings. 
 | 
CompletableFuture<Void> | 
AsyncAdmin.setQuota(QuotaSettings quota)
Apply the new quota settings. 
 | 
CompletableFuture<Void> | 
RawAsyncHBaseAdmin.setQuota(QuotaSettings quota)  | 
CompletableFuture<Void> | 
AsyncHBaseAdmin.setQuota(QuotaSettings quota)  | 
void | 
HBaseAdmin.setQuota(QuotaSettings quota)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
GlobalQuotaSettings
An object which captures all quotas types (throttle or space) for a subject (user, table, or
 namespace). 
 | 
class  | 
GlobalQuotaSettingsImpl
Implementation of  
GlobalQuotaSettings to hide the Protobuf messages we use internally. | 
(package private) static class  | 
QuotaSettingsFactory.QuotaGlobalsSettingsBypass  | 
(package private) class  | 
SpaceLimitSettings
A  
QuotaSettings implementation for configuring filesystem-use quotas. | 
class  | 
ThrottleSettings  | 
| Modifier and Type | Field and Description | 
|---|---|
(package private) QuotaSettings | 
QuotaRetriever.Iter.cache  | 
| Modifier and Type | Field and Description | 
|---|---|
private Queue<QuotaSettings> | 
QuotaRetriever.cache  | 
| Modifier and Type | Method and Description | 
|---|---|
static QuotaSettings | 
QuotaSettings.buildFromProto(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaRequest request)
Converts the protocol buffer request into a QuotaSetting POJO. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.bypassGlobals(String userName,
             boolean bypassGlobals)
Set the "bypass global settings" for the specified user 
 | 
(package private) static QuotaSettings | 
QuotaSettingsFactory.fromSpace(TableName table,
         String namespace,
         org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota protoQuota)  | 
static QuotaSettings | 
QuotaSettingsFactory.limitNamespaceSpace(String namespace,
                   long sizeLimit,
                   SpaceViolationPolicy violationPolicy)
Creates a  
QuotaSettings object to limit the FileSystem space usage for the given
 namespace to the given size in bytes. | 
static QuotaSettings | 
QuotaSettingsFactory.limitTableSpace(TableName tableName,
               long sizeLimit,
               SpaceViolationPolicy violationPolicy)
Creates a  
QuotaSettings object to limit the FileSystem space usage for the given table
 to the given size in bytes. | 
protected QuotaSettings | 
SpaceLimitSettings.merge(QuotaSettings newSettings)  | 
(package private) abstract QuotaSettings | 
QuotaSettings.merge(QuotaSettings newSettings)
Merges the provided settings with  
this and returns a new settings
 object to the caller if the merged settings differ from the original. | 
QuotaSettings | 
QuotaRetriever.next()  | 
QuotaSettings | 
QuotaRetriever.Iter.next()  | 
static QuotaSettings | 
QuotaSettingsFactory.removeNamespaceSpaceLimit(String namespace)
Creates a  
QuotaSettings object to remove the FileSystem space quota for the given
 namespace. | 
static QuotaSettings | 
QuotaSettingsFactory.removeTableSpaceLimit(TableName tableName)
Creates a  
QuotaSettings object to remove the FileSystem space quota for the given
 table. | 
private static QuotaSettings | 
QuotaSettingsFactory.throttle(String userName,
        TableName tableName,
        String namespace,
        String regionServer,
        ThrottleType type,
        long limit,
        TimeUnit timeUnit,
        QuotaScope scope)  | 
static QuotaSettings | 
QuotaSettingsFactory.throttleNamespace(String namespace,
                 ThrottleType type,
                 long limit,
                 TimeUnit timeUnit)
Throttle the specified namespace. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.throttleNamespace(String namespace,
                 ThrottleType type,
                 long limit,
                 TimeUnit timeUnit,
                 QuotaScope scope)
Throttle the specified namespace. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.throttleRegionServer(String regionServer,
                    ThrottleType type,
                    long limit,
                    TimeUnit timeUnit)
Throttle the specified region server. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.throttleTable(TableName tableName,
             ThrottleType type,
             long limit,
             TimeUnit timeUnit)
Throttle the specified table. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.throttleTable(TableName tableName,
             ThrottleType type,
             long limit,
             TimeUnit timeUnit,
             QuotaScope scope)
Throttle the specified table. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.throttleUser(String userName,
            String namespace,
            ThrottleType type,
            long limit,
            TimeUnit timeUnit)
Throttle the specified user on the specified namespace. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.throttleUser(String userName,
            String namespace,
            ThrottleType type,
            long limit,
            TimeUnit timeUnit,
            QuotaScope scope)
Throttle the specified user on the specified namespace. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.throttleUser(String userName,
            TableName tableName,
            ThrottleType type,
            long limit,
            TimeUnit timeUnit)
Throttle the specified user on the specified table. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.throttleUser(String userName,
            TableName tableName,
            ThrottleType type,
            long limit,
            TimeUnit timeUnit,
            QuotaScope scope)
Throttle the specified user on the specified table. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.throttleUser(String userName,
            ThrottleType type,
            long limit,
            TimeUnit timeUnit)
Throttle the specified user. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.throttleUser(String userName,
            ThrottleType type,
            long limit,
            TimeUnit timeUnit,
            QuotaScope scope)
Throttle the specified user. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.unthrottleNamespace(String namespace)
Remove the throttling for the specified namespace. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.unthrottleNamespaceByThrottleType(String namespace,
                                 ThrottleType type)
Remove the throttling for the specified namespace by throttle type. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.unthrottleRegionServer(String regionServer)
Remove the throttling for the specified region server. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.unthrottleRegionServerByThrottleType(String regionServer,
                                    ThrottleType type)
Remove the throttling for the specified region server by throttle type. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.unthrottleTable(TableName tableName)
Remove the throttling for the specified table. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.unthrottleTableByThrottleType(TableName tableName,
                             ThrottleType type)
Remove the throttling for the specified table. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.unthrottleUser(String userName)
Remove the throttling for the specified user. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.unthrottleUser(String userName,
              String namespace)
Remove the throttling for the specified user on the specified namespace. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.unthrottleUser(String userName,
              TableName tableName)
Remove the throttling for the specified user on the specified table. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.unthrottleUserByThrottleType(String userName,
                            String namespace,
                            ThrottleType type)
Remove the throttling for the specified user on the specified namespace. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.unthrottleUserByThrottleType(String userName,
                            TableName tableName,
                            ThrottleType type)
Remove the throttling for the specified user on the specified table. 
 | 
static QuotaSettings | 
QuotaSettingsFactory.unthrottleUserByThrottleType(String userName,
                            ThrottleType type)
Remove the throttling for the specified user. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
(package private) static List<QuotaSettings> | 
QuotaSettingsFactory.fromNamespaceQuotas(String namespace,
                   org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas)  | 
private static List<QuotaSettings> | 
QuotaSettingsFactory.fromQuotas(String userName,
          TableName tableName,
          String namespace,
          String regionServer,
          org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas)  | 
(package private) static List<QuotaSettings> | 
QuotaSettingsFactory.fromRegionServerQuotas(String regionServer,
                      org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas)  | 
(package private) static List<QuotaSettings> | 
QuotaSettingsFactory.fromTableQuotas(TableName tableName,
               org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas)  | 
(package private) static List<QuotaSettings> | 
QuotaSettingsFactory.fromUserQuotas(String userName,
              org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas)  | 
(package private) static List<QuotaSettings> | 
QuotaSettingsFactory.fromUserQuotas(String userName,
              String namespace,
              org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas)  | 
(package private) static List<QuotaSettings> | 
QuotaSettingsFactory.fromUserQuotas(String userName,
              TableName tableName,
              org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas)  | 
List<QuotaSettings> | 
GlobalQuotaSettingsImpl.getQuotaSettings()  | 
abstract List<QuotaSettings> | 
GlobalQuotaSettings.getQuotaSettings()
Computes a list of QuotaSettings that present the complete quota state of the combination of
 this user, table, and/or namespace. 
 | 
Iterator<QuotaSettings> | 
QuotaRetriever.iterator()  | 
| Modifier and Type | Method and Description | 
|---|---|
static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaRequest | 
QuotaSettings.buildSetQuotaRequestProto(QuotaSettings settings)
Convert a QuotaSettings to a protocol buffer SetQuotaRequest. 
 | 
protected QuotaSettingsFactory.QuotaGlobalsSettingsBypass | 
QuotaSettingsFactory.QuotaGlobalsSettingsBypass.merge(QuotaSettings newSettings)  | 
protected QuotaSettings | 
SpaceLimitSettings.merge(QuotaSettings newSettings)  | 
protected ThrottleSettings | 
ThrottleSettings.merge(QuotaSettings other)  | 
(package private) abstract QuotaSettings | 
QuotaSettings.merge(QuotaSettings newSettings)
Merges the provided settings with  
this and returns a new settings
 object to the caller if the merged settings differ from the original. | 
protected GlobalQuotaSettingsImpl | 
GlobalQuotaSettingsImpl.merge(QuotaSettings other)  | 
(package private) void | 
QuotaSettings.validateQuotaTarget(QuotaSettings mergee)
Validates that settings being merged into  
this is targeting the same "subject", e.g. | 
| Modifier and Type | Method and Description | 
|---|---|
static void | 
QuotaTableUtil.parseResultToCollection(Result result,
                       Collection<QuotaSettings> quotaSettings)  | 
| Modifier and Type | Method and Description | 
|---|---|
List<QuotaSettings> | 
ThriftAdmin.getQuota(QuotaFilter filter)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ThriftAdmin.setQuota(QuotaSettings quota)  | 
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.