| Package | Description |
|---|---|
| org.apache.hadoop.hbase.constraint |
Restrict the domain of a data attribute, often times to fulfill business rules/requirements.
|
| org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
| org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.regionserver.wal | |
| org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
| org.apache.hadoop.hbase.replication.regionserver | |
| org.apache.hadoop.hbase.security.access | |
| org.apache.hadoop.hbase.wal |
| Class and Description |
|---|
| WALEdit
Used in HBase's transaction log (WAL) to represent a collection of edits (Cell/KeyValue objects)
that came in as a single transaction.
|
| Class and Description |
|---|
| WAL
A Write Ahead Log (WAL) provides service for reading, writing waledits.
|
| WALEdit
Used in HBase's transaction log (WAL) to represent a collection of edits (Cell/KeyValue objects)
that came in as a single transaction.
|
| WALKey
Key for WAL Entry.
|
| Class and Description |
|---|
| WAL.Entry
Utility class that lets us keep track of the edit with it's key.
|
| WAL.Reader
When outside clients need to consume persisted WALs, they rely on a provided
Reader.
|
| WALEdit
Used in HBase's transaction log (WAL) to represent a collection of edits (Cell/KeyValue objects)
that came in as a single transaction.
|
| WALKey
Key for WAL Entry.
|
| Class and Description |
|---|
| WAL
A Write Ahead Log (WAL) provides service for reading, writing waledits.
|
| WALEdit
Used in HBase's transaction log (WAL) to represent a collection of edits (Cell/KeyValue objects)
that came in as a single transaction.
|
| WALFactory
Entry point for users of the Write Ahead Log.
|
| WALKey
Key for WAL Entry.
|
| WALProvider
The Write Ahead Log (WAL) stores all durable edits to the HRegion.
|
| WALSplitter.MutationReplay
A struct used by getMutationsFromWALEntry
|
| Class and Description |
|---|
| AbstractFSWALProvider.Reader |
| AsyncFSWALProvider.AsyncWriter |
| FSHLogProvider.Writer |
| WAL
A Write Ahead Log (WAL) provides service for reading, writing waledits.
|
| WAL.Entry
Utility class that lets us keep track of the edit with it's key.
|
| WAL.Reader
When outside clients need to consume persisted WALs, they rely on a provided
Reader.
|
| WALEdit
Used in HBase's transaction log (WAL) to represent a collection of edits (Cell/KeyValue objects)
that came in as a single transaction.
|
| WALKey
Key for WAL Entry.
|
| WALKeyImpl
Default implementation of Key for an Entry in the WAL.
|
| WALProvider.AsyncWriter |
| WALProvider.Writer |
| WALProvider.WriterBase |
| Class and Description |
|---|
| WAL.Entry
Utility class that lets us keep track of the edit with it's key.
|
| Class and Description |
|---|
| WAL.Entry
Utility class that lets us keep track of the edit with it's key.
|
| WAL.Reader
When outside clients need to consume persisted WALs, they rely on a provided
Reader.
|
| WALEdit
Used in HBase's transaction log (WAL) to represent a collection of edits (Cell/KeyValue objects)
that came in as a single transaction.
|
| WALKey
Key for WAL Entry.
|
| WALProvider
The Write Ahead Log (WAL) stores all durable edits to the HRegion.
|
| WALSplitter.EntryBuffers
Class which accumulates edits and separates them into a buffer per region
while simultaneously accounting RAM usage.
|
| WALSplitter.OutputSink
The following class is an abstraction class to provide a common interface to support
different ways of consuming recovered edits.
|
| WALSplitter.PipelineController
Contains some methods to control WAL-entries producer / consumer interactions
|
| WALSplitter.RegionEntryBuffer
A buffer of some number of edits for a given region.
|
| WALSplitter.SinkWriter
Class wraps the actual writer which writes data out and related statistics
|
| Class and Description |
|---|
| WALEdit
Used in HBase's transaction log (WAL) to represent a collection of edits (Cell/KeyValue objects)
that came in as a single transaction.
|
| Class and Description |
|---|
| AbstractFSWALProvider
Base class of a WAL Provider that returns a single thread safe WAL that writes to Hadoop FS.
|
| AbstractFSWALProvider.Reader |
| AsyncFSWALProvider.AsyncWriter |
| FSHLogProvider.Writer |
| RegionGroupingProvider.RegionGroupingStrategy
Map identifiers to a group number.
|
| RegionGroupingProvider.Strategies
Maps between configuration names for strategies and implementation classes.
|
| WAL
A Write Ahead Log (WAL) provides service for reading, writing waledits.
|
| WAL.Entry
Utility class that lets us keep track of the edit with it's key.
|
| WAL.Reader
When outside clients need to consume persisted WALs, they rely on a provided
Reader.
|
| WALEdit
Used in HBase's transaction log (WAL) to represent a collection of edits (Cell/KeyValue objects)
that came in as a single transaction.
|
| WALFactory
Entry point for users of the Write Ahead Log.
|
| WALFactory.Providers
Maps between configuration names for providers and implementation classes.
|
| WALKey
Key for WAL Entry.
|
| WALKeyImpl
Default implementation of Key for an Entry in the WAL.
|
| WALProvider
The Write Ahead Log (WAL) stores all durable edits to the HRegion.
|
| WALProvider.AsyncWriter |
| WALProvider.Writer |
| WALProvider.WriterBase |
| WALSplitter.CorruptedLogFileException |
| WALSplitter.EntryBuffers
Class which accumulates edits and separates them into a buffer per region
while simultaneously accounting RAM usage.
|
| WALSplitter.LogRecoveredEditsOutputSink
Class that manages the output streams from the log splitting process.
|
| WALSplitter.MutationReplay
A struct used by getMutationsFromWALEntry
|
| WALSplitter.OutputSink
The following class is an abstraction class to provide a common interface to support
different ways of consuming recovered edits.
|
| WALSplitter.PipelineController
Contains some methods to control WAL-entries producer / consumer interactions
|
| WALSplitter.RegionEntryBuffer
A buffer of some number of edits for a given region.
|
| WALSplitter.SinkWriter
Class wraps the actual writer which writes data out and related statistics
|
| WALSplitter.WriterAndPath
Private data structure that wraps a Writer and its Path, also collecting statistics about the
data written to this output.
|
| WALSplitter.WriterThread |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.