Uses of Class
org.apache.hadoop.hbase.util.NonceKey
Package
Description
-
Uses of NonceKey in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionlong
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) -
Uses of NonceKey in org.apache.hadoop.hbase.master.locking
Modifier and TypeMethodDescriptionlong
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) -
Uses of NonceKey in org.apache.hadoop.hbase.master.procedure
Modifier and TypeFieldDescriptionprivate final NonceKey
MasterProcedureUtil.NonceProcedureRunnable.nonceKey
Modifier and TypeMethodDescriptionprotected NonceKey
MasterProcedureUtil.NonceProcedureRunnable.getNonceKey()
-
Uses of NonceKey in org.apache.hadoop.hbase.master.snapshot
Modifier and TypeMethodDescription(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 snapshotprivate 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. -
Uses of NonceKey in org.apache.hadoop.hbase.procedure2
Modifier and TypeFieldDescriptionCompletedProcedureCleaner.nonceKeysToProcIdsMap
private final ConcurrentHashMap<NonceKey,
Long> ProcedureExecutor.nonceKeysToProcIdsMap
Helper map to lookup whether the procedure already issued from the same client.Modifier and TypeMethodDescriptionProcedureExecutor.createNonceKey
(long nonceGroup, long nonce) Create a NonceKey from the specified nonceGroup and nonce.Procedure.getNonceKey()
Modifier and TypeMethodDescriptionlong
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.ModifierConstructorDescriptionFailedProcedure
(long procId, String procName, User owner, NonceKey nonceKey, IOException exception) -
Uses of NonceKey in org.apache.hadoop.hbase.regionserver
Modifier and TypeMethodDescriptionHRegion.BatchOperation.buildWALEdits
(MiniBatchOperationInProgress<Mutation> miniBatchOp) Builds separate WALEdit per nonce by applying input mutations.HRegion.MutationBatchOperation.buildWALEdits
(MiniBatchOperationInProgress<Mutation> miniBatchOp) Modifier and TypeMethodDescriptionHRegion.doWALAppend
(WALEdit walEdit, HRegion.BatchOperation<?> batchOp, MiniBatchOperationInProgress<Mutation> miniBatchOp, long now, NonceKey nonceKey) Returns writeEntry associated with this appendModifier and TypeMethodDescriptionprotected abstract void
HRegion.BatchOperation.cacheSkipWALMutationForRegionReplication
(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> walEdits, Map<byte[], List<ExtendedCell>> familyCellMap) protected void
HRegion.MutationBatchOperation.cacheSkipWALMutationForRegionReplication
(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> nonceKeyAndWALEdits, Map<byte[], List<ExtendedCell>> familyCellMap) Here is for HBASE-26993,in order to make the new framework for region replication could work for SKIP_WAL, we save theMutation
whichMutation.getDurability()
isDurability.SKIP_WAL
in miniBatchOp.protected void
HRegion.ReplayBatchOperation.cacheSkipWALMutationForRegionReplication
(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> walEdits, Map<byte[], List<ExtendedCell>> familyCellMap) Deprecated.private WALEdit
HRegion.MutationBatchOperation.createWALEditForReplicateSkipWAL
(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> nonceKeyAndWALEdits)