Uses of Interface
org.apache.hadoop.hbase.wal.WAL
Package
Description
Table of Contents
-
Uses of WAL in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionstatic WAL
HBaseTestingUtility.createWal
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.Path rootDir, RegionInfo hri) Deprecated.Create an unmanaged WAL.MockRegionServerServices.getWAL
(RegionInfo regionInfo) Modifier and TypeMethodDescriptionHBaseTestingUtility.createLocalHRegion
(RegionInfo info, org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, WAL wal) Deprecated.Create an HRegion that writes to the local tmp dirs with specified walHBaseTestingUtility.createLocalHRegion
(TableName tableName, byte[] startKey, byte[] stopKey, org.apache.hadoop.conf.Configuration conf, boolean isReadOnly, Durability durability, WAL wal, byte[]... families) Deprecated.Return a region on which you must callHBaseTestingUtility.closeRegionAndWAL(HRegion)
when done.HBaseTestingUtility.createLocalHRegionWithInMemoryFlags
(TableName tableName, byte[] startKey, byte[] stopKey, org.apache.hadoop.conf.Configuration conf, boolean isReadOnly, Durability durability, WAL wal, boolean[] compactedMemStore, byte[]... families) Deprecated. -
Uses of WAL in org.apache.hadoop.hbase.coprocessor
-
Uses of WAL in org.apache.hadoop.hbase.master.region
Modifier and TypeMethodDescriptionprivate static WAL
MasterRegion.createWAL
(WALFactory walFactory, MasterRegionWALRoller walRoller, String serverName, org.apache.hadoop.fs.FileSystem walFs, org.apache.hadoop.fs.Path walRootDir, RegionInfo regionInfo) -
Uses of WAL in org.apache.hadoop.hbase.regionserver
Modifier and TypeMethodDescriptionHRegion.getWAL()
Returns WAL in use for this regionHRegionServer.getWAL
(RegionInfo regionInfo) RegionServerServices.getWAL
(RegionInfo regionInfo) Returns the WAL for a particular region.RegionServicesForStores.getWAL()
Modifier and TypeMethodDescription(package private) Map<WAL,
AbstractWALRoller<RegionServerServices>.RollController> LogRoller.getWalNeedsRoll()
HRegionServer.getWALs()
RegionServerServices.getWALs()
Returns the List of WALs that are used by this server Doesn't include the meta WALModifier and TypeMethodDescriptionstatic HRegion
HRegion.createHRegion
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor hTableDescriptor, WAL wal) static HRegion
HRegion.createHRegion
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor hTableDescriptor, WAL wal, boolean initialize) Convenience method creating new HRegions.static HRegion
HRegion.createHRegion
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor hTableDescriptor, WAL wal, boolean initialize, RegionServerServices rsRpcServices) Convenience method creating new HRegions.private void
HRegion.doAbortFlushToWAL
(WAL wal, long flushOpSeqId, Map<byte[], List<org.apache.hadoop.fs.Path>> committedFiles) private static void
HRegion.doSyncOfUnflushedWALChanges
(WAL wal, RegionInfo hri) Sync unflushed WAL changes.protected long
HRegion.getNextSequenceId
(WAL wal) Method to safely get the next sequence number.protected HRegion.FlushResultImpl
HRegion.internalFlushcache
(WAL wal, long myseqid, Collection<HStore> storesToFlush, MonitoredTask status, boolean writeFlushWalMarker, FlushLifeCycleTracker tracker) Flush the memstore.(package private) HRegion.FlushResultImpl
HRegion.internalFlushCacheAndCommit
(WAL wal, MonitoredTask status, HRegion.PrepareFlushResult prepareResult, Collection<HStore> storesToFlush) protected HRegion.PrepareFlushResult
HRegion.internalPrepareFlushCache
(WAL wal, long myseqid, Collection<HStore> storesToFlush, MonitoredTask status, boolean writeFlushWalMarker, FlushLifeCycleTracker tracker) static HRegion
HRegion.newHRegion
(org.apache.hadoop.fs.Path tableDir, WAL wal, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, RegionInfo regionInfo, TableDescriptor htd, RegionServerServices rsServices) A utility method to create new instances of HRegion based on theHConstants.REGION_IMPL
configuration property.static HRegion
HRegion.openHRegion
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, RegionInfo info, TableDescriptor htd, WAL wal) Open a Region.static HRegion
HRegion.openHRegion
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, RegionInfo info, TableDescriptor htd, WAL wal, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegion
HRegion.openHRegion
(org.apache.hadoop.fs.Path rootDir, RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf) Open a Region.static HRegion
HRegion.openHRegion
(org.apache.hadoop.fs.Path rootDir, RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegion
HRegion.openHRegion
(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf) Open a Region.static HRegion
HRegion.openHRegion
(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegion
HRegion.openHRegionFromTableDir
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, RegionInfo info, TableDescriptor htd, WAL wal, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegion
HRegion.warmupHRegion
(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) private boolean
HRegion.writeCanNotFlushMarkerToWAL
(MultiVersionConcurrencyControl.WriteEntry flushOpSeqIdMVCCEntry, WAL wal, boolean writeFlushWalMarker) This method is only used when we flush but the memstore is empty,if writeFlushWalMarker is true,we write theWALProtos.FlushDescriptor.FlushAction.CANNOT_FLUSH
flush marker to WAL when the memstore is empty.private void
HRegion.writeRegionCloseMarker
(WAL wal) protected void
HRegion.writeRegionOpenMarker
(WAL wal, long openSeqId) ModifierConstructorDescriptionHRegion
(org.apache.hadoop.fs.Path tableDir, WAL wal, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration confParam, RegionInfo regionInfo, TableDescriptor htd, RegionServerServices rsServices) Deprecated.Use other constructors.HRegion
(HRegionFileSystem fs, WAL wal, org.apache.hadoop.conf.Configuration confParam, TableDescriptor htd, RegionServerServices rsServices) HRegion constructor. -
Uses of WAL in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeClassDescriptionclass
AbstractFSWAL<W extends WALProvider.WriterBase>
Implementation ofWAL
to go againstFileSystem
; i.e.class
An asynchronous implementation of FSWAL.class
The original implementation of FSWAL.Modifier and TypeFieldDescriptionprivate final WAL
WALCoprocessorHost.wal
private final WAL
WALCoprocessorHost.WALEnvironment.wal
Modifier and TypeMethodDescriptionprivate static WALKeyImpl
WALUtil.doFullMarkerAppendTransaction
(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, WALEdit edit, MultiVersionConcurrencyControl mvcc, Map<String, byte[]> extendedAttributes, boolean sync, RegionReplicationSink sink) A 'full' WAL transaction involves starting an mvcc transaction followed by an append, an optional sync, and then a call to complete the mvcc transaction.static WALKeyImpl
WALUtil.writeBulkLoadMarkerAndSync
(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor desc, MultiVersionConcurrencyControl mvcc, RegionReplicationSink sink) Write a log marker that a bulk load has succeeded and is about to be committed.static WALKeyImpl
WALUtil.writeCompactionMarker
(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptor c, MultiVersionConcurrencyControl mvcc, RegionReplicationSink sink) Write the marker that a compaction has succeeded and is about to be committed.static WALKeyImpl
WALUtil.writeFlushMarker
(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor f, boolean sync, MultiVersionConcurrencyControl mvcc, RegionReplicationSink sink) Write a flush marker indicating a start / abort or a complete of a region flushprivate static WALKeyImpl
WALUtil.writeMarker
(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, WALEdit edit, MultiVersionConcurrencyControl mvcc, Map<String, byte[]> extendedAttributes, RegionReplicationSink sink) static WALKeyImpl
WALUtil.writeRegionEventMarker
(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptor r, MultiVersionConcurrencyControl mvcc, RegionReplicationSink sink) Write a region open marker indicating that the region is opened.static void
WALUtil.writeReplicationMarkerAndSync
(WAL wal, MultiVersionConcurrencyControl mvcc, RegionInfo regionInfo, byte[] rowKey, long timestamp) ModifierConstructorDescriptionWALCoprocessorHost
(WAL log, org.apache.hadoop.conf.Configuration conf) Constructorprivate
WALEnvironment
(WALCoprocessor impl, int priority, int seq, org.apache.hadoop.conf.Configuration conf, WAL wal) Constructor -
Uses of WAL in org.apache.hadoop.hbase.replication.regionserver
-
Uses of WAL in org.apache.hadoop.hbase.wal
Modifier and TypeFieldDescription(package private) WAL
DisabledWALProvider.disabled
private final WAL
AbstractWALRoller.RollController.wal
Modifier and TypeFieldDescriptionprivate final ConcurrentMap<String,
Optional<WAL>> AbstractWALProvider.peerId2WAL
protected final ConcurrentMap<WAL,
AbstractWALRoller<T>.RollController> AbstractWALRoller.wals
WALPerformanceEvaluation.walsListenedTo
Modifier and TypeMethodDescriptionprotected WAL
AbstractFSWALProvider.createRemoteWAL
(RegionInfo region, org.apache.hadoop.fs.FileSystem remoteFs, org.apache.hadoop.fs.Path remoteWALDir, String prefix, String suffix) protected abstract WAL
AbstractWALProvider.createRemoteWAL
(RegionInfo region, org.apache.hadoop.fs.FileSystem remoteFs, org.apache.hadoop.fs.Path remoteWALDir, String prefix, String suffix) protected WAL
AsyncFSWALProvider.createRemoteWAL
(RegionInfo region, org.apache.hadoop.fs.FileSystem remoteFs, org.apache.hadoop.fs.Path remoteWALDir, String prefix, String suffix) protected WAL
FSHLogProvider.createRemoteWAL
(RegionInfo region, org.apache.hadoop.fs.FileSystem remoteFs, org.apache.hadoop.fs.Path remoteWALDir, String prefix, String suffix) protected WAL
RegionGroupingProvider.createRemoteWAL
(RegionInfo region, org.apache.hadoop.fs.FileSystem remoteFs, org.apache.hadoop.fs.Path remoteWALDir, String prefix, String suffix) private WAL
AbstractWALProvider.getRemoteWAL
(RegionInfo region, String peerId, String remoteWALDir) final WAL
AbstractWALProvider.getWAL
(RegionInfo region) DisabledWALProvider.getWAL
(RegionInfo region) private WAL
WALFactory.getWAL
(RegionInfo region) WALProvider.getWAL
(RegionInfo region) protected abstract WAL
AbstractWALProvider.getWAL0
(RegionInfo region) protected WAL
RegionGroupingProvider.getWAL0
(RegionInfo region) Modifier and TypeMethodDescriptionAbstractWALProvider.getWALs()
DisabledWALProvider.getWALs()
WALFactory.getWALs()
WALProvider.getWALs()
Returns the List of WALs that are used by this serverAbstractFSWALProvider.getWALs0()
AbstractWALProvider.getWALs0()
RegionGroupingProvider.getWALs0()
Modifier and TypeMethodDescriptionvoid
static long
AbstractFSWALProvider.extractFileNumFromWAL
(WAL wal) It returns the file create timestamp (the 'FileNum') from the file name.static org.apache.hadoop.fs.Path
AbstractFSWALProvider.getCurrentFileName
(WAL wal) return the current filename from the current wal.static long
AbstractFSWALProvider.getLogFileSize
(WAL wal) returns the size of rolled WAL files.static int
AbstractFSWALProvider.getNumRolledLogFiles
(WAL wal) returns the number of rolled WAL files.protected final void
(package private) static void
AbstractFSWALProvider.requestLogRoll
(WAL wal) request a log roll, but don't actually do it.private static void
Modifier and TypeMethodDescriptionprivate void
AbstractWALProvider.cleanup
(IOExceptionConsumer<WAL> cleanupWAL, IOExceptionRunnable finalCleanup)