@InterfaceAudience.Private public class RegionMergeTransaction extends Object
prepare(RegionServerServices)
to setup the
transaction, execute(Server, RegionServerServices)
to run the
transaction and rollback(Server, RegionServerServices)
to cleanup if
execute fails.
Here is an example of how you would use this class:
RegionMergeTransaction mt = new RegionMergeTransaction(this.conf, parent, midKey) if (!mt.prepare(services)) return; try { mt.execute(server, services); } catch (IOException ioe) { try { mt.rollback(server, services); return; } catch (RuntimeException e) { myAbortable.abort("Failed merge, abort"); } }
This class is not thread safe. Caller needs ensure merge is run by one thread only.
Constructor and Description |
---|
RegionMergeTransaction(HRegion a,
HRegion b,
boolean forcible)
Constructor
|
Modifier and Type | Method and Description |
---|---|
Put |
addLocation(Put p,
ServerName sn,
long openSeqNum) |
static void |
createNodeMerging(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
HRegionInfo a,
HRegionInfo b)
Creates a new ephemeral node in the PENDING_MERGE state for the merged region.
|
HRegion |
execute(Server server,
RegionServerServices services)
Run the transaction.
|
static HRegionInfo |
getMergedRegionInfo(HRegionInfo a,
HRegionInfo b)
Get merged region info through the specified two regions
|
boolean |
prepare(RegionServerServices services)
Does checks on merge inputs.
|
void |
prepareMutationsForMerge(HRegionInfo mergedRegion,
HRegionInfo regionA,
HRegionInfo regionB,
ServerName serverName,
List<Mutation> mutations) |
boolean |
rollback(Server server,
RegionServerServices services) |
HRegion |
stepsAfterPONR(Server server,
RegionServerServices services,
HRegion mergedRegion) |
HRegion |
stepsBeforePONR(Server server,
RegionServerServices services,
boolean testing) |
static int |
transitionMergingNode(ZooKeeperWatcher zkw,
HRegionInfo merged,
HRegionInfo a,
HRegionInfo b,
ServerName serverName,
int znodeVersion,
EventType beginState,
EventType endState)
Transitions an existing ephemeral node for the specified region which is
currently in the begin state to be in the end state.
|
public boolean prepare(RegionServerServices services)
services
- true
if the regions are mergeable else
false
if they are not (e.g. its already closed, etc.).public HRegion execute(Server server, RegionServerServices services) throws IOException
server
- Hosting server instance. Can be null when testing (won't try
and update in zk if a null server)services
- Used to online/offline regions.IOException
- If thrown, transaction failed. Call
rollback(Server, RegionServerServices)
IOException
rollback(Server, RegionServerServices)
public HRegion stepsAfterPONR(Server server, RegionServerServices services, HRegion mergedRegion) throws IOException
IOException
public void prepareMutationsForMerge(HRegionInfo mergedRegion, HRegionInfo regionA, HRegionInfo regionB, ServerName serverName, List<Mutation> mutations) throws IOException
IOException
public Put addLocation(Put p, ServerName sn, long openSeqNum)
public HRegion stepsBeforePONR(Server server, RegionServerServices services, boolean testing) throws IOException
IOException
public static HRegionInfo getMergedRegionInfo(HRegionInfo a, HRegionInfo b)
a
- merging region Ab
- merging region Bpublic boolean rollback(Server server, RegionServerServices services) throws IOException
server
- Hosting server instance (May be null when testing).services
- Services of regionserver, used to online regions.IOException
- If thrown, rollback failed. Take drastic action.public static void createNodeMerging(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName, HRegionInfo a, HRegionInfo b) throws org.apache.zookeeper.KeeperException, IOException
Does not transition nodes from other states. If a node already exists for
this region, a KeeperException.NodeExistsException
will be thrown.
zkw
- zk referenceregion
- region to be created as offlineserverName
- server event originates fromorg.apache.zookeeper.KeeperException
IOException
public static int transitionMergingNode(ZooKeeperWatcher zkw, HRegionInfo merged, HRegionInfo a, HRegionInfo b, ServerName serverName, int znodeVersion, EventType beginState, EventType endState) throws org.apache.zookeeper.KeeperException, IOException
Does not transition nodes from other states. If for some reason the node could not be transitioned, the method returns -1. If the transition is successful, the version of the node after transition is returned.
This method can fail and return false for three different reasons:
Does not set any watches.
This method should only be used by a RegionServer when merging two regions.
zkw
- zk referencemerged
- region to be transitioned to openeda
- merging region Ab
- merging region BserverName
- server event originates fromznodeVersion
- expected version of data before modificationbeginState
- the expected current state the znode should beendState
- the state to be transition toorg.apache.zookeeper.KeeperException
- if unexpected zookeeper exceptionIOException
Copyright © 2014 The Apache Software Foundation. All rights reserved.