|
||||||||||
| PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
| SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD | |||||||||
public interface RegionServerObserver
| Nested Class Summary |
|---|
| Nested classes/interfaces inherited from interface org.apache.hadoop.hbase.Coprocessor |
|---|
Coprocessor.State |
| Field Summary |
|---|
| Fields inherited from interface org.apache.hadoop.hbase.Coprocessor |
|---|
PRIORITY_HIGHEST, PRIORITY_LOWEST, PRIORITY_SYSTEM, PRIORITY_USER, VERSION |
| Method Summary | |
|---|---|
ReplicationEndpoint |
postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
ReplicationEndpoint endpoint)
This will be called after the replication endpoint is instantiated. |
void |
postMerge(ObserverContext<RegionServerCoprocessorEnvironment> c,
HRegion regionA,
HRegion regionB,
HRegion mergedRegion)
called after the regions merge. |
void |
postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
HRegion regionA,
HRegion regionB,
HRegion mergedRegion)
This will be called after PONR step as part of regions merge transaction. |
void |
postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry> entries,
CellScanner cells)
This will be called after executing replication request to shipping log entries. |
void |
postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
HRegion regionA,
HRegion regionB)
This will be called after the roll back of the regions merge. |
void |
postRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment> ctx)
This will be called after executing user request to roll a region server WAL. |
void |
preMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
HRegion regionA,
HRegion regionB)
Called before the regions merge. |
void |
preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
HRegion regionA,
HRegion regionB,
List<Mutation> metaEntries)
This will be called before PONR step as part of regions merge transaction. |
void |
preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry> entries,
CellScanner cells)
This will be called before executing replication request to shipping log entries. |
void |
preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
HRegion regionA,
HRegion regionB)
This will be called before the roll back of the regions merge. |
void |
preRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment> ctx)
This will be called before executing user request to roll a region server WAL. |
void |
preStopRegionServer(ObserverContext<RegionServerCoprocessorEnvironment> env)
Called before stopping region server. |
| Methods inherited from interface org.apache.hadoop.hbase.Coprocessor |
|---|
start, stop |
| Method Detail |
|---|
void preStopRegionServer(ObserverContext<RegionServerCoprocessorEnvironment> env)
throws IOException
env - An instance of RegionServerCoprocessorEnvironment
IOException - Signals that an I/O exception has occurred.
void preMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
HRegion regionA,
HRegion regionB)
throws IOException
ObserverContext.bypass() to skip the merge.
ctx - regionA - regionB -
IOException - if an error occurred on the coprocessor
IOException
void postMerge(ObserverContext<RegionServerCoprocessorEnvironment> c,
HRegion regionA,
HRegion regionB,
HRegion mergedRegion)
throws IOException
c - regionA - regionB - mergedRegion -
IOException
void preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
HRegion regionA,
HRegion regionB,
@MetaMutationAnnotation
List<Mutation> metaEntries)
throws IOException
ObserverContext.bypass() rollback the merge
ctx - regionA - regionB - metaEntries - mutations to execute on hbase:meta atomically with regions merge updates.
Any puts or deletes to execute on hbase:meta can be added to the mutations.
IOException
void postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
HRegion regionA,
HRegion regionB,
HRegion mergedRegion)
throws IOException
ctx - regionA - regionB - mergedRegion -
IOException
void preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
HRegion regionA,
HRegion regionB)
throws IOException
ctx - regionA - regionB -
IOException
void postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
HRegion regionA,
HRegion regionB)
throws IOException
ctx - regionA - regionB -
IOException
void preRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment> ctx)
throws IOException
ctx - An instance of ObserverContext
IOException - Signals that an I/O exception has occurred.
void postRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment> ctx)
throws IOException
ctx - An instance of ObserverContext
IOException - Signals that an I/O exception has occurred.
ReplicationEndpoint postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
ReplicationEndpoint endpoint)
ctx - endpoint - - the base endpoint for replication
void preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry> entries,
CellScanner cells)
throws IOException
ctx - An instance of ObserverContextentries - list of WALEntries to replicatecells - Cells that the WALEntries refer to (if cells is non-null)
IOException - Signals that an I/O exception has occurred.
void postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry> entries,
CellScanner cells)
throws IOException
ctx - An instance of ObserverContextentries - list of WALEntries to replicatecells - Cells that the WALEntries refer to (if cells is non-null)
IOException - Signals that an I/O exception has occurred.
|
||||||||||
| PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
| SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD | |||||||||