protected static class UnilateralSortMerger.ReadingThread<E> extends UnilateralSortMerger.ThreadBase<E>
Thread.State, Thread.UncaughtExceptionHandler
queues
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
Constructor and Description |
---|
ReadingThread(ExceptionHandler<IOException> exceptionHandler,
MutableObjectIterator<E> reader,
UnilateralSortMerger.CircularQueues<E> queues,
LargeRecordHandler<E> largeRecordsHandler,
E readTarget,
AbstractInvokable parentTask,
long startSpillingBytes)
Creates a new reading thread.
|
Modifier and Type | Method and Description |
---|---|
void |
go()
The entry point for the thread.
|
internalHandleException, isRunning, run, shutdown, uncaughtException
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 ReadingThread(ExceptionHandler<IOException> exceptionHandler, MutableObjectIterator<E> reader, UnilateralSortMerger.CircularQueues<E> queues, LargeRecordHandler<E> largeRecordsHandler, E readTarget, AbstractInvokable parentTask, long startSpillingBytes)
exceptionHandler
- The exception handler to call for all exceptions.reader
- The reader to pull the data from.queues
- The queues used to pass buffers between the threads.parentTask
- The task that started this thread. If non-null, it is used to register this thread.public void go() throws IOException
go
in class UnilateralSortMerger.ThreadBase<E>
IOException
- Exceptions that prohibit correct completion of the work may be thrown by the thread.Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.