@InterfaceAudience.LimitedPrivate(value="Coprocesssor") @InterfaceStability.Evolving public class BaseRegionServerObserver extends Object implements RegionServerObserver
Coprocessor.State
PRIORITY_HIGHEST, PRIORITY_LOWEST, PRIORITY_SYSTEM, PRIORITY_USER, VERSION
Constructor and Description |
---|
BaseRegionServerObserver() |
Modifier and Type | Method and Description |
---|---|
ReplicationEndpoint |
postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
ReplicationEndpoint endpoint)
This will be called after the replication endpoint is instantiated.
|
void |
postMerge(ObserverContext<RegionServerCoprocessorEnvironment> c,
Region regionA,
Region regionB,
Region mergedRegion)
called after the regions merge.
|
void |
postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB,
Region mergedRegion)
This will be called after PONR step as part of regions merge transaction.
|
void |
postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<AdminProtos.WALEntry> entries,
CellScanner cells)
This will be called after executing replication request to shipping log entries.
|
void |
postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region 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,
Region regionA,
Region regionB)
Called before the regions merge.
|
void |
preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB,
List<Mutation> metaEntries)
This will be called before PONR step as part of regions merge transaction.
|
void |
preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
List<AdminProtos.WALEntry> entries,
CellScanner cells)
This will be called before executing replication request to shipping log entries.
|
void |
preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region 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.
|
void |
start(CoprocessorEnvironment env) |
void |
stop(CoprocessorEnvironment env) |
public void preStopRegionServer(ObserverContext<RegionServerCoprocessorEnvironment> env) throws IOException
RegionServerObserver
preStopRegionServer
in interface RegionServerObserver
env
- An instance of RegionServerCoprocessorEnvironmentIOException
- Signals that an I/O exception has occurred.public void start(CoprocessorEnvironment env) throws IOException
start
in interface Coprocessor
IOException
public void stop(CoprocessorEnvironment env) throws IOException
stop
in interface Coprocessor
IOException
public void preMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx, Region regionA, Region regionB) throws IOException
RegionServerObserver
ObserverContext.bypass()
to skip the merge.preMerge
in interface RegionServerObserver
IOException
- if an error occurred on the coprocessorpublic void postMerge(ObserverContext<RegionServerCoprocessorEnvironment> c, Region regionA, Region regionB, Region mergedRegion) throws IOException
RegionServerObserver
postMerge
in interface RegionServerObserver
IOException
public void preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx, Region regionA, Region regionB, List<Mutation> metaEntries) throws IOException
RegionServerObserver
ObserverContext.bypass()
rollback the mergepreMergeCommit
in interface RegionServerObserver
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
public void postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx, Region regionA, Region regionB, Region mergedRegion) throws IOException
RegionServerObserver
postMergeCommit
in interface RegionServerObserver
IOException
public void preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx, Region regionA, Region regionB) throws IOException
RegionServerObserver
preRollBackMerge
in interface RegionServerObserver
IOException
public void postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx, Region regionA, Region regionB) throws IOException
RegionServerObserver
postRollBackMerge
in interface RegionServerObserver
IOException
public void preRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment> ctx) throws IOException
RegionServerObserver
preRollWALWriterRequest
in interface RegionServerObserver
ctx
- An instance of ObserverContextIOException
- Signals that an I/O exception has occurred.public void postRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment> ctx) throws IOException
RegionServerObserver
postRollWALWriterRequest
in interface RegionServerObserver
ctx
- An instance of ObserverContextIOException
- Signals that an I/O exception has occurred.public ReplicationEndpoint postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment> ctx, ReplicationEndpoint endpoint)
RegionServerObserver
postCreateReplicationEndPoint
in interface RegionServerObserver
endpoint
- - the base endpoint for replicationpublic void preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx, List<AdminProtos.WALEntry> entries, CellScanner cells) throws IOException
RegionServerObserver
preReplicateLogEntries
in interface RegionServerObserver
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.public void postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx, List<AdminProtos.WALEntry> entries, CellScanner cells) throws IOException
RegionServerObserver
postReplicateLogEntries
in interface RegionServerObserver
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.Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.