Package | Description |
---|---|
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.protobuf.generated | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.wal |
Modifier and Type | Method and Description |
---|---|
void |
RegionServerObserver.postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<AdminProtos.WALEntry> entries,
CellScanner cells)
This will be called after executing replication request to shipping log entries.
|
void |
BaseRegionServerObserver.postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<AdminProtos.WALEntry> entries,
CellScanner cells) |
void |
RegionServerObserver.preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<AdminProtos.WALEntry> entries,
CellScanner cells)
This will be called before executing replication request to shipping log entries.
|
void |
BaseRegionServerObserver.preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<AdminProtos.WALEntry> entries,
CellScanner cells) |
Modifier and Type | Field and Description |
---|---|
static com.google.protobuf.Parser<AdminProtos.WALEntry> |
AdminProtos.WALEntry.PARSER |
Modifier and Type | Method and Description |
---|---|
AdminProtos.WALEntry |
AdminProtos.WALEntry.Builder.build() |
AdminProtos.WALEntry |
AdminProtos.WALEntry.Builder.buildPartial() |
static AdminProtos.WALEntry |
AdminProtos.WALEntry.getDefaultInstance() |
AdminProtos.WALEntry |
AdminProtos.WALEntry.getDefaultInstanceForType() |
AdminProtos.WALEntry |
AdminProtos.WALEntry.Builder.getDefaultInstanceForType() |
AdminProtos.WALEntry |
AdminProtos.ReplicateWALEntryRequestOrBuilder.getEntry(int index)
repeated .WALEntry entry = 1; |
AdminProtos.WALEntry |
AdminProtos.ReplicateWALEntryRequest.getEntry(int index)
repeated .WALEntry entry = 1; |
AdminProtos.WALEntry |
AdminProtos.ReplicateWALEntryRequest.Builder.getEntry(int index)
repeated .WALEntry entry = 1; |
static AdminProtos.WALEntry |
AdminProtos.WALEntry.parseDelimitedFrom(InputStream input) |
static AdminProtos.WALEntry |
AdminProtos.WALEntry.parseDelimitedFrom(InputStream input,
com.google.protobuf.ExtensionRegistryLite extensionRegistry) |
static AdminProtos.WALEntry |
AdminProtos.WALEntry.parseFrom(byte[] data) |
static AdminProtos.WALEntry |
AdminProtos.WALEntry.parseFrom(byte[] data,
com.google.protobuf.ExtensionRegistryLite extensionRegistry) |
static AdminProtos.WALEntry |
AdminProtos.WALEntry.parseFrom(com.google.protobuf.ByteString data) |
static AdminProtos.WALEntry |
AdminProtos.WALEntry.parseFrom(com.google.protobuf.ByteString data,
com.google.protobuf.ExtensionRegistryLite extensionRegistry) |
static AdminProtos.WALEntry |
AdminProtos.WALEntry.parseFrom(com.google.protobuf.CodedInputStream input) |
static AdminProtos.WALEntry |
AdminProtos.WALEntry.parseFrom(com.google.protobuf.CodedInputStream input,
com.google.protobuf.ExtensionRegistryLite extensionRegistry) |
static AdminProtos.WALEntry |
AdminProtos.WALEntry.parseFrom(InputStream input) |
static AdminProtos.WALEntry |
AdminProtos.WALEntry.parseFrom(InputStream input,
com.google.protobuf.ExtensionRegistryLite extensionRegistry) |
Modifier and Type | Method and Description |
---|---|
List<AdminProtos.WALEntry> |
AdminProtos.ReplicateWALEntryRequestOrBuilder.getEntryList()
repeated .WALEntry entry = 1; |
List<AdminProtos.WALEntry> |
AdminProtos.ReplicateWALEntryRequest.getEntryList()
repeated .WALEntry entry = 1; |
List<AdminProtos.WALEntry> |
AdminProtos.ReplicateWALEntryRequest.Builder.getEntryList()
repeated .WALEntry entry = 1; |
com.google.protobuf.Parser<AdminProtos.WALEntry> |
AdminProtos.WALEntry.getParserForType() |
Modifier and Type | Method and Description |
---|---|
AdminProtos.ReplicateWALEntryRequest.Builder |
AdminProtos.ReplicateWALEntryRequest.Builder.addEntry(AdminProtos.WALEntry value)
repeated .WALEntry entry = 1; |
AdminProtos.ReplicateWALEntryRequest.Builder |
AdminProtos.ReplicateWALEntryRequest.Builder.addEntry(int index,
AdminProtos.WALEntry value)
repeated .WALEntry entry = 1; |
AdminProtos.WALEntry.Builder |
AdminProtos.WALEntry.Builder.mergeFrom(AdminProtos.WALEntry other) |
static AdminProtos.WALEntry.Builder |
AdminProtos.WALEntry.newBuilder(AdminProtos.WALEntry prototype) |
AdminProtos.ReplicateWALEntryRequest.Builder |
AdminProtos.ReplicateWALEntryRequest.Builder.setEntry(int index,
AdminProtos.WALEntry value)
repeated .WALEntry entry = 1; |
Modifier and Type | Method and Description |
---|---|
AdminProtos.ReplicateWALEntryRequest.Builder |
AdminProtos.ReplicateWALEntryRequest.Builder.addAllEntry(Iterable<? extends AdminProtos.WALEntry> values)
repeated .WALEntry entry = 1; |
Modifier and Type | Method and Description |
---|---|
void |
RegionServerCoprocessorHost.postReplicateLogEntries(List<AdminProtos.WALEntry> entries,
CellScanner cells) |
void |
RegionServerCoprocessorHost.preReplicateLogEntries(List<AdminProtos.WALEntry> entries,
CellScanner cells) |
void |
ReplicationSinkService.replicateLogEntries(List<AdminProtos.WALEntry> entries,
CellScanner cells)
Carry on the list of log entries down to the sink
|
Modifier and Type | Method and Description |
---|---|
void |
ReplicationSink.replicateEntries(List<AdminProtos.WALEntry> entries,
CellScanner cells)
Replicate this array of entries directly into the local cluster using the native client.
|
void |
Replication.replicateLogEntries(List<AdminProtos.WALEntry> entries,
CellScanner cells)
Carry on the list of log entries down to the sink
|
Modifier and Type | Method and Description |
---|---|
void |
AccessController.postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<AdminProtos.WALEntry> entries,
CellScanner cells) |
void |
AccessController.preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<AdminProtos.WALEntry> entries,
CellScanner cells) |
Modifier and Type | Method and Description |
---|---|
static List<WALSplitter.MutationReplay> |
WALSplitter.getMutationsFromWALEntry(AdminProtos.WALEntry entry,
CellScanner cells,
Pair<WALKey,WALEdit> logEntry,
Durability durability)
This function is used to construct mutations from a WALEntry.
|
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.