Thread.State, Thread.UncaughtExceptionHandler
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
Constructor and Description |
---|
SerialReplicationSourceWALReader(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
PriorityBlockingQueue<org.apache.hadoop.fs.Path> logQueue,
long startPosition,
WALEntryFilter filter,
ReplicationSource source) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
addEntryToBatch(org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch batch,
WAL.Entry entry) |
protected org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch |
createBatch(org.apache.hadoop.hbase.replication.regionserver.WALEntryStream entryStream) |
protected WAL.Entry |
filterEntry(WAL.Entry entry) |
org.apache.hadoop.fs.Path |
getCurrentPath() |
static long |
getEntrySizeExcludeBulkLoad(WAL.Entry entry) |
boolean |
isReaderRunning() |
org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch |
poll(long timeout) |
protected org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch |
readWALEntries(org.apache.hadoop.hbase.replication.regionserver.WALEntryStream entryStream) |
void |
run() |
void |
setReaderRunning(boolean readerRunning) |
protected static boolean |
switched(org.apache.hadoop.hbase.replication.regionserver.WALEntryStream entryStream,
org.apache.hadoop.fs.Path path) |
org.apache.hadoop.hbase.replication.regionserver.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 SerialReplicationSourceWALReader(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, PriorityBlockingQueue<org.apache.hadoop.fs.Path> logQueue, long startPosition, WALEntryFilter filter, ReplicationSource source)
protected org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch readWALEntries(org.apache.hadoop.hbase.replication.regionserver.WALEntryStream entryStream) throws IOException, InterruptedException
IOException
InterruptedException
protected final boolean addEntryToBatch(org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch batch, WAL.Entry entry)
protected static final boolean switched(org.apache.hadoop.hbase.replication.regionserver.WALEntryStream entryStream, org.apache.hadoop.fs.Path path)
public org.apache.hadoop.fs.Path getCurrentPath()
protected final org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch createBatch(org.apache.hadoop.hbase.replication.regionserver.WALEntryStream entryStream)
public org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch take() throws InterruptedException
InterruptedException
- if interrupted while waitingpublic org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch poll(long timeout) throws InterruptedException
InterruptedException
public static long getEntrySizeExcludeBulkLoad(WAL.Entry entry)
public boolean isReaderRunning()
public void setReaderRunning(boolean readerRunning)
readerRunning
- the readerRunning to setCopyright © 2007–2019 Cloudera. All rights reserved.