Package | Description |
---|---|
org.apache.hadoop.hbase.chaos.actions | |
org.apache.hadoop.hbase.chaos.policies | |
org.apache.hadoop.hbase.mttr |
Modifier and Type | Class and Description |
---|---|
class |
AddColumnAction
Action the adds a column family to a table.
|
class |
AddCPULoadAction
Action that adds high cpu load to a random regionserver for a given duration
|
class |
BatchRestartRsAction
Restarts a ratio of the running regionservers at the same time
|
class |
ChangeBloomFilterAction
Action that tries to adjust the bloom filter setting on all the columns of a
table
|
class |
ChangeCompressionAction
Action that changes the compression algorithm on a column family from a list of tables.
|
class |
ChangeEncodingAction
Action that changes the encoding on a column family from a list of tables.
|
class |
ChangeSplitPolicyAction |
class |
ChangeVersionsAction
Action that changes the number of versions on a column family from a list of tables.
|
class |
CompactMobAction
Action that queues a table compaction.
|
class |
CompactRandomRegionOfTableAction
Region that queues a compaction of a random region from the table.
|
class |
CompactTableAction
Action that queues a table compaction.
|
class |
CorruptDataFilesAction
Action corrupts HFiles with a certain chance.
|
class |
CorruptPacketsCommandAction
Corrupt network packets on a random regionserver.
|
class |
DecreaseMaxHFileSizeAction |
class |
DelayPacketsCommandAction
Action adds latency to communication on a random regionserver.
|
class |
DeleteDataFilesAction
Action deletes HFiles with a certain chance.
|
class |
DumpClusterStatusAction
Action to dump the cluster status.
|
class |
DuplicatePacketsCommandAction
Duplicate network packets on a random regionserver.
|
class |
FillDiskCommandAction
Fill the disk on a random regionserver.
|
class |
FlushRandomRegionOfTableAction
Action that tries to flush a random region of a table.
|
class |
FlushTableAction
Action that tries to flush a table.
|
class |
ForceBalancerAction
Action that tries to force a balancer run.
|
class |
GracefulRollingRestartRsAction
Gracefully restarts every regionserver in a rolling fashion.
|
class |
LosePacketsCommandAction
Lose network packets on a random regionserver.
|
class |
MergeRandomAdjacentRegionsOfTableAction
Action to merge regions of a table.
|
class |
MoveRandomRegionOfTableAction
Action that tries to move a random region of a table.
|
class |
MoveRegionsOfTableAction
Action that tries to move every region of a table.
|
class |
RemoveColumnAction
Action that removes a column family.
|
class |
ReorderPacketsCommandAction
Reorder network packets on a random regionserver.
|
class |
RestartActionBaseAction
Base class for restarting HBaseServer's
|
class |
RestartActiveMasterAction
Action that tries to restart the active master.
|
class |
RestartActiveNameNodeAction
Action that tries to restart the active namenode.
|
class |
RestartRandomDataNodeAction
Action that restarts a random datanode.
|
class |
RestartRandomRsAction
Action that restarts a random HRegionServer
|
class |
RestartRandomRsExceptMetaAction |
class |
RestartRandomZKNodeAction
Action that restarts a random zookeeper node.
|
class |
RestartRsHoldingMetaAction
Action that tries to restart the HRegionServer holding Meta.
|
class |
RestartRsHoldingTableAction
Action that restarts an HRegionServer holding one of the regions of the table.
|
class |
RollingBatchRestartRsAction
Restarts a ratio of the regionservers in a rolling fashion.
|
class |
RollingBatchSuspendResumeRsAction
Suspend then resume a ratio of the regionservers in a rolling fashion.
|
class |
SnapshotTableAction
Action that tries to take a snapshot of a table.
|
class |
SplitAllRegionOfTableAction |
class |
SplitRandomRegionOfTableAction
Action that tries to split a random region of a table.
|
class |
SudoCommandAction
Base class for performing Actions based on linux commands requiring sudo privileges
|
class |
TCCommandAction
Base class for tc command actions
|
class |
TruncateTableAction
Action that tries to truncate of a table.
|
class |
UnbalanceKillAndRebalanceAction
This action is too specific to put in ChaosMonkey; put it here
|
class |
UnbalanceRegionsAction
Action that tries to unbalance the regions of a cluster.
|
Modifier and Type | Field and Description |
---|---|
private Action |
TwoConcurrentActionPolicy.ActionRunner.action |
private Action[] |
TwoConcurrentActionPolicy.actionsOne |
private Action[] |
TwoConcurrentActionPolicy.actionsTwo |
Modifier and Type | Field and Description |
---|---|
private List<org.apache.hadoop.hbase.util.Pair<Action,Integer>> |
PeriodicRandomActionPolicy.actions |
private List<Action> |
DoActionsOncePolicy.actions |
Constructor and Description |
---|
ActionRunner(Action action) |
DoActionsOncePolicy(long periodMs,
Action... actions) |
PeriodicRandomActionPolicy(long periodMs,
Action... actions) |
TwoConcurrentActionPolicy(long sleepTime,
Action[] actionsOne,
Action[] actionsTwo) |
TwoConcurrentActionPolicy(long sleepTime,
Action[] actionsOne,
Action[] actionsTwo) |
Constructor and Description |
---|
DoActionsOncePolicy(long periodMs,
List<Action> actions) |
PeriodicRandomActionPolicy(long periodMs,
List<org.apache.hadoop.hbase.util.Pair<Action,Integer>> actions) |
Modifier and Type | Field and Description |
---|---|
private Action |
IntegrationTestMTTR.ActionCallable.action |
private static Action |
IntegrationTestMTTR.moveMetaRegionsAction |
private static Action |
IntegrationTestMTTR.moveRegionAction |
private static Action |
IntegrationTestMTTR.restartMasterAction |
private static Action |
IntegrationTestMTTR.restartMetaAction |
private static Action |
IntegrationTestMTTR.restartRSAction
All of the chaos monkey actions used.
|
Constructor and Description |
---|
ActionCallable(Action action) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.