Package | Description |
---|---|
org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.regionserver.wal | |
org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.wal |
Modifier and Type | Field and Description |
---|---|
(package private) WAL.Entry |
WALInputFormat.WALRecordReader.currentEntry |
Modifier and Type | Class and Description |
---|---|
(package private) class |
FSWALEntry
A WAL Entry for
FSHLog implementation. |
Modifier and Type | Field and Description |
---|---|
private List<WAL.Entry> |
WALEditsReplaySink.ReplayServerCallable.entries |
Modifier and Type | Method and Description |
---|---|
WAL.Entry |
ReaderBase.next() |
WAL.Entry |
ReaderBase.next(WAL.Entry reuse) |
Modifier and Type | Method and Description |
---|---|
void |
ProtobufLogWriter.append(WAL.Entry entry) |
WAL.Entry |
ReaderBase.next(WAL.Entry reuse) |
private long |
FSHLog.postAppend(WAL.Entry e,
long elapsedTime) |
protected boolean |
ProtobufLogReader.readNext(WAL.Entry entry) |
protected abstract boolean |
ReaderBase.readNext(WAL.Entry e)
Read next entry.
|
protected boolean |
SequenceFileLogReader.readNext(WAL.Entry e)
fill in the passed entry with teh next key/value.
|
Modifier and Type | Method and Description |
---|---|
private void |
WALEditsReplaySink.replayEdits(HRegionLocation regionLoc,
HRegionInfo regionInfo,
List<WAL.Entry> entries) |
void |
WALEditsReplaySink.replayEntries(List<Pair<HRegionLocation,WAL.Entry>> entries)
Replay an array of actions of the same region directly into the newly assigned Region Server
|
private void |
WALEditsReplaySink.ReplayServerCallable.replayToServer(HRegionInfo regionInfo,
List<WAL.Entry> entries) |
Constructor and Description |
---|
WALEditsReplaySink.ReplayServerCallable(HConnection connection,
TableName tableName,
HRegionLocation regionLoc,
HRegionInfo regionInfo,
List<WAL.Entry> entries) |
Modifier and Type | Field and Description |
---|---|
(package private) List<WAL.Entry> |
ReplicationEndpoint.ReplicateContext.entries |
Modifier and Type | Method and Description |
---|---|
WAL.Entry |
SystemTableWALEntryFilter.filter(WAL.Entry entry) |
WAL.Entry |
TableCfWALEntryFilter.filter(WAL.Entry entry) |
WAL.Entry |
ScopeWALEntryFilter.filter(WAL.Entry entry) |
WAL.Entry |
ChainWALEntryFilter.filter(WAL.Entry entry) |
WAL.Entry |
WALEntryFilter.filter(WAL.Entry entry)
Applies the filter, possibly returning a different Entry instance.
|
Modifier and Type | Method and Description |
---|---|
List<WAL.Entry> |
ReplicationEndpoint.ReplicateContext.getEntries() |
Modifier and Type | Method and Description |
---|---|
WAL.Entry |
SystemTableWALEntryFilter.filter(WAL.Entry entry) |
WAL.Entry |
TableCfWALEntryFilter.filter(WAL.Entry entry) |
WAL.Entry |
ScopeWALEntryFilter.filter(WAL.Entry entry) |
WAL.Entry |
ChainWALEntryFilter.filter(WAL.Entry entry) |
WAL.Entry |
WALEntryFilter.filter(WAL.Entry entry)
Applies the filter, possibly returning a different Entry instance.
|
Modifier and Type | Method and Description |
---|---|
ReplicationEndpoint.ReplicateContext |
ReplicationEndpoint.ReplicateContext.setEntries(List<WAL.Entry> entries) |
Modifier and Type | Field and Description |
---|---|
private List<WAL.Entry> |
HBaseInterClusterReplicationEndpoint.Replicator.entries |
private List<WAL.Entry> |
RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable.entries |
Modifier and Type | Method and Description |
---|---|
WAL.Entry |
RegionReplicaReplicationEndpoint.SkipReplayedEditsFilter.filter(WAL.Entry entry) |
WAL.Entry |
ReplicationWALReaderManager.readNextAndSetPosition()
Get the next entry, returned and also added in the array
|
Modifier and Type | Method and Description |
---|---|
WAL.Entry |
RegionReplicaReplicationEndpoint.SkipReplayedEditsFilter.filter(WAL.Entry entry) |
boolean |
RegionReplicaReplicationEndpoint.RegionReplicaOutputSink.keepRegionEvent(WAL.Entry entry) |
Modifier and Type | Method and Description |
---|---|
void |
RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter.append(TableName tableName,
byte[] encodedRegionName,
byte[] row,
List<WAL.Entry> entries) |
protected HBaseInterClusterReplicationEndpoint.Replicator |
HBaseInterClusterReplicationEndpoint.createReplicator(List<WAL.Entry> entries,
int ordinal) |
protected boolean |
ReplicationSource.ReplicationSourceWorkerThread.readAllEntriesToReplicateOrNextFile(boolean currentWALisBeingWrittenTo,
List<WAL.Entry> entries)
Read all the entries from the current log files and retain those that need to be replicated.
|
private org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse |
RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable.replayToServer(List<WAL.Entry> entries,
int timeout) |
private boolean |
RegionReplicaReplicationEndpoint.RegionReplicaOutputSink.requiresReplication(TableName tableName,
List<WAL.Entry> entries)
returns true if the specified entry must be replicated.
|
protected void |
ReplicationSource.ReplicationSourceWorkerThread.shipEdits(boolean currentWALisBeingWrittenTo,
List<WAL.Entry> entries)
Do the shipping logic
|
Constructor and Description |
---|
HBaseInterClusterReplicationEndpoint.Replicator(List<WAL.Entry> entries,
int ordinal) |
RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
HRegionLocation location,
HRegionInfo regionInfo,
byte[] row,
List<WAL.Entry> entries,
AtomicLong skippedEntries) |
Modifier and Type | Field and Description | ||||||||||||||||||||||||||||||||||||||||||||||
---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|---|
(package private) List<WAL.Entry> |
WALSplitter.RegionEntryBuffer.entryBuffer |
||||||||||||||||||||||||||||||||||||||||||||||
private Map<String,List<Pair<HRegionLocation,WAL.Entry>>> |
WALSplitter.LogReplayOutputSink.serverToBufferQueueMap
Map key -> value layout
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved. |