public class RSProcedureDispatcher extends RemoteProcedureDispatcher<MasterProcedureEnv,ServerName> implements ServerListener
Modifier and Type | Class and Description |
---|---|
protected class |
RSProcedureDispatcher.AbstractRSRemoteCall
Base remote call
|
protected class |
RSProcedureDispatcher.CompatRemoteProcedureResolver |
protected class |
RSProcedureDispatcher.ExecuteProceduresRemoteCall |
static class |
RSProcedureDispatcher.RegionCloseOperation |
static class |
RSProcedureDispatcher.RegionOpenOperation |
static class |
RSProcedureDispatcher.RegionOperation |
static class |
RSProcedureDispatcher.ServerOperation |
RemoteProcedureDispatcher.BufferNode, RemoteProcedureDispatcher.RemoteNode<TEnv,TRemote>, RemoteProcedureDispatcher.RemoteOperation, RemoteProcedureDispatcher.RemoteProcedure<TEnv,TRemote>
Modifier and Type | Field and Description |
---|---|
protected MasterServices |
master |
static String |
RS_RPC_STARTUP_WAIT_TIME_CONF_KEY |
protected long |
rsStartupWaitTime |
DISPATCH_DELAY_CONF_KEY, DISPATCH_MAX_QUEUE_SIZE_CONF_KEY, THREAD_POOL_SIZE_CONF_KEY
Constructor and Description |
---|
RSProcedureDispatcher(MasterServices master) |
Modifier and Type | Method and Description |
---|---|
protected void |
abortPendingOperations(ServerName serverName,
Set<RemoteProcedureDispatcher.RemoteProcedure> operations) |
protected void |
remoteDispatch(ServerName serverName,
Set<RemoteProcedureDispatcher.RemoteProcedure> operations) |
void |
serverAdded(ServerName serverName)
The server has joined the cluster.
|
void |
serverRemoved(ServerName serverName)
The server was removed from the cluster.
|
void |
splitAndResolveOperation(ServerName serverName,
Set<RemoteProcedureDispatcher.RemoteProcedure> operations,
org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.RemoteProcedureResolver resolver) |
boolean |
start() |
boolean |
stop() |
addNode, addOperationToNode, buildAndGroupRequestByType, fetchType, getUncaughtExceptionHandler, join, removeNode, submitTask, submitTask
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
waiting
public static final String RS_RPC_STARTUP_WAIT_TIME_CONF_KEY
protected final MasterServices master
protected final long rsStartupWaitTime
public RSProcedureDispatcher(MasterServices master)
public boolean start()
start
in class RemoteProcedureDispatcher<MasterProcedureEnv,ServerName>
public boolean stop()
stop
in class RemoteProcedureDispatcher<MasterProcedureEnv,ServerName>
protected void remoteDispatch(ServerName serverName, Set<RemoteProcedureDispatcher.RemoteProcedure> operations)
remoteDispatch
in class RemoteProcedureDispatcher<MasterProcedureEnv,ServerName>
protected void abortPendingOperations(ServerName serverName, Set<RemoteProcedureDispatcher.RemoteProcedure> operations)
abortPendingOperations
in class RemoteProcedureDispatcher<MasterProcedureEnv,ServerName>
public void serverAdded(ServerName serverName)
ServerListener
serverAdded
in interface ServerListener
serverName
- The remote servers name.public void serverRemoved(ServerName serverName)
ServerListener
serverRemoved
in interface ServerListener
serverName
- The remote servers name.public void splitAndResolveOperation(ServerName serverName, Set<RemoteProcedureDispatcher.RemoteProcedure> operations, org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.RemoteProcedureResolver resolver)
Copyright © 2007–2017 The Apache Software Foundation. All rights reserved.