Package org.apache.hadoop.hbase.quotas


package org.apache.hadoop.hbase.quotas
  • Class
    Description
    org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
    A class to ease dealing with tables that have and do not have violation policies being enforced.
    org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
    This limiter will refill resources at every TimeUnit/resources interval.
    org.apache.hadoop.hbase.quotas.DefaultOperationQuota
     
    org.apache.hadoop.hbase.quotas.ExceedOperationQuota
     
    org.apache.hadoop.hbase.quotas.FileArchiverNotifier
    Interface allowing various implementations of tracking files that have recently been archived to allow for the Master to notice changes to snapshot sizes for space quotas.
    org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactory
    Factory class to create FileArchiverNotifier instances.
    org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl
    A factory for getting instances of FileArchiverNotifier.
    org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
    Tracks file archiving and updates the hbase quota table.
    org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.QuotaSnapshotSizeSerializationException
    An Exception thrown when SnapshotSize updates to hbase:quota fail to be written.
    org.apache.hadoop.hbase.quotas.FileSystemUtilizationChore
    A chore which computes the size of each HRegion on the FileSystem hosted by the given HRegionServer.
    org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
    With this limiter resources will be refilled only after a fixed interval of time.
    org.apache.hadoop.hbase.quotas.GlobalQuotaSettings
    An object which captures all quotas types (throttle or space) for a subject (user, table, or namespace).
    org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
    Implementation of GlobalQuotaSettings to hide the Protobuf messages we use internally.
    org.apache.hadoop.hbase.quotas.MasterQuotaManager
    Master Quota Manager.
    org.apache.hadoop.hbase.quotas.MasterQuotasObserver
    An observer to automatically delete quotas when a table/namespace is deleted.
    org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
    QuotaSnapshotStore implementation for namespaces.
    org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
    A RegionSizeStore implementation that stores nothing.
    org.apache.hadoop.hbase.quotas.OperationQuota
    Interface that allows to check the quota available for an operation.
    org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
     
    org.apache.hadoop.hbase.quotas.QuotaCache
    Cache that keeps track of the quota settings for the users and tables that are interacting with it.
    org.apache.hadoop.hbase.quotas.QuotaExceededException
    Generic quota exceeded exception
    org.apache.hadoop.hbase.quotas.QuotaFilter
    Filter to use to filter the QuotaRetriever results.
    org.apache.hadoop.hbase.quotas.QuotaLimiter
    Internal interface used to interact with the user/table quota.
    org.apache.hadoop.hbase.quotas.QuotaLimiterFactory
     
    org.apache.hadoop.hbase.quotas.QuotaObserverChore
    Reads the currently received Region filesystem-space use reports and acts on those which violate a defined quota.
    org.apache.hadoop.hbase.quotas.QuotaRetriever
    Scanner to iterate over the quota settings.
    org.apache.hadoop.hbase.quotas.QuotaScope
    Describe the Scope of the quota rules.
    org.apache.hadoop.hbase.quotas.QuotaSettings
     
    org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
     
    org.apache.hadoop.hbase.quotas.QuotaSnapshotStore<T>
    A common interface for computing and storing space quota observance/violation for entities.
    org.apache.hadoop.hbase.quotas.QuotaState
    In-Memory state of table or namespace quotas
    org.apache.hadoop.hbase.quotas.QuotaTableUtil
    Helper class to interact with the quota table.
    org.apache.hadoop.hbase.quotas.QuotaTableUtil.NamespaceQuotasVisitor
     
    org.apache.hadoop.hbase.quotas.QuotaTableUtil.QuotasVisitor
     
    org.apache.hadoop.hbase.quotas.QuotaTableUtil.TableQuotasVisitor
     
    org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
     
    org.apache.hadoop.hbase.quotas.QuotaType
    Describe the Quota Type.
    org.apache.hadoop.hbase.quotas.QuotaUtil
    Helper class to interact with the quota table
    org.apache.hadoop.hbase.quotas.RateLimiter
    Simple rate limiter.
    org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
    Region Server Quota Manager.
    org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
    A manager for filesystem space quotas in the RegionServer.
    org.apache.hadoop.hbase.quotas.RegionSize
    Interface that encapsulates optionally sending a Region's size to the master.
    org.apache.hadoop.hbase.quotas.RegionSizeImpl
    An object encapsulating a Region's size and whether it's been reported to the master since the value last changed.
    org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
    A Chore which sends the region size reports on this RegionServer to the Master.
    org.apache.hadoop.hbase.quotas.RegionSizeStore
    An interface for concurrently storing and updating the size of a Region.
    org.apache.hadoop.hbase.quotas.RegionSizeStoreFactory
    A factory class for creating implementations of RegionSizeStore.
    org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
    A RegionSizeStore implementation backed by a ConcurrentHashMap.
    org.apache.hadoop.hbase.quotas.RpcThrottleStorage
    ZK based rpc throttle storage.
    org.apache.hadoop.hbase.quotas.RpcThrottlingException
    Describe the throttling result.
    org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
     
    org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
    A Master-invoked Chore that computes the size of each snapshot which was created from a table which has a space quota.
    org.apache.hadoop.hbase.quotas.SpaceLimitingException
    An Exception that is thrown when a space quota is in violation.
    org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
    A ScheduledChore which periodically updates the RegionServerSpaceQuotaManager with information from the hbase:quota.
    org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
    A point-in-time view of a space quota on a table.
    org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
    Encapsulates the state of a quota on a table.
    org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifier
    An interface which abstract away the action taken to enable or disable a space quota violation policy across the HBase cluster.
    org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifierFactory
    Factory for creating SpaceQuotaSnapshotNotifier implementations.
    org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
    A point-in-time view of a space quota on a table, read only.
    org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView.SpaceQuotaStatusView
    Encapsulates the state of a quota on a table.
    org.apache.hadoop.hbase.quotas.SpaceViolationPolicy
    Enumeration that represents the action HBase will take when a space quota is violated.
    org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
    RegionServer implementation of SpaceViolationPolicy.
    org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementFactory
    A factory class for instantiating SpaceViolationPolicyEnforcement instances.
    org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
    QuotaSnapshotStore for tables.
    org.apache.hadoop.hbase.quotas.TableSpaceQuotaSnapshotNotifier
    A SpaceQuotaSnapshotNotifier which uses the hbase:quota table.
    org.apache.hadoop.hbase.quotas.ThrottleSettings
     
    org.apache.hadoop.hbase.quotas.ThrottleType
    Describe the Throttle Type.
    org.apache.hadoop.hbase.quotas.ThrottlingException
    Deprecated.
    replaced by RpcThrottlingException since hbase-2.0.0.
    org.apache.hadoop.hbase.quotas.ThrottlingException.Type
     
    org.apache.hadoop.hbase.quotas.TimeBasedLimiter
    Simple time based limiter that checks the quota Throttle
    org.apache.hadoop.hbase.quotas.UserQuotaState
    In-Memory state of the user quotas