Package org.apache.hadoop.hbase.chaos.actions


package org.apache.hadoop.hbase.chaos.actions
  • Classes
    Class
    Description
    org.apache.hadoop.hbase.chaos.actions.Action
    A (possibly mischievous) action that the ChaosMonkey can perform.
    org.apache.hadoop.hbase.chaos.actions.Action.ActionContext
    Context for Action's
    org.apache.hadoop.hbase.chaos.actions.AddColumnAction
    Action the adds a column family to a table.
    org.apache.hadoop.hbase.chaos.actions.AddCPULoadAction
    Action that adds high cpu load to a random regionserver for a given duration
    org.apache.hadoop.hbase.chaos.actions.BatchRestartRsAction
    Restarts a ratio of the running regionservers at the same time
    org.apache.hadoop.hbase.chaos.actions.ChangeBloomFilterAction
    Action that tries to adjust the bloom filter setting on all the columns of a table
    org.apache.hadoop.hbase.chaos.actions.ChangeCompressionAction
    Action that changes the compression algorithm on a column family from a list of tables.
    org.apache.hadoop.hbase.chaos.actions.ChangeEncodingAction
    Action that changes the encoding on a column family from a list of tables.
    org.apache.hadoop.hbase.chaos.actions.ChangeSplitPolicyAction
     
    org.apache.hadoop.hbase.chaos.actions.ChangeVersionsAction
    Action that changes the number of versions on a column family from a list of tables.
    org.apache.hadoop.hbase.chaos.actions.CompactMobAction
    Action that queues a table compaction.
    org.apache.hadoop.hbase.chaos.actions.CompactRandomRegionOfTableAction
    Region that queues a compaction of a random region from the table.
    org.apache.hadoop.hbase.chaos.actions.CompactTableAction
    Action that queues a table compaction.
    org.apache.hadoop.hbase.chaos.actions.CorruptDataFilesAction
    Action corrupts HFiles with a certain chance.
    org.apache.hadoop.hbase.chaos.actions.CorruptPacketsCommandAction
    Corrupt network packets on a random regionserver.
    org.apache.hadoop.hbase.chaos.actions.DecreaseMaxHFileSizeAction
     
    org.apache.hadoop.hbase.chaos.actions.DelayPacketsCommandAction
    Action adds latency to communication on a random regionserver.
    org.apache.hadoop.hbase.chaos.actions.DeleteDataFilesAction
    Action deletes HFiles with a certain chance.
    org.apache.hadoop.hbase.chaos.actions.DumpClusterStatusAction
    Action to dump the cluster status.
    org.apache.hadoop.hbase.chaos.actions.DumpHdfsClusterStatusAction
     
    org.apache.hadoop.hbase.chaos.actions.DuplicatePacketsCommandAction
    Duplicate network packets on a random regionserver.
    org.apache.hadoop.hbase.chaos.actions.FillDiskCommandAction
    Fill the disk on a random regionserver.
    org.apache.hadoop.hbase.chaos.actions.FlushRandomRegionOfTableAction
    Action that tries to flush a random region of a table.
    org.apache.hadoop.hbase.chaos.actions.FlushTableAction
    Action that tries to flush a table.
    org.apache.hadoop.hbase.chaos.actions.ForceBalancerAction
    Action that tries to force a balancer run.
    org.apache.hadoop.hbase.chaos.actions.GracefulRollingRestartRsAction
    Gracefully restarts every regionserver in a rolling fashion.
    org.apache.hadoop.hbase.chaos.actions.HdfsActionUtils
    Configuration common across the HDFS Actions.
    org.apache.hadoop.hbase.chaos.actions.LosePacketsCommandAction
    Lose network packets on a random regionserver.
    org.apache.hadoop.hbase.chaos.actions.MergeRandomAdjacentRegionsOfTableAction
    Action to merge regions of a table.
    org.apache.hadoop.hbase.chaos.actions.MoveRandomRegionOfTableAction
    Action that tries to move a random region of a table.
    org.apache.hadoop.hbase.chaos.actions.MoveRegionsOfTableAction
    Action that tries to move every region of a table.
    org.apache.hadoop.hbase.chaos.actions.RemoveColumnAction
    Action that removes a column family.
    org.apache.hadoop.hbase.chaos.actions.ReorderPacketsCommandAction
    Reorder network packets on a random regionserver.
    org.apache.hadoop.hbase.chaos.actions.RestartActionBaseAction
    Base class for restarting HBaseServer's
    org.apache.hadoop.hbase.chaos.actions.RestartActiveMasterAction
    Action that tries to restart the active master.
    org.apache.hadoop.hbase.chaos.actions.RestartActiveNameNodeAction
    Action that tries to restart the active namenode.
    org.apache.hadoop.hbase.chaos.actions.RestartRandomDataNodeAction
    Action that restarts a random datanode.
    org.apache.hadoop.hbase.chaos.actions.RestartRandomJournalNodeAction
     
    org.apache.hadoop.hbase.chaos.actions.RestartRandomRsAction
    Action that restarts a random HRegionServer
    org.apache.hadoop.hbase.chaos.actions.RestartRandomRsExceptMetaAction
     
    org.apache.hadoop.hbase.chaos.actions.RestartRandomZKNodeAction
    Action that restarts a random zookeeper node.
    org.apache.hadoop.hbase.chaos.actions.RestartRsHoldingMetaAction
    Action that tries to restart the HRegionServer holding Meta.
    org.apache.hadoop.hbase.chaos.actions.RestartRsHoldingTableAction
    Action that restarts an HRegionServer holding one of the regions of the table.
    org.apache.hadoop.hbase.chaos.actions.RollingBatchRestartRsAction
    Restarts a ratio of the regionservers in a rolling fashion.
    org.apache.hadoop.hbase.chaos.actions.RollingBatchSuspendResumeRsAction
    Suspend then resume a ratio of the regionservers in a rolling fashion.
    org.apache.hadoop.hbase.chaos.actions.SnapshotTableAction
    Action that tries to take a snapshot of a table.
    org.apache.hadoop.hbase.chaos.actions.SplitAllRegionOfTableAction
     
    org.apache.hadoop.hbase.chaos.actions.SplitRandomRegionOfTableAction
    Action that tries to split a random region of a table.
    org.apache.hadoop.hbase.chaos.actions.SudoCommandAction
    Base class for performing Actions based on linux commands requiring sudo privileges
    org.apache.hadoop.hbase.chaos.actions.TCCommandAction
    Base class for tc command actions
    org.apache.hadoop.hbase.chaos.actions.TestChangeSplitPolicyAction
     
    org.apache.hadoop.hbase.chaos.actions.TruncateTableAction
    Action that tries to truncate of a table.
    org.apache.hadoop.hbase.chaos.actions.UnbalanceKillAndRebalanceAction
    This action is too specific to put in ChaosMonkey; put it here
    org.apache.hadoop.hbase.chaos.actions.UnbalanceRegionsAction
    Action that tries to unbalance the regions of a cluster.