static org.apache.hadoop.hbase.quotas.QuotaLimiter
QuotaLimiterFactory.fromThrottle(org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Throttle throttle)
org.apache.hadoop.hbase.quotas.QuotaLimiter
QuotaState.getGlobalLimiter()
Return the limiter associated with this quota.
org.apache.hadoop.hbase.quotas.QuotaLimiter
QuotaCache.getNamespaceLimiter(String namespace)
Returns the limiter associated to the specified namespace.
org.apache.hadoop.hbase.quotas.QuotaLimiter
QuotaCache.getRegionServerQuotaLimiter(String regionServer)
Returns the limiter associated to the specified region server.
org.apache.hadoop.hbase.quotas.QuotaLimiter
QuotaCache.getTableLimiter(org.apache.hadoop.hbase.TableName table)
Returns the limiter associated to the specified table.
org.apache.hadoop.hbase.quotas.QuotaLimiter
UserQuotaState.getTableLimiter(org.apache.hadoop.hbase.TableName table)
Return the limiter for the specified table associated with this quota.
org.apache.hadoop.hbase.quotas.QuotaLimiter
QuotaCache.getUserLimiter(org.apache.hadoop.security.UserGroupInformation ugi,
org.apache.hadoop.hbase.TableName table)
Returns the limiter associated to the specified user/table.
static org.apache.hadoop.hbase.quotas.QuotaLimiter
QuotaLimiterFactory.update(org.apache.hadoop.hbase.quotas.QuotaLimiter a,
org.apache.hadoop.hbase.quotas.QuotaLimiter b)
static org.apache.hadoop.hbase.quotas.QuotaLimiter
QuotaLimiterFactory.update(org.apache.hadoop.hbase.quotas.QuotaLimiter a,
org.apache.hadoop.hbase.quotas.QuotaLimiter b)
DefaultOperationQuota(org.apache.hadoop.conf.Configuration conf,
int blockSizeBytes,
org.apache.hadoop.hbase.quotas.QuotaLimiter... limiters)
ExceedOperationQuota(org.apache.hadoop.conf.Configuration conf,
int blockSizeBytes,
org.apache.hadoop.hbase.quotas.QuotaLimiter regionServerLimiter,
org.apache.hadoop.hbase.quotas.QuotaLimiter... limiters)