@InterfaceAudience.Private public class WALSplitterHandler extends EventHandler
EventHandler.EventHandlerListener
Modifier and Type | Field and Description |
---|---|
private SplitLogWorkerCoordination |
coordination |
private AtomicInteger |
inProgressTasks |
private static org.apache.commons.logging.Log |
LOG |
private org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.RecoveryMode |
mode |
private CancelableProgressable |
reporter |
private ServerName |
serverName |
private SplitLogWorkerCoordination.SplitTaskDetails |
splitTaskDetails |
private SplitLogWorker.TaskExecutor |
splitTaskExecutor |
eventType, seqids, server, waitingTimeForEvents
Constructor and Description |
---|
WALSplitterHandler(Server server,
SplitLogWorkerCoordination coordination,
SplitLogWorkerCoordination.SplitTaskDetails splitDetails,
CancelableProgressable reporter,
AtomicInteger inProgressTasks,
SplitLogWorker.TaskExecutor splitTaskExecutor,
org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.RecoveryMode mode) |
Modifier and Type | Method and Description |
---|---|
void |
process()
This method is the main processing loop to be implemented by the various
subclasses.
|
compareTo, getEventType, getInformativeName, getListener, getPriority, getSeqid, handleException, prepare, run, setListener, toString
private static final org.apache.commons.logging.Log LOG
private final ServerName serverName
private final CancelableProgressable reporter
private final AtomicInteger inProgressTasks
private final SplitLogWorker.TaskExecutor splitTaskExecutor
private final org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.RecoveryMode mode
private final SplitLogWorkerCoordination.SplitTaskDetails splitTaskDetails
private final SplitLogWorkerCoordination coordination
public WALSplitterHandler(Server server, SplitLogWorkerCoordination coordination, SplitLogWorkerCoordination.SplitTaskDetails splitDetails, CancelableProgressable reporter, AtomicInteger inProgressTasks, SplitLogWorker.TaskExecutor splitTaskExecutor, org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.RecoveryMode mode)
public void process() throws IOException
EventHandler
process
in class EventHandler
IOException
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.