Uses of Class
org.apache.hadoop.hbase.quotas.RpcThrottlingException
Package
Description
Table of Contents
-
Uses of org.apache.hadoop.hbase.quotas.RpcThrottlingException in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.quotas.OperationQuota
RegionCoprocessorEnvironment.checkBatchQuota
(org.apache.hadoop.hbase.regionserver.Region region, int numWrites, int numReads) Check the quota for the current (rpc-context) user.org.apache.hadoop.hbase.quotas.OperationQuota
RegionCoprocessorEnvironment.checkBatchQuota
(org.apache.hadoop.hbase.regionserver.Region region, org.apache.hadoop.hbase.quotas.OperationQuota.OperationType type) Check the quota for the current (rpc-context) user.org.apache.hadoop.hbase.quotas.OperationQuota
RegionCoprocessorEnvironment.checkScanQuota
(org.apache.hadoop.hbase.client.Scan scan, long maxBlockBytesScanned, long prevBlockBytesScannedDifference) Check the quota for the current (rpc-context) user. -
Uses of org.apache.hadoop.hbase.quotas.RpcThrottlingException in org.apache.hadoop.hbase.quotas
Modifier and TypeMethodDescriptionvoid
DefaultOperationQuota.checkBatchQuota
(int numWrites, int numReads) void
ExceedOperationQuota.checkBatchQuota
(int numWrites, int numReads) void
OperationQuota.checkBatchQuota
(int numWrites, int numReads) Checks if it is possible to execute the specified operation.org.apache.hadoop.hbase.quotas.OperationQuota
RegionServerRpcQuotaManager.checkBatchQuota
(org.apache.hadoop.hbase.regionserver.Region region, int numWrites, int numReads) Check the quota for the current (rpc-context) user.org.apache.hadoop.hbase.quotas.OperationQuota
RegionServerRpcQuotaManager.checkBatchQuota
(org.apache.hadoop.hbase.regionserver.Region region, List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> actions, boolean hasCondition) org.apache.hadoop.hbase.quotas.OperationQuota
RegionServerRpcQuotaManager.checkBatchQuota
(org.apache.hadoop.hbase.regionserver.Region region, org.apache.hadoop.hbase.quotas.OperationQuota.OperationType type) org.apache.hadoop.hbase.quotas.OperationQuota
RpcQuotaManager.checkBatchQuota
(org.apache.hadoop.hbase.regionserver.Region region, int numWrites, int numReads) Check the quota for the current (rpc-context) user.org.apache.hadoop.hbase.quotas.OperationQuota
RpcQuotaManager.checkBatchQuota
(org.apache.hadoop.hbase.regionserver.Region region, List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> actions, boolean hasCondition) Check the quota for the current (rpc-context) user.org.apache.hadoop.hbase.quotas.OperationQuota
RpcQuotaManager.checkBatchQuota
(org.apache.hadoop.hbase.regionserver.Region region, org.apache.hadoop.hbase.quotas.OperationQuota.OperationType type) Check the quota for the current (rpc-context) user.void
QuotaLimiter.checkQuota
(long writeReqs, long estimateWriteSize, long readReqs, long estimateReadSize, long estimateWriteCapacityUnit, long estimateReadCapacityUnit) Checks if it is possible to execute the specified operation.void
TimeBasedLimiter.checkQuota
(long writeReqs, long estimateWriteSize, long readReqs, long estimateReadSize, long estimateWriteCapacityUnit, long estimateReadCapacityUnit) void
DefaultOperationQuota.checkScanQuota
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest scanRequest, long maxScannerResultSize, long maxBlockBytesScanned, long prevBlockBytesScannedDifference) void
ExceedOperationQuota.checkScanQuota
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest scanRequest, long maxScannerResultSize, long maxBlockBytesScanned, long prevBlockBytesScannedDifference) void
OperationQuota.checkScanQuota
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest scanRequest, long maxScannerResultSize, long maxBlockBytesScanned, long prevBlockBytesScannedDifference) Checks if it is possible to execute the scan.org.apache.hadoop.hbase.quotas.OperationQuota
RegionServerRpcQuotaManager.checkScanQuota
(org.apache.hadoop.hbase.regionserver.Region region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest scanRequest, long maxScannerResultSize, long maxBlockBytesScanned, long prevBlockBytesScannedDifference) org.apache.hadoop.hbase.quotas.OperationQuota
RpcQuotaManager.checkScanQuota
(org.apache.hadoop.hbase.regionserver.Region region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest scanRequest, long maxScannerResultSize, long maxBlockBytesScanned, long prevBlockBytesScannedDifference) Check the quota for the current (rpc-context) user.static void
RpcThrottlingException.throwNumReadRequestsExceeded
(long waitInterval) static void
RpcThrottlingException.throwNumRequestsExceeded
(long waitInterval) static void
RpcThrottlingException.throwNumWriteRequestsExceeded
(long waitInterval) static void
RpcThrottlingException.throwReadCapacityUnitExceeded
(long waitInterval) static void
RpcThrottlingException.throwReadSizeExceeded
(long waitInterval) static void
RpcThrottlingException.throwRequestCapacityUnitExceeded
(long waitInterval) static void
RpcThrottlingException.throwRequestSizeExceeded
(long waitInterval) static void
RpcThrottlingException.throwWriteCapacityUnitExceeded
(long waitInterval) static void
RpcThrottlingException.throwWriteSizeExceeded
(long waitInterval)