public abstract class InterBrokerSendThread extends ShutdownableThread
Thread.State, Thread.UncaughtExceptionHandler
logPrefix
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
Constructor and Description |
---|
InterBrokerSendThread(String name,
org.apache.kafka.clients.KafkaClient networkClient,
int requestTimeoutMs,
org.apache.kafka.common.utils.Time time) |
InterBrokerSendThread(String name,
org.apache.kafka.clients.KafkaClient networkClient,
int requestTimeoutMs,
org.apache.kafka.common.utils.Time time,
boolean isInterruptible) |
Modifier and Type | Method and Description |
---|---|
void |
doWork()
This method is repeatedly invoked until the thread shuts down or this method throws an exception
|
abstract Collection<RequestAndCompletionHandler> |
generateRequests() |
boolean |
hasUnsentRequests() |
void |
shutdown() |
void |
wakeup() |
awaitShutdown, initiateShutdown, isRunning, isShutdownComplete, isShutdownInitiated, isThreadFailed, pause, run
activeCount, checkAccess, 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 InterBrokerSendThread(String name, org.apache.kafka.clients.KafkaClient networkClient, int requestTimeoutMs, org.apache.kafka.common.utils.Time time)
public InterBrokerSendThread(String name, org.apache.kafka.clients.KafkaClient networkClient, int requestTimeoutMs, org.apache.kafka.common.utils.Time time, boolean isInterruptible)
public abstract Collection<RequestAndCompletionHandler> generateRequests()
public boolean hasUnsentRequests()
public void shutdown() throws InterruptedException
shutdown
in class ShutdownableThread
InterruptedException
public void doWork()
ShutdownableThread
doWork
in class ShutdownableThread
public void wakeup()