Package | Description |
---|---|
org.apache.hadoop.hbase.executor | |
org.apache.hadoop.hbase.master.snapshot | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.handler |
Modifier and Type | Field and Description |
---|---|
(package private) EventHandler |
ExecutorService.RunningEventStatus.event |
Modifier and Type | Field and Description |
---|---|
(package private) List<EventHandler> |
ExecutorService.ExecutorStatus.queuedEvents |
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 |
---|---|
int |
EventHandler.compareTo(EventHandler o)
Default prioritized runnable comparator which implements a FIFO ordering.
|
void |
ExecutorService.delayedSubmit(EventHandler eh,
long delay,
TimeUnit unit) |
void |
ExecutorService.submit(EventHandler eh) |
(package private) void |
ExecutorService.Executor.submit(EventHandler event)
Submit the event to the queue for handling.
|
Constructor and Description |
---|
RunningEventStatus(Thread t,
EventHandler event) |
Constructor and Description |
---|
ExecutorStatus(ExecutorService.Executor executor,
List<EventHandler> queuedEvents,
List<ExecutorService.RunningEventStatus> running) |
Modifier and Type | Class and Description |
---|---|
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 |
TakeSnapshotHandler
A handler for taking snapshots from the master.
|
Modifier and Type | Class and Description |
---|---|
class |
CompactedHFilesDischargeHandler
Event handler that handles the removal and archival of the compacted hfiles
|
Modifier and Type | Class and Description |
---|---|
class |
AssignRegionHandler
Handles opening of a region on a region server.
|
class |
CloseMetaHandler
Handles closing of the meta region on a region server.
|
class |
CloseRegionHandler
Handles closing of a region on a region server.
|
class |
OpenMetaHandler
Handles opening of a meta region on a region server.
|
class |
OpenPriorityRegionHandler
Handles opening of a high priority region on a region server.
|
class |
OpenRegionHandler
Deprecated.
Keep it here only for compatible
|
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 |
RSProcedureHandler
A event handler for running procedure.
|
class |
UnassignRegionHandler
Handles closing of a region on a region server.
|
class |
WALSplitterHandler
Deprecated.
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
distributed WAL splitter, see SplitWALManager
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.