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 |
CreateTableProcedure |
class |
DeleteColumnFamilyProcedure
The procedure to delete a column family from an existing table.
|
class |
DeleteTableProcedure |
class |
DisableTableProcedure |
class |
EnableTableProcedure |
class |
ModifyColumnFamilyProcedure
The procedure to modify a column family from an existing table.
|
class |
ModifyTableProcedure |
class |
TruncateTableProcedure |
Modifier and Type | Method and Description |
---|---|
void |
MasterProcedureQueue.addBack(Procedure proc) |
void |
MasterProcedureQueue.addFront(Procedure proc) |
void |
MasterProcedureQueue.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) |
static byte[] |
ProcedureSyncWait.submitAndWaitProcedure(ProcedureExecutor<MasterProcedureEnv> procExec,
Procedure proc) |
void |
MasterProcedureQueue.yield(Procedure proc) |
Modifier and Type | Class and Description |
---|---|
class |
OnePhaseProcedure<TEnvironment> |
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(ProcedureProtos.Procedure proto)
Helper to convert the protobuf procedure.
|
protected Procedure[] |
SequentialProcedure.doExecute(TEnvironment env) |
protected Procedure[] |
Procedure.doExecute(TEnvironment env)
Internal method called by the ProcedureExecutor that starts the
user-level code execute().
|
protected Procedure[] |
StateMachineProcedure.execute(TEnvironment env) |
protected abstract Procedure[] |
Procedure.execute(TEnvironment env)
The main code of the procedure.
|
Procedure |
ProcedureExecutor.getProcedure(long procId) |
protected static Procedure |
Procedure.newInstance(String className) |
Modifier and Type | Method and Description |
---|---|
Pair<ProcedureInfo,Procedure> |
ProcedureExecutor.getResultOrProcedure(long procId) |
Modifier and Type | Method and Description |
---|---|
void |
ProcedureSimpleRunQueue.addBack(Procedure proc) |
void |
ProcedureRunnableSet.addBack(Procedure proc)
Inserts the specified element at the end of this queue.
|
void |
ProcedureSimpleRunQueue.addFront(Procedure proc) |
void |
ProcedureRunnableSet.addFront(Procedure proc)
Inserts the specified element at the front of this queue.
|
int |
Procedure.compareTo(Procedure other) |
void |
ProcedureSimpleRunQueue.completionCleanup(Procedure proc) |
void |
ProcedureRunnableSet.completionCleanup(Procedure proc)
The procedure in execution completed.
|
static 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,
long nonceGroup,
long nonce)
Add a new root-procedure to the executor.
|
protected static void |
Procedure.validateClass(Procedure proc) |
void |
ProcedureSimpleRunQueue.yield(Procedure proc) |
void |
ProcedureRunnableSet.yield(Procedure proc)
The procedure can't run at the moment.
|
Modifier and Type | Method and Description |
---|---|
protected static Long |
Procedure.getRootProcedureId(Map<Long,Procedure> procedures,
Procedure proc) |
Modifier and Type | Method and Description |
---|---|
Iterator<Procedure> |
ProcedureStore.load()
Load the Procedures in the store.
|
Modifier and Type | Method and Description |
---|---|
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 |
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 |
---|---|
Iterator<Procedure> |
ProcedureWALFormatReader.getProcedures() |
Iterator<Procedure> |
WALProcedureStore.load() |
static Iterator<Procedure> |
ProcedureWALFormat.load(Iterator<ProcedureWALFile> logs,
ProcedureStoreTracker tracker,
org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat.Loader loader) |
Modifier and Type | Method and Description |
---|---|
void |
WALProcedureStore.insert(Procedure proc,
Procedure[] subprocs) |
void |
WALProcedureStore.insert(Procedure proc,
Procedure[] subprocs) |
void |
WALProcedureStore.update(Procedure proc) |
static void |
ProcedureWALFormat.writeEntry(ByteSlot slot,
ProcedureProtos.ProcedureWALEntry.Type type,
Procedure proc,
Procedure[] subprocs) |
static void |
ProcedureWALFormat.writeEntry(ByteSlot slot,
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-2016 The Apache Software Foundation. All Rights Reserved.