Uses of Class
org.apache.hadoop.hbase.quotas.RpcThrottlingException
Packages that use 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
Methods in org.apache.hadoop.hbase.coprocessor that throw org.apache.hadoop.hbase.quotas.RpcThrottlingException in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.quotas.OperationQuotaRegionCoprocessorEnvironment.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.OperationQuotaRegionCoprocessorEnvironment.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.OperationQuotaRegionCoprocessorEnvironment.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
Methods in org.apache.hadoop.hbase.quotas that throw org.apache.hadoop.hbase.quotas.RpcThrottlingException in inModifier and TypeMethodDescriptionvoidDefaultOperationQuota.checkBatchQuota(int numWrites, int numReads, boolean isAtomic) voidExceedOperationQuota.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.org.apache.hadoop.hbase.quotas.OperationQuotaRegionServerRpcQuotaManager.checkBatchQuota(org.apache.hadoop.hbase.regionserver.Region region, int numWrites, int numReads, boolean isAtomic) Check the quota for the current (rpc-context) user.org.apache.hadoop.hbase.quotas.OperationQuotaRegionServerRpcQuotaManager.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.OperationQuotaRegionServerRpcQuotaManager.checkBatchQuota(org.apache.hadoop.hbase.regionserver.Region region, org.apache.hadoop.hbase.quotas.OperationQuota.OperationType type) org.apache.hadoop.hbase.quotas.OperationQuotaRpcQuotaManager.checkBatchQuota(org.apache.hadoop.hbase.regionserver.Region region, int numWrites, int numReads, boolean isAtomic) Check the quota for the current (rpc-context) user.org.apache.hadoop.hbase.quotas.OperationQuotaRpcQuotaManager.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.OperationQuotaRpcQuotaManager.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.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) 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.org.apache.hadoop.hbase.quotas.OperationQuotaRegionServerRpcQuotaManager.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.OperationQuotaRpcQuotaManager.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 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) static voidRpcThrottlingException.throwWriteCapacityUnitExceeded(long waitInterval) static voidRpcThrottlingException.throwWriteSizeExceeded(long waitInterval)