public class LocatedBlocksRefresher
extends org.apache.hadoop.util.Daemon
LocatedBlocks
for eligible registered
DFSInputStream
s. DFSInputStreams are eligible for refreshing if they have any
deadNodes or any blocks are lacking local replicas.
Disabled by default, unless an interval is configured.Thread.State, Thread.UncaughtExceptionHandler
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
Modifier and Type | Method and Description |
---|---|
void |
addInputStream(org.apache.hadoop.hdfs.DFSInputStream dfsInputStream) |
long |
getInterval() |
int |
getRefreshCount() |
int |
getRunCount() |
boolean |
isInputStreamTracked(org.apache.hadoop.hdfs.DFSInputStream dfsInputStream) |
void |
removeInputStream(org.apache.hadoop.hdfs.DFSInputStream dfsInputStream) |
void |
run() |
void |
shutdown()
Shutdown all the threads.
|
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 int getRunCount()
public int getRefreshCount()
public void shutdown()
public void addInputStream(org.apache.hadoop.hdfs.DFSInputStream dfsInputStream)
public void removeInputStream(org.apache.hadoop.hdfs.DFSInputStream dfsInputStream)
public boolean isInputStreamTracked(org.apache.hadoop.hdfs.DFSInputStream dfsInputStream)
public long getInterval()
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.