Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.quotas | |
org.apache.hadoop.hbase.quotas.policies | |
org.apache.hadoop.hbase.thrift2.client |
Modifier and Type | Method and Description |
---|---|
SpaceQuotaSnapshot |
HBaseAdmin.getCurrentSpaceQuotaSnapshot(String namespace) |
SpaceQuotaSnapshot |
HBaseAdmin.getCurrentSpaceQuotaSnapshot(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
private CompletableFuture<SpaceQuotaSnapshot> |
RawAsyncHBaseAdmin.getCurrentSpaceQuotaSnapshot(RawAsyncHBaseAdmin.Converter<SpaceQuotaSnapshot,org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetQuotaStatesResponse> converter) |
Modifier and Type | Method and Description |
---|---|
(package private) Map.Entry<Long,Long> |
MetricsMasterWrapperImpl.convertSnapshot(SpaceQuotaSnapshot snapshot) |
Modifier and Type | Field and Description |
---|---|
static SpaceQuotaSnapshot |
QuotaSnapshotStore.NO_QUOTA
Singleton to represent a table without a quota defined.
|
private static SpaceQuotaSnapshot |
SpaceQuotaSnapshot.NO_SUCH_SNAPSHOT |
Modifier and Type | Field and Description |
---|---|
private AtomicReference<Map<TableName,SpaceQuotaSnapshot>> |
RegionServerSpaceQuotaManager.currentQuotaSnapshots |
private Map<String,SpaceQuotaSnapshot> |
QuotaObserverChore.namespaceQuotaSnapshots |
private Map<String,SpaceQuotaSnapshot> |
QuotaObserverChore.readOnlyNamespaceSnapshots |
private Map<TableName,SpaceQuotaSnapshot> |
QuotaObserverChore.readOnlyTableQuotaSnapshots |
private Map<TableName,SpaceQuotaSnapshot> |
ActivePolicyEnforcement.snapshots |
private Map<TableName,SpaceQuotaSnapshot> |
QuotaObserverChore.tableQuotaSnapshots |
Modifier and Type | Method and Description |
---|---|
static SpaceQuotaSnapshot |
QuotaTableUtil.getCurrentSnapshotFromQuotaTable(Connection conn,
TableName tableName)
Returns the current space quota snapshot of the given
tableName from
QuotaTableUtil.QUOTA_TABLE_NAME or null if the no quota information is available for
that tableName. |
SpaceQuotaSnapshot |
NamespaceQuotaSnapshotStore.getCurrentState(String namespace) |
SpaceQuotaSnapshot |
QuotaSnapshotStore.getCurrentState(T subject)
Returns the current
SpaceQuotaSnapshot for the given subject . |
SpaceQuotaSnapshot |
TableQuotaSnapshotStore.getCurrentState(TableName table) |
(package private) SpaceQuotaSnapshot |
QuotaObserverChore.getNamespaceQuotaSnapshot(String namespace)
Fetches the
SpaceQuotaSnapshot for the given namespace from this chore. |
static SpaceQuotaSnapshot |
SpaceQuotaSnapshot.getNoSuchSnapshot()
Returns a singleton that corresponds to no snapshot information.
|
SpaceQuotaSnapshot |
SpaceViolationPolicyEnforcement.getQuotaSnapshot()
Returns the
SpaceQuotaSnapshot this was initialized with. |
(package private) SpaceQuotaSnapshot |
QuotaObserverChore.getTableQuotaSnapshot(TableName table)
Fetches the
SpaceQuotaSnapshot for the given table. |
SpaceQuotaSnapshot |
NamespaceQuotaSnapshotStore.getTargetState(String subject,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota spaceQuota) |
SpaceQuotaSnapshot |
TableQuotaSnapshotStore.getTargetState(TableName table,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota spaceQuota) |
SpaceQuotaSnapshot |
QuotaSnapshotStore.getTargetState(T subject,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuota spaceQuota)
|
static SpaceQuotaSnapshot |
SpaceQuotaSnapshot.toSpaceQuotaSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuotaSnapshot proto) |
Modifier and Type | Method and Description |
---|---|
Map<TableName,SpaceQuotaSnapshot> |
RegionServerSpaceQuotaManager.copyQuotaSnapshots()
Copies the last
SpaceQuotaSnapshot s that were recorded. |
Map<TableName,SpaceQuotaSnapshot> |
SpaceQuotaRefresherChore.fetchSnapshotsFromQuotaTable()
Reads all quota snapshots from the quota table.
|
Map<TableName,SpaceQuotaSnapshot> |
RegionServerSpaceQuotaManager.getActivePoliciesAsMap()
Converts a map of table to
SpaceViolationPolicyEnforcement s into
SpaceViolationPolicy s. |
Map<String,SpaceQuotaSnapshot> |
QuotaObserverChore.getNamespaceQuotaSnapshots()
Returns an unmodifiable view over the current
SpaceQuotaSnapshot objects for each HBase
namespace with a quota defined. |
static Map<TableName,SpaceQuotaSnapshot> |
QuotaTableUtil.getSnapshots(Connection conn)
Fetches all
SpaceQuotaSnapshot objects from the hbase:quota table. |
Map<TableName,SpaceQuotaSnapshot> |
QuotaObserverChore.getTableQuotaSnapshots()
Returns an unmodifiable view over the current
SpaceQuotaSnapshot objects for each HBase
table with a quota defined. |
Modifier and Type | Method and Description |
---|---|
SpaceViolationPolicyEnforcement |
SpaceViolationPolicyEnforcementFactory.create(RegionServerServices rss,
TableName tableName,
SpaceQuotaSnapshot snapshot)
Constructs the appropriate
SpaceViolationPolicyEnforcement for tables that are in
violation of their space quota. |
(package private) static Put |
QuotaTableUtil.createPutForSpaceSnapshot(TableName tableName,
SpaceQuotaSnapshot snapshot)
|
SpaceViolationPolicyEnforcement |
SpaceViolationPolicyEnforcementFactory.createWithoutViolation(RegionServerServices rss,
TableName tableName,
SpaceQuotaSnapshot snapshot)
Creates the "default"
SpaceViolationPolicyEnforcement for a table that isn't in
violation. |
void |
RegionServerSpaceQuotaManager.enforceViolationPolicy(TableName tableName,
SpaceQuotaSnapshot snapshot)
Enforces the given violationPolicy on the given table in this RegionServer.
|
void |
SpaceViolationPolicyEnforcement.initialize(RegionServerServices rss,
TableName tableName,
SpaceQuotaSnapshot snapshot)
Initializes this policy instance.
|
(package private) boolean |
SpaceQuotaRefresherChore.isInViolation(SpaceQuotaSnapshot snapshot)
Checks if the given
snapshot is in violation, allowing the snapshot to be null. |
void |
NamespaceQuotaSnapshotStore.setCurrentState(String namespace,
SpaceQuotaSnapshot snapshot) |
void |
TableQuotaSnapshotStore.setCurrentState(TableName table,
SpaceQuotaSnapshot snapshot) |
void |
QuotaSnapshotStore.setCurrentState(T subject,
SpaceQuotaSnapshot state)
Persists the current
SpaceQuotaSnapshot for the subject . |
(package private) void |
QuotaObserverChore.setNamespaceQuotaSnapshot(String namespace,
SpaceQuotaSnapshot snapshot)
Stores the given
snapshot for the given namespace in this chore. |
(package private) void |
QuotaObserverChore.setTableQuotaSnapshot(TableName table,
SpaceQuotaSnapshot snapshot)
Stores the quota state for the given table.
|
static org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.SpaceQuotaSnapshot |
SpaceQuotaSnapshot.toProtoSnapshot(SpaceQuotaSnapshot snapshot) |
void |
TableSpaceQuotaSnapshotNotifier.transitionTable(TableName tableName,
SpaceQuotaSnapshot snapshot) |
void |
SpaceQuotaSnapshotNotifier.transitionTable(TableName tableName,
SpaceQuotaSnapshot snapshot)
Informs the cluster of the current state of a space quota for a table.
|
(package private) void |
QuotaObserverChore.updateNamespaceQuota(String namespace,
SpaceQuotaSnapshot currentSnapshot,
SpaceQuotaSnapshot targetSnapshot,
org.apache.hbase.thirdparty.com.google.common.collect.Multimap<String,TableName> tablesByNamespace)
Updates the hbase:quota table with the target quota policy for this
namespace if
necessary. |
(package private) void |
QuotaObserverChore.updateTableQuota(TableName table,
SpaceQuotaSnapshot currentSnapshot,
SpaceQuotaSnapshot targetSnapshot)
Updates the hbase:quota table with the new quota policy for this
table if
necessary. |
Modifier and Type | Method and Description |
---|---|
(package private) void |
SpaceQuotaRefresherChore.extractQuotaSnapshot(Result result,
Map<TableName,SpaceQuotaSnapshot> snapshots)
Wrapper around
QuotaTableUtil.extractQuotaSnapshot(Result, Map) for testing. |
static void |
QuotaTableUtil.extractQuotaSnapshot(Result result,
Map<TableName,SpaceQuotaSnapshot> snapshots)
Extracts the
SpaceViolationPolicy and TableName from the provided
Result and adds them to the given Map . |
void |
RegionServerSpaceQuotaManager.updateQuotaSnapshot(Map<TableName,SpaceQuotaSnapshot> newSnapshots)
Updates the current
SpaceQuotaSnapshot s for the RegionServer. |
Constructor and Description |
---|
ActivePolicyEnforcement(Map<TableName,SpaceViolationPolicyEnforcement> activePolicies,
Map<TableName,SpaceQuotaSnapshot> snapshots,
RegionServerServices rss) |
ActivePolicyEnforcement(Map<TableName,SpaceViolationPolicyEnforcement> activePolicies,
Map<TableName,SpaceQuotaSnapshot> snapshots,
RegionServerServices rss,
SpaceViolationPolicyEnforcementFactory factory) |
Modifier and Type | Field and Description |
---|---|
(package private) SpaceQuotaSnapshot |
AbstractViolationPolicyEnforcement.quotaSnapshot |
Modifier and Type | Method and Description |
---|---|
SpaceQuotaSnapshot |
AbstractViolationPolicyEnforcement.getQuotaSnapshot() |
Modifier and Type | Method and Description |
---|---|
void |
AbstractViolationPolicyEnforcement.initialize(RegionServerServices rss,
TableName tableName,
SpaceQuotaSnapshot snapshot) |
void |
AbstractViolationPolicyEnforcement.setQuotaSnapshot(SpaceQuotaSnapshot snapshot) |
Modifier and Type | Method and Description |
---|---|
SpaceQuotaSnapshot |
ThriftAdmin.getCurrentSpaceQuotaSnapshot(String namespace) |
SpaceQuotaSnapshot |
ThriftAdmin.getCurrentSpaceQuotaSnapshot(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
Map<TableName,SpaceQuotaSnapshot> |
ThriftAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.