private static final class TestWALLockup.DodgyFSLog extends org.apache.hadoop.hbase.regionserver.wal.FSHLog
| Modifier and Type | Field and Description |
|---|---|
(package private) CountDownLatch |
latch |
(package private) boolean |
throwException |
blocksize, closed, conf, coprocessorHost, DEFAULT_SLOW_SYNC_TIME_MS, filenum, fs, highestSyncedTxid, highestUnsyncedTxid, implClassName, listeners, logrollsize, maxLogs, numEntries, ourFiles, prefixPathStr, rollRequested, rollWriterLock, sequenceIdAccounting, shutdown, slowSyncNs, totalLogSize, walArchiveDir, walDir, walFile2Props, walFilePrefix, walFileSuffix| Constructor and Description |
|---|
DodgyFSLog(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path root,
String logDir,
org.apache.hadoop.conf.Configuration conf) |
| Modifier and Type | Method and Description |
|---|---|
protected void |
afterCreatingZigZagLatch() |
protected void |
beforeWaitOnSafePoint() |
protected org.apache.hadoop.hbase.wal.WALProvider.Writer |
createWriterInstance(org.apache.hadoop.fs.Path path) |
append, doAppend, doCheckLogLowReplication, doReplaceWriter, doShutdown, getSequenceOnRingBuffer, publishSyncOnRingBuffer, sync, syncabortCacheFlush, append, atHeadOfRingBufferEventHandlerAppend, blockOnSync, checkLogLowReplication, close, completeCacheFlush, computeFilename, getCoprocessorHost, getCurrentFileName, getEarliestMemStoreSeqNum, getEarliestMemStoreSeqNum, getFilenum, getFileNumFromFileName, getLogFileSize, getLogFileSizeIfBeingWritten, getNumLogFiles, getNumRolledLogFiles, getPreallocatedEventCount, getSyncFuture, getWALArchivePath, isLogRollRequested, logRollAndSetupWalProps, main, postSync, registerWALActionsListener, requestLogRoll, requestLogRoll, rollWriter, rollWriter, shutdown, stampSequenceIdAndPublishToRingBuffer, startCacheFlush, startCacheFlush, toString, unregisterWALActionsListener, updateStorevolatile boolean throwException
CountDownLatch latch
public DodgyFSLog(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path root, String logDir, org.apache.hadoop.conf.Configuration conf) throws IOException
IOExceptionprotected void afterCreatingZigZagLatch()
afterCreatingZigZagLatch in class org.apache.hadoop.hbase.regionserver.wal.FSHLogprotected void beforeWaitOnSafePoint()
beforeWaitOnSafePoint in class org.apache.hadoop.hbase.regionserver.wal.FSHLogprotected org.apache.hadoop.hbase.wal.WALProvider.Writer createWriterInstance(org.apache.hadoop.fs.Path path) throws IOException
createWriterInstance in class org.apache.hadoop.hbase.regionserver.wal.FSHLogIOExceptionCopyright © 2007–2019 The Apache Software Foundation. All rights reserved.