Modifier and Type | Method and Description |
---|---|
long |
ClusterSchema.createNamespace(NamespaceDescriptor namespaceDescriptor,
NonceKey nonceKey,
ProcedurePrepareLatch latch)
Create a new Namespace.
|
long |
ClusterSchemaServiceImpl.createNamespace(NamespaceDescriptor namespaceDescriptor,
NonceKey nonceKey,
ProcedurePrepareLatch latch) |
long |
ClusterSchema.deleteNamespace(String name,
NonceKey nonceKey,
ProcedurePrepareLatch latch)
Delete an existing Namespace.
|
long |
ClusterSchemaServiceImpl.deleteNamespace(String name,
NonceKey nonceKey,
ProcedurePrepareLatch latch) |
long |
ClusterSchema.modifyNamespace(NamespaceDescriptor descriptor,
NonceKey nonceKey,
ProcedurePrepareLatch latch)
Modify an existing Namespace.
|
long |
ClusterSchemaServiceImpl.modifyNamespace(NamespaceDescriptor namespaceDescriptor,
NonceKey nonceKey,
ProcedurePrepareLatch latch) |
private long |
ClusterSchemaServiceImpl.submitProcedure(Procedure<MasterProcedureEnv> procedure,
NonceKey nonceKey) |
Modifier and Type | Method and Description |
---|---|
long |
LockManager.RemoteLocks.requestNamespaceLock(String namespace,
LockType type,
String description,
NonceKey nonceKey) |
long |
LockManager.RemoteLocks.requestRegionsLock(RegionInfo[] regionInfos,
String description,
NonceKey nonceKey) |
long |
LockManager.RemoteLocks.requestTableLock(TableName tableName,
LockType type,
String description,
NonceKey nonceKey) |
private void |
LockManager.submitProcedure(LockProcedure proc,
NonceKey nonceKey) |
Modifier and Type | Field and Description |
---|---|
private NonceKey |
MasterProcedureUtil.NonceProcedureRunnable.nonceKey |
Modifier and Type | Method and Description |
---|---|
protected NonceKey |
MasterProcedureUtil.NonceProcedureRunnable.getNonceKey() |
Modifier and Type | Method and Description |
---|---|
(package private) long |
SnapshotManager.cloneSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
TableDescriptor tableDescriptor,
NonceKey nonceKey,
boolean restoreAcl,
String customSFT)
Clone the specified snapshot into a new table.
|
private long |
SnapshotManager.cloneSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription reqSnapshot,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
TableDescriptor snapshotTableDesc,
NonceKey nonceKey,
boolean restoreAcl,
String customSFT)
Clone the specified snapshot.
|
long |
SnapshotManager.restoreOrCloneSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription reqSnapshot,
NonceKey nonceKey,
boolean restoreAcl,
String customSFT)
Restore or Clone the specified snapshot n * @param nonceKey unique identifier to prevent
duplicated RPC n
|
private long |
SnapshotManager.restoreSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
TableDescriptor tableDescriptor,
NonceKey nonceKey,
boolean restoreAcl)
Restore the specified snapshot.
|
private long |
SnapshotManager.restoreSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription reqSnapshot,
TableName tableName,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
TableDescriptor snapshotTableDesc,
NonceKey nonceKey,
boolean restoreAcl)
Restore the specified snapshot.
|
Modifier and Type | Field and Description |
---|---|
private NonceKey |
Procedure.nonceKey |
Modifier and Type | Field and Description |
---|---|
private ConcurrentHashMap<NonceKey,Long> |
ProcedureExecutor.nonceKeysToProcIdsMap
Helper map to lookup whether the procedure already issued from the same client.
|
private Map<NonceKey,Long> |
CompletedProcedureCleaner.nonceKeysToProcIdsMap |
Modifier and Type | Method and Description |
---|---|
NonceKey |
ProcedureExecutor.createNonceKey(long nonceGroup,
long nonce)
Create a NonceKey from the specified nonceGroup and nonce.
|
NonceKey |
Procedure.getNonceKey() |
Modifier and Type | Method and Description |
---|---|
long |
ProcedureExecutor.registerNonce(NonceKey nonceKey)
Register a nonce for a procedure that is going to be submitted.
|
void |
ProcedureExecutor.setFailureResultForNonce(NonceKey nonceKey,
String procName,
User procOwner,
IOException exception)
If the failure failed before submitting it, we may want to give back the same error to the
requests with the same nonceKey.
|
protected void |
Procedure.setNonceKey(NonceKey nonceKey)
Called by the ProcedureExecutor to set the value to the newly created procedure.
|
long |
ProcedureExecutor.submitProcedure(Procedure<TEnvironment> proc,
NonceKey nonceKey)
Add a new root-procedure to the executor.
|
void |
ProcedureExecutor.unregisterNonceIfProcedureWasNotSubmitted(NonceKey nonceKey)
Remove the NonceKey if the procedure was not submitted to the executor.
|
Constructor and Description |
---|
FailedProcedure(long procId,
String procName,
User owner,
NonceKey nonceKey,
IOException exception) |
Constructor and Description |
---|
CompletedProcedureCleaner(org.apache.hadoop.conf.Configuration conf,
ProcedureStore store,
IdLock procExecutionLock,
Map<Long,CompletedProcedureRetainer<TEnvironment>> completedMap,
Map<NonceKey,Long> nonceKeysToProcIdsMap) |
Modifier and Type | Field and Description |
---|---|
private ConcurrentHashMap<NonceKey,ServerNonceManager.OperationContext> |
ServerNonceManager.nonces
Nonces.
|
Modifier and Type | Method and Description |
---|---|
List<Pair<NonceKey,WALEdit>> |
HRegion.BatchOperation.buildWALEdits(MiniBatchOperationInProgress<Mutation> miniBatchOp)
Builds separate WALEdit per nonce by applying input mutations.
|
List<Pair<NonceKey,WALEdit>> |
HRegion.MutationBatchOperation.buildWALEdits(MiniBatchOperationInProgress<Mutation> miniBatchOp) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.