@InterfaceAudience.Private public class FaultyFSLog extends org.apache.hadoop.hbase.regionserver.wal.FSHLog
Modifier and Type | Class and Description |
---|---|
static class |
FaultyFSLog.FailureType |
Modifier and Type | Field and Description |
---|---|
(package private) FaultyFSLog.FailureType |
ft |
abortable, blocksize, closed, conf, coprocessorHost, DEFAULT_ROLL_ON_SYNC_TIME_MS, DEFAULT_SLOW_SYNC_ROLL_INTERVAL_MS, DEFAULT_SLOW_SYNC_ROLL_THRESHOLD, DEFAULT_SLOW_SYNC_TIME_MS, DEFAULT_WAL_SYNC_TIMEOUT_MS, filenum, fs, highestSyncedTxid, highestUnsyncedTxid, implClassName, inflightWALClosures, listeners, logrollsize, MAX_LOGS, maxLogs, numEntries, ourFiles, prefixPathStr, RING_BUFFER_SLOT_COUNT, ROLL_ON_SYNC_TIME_MS, rollOnSyncNs, rollRequested, rollWriterLock, sequenceIdAccounting, shutdown, SLOW_SYNC_ROLL_INTERVAL_MS, SLOW_SYNC_ROLL_THRESHOLD, SLOW_SYNC_TIME_MS, slowSyncCheckInterval, slowSyncCount, slowSyncNs, slowSyncRollThreshold, syncFutureCache, totalLogSize, useHsync, WAL_ROLL_MULTIPLIER, WAL_SYNC_TIMEOUT_MS, walArchiveDir, walDir, walFile2Props, walFilePrefix, walFileSuffix
Constructor and Description |
---|
FaultyFSLog(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
String logName,
org.apache.hadoop.conf.Configuration conf) |
Modifier and Type | Method and Description |
---|---|
protected long |
append(org.apache.hadoop.hbase.client.RegionInfo info,
org.apache.hadoop.hbase.wal.WALKeyImpl key,
org.apache.hadoop.hbase.wal.WALEdit edits,
boolean inMemstore) |
protected void |
doSync(long txid,
boolean forceSync) |
void |
setFailureType(FaultyFSLog.FailureType fType) |
afterCreatingZigZagLatch, beforeWaitOnSafePoint, createWriterInstance, doAppend, doCheckLogLowReplication, doReplaceWriter, doShutdown, doSync, getSequenceOnRingBuffer, publishSyncOnRingBuffer
abortCacheFlush, appendData, appendEntry, appendMarker, archive, archiveLogFile, atHeadOfRingBufferEventHandlerAppend, blockOnSync, checkLogLowReplication, close, completeCacheFlush, computeFilename, doCheckSlowSync, getCoprocessorHost, getCurrentFileName, getEarliestMemStoreSeqNum, getEarliestMemStoreSeqNum, getFilenum, getFileNumFromFileName, getInflightWALCloseCount, getLogFileSize, getLogFileSizeIfBeingWritten, getNumLogFiles, getNumRolledLogFiles, getPreallocatedEventCount, getSyncFuture, getWALArchivePath, init, isLogRollRequested, logRollAndSetupWalProps, main, postSync, registerWALActionsListener, requestLogRoll, requestLogRoll, rollWriter, rollWriter, shutdown, stampSequenceIdAndPublishToRingBuffer, startCacheFlush, startCacheFlush, sync, sync, sync, sync, toString, unregisterWALActionsListener, updateStore
public FaultyFSLog(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, String logName, org.apache.hadoop.conf.Configuration conf) throws IOException
IOException
public void setFailureType(FaultyFSLog.FailureType fType)
protected void doSync(long txid, boolean forceSync) throws IOException
doSync
in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
IOException
protected long append(org.apache.hadoop.hbase.client.RegionInfo info, org.apache.hadoop.hbase.wal.WALKeyImpl key, org.apache.hadoop.hbase.wal.WALEdit edits, boolean inMemstore) throws IOException
append
in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
IOException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.