Package | Description |
---|---|
org.apache.hadoop.hbase.executor | |
org.apache.hadoop.hbase.master.handler | |
org.apache.hadoop.hbase.master.snapshot | |
org.apache.hadoop.hbase.regionserver.handler |
Modifier and Type | Method and Description |
---|---|
EventHandler |
EventHandler.prepare()
Event handlers should do all the necessary checks in this method (rather than
in the constructor, or in process()) so that the caller, which is mostly executed
in the ipc context can fail fast.
|
Modifier and Type | Method and Description |
---|---|
void |
EventHandler.EventHandlerListener.afterProcess(EventHandler event)
Called after any event is processed
|
void |
EventHandler.EventHandlerListener.beforeProcess(EventHandler event)
Called before any event is processed
|
void |
ExecutorService.submit(EventHandler eh) |
Constructor and Description |
---|
ExecutorService.RunningEventStatus(Thread t,
EventHandler event) |
Modifier and Type | Class and Description |
---|---|
class |
ClosedRegionHandler
Handles CLOSED region event on Master.
|
class |
CreateTableHandler
Handler to create a table.
|
class |
DeleteTableHandler |
class |
DisableTableHandler
Handler to run disable of a table.
|
class |
DispatchMergingRegionHandler
Handles MERGE regions request on master: move the regions together(on the
same regionserver) and send MERGE RPC to regionserver.
|
class |
EnableTableHandler
Handler to run enable of a table.
|
class |
LogReplayHandler
Handle logReplay work from SSH.
|
class |
MetaServerShutdownHandler
Shutdown handler for the server hosting
hbase:meta |
class |
ModifyTableHandler |
class |
OpenedRegionHandler
Handles OPENED region event on Master.
|
class |
ServerShutdownHandler
Process server shutdown.
|
class |
TableAddFamilyHandler
Handles adding a new family to an existing table.
|
class |
TableDeleteFamilyHandler
Handles Deleting a column family from an existing table.
|
class |
TableEventHandler
Base class for performing operations against tables.
|
class |
TableModifyFamilyHandler
Handles adding a new family to an existing table.
|
class |
TruncateTableHandler
Truncate the table by removing META and the HDFS files and recreating it.
|
Modifier and Type | Class and Description |
---|---|
class |
CloneSnapshotHandler
Handler to Clone a snapshot.
|
class |
DisabledTableSnapshotHandler
Take a snapshot of a disabled table.
|
class |
EnabledTableSnapshotHandler
Handle the master side of taking a snapshot of an online table, regardless of snapshot type.
|
class |
RestoreSnapshotHandler
Handler to Restore a snapshot.
|
class |
TakeSnapshotHandler
A handler for taking snapshots from the master.
|
Modifier and Type | Class and Description |
---|---|
class |
CloseMetaHandler
Handles closing of the root region on a region server.
|
class |
CloseRegionHandler
Handles closing of a region on a region server.
|
class |
FinishRegionRecoveringHandler |
class |
OpenMetaHandler
Handles opening of a meta region on a region server.
|
class |
OpenRegionHandler
Handles opening of a region on a region server.
|
class |
ParallelSeekHandler
Handler to seek storefiles in parallel.
|
class |
RegionReplicaFlushHandler
HBASE-11580: With the async wal approach (HBASE-11568), the edits are not persisted to wal in
secondary region replicas.
|
class |
WALSplitterHandler
Handles log splitting a wal
|
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.