Interface | Description |
---|---|
MetricsWALSource |
Interface of the source that will export metrics about the region server's WAL.
|
WALActionsListener |
Get notification of WAL events.
|
WALCellCodec.ByteStringCompressor | |
WALCellCodec.ByteStringUncompressor |
Class | Description |
---|---|
AbstractFSWAL<W extends WALProvider.WriterBase> |
Implementation of
WAL to go against FileSystem ; i.e. |
AbstractFSWAL.WALProps | |
AbstractProtobufLogWriter |
Base class for Protobuf log writer.
|
AbstractProtobufWALReader |
Base class for reading protobuf based wal reader
|
AsyncFSWAL |
An asynchronous implementation of FSWAL.
|
AsyncProtobufLogWriter |
AsyncWriter for protobuf-based WAL.
|
AsyncProtobufLogWriter.OutputStreamWrapper | |
CombinedAsyncWriter |
An
WALProvider.AsyncWriter wrapper which writes data to a set of WALProvider.AsyncWriter instances. |
CompressionContext |
Context that holds the various dictionaries for compression in WAL.
|
CompressionContext.ValueCompressor |
Encapsulates the compression algorithm and its streams that we will use for value compression
in this WAL.
|
Compressor |
A set of static functions for running our custom WAL compression/decompression.
|
DualAsyncFSWAL |
An AsyncFSWAL which writes data to two filesystems.
|
FSHLog |
The original implementation of FSWAL.
|
FSHLog.RingBufferExceptionHandler |
Exception handler to pass the disruptor ringbuffer.
|
FSHLog.SafePointZigZagLatch |
This class is used coordinating two threads holding one thread at a 'safe point' while the
orchestrating thread does some work that requires the first thread paused: e.g.
|
FSWALEntry |
A WAL Entry for
AbstractFSWAL implementation. |
MetricsWAL |
Class used to push numbers about the WAL into the metrics subsystem.
|
MetricsWALSourceImpl |
Class that transitions metrics from MetricsWAL into the metrics subsystem.
|
ProtobufLogWriter |
Writer for protobuf-based WAL.
|
ProtobufWALStreamReader |
A one way stream reader for reading protobuf based WAL file.
|
ProtobufWALTailingReader |
A WAL reader for replication.
|
ProtobufWALTailingReader.ReadWALKeyResult | |
RingBufferTruck |
A 'truck' to carry a payload across the ring buffer from Handler to WAL.
|
SecureWALCellCodec |
A WALCellCodec that encrypts the WALedits.
|
SecureWALCellCodec.EncryptedKvDecoder | |
SecureWALCellCodec.EncryptedKvEncoder | |
SequenceIdAccounting |
Accounting of sequence ids per region and then by column family.
|
SyncFuture |
A Future on a filesystem sync call.
|
SyncFutureCache |
A cache of
SyncFuture s. |
WALCellCodec |
Compression in this class is lifted off Compressor/KeyValueCompression.
|
WALCellCodec.BaosAndCompressor | |
WALCellCodec.CompressedKvDecoder | |
WALCellCodec.CompressedKvEncoder | |
WALCellCodec.EnsureKvEncoder | |
WALCellCodec.NoneCompressor | |
WALCellCodec.NoneUncompressor | |
WALCellCodec.StatelessUncompressor | |
WALCoprocessorHost |
Implements the coprocessor environment and runtime support for coprocessors loaded within a
WAL . |
WALCoprocessorHost.WALEnvironment |
Encapsulation of the environment of each coprocessor
|
WALEventTrackerListener | |
WALUtil |
Helper methods to ease Region Server integration with the Write Ahead Log (WAL).
|
Enum | Description |
---|---|
CompressionContext.DictionaryIndex | |
RingBufferTruck.Type | |
WALActionsListener.RollRequestReason |
The reason for the log roll request.
|
WALEventTrackerListener.WalState |
Exception | Description |
---|---|
DamagedWALException |
Thrown when a failed append or sync on a WAL.
|
FailedLogCloseException |
Thrown when we fail close of the write-ahead-log file.
|
FailedSyncBeforeLogCloseException |
Thrown when we fail close of the write-ahead-log file.
|
WALClosedException |
Thrown when
LogRoller try to roll writer but the WAL already was closed. |
WALHeaderEOFException |
A special EOFException to indicate that the EOF happens when we read the header of a WAL file.
|
WALSyncTimeoutIOException |
Thrown when
WAL.sync() timeout. |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.