Uses of Class
org.apache.hadoop.hbase.quotas.RpcThrottlingException
Packages that use RpcThrottlingException
Package
Description
Table of Contents
- 
Uses of RpcThrottlingException in org.apache.hadoop.hbase.coprocessorMethods in org.apache.hadoop.hbase.coprocessor that throw RpcThrottlingExceptionModifier and TypeMethodDescriptionRegionCoprocessorEnvironment.checkBatchQuota(Region region, int numWrites, int numReads) Check the quota for the current (rpc-context) user.RegionCoprocessorEnvironment.checkBatchQuota(Region region, OperationQuota.OperationType type) Check the quota for the current (rpc-context) user.RegionCoprocessorEnvironment.checkScanQuota(Scan scan, long maxBlockBytesScanned, long prevBlockBytesScannedDifference) Check the quota for the current (rpc-context) user.
- 
Uses of RpcThrottlingException in org.apache.hadoop.hbase.quotasMethods in org.apache.hadoop.hbase.quotas that throw RpcThrottlingExceptionModifier and TypeMethodDescriptionvoidDefaultOperationQuota.checkBatchQuota(int numWrites, int numReads, boolean isAtomic) voidExceedOperationQuota.checkBatchQuota(int numWrites, int numReads, boolean isAtomic) voidNoopOperationQuota.checkBatchQuota(int numWrites, int numReads, boolean isAtomic) voidOperationQuota.checkBatchQuota(int numWrites, int numReads, boolean isAtomic) Checks if it is possible to execute the specified operation.RegionServerRpcQuotaManager.checkBatchQuota(Region region, int numWrites, int numReads, boolean isAtomic) Check the quota for the current (rpc-context) user.RegionServerRpcQuotaManager.checkBatchQuota(Region region, List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> actions, boolean hasCondition) RegionServerRpcQuotaManager.checkBatchQuota(Region region, OperationQuota.OperationType type) RpcQuotaManager.checkBatchQuota(Region region, int numWrites, int numReads, boolean isAtomic) Check the quota for the current (rpc-context) user.RpcQuotaManager.checkBatchQuota(Region region, List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> actions, boolean hasCondition) Check the quota for the current (rpc-context) user.RpcQuotaManager.checkBatchQuota(Region region, OperationQuota.OperationType type) Check the quota for the current (rpc-context) user.private voidDefaultOperationQuota.checkQuota(long numWrites, long numReads, boolean isAtomic) private voidExceedOperationQuota.checkQuota(Runnable estimateQuota, ExceedOperationQuota.CheckQuotaRunnable checkQuota, int numWrites, int numReads, int numScans, boolean isAtomic) voidNoopQuotaLimiter.checkQuota(long writeReqs, long estimateWriteSize, long readReqs, long estimateReadSize, long estimateWriteCapacityUnit, long estimateReadCapacityUnit, boolean isAtomic, long estimateHandlerThreadUsageMs) voidQuotaLimiter.checkQuota(long writeReqs, long estimateWriteSize, long readReqs, long estimateReadSize, long estimateWriteCapacityUnit, long estimateReadCapacityUnit, boolean isAtomic, long estimateHandlerThreadUsageMs) Checks if it is possible to execute the specified operation.voidTimeBasedLimiter.checkQuota(long writeReqs, long estimateWriteSize, long readReqs, long estimateReadSize, long estimateWriteCapacityUnit, long estimateReadCapacityUnit, boolean isAtomic, long estimatedReqHandlerUsageTimeMs) voidDefaultOperationQuota.checkScanQuota(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest scanRequest, long maxScannerResultSize, long maxBlockBytesScanned, long prevBlockBytesScannedDifference) voidExceedOperationQuota.checkScanQuota(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest scanRequest, long maxScannerResultSize, long maxBlockBytesScanned, long prevBlockBytesScannedDifference) voidNoopOperationQuota.checkScanQuota(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest scanRequest, long maxScannerResultSize, long maxBlockBytesScanned, long prevBlockBytesScannedDifference) voidOperationQuota.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.RegionServerRpcQuotaManager.checkScanQuota(Region region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest scanRequest, long maxScannerResultSize, long maxBlockBytesScanned, long prevBlockBytesScannedDifference) RpcQuotaManager.checkScanQuota(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.voidExceedOperationQuota.CheckQuotaRunnable.run()static voidRpcThrottlingException.throwAtomicReadSizeExceeded(long waitInterval) static voidRpcThrottlingException.throwAtomicRequestNumberExceeded(long waitInterval) static voidRpcThrottlingException.throwAtomicWriteSizeExceeded(long waitInterval) static voidRpcThrottlingException.throwNumReadRequestsExceeded(long waitInterval) static voidRpcThrottlingException.throwNumRequestsExceeded(long waitInterval) static voidRpcThrottlingException.throwNumWriteRequestsExceeded(long waitInterval) static voidRpcThrottlingException.throwReadCapacityUnitExceeded(long waitInterval) static voidRpcThrottlingException.throwReadSizeExceeded(long waitInterval) static voidRpcThrottlingException.throwRequestCapacityUnitExceeded(long waitInterval) static voidRpcThrottlingException.throwRequestHandlerUsageTimeExceeded(long waitInterval) static voidRpcThrottlingException.throwRequestSizeExceeded(long waitInterval) private static voidRpcThrottlingException.throwThrottlingException(RpcThrottlingException.Type type, long waitInterval) static voidRpcThrottlingException.throwWriteCapacityUnitExceeded(long waitInterval) static voidRpcThrottlingException.throwWriteSizeExceeded(long waitInterval) 
- 
Uses of RpcThrottlingException in org.apache.hadoop.hbase.regionserverMethods in org.apache.hadoop.hbase.regionserver that throw RpcThrottlingExceptionModifier and TypeMethodDescriptionRegionCoprocessorHost.RegionEnvironment.checkBatchQuota(Region region, int numWrites, int numReads) RegionCoprocessorHost.RegionEnvironment.checkBatchQuota(Region region, OperationQuota.OperationType type) RegionCoprocessorHost.RegionEnvironment.checkScanQuota(Scan scan, long maxBlockBytesScanned, long prevBlockBytesScannedDifference)