@InterfaceAudience.Private @InterfaceStability.Evolving public class ReplicationSourceWALReaderThread extends Thread
Thread.State, Thread.UncaughtExceptionHandler
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
Constructor and Description |
---|
ReplicationSourceWALReaderThread(ReplicationSourceManager manager,
ReplicationQueueInfo replicationQueueInfo,
PriorityBlockingQueue<org.apache.hadoop.fs.Path> logQueue,
long startPosition,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
WALEntryFilter filter,
MetricsSource metrics)
Creates a reader worker for a given WAL queue.
|
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.fs.Path |
getCurrentPath() |
boolean |
isReaderRunning() |
void |
run() |
void |
setReaderRunning(boolean readerRunning) |
org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReaderThread.WALEntryBatch |
take()
Retrieves the next batch of WAL entries from the queue, waiting up to the specified time for a
batch to become available
|
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 ReplicationSourceWALReaderThread(ReplicationSourceManager manager, ReplicationQueueInfo replicationQueueInfo, PriorityBlockingQueue<org.apache.hadoop.fs.Path> logQueue, long startPosition, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, WALEntryFilter filter, MetricsSource metrics)
manager
- replication managerreplicationQueueInfo
- logQueue
- The WAL queue to read off ofstartPosition
- position in the first WAL to start reading fromfs
- the files system to useconf
- configuration to usefilter
- The filter to use while readingmetrics
- replication metricspublic org.apache.hadoop.fs.Path getCurrentPath()
public org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReaderThread.WALEntryBatch take() throws InterruptedException
InterruptedException
- if interrupted while waitingpublic boolean isReaderRunning()
public void setReaderRunning(boolean readerRunning)
readerRunning
- the readerRunning to setCopyright © 2007–2019 The Apache Software Foundation. All rights reserved.