Package | Description |
---|---|
org.apache.hadoop.hbase.master.procedure | |
org.apache.hadoop.hbase.procedure2 | |
org.apache.hadoop.hbase.procedure2.store | |
org.apache.hadoop.hbase.procedure2.store.wal |
Modifier and Type | Class and Description |
---|---|
class |
AddColumnFamilyProcedure
The procedure to add a column family to an existing table.
|
class |
CreateNamespaceProcedure
The procedure to create a new namespace.
|
class |
CreateTableProcedure |
class |
DeleteColumnFamilyProcedure
The procedure to delete a column family from an existing table.
|
class |
DeleteNamespaceProcedure
The procedure to remove a namespace.
|
class |
DeleteTableProcedure |
class |
DisableTableProcedure |
class |
EnableTableProcedure |
class |
ModifyColumnFamilyProcedure
The procedure to modify a column family from an existing table.
|
class |
ModifyNamespaceProcedure
The procedure to add a namespace to an existing table.
|
class |
ModifyTableProcedure |
class |
ServerCrashProcedure
Handle crashed server.
|
class |
TruncateTableProcedure |
Modifier and Type | Method and Description |
---|---|
Procedure |
MasterProcedureScheduler.poll() |
Modifier and Type | Method and Description |
---|---|
void |
MasterProcedureScheduler.addBack(Procedure proc) |
void |
MasterProcedureScheduler.addFront(Procedure proc) |
void |
MasterProcedureScheduler.completionCleanup(Procedure proc) |
protected abstract void |
ProcedurePrepareLatch.countDown(Procedure proc) |
protected void |
ProcedurePrepareLatch.CompatibilityLatch.countDown(Procedure proc) |
protected static void |
ProcedurePrepareLatch.releaseLatch(ProcedurePrepareLatch latch,
Procedure proc) |
void |
MasterProcedureScheduler.releaseNamespaceExclusiveLock(Procedure procedure,
String nsName)
Release the exclusive lock
|
void |
MasterProcedureScheduler.releaseServerExclusiveLock(Procedure procedure,
ServerName serverName)
Release the exclusive lock
|
void |
MasterProcedureScheduler.releaseServerSharedLock(Procedure procedure,
ServerName serverName)
Release the shared lock taken
|
void |
MasterProcedureScheduler.releaseTableExclusiveLock(Procedure procedure,
TableName table)
Release the exclusive lock taken with tryAcquireTableWrite()
|
void |
MasterProcedureScheduler.releaseTableSharedLock(Procedure procedure,
TableName table)
Release the shared lock taken with tryAcquireTableRead()
|
boolean |
MasterProcedureScheduler.ServerQueue.requireExclusiveLock(Procedure proc) |
boolean |
MasterProcedureScheduler.TableQueue.requireExclusiveLock(Procedure proc) |
static byte[] |
ProcedureSyncWait.submitAndWaitProcedure(ProcedureExecutor<MasterProcedureEnv> procExec,
Procedure proc) |
protected long |
MasterProcedureUtil.NonceProcedureRunnable.submitProcedure(Procedure proc) |
boolean |
MasterProcedureScheduler.tryAcquireNamespaceExclusiveLock(Procedure procedure,
String nsName)
Try to acquire the exclusive lock on the specified namespace.
|
boolean |
MasterProcedureScheduler.tryAcquireServerExclusiveLock(Procedure procedure,
ServerName serverName)
Try to acquire the exclusive lock on the specified server.
|
boolean |
MasterProcedureScheduler.tryAcquireServerSharedLock(Procedure procedure,
ServerName serverName)
Try to acquire the shared lock on the specified server.
|
boolean |
MasterProcedureScheduler.tryAcquireTableExclusiveLock(Procedure procedure,
TableName table)
Try to acquire the exclusive lock on the specified table.
|
boolean |
MasterProcedureScheduler.tryAcquireTableSharedLock(Procedure procedure,
TableName table)
Try to acquire the shared lock on the specified table.
|
boolean |
MasterProcedureScheduler.waitEvent(MasterProcedureScheduler.ProcedureEvent event,
Procedure procedure) |
boolean |
MasterProcedureScheduler.waitEvent(MasterProcedureScheduler.ProcedureEvent event,
Procedure procedure,
boolean suspendQueue) |
boolean |
MasterProcedureEnv.waitInitialized(Procedure proc) |
boolean |
MasterProcedureEnv.waitServerCrashProcessingEnabled(Procedure proc) |
void |
MasterProcedureScheduler.yield(Procedure proc) |
Modifier and Type | Class and Description |
---|---|
class |
OnePhaseProcedure<TEnvironment> |
class |
ProcedureInMemoryChore<TEnvironment>
Special procedure used as a chore.
|
class |
SequentialProcedure<TEnvironment>
A SequentialProcedure describes one step in a procedure chain.
|
class |
StateMachineProcedure<TEnvironment,TState>
Procedure described by a series of steps.
|
class |
TwoPhaseProcedure<TEnvironment> |
Modifier and Type | Method and Description |
---|---|
static Procedure |
Procedure.convert(org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure proto)
Helper to convert the protobuf procedure.
|
protected Procedure[] |
Procedure.doExecute(TEnvironment env)
Internal method called by the ProcedureExecutor that starts the
user-level code execute().
|
protected Procedure[] |
SequentialProcedure.doExecute(TEnvironment env) |
protected Procedure[] |
StateMachineProcedure.execute(TEnvironment env) |
protected abstract Procedure[] |
Procedure.execute(TEnvironment env)
The main code of the procedure.
|
protected Procedure[] |
ProcedureInMemoryChore.execute(TEnvironment env) |
Procedure |
ProcedureExecutor.getProcedure(long procId) |
protected static Procedure |
Procedure.newInstance(String className) |
Procedure |
ProcedureRunnableSet.poll()
Fetch one Procedure from the queue
|
Procedure |
ProcedureSimpleRunQueue.poll() |
Modifier and Type | Method and Description |
---|---|
Pair<ProcedureInfo,Procedure> |
ProcedureExecutor.getResultOrProcedure(long procId) |
Modifier and Type | Method and Description |
---|---|
void |
ProcedureRunnableSet.addBack(Procedure proc)
Inserts the specified element at the end of this queue.
|
void |
ProcedureSimpleRunQueue.addBack(Procedure proc) |
protected void |
StateMachineProcedure.addChildProcedure(Procedure... subProcedure)
Add a child procedure to execute
|
void |
ProcedureRunnableSet.addFront(Procedure proc)
Inserts the specified element at the front of this queue.
|
void |
ProcedureSimpleRunQueue.addFront(Procedure proc) |
int |
Procedure.compareTo(Procedure other) |
void |
ProcedureRunnableSet.completionCleanup(Procedure proc)
The procedure in execution completed.
|
void |
ProcedureSimpleRunQueue.completionCleanup(Procedure proc) |
static org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure |
Procedure.convert(Procedure proc)
Helper to convert the procedure to protobuf.
|
static ProcedureInfo |
Procedure.createProcedureInfo(Procedure proc,
NonceKey nonceKey)
Helper to create the ProcedureInfo from Procedure.
|
protected static Long |
Procedure.getRootProcedureId(Map<Long,Procedure> procedures,
Procedure proc) |
long |
ProcedureExecutor.submitProcedure(Procedure proc)
Add a new root-procedure to the executor.
|
long |
ProcedureExecutor.submitProcedure(Procedure proc,
NonceKey nonceKey)
Add a new root-procedure to the executor.
|
protected static void |
Procedure.validateClass(Procedure proc) |
void |
ProcedureRunnableSet.yield(Procedure proc)
The procedure can't run at the moment.
|
void |
ProcedureSimpleRunQueue.yield(Procedure proc) |
Modifier and Type | Method and Description |
---|---|
protected static Long |
Procedure.getRootProcedureId(Map<Long,Procedure> procedures,
Procedure proc) |
Modifier and Type | Method and Description |
---|---|
Procedure |
ProcedureStore.ProcedureIterator.nextAsProcedure()
Returns the next procedure in the iteration.
|
Modifier and Type | Method and Description |
---|---|
void |
NoopProcedureStore.delete(Procedure proc,
long[] subprocs) |
void |
ProcedureStore.delete(Procedure parentProc,
long[] subProcIds)
The parent procedure completed.
|
void |
NoopProcedureStore.insert(Procedure proc,
Procedure[] subprocs) |
void |
NoopProcedureStore.insert(Procedure proc,
Procedure[] subprocs) |
void |
ProcedureStore.insert(Procedure proc,
Procedure[] subprocs)
When a procedure is submitted to the executor insert(proc, null) will be called.
|
void |
ProcedureStore.insert(Procedure proc,
Procedure[] subprocs)
When a procedure is submitted to the executor insert(proc, null) will be called.
|
void |
NoopProcedureStore.update(Procedure proc) |
void |
ProcedureStore.update(Procedure proc)
The specified procedure was executed,
and the new state should be written to the store.
|
Modifier and Type | Method and Description |
---|---|
void |
WALProcedureStore.delete(Procedure proc,
long[] subProcIds) |
void |
WALProcedureStore.insert(Procedure proc,
Procedure[] subprocs) |
void |
WALProcedureStore.insert(Procedure proc,
Procedure[] subprocs) |
void |
WALProcedureStore.update(Procedure proc) |
static void |
ProcedureWALFormat.writeDelete(ByteSlot slot,
Procedure proc,
long[] subprocs) |
static void |
ProcedureWALFormat.writeEntry(ByteSlot slot,
org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Type type,
Procedure proc,
Procedure[] subprocs) |
static void |
ProcedureWALFormat.writeEntry(ByteSlot slot,
org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Type type,
Procedure proc,
Procedure[] subprocs) |
static void |
ProcedureWALFormat.writeInsert(ByteSlot slot,
Procedure proc) |
static void |
ProcedureWALFormat.writeInsert(ByteSlot slot,
Procedure proc,
Procedure[] subprocs) |
static void |
ProcedureWALFormat.writeInsert(ByteSlot slot,
Procedure proc,
Procedure[] subprocs) |
static void |
ProcedureWALFormat.writeUpdate(ByteSlot slot,
Procedure proc) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.