You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by ni...@apache.org on 2023/12/18 10:54:59 UTC

(ignite) branch master updated: IGNITE-14823 Current abbrevation (#11104)

This is an automated email from the ASF dual-hosted git repository.

nizhikov pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/ignite.git


The following commit(s) were added to refs/heads/master by this push:
     new d2d9c3d7fed IGNITE-14823 Current abbrevation (#11104)
d2d9c3d7fed is described below

commit d2d9c3d7feda4c046c10f8228067c7e545e49dd9
Author: Nikolay <ni...@apache.org>
AuthorDate: Mon Dec 18 13:54:54 2023 +0300

    IGNITE-14823 Current abbrevation (#11104)
---
 .../query/calcite/exec/exp/RexToLixTranslator.java | 12 +++++-----
 .../checkstyle/src/main/resources/abbrevations.csv |  2 +-
 .../java/org/apache/ignite/cache/QueryEntity.java  |  8 +++----
 .../management/cache/ValidateIndexesClosure.java   | 16 ++++++-------
 .../affinity/GridAffinityAssignmentCache.java      | 10 ++++-----
 .../bulkload/pipeline/CsvLineProcessorBlock.java   | 26 +++++++++++-----------
 .../internal/processors/cache/CachesRegistry.java  |  6 ++---
 .../processors/cache/GridCacheMapEntry.java        |  8 +++----
 .../cache/GridCachePartitionExchangeManager.java   |  4 ++--
 .../processors/cache/IgniteCacheProxyImpl.java     | 14 ++++++------
 .../preloader/GridDhtPartitionsFullMessage.java    |  4 ++--
 .../topology/GridDhtPartitionsStateValidator.java  |  8 +++----
 .../pagelocktracker/SharedPageLockTracker.java     |  6 ++---
 ...edBasedMemoryConsumptionThrottlingStrategy.java | 18 +++++++--------
 .../datastructures/GridCacheLockImpl.java          | 16 ++++++-------
 .../internal/processors/query/stat/hll/HLL.java    |  4 ++--
 .../cluster/GridChangeStateCommandHandler.java     |  4 ++--
 .../CacheLateAffinityAssignmentTest.java           |  4 ++--
 .../pagemem/PagesWriteThrottleSandboxTest.java     |  4 ++--
 .../spi/discovery/ClusterMetricsSelfTest.java      | 16 ++++++-------
 .../development/utils/IgniteWalConverter.java      | 10 ++++-----
 21 files changed, 100 insertions(+), 100 deletions(-)

diff --git a/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/exec/exp/RexToLixTranslator.java b/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/exec/exp/RexToLixTranslator.java
index 8cba1b67875..3be0a7cf6b6 100644
--- a/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/exec/exp/RexToLixTranslator.java
+++ b/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/exec/exp/RexToLixTranslator.java
@@ -1110,13 +1110,13 @@ public class RexToLixTranslator implements RexVisitor<RexToLixTranslator.Result>
      */
     private void implementRecursively(final RexToLixTranslator currentTranslator,
         final List<RexNode> operandList, final ParameterExpression valueVariable, int pos) {
-        final BlockBuilder currentBlockBuilder = currentTranslator.getBlockBuilder();
+        final BlockBuilder curBlockBuilder = currentTranslator.getBlockBuilder();
         final List<Type> storageTypes = ConverterUtils.internalTypes(operandList);
         // [ELSE] clause
         if (pos == operandList.size() - 1) {
             Expression res = implementCallOperand2(operandList.get(pos),
                 storageTypes.get(pos), currentTranslator);
-            currentBlockBuilder.add(
+            curBlockBuilder.add(
                 Expressions.statement(
                     Expressions.assign(valueVariable,
                         ConverterUtils.convert(res, valueVariable.getType()))));
@@ -1132,7 +1132,7 @@ public class RexToLixTranslator implements RexVisitor<RexToLixTranslator.Result>
         // Code for {if} branch
         final RexNode ifTrueNode = operandList.get(pos + 1);
         final BlockBuilder ifTrueBlockBuilder =
-            new BlockBuilder(true, currentBlockBuilder);
+            new BlockBuilder(true, curBlockBuilder);
         final RexToLixTranslator ifTrueTranslator =
             currentTranslator.setBlock(ifTrueBlockBuilder);
         final Expression ifTrueRes = implementCallOperand2(ifTrueNode,
@@ -1145,18 +1145,18 @@ public class RexToLixTranslator implements RexVisitor<RexToLixTranslator.Result>
         final BlockStatement ifTrue = ifTrueBlockBuilder.toBlock();
         // There is no [ELSE] clause
         if (pos + 1 == operandList.size() - 1) {
-            currentBlockBuilder.add(
+            curBlockBuilder.add(
                 Expressions.ifThen(tester, ifTrue));
             return;
         }
         // Generate code for {else} branch recursively
         final BlockBuilder ifFalseBlockBuilder =
-            new BlockBuilder(true, currentBlockBuilder);
+            new BlockBuilder(true, curBlockBuilder);
         final RexToLixTranslator ifFalseTranslator =
             currentTranslator.setBlock(ifFalseBlockBuilder);
         implementRecursively(ifFalseTranslator, operandList, valueVariable, pos + 2);
         final BlockStatement ifFalse = ifFalseBlockBuilder.toBlock();
-        currentBlockBuilder.add(
+        curBlockBuilder.add(
             Expressions.ifThenElse(tester, ifTrue, ifFalse));
     }
 
diff --git a/modules/checkstyle/src/main/resources/abbrevations.csv b/modules/checkstyle/src/main/resources/abbrevations.csv
index ca723341f01..553798283e6 100644
--- a/modules/checkstyle/src/main/resources/abbrevations.csv
+++ b/modules/checkstyle/src/main/resources/abbrevations.csv
@@ -15,7 +15,7 @@ config,cfg
 context,ctx
 contexts,ctxs
 count,cnt
-#current,cur
+current,cur
 #database,db
 #default,dflt
 #destination,dest
diff --git a/modules/core/src/main/java/org/apache/ignite/cache/QueryEntity.java b/modules/core/src/main/java/org/apache/ignite/cache/QueryEntity.java
index 93ba83f53ca..c911c2983d5 100644
--- a/modules/core/src/main/java/org/apache/ignite/cache/QueryEntity.java
+++ b/modules/core/src/main/java/org/apache/ignite/cache/QueryEntity.java
@@ -227,19 +227,19 @@ public class QueryEntity implements Serializable {
     @NotNull private Collection<QueryIndex> checkIndexes(QueryEntity target, StringBuilder conflicts) {
         HashSet<QueryIndex> indexesToAdd = new HashSet<>();
 
-        Map<String, QueryIndex> currentIndexes = new HashMap<>();
+        Map<String, QueryIndex> curIndexes = new HashMap<>();
 
         for (QueryIndex index : getIndexes()) {
-            if (currentIndexes.put(index.getName(), index) != null)
+            if (curIndexes.put(index.getName(), index) != null)
                 throw new IllegalStateException("Duplicate key");
         }
 
         for (QueryIndex queryIndex : target.getIndexes()) {
-            if (currentIndexes.containsKey(queryIndex.getName())) {
+            if (curIndexes.containsKey(queryIndex.getName())) {
                 checkEquals(
                     conflicts,
                     "index " + queryIndex.getName(),
-                    currentIndexes.get(queryIndex.getName()),
+                    curIndexes.get(queryIndex.getName()),
                     queryIndex
                 );
             }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/management/cache/ValidateIndexesClosure.java b/modules/core/src/main/java/org/apache/ignite/internal/management/cache/ValidateIndexesClosure.java
index 1e26da8e4ce..3dfab6cceeb 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/management/cache/ValidateIndexesClosure.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/management/cache/ValidateIndexesClosure.java
@@ -583,7 +583,7 @@ public class ValidateIndexesClosure implements IgniteCallable<ValidateIndexesJob
         final boolean skipConditions = checkFirst > 0 || checkThrough > 0;
         final boolean bothSkipConditions = checkFirst > 0 && checkThrough > 0;
 
-        long current = 0;
+        long cur = 0;
         long processedNumber = 0;
 
         while (it.hasNextX() && !validateCtx.isCancelled()) {
@@ -596,18 +596,18 @@ public class ValidateIndexesClosure implements IgniteCallable<ValidateIndexesJob
                 if (bothSkipConditions) {
                     if (processedNumber > checkFirst)
                         break;
-                    else if (current++ % checkThrough > 0)
+                    else if (cur++ % checkThrough > 0)
                         continue;
                     else
                         processedNumber++;
                 }
                 else {
                     if (checkFirst > 0) {
-                        if (current++ > checkFirst)
+                        if (cur++ > checkFirst)
                             break;
                     }
                     else {
-                        if (current++ % checkThrough > 0)
+                        if (cur++ % checkThrough > 0)
                             continue;
                     }
                 }
@@ -768,7 +768,7 @@ public class ValidateIndexesClosure implements IgniteCallable<ValidateIndexesJob
         final boolean skipConditions = checkFirst > 0 || checkThrough > 0;
         final boolean bothSkipConditions = checkFirst > 0 && checkThrough > 0;
 
-        long current = 0;
+        long cur = 0;
         long processedNumber = 0;
 
         KeyCacheObject previousKey = null;
@@ -798,18 +798,18 @@ public class ValidateIndexesClosure implements IgniteCallable<ValidateIndexesJob
                     if (bothSkipConditions) {
                         if (processedNumber > checkFirst)
                             break;
-                        else if (current++ % checkThrough > 0)
+                        else if (cur++ % checkThrough > 0)
                             continue;
                         else
                             processedNumber++;
                     }
                     else {
                         if (checkFirst > 0) {
-                            if (current++ > checkFirst)
+                            if (cur++ > checkFirst)
                                 break;
                         }
                         else {
-                            if (current++ % checkThrough > 0)
+                            if (cur++ % checkThrough > 0)
                                 continue;
                         }
                     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/affinity/GridAffinityAssignmentCache.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/affinity/GridAffinityAssignmentCache.java
index 0806b7f4a75..07f87c98b01 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/affinity/GridAffinityAssignmentCache.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/affinity/GridAffinityAssignmentCache.java
@@ -494,20 +494,20 @@ public class GridAffinityAssignmentCache {
 
         for (int p = 0; p < assignment.size(); p++) {
             List<ClusterNode> baselineMapping = assignment.get(p);
-            List<ClusterNode> currentMapping = null;
+            List<ClusterNode> curMapping = null;
 
             for (ClusterNode node : baselineMapping) {
                 ClusterNode aliveNode = alives.get(node.consistentId());
 
                 if (aliveNode != null) {
-                    if (currentMapping == null)
-                        currentMapping = new ArrayList<>();
+                    if (curMapping == null)
+                        curMapping = new ArrayList<>();
 
-                    currentMapping.add(aliveNode);
+                    curMapping.add(aliveNode);
                 }
             }
 
-            result.add(p, currentMapping != null ? currentMapping : Collections.<ClusterNode>emptyList());
+            result.add(p, curMapping != null ? curMapping : Collections.<ClusterNode>emptyList());
         }
 
         return result;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/bulkload/pipeline/CsvLineProcessorBlock.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/bulkload/pipeline/CsvLineProcessorBlock.java
index 8801e053c58..1d3123c869b 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/bulkload/pipeline/CsvLineProcessorBlock.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/bulkload/pipeline/CsvLineProcessorBlock.java
@@ -66,13 +66,13 @@ public class CsvLineProcessorBlock extends PipelineBlock<String, String[]> {
     @Override public void accept(String input, boolean isLastPortion) throws IgniteCheckedException {
         List<String> fields = new ArrayList<>();
 
-        StringBuilder currentField = new StringBuilder(256);
+        StringBuilder curField = new StringBuilder(256);
 
         ReaderState state = ReaderState.IDLE;
 
         final int length = input.length();
         int copy = 0;
-        int current = 0;
+        int cur = 0;
         int prev = -1;
         int copyStart = 0;
 
@@ -82,20 +82,20 @@ public class CsvLineProcessorBlock extends PipelineBlock<String, String[]> {
         symbol = 0;
 
         while (true) {
-            if (current == length) {
+            if (cur == length) {
                 if (!quotesMatched)
                     throw new IgniteCheckedException(new SQLException("Unmatched quote found at the end of line "
                         + line + ", symbol " + symbol));
 
                 if (copy > 0)
-                    currentField.append(input, copyStart, copyStart + copy);
+                    curField.append(input, copyStart, copyStart + copy);
 
-                addField(fields, currentField, prev == quoteChars);
+                addField(fields, curField, prev == quoteChars);
 
                 break;
             }
 
-            final char c = input.charAt(current++);
+            final char c = input.charAt(cur++);
             symbol++;
 
             if (state == ReaderState.QUOTED) {
@@ -104,12 +104,12 @@ public class CsvLineProcessorBlock extends PipelineBlock<String, String[]> {
                     quotesMatched = !quotesMatched;
 
                     if (copy > 0) {
-                        currentField.append(input, copyStart, copyStart + copy);
+                        curField.append(input, copyStart, copyStart + copy);
 
                         copy = 0;
                     }
 
-                    copyStart = current;
+                    copyStart = cur;
                 }
                 else
                     copy++;
@@ -117,15 +117,15 @@ public class CsvLineProcessorBlock extends PipelineBlock<String, String[]> {
             else {
                 if (c == fldDelim) {
                     if (copy > 0) {
-                        currentField.append(input, copyStart, copyStart + copy);
+                        curField.append(input, copyStart, copyStart + copy);
 
                         copy = 0;
                     }
 
-                    addField(fields, currentField, prev == quoteChars);
+                    addField(fields, curField, prev == quoteChars);
 
-                    currentField = new StringBuilder();
-                    copyStart = current;
+                    curField = new StringBuilder();
+                    copyStart = cur;
 
                     state = ReaderState.IDLE;
                 }
@@ -137,7 +137,7 @@ public class CsvLineProcessorBlock extends PipelineBlock<String, String[]> {
                     if (prev == quoteChars)
                         copy++;
                     else
-                        copyStart = current;
+                        copyStart = cur;
                 }
                 else {
                     if (c == quoteChars) {
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CachesRegistry.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CachesRegistry.java
index 65868e2a94c..8bf070eda91 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CachesRegistry.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CachesRegistry.java
@@ -213,11 +213,11 @@ public class CachesRegistry {
      * Awaits last registered caches configurations persist future.
      */
     private void waitLastRegistration() {
-        IgniteInternalFuture<?> currentFut = cachesConfPersistFuture;
+        IgniteInternalFuture<?> curFut = cachesConfPersistFuture;
 
-        if (currentFut != null && !currentFut.isDone()) {
+        if (curFut != null && !curFut.isDone()) {
             try {
-                currentFut.get();
+                curFut.get();
             }
             catch (IgniteCheckedException e) {
                 throw new IgniteException("Failed to wait for last registered caches registration future", e);
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheMapEntry.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheMapEntry.java
index ede08985d78..53fa60f079c 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheMapEntry.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheMapEntry.java
@@ -2933,16 +2933,16 @@ public abstract class GridCacheMapEntry extends GridMetadataAwareAdapter impleme
                 @Override public boolean apply(@Nullable CacheDataRow row) {
                     boolean update0;
 
-                    GridCacheVersion currentVer = row != null ? row.version() : GridCacheMapEntry.this.ver;
+                    GridCacheVersion curVer = row != null ? row.version() : GridCacheMapEntry.this.ver;
 
-                    boolean isStartVer = cctx.shared().versions().isStartVersion(currentVer);
+                    boolean isStartVer = cctx.shared().versions().isStartVersion(curVer);
 
                     if (cctx.group().persistenceEnabled()) {
                         if (!isStartVer) {
                             if (cctx.atomic())
-                                update0 = ATOMIC_VER_COMPARATOR.compare(currentVer, ver) < 0;
+                                update0 = ATOMIC_VER_COMPARATOR.compare(curVer, ver) < 0;
                             else
-                                update0 = currentVer.compareTo(ver) < 0;
+                                update0 = curVer.compareTo(ver) < 0;
                         }
                         else
                             update0 = true;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePartitionExchangeManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePartitionExchangeManager.java
index 6ef94e2a613..e32b21cad7a 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePartitionExchangeManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePartitionExchangeManager.java
@@ -454,9 +454,9 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
             new MessageHandler<GridDhtPartitionsFullMessage>() {
                 @Override public void onMessage(ClusterNode node, GridDhtPartitionsFullMessage msg) {
                     if (msg.exchangeId() == null) {
-                        GridDhtPartitionsExchangeFuture currentExchange = lastTopologyFuture();
+                        GridDhtPartitionsExchangeFuture curExchange = lastTopologyFuture();
 
-                        if (currentExchange != null && currentExchange.addOrMergeDelayedFullMessage(node, msg)) {
+                        if (curExchange != null && curExchange.addOrMergeDelayedFullMessage(node, msg)) {
                             if (log.isInfoEnabled()) {
                                 log.info("Delay process full message without exchange id (there is exchange in progress) " +
                                     "[nodeId=" + node.id() + "]");
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheProxyImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheProxyImpl.java
index 02cc31cc2b5..d638ec1856e 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheProxyImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheProxyImpl.java
@@ -2237,12 +2237,12 @@ public class IgniteCacheProxyImpl<K, V> extends AsyncSupportAdapter<IgniteCache<
      * Throws {@code IgniteCacheRestartingException} if proxy is restarting.
      */
     public void checkRestart(boolean noWait) {
-        RestartFuture currentFut = restartFut.get();
+        RestartFuture curFut = restartFut.get();
 
-        if (currentFut != null) {
+        if (curFut != null) {
             try {
                 if (!noWait) {
-                    currentFut.get(1, TimeUnit.SECONDS);
+                    curFut.get(1, TimeUnit.SECONDS);
 
                     return;
                 }
@@ -2251,7 +2251,7 @@ public class IgniteCacheProxyImpl<K, V> extends AsyncSupportAdapter<IgniteCache<
                 //do nothing
             }
 
-            throw new IgniteCacheRestartingException(new IgniteFutureImpl<>(currentFut, exec()), cacheName);
+            throw new IgniteCacheRestartingException(new IgniteFutureImpl<>(curFut, exec()), cacheName);
         }
     }
 
@@ -2296,10 +2296,10 @@ public class IgniteCacheProxyImpl<K, V> extends AsyncSupportAdapter<IgniteCache<
      * @param fut Finish restart future.
      */
     public void registrateFutureRestart(GridFutureAdapter<?> fut) {
-        RestartFuture currentFut = restartFut.get();
+        RestartFuture curFut = restartFut.get();
 
-        if (currentFut != null)
-            currentFut.addRestartFinishedFuture(fut);
+        if (curFut != null)
+            curFut.addRestartFinishedFuture(fut);
     }
 
     /**
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsFullMessage.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsFullMessage.java
index aef7adc7f69..19be85dd733 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsFullMessage.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsFullMessage.java
@@ -938,13 +938,13 @@ public class GridDhtPartitionsFullMessage extends GridDhtPartitionsAbstractMessa
             if (currMap == null)
                 partitions().put(grpId, updMap);
             else {
-                ClusterNode currentMapSentBy = discovery.node(currMap.nodeId());
+                ClusterNode curMapSentBy = discovery.node(currMap.nodeId());
                 ClusterNode newMapSentBy = discovery.node(updMap.nodeId());
 
                 if (newMapSentBy == null)
                     continue;
 
-                if (currentMapSentBy == null || newMapSentBy.order() > currentMapSentBy.order() || updMap.compareTo(currMap) >= 0)
+                if (curMapSentBy == null || newMapSentBy.order() > curMapSentBy.order() || updMap.compareTo(currMap) >= 0)
                     partitions().put(grpId, updMap);
             }
         }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionsStateValidator.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionsStateValidator.java
index 8dafc6d67d5..41e3b0e3a47 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionsStateValidator.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionsStateValidator.java
@@ -217,9 +217,9 @@ public class GridDhtPartitionsStateValidator {
                 if (ignorePartitions != null && ignorePartitions.contains(p))
                     continue;
 
-                long currentCounter = countersMap.updateCounterAt(i);
+                long curCounter = countersMap.updateCounterAt(i);
 
-                process(invalidPartitions, updateCountersAndNodesByPartitions, p, nodeId, currentCounter);
+                process(invalidPartitions, updateCountersAndNodesByPartitions, p, nodeId, curCounter);
             }
         }
 
@@ -278,9 +278,9 @@ public class GridDhtPartitionsStateValidator {
                 if (ignorePartitions != null && ignorePartitions.contains(p))
                     continue;
 
-                long currentSize = sizesMap.getOrDefault(p, 0L);
+                long curSize = sizesMap.getOrDefault(p, 0L);
 
-                process(invalidPartitions, sizesAndNodesByPartitions, p, nodeId, currentSize);
+                process(invalidPartitions, sizesAndNodesByPartitions, p, nodeId, curSize);
             }
         }
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/diagnostic/pagelocktracker/SharedPageLockTracker.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/diagnostic/pagelocktracker/SharedPageLockTracker.java
index 1a863aa6596..1158bf6ef62 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/diagnostic/pagelocktracker/SharedPageLockTracker.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/diagnostic/pagelocktracker/SharedPageLockTracker.java
@@ -276,10 +276,10 @@ public class SharedPageLockTracker {
     private synchronized Set<PageLockThreadState> hangThreads() {
         Set<PageLockThreadState> hangsThreads = new HashSet<>();
 
-        Map<Long, PageLockThreadState> currentThreadsOperationState = getThreadOperationState();
+        Map<Long, PageLockThreadState> curThreadsOperationState = getThreadOperationState();
 
         prevThreadsState.forEach((threadId, prevState) -> {
-            PageLockThreadState state = currentThreadsOperationState.get(threadId);
+            PageLockThreadState state = curThreadsOperationState.get(threadId);
 
             if (state == null)
                 return;
@@ -291,7 +291,7 @@ public class SharedPageLockTracker {
                 hangsThreads.add(state);
         });
 
-        prevThreadsState = currentThreadsOperationState;
+        prevThreadsState = curThreadsOperationState;
 
         return hangsThreads;
     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/SpeedBasedMemoryConsumptionThrottlingStrategy.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/SpeedBasedMemoryConsumptionThrottlingStrategy.java
index 9fe7a90eb90..92d796a4ff3 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/SpeedBasedMemoryConsumptionThrottlingStrategy.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/SpeedBasedMemoryConsumptionThrottlingStrategy.java
@@ -253,12 +253,12 @@ class SpeedBasedMemoryConsumptionThrottlingStrategy {
 
         final long targetSpeedToMarkAll = calcSpeedToMarkAllSpaceTillEndOfCp(dirtyPagesRatio, donePages,
             avgCpWriteSpeed, cpTotalPages);
-        final double targetCurrentDirtyRatio = targetCurrentDirtyRatio(donePages, cpTotalPages);
+        final double targetCurDirtyRatio = targetCurrentDirtyRatio(donePages, cpTotalPages);
 
-        publishSpeedAndRatioForMetrics(targetSpeedToMarkAll, targetCurrentDirtyRatio);
+        publishSpeedAndRatioForMetrics(targetSpeedToMarkAll, targetCurDirtyRatio);
 
         return delayIfMarkingFasterThanTargetSpeedAllows(instantaneousMarkDirtySpeed,
-            dirtyPagesRatio, nThreads, targetSpeedToMarkAll, targetCurrentDirtyRatio);
+            dirtyPagesRatio, nThreads, targetSpeedToMarkAll, targetCurDirtyRatio);
     }
 
     /***/
@@ -339,16 +339,16 @@ class SpeedBasedMemoryConsumptionThrottlingStrategy {
 
     /** Returns total number of pages storable in page memory. */
     private long pageMemTotalPages() {
-        long currentTotalPages = pageMemTotalPages;
+        long curTotalPages = pageMemTotalPages;
 
-        if (currentTotalPages == 0) {
-            currentTotalPages = pageMemory.totalPages();
-            pageMemTotalPages = currentTotalPages;
+        if (curTotalPages == 0) {
+            curTotalPages = pageMemory.totalPages();
+            pageMemTotalPages = curTotalPages;
         }
 
-        assert currentTotalPages > 0 : "PageMemory.totalPages() is still 0";
+        assert curTotalPages > 0 : "PageMemory.totalPages() is still 0";
 
-        return currentTotalPages;
+        return curTotalPages;
     }
 
     /**
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheLockImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheLockImpl.java
index 22999476c38..c4ebc446567 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheLockImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheLockImpl.java
@@ -371,7 +371,7 @@ public final class GridCacheLockImpl extends AtomicDataStructureProxy<GridCacheL
             if (interruptAll)
                 return true;
 
-            final Thread current = Thread.currentThread();
+            final Thread cur = Thread.currentThread();
 
             boolean failed = false;
 
@@ -379,10 +379,10 @@ public final class GridCacheLockImpl extends AtomicDataStructureProxy<GridCacheL
 
             // Wait for lock to reach stable state.
             while (c != 0) {
-                UUID currentOwner = currentOwnerNode;
+                UUID curOwner = currentOwnerNode;
 
-                if (currentOwner != null) {
-                    failed = ctx.discovery().node(currentOwner) == null;
+                if (curOwner != null) {
+                    failed = ctx.discovery().node(curOwner) == null;
 
                     break;
                 }
@@ -392,10 +392,10 @@ public final class GridCacheLockImpl extends AtomicDataStructureProxy<GridCacheL
 
             // Check if lock is released or current owner failed.
             if (c == 0 || failed) {
-                if (compareAndSetGlobalState(0, acquires, current, fair)) {
+                if (compareAndSetGlobalState(0, acquires, cur, fair)) {
 
                     // Not used for synchronization (we use ThreadID), but updated anyway.
-                    setExclusiveOwnerThread(current);
+                    setExclusiveOwnerThread(cur);
 
                     while (!isHeldExclusively() && !interruptAll)
                         Thread.yield();
@@ -414,8 +414,8 @@ public final class GridCacheLockImpl extends AtomicDataStructureProxy<GridCacheL
                 return true;
             }
 
-            if (fair && !isQueued(current))
-                synchronizeQueue(false, current);
+            if (fair && !isQueued(cur))
+                synchronizeQueue(false, cur);
 
             return false;
         }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/query/stat/hll/HLL.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/query/stat/hll/HLL.java
index 31319b42046..1da614f15a6 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/query/stat/hll/HLL.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/query/stat/hll/HLL.java
@@ -890,9 +890,9 @@ public class HLL implements Cloneable {
             case SPARSE:
                 for (final int registerIndex : other.sparseProbabilisticStorage.keySet()) {
                     final byte registerValue = other.sparseProbabilisticStorage.get(registerIndex);
-                    final byte currentRegisterValue = sparseProbabilisticStorage.getOrDefault(registerIndex, (byte)0);
+                    final byte curRegisterValue = sparseProbabilisticStorage.getOrDefault(registerIndex, (byte)0);
 
-                    if (registerValue > currentRegisterValue)
+                    if (registerValue > curRegisterValue)
                         sparseProbabilisticStorage.put(registerIndex, registerValue);
                 }
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/cluster/GridChangeStateCommandHandler.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/cluster/GridChangeStateCommandHandler.java
index c5dce31320c..b7207a6bd2a 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/cluster/GridChangeStateCommandHandler.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/cluster/GridChangeStateCommandHandler.java
@@ -64,9 +64,9 @@ public class GridChangeStateCommandHandler extends GridRestCommandHandlerAdapter
 
         switch (req.command()) {
             case CLUSTER_CURRENT_STATE:
-                Boolean currentState = ctx.state().publicApiActiveState(false);
+                Boolean curState = ctx.state().publicApiActiveState(false);
 
-                return new GridFinishedFuture<>(new GridRestResponse(currentState));
+                return new GridFinishedFuture<>(new GridRestResponse(curState));
 
             case CLUSTER_ACTIVE:
             case CLUSTER_INACTIVE:
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheLateAffinityAssignmentTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheLateAffinityAssignmentTest.java
index d50c2c53187..173cac6171b 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheLateAffinityAssignmentTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheLateAffinityAssignmentTest.java
@@ -1332,9 +1332,9 @@ public class CacheLateAffinityAssignmentTest extends GridCommonAbstractTest {
             }
         });
 
-        AffinityTopologyVersion currentTop = ignite(0).context().cache().context().exchange().readyAffinityVersion();
+        AffinityTopologyVersion curTop = ignite(0).context().cache().context().exchange().readyAffinityVersion();
 
-        checkAffinity(cnt, currentTop, true);
+        checkAffinity(cnt, curTop, true);
 
         stopNode(stopId, ord);
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PagesWriteThrottleSandboxTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PagesWriteThrottleSandboxTest.java
index 0d7de7b90c2..31d6e4843fc 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PagesWriteThrottleSandboxTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PagesWriteThrottleSandboxTest.java
@@ -168,8 +168,8 @@ public class PagesWriteThrottleSandboxTest extends GridCommonAbstractTest {
                             cpBufPages = pageMemory.checkpointBufferPagesCount();
 
                             if (System.nanoTime() - startNanos > TimeUnit.SECONDS.toNanos(10)) {
-                                double currentDirtyRatio = (double)dirtyPages / pageMemory.totalPages();
-                                double newMaxDirtyRatio = Math.max(maxDirtyRatio.get(), currentDirtyRatio);
+                                double curDirtyRatio = (double)dirtyPages / pageMemory.totalPages();
+                                double newMaxDirtyRatio = Math.max(maxDirtyRatio.get(), curDirtyRatio);
                                 maxDirtyRatio.set(newMaxDirtyRatio);
                             }
                         }
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/discovery/ClusterMetricsSelfTest.java b/modules/core/src/test/java/org/apache/ignite/spi/discovery/ClusterMetricsSelfTest.java
index 7b5f3a36259..85e1065871f 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/discovery/ClusterMetricsSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/discovery/ClusterMetricsSelfTest.java
@@ -79,8 +79,8 @@ public class ClusterMetricsSelfTest extends GridCommonAbstractTest {
 
         MetricRegistry reg = ignite.context().metric().registry(PME_METRICS);
 
-        LongMetric currentPMEDuration = reg.findMetric(PME_DURATION);
-        LongMetric currentBlockingPMEDuration = reg.findMetric(PME_OPS_BLOCKED_DURATION);
+        LongMetric curPMEDuration = reg.findMetric(PME_DURATION);
+        LongMetric curBlockingPMEDuration = reg.findMetric(PME_OPS_BLOCKED_DURATION);
 
         HistogramMetricImpl durationHistogram = reg.findMetric(PME_DURATION_HISTOGRAM);
         HistogramMetricImpl blockindDurationHistogram = reg.findMetric(PME_OPS_BLOCKED_DURATION_HISTOGRAM);
@@ -95,8 +95,8 @@ public class ClusterMetricsSelfTest extends GridCommonAbstractTest {
 
         int timeout = 5000;
 
-        assertTrue(GridTestUtils.waitForCondition(() -> currentPMEDuration.value() == 0, timeout));
-        assertEquals(0, currentBlockingPMEDuration.value());
+        assertTrue(GridTestUtils.waitForCondition(() -> curPMEDuration.value() == 0, timeout));
+        assertEquals(0, curBlockingPMEDuration.value());
 
         // There was two blocking exchange: server node start and cache start.
         assertEquals(2, Arrays.stream(durationHistogram.value()).sum());
@@ -117,9 +117,9 @@ public class ClusterMetricsSelfTest extends GridCommonAbstractTest {
             timeout));
 
         if (client)
-            assertEquals(0, currentBlockingPMEDuration.value());
+            assertEquals(0, curBlockingPMEDuration.value());
         else
-            assertTrue(currentBlockingPMEDuration.value() > 0);
+            assertTrue(curBlockingPMEDuration.value() > 0);
 
         lock.unlock();
 
@@ -128,8 +128,8 @@ public class ClusterMetricsSelfTest extends GridCommonAbstractTest {
 
         awaitPartitionMapExchange();
 
-        assertTrue(GridTestUtils.waitForCondition(() -> currentPMEDuration.value() == 0, timeout));
-        assertEquals(0, currentBlockingPMEDuration.value());
+        assertTrue(GridTestUtils.waitForCondition(() -> curPMEDuration.value() == 0, timeout));
+        assertEquals(0, curBlockingPMEDuration.value());
 
         if (client) {
             // There was non-blocking exchange: client node start.
diff --git a/modules/dev-utils/src/main/java/org/apache/ignite/development/utils/IgniteWalConverter.java b/modules/dev-utils/src/main/java/org/apache/ignite/development/utils/IgniteWalConverter.java
index c13d63f8abb..c61313bdb26 100644
--- a/modules/dev-utils/src/main/java/org/apache/ignite/development/utils/IgniteWalConverter.java
+++ b/modules/dev-utils/src/main/java/org/apache/ignite/development/utils/IgniteWalConverter.java
@@ -98,15 +98,15 @@ public class IgniteWalConverter {
         boolean printAlways = F.isEmpty(params.getRecordTypes());
 
         try (WALIterator stIt = walIterator(factory.iterator(iteratorParametersBuilder), params.getPages())) {
-            String currentWalPath = null;
+            String curWalPath = null;
 
             while (stIt.hasNextX()) {
-                final String currentRecordWalPath = getCurrentWalFilePath(stIt);
+                final String curRecordWalPath = getCurrentWalFilePath(stIt);
 
-                if (currentWalPath == null || !currentWalPath.equals(currentRecordWalPath)) {
-                    out.println("File: " + currentRecordWalPath);
+                if (curWalPath == null || !curWalPath.equals(curRecordWalPath)) {
+                    out.println("File: " + curRecordWalPath);
 
-                    currentWalPath = currentRecordWalPath;
+                    curWalPath = curRecordWalPath;
                 }
 
                 IgniteBiTuple<WALPointer, WALRecord> next = stIt.nextX();