@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 |
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 |
---|
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 |
---|---|
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) |
void |
setFailureType(FaultyFSLog.FailureType fType) |
void |
sync(long txid) |
afterCreatingZigZagLatch, beforeWaitOnSafePoint, createWriterInstance, doAppend, doCheckLogLowReplication, doReplaceWriter, doShutdown, getSequenceOnRingBuffer, publishSyncOnRingBuffer, sync
abortCacheFlush, 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, 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)
public void sync(long txid) throws IOException
sync
in interface org.apache.hadoop.hbase.wal.WAL
sync
in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
IOException
public 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 interface org.apache.hadoop.hbase.wal.WAL
append
in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
IOException
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.