public class ReplicationSource.ReplicationSourceShipperThread extends Thread
Thread.State, Thread.UncaughtExceptionHandler
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
Constructor and Description |
---|
ReplicationSource.ReplicationSourceShipperThread(String walGroupId,
PriorityBlockingQueue<org.apache.hadoop.fs.Path> queue,
ReplicationQueueInfo replicationQueueInfo,
ReplicationSourceInterface source) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.fs.Path |
getCurrentPath() |
long |
getCurrentPosition() |
ReplicationSource.WorkerState |
getWorkerState()
Get the current state of this worker.
|
void |
run() |
void |
setWorkerState(ReplicationSource.WorkerState state)
Set the worker state
|
protected void |
shipEdits(org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReaderThread.WALEntryBatch entryBatch)
Do the shipping logic
|
void |
startup() |
activeCount, checkAccess, clone, countStackFrames, currentThread, destroy, dumpStack, enumerate, getAllStackTraces, getContextClassLoader, getDefaultUncaughtExceptionHandler, getId, getName, getPriority, getStackTrace, getState, getThreadGroup, getUncaughtExceptionHandler, holdsLock, interrupt, interrupted, isAlive, isDaemon, isInterrupted, join, join, join, resume, setContextClassLoader, setDaemon, setDefaultUncaughtExceptionHandler, setName, setPriority, setUncaughtExceptionHandler, sleep, sleep, start, stop, stop, suspend, toString, yield
public ReplicationSource.ReplicationSourceShipperThread(String walGroupId, PriorityBlockingQueue<org.apache.hadoop.fs.Path> queue, ReplicationQueueInfo replicationQueueInfo, ReplicationSourceInterface source)
protected void shipEdits(org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReaderThread.WALEntryBatch entryBatch)
public void startup()
public org.apache.hadoop.fs.Path getCurrentPath()
public long getCurrentPosition()
public void setWorkerState(ReplicationSource.WorkerState state)
state
- public ReplicationSource.WorkerState getWorkerState()
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.