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/21 09:09:39 UTC

(ignite) branch master updated: IGNITE-14823 Handler abbrevation (#11117)

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 431f5983570 IGNITE-14823 Handler abbrevation (#11117)
431f5983570 is described below

commit 431f598357047a7bfdc51d1999524e9a8ccc4d98
Author: Nikolay <ni...@apache.org>
AuthorDate: Thu Dec 21 12:09:32 2023 +0300

    IGNITE-14823 Handler abbrevation (#11117)
---
 .../calcite/exec/exp/ExpressionFactoryImpl.java    |  6 +--
 .../query/calcite/exec/rel/SortAggregateNode.java  |  8 ++--
 .../calcite/schema/CacheTableDescriptorImpl.java   | 30 +++++++--------
 .../processors/query/calcite/util/TypeUtils.java   | 10 ++---
 .../checkstyle/src/main/resources/abbrevations.csv |  2 +-
 .../util/GridCommandHandlerIndexListTest.java      | 26 ++++++-------
 .../GridCommandHandlerIndexRebuildStatusTest.java  | 14 +++----
 .../processors/cache/GridCacheProcessor.java       | 10 ++---
 .../processors/odbc/ClientListenerNioListener.java | 10 ++---
 .../FilePerformanceStatisticsReader.java           | 44 +++++++++++-----------
 ...JdbcPojoWriteBehindStoreWithCoalescingTest.java | 12 +++---
 .../pagelocktracker/SharedPageLockTrackerTest.java |  4 +-
 .../handlers/log/GridLogCommandHandlerTest.java    | 36 +++++++++---------
 .../internal/websession/WebSessionSelfTest.java    |  6 +--
 14 files changed, 109 insertions(+), 109 deletions(-)

diff --git a/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/exec/exp/ExpressionFactoryImpl.java b/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/exec/exp/ExpressionFactoryImpl.java
index 69acc6028b3..82b3a1fd859 100644
--- a/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/exec/exp/ExpressionFactoryImpl.java
+++ b/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/exec/exp/ExpressionFactoryImpl.java
@@ -253,8 +253,8 @@ public class ExpressionFactoryImpl<Row> implements ExpressionFactory<Row> {
 
     /** {@inheritDoc} */
     @Override public Iterable<Row> values(List<RexLiteral> values, RelDataType rowType) {
-        RowHandler<Row> handler = ctx.rowHandler();
-        RowFactory<Row> factory = handler.factory(typeFactory, rowType);
+        RowHandler<Row> hnd = ctx.rowHandler();
+        RowFactory<Row> factory = hnd.factory(typeFactory, rowType);
 
         int columns = rowType.getFieldCount();
         assert values.size() % columns == 0;
@@ -273,7 +273,7 @@ public class ExpressionFactoryImpl<Row> implements ExpressionFactory<Row> {
 
             RexLiteral literal = values.get(i);
 
-            handler.set(field, currRow, literal.getValueAs(types.get(field)));
+            hnd.set(field, currRow, literal.getValueAs(types.get(field)));
         }
 
         return rows;
diff --git a/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/exec/rel/SortAggregateNode.java b/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/exec/rel/SortAggregateNode.java
index cf7d8546dc6..3b261b936b3 100644
--- a/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/exec/rel/SortAggregateNode.java
+++ b/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/exec/rel/SortAggregateNode.java
@@ -184,10 +184,10 @@ public class SortAggregateNode<Row> extends AggregateNode<Row> {
         final Object[] grpKeys = new Object[grpSet.cardinality()];
         List<Integer> fldIdxs = grpSet.asList();
 
-        final RowHandler<Row> rowHandler = rowFactory.handler();
+        final RowHandler<Row> rowHnd = rowFactory.handler();
 
         for (int i = 0; i < grpKeys.length; ++i)
-            grpKeys[i] = rowHandler.get(fldIdxs.get(i), r);
+            grpKeys[i] = rowHnd.get(fldIdxs.get(i), r);
 
         Group grp = new Group(grpKeys);
 
@@ -249,10 +249,10 @@ public class SortAggregateNode<Row> extends AggregateNode<Row> {
 
         /** */
         private void addOnReducer(Row row) {
-            RowHandler<Row> handler = context().rowHandler();
+            RowHandler<Row> hnd = context().rowHandler();
 
             List<Accumulator> accums = hasAccumulators() ?
-                (List<Accumulator>)handler.get(handler.columnCount(row) - 1, row)
+                (List<Accumulator>)hnd.get(hnd.columnCount(row) - 1, row)
                 : Collections.emptyList();
 
             for (int i = 0; i < accums.size(); i++) {
diff --git a/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/schema/CacheTableDescriptorImpl.java b/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/schema/CacheTableDescriptorImpl.java
index e19a5420350..84f05bd14d2 100644
--- a/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/schema/CacheTableDescriptorImpl.java
+++ b/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/schema/CacheTableDescriptorImpl.java
@@ -255,19 +255,19 @@ public class CacheTableDescriptorImpl extends NullInitializerExpressionFactory
         RowHandler.RowFactory<Row> factory,
         @Nullable ImmutableBitSet requiredColumns
     ) throws IgniteCheckedException {
-        RowHandler<Row> handler = factory.handler();
+        RowHandler<Row> hnd = factory.handler();
 
-        assert handler == ectx.rowHandler();
+        assert hnd == ectx.rowHandler();
 
         Row res = factory.create();
 
-        assert handler.columnCount(res) == (requiredColumns == null ? descriptors.length : requiredColumns.cardinality());
+        assert hnd.columnCount(res) == (requiredColumns == null ? descriptors.length : requiredColumns.cardinality());
 
         if (requiredColumns == null) {
             for (int i = 0; i < descriptors.length; i++) {
                 CacheColumnDescriptor desc = descriptors[i];
 
-                handler.set(i, res, TypeUtils.toInternal(ectx,
+                hnd.set(i, res, TypeUtils.toInternal(ectx,
                     desc.value(ectx, cacheContext(), row), desc.storageType()));
             }
         }
@@ -275,7 +275,7 @@ public class CacheTableDescriptorImpl extends NullInitializerExpressionFactory
             for (int i = 0, j = requiredColumns.nextSetBit(0); j != -1; j = requiredColumns.nextSetBit(j + 1), i++) {
                 CacheColumnDescriptor desc = descriptors[j];
 
-                handler.set(i, res, TypeUtils.toInternal(ectx,
+                hnd.set(i, res, TypeUtils.toInternal(ectx,
                     desc.value(ectx, cacheContext(), row), desc.storageType()));
             }
         }
@@ -350,9 +350,9 @@ public class CacheTableDescriptorImpl extends NullInitializerExpressionFactory
 
     /** */
     private <Row> Object insertKey(Row row, ExecutionContext<Row> ectx) throws IgniteCheckedException {
-        RowHandler<Row> handler = ectx.rowHandler();
+        RowHandler<Row> hnd = ectx.rowHandler();
 
-        Object key = handler.get(keyField, row);
+        Object key = hnd.get(keyField, row);
 
         if (key != null)
             return TypeUtils.fromInternal(ectx, key, descriptors[QueryUtils.KEY_COL].storageType());
@@ -364,7 +364,7 @@ public class CacheTableDescriptorImpl extends NullInitializerExpressionFactory
             if (!desc.field() || !desc.key())
                 continue;
 
-            Object fieldVal = handler.get(i, row);
+            Object fieldVal = hnd.get(i, row);
 
             if (fieldVal != null) {
                 if (key == null)
@@ -382,9 +382,9 @@ public class CacheTableDescriptorImpl extends NullInitializerExpressionFactory
 
     /** */
     private <Row> Object insertVal(Row row, ExecutionContext<Row> ectx) throws IgniteCheckedException {
-        RowHandler<Row> handler = ectx.rowHandler();
+        RowHandler<Row> hnd = ectx.rowHandler();
 
-        Object val = handler.get(valField, row);
+        Object val = hnd.get(valField, row);
 
         if (val == null) {
             val = newVal(typeDesc.valueTypeName(), typeDesc.valueClass());
@@ -393,7 +393,7 @@ public class CacheTableDescriptorImpl extends NullInitializerExpressionFactory
             for (int i = 2; i < descriptors.length; i++) {
                 final CacheColumnDescriptor desc = descriptors[i];
 
-                Object fieldVal = handler.get(i, row);
+                Object fieldVal = hnd.get(i, row);
 
                 if (desc.field() && !desc.key() && fieldVal != null)
                     desc.set(val, TypeUtils.fromInternal(ectx, fieldVal, desc.storageType()));
@@ -449,10 +449,10 @@ public class CacheTableDescriptorImpl extends NullInitializerExpressionFactory
     /** */
     private <Row> ModifyTuple updateTuple(Row row, List<String> updateColList, int offset, ExecutionContext<Row> ectx)
         throws IgniteCheckedException {
-        RowHandler<Row> handler = ectx.rowHandler();
+        RowHandler<Row> hnd = ectx.rowHandler();
 
-        Object key = Objects.requireNonNull(handler.get(offset + QueryUtils.KEY_COL, row));
-        Object val = clone(Objects.requireNonNull(handler.get(offset + QueryUtils.VAL_COL, row)));
+        Object key = Objects.requireNonNull(hnd.get(offset + QueryUtils.KEY_COL, row));
+        Object val = clone(Objects.requireNonNull(hnd.get(offset + QueryUtils.VAL_COL, row)));
 
         offset += descriptorsMap.size();
 
@@ -461,7 +461,7 @@ public class CacheTableDescriptorImpl extends NullInitializerExpressionFactory
 
             assert !desc.key();
 
-            Object fieldVal = handler.get(i + offset, row);
+            Object fieldVal = hnd.get(i + offset, row);
 
             if (desc.field())
                 desc.set(val, TypeUtils.fromInternal(ectx, fieldVal, desc.storageType()));
diff --git a/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/util/TypeUtils.java b/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/util/TypeUtils.java
index 3a7101a571b..1a4e862f55d 100644
--- a/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/util/TypeUtils.java
+++ b/modules/calcite/src/main/java/org/apache/ignite/internal/processors/query/calcite/util/TypeUtils.java
@@ -252,16 +252,16 @@ public class TypeUtils {
         assert resultType.isStruct();
 
         if (hasConvertableFields(resultType)) {
-            RowHandler<Row> handler = ectx.rowHandler();
+            RowHandler<Row> hnd = ectx.rowHandler();
             List<RelDataType> types = RelOptUtil.getFieldTypeList(resultType);
-            RowHandler.RowFactory<Row> factory = handler.factory(ectx.getTypeFactory(), types);
+            RowHandler.RowFactory<Row> factory = hnd.factory(ectx.getTypeFactory(), types);
             List<Function<Object, Object>> converters = transform(types, t -> fieldConverter(ectx, t));
             return r -> {
                 Row newRow = factory.create();
-                assert handler.columnCount(newRow) == converters.size();
-                assert handler.columnCount(r) == converters.size();
+                assert hnd.columnCount(newRow) == converters.size();
+                assert hnd.columnCount(r) == converters.size();
                 for (int i = 0; i < converters.size(); i++)
-                    handler.set(i, newRow, converters.get(i).apply(handler.get(i, r)));
+                    hnd.set(i, newRow, converters.get(i).apply(hnd.get(i, r)));
                 return newRow;
             };
         }
diff --git a/modules/checkstyle/src/main/resources/abbrevations.csv b/modules/checkstyle/src/main/resources/abbrevations.csv
index e1969ffde81..9db1e380a09 100644
--- a/modules/checkstyle/src/main/resources/abbrevations.csv
+++ b/modules/checkstyle/src/main/resources/abbrevations.csv
@@ -27,7 +27,7 @@ execute,exec
 frequency,freq
 future,fut
 #group,grp
-#handler,hnd
+handler,hnd
 #header,hdr
 #implementation,impl
 #index,idx
diff --git a/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerIndexListTest.java b/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerIndexListTest.java
index 50745cb181f..ba431d3b43a 100644
--- a/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerIndexListTest.java
+++ b/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerIndexListTest.java
@@ -81,9 +81,9 @@ public class GridCommandHandlerIndexListTest extends GridCommandHandlerAbstractT
 
         injectTestSystemOut();
 
-        final TestCommandHandler handler = newCommandHandler(createTestLogger());
+        final TestCommandHandler hnd = newCommandHandler(createTestLogger());
 
-        assertEquals(EXIT_CODE_OK, execute(handler, "--cache", "indexes_list", "--index-name", idxName));
+        assertEquals(EXIT_CODE_OK, execute(hnd, "--cache", "indexes_list", "--index-name", idxName));
 
         String outStr = testOut.toString();
 
@@ -108,7 +108,7 @@ public class GridCommandHandlerIndexListTest extends GridCommandHandlerAbstractT
         assertEquals("Unexpected number of index description lines: " + indexDescrLinesNum,
             indexDescrLinesNum, expectedIndexDescrLinesNum);
 
-        Set<IndexListInfoContainer> cmdResult = handler.getLastOperationResult();
+        Set<IndexListInfoContainer> cmdResult = hnd.getLastOperationResult();
         assertNotNull(cmdResult);
 
         final int resSetSize = cmdResult.size();
@@ -131,9 +131,9 @@ public class GridCommandHandlerIndexListTest extends GridCommandHandlerAbstractT
 
         injectTestSystemOut();
 
-        final TestCommandHandler handler = newCommandHandler(createTestLogger());
+        final TestCommandHandler hnd = newCommandHandler(createTestLogger());
 
-        assertEquals(EXIT_CODE_OK, execute(handler, "--cache", "indexes_list",
+        assertEquals(EXIT_CODE_OK, execute(hnd, "--cache", "indexes_list",
             "--node-id", grid(0).localNode().id().toString(),
             "--group-name", "^" + GROUP_NAME + "$",
             "--cache-name", CACHE_NAME,
@@ -156,7 +156,7 @@ public class GridCommandHandlerIndexListTest extends GridCommandHandlerAbstractT
 
         injectTestSystemOut();
 
-        final TestCommandHandler handler = newCommandHandler(createTestLogger());
+        final TestCommandHandler hnd = newCommandHandler(createTestLogger());
 
         try {
             ignite.createCache(tmpCacheName);
@@ -166,7 +166,7 @@ public class GridCommandHandlerIndexListTest extends GridCommandHandlerAbstractT
                     streamer.addData(i * 13, i * 17);
             }
 
-            assertEquals(EXIT_CODE_OK, execute(handler, "--cache", "indexes_list", "--cache-name", tmpCacheName));
+            assertEquals(EXIT_CODE_OK, execute(hnd, "--cache", "indexes_list", "--cache-name", tmpCacheName));
 
             String str = testOut.toString();
 
@@ -215,11 +215,11 @@ public class GridCommandHandlerIndexListTest extends GridCommandHandlerAbstractT
 
     /** */
     private void checkGroup(String grpRegEx, Predicate<String> predicate, int expectedResNum) {
-        final TestCommandHandler handler = newCommandHandler(createTestLogger());
+        final TestCommandHandler hnd = newCommandHandler(createTestLogger());
 
-        assertEquals(EXIT_CODE_OK, execute(handler, "--cache", "indexes_list", "--group-name", grpRegEx));
+        assertEquals(EXIT_CODE_OK, execute(hnd, "--cache", "indexes_list", "--group-name", grpRegEx));
 
-        Set<IndexListInfoContainer> cmdResult = handler.getLastOperationResult();
+        Set<IndexListInfoContainer> cmdResult = hnd.getLastOperationResult();
         assertNotNull(cmdResult);
 
         boolean isResCorrect =
@@ -262,11 +262,11 @@ public class GridCommandHandlerIndexListTest extends GridCommandHandlerAbstractT
 
     /** */
     private void checkCacheNameFilter(String cacheRegEx, Predicate<String> predicate, int expectedResNum) {
-        final TestCommandHandler handler = newCommandHandler(createTestLogger());
+        final TestCommandHandler hnd = newCommandHandler(createTestLogger());
 
-        assertEquals(EXIT_CODE_OK, execute(handler, "--cache", "indexes_list", "--cache-name", cacheRegEx));
+        assertEquals(EXIT_CODE_OK, execute(hnd, "--cache", "indexes_list", "--cache-name", cacheRegEx));
 
-        Set<IndexListInfoContainer> cmdResult = handler.getLastOperationResult();
+        Set<IndexListInfoContainer> cmdResult = hnd.getLastOperationResult();
         assertNotNull(cmdResult);
 
         boolean isResCorrect =
diff --git a/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerIndexRebuildStatusTest.java b/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerIndexRebuildStatusTest.java
index 5ae7f108d79..31c74871949 100644
--- a/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerIndexRebuildStatusTest.java
+++ b/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerIndexRebuildStatusTest.java
@@ -144,7 +144,7 @@ public class GridCommandHandlerIndexRebuildStatusTest extends GridCommandHandler
         injectTestSystemOut();
         idxRebuildsStartedNum.set(0);
 
-        final TestCommandHandler handler = newCommandHandler(createTestLogger());
+        final TestCommandHandler hnd = newCommandHandler(createTestLogger());
 
         stopGrid(GRIDS_NUM - 1);
         stopGrid(GRIDS_NUM - 2);
@@ -163,9 +163,9 @@ public class GridCommandHandlerIndexRebuildStatusTest extends GridCommandHandler
         boolean allRebuildsStarted = GridTestUtils.waitForCondition(() -> idxRebuildsStartedNum.get() == 6, 30_000);
         assertTrue("Failed to wait for all indexes to start being rebuilt", allRebuildsStarted);
 
-        assertEquals(EXIT_CODE_OK, execute(handler, "--cache", "indexes_rebuild_status"));
+        assertEquals(EXIT_CODE_OK, execute(hnd, "--cache", "indexes_rebuild_status"));
 
-        checkResult(handler, 1, 2);
+        checkResult(hnd, 1, 2);
 
         statusRequestingFinished.set(true);
 
@@ -187,7 +187,7 @@ public class GridCommandHandlerIndexRebuildStatusTest extends GridCommandHandler
 
         assertTrue(idxProgressBlockedLatch.await(getTestTimeout(), MILLISECONDS));
 
-        assertEquals(EXIT_CODE_OK, execute(handler, "--cache", "indexes_rebuild_status"));
+        assertEquals(EXIT_CODE_OK, execute(hnd, "--cache", "indexes_rebuild_status"));
 
         checkRebuildInProgressOutputFor("cache1");
 
@@ -202,7 +202,7 @@ public class GridCommandHandlerIndexRebuildStatusTest extends GridCommandHandler
         injectTestSystemOut();
         idxRebuildsStartedNum.set(0);
 
-        final TestCommandHandler handler = newCommandHandler(createTestLogger());
+        final TestCommandHandler hnd = newCommandHandler(createTestLogger());
 
         stopGrid(GRIDS_NUM - 1);
         stopGrid(GRIDS_NUM - 2);
@@ -221,11 +221,11 @@ public class GridCommandHandlerIndexRebuildStatusTest extends GridCommandHandler
         boolean allRebuildsStarted = GridTestUtils.waitForCondition(() -> idxRebuildsStartedNum.get() == 6, 30_000);
         assertTrue("Failed to wait for all indexes to start being rebuilt", allRebuildsStarted);
 
-        assertEquals(EXIT_CODE_OK, execute(handler, "--cache", "indexes_rebuild_status", "--node-id", id1.toString()));
+        assertEquals(EXIT_CODE_OK, execute(hnd, "--cache", "indexes_rebuild_status", "--node-id", id1.toString()));
 
         statusRequestingFinished.set(true);
 
-        checkResult(handler, 2);
+        checkResult(hnd, 2);
     }
 
     /**
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
index 8bd21c36921..9a7461863d3 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
@@ -2474,12 +2474,12 @@ public class GridCacheProcessor extends GridProcessorAdapter {
         boolean persistenceEnabled = recoveryMode || sharedCtx.localNode().isClient() ? desc.persistenceEnabled() :
             dataRegion != null && dataRegion.config().isPersistenceEnabled();
 
-        CompressionHandler compressHandler = CompressionHandler.create(ctx, cfg);
+        CompressionHandler compressHnd = CompressionHandler.create(ctx, cfg);
 
-        if (log.isInfoEnabled() && compressHandler.compressionEnabled()) {
+        if (log.isInfoEnabled() && compressHnd.compressionEnabled()) {
             log.info("Disk page compression is enabled [cacheGrp=" + CU.cacheOrGroupName(cfg) +
-                ", compression=" + compressHandler.diskPageCompression() + ", level=" +
-                compressHandler.diskPageCompressionLevel() + "]");
+                ", compression=" + compressHnd.diskPageCompression() + ", level=" +
+                compressHnd.diskPageCompressionLevel() + "]");
         }
 
         CacheGroupContext grp = new CacheGroupContext(sharedCtx,
@@ -2496,7 +2496,7 @@ public class GridCacheProcessor extends GridProcessorAdapter {
             persistenceEnabled,
             desc.walEnabled(),
             recoveryMode,
-            compressHandler
+            compressHnd
         );
 
         for (Object obj : grp.configuredUserObjects())
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/odbc/ClientListenerNioListener.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/odbc/ClientListenerNioListener.java
index e26ebddbcf1..eb8dcd9ce14 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/odbc/ClientListenerNioListener.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/odbc/ClientListenerNioListener.java
@@ -171,7 +171,7 @@ public class ClientListenerNioListener extends GridNioServerListenerAdapter<Clie
         }
 
         ClientListenerMessageParser parser = connCtx.parser();
-        ClientListenerRequestHandler handler = connCtx.handler();
+        ClientListenerRequestHandler hnd = connCtx.handler();
 
         ClientListenerRequest req;
 
@@ -180,7 +180,7 @@ public class ClientListenerNioListener extends GridNioServerListenerAdapter<Clie
         }
         catch (Exception e) {
             try {
-                handler.unregisterRequest(parser.decodeRequestId(msg));
+                hnd.unregisterRequest(parser.decodeRequestId(msg));
             }
             catch (Exception e1) {
                 U.error(log, "Failed to unregister request.", e1);
@@ -208,7 +208,7 @@ public class ClientListenerNioListener extends GridNioServerListenerAdapter<Clie
             ClientListenerResponse resp;
 
             try (OperationSecurityContext s = ctx.security().withContext(connCtx.securityContext())) {
-                resp = handler.handle(req);
+                resp = hnd.handle(req);
             }
 
             if (resp != null) {
@@ -228,14 +228,14 @@ public class ClientListenerNioListener extends GridNioServerListenerAdapter<Clie
             }
         }
         catch (Throwable e) {
-            handler.unregisterRequest(req.requestId());
+            hnd.unregisterRequest(req.requestId());
 
             if (e instanceof Error)
                 U.error(log, "Failed to process client request [req=" + req + ", msg=" + e.getMessage() + "]", e);
             else
                 U.warn(log, "Failed to process client request [req=" + req + ", msg=" + e.getMessage() + "]", e);
 
-            ses.send(parser.encode(handler.handleException(e, req)));
+            ses.send(parser.encode(hnd.handleException(e, req)));
 
             if (e instanceof Error)
                 throw (Error)e;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/performancestatistics/FilePerformanceStatisticsReader.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/performancestatistics/FilePerformanceStatisticsReader.java
index b0c8244734a..d18770505d5 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/performancestatistics/FilePerformanceStatisticsReader.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/performancestatistics/FilePerformanceStatisticsReader.java
@@ -219,8 +219,8 @@ public class FilePerformanceStatisticsReader {
             long startTime = buf.getLong();
             long duration = buf.getLong();
 
-            for (PerformanceStatisticsHandler handler : curHnd)
-                handler.cacheOperation(nodeId, opType, cacheId, startTime, duration);
+            for (PerformanceStatisticsHandler hnd : curHnd)
+                hnd.cacheOperation(nodeId, opType, cacheId, startTime, duration);
 
             return true;
         }
@@ -241,8 +241,8 @@ public class FilePerformanceStatisticsReader {
             long startTime = buf.getLong();
             long duration = buf.getLong();
 
-            for (PerformanceStatisticsHandler handler : curHnd)
-                handler.transaction(nodeId, cacheIds, startTime, duration, opType == TX_COMMIT);
+            for (PerformanceStatisticsHandler hnd : curHnd)
+                hnd.transaction(nodeId, cacheIds, startTime, duration, opType == TX_COMMIT);
 
             return true;
         }
@@ -287,8 +287,8 @@ public class FilePerformanceStatisticsReader {
             if (text == null)
                 forwardRead(hash);
 
-            for (PerformanceStatisticsHandler handler : curHnd)
-                handler.query(nodeId, queryType, text, id, startTime, duration, success);
+            for (PerformanceStatisticsHandler hnd : curHnd)
+                hnd.query(nodeId, queryType, text, id, startTime, duration, success);
 
             return true;
         }
@@ -302,8 +302,8 @@ public class FilePerformanceStatisticsReader {
             long logicalReads = buf.getLong();
             long physicalReads = buf.getLong();
 
-            for (PerformanceStatisticsHandler handler : curHnd)
-                handler.queryReads(nodeId, queryType, uuid, id, logicalReads, physicalReads);
+            for (PerformanceStatisticsHandler hnd : curHnd)
+                hnd.queryReads(nodeId, queryType, uuid, id, logicalReads, physicalReads);
 
             return true;
         }
@@ -318,8 +318,8 @@ public class FilePerformanceStatisticsReader {
             long id = buf.getLong();
             long rows = buf.getLong();
 
-            for (PerformanceStatisticsHandler handler : curHnd)
-                handler.queryRows(nodeId, qryType, uuid, id, action, rows);
+            for (PerformanceStatisticsHandler hnd : curHnd)
+                hnd.queryRows(nodeId, qryType, uuid, id, action, rows);
 
             return true;
         }
@@ -341,8 +341,8 @@ public class FilePerformanceStatisticsReader {
             UUID uuid = readUuid(buf);
             long id = buf.getLong();
 
-            for (PerformanceStatisticsHandler handler : curHnd)
-                handler.queryProperty(nodeId, qryType, uuid, id, name, val);
+            for (PerformanceStatisticsHandler hnd : curHnd)
+                hnd.queryProperty(nodeId, qryType, uuid, id, name, val);
 
             return true;
         }
@@ -386,8 +386,8 @@ public class FilePerformanceStatisticsReader {
             if (taskName == null)
                 forwardRead(hash);
 
-            for (PerformanceStatisticsHandler handler : curHnd)
-                handler.task(nodeId, sesId, taskName, startTime, duration, affPartId);
+            for (PerformanceStatisticsHandler hnd : curHnd)
+                hnd.task(nodeId, sesId, taskName, startTime, duration, affPartId);
 
             return true;
         }
@@ -401,8 +401,8 @@ public class FilePerformanceStatisticsReader {
             long duration = buf.getLong();
             boolean timedOut = buf.get() != 0;
 
-            for (PerformanceStatisticsHandler handler : curHnd)
-                handler.job(nodeId, sesId, queuedTime, startTime, duration, timedOut);
+            for (PerformanceStatisticsHandler hnd : curHnd)
+                hnd.job(nodeId, sesId, queuedTime, startTime, duration, timedOut);
 
             return true;
         }
@@ -440,8 +440,8 @@ public class FilePerformanceStatisticsReader {
 
             int cacheId = buf.getInt();
 
-            for (PerformanceStatisticsHandler handler : curHnd)
-                handler.cacheStart(nodeId, cacheId, cacheName);
+            for (PerformanceStatisticsHandler hnd : curHnd)
+                hnd.cacheStart(nodeId, cacheId, cacheName);
 
             return true;
         }
@@ -465,8 +465,8 @@ public class FilePerformanceStatisticsReader {
             int dataPagesWritten = buf.getInt();
             int cowPagesWritten = buf.getInt();
 
-            for (PerformanceStatisticsHandler handler : curHnd) {
-                handler.checkpoint(nodeId,
+            for (PerformanceStatisticsHandler hnd : curHnd) {
+                hnd.checkpoint(nodeId,
                     beforeLockDuration,
                     lockWaitDuration,
                     listenersExecDuration,
@@ -493,8 +493,8 @@ public class FilePerformanceStatisticsReader {
             long endTime = buf.getLong();
             long duration = buf.getLong();
 
-            for (PerformanceStatisticsHandler handler : curHnd)
-                handler.pagesWriteThrottle(nodeId, endTime, duration);
+            for (PerformanceStatisticsHandler hnd : curHnd)
+                hnd.pagesWriteThrottle(nodeId, endTime, duration);
 
             return true;
         }
diff --git a/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoWriteBehindStoreWithCoalescingTest.java b/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoWriteBehindStoreWithCoalescingTest.java
index 12d94456bc1..3714c6f7f59 100644
--- a/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoWriteBehindStoreWithCoalescingTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoWriteBehindStoreWithCoalescingTest.java
@@ -502,11 +502,11 @@ public class CacheJdbcPojoWriteBehindStoreWithCoalescingTest extends GridCommonA
             }
         });
 
-        TestErrorHandler handler = new TestErrorHandler();
+        TestErrorHandler hnd = new TestErrorHandler();
 
-        t1.setUncaughtExceptionHandler(handler);
+        t1.setUncaughtExceptionHandler(hnd);
 
-        t2.setUncaughtExceptionHandler(handler);
+        t2.setUncaughtExceptionHandler(hnd);
 
         t1.start();
 
@@ -579,11 +579,11 @@ public class CacheJdbcPojoWriteBehindStoreWithCoalescingTest extends GridCommonA
             }
         });
 
-        TestErrorHandler handler = new TestErrorHandler();
+        TestErrorHandler hnd = new TestErrorHandler();
 
-        t1.setUncaughtExceptionHandler(handler);
+        t1.setUncaughtExceptionHandler(hnd);
 
-        t2.setUncaughtExceptionHandler(handler);
+        t2.setUncaughtExceptionHandler(hnd);
 
         t1.start();
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/diagnostic/pagelocktracker/SharedPageLockTrackerTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/diagnostic/pagelocktracker/SharedPageLockTrackerTest.java
index ae4b20f0c0c..9ed00f9f0eb 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/diagnostic/pagelocktracker/SharedPageLockTrackerTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/diagnostic/pagelocktracker/SharedPageLockTrackerTest.java
@@ -305,11 +305,11 @@ public class SharedPageLockTrackerTest extends AbstractPageLockTest {
     public void testMemoryLeakOnThreadTerminates() throws Exception {
         int threadLimits = 1000;
         int timeOutWorkerInterval = 10_000;
-        Consumer<Set<PageLockThreadState>> handler = (threads) -> {
+        Consumer<Set<PageLockThreadState>> hnd = (threads) -> {
         };
 
         SharedPageLockTracker sharedPageLockTracker = new SharedPageLockTracker(
-            threadLimits, timeOutWorkerInterval, handler, new MemoryCalculator());
+            threadLimits, timeOutWorkerInterval, hnd, new MemoryCalculator());
 
         int threads = 10_000;
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/log/GridLogCommandHandlerTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/log/GridLogCommandHandlerTest.java
index 71627f91b39..4739051425a 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/log/GridLogCommandHandlerTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/log/GridLogCommandHandlerTest.java
@@ -72,9 +72,9 @@ public class GridLogCommandHandlerTest extends GridCommonAbstractTest {
      */
     @Test
     public void testSupportedCommands() throws Exception {
-        GridLogCommandHandler cmdHandler = new GridLogCommandHandler(newContext());
+        GridLogCommandHandler cmdHnd = new GridLogCommandHandler(newContext());
 
-        Collection<GridRestCommand> cmds = cmdHandler.supportedCommands();
+        Collection<GridRestCommand> cmds = cmdHnd.supportedCommands();
 
         assertEquals(1, cmds.size());
         assertTrue(cmds.contains(GridRestCommand.LOG));
@@ -85,9 +85,9 @@ public class GridLogCommandHandlerTest extends GridCommonAbstractTest {
      */
     @Test
     public void testUnSupportedCommands() throws Exception {
-        GridLogCommandHandler cmdHandler = new GridLogCommandHandler(newContext());
+        GridLogCommandHandler cmdHnd = new GridLogCommandHandler(newContext());
 
-        Collection<GridRestCommand> cmds = cmdHandler.supportedCommands();
+        Collection<GridRestCommand> cmds = cmdHnd.supportedCommands();
 
         assertEquals(1, cmds.size());
         assertFalse(cmds.contains(GridRestCommand.VERSION));
@@ -101,14 +101,14 @@ public class GridLogCommandHandlerTest extends GridCommonAbstractTest {
         IgniteConfiguration cfg = new IgniteConfiguration();
         cfg.setIgniteHome(igniteHome);
         GridTestKernalContext ctx = newContext(cfg);
-        GridLogCommandHandler cmdHandler = new GridLogCommandHandler(ctx);
+        GridLogCommandHandler cmdHnd = new GridLogCommandHandler(ctx);
         GridRestLogRequest req = new GridRestLogRequest();
 
         req.to(5);
         req.from(2);
 
         req.path(igniteHome + "/work/log/" + "test.log");
-        IgniteInternalFuture<GridRestResponse> resp = cmdHandler.handleAsync(req);
+        IgniteInternalFuture<GridRestResponse> resp = cmdHnd.handleAsync(req);
 
         assertNull(resp.result().getError());
         assertEquals(GridRestResponse.STATUS_SUCCESS, resp.result().getSuccessStatus());
@@ -123,14 +123,14 @@ public class GridLogCommandHandlerTest extends GridCommonAbstractTest {
         IgniteConfiguration cfg = new IgniteConfiguration();
         cfg.setIgniteHome(igniteHome);
         GridTestKernalContext ctx = newContext(cfg);
-        GridLogCommandHandler cmdHandler = new GridLogCommandHandler(ctx);
+        GridLogCommandHandler cmdHnd = new GridLogCommandHandler(ctx);
         GridRestLogRequest req = new GridRestLogRequest();
 
         req.to(50);
         req.from(20);
 
         req.path(igniteHome + "/work/log/" + "test.log");
-        IgniteInternalFuture<GridRestResponse> resp = cmdHandler.handleAsync(req);
+        IgniteInternalFuture<GridRestResponse> resp = cmdHnd.handleAsync(req);
 
         assertEquals("Request parameter 'from' and 'to' are for lines that do not exist in log file.", resp.result().getError());
         assertEquals(GridRestResponse.STATUS_FAILED, resp.result().getSuccessStatus());
@@ -145,11 +145,11 @@ public class GridLogCommandHandlerTest extends GridCommonAbstractTest {
         IgniteConfiguration cfg = new IgniteConfiguration();
         cfg.setIgniteHome(igniteHome);
         GridTestKernalContext ctx = newContext(cfg);
-        GridLogCommandHandler cmdHandler = new GridLogCommandHandler(ctx);
+        GridLogCommandHandler cmdHnd = new GridLogCommandHandler(ctx);
         GridRestLogRequest req = new GridRestLogRequest();
 
         req.path(igniteHome + "/work/log/" + "test.log");
-        IgniteInternalFuture<GridRestResponse> resp = cmdHandler.handleAsync(req);
+        IgniteInternalFuture<GridRestResponse> resp = cmdHnd.handleAsync(req);
 
         assertNull(resp.result().getError());
         assertEquals(GridRestResponse.STATUS_SUCCESS, resp.result().getSuccessStatus());
@@ -163,13 +163,13 @@ public class GridLogCommandHandlerTest extends GridCommonAbstractTest {
     public void testHandleAsyncPathNotSet() throws Exception {
         GridTestKernalContext ctx = newContext();
         ctx.config().setIgniteHome(igniteHome);
-        GridLogCommandHandler cmdHandler = new GridLogCommandHandler(ctx);
+        GridLogCommandHandler cmdHnd = new GridLogCommandHandler(ctx);
         GridRestLogRequest req = new GridRestLogRequest();
 
         req.to(5);
         req.from(2);
 
-        IgniteInternalFuture<GridRestResponse> resp = cmdHandler.handleAsync(req);
+        IgniteInternalFuture<GridRestResponse> resp = cmdHnd.handleAsync(req);
 
         assertNull(resp.result().getError());
         assertEquals(GridRestResponse.STATUS_SUCCESS, resp.result().getSuccessStatus());
@@ -184,14 +184,14 @@ public class GridLogCommandHandlerTest extends GridCommonAbstractTest {
         IgniteConfiguration cfg = new IgniteConfiguration();
         cfg.setIgniteHome(igniteHome);
         GridTestKernalContext ctx = newContext(cfg);
-        GridLogCommandHandler cmdHandler = new GridLogCommandHandler(ctx);
+        GridLogCommandHandler cmdHnd = new GridLogCommandHandler(ctx);
         GridRestLogRequest req = new GridRestLogRequest();
 
         req.to(5);
         req.from(2);
         req.path("/home/users/mytest.log");
 
-        IgniteInternalFuture<GridRestResponse> resp = cmdHandler.handleAsync(req);
+        IgniteInternalFuture<GridRestResponse> resp = cmdHnd.handleAsync(req);
 
         assertEquals("Request parameter 'path' must contain a path to valid log file.", resp.result().getError());
         assertEquals(GridRestResponse.STATUS_FAILED, resp.result().getSuccessStatus());
@@ -206,14 +206,14 @@ public class GridLogCommandHandlerTest extends GridCommonAbstractTest {
         IgniteConfiguration cfg = new IgniteConfiguration();
         cfg.setIgniteHome(igniteHome);
         GridTestKernalContext ctx = newContext(cfg);
-        GridLogCommandHandler cmdHandler = new GridLogCommandHandler(ctx);
+        GridLogCommandHandler cmdHnd = new GridLogCommandHandler(ctx);
         GridRestLogRequest req = new GridRestLogRequest();
 
         req.to(5);
         req.from(7);
 
         req.path(igniteHome + "/work/log/" + "test.log");
-        IgniteInternalFuture<GridRestResponse> resp = cmdHandler.handleAsync(req);
+        IgniteInternalFuture<GridRestResponse> resp = cmdHnd.handleAsync(req);
 
         assertEquals("Request parameter 'from' must be less than 'to'.", resp.result().getError());
         assertEquals(GridRestResponse.STATUS_FAILED, resp.result().getSuccessStatus());
@@ -228,14 +228,14 @@ public class GridLogCommandHandlerTest extends GridCommonAbstractTest {
         IgniteConfiguration cfg = new IgniteConfiguration();
         cfg.setIgniteHome(igniteHome);
         GridTestKernalContext ctx = newContext(cfg);
-        GridLogCommandHandler cmdHandler = new GridLogCommandHandler(ctx);
+        GridLogCommandHandler cmdHnd = new GridLogCommandHandler(ctx);
         GridRestLogRequest req = new GridRestLogRequest();
 
         req.to(5);
         req.from(5);
 
         req.path(igniteHome + "/work/log/" + "test.log");
-        IgniteInternalFuture<GridRestResponse> resp = cmdHandler.handleAsync(req);
+        IgniteInternalFuture<GridRestResponse> resp = cmdHnd.handleAsync(req);
 
         assertEquals("Request parameter 'from' must be less than 'to'.", resp.result().getError());
         assertEquals(GridRestResponse.STATUS_FAILED, resp.result().getSuccessStatus());
diff --git a/modules/web/src/test/java/org/apache/ignite/internal/websession/WebSessionSelfTest.java b/modules/web/src/test/java/org/apache/ignite/internal/websession/WebSessionSelfTest.java
index f58bd04ab41..616117fd345 100644
--- a/modules/web/src/test/java/org/apache/ignite/internal/websession/WebSessionSelfTest.java
+++ b/modules/web/src/test/java/org/apache/ignite/internal/websession/WebSessionSelfTest.java
@@ -1018,10 +1018,10 @@ public class WebSessionSelfTest extends GridCommonAbstractTest {
         hashLoginService.setName("Test Realm");
         createRealm();
         hashLoginService.setConfig("/tmp/realm.properties");
-        SecurityHandler securityHandler = ctx.getSecurityHandler();
+        SecurityHandler securityHnd = ctx.getSecurityHandler();
         // DefaultAuthenticatorFactory doesn't default to basic auth anymore.
-        securityHandler.setAuthMethod(Constraint.__BASIC_AUTH);
-        securityHandler.setLoginService(hashLoginService);
+        securityHnd.setAuthMethod(Constraint.__BASIC_AUTH);
+        securityHnd.setLoginService(hashLoginService);
 
         srv.setHandler(ctx);