Class RecoveredReplicationSourceShipper
java.lang.Object
java.lang.Thread
org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSourceShipper
- All Implemented Interfaces:
Runnable
Used by a
RecoveredReplicationSource.-
Nested Class Summary
Nested classes/interfaces inherited from class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
ReplicationSourceShipper.WorkerStateNested classes/interfaces inherited from class java.lang.Thread
Thread.State, Thread.UncaughtExceptionHandler -
Field Summary
FieldsModifier and TypeFieldDescriptionprivate static final org.slf4j.Loggerprivate final ReplicationQueueStorageprotected final RecoveredReplicationSourceFields inherited from class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
entryReader, logQueue, maxRetriesMultiplier, sleepForRetries, walGroupIdFields inherited from class java.lang.Thread
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY -
Constructor Summary
ConstructorsConstructorDescriptionRecoveredReplicationSourceShipper(org.apache.hadoop.conf.Configuration conf, String walGroupId, ReplicationSourceLogQueue logQueue, RecoveredReplicationSource source, ReplicationQueueStorage queueStorage) -
Method Summary
Modifier and TypeMethodDescriptionprivate longlongprotected voidprotected voidprivate voidMethods inherited from class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
clearWALEntryBatch, getCurrentPath, getCurrentPosition, isActive, isFinished, run, setWALReader, setWorkerState, sleepForRetries, startup, stopWorkerMethods inherited from class java.lang.Thread
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
-
Field Details
-
LOG
-
source
-
replicationQueues
-
-
Constructor Details
-
RecoveredReplicationSourceShipper
public RecoveredReplicationSourceShipper(org.apache.hadoop.conf.Configuration conf, String walGroupId, ReplicationSourceLogQueue logQueue, RecoveredReplicationSource source, ReplicationQueueStorage queueStorage)
-
-
Method Details
-
noMoreData
- Overrides:
noMoreDatain classReplicationSourceShipper
-
postFinish
- Overrides:
postFinishin classReplicationSourceShipper
-
getStartPosition
- Overrides:
getStartPositionin classReplicationSourceShipper
-
getRecoveredQueueStartPos
-
terminate
-