private static class IOTestProvider.IOTestWAL extends org.apache.hadoop.hbase.regionserver.wal.FSHLog
| Modifier and Type | Field and Description | 
|---|---|
| private boolean | doFileRolls | 
| private boolean | initialized | 
| private org.apache.hadoop.hbase.wal.WALProvider.Writer | noRollsWriter | 
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 | 
|---|
| IOTestWAL(org.apache.hadoop.fs.FileSystem fs,
         org.apache.hadoop.fs.Path rootDir,
         String logDir,
         String archiveDir,
         org.apache.hadoop.conf.Configuration conf,
         List<org.apache.hadoop.hbase.regionserver.wal.WALActionsListener> listeners,
         boolean failIfWALExists,
         String prefix,
         String suffix)Create an edit log at the given  dirlocation. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected org.apache.hadoop.hbase.wal.WALProvider.Writer | createWriterInstance(org.apache.hadoop.fs.Path path) | 
afterCreatingZigZagLatch, append, beforeWaitOnSafePoint, doAppend, doCheckLogLowReplication, doReplaceWriter, doShutdown, doSync, doSync, getSequenceOnRingBuffer, publishSyncOnRingBufferabortCacheFlush, 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, updateStoreprivate final boolean doFileRolls
private final boolean initialized
private org.apache.hadoop.hbase.wal.WALProvider.Writer noRollsWriter
public IOTestWAL(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, String logDir, String archiveDir, org.apache.hadoop.conf.Configuration conf, List<org.apache.hadoop.hbase.regionserver.wal.WALActionsListener> listeners, boolean failIfWALExists, String prefix, String suffix) throws IOException
dir location. You should never have to load an
 existing log. If there is a log at startup, it should have already been processed and deleted
 by the time the WAL object is started up.fs - filesystem handlerootDir - path to where logs and oldlogslogDir - dir where wals are storedarchiveDir - dir where wals are archivedconf - configuration to uselisteners - Listeners on WAL events. Listeners passed here will be registered
                        before we do anything else; e.g. the Constructor
                        AbstractFSWAL.rollWriter().failIfWALExists - If true IOException will be thrown if files related to this wal
                        already exist.prefix - should always be hostname and port in distributed env and it will be
                        URL encoded before being used. If prefix is null, "wal" will be usedsuffix - will be url encoded. null is treated as empty. non-empty must start
                        with AbstractFSWALProvider.WAL_FILE_NAME_DELIMITER nIOExceptionprotected 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–2020 The Apache Software Foundation. All rights reserved.