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 2021/05/19 17:33:18 UTC

[ignite] branch master updated: IGNITE-14714 LineLength checkstyle rule added (#9106)

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 b1529fb  IGNITE-14714 LineLength checkstyle rule added (#9106)
b1529fb is described below

commit b1529fbd7d42e3f3a5500a217a2b8b21acbb4189
Author: Nikolay <ni...@apache.org>
AuthorDate: Wed May 19 20:32:53 2021 +0300

    IGNITE-14714 LineLength checkstyle rule added (#9106)
---
 checkstyle/checkstyle-suppressions.xml             |  2 +
 checkstyle/checkstyle.xml                          |  8 ++
 .../ml/clustering/KMeansClusterizationExample.java |  3 +-
 .../dataset/AlgorithmSpecificDatasetExample.java   | 22 +++---
 .../CatboostClassificationModelParserExample.java  |  3 +-
 .../KMeansClusterizationExportImportExample.java   |  3 +-
 .../modelparser/DecisionTreeFromSparkExample.java  |  9 ++-
 .../DecisionTreeRegressionFromSparkExample.java    |  9 ++-
 .../spark/modelparser/GBTFromSparkExample.java     |  9 ++-
 .../modelparser/GBTRegressionFromSparkExample.java |  9 ++-
 .../spark/modelparser/KMeansFromSparkExample.java  |  5 +-
 .../LinearRegressionFromSparkExample.java          |  8 +-
 .../spark/modelparser/LogRegFromSparkExample.java  |  9 ++-
 .../modelparser/RandomForestFromSparkExample.java  |  9 ++-
 .../RandomForestRegressionFromSparkExample.java    |  9 ++-
 .../spark/modelparser/SVMFromSparkExample.java     |  5 +-
 .../multiclass/OneVsRestClassificationExample.java |  7 +-
 .../encoding/TargetEncoderExample.java             |  4 +-
 .../linear/BostonHousePricesPredictionExample.java |  3 +-
 ...gressionLSQRTrainerWithMinMaxScalerExample.java |  4 +-
 ...eeClassificationTrainerSQLInferenceExample.java |  4 +-
 .../RandomForestClassificationExample.java         |  4 +-
 .../hyperparametertuning/Step_13_RandomSearch.java |  6 +-
 .../Step_14_Parallel_Brute_Force_Search.java       |  6 +-
 .../Step_15_Parallel_Random_Search.java            |  6 +-
 .../Step_16_Genetic_Programming_Search.java        |  6 +-
 ...tep_17_Parallel_Genetic_Programming_Search.java |  6 +-
 .../ignite/examples/ml/util/MLSandboxDatasets.java |  9 ++-
 .../spark/JavaIgniteDataFrameJoinExample.java      |  4 +-
 idea/ignite_codeStyle.xml                          |  1 +
 .../aop/aspectj/GridifySetToSetAspectJAspect.java  |  3 +-
 .../aspectj/GridifySetToValueAspectJAspect.java    |  3 +-
 .../gridify/aop/spring/GridifySpringEnhancer.java  |  3 +-
 .../GridDhtPartitionsStateValidatorBenchmark.java  |  5 +-
 .../cassandra/CassandraCacheStoreFactory.java      |  5 +-
 .../persistence/KeyValuePersistenceSettings.java   | 15 +++-
 .../ignite/tests/IgnitePersistentStoreTest.java    | 12 ++-
 .../apache/ignite/tests/utils/CassandraHelper.java |  3 +-
 .../tests/persistence/blob/ignite-config.xml       |  6 +-
 .../tests/persistence/pojo/ignite-config.xml       | 21 +++--
 .../tests/persistence/primitive/ignite-config.xml  |  6 +-
 .../client/ClientReconnectionSelfTest.java         | 23 +++---
 .../internal/client/TaskSingleJobSplitAdapter.java |  3 +-
 .../jdbc2/JdbcAbstractDmlStatementSelfTest.java    |  6 +-
 .../jdbc2/JdbcDistributedJoinsQueryTest.java       |  3 +-
 .../internal/jdbc2/JdbcMetadataSelfTest.java       |  3 +-
 .../ignite/jdbc/thin/JdbcThinBatchSelfTest.java    |  3 +-
 .../jdbc/thin/JdbcThinConnectionSelfTest.java      |  3 +-
 .../qa/query/WarningOnBigQueryResultsBaseTest.java |  3 +-
 .../persistence/FoldersReuseCompatibilityTest.java |  3 +-
 .../internal/commandline/CommandHandler.java       |  3 +-
 .../commandline/cache/CheckIndexInlineSizes.java   |  4 +-
 .../commandline/CommandHandlerParsingTest.java     | 90 ++++++++++++++++-----
 ...idCommandHandlerCheckIndexesInlineSizeTest.java |  6 +-
 .../util/GridCommandHandlerClusterByClassTest.java |  3 +-
 .../apache/ignite/util/GridCommandHandlerTest.java |  9 ++-
 .../src/main/java/org/apache/ignite/Ignite.java    |  6 +-
 .../org/apache/ignite/IgniteSystemProperties.java  | 10 ++-
 .../cache/store/jdbc/CacheJdbcPojoStore.java       |  7 +-
 .../cache/store/jdbc/dialect/BasicJdbcDialect.java |  8 +-
 .../cache/store/jdbc/dialect/DB2Dialect.java       |  7 +-
 .../cache/store/jdbc/dialect/SQLServerDialect.java |  7 +-
 .../events/CacheConsistencyViolationEvent.java     |  7 +-
 .../ignite/events/CacheQueryExecutedEvent.java     |  7 +-
 .../apache/ignite/events/CacheQueryReadEvent.java  |  7 +-
 .../org/apache/ignite/events/CheckpointEvent.java  |  7 +-
 .../org/apache/ignite/events/DeploymentEvent.java  |  7 +-
 .../org/apache/ignite/events/DiscoveryEvent.java   |  7 +-
 .../main/java/org/apache/ignite/events/Event.java  |  4 +-
 .../ignite/events/SqlQueryExecutionEvent.java      |  7 +-
 .../java/org/apache/ignite/events/TaskEvent.java   |  7 +-
 .../ignite/internal/GridJobExecuteRequest.java     |  6 +-
 .../org/apache/ignite/internal/IgnitionEx.java     | 11 ++-
 .../apache/ignite/internal/binary/BinaryUtils.java | 13 +--
 .../binary/streams/BinaryMemoryAllocator.java      |  3 +-
 .../query/index/sorted/inline/InlineIndexImpl.java |  7 +-
 .../client/thin/IgniteClientFutureImpl.java        | 54 ++++++++++---
 .../ignite/internal/cluster/IgniteClusterImpl.java |  7 +-
 .../internal/jdbc/thin/JdbcThinConnection.java     |  6 +-
 .../internal/managers/GridManagerAdapter.java      |  8 +-
 .../managers/discovery/GridDiscoveryManager.java   | 27 +++++--
 .../managers/encryption/GridEncryptionManager.java |  3 +-
 .../internal/metric/IoStatisticsHolderQuery.java   |  3 +-
 .../pagemem/store/IgnitePageStoreManager.java      |  8 +-
 .../internal/pagemem/wal/record/DataEntry.java     |  5 +-
 .../internal/pagemem/wal/record/WALRecord.java     |  3 +-
 .../delta/MetaPageUpdatePartitionDataRecordV2.java |  9 ++-
 .../internal/processors/GridProcessorAdapter.java  |  5 +-
 .../affinity/GridAffinityAssignmentCache.java      |  4 +-
 .../processors/affinity/GridAffinityProcessor.java | 29 ++++---
 .../processors/cache/CacheGroupMetricsImpl.java    |  3 +-
 .../internal/processors/cache/CacheLazyEntry.java  | 19 ++++-
 .../processors/cache/CacheMetricsImpl.java         |  7 +-
 .../processors/cache/ClusterCachesInfo.java        |  7 +-
 .../cache/GatewayProtectedCacheProxy.java          | 56 ++++++++++---
 .../processors/cache/GridCacheAdapter.java         |  6 +-
 .../processors/cache/GridCacheIoManager.java       | 13 ++-
 .../processors/cache/GridCacheMapEntry.java        |  7 +-
 .../cache/GridCachePartitionExchangeManager.java   | 10 ++-
 .../cache/ValidationOnNodeJoinUtils.java           |  4 +-
 .../cache/binary/BinaryMetadataTransport.java      |  3 +-
 .../distributed/dht/atomic/GridDhtAtomicCache.java |  6 +-
 .../dht/colocated/GridDhtColocatedCache.java       |  6 +-
 .../dht/colocated/GridDhtColocatedLockFuture.java  |  3 +-
 .../dht/colocated/GridDhtDetachedCacheEntry.java   |  8 +-
 .../dht/preloader/GridDhtPartitionFullMap.java     |  3 +-
 .../preloader/GridDhtPartitionsExchangeFuture.java | 23 ++++--
 .../dht/preloader/GridDhtPreloader.java            |  4 +-
 .../dht/topology/GridDhtPartitionTopologyImpl.java |  6 +-
 .../distributed/near/GridNearAtomicCache.java      |  3 +-
 ...dNearOptimisticSerializableTxPrepareFuture.java | 18 +++--
 .../near/GridNearOptimisticTxPrepareFuture.java    |  3 +-
 .../cache/distributed/near/GridNearTxLocal.java    | 70 +++++++++++-----
 .../processors/cache/mvcc/MvccProcessorImpl.java   |  3 +-
 .../internal/processors/cache/mvcc/MvccUtils.java  |  4 +-
 .../internal/processors/cache/package-info.java    |  5 +-
 .../GridCacheDatabaseSharedManager.java            |  6 +-
 .../cache/persistence/GridCacheOffheapManager.java |  8 +-
 .../checkpoint/CheckpointPagesWriter.java          |  3 +-
 .../CachePartitionDefragmentationManager.java      |  6 +-
 .../cache/persistence/defragmentation/LinkMap.java | 16 +++-
 .../persistence/file/FilePageStoreManager.java     |  8 +-
 .../file/FileVersionCheckingFactory.java           |  4 +-
 .../cache/persistence/freelist/PagesList.java      |  3 +-
 .../cache/persistence/metastorage/MetaStorage.java |  6 +-
 .../processors/cache/persistence/package-info.java |  5 +-
 .../cache/persistence/pagemem/PageMemoryImpl.java  |  7 +-
 .../pagemem/PageReadWriteManagerImpl.java          |  8 +-
 .../cache/persistence/pagemem/package-info.java    |  5 +-
 .../snapshot/IgniteCacheSnapshotManager.java       |  3 +-
 .../snapshot/IgniteSnapshotManager.java            | 49 ++++++++----
 .../cache/persistence/tree/BPlusTree.java          |  3 +-
 .../persistence/tree/io/AbstractDataPageIO.java    |  3 +-
 .../cache/persistence/tree/io/PageIO.java          |  3 +-
 .../cache/persistence/tree/util/PageHandler.java   | 16 +++-
 .../wal/reader/StandaloneWalRecordsIterator.java   |  6 +-
 .../wal/serializer/RecordV1Serializer.java         |  8 +-
 .../cache/query/GridCacheQueryManager.java         | 17 ++--
 .../cache/transactions/IgniteTxHandler.java        |  5 +-
 .../cache/transactions/IgniteTxManager.java        |  6 +-
 .../processors/cache/tree/CacheDataRowStore.java   | 10 ++-
 .../cache/tree/mvcc/data/MvccUpdateDataRow.java    |  6 +-
 .../cluster/ClusterMetricsUpdateMessage.java       |  6 +-
 .../cluster/GridClusterStateProcessor.java         |  4 +-
 .../datastreamer/DataStreamerRequest.java          |  6 +-
 .../datastructures/DataStructuresProcessor.java    | 36 +++++++--
 .../GridCacheAtomicReferenceImpl.java              |  4 +-
 .../marshaller/MarshallerMappingTransport.java     |  5 +-
 .../processors/offheap/GridOffHeapProcessor.java   |  7 +-
 .../ignite/internal/processors/package-info.java   |  4 +-
 .../processors/platform/PlatformProcessorImpl.java |  6 +-
 .../platform/client/ClientConnectionContext.java   |  8 +-
 .../transactions/PlatformTransactions.java         |  6 +-
 .../processors/query/GridQueryProcessor.java       |  8 +-
 .../handlers/probe/GridProbeCommandHandler.java    |  6 +-
 .../GridInternalSubscriptionProcessor.java         |  3 +-
 .../GridTracingConfigurationManager.java           |  8 +-
 .../apache/ignite/internal/util/GridUnsafe.java    |  7 +-
 .../apache/ignite/internal/util/IgniteUtils.java   | 22 ++++--
 .../util/tostring/GridToStringBuilder.java         |  7 +-
 .../apache/ignite/internal/util/typedef/CIX1.java  |  7 +-
 .../apache/ignite/internal/util/typedef/CIX2.java  |  7 +-
 .../apache/ignite/internal/util/typedef/COX.java   |  7 +-
 .../apache/ignite/internal/util/typedef/CX1.java   |  7 +-
 .../apache/ignite/internal/util/typedef/CX2.java   |  7 +-
 .../apache/ignite/internal/util/typedef/PX1.java   |  7 +-
 .../apache/ignite/internal/util/typedef/PX2.java   |  7 +-
 .../apache/ignite/internal/util/typedef/R2.java    |  7 +-
 .../apache/ignite/internal/util/typedef/R3.java    |  7 +-
 .../apache/ignite/internal/util/typedef/RX1.java   |  7 +-
 .../apache/ignite/internal/util/typedef/RX2.java   |  7 +-
 .../apache/ignite/internal/util/typedef/RX3.java   |  7 +-
 .../ignite/internal/util/worker/GridWorker.java    |  4 +-
 ...VisorFindAndDeleteGarbageInPersistenceTask.java | 17 ++--
 .../visor/cache/index/IndexRebuildStatusTask.java  |  5 +-
 .../node/VisorCacheRebalanceCollectorTask.java     |  3 +-
 .../query/VisorRunningQueriesCollectorTask.java    |  4 +-
 .../VisorTracingConfigurationTask.java             |  3 +-
 .../ignite/internal/visor/util/VisorMimeTypes.java |  9 ++-
 .../ignite/mxbean/DataRegionMetricsMXBean.java     |  4 +-
 .../ignite/mxbean/DefragmentationMXBean.java       |  4 +-
 .../ignite/spi/checkpoint/CheckpointSpi.java       |  8 +-
 .../jobstealing/JobStealingCollisionSpi.java       |  4 +-
 .../spi/communication/tcp/TcpCommunicationSpi.java |  9 ++-
 .../tcp/internal/CommunicationWorker.java          |  4 +-
 .../tcp/internal/ConnectionClientPool.java         | 27 +++++--
 .../tcp/internal/GridNioServerWrapper.java         |  3 +-
 .../TcpCommunicationConfigInitializer.java         |  3 +-
 .../TcpCommunicationConnectionCheckFuture.java     |  3 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java       |  3 +-
 .../spi/discovery/tcp/TcpDiscoverySpiMBean.java    |  3 +-
 .../multicast/TcpDiscoveryMulticastIpFinder.java   |  4 +-
 .../apache/ignite/spi/failover/FailoverSpi.java    |  3 +-
 .../jobstealing/JobStealingFailoverSpi.java        |  6 +-
 .../view/datastructures/ReentrantLockView.java     |  3 +-
 .../view/datastructures/SemaphoreView.java         |  3 +-
 ...nerRWThroughDisabledTransactionalCacheTest.java |  3 +-
 ...CacheStoreSessionListenerLifecycleSelfTest.java |  5 +-
 ...hallerStoreKeepBinaryWithSqlEscapeSelfTest.java |  3 +-
 .../cache/store/jdbc/CacheJdbcPojoStoreTest.java   |  6 +-
 .../jdbc/JdbcTypesDefaultTransformerTest.java      |  7 +-
 .../TestJdbcPojoStoreFactoryWithHangWriteAll.java  |  7 +-
 .../internal/ClusterNodeMetricsSelfTest.java       |  5 +-
 .../internal/GridContinuousTaskSelfTest.java       |  6 +-
 .../internal/GridJobMasterLeaveAwareSelfTest.java  |  3 +-
 .../ignite/internal/IgniteClientFailuresTest.java  |  3 +-
 .../binary/BinaryClassLoaderMultiJvmTest.java      |  3 +-
 .../internal/binary/BinaryClassLoaderTest.java     |  3 +-
 .../BinaryObjectBuilderAdditionalSelfTest.java     | 11 ++-
 .../BinaryObjectBuilderDefaultMappersSelfTest.java |  3 +-
 .../inline/InlineIndexKeyTypeRegistryTest.java     | 12 ++-
 ...GridManagerMxBeanIllegalArgumentHandleTest.java |  4 +-
 .../managers/IgniteDiagnosticMessagesTest.java     |  5 +-
 .../IgniteCommunicationBalanceTest.java            |  3 +-
 .../P2PCacheOperationIntoComputeTest.java          |  5 +-
 .../wal/record/WALRecordSerializationTest.java     |  3 +-
 .../processors/cache/CacheMetricsManageTest.java   |  6 +-
 .../processors/cache/ClusterStateTestUtils.java    |  5 +-
 .../GridCacheConfigurationConsistencySelfTest.java |  3 +-
 .../cache/GridCachePartitionedWritesTest.java      |  4 +-
 .../IgniteCacheClusterReadOnlyModeSelfTest.java    |  6 +-
 .../cache/IgniteClientCacheStartFailoverTest.java  |  8 +-
 .../cache/IgniteDynamicCacheStartSelfTest.java     |  8 +-
 ...iteExchangeLatchManagerCoordinatorFailTest.java |  4 +-
 .../IgniteSemaphoreAbstractSelfTest.java           |  6 +-
 .../GridCachePartitionedNodeRestartTxSelfTest.java |  5 +-
 .../distributed/CacheBaselineTopologyTest.java     |  8 +-
 .../CacheClientsConcurrentStartTest.java           | 30 ++++---
 .../cache/distributed/CacheStartOnJoinTest.java    |  7 +-
 ...PartitionEvictionDuringReadThroughSelfTest.java |  7 +-
 ...ridExchangeFreeCellularSwitchIsolationTest.java |  3 +-
 .../IgniteCachePartitionLossPolicySelfTest.java    |  4 +-
 ...sabledAtomicOnheapMultiNodeFullApiSelfTest.java |  3 +-
 .../GridCachePartitionsStateValidationTest.java    | 25 ++++--
 .../GridCachePartitionsStateValidatorSelfTest.java |  3 +-
 .../dht/IgniteCacheStartWithLoadTest.java          |  7 +-
 .../dht/topology/BlockedEvictionsTest.java         |  7 +-
 ...MovingPartitionIsEvictedDuringClearingTest.java |  7 +-
 ...reloadingRestartWhileClearingPartitionTest.java |  7 +-
 .../GridCachePartitionedFilteredPutSelfTest.java   |  3 +-
 ...isabledAtomicOnheapMultiJvmFullApiSelfTest.java |  3 +-
 ...dNearDisabledOnheapMultiJvmFullApiSelfTest.java |  3 +-
 ...heMvccAbstractBasicCoordinatorFailoverTest.java |  5 +-
 .../cache/mvcc/CacheMvccTxFailoverTest.java        |  3 +-
 ...gnitePdsBinaryMetadataOnClusterRestartTest.java | 12 ++-
 .../persistence/MaintenanceRegistrySimpleTest.java | 14 +++-
 ...hangingBaselineDownCacheRemoveFailoverTest.java |  5 +-
 ...eChangingBaselineUpCacheRemoveFailoverTest.java |  5 +-
 ...gniteStableBaselineCacheRemoveFailoverTest.java |  5 +-
 .../persistence/db/IgniteLogicalRecoveryTest.java  |  7 +-
 .../db/IgnitePdsTransactionsHangTest.java          |  4 +-
 .../db/checkpoint/CheckpointFreeListTest.java      |  6 +-
 ...CheckpointSimulationWithRealCpDisabledTest.java |  7 +-
 .../db/file/IgnitePdsDiskErrorsRecoveringTest.java | 10 ++-
 .../db/wal/reader/IgniteWalReaderTest.java         |  6 +-
 .../persistence/pagemem/NoOpPageStoreManager.java  |  8 +-
 .../cache/persistence/pagemem/NoOpWALManager.java  |  5 +-
 .../persistence/pagemem/PageMemoryImplTest.java    |  8 +-
 .../pagemem/PagesWriteThrottleSandboxTest.java     |  3 +-
 .../snapshot/IgniteClusterSnapshotCheckTest.java   |  8 +-
 ...inActiveNodeToActiveClusterWithPersistence.java |  6 +-
 ...InActiveNodeToActiveClusterWithPersistence.java |  6 +-
 .../wal/SegmentedRingByteBufferTest.java           |  4 +-
 .../reader/StandaloneWalRecordsIteratorTest.java   |  5 +-
 ...cheContinuousQueryFailoverAbstractSelfTest.java |  9 ++-
 .../CacheContinuousQueryRandomOperationsTest.java  | 26 +++---
 ...CacheContinuousWithTransformerFailoverTest.java | 13 +--
 .../store/GridCacheWriteBehindStoreSelfTest.java   |  5 +-
 .../AbstractTransactionIntergrityTest.java         | 19 ++++-
 .../TxCrossCacheMapOnInvalidTopologyTest.java      |  5 +-
 .../cache/transactions/TxDeadlockCauseTest.java    | 11 ++-
 .../TxDeadlockOnEntryToStringTest.java             | 24 +++++-
 ...titionCounterStateOnePrimaryTwoBackupsTest.java |  3 +-
 ...titionCounterStateTwoPrimaryTwoBackupsTest.java |  5 +-
 .../warmup/LoadAllWarmUpStrategySelfTest.java      |  3 +-
 .../database/IgniteDbMemoryLeakAbstractTest.java   |  5 +-
 .../failure/FailureProcessorLoggingTest.java       |  4 +-
 ...ridServiceDeploymentCompoundFutureSelfTest.java |  3 +-
 .../ServiceDeploymentProcessIdSelfTest.java        |  6 +-
 .../internal/sql/SqlParserCreateIndexSelfTest.java | 68 +++++++++++++---
 .../internal/sql/SqlParserKillQuerySelfTest.java   |  6 +-
 .../util/IgniteUtilsWorkDirectoryTest.java         |  3 +-
 .../util/nio/impl/GridNioFilterChainSelfTest.java  | 14 +++-
 .../loadtests/colocation/GridTestCacheStore.java   |  3 +-
 .../ignite/loadtests/job/GridJobLoadTest.java      |  3 +-
 .../lang/GridConcurrentLinkedHashMapBenchmark.java | 11 ++-
 .../marshaller/MarshallerContextTestImpl.java      |  7 +-
 .../ignite/messaging/GridMessagingSelfTest.java    | 12 ++-
 ...2PContinuousDeploymentClientDisconnectTest.java |  9 ++-
 .../session/GridSessionWaitAttributeSelfTest.java  |  5 +-
 .../tcp/GridTcpCommunicationSpiLogTest.java        |  3 +-
 .../IgniteTcpCommunicationConnectOnInitTest.java   | 32 ++++++--
 .../tcp/TcpCommunicationStatisticsTest.java        |  7 +-
 .../spi/discovery/tcp/IgniteClientConnectTest.java |  8 +-
 .../tcp/TcpClientDiscoverySpiSelfTest.java         | 18 +++--
 .../tcp/TcpDiscoveryCoordinatorFailureTest.java    | 11 ++-
 .../tcp/TcpDiscoveryIpFinderFailureTest.java       |  6 +-
 .../tcp/TcpDiscoveryNodeJoinAndFailureTest.java    |  8 +-
 .../TcpDiscoveryPendingMessageDeliveryTest.java    |  3 +-
 .../tcp/TcpDiscoverySslParametersTest.java         |  7 +-
 .../vm/TcpDiscoveryVmIpFinderDnsResolveTest.java   | 15 ++--
 .../GridInternalTasksLoadBalancingSelfTest.java    |  3 +-
 .../ignite/spi/metric/jmx/DummyMBeanServer.java    |  7 +-
 .../startup/servlet/GridServletLoaderTest.java     |  3 +-
 .../testframework/junits/GridAbstractTest.java     |  6 +-
 .../testframework/wal/record/RecordUtils.java      |  3 +-
 .../testsuites/IgniteCacheMvccTestSuite2.java      |  3 +-
 .../testsuites/IgniteCacheMvccTestSuite6.java      |  6 +-
 .../development/utils/IgniteWalConverter.java      | 11 +--
 .../utils/IgniteWalConverterArguments.java         | 12 ++-
 .../development/utils/IgniteWalConverterTest.java  | 15 ++--
 .../cache/persistence/file/IgniteNativeIoLib.java  |  3 +-
 ...oteTransformerWithStaticInitializerFactory.java |  3 +-
 .../cache/hibernate/HibernateEntityRegion.java     |  9 ++-
 .../hibernate/IgniteCachedDomainDataAccess.java    | 15 +++-
 .../cache/hibernate/IgniteEntityDataAccess.java    |  9 ++-
 .../cache/hibernate/IgniteNaturalIdDataAccess.java |  7 +-
 .../HibernateL2CacheConfigurationSelfTest.java     | 10 ++-
 .../HibernateL2CacheStrategySelfTest.java          | 10 ++-
 .../processors/query/h2/IgniteH2Indexing.java      |  8 +-
 .../query/h2/database/H2PkHashIndex.java           |  9 ++-
 .../processors/query/h2/opt/GridH2ProxyIndex.java  |  9 ++-
 .../apache/ignite/client/FunctionalQueryTest.java  |  3 +-
 ...finityKeyNameAndValueFieldNameConflictTest.java |  3 +-
 .../cache/BinaryTypeMismatchLoggingTest.java       |  3 +-
 .../cache/CacheRegisterMetadataLocallyTest.java    |  4 +-
 ...eckIndexesInlineSizeOnNodeJoinMultiJvmTest.java | 13 ++-
 .../cache/GridCacheDynamicLoadOnClientTest.java    |  4 +-
 .../IgniteCacheAbstractFieldsQuerySelfTest.java    | 17 ++--
 ...teCacheConfigurationPrimitiveTypesSelfTest.java |  3 +-
 .../cache/IgniteDynamicSqlRestoreTest.java         |  3 +-
 .../QueryJoinWithDifferentNodeFiltersTest.java     |  4 +-
 .../processors/cache/index/BasicIndexTest.java     |  4 +-
 .../cache/index/H2RowExpireTimeIndexSelfTest.java  |  6 +-
 .../cache/index/QueryEntityValidationSelfTest.java |  6 +-
 ...acheMvccAbstractSqlCoordinatorFailoverTest.java |  4 +-
 .../mvcc/CacheMvccBasicContinuousQueryTest.java    |  9 ++-
 ...eMvccPartitionedSqlCoordinatorFailoverTest.java | 10 ++-
 .../CacheMvccSqlConfigurationValidationTest.java   |  7 +-
 .../mvcc/CacheMvccSqlQueriesAbstractTest.java      |  8 +-
 .../mvcc/CacheMvccSqlTxQueriesAbstractTest.java    |  5 +-
 .../db/LongDestroyDurableBackgroundTaskTest.java   |  3 +-
 .../RebuildIndexWithHistoricalRebalanceTest.java   |  5 +-
 ...ngingBaselineCacheQueryNodeRestartSelfTest.java |  5 +-
 ...ableBaselineCacheQueryNodeRestartsSelfTest.java |  5 +-
 .../query/IgniteSqlKeyValueFieldsTest.java         |  3 +-
 .../query/IgniteSqlSplitterSelfTest.java           | 19 +++--
 .../query/KillQueryOnClientDisconnectTest.java     | 11 ++-
 .../processors/query/SqlSystemViewsSelfTest.java   | 40 +++++++---
 .../inlinecolumn/InlineIndexColumnTest.java        | 92 +++++++++++++++++-----
 .../query/h2/sql/BaseH2CompareQueryTest.java       | 15 +++-
 .../query/h2/sql/H2CompareBigQueryTest.java        | 14 +++-
 .../DisappearedCacheCauseRetryMessageSelfTest.java |  5 +-
 .../h2/twostep/RetryCauseMessageSelfTest.java      |  9 ++-
 .../ml/sparkmodelparser/SparkModelParser.java      |  5 +-
 .../ml/sparkmodelparser/SparkModelParserTest.java  |  5 +-
 .../ignite/ml/clustering/kmeans/KMeansModel.java   |  6 +-
 .../ignite/ml/composition/ModelsComposition.java   |  4 +-
 .../ml/composition/bagging/BaggedTrainer.java      |  4 +-
 .../ml/dataset/impl/cache/CacheBasedDataset.java   |  3 +-
 .../impl/cache/CacheBasedDatasetBuilder.java       | 14 +++-
 .../ml/dataset/impl/local/LocalDatasetBuilder.java |  5 +-
 .../ignite/ml/knn/ann/ANNClassificationModel.java  |  6 +-
 .../ml/knn/ann/ANNClassificationTrainer.java       |  9 ++-
 .../preprocessing/IllegalFeatureTypeException.java |  3 +-
 .../preprocessing/IllegalLabelTypeException.java   |  3 +-
 .../ignite/ml/multiclass/MultiClassModel.java      |  3 +-
 .../ignite/ml/multiclass/OneVsRestTrainer.java     |  3 +-
 .../compound/CompoundNaiveBayesTrainer.java        | 12 ++-
 .../apache/ignite/ml/nn/MultilayerPerceptron.java  |  3 +-
 .../updatecalculators/SimpleGDParameterUpdate.java |  3 +-
 .../ml/preprocessing/encoding/EncoderTrainer.java  |  4 +-
 .../onehotencoder/OneHotEncoderPreprocessor.java   |  6 +-
 .../stringencoder/StringEncoderPreprocessor.java   |  3 +-
 .../preprocessing/imputing/ImputingStrategy.java   |  5 +-
 .../linear/LinearRegressionLSQRTrainer.java        |  3 +-
 .../linear/LinearRegressionSGDTrainer.java         |  3 +-
 .../logistic/LogisticRegressionSGDTrainer.java     |  3 +-
 .../ml/selection/cv/AbstractCrossValidation.java   |  3 +-
 ...assificationPointwiseMetricStatsAggregator.java |  3 +-
 .../ClassificationMetricsAggregator.java           |  3 +-
 .../RegressionMetricStatsAggregator.java           |  3 +-
 .../BinaryClassificationEvaluationContext.java     |  3 +-
 .../classification/BinaryClassificationMetric.java |  3 +-
 .../ml/svm/SVMLinearClassificationTrainer.java     |  3 +-
 .../ml/trainers/AdaptableDatasetTrainer.java       | 15 ++--
 .../apache/ignite/ml/trainers/DatasetTrainer.java  |  9 ++-
 .../java/org/apache/ignite/ml/tree/NodeData.java   |  8 +-
 .../ignite/ml/util/genetic/GeneticAlgorithm.java   |  3 +-
 .../test/java/org/apache/ignite/ml/TestUtils.java  |  6 +-
 .../ignite/ml/clustering/KMeansTrainerTest.java    |  3 +-
 .../apache/ignite/ml/common/LocalModelsTest.java   |  9 ++-
 .../ml/composition/boosting/GDBTrainerTest.java    |  3 +-
 .../primitive/SimpleLabeledDatasetTest.java        |  3 +-
 .../LearningEnvironmentBuilderTest.java            | 16 ++--
 .../ml/environment/LearningEnvironmentTest.java    | 11 ++-
 .../ml/environment/deploy/MLDeployingTest.java     |  4 +-
 .../ignite/ml/math/isolve/lsqr/LSQROnHeapTest.java |  9 ++-
 .../primitives/matrix/MatrixStorageFixtures.java   |  3 +-
 .../matrix/MatrixStorageImplementationTest.java    |  9 ++-
 .../math/primitives/vector/AbstractVectorTest.java | 25 +++++-
 .../ml/math/primitives/vector/VectorNormTest.java  |  3 +-
 .../ignite/ml/multiclass/OneVsRestTrainerTest.java |  3 +-
 .../gaussian/GaussianNaiveBayesTrainerTest.java    |  3 +-
 .../test/java/org/apache/ignite/ml/nn/MLPTest.java |  6 +-
 .../org/apache/ignite/ml/nn/MLPTrainerTest.java    | 12 ++-
 .../ignite/ml/nn/performance/MnistMLPTestUtil.java |  7 +-
 .../preprocessing/encoding/EncoderTrainerTest.java | 48 +++++++++--
 .../preprocessing/imputing/ImputerTrainerTest.java | 30 +++++--
 .../linear/LinearRegressionLSQRTrainerTest.java    |  3 +-
 .../logistic/LogisticRegressionSGDTrainerTest.java |  3 +-
 .../ml/selection/cv/CrossValidationTest.java       | 84 ++++++++++++--------
 .../cursor/CacheBasedLabelPairCursorTest.java      |  3 +-
 .../scoring/cursor/LocalLabelPairCursorTest.java   |  3 +-
 .../apache/ignite/ml/svm/SVMBinaryTrainerTest.java |  3 +-
 .../RandomForestClassifierTrainerTest.java         |  3 +-
 .../RandomForestRegressionTrainerTest.java         |  3 +-
 .../ml/util/genetic/GeneticAlgorithmTest.java      |  3 +-
 .../http/jetty/GridJettyObjectMapper.java          | 27 ++++---
 .../protocols/http/jetty/GridJettyRestHandler.java |  6 +-
 .../resource/GridResourceProcessorSelfTest.java    |  3 +-
 .../apache/ignite/spring/injection/spring-bean.xml |  3 +-
 .../tools/ant/beautifier/GridJavadocAntTask.java   |  3 +-
 .../spi/deployment/uri/UriDeploymentSpi.java       |  4 +-
 .../servlet/ServletContextListenerStartup.java     |  6 +-
 .../ignite/startup/servlet/ServletStartup.java     |  6 +-
 .../ignite/yardstick/IgniteBenchmarkArguments.java |  6 +-
 .../yardstick/cache/jdbc/RdbmsBenchmark.java       |  4 +-
 .../jdbc/NativeSqlJoinQueryRangeBenchmark.java     |  6 +-
 429 files changed, 2572 insertions(+), 975 deletions(-)

diff --git a/checkstyle/checkstyle-suppressions.xml b/checkstyle/checkstyle-suppressions.xml
index 250e0fa..20c9537 100644
--- a/checkstyle/checkstyle-suppressions.xml
+++ b/checkstyle/checkstyle-suppressions.xml
@@ -24,4 +24,6 @@
     <suppress checks="EmptyLineSeparator|MethodParamPad|SingleSpaceSeparator"
               files="BCrypt\.java|ConcurrentLinkedDeque8\.java"/>
     <suppress checks="NoWhitespaceBefore" files="ConcurrentLinkedHashMap\.java"/>
+    <suppress checks="LineLength"
+              files="ClusterTagGenerator\.java|PagesWriteSpeedBasedThrottle\.java|GridExecutorService\.java|CatboostClassificationModel\.java"/>
 </suppressions>
diff --git a/checkstyle/checkstyle.xml b/checkstyle/checkstyle.xml
index 3e674bd..87b156c 100644
--- a/checkstyle/checkstyle.xml
+++ b/checkstyle/checkstyle.xml
@@ -135,4 +135,12 @@
         -->
         <module name="GenericWhitespace"/>
     </module>
+
+    <!--
+        Checks that the line length not exceeds 140 chars.
+        See: https://checkstyle.org/config_sizes.html#LineLength
+    -->
+    <module name="LineLength">
+        <property name="max" value="140"/>
+    </module>
 </module>
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/clustering/KMeansClusterizationExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/clustering/KMeansClusterizationExample.java
index 3127418..b834529 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/clustering/KMeansClusterizationExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/clustering/KMeansClusterizationExample.java
@@ -62,7 +62,8 @@ public class KMeansClusterizationExample {
             try {
                 dataCache = new SandboxMLCache(ignite).fillCacheWith(MLSandboxDatasets.TWO_CLASSED_IRIS);
 
-                Vectorizer<Integer, Vector, Integer, Double> vectorizer = new DummyVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
+                Vectorizer<Integer, Vector, Integer, Double> vectorizer =
+                    new DummyVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
 
                 KMeansTrainer trainer = new KMeansTrainer();
 
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/dataset/AlgorithmSpecificDatasetExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/dataset/AlgorithmSpecificDatasetExample.java
index 731227f..85102f4 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/dataset/AlgorithmSpecificDatasetExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/dataset/AlgorithmSpecificDatasetExample.java
@@ -80,7 +80,8 @@ public class AlgorithmSpecificDatasetExample {
 
                 Vectorizer<Integer, Vector, Integer, Double> vectorizer = new DummyVectorizer<>(1);
 
-                IgniteFunction<LabeledVector<Double>, LabeledVector<double[]>> func = lv -> new LabeledVector<>(lv.features(), new double[] {lv.label()});
+                IgniteFunction<LabeledVector<Double>, LabeledVector<double[]>> func =
+                    lv -> new LabeledVector<>(lv.features(), new double[] {lv.label()});
 
                 //NOTE: This class is part of Developer API and all lambdas should be loaded on server manually.
                 Preprocessor<Integer, Vector> preprocessor = new PatchedPreprocessor<>(func, vectorizer);
@@ -89,18 +90,19 @@ public class AlgorithmSpecificDatasetExample {
                 SimpleLabeledDatasetDataBuilder<Integer, Vector, AlgorithmSpecificPartitionContext> builder =
                     new SimpleLabeledDatasetDataBuilder<>(preprocessor);
 
-                IgniteBiFunction<SimpleLabeledDatasetData, AlgorithmSpecificPartitionContext, SimpleLabeledDatasetData> builderFun = (data, ctx) -> {
-                    double[] features = data.getFeatures();
-                    int rows = data.getRows();
+                IgniteBiFunction<SimpleLabeledDatasetData, AlgorithmSpecificPartitionContext, SimpleLabeledDatasetData> builderFun =
+                    (data, ctx) -> {
+                        double[] features = data.getFeatures();
+                        int rows = data.getRows();
 
-                    // Makes a copy of features to supplement it by columns with values equal to 1.0.
-                    double[] a = new double[features.length + rows];
-                    Arrays.fill(a, 1.0);
+                        // Makes a copy of features to supplement it by columns with values equal to 1.0.
+                        double[] a = new double[features.length + rows];
+                        Arrays.fill(a, 1.0);
 
-                    System.arraycopy(features, 0, a, rows, features.length);
+                        System.arraycopy(features, 0, a, rows, features.length);
 
-                    return new SimpleLabeledDatasetData(a, data.getLabels(), rows);
-                };
+                        return new SimpleLabeledDatasetData(a, data.getLabels(), rows);
+                    };
 
                 try (AlgorithmSpecificDataset dataset = DatasetFactory.create(
                     ignite,
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/inference/catboost/CatboostClassificationModelParserExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/inference/catboost/CatboostClassificationModelParserExample.java
index e6f9f65..093469a 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/inference/catboost/CatboostClassificationModelParserExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/inference/catboost/CatboostClassificationModelParserExample.java
@@ -53,7 +53,8 @@ public class CatboostClassificationModelParserExample {
     /**
      * Test expected results.
      */
-    private static final String TEST_ER_RES = "examples/src/main/resources/datasets/amazon-employee-access-challenge-sample-catboost-expected-results.csv";
+    private static final String TEST_ER_RES =
+        "examples/src/main/resources/datasets/amazon-employee-access-challenge-sample-catboost-expected-results.csv";
 
     /**
      * Parser.
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/inference/exchange/KMeansClusterizationExportImportExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/inference/exchange/KMeansClusterizationExportImportExample.java
index ec5e689..f841a06 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/inference/exchange/KMeansClusterizationExportImportExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/inference/exchange/KMeansClusterizationExportImportExample.java
@@ -62,7 +62,8 @@ public class KMeansClusterizationExportImportExample {
             try {
                 dataCache = new SandboxMLCache(ignite).fillCacheWith(MLSandboxDatasets.TWO_CLASSED_IRIS);
 
-                Vectorizer<Integer, Vector, Integer, Double> vectorizer = new DummyVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
+                Vectorizer<Integer, Vector, Integer, Double> vectorizer =
+                    new DummyVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
 
                 KMeansTrainer trainer = new KMeansTrainer()
                     .withDistance(new WeightedMinkowskiDistance(2, new double[] {5.9360, 2.7700, 4.2600, 1.3260}));
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/DecisionTreeFromSparkExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/DecisionTreeFromSparkExample.java
index d03bb966..41717ba 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/DecisionTreeFromSparkExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/DecisionTreeFromSparkExample.java
@@ -50,15 +50,18 @@ public class DecisionTreeFromSparkExample {
         .toPath().toAbsolutePath().toString();
 
     /** Learning environment. */
-    public static final LearningEnvironment env = LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
-        .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
+    public static final LearningEnvironment env =
+        LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
+            .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
 
     /**
      * Run example.
      */
     public static void main(String[] args) throws FileNotFoundException {
         System.out.println();
-        System.out.println(">>> Decision Tree model loaded from Spark through serialization over partitioned dataset usage example started.");
+        System.out.println(
+            ">>> Decision Tree model loaded from Spark through serialization over partitioned dataset usage example started."
+        );
         // Start ignite grid.
         try (Ignite ignite = Ignition.start("examples/config/example-ignite.xml")) {
             System.out.println(">>> Ignite grid started.");
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/DecisionTreeRegressionFromSparkExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/DecisionTreeRegressionFromSparkExample.java
index 5fd4461..f0e95fdb 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/DecisionTreeRegressionFromSparkExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/DecisionTreeRegressionFromSparkExample.java
@@ -50,15 +50,18 @@ public class DecisionTreeRegressionFromSparkExample {
     public static final String SPARK_MDL_PATH = "examples/src/main/resources/models/spark/serialized/dtreg";
 
     /** Learning environment. */
-    public static final LearningEnvironment env = LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
-        .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
+    public static final LearningEnvironment env =
+        LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
+            .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
 
     /**
      * Run example.
      */
     public static void main(String[] args) throws FileNotFoundException {
         System.out.println();
-        System.out.println(">>> Decision tree regression model loaded from Spark through serialization over partitioned dataset usage example started.");
+        System.out.println(
+            ">>> Decision tree regression model loaded from Spark through serialization over partitioned dataset usage example started."
+        );
         // Start ignite grid.
         try (Ignite ignite = Ignition.start("examples/config/example-ignite.xml")) {
             System.out.println(">>> Ignite grid started.");
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/GBTFromSparkExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/GBTFromSparkExample.java
index 1fc72fa..4154f24 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/GBTFromSparkExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/GBTFromSparkExample.java
@@ -48,15 +48,18 @@ public class GBTFromSparkExample {
     public static final String SPARK_MDL_PATH = "examples/src/main/resources/models/spark/serialized/gbt";
 
     /** Learning environment. */
-    public static final LearningEnvironment env = LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
-        .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
+    public static final LearningEnvironment env =
+        LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
+            .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
 
     /**
      * Run example.
      */
     public static void main(String[] args) throws FileNotFoundException {
         System.out.println();
-        System.out.println(">>> Gradient Boosted trees model loaded from Spark through serialization over partitioned dataset usage example started.");
+        System.out.println(
+            ">>> Gradient Boosted trees model loaded from Spark through serialization over partitioned dataset usage example started."
+        );
         // Start ignite grid.
         try (Ignite ignite = Ignition.start("examples/config/example-ignite.xml")) {
             System.out.println(">>> Ignite grid started.");
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/GBTRegressionFromSparkExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/GBTRegressionFromSparkExample.java
index ee3e8bf..561ab9c 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/GBTRegressionFromSparkExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/GBTRegressionFromSparkExample.java
@@ -50,15 +50,18 @@ public class GBTRegressionFromSparkExample {
     public static final String SPARK_MDL_PATH = "examples/src/main/resources/models/spark/serialized/gbtreg";
 
     /** Learning environment. */
-    public static final LearningEnvironment env = LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
-        .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
+    public static final LearningEnvironment env =
+        LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
+            .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
 
     /**
      * Run example.
      */
     public static void main(String[] args) throws FileNotFoundException {
         System.out.println();
-        System.out.println(">>> GBT Regression model loaded from Spark through serialization over partitioned dataset usage example started.");
+        System.out.println(
+            ">>> GBT Regression model loaded from Spark through serialization over partitioned dataset usage example started."
+        );
         // Start ignite grid.
         try (Ignite ignite = Ignition.start("examples/config/example-ignite.xml")) {
             System.out.println(">>> Ignite grid started.");
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/KMeansFromSparkExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/KMeansFromSparkExample.java
index 3ac8b64..5aa6527 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/KMeansFromSparkExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/KMeansFromSparkExample.java
@@ -50,8 +50,9 @@ public class KMeansFromSparkExample {
     public static final String SPARK_MDL_PATH = "examples/src/main/resources/models/spark/serialized/kmeans";
 
     /** Learning environment. */
-    public static final LearningEnvironment env = LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
-        .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
+    public static final LearningEnvironment env =
+        LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
+            .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
 
     /**
      * Run example.
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/LinearRegressionFromSparkExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/LinearRegressionFromSparkExample.java
index b799d40..52842aa 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/LinearRegressionFromSparkExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/LinearRegressionFromSparkExample.java
@@ -50,15 +50,17 @@ public class LinearRegressionFromSparkExample {
     public static final String SPARK_MDL_PATH = "examples/src/main/resources/models/spark/serialized/linreg";
 
     /** Learning environment. */
-    public static final LearningEnvironment env = LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
-        .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
+    public static final LearningEnvironment env =
+        LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
+            .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
 
     /**
      * Run example.
      */
     public static void main(String[] args) throws FileNotFoundException {
         System.out.println();
-        System.out.println(">>> Linear regression model loaded from Spark through serialization over partitioned dataset usage example started.");
+        System.out.println(
+            ">>> Linear regression model loaded from Spark through serialization over partitioned dataset usage example started.");
         // Start ignite grid.
         try (Ignite ignite = Ignition.start("examples/config/example-ignite.xml")) {
             System.out.println(">>> Ignite grid started.");
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/LogRegFromSparkExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/LogRegFromSparkExample.java
index 4a4df17..725ac38 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/LogRegFromSparkExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/LogRegFromSparkExample.java
@@ -48,15 +48,18 @@ public class LogRegFromSparkExample {
     public static final String SPARK_MDL_PATH = "examples/src/main/resources/models/spark/serialized/logreg";
 
     /** Learning environment. */
-    public static final LearningEnvironment env = LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
-        .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
+    public static final LearningEnvironment env =
+        LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
+            .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
 
     /**
      * Run example.
      */
     public static void main(String[] args) throws FileNotFoundException {
         System.out.println();
-        System.out.println(">>> Logistic regression model loaded from Spark through serialization over partitioned dataset usage example started.");
+        System.out.println(
+            ">>> Logistic regression model loaded from Spark through serialization over partitioned dataset usage example started."
+        );
         // Start ignite grid.
         try (Ignite ignite = Ignition.start("examples/config/example-ignite.xml")) {
             System.out.println(">>> Ignite grid started.");
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/RandomForestFromSparkExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/RandomForestFromSparkExample.java
index 404ad840..641285d 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/RandomForestFromSparkExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/RandomForestFromSparkExample.java
@@ -48,15 +48,18 @@ public class RandomForestFromSparkExample {
     public static final String SPARK_MDL_PATH = "examples/src/main/resources/models/spark/serialized/rf";
 
     /** Learning environment. */
-    public static final LearningEnvironment env = LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
-        .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
+    public static final LearningEnvironment env =
+        LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
+            .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
 
     /**
      * Run example.
      */
     public static void main(String[] args) throws FileNotFoundException {
         System.out.println();
-        System.out.println(">>> Random Forest model loaded from Spark through serialization over partitioned dataset usage example started.");
+        System.out.println(
+            ">>> Random Forest model loaded from Spark through serialization over partitioned dataset usage example started."
+        );
         // Start ignite grid.
         try (Ignite ignite = Ignition.start("examples/config/example-ignite.xml")) {
             System.out.println(">>> Ignite grid started.");
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/RandomForestRegressionFromSparkExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/RandomForestRegressionFromSparkExample.java
index 5f535f1..c1b8bab 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/RandomForestRegressionFromSparkExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/RandomForestRegressionFromSparkExample.java
@@ -50,15 +50,18 @@ public class RandomForestRegressionFromSparkExample {
     public static final String SPARK_MDL_PATH = "examples/src/main/resources/models/spark/serialized/rfreg";
 
     /** Learning environment. */
-    public static final LearningEnvironment env = LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
-        .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
+    public static final LearningEnvironment env =
+        LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
+            .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
 
     /**
      * Run example.
      */
     public static void main(String[] args) throws FileNotFoundException {
         System.out.println();
-        System.out.println(">>> Random Forest regression model loaded from Spark through serialization over partitioned dataset usage example started.");
+        System.out.println(
+            ">>> Random Forest regression model loaded from Spark through serialization over partitioned dataset usage example started."
+        );
         // Start ignite grid.
         try (Ignite ignite = Ignition.start("examples/config/example-ignite.xml")) {
             System.out.println(">>> Ignite grid started.");
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/SVMFromSparkExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/SVMFromSparkExample.java
index d66e882..adcab7a 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/SVMFromSparkExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/inference/spark/modelparser/SVMFromSparkExample.java
@@ -48,8 +48,9 @@ public class SVMFromSparkExample {
     public static final String SPARK_MDL_PATH = "examples/src/main/resources/models/spark/serialized/svm";
 
     /** Learning environment. */
-    public static final LearningEnvironment env = LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
-        .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
+    public static final LearningEnvironment env =
+        LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
+            .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
 
     /**
      * Run example.
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/multiclass/OneVsRestClassificationExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/multiclass/OneVsRestClassificationExample.java
index dd5fecf..14b05c4 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/multiclass/OneVsRestClassificationExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/multiclass/OneVsRestClassificationExample.java
@@ -145,7 +145,12 @@ public class OneVsRestClassificationExample {
 
                         confusionMtxWithMinMaxScaling[idx1][idx2]++;
 
-                        System.out.printf(">>> | %.4f\t\t| %.4f\t\t\t\t\t\t| %.4f\t\t|\n", prediction, predictionWithMinMaxScaling, groundTruth);
+                        System.out.printf(
+                            ">>> | %.4f\t\t| %.4f\t\t\t\t\t\t| %.4f\t\t|\n",
+                            prediction,
+                            predictionWithMinMaxScaling,
+                            groundTruth
+                        );
                     }
                     System.out.println(">>> ----------------------------------------------------------------");
                     System.out.println("\n>>> -----------------One-vs-Rest SVM model-------------");
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/preprocessing/encoding/TargetEncoderExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/preprocessing/encoding/TargetEncoderExample.java
index e3864b6..82089ac 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/preprocessing/encoding/TargetEncoderExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/preprocessing/encoding/TargetEncoderExample.java
@@ -71,8 +71,8 @@ public class TargetEncoderExample {
                 Set<Integer> targetEncodedfeaturesIndexies = new HashSet<>(Arrays.asList(1, 5, 6));
                 Integer targetIndex = 0;
 
-                final Vectorizer<Integer, Object[], Integer, Object> vectorizer = new ObjectArrayVectorizer<Integer>(featuresIndexies.toArray(new Integer[0]))
-                    .labeled(targetIndex);
+                final Vectorizer<Integer, Object[], Integer, Object> vectorizer =
+                    new ObjectArrayVectorizer<Integer>(featuresIndexies.toArray(new Integer[0])).labeled(targetIndex);
 
                 Preprocessor<Integer, Object[]> strEncoderPreprocessor = new EncoderTrainer<Integer, Object[]>()
                     .withEncoderType(EncoderType.STRING_ENCODER)
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/regression/linear/BostonHousePricesPredictionExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/regression/linear/BostonHousePricesPredictionExample.java
index c572d81..9d2b316 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/regression/linear/BostonHousePricesPredictionExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/regression/linear/BostonHousePricesPredictionExample.java
@@ -42,7 +42,8 @@ import org.apache.ignite.ml.trainers.DatasetTrainer;
  * Description of model can be found in: https://en.wikipedia.org/wiki/Linear_regression . Original dataset can be
  * downloaded from: https://archive.ics.uci.edu/ml/machine-learning-databases/housing/ . Copy of dataset are stored in:
  * modules/ml/src/main/resources/datasets/boston_housing_dataset.txt . Score for regression estimation: R^2 (coefficient
- * of determination). Description of score evaluation can be found in: https://stattrek.com/statistics/dictionary.aspx?definition=coefficient_of_determination
+ * of determination). Description of score evaluation can be found in:
+ * https://stattrek.com/statistics/dictionary.aspx?definition=coefficient_of_determination
  * .
  */
 public class BostonHousePricesPredictionExample {
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/regression/linear/LinearRegressionLSQRTrainerWithMinMaxScalerExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/regression/linear/LinearRegressionLSQRTrainerWithMinMaxScalerExample.java
index 9979d3c..35dbdcd 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/regression/linear/LinearRegressionLSQRTrainerWithMinMaxScalerExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/regression/linear/LinearRegressionLSQRTrainerWithMinMaxScalerExample.java
@@ -92,7 +92,9 @@ public class LinearRegressionLSQRTrainerWithMinMaxScalerExample {
                 System.out.println("\n>>> Rmse = " + rmse);
 
                 System.out.println(">>> ---------------------------------");
-                System.out.println(">>> Linear regression model with MinMaxScaler preprocessor over cache based dataset usage example completed.");
+                System.out.println(
+                    ">>> Linear regression model with MinMaxScaler preprocessor over cache based dataset usage example completed."
+                );
             }
             finally {
                 if (dataCache != null)
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/sql/DecisionTreeClassificationTrainerSQLInferenceExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/sql/DecisionTreeClassificationTrainerSQLInferenceExample.java
index 68058b7..9847288 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/sql/DecisionTreeClassificationTrainerSQLInferenceExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/sql/DecisionTreeClassificationTrainerSQLInferenceExample.java
@@ -118,8 +118,8 @@ public class DecisionTreeClassificationTrainerSQLInferenceExample {
                 System.out.println("Inference...");
                 try (QueryCursor<List<?>> cursor = cache.query(new SqlFieldsQuery("select " +
                     "survived as truth, " +
-                    "predict('titanic_model_tree', pclass, age, sibsp, parch, fare, case sex when 'male' then 1 else 0 end) as prediction " +
-                    "from titanic_train"))) {
+                    "predict('titanic_model_tree', pclass, age, sibsp, parch, fare, case sex when 'male' then 1 else 0 end) as prediction" +
+                    " from titanic_train"))) {
                     // Print inference result.
                     System.out.println("| Truth | Prediction |");
                     System.out.println("|--------------------|");
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/tree/randomforest/RandomForestClassificationExample.java b/examples/src/main/java/org/apache/ignite/examples/ml/tree/randomforest/RandomForestClassificationExample.java
index 0d9dbef..07657c3 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/tree/randomforest/RandomForestClassificationExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/tree/randomforest/RandomForestClassificationExample.java
@@ -108,7 +108,9 @@ public class RandomForestClassificationExample {
 
                     System.out.println("\n>>> Absolute amount of errors " + amountOfErrors);
                     System.out.println("\n>>> Accuracy " + (1 - amountOfErrors / (double)totalAmount));
-                    System.out.println(">>> Random Forest multi-class classification algorithm over cached dataset usage example completed.");
+                    System.out.println(
+                        ">>> Random Forest multi-class classification algorithm over cached dataset usage example completed."
+                    );
                 }
 
             }
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_13_RandomSearch.java b/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_13_RandomSearch.java
index c489fc9..445a649 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_13_RandomSearch.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_13_RandomSearch.java
@@ -134,7 +134,11 @@ public class Step_13_RandomSearch {
                     )
                     .addHyperParam("p", normalizationTrainer::withP, new Double[] {1.0, 2.0, 3.0, 4.0, 5.0, 6.0, 7.0, 8.0, 9.0, 10.0})
                     .addHyperParam("maxDeep", trainerCV::withMaxDeep, new Double[] {1.0, 2.0, 3.0, 4.0, 5.0, 6.0, 7.0, 8.0, 9.0, 10.0})
-                    .addHyperParam("minImpurityDecrease", trainerCV::withMinImpurityDecrease, new Double[] {0.0, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 1.0});
+                    .addHyperParam(
+                        "minImpurityDecrease",
+                        trainerCV::withMinImpurityDecrease,
+                        new Double[] {0.0, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 1.0}
+                    );
 
                 scoreCalculator
                     .withIgnite(ignite)
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_14_Parallel_Brute_Force_Search.java b/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_14_Parallel_Brute_Force_Search.java
index b63bf96..0acfa8a 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_14_Parallel_Brute_Force_Search.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_14_Parallel_Brute_Force_Search.java
@@ -133,7 +133,11 @@ public class Step_14_Parallel_Brute_Force_Search {
                     .withParameterSearchStrategy(new BruteForceStrategy())
                     .addHyperParam("p", normalizationTrainer::withP, new Double[] {1.0, 2.0, 3.0, 4.0, 5.0, 6.0, 7.0, 8.0, 9.0, 10.0})
                     .addHyperParam("maxDeep", trainerCV::withMaxDeep, new Double[] {1.0, 2.0, 3.0, 4.0, 5.0, 6.0, 7.0, 8.0, 9.0, 10.0})
-                    .addHyperParam("minImpurityDecrease", trainerCV::withMinImpurityDecrease, new Double[] {0.0, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 1.0});
+                    .addHyperParam(
+                        "minImpurityDecrease",
+                        trainerCV::withMinImpurityDecrease,
+                        new Double[] {0.0, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 1.0}
+                    );
 
                 scoreCalculator
                     .withIgnite(ignite)
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_15_Parallel_Random_Search.java b/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_15_Parallel_Random_Search.java
index ac6c1eb..c500cbd 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_15_Parallel_Random_Search.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_15_Parallel_Random_Search.java
@@ -136,7 +136,11 @@ public class Step_15_Parallel_Random_Search {
                     )
                     .addHyperParam("p", normalizationTrainer::withP, new Double[] {1.0, 2.0, 3.0, 4.0, 5.0, 6.0, 7.0, 8.0, 9.0, 10.0})
                     .addHyperParam("maxDeep", trainerCV::withMaxDeep, new Double[] {1.0, 2.0, 3.0, 4.0, 5.0, 6.0, 7.0, 8.0, 9.0, 10.0})
-                    .addHyperParam("minImpurityDecrease", trainerCV::withMinImpurityDecrease, new Double[] {0.0, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 1.0});
+                    .addHyperParam(
+                        "minImpurityDecrease",
+                        trainerCV::withMinImpurityDecrease,
+                        new Double[] {0.0, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 1.0}
+                    );
 
                 scoreCalculator
                     .withIgnite(ignite)
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_16_Genetic_Programming_Search.java b/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_16_Genetic_Programming_Search.java
index 408eb48..9a78a8b 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_16_Genetic_Programming_Search.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_16_Genetic_Programming_Search.java
@@ -130,7 +130,11 @@ public class Step_16_Genetic_Programming_Search {
                     .withParameterSearchStrategy(new EvolutionOptimizationStrategy())
                     .addHyperParam("p", normalizationTrainer::withP, new Double[] {1.0, 2.0, 3.0, 4.0, 5.0, 6.0, 7.0, 8.0, 9.0, 10.0})
                     .addHyperParam("maxDeep", trainerCV::withMaxDeep, new Double[] {1.0, 2.0, 3.0, 4.0, 5.0, 6.0, 7.0, 8.0, 9.0, 10.0})
-                    .addHyperParam("minImpurityDecrease", trainerCV::withMinImpurityDecrease, new Double[] {0.0, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 1.0});
+                    .addHyperParam(
+                        "minImpurityDecrease",
+                        trainerCV::withMinImpurityDecrease,
+                        new Double[] {0.0, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 1.0}
+                    );
 
                 scoreCalculator
                     .withIgnite(ignite)
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_17_Parallel_Genetic_Programming_Search.java b/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_17_Parallel_Genetic_Programming_Search.java
index a9d39bd..eee4f8c 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_17_Parallel_Genetic_Programming_Search.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/tutorial/hyperparametertuning/Step_17_Parallel_Genetic_Programming_Search.java
@@ -133,7 +133,11 @@ public class Step_17_Parallel_Genetic_Programming_Search {
                     .withParameterSearchStrategy(new EvolutionOptimizationStrategy())
                     .addHyperParam("p", normalizationTrainer::withP, new Double[] {1.0, 2.0, 3.0, 4.0, 5.0, 6.0, 7.0, 8.0, 9.0, 10.0})
                     .addHyperParam("maxDeep", trainerCV::withMaxDeep, new Double[] {1.0, 2.0, 3.0, 4.0, 5.0, 6.0, 7.0, 8.0, 9.0, 10.0})
-                    .addHyperParam("minImpurityDecrease", trainerCV::withMinImpurityDecrease, new Double[] {0.0, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 1.0});
+                    .addHyperParam(
+                        "minImpurityDecrease",
+                        trainerCV::withMinImpurityDecrease,
+                        new Double[] {0.0, 0.1, 0.2, 0.3, 0.4, 0.5, 0.6, 0.7, 0.8, 0.9, 1.0}
+                    );
 
                 scoreCalculator
                     .withIgnite(ignite)
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/util/MLSandboxDatasets.java b/examples/src/main/java/org/apache/ignite/examples/ml/util/MLSandboxDatasets.java
index 9f70659..74704ff 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/util/MLSandboxDatasets.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/util/MLSandboxDatasets.java
@@ -52,7 +52,10 @@ public enum MLSandboxDatasets {
     /** The Wine recognition data. Could be found <a href="https://archive.ics.uci.edu/ml/machine-learning-databases/wine/">here</a>. */
     WINE_RECOGNITION("examples/src/main/resources/datasets/wine.txt", false, ","),
 
-    /** The Boston house-prices dataset. Could be found <a href="https://archive.ics.uci.edu/ml/machine-learning-databases/housing/">here</a>. */
+    /**
+     * The Boston house-prices dataset.
+     * Could be found <a href="https://archive.ics.uci.edu/ml/machine-learning-databases/housing/">here</a>.
+     */
     BOSTON_HOUSE_PRICES("examples/src/main/resources/datasets/boston_housing_dataset.txt", false, ","),
 
     /** Example from book Barber D. Bayesian reasoning and machine learning. Chapter 10. */
@@ -61,7 +64,9 @@ public enum MLSandboxDatasets {
     /** Wholesale customers dataset. Could be found <a href="https://archive.ics.uci.edu/ml/datasets/Wholesale+customers">here</a>. */
     WHOLESALE_CUSTOMERS("examples/src/main/resources/datasets/wholesale_customers.csv", true, ","),
 
-    /** Fraud detection problem [part of whole dataset]. Could be found <a href="https://www.kaggle.com/mlg-ulb/creditcardfraud/">here</a>. */
+    /**
+     * Fraud detection problem [part of whole dataset]. Could be found <a href="https://www.kaggle.com/mlg-ulb/creditcardfraud/">here</a>.
+     */
     FRAUD_DETECTION("examples/src/main/resources/datasets/fraud_detection.csv", false, ","),
 
     /** A dataset with discrete and continuous features. */
diff --git a/examples/src/main/spark/org/apache/ignite/examples/spark/JavaIgniteDataFrameJoinExample.java b/examples/src/main/spark/org/apache/ignite/examples/spark/JavaIgniteDataFrameJoinExample.java
index f077e1a..b0a4db6 100644
--- a/examples/src/main/spark/org/apache/ignite/examples/spark/JavaIgniteDataFrameJoinExample.java
+++ b/examples/src/main/spark/org/apache/ignite/examples/spark/JavaIgniteDataFrameJoinExample.java
@@ -120,7 +120,9 @@ public class JavaIgniteDataFrameJoinExample {
         cities.createOrReplaceTempView("city");
 
         // Selecting data from Ignite through Spark SQL Engine.
-        Dataset<Row> joinResult = spark.sql("SELECT person.name AS person, age, city.name AS city, country FROM person JOIN city ON person.city_id = city.id");
+        Dataset<Row> joinResult = spark.sql(
+            "SELECT person.name AS person, age, city.name AS city, country FROM person JOIN city ON person.city_id = city.id"
+        );
 
         joinResult.explain(true);
         joinResult.printSchema();
diff --git a/idea/ignite_codeStyle.xml b/idea/ignite_codeStyle.xml
index 5cbce88..8004e25 100644
--- a/idea/ignite_codeStyle.xml
+++ b/idea/ignite_codeStyle.xml
@@ -13,6 +13,7 @@
       <option name="USE_RELATIVE_INDENTS" value="false" />
     </value>
   </option>
+  <option name="RIGHT_MARGIN" value="120" />
   <option name="PREFER_LONGER_NAMES" value="false" />
   <option name="CLASS_COUNT_TO_USE_IMPORT_ON_DEMAND" value="1000" />
   <option name="NAMES_COUNT_TO_USE_IMPORT_ON_DEMAND" value="1000" />
diff --git a/modules/aop/src/main/java/org/apache/ignite/compute/gridify/aop/aspectj/GridifySetToSetAspectJAspect.java b/modules/aop/src/main/java/org/apache/ignite/compute/gridify/aop/aspectj/GridifySetToSetAspectJAspect.java
index 8c071e4..1ae43bb 100644
--- a/modules/aop/src/main/java/org/apache/ignite/compute/gridify/aop/aspectj/GridifySetToSetAspectJAspect.java
+++ b/modules/aop/src/main/java/org/apache/ignite/compute/gridify/aop/aspectj/GridifySetToSetAspectJAspect.java
@@ -57,7 +57,8 @@ public class GridifySetToSetAspectJAspect extends GridifySetToSetAbstractAspect
      * @throws Throwable If execution failed.
      */
     @SuppressWarnings({"ProhibitedExceptionDeclared", "ProhibitedExceptionThrown"})
-    @Around("execution(@org.apache.ignite.compute.gridify.GridifySetToSet * *(..)) && !cflow(call(* org.apache.ignite.compute.ComputeJob.*(..)))")
+    @Around("execution(@org.apache.ignite.compute.gridify.GridifySetToSet * *(..)) && " +
+        "!cflow(call(* org.apache.ignite.compute.ComputeJob.*(..)))")
     public Object gridify(ProceedingJoinPoint joinPnt) throws Throwable {
         Method mtd = ((MethodSignature) joinPnt.getSignature()).getMethod();
 
diff --git a/modules/aop/src/main/java/org/apache/ignite/compute/gridify/aop/aspectj/GridifySetToValueAspectJAspect.java b/modules/aop/src/main/java/org/apache/ignite/compute/gridify/aop/aspectj/GridifySetToValueAspectJAspect.java
index af90bc3..8848e68 100644
--- a/modules/aop/src/main/java/org/apache/ignite/compute/gridify/aop/aspectj/GridifySetToValueAspectJAspect.java
+++ b/modules/aop/src/main/java/org/apache/ignite/compute/gridify/aop/aspectj/GridifySetToValueAspectJAspect.java
@@ -57,7 +57,8 @@ public class GridifySetToValueAspectJAspect extends GridifySetToValueAbstractAsp
      * @throws Throwable If execution failed.
      */
     @SuppressWarnings({"ProhibitedExceptionDeclared", "ProhibitedExceptionThrown"})
-    @Around("execution(@org.apache.ignite.compute.gridify.GridifySetToValue * *(..)) && !cflow(call(* org.apache.ignite.compute.ComputeJob.*(..)))")
+    @Around("execution(@org.apache.ignite.compute.gridify.GridifySetToValue * *(..)) && " +
+        "!cflow(call(* org.apache.ignite.compute.ComputeJob.*(..)))")
     public Object gridify(ProceedingJoinPoint joinPnt) throws Throwable {
         Method mtd = ((MethodSignature) joinPnt.getSignature()).getMethod();
 
diff --git a/modules/aop/src/main/java/org/apache/ignite/compute/gridify/aop/spring/GridifySpringEnhancer.java b/modules/aop/src/main/java/org/apache/ignite/compute/gridify/aop/spring/GridifySpringEnhancer.java
index ab7daad..c174683 100644
--- a/modules/aop/src/main/java/org/apache/ignite/compute/gridify/aop/spring/GridifySpringEnhancer.java
+++ b/modules/aop/src/main/java/org/apache/ignite/compute/gridify/aop/spring/GridifySpringEnhancer.java
@@ -22,7 +22,8 @@ import org.springframework.aop.support.DefaultPointcutAdvisor;
 
 /**
  * Spring AOP enhancer. Use it to grid-enable methods annotated with
- * {@link org.apache.ignite.compute.gridify.Gridify}, {@link org.apache.ignite.compute.gridify.GridifySetToValue} and {@link org.apache.ignite.compute.gridify.GridifySetToSet} annotations.
+ * {@link org.apache.ignite.compute.gridify.Gridify}, {@link org.apache.ignite.compute.gridify.GridifySetToValue} and
+ * {@link org.apache.ignite.compute.gridify.GridifySetToSet} annotations.
  * <p>
  * Note, that Spring AOP requires that all grid-enabled methods must
  * be {@code enhanced} because it is proxy-based. Other AOP implementations,
diff --git a/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/misc/GridDhtPartitionsStateValidatorBenchmark.java b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/misc/GridDhtPartitionsStateValidatorBenchmark.java
index 38cd4aa..935bda9 100644
--- a/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/misc/GridDhtPartitionsStateValidatorBenchmark.java
+++ b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/misc/GridDhtPartitionsStateValidatorBenchmark.java
@@ -90,7 +90,10 @@ public class GridDhtPartitionsStateValidatorBenchmark extends JmhAbstractBenchma
          * @param sizesMap Sizes map.
          * @return Message with specified {@code countersMap} and {@code sizeMap}.
          */
-        private GridDhtPartitionsSingleMessage from(@Nullable Map<Integer, T2<Long, Long>> countersMap, @Nullable Map<Integer, Long> sizesMap) {
+        private GridDhtPartitionsSingleMessage from(
+            @Nullable Map<Integer, T2<Long, Long>> countersMap,
+            @Nullable Map<Integer, Long> sizesMap
+        ) {
             GridDhtPartitionsSingleMessage msg = new GridDhtPartitionsSingleMessage();
             if (countersMap != null)
                 msg.addPartitionUpdateCounters(0, countersMap);
diff --git a/modules/cassandra/store/src/main/java/org/apache/ignite/cache/store/cassandra/CassandraCacheStoreFactory.java b/modules/cassandra/store/src/main/java/org/apache/ignite/cache/store/cassandra/CassandraCacheStoreFactory.java
index 3f5b59e..d170949 100644
--- a/modules/cassandra/store/src/main/java/org/apache/ignite/cache/store/cassandra/CassandraCacheStoreFactory.java
+++ b/modules/cassandra/store/src/main/java/org/apache/ignite/cache/store/cassandra/CassandraCacheStoreFactory.java
@@ -192,7 +192,10 @@ public class CassandraCacheStoreFactory<K, V> implements Factory<CassandraCacheS
             return spring.loadBeanFromAppContext(appCtx, beanName);
         }
         catch (Exception e) {
-            throw new IgniteException("Failed to load bean in application context [beanName=" + beanName + ", igniteConfig=" + appCtx + ']', e);
+            throw new IgniteException(
+                "Failed to load bean in application context [beanName=" + beanName + ", igniteConfig=" + appCtx + ']',
+                e
+            );
         }
     }
 }
diff --git a/modules/cassandra/store/src/main/java/org/apache/ignite/cache/store/cassandra/persistence/KeyValuePersistenceSettings.java b/modules/cassandra/store/src/main/java/org/apache/ignite/cache/store/cassandra/persistence/KeyValuePersistenceSettings.java
index be25ab8..f865674 100644
--- a/modules/cassandra/store/src/main/java/org/apache/ignite/cache/store/cassandra/persistence/KeyValuePersistenceSettings.java
+++ b/modules/cassandra/store/src/main/java/org/apache/ignite/cache/store/cassandra/persistence/KeyValuePersistenceSettings.java
@@ -84,7 +84,10 @@ public class KeyValuePersistenceSettings implements Serializable {
     /** Xml element specifying Ignite cache value persistence settings. */
     private static final String VALUE_PERSISTENCE_NODE = "valuePersistence";
 
-    /** TTL (time to leave) for rows inserted into Cassandra table {@link <a href="https://docs.datastax.com/en/cql/3.1/cql/cql_using/use_expire_c.html">Expiring data</a>}. */
+    /**
+     * TTL (time to leave) for rows inserted into Cassandra table
+     * {@link <a href="https://docs.datastax.com/en/cql/3.1/cql/cql_using/use_expire_c.html">Expiring data</a>}.
+     */
     private Integer ttl;
 
     /** Cassandra keyspace (analog of tablespace in relational databases). */
@@ -93,10 +96,16 @@ public class KeyValuePersistenceSettings implements Serializable {
     /** Cassandra table. */
     private String tbl;
 
-    /** Cassandra table creation options {@link <a href="https://docs.datastax.com/en/cql/3.0/cql/cql_reference/create_table_r.html">CREATE TABLE</a>}. */
+    /**
+     * Cassandra table creation options
+     * {@link <a href="https://docs.datastax.com/en/cql/3.0/cql/cql_reference/create_table_r.html">CREATE TABLE</a>}.
+     */
     private String tblOptions;
 
-    /** Cassandra keyspace creation options {@link <a href="https://docs.datastax.com/en/cql/3.0/cql/cql_reference/create_keyspace_r.html">CREATE KEYSPACE</a>}. */
+    /**
+     * Cassandra keyspace creation options
+     * {@link <a href="https://docs.datastax.com/en/cql/3.0/cql/cql_reference/create_keyspace_r.html">CREATE KEYSPACE</a>}.
+     */
     private String keyspaceOptions = DFLT_KEYSPACE_OPTIONS;
 
     /** Persistence settings for Ignite cache keys. */
diff --git a/modules/cassandra/store/src/test/java/org/apache/ignite/tests/IgnitePersistentStoreTest.java b/modules/cassandra/store/src/test/java/org/apache/ignite/tests/IgnitePersistentStoreTest.java
index b18356c..727fec9 100644
--- a/modules/cassandra/store/src/test/java/org/apache/ignite/tests/IgnitePersistentStoreTest.java
+++ b/modules/cassandra/store/src/test/java/org/apache/ignite/tests/IgnitePersistentStoreTest.java
@@ -442,8 +442,10 @@ public class IgnitePersistentStoreTest {
         Map<SimplePersonId, SimplePerson> personMap6 = TestsHelper.generateSimplePersonIdsPersonsMap();
 
         try (Ignite ignite = Ignition.start("org/apache/ignite/tests/persistence/pojo/ignite-config.xml")) {
-            IgniteCache<SimplePersonId, SimplePerson> personCache5 = ignite.getOrCreateCache(new CacheConfiguration<SimplePersonId, SimplePerson>("cache5"));
-            IgniteCache<SimplePersonId, SimplePerson> personCache6 = ignite.getOrCreateCache(new CacheConfiguration<SimplePersonId, SimplePerson>("cache6"));
+            IgniteCache<SimplePersonId, SimplePerson> personCache5 =
+                ignite.getOrCreateCache(new CacheConfiguration<SimplePersonId, SimplePerson>("cache5"));
+            IgniteCache<SimplePersonId, SimplePerson> personCache6 =
+                ignite.getOrCreateCache(new CacheConfiguration<SimplePersonId, SimplePerson>("cache6"));
 
             LOGGER.info("Running single operation write tests");
 
@@ -466,8 +468,10 @@ public class IgnitePersistentStoreTest {
         try (Ignite ignite = Ignition.start("org/apache/ignite/tests/persistence/pojo/ignite-config.xml")) {
             LOGGER.info("Running POJO strategy read tests for simple objects");
 
-            IgniteCache<SimplePersonId, SimplePerson> personCache5 = ignite.getOrCreateCache(new CacheConfiguration<SimplePersonId, SimplePerson>("cache5"));
-            IgniteCache<SimplePersonId, SimplePerson> personCache6 = ignite.getOrCreateCache(new CacheConfiguration<SimplePersonId, SimplePerson>("cache6"));
+            IgniteCache<SimplePersonId, SimplePerson> personCache5 =
+                ignite.getOrCreateCache(new CacheConfiguration<SimplePersonId, SimplePerson>("cache5"));
+            IgniteCache<SimplePersonId, SimplePerson> personCache6 =
+                ignite.getOrCreateCache(new CacheConfiguration<SimplePersonId, SimplePerson>("cache6"));
 
             LOGGER.info("Running single operation read tests");
 
diff --git a/modules/cassandra/store/src/test/java/org/apache/ignite/tests/utils/CassandraHelper.java b/modules/cassandra/store/src/test/java/org/apache/ignite/tests/utils/CassandraHelper.java
index 34be344..8a9934a 100644
--- a/modules/cassandra/store/src/test/java/org/apache/ignite/tests/utils/CassandraHelper.java
+++ b/modules/cassandra/store/src/test/java/org/apache/ignite/tests/utils/CassandraHelper.java
@@ -56,7 +56,8 @@ public class CassandraHelper {
     private static final String EMBEDDED_CASSANDRA_YAML = "org/apache/ignite/tests/cassandra/embedded-cassandra.yaml";
 
     /** */
-    private static final ApplicationContext connectionContext = new ClassPathXmlApplicationContext("org/apache/ignite/tests/cassandra/connection-settings.xml");
+    private static final ApplicationContext connectionContext =
+        new ClassPathXmlApplicationContext("org/apache/ignite/tests/cassandra/connection-settings.xml");
 
     /** */
     private static DataSource adminDataSrc;
diff --git a/modules/cassandra/store/src/test/resources/org/apache/ignite/tests/persistence/blob/ignite-config.xml b/modules/cassandra/store/src/test/resources/org/apache/ignite/tests/persistence/blob/ignite-config.xml
index db360d5..cde4bec 100644
--- a/modules/cassandra/store/src/test/resources/org/apache/ignite/tests/persistence/blob/ignite-config.xml
+++ b/modules/cassandra/store/src/test/resources/org/apache/ignite/tests/persistence/blob/ignite-config.xml
@@ -28,12 +28,14 @@
 
     <!-- Persistence settings for 'cache1' -->
     <bean id="cache1_persistence_settings" class="org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings">
-        <constructor-arg type="org.springframework.core.io.Resource" value="classpath:org/apache/ignite/tests/persistence/blob/persistence-settings-1.xml" />
+        <constructor-arg type="org.springframework.core.io.Resource"
+                         value="classpath:org/apache/ignite/tests/persistence/blob/persistence-settings-1.xml" />
     </bean>
 
     <!-- Persistence settings for 'cache2' -->
     <bean id="cache2_persistence_settings" class="org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings">
-        <constructor-arg type="org.springframework.core.io.Resource" value="classpath:org/apache/ignite/tests/persistence/blob/persistence-settings-3.xml" />
+        <constructor-arg type="org.springframework.core.io.Resource"
+                         value="classpath:org/apache/ignite/tests/persistence/blob/persistence-settings-3.xml" />
     </bean>
 
     <!-- Ignite configuration -->
diff --git a/modules/cassandra/store/src/test/resources/org/apache/ignite/tests/persistence/pojo/ignite-config.xml b/modules/cassandra/store/src/test/resources/org/apache/ignite/tests/persistence/pojo/ignite-config.xml
index 75041fd..4105b3d 100644
--- a/modules/cassandra/store/src/test/resources/org/apache/ignite/tests/persistence/pojo/ignite-config.xml
+++ b/modules/cassandra/store/src/test/resources/org/apache/ignite/tests/persistence/pojo/ignite-config.xml
@@ -28,37 +28,44 @@
 
     <!-- Persistence settings for 'cache1' -->
     <bean id="cache1_persistence_settings" class="org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings">
-        <constructor-arg type="org.springframework.core.io.Resource" value="classpath:org/apache/ignite/tests/persistence/pojo/persistence-settings-1.xml" />
+        <constructor-arg type="org.springframework.core.io.Resource"
+                         value="classpath:org/apache/ignite/tests/persistence/pojo/persistence-settings-1.xml" />
     </bean>
 
     <!-- Persistence settings for 'cache2' -->
     <bean id="cache2_persistence_settings" class="org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings">
-        <constructor-arg type="org.springframework.core.io.Resource" value="classpath:org/apache/ignite/tests/persistence/pojo/persistence-settings-2.xml" />
+        <constructor-arg type="org.springframework.core.io.Resource"
+                         value="classpath:org/apache/ignite/tests/persistence/pojo/persistence-settings-2.xml" />
     </bean>
 
     <!-- Persistence settings for 'cache3' -->
     <bean id="cache3_persistence_settings" class="org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings">
-        <constructor-arg type="org.springframework.core.io.Resource" value="classpath:org/apache/ignite/tests/persistence/pojo/persistence-settings-3.xml" />
+        <constructor-arg type="org.springframework.core.io.Resource"
+                         value="classpath:org/apache/ignite/tests/persistence/pojo/persistence-settings-3.xml" />
     </bean>
 
     <!-- Persistence settings for 'cache4' -->
     <bean id="cache4_persistence_settings" class="org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings">
-        <constructor-arg type="org.springframework.core.io.Resource" value="classpath:org/apache/ignite/tests/persistence/pojo/persistence-settings-4.xml" />
+        <constructor-arg type="org.springframework.core.io.Resource"
+                         value="classpath:org/apache/ignite/tests/persistence/pojo/persistence-settings-4.xml" />
     </bean>
 
     <!-- Persistence settings for 'cache5' -->
     <bean id="cache5_persistence_settings" class="org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings">
-        <constructor-arg type="org.springframework.core.io.Resource" value="classpath:org/apache/ignite/tests/persistence/pojo/persistence-settings-5.xml" />
+        <constructor-arg type="org.springframework.core.io.Resource"
+                         value="classpath:org/apache/ignite/tests/persistence/pojo/persistence-settings-5.xml" />
     </bean>
 
     <!-- Persistence settings for 'cache6' -->
     <bean id="cache6_persistence_settings" class="org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings">
-        <constructor-arg type="org.springframework.core.io.Resource" value="classpath:org/apache/ignite/tests/persistence/pojo/persistence-settings-6.xml" />
+        <constructor-arg type="org.springframework.core.io.Resource"
+                         value="classpath:org/apache/ignite/tests/persistence/pojo/persistence-settings-6.xml" />
     </bean>
 
     <!-- Persistence settings for 'product' -->
     <bean id="product_persistence_settings" class="org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings">
-        <constructor-arg type="org.springframework.core.io.Resource" value="classpath:org/apache/ignite/tests/persistence/pojo/product.xml" />
+        <constructor-arg type="org.springframework.core.io.Resource"
+                         value="classpath:org/apache/ignite/tests/persistence/pojo/product.xml" />
     </bean>
 
     <!-- Persistence settings for 'order' -->
diff --git a/modules/cassandra/store/src/test/resources/org/apache/ignite/tests/persistence/primitive/ignite-config.xml b/modules/cassandra/store/src/test/resources/org/apache/ignite/tests/persistence/primitive/ignite-config.xml
index a7d101d..99091fa 100644
--- a/modules/cassandra/store/src/test/resources/org/apache/ignite/tests/persistence/primitive/ignite-config.xml
+++ b/modules/cassandra/store/src/test/resources/org/apache/ignite/tests/persistence/primitive/ignite-config.xml
@@ -28,12 +28,14 @@
 
     <!-- Persistence settings for 'cache1' -->
     <bean id="cache1_persistence_settings" class="org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings">
-        <constructor-arg type="org.springframework.core.io.Resource" value="classpath:org/apache/ignite/tests/persistence/primitive/persistence-settings-1.xml" />
+        <constructor-arg type="org.springframework.core.io.Resource"
+                         value="classpath:org/apache/ignite/tests/persistence/primitive/persistence-settings-1.xml" />
     </bean>
 
     <!-- Persistence settings for 'cache2' -->
     <bean id="cache2_persistence_settings" class="org.apache.ignite.cache.store.cassandra.persistence.KeyValuePersistenceSettings">
-        <constructor-arg type="org.springframework.core.io.Resource" value="classpath:org/apache/ignite/tests/persistence/primitive/persistence-settings-2.xml" />
+        <constructor-arg type="org.springframework.core.io.Resource"
+                         value="classpath:org/apache/ignite/tests/persistence/primitive/persistence-settings-2.xml" />
     </bean>
 
     <!-- Ignite configuration -->
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/client/ClientReconnectionSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/client/ClientReconnectionSelfTest.java
index 26496ea..f4ed797 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/client/ClientReconnectionSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/client/ClientReconnectionSelfTest.java
@@ -27,6 +27,9 @@ import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
 import org.junit.Ignore;
 import org.junit.Test;
 
+import static org.apache.ignite.internal.client.ClientTestRestServer.FIRST_SERVER_PORT;
+import static org.apache.ignite.internal.client.ClientTestRestServer.SERVERS_CNT;
+
 /**
  *
  */
@@ -35,7 +38,7 @@ public class ClientReconnectionSelfTest extends GridCommonAbstractTest {
     public static final String HOST = "127.0.0.1";
 
     /** */
-    private ClientTestRestServer[] srvs = new ClientTestRestServer[ClientTestRestServer.SERVERS_CNT];
+    private ClientTestRestServer[] srvs = new ClientTestRestServer[SERVERS_CNT];
 
     /** {@inheritDoc} */
     @Override protected void afterTest() throws Exception {
@@ -71,7 +74,7 @@ public class ClientReconnectionSelfTest extends GridCommonAbstractTest {
 
         Collection<String> addrs = new ArrayList<>();
 
-        for (int port = ClientTestRestServer.FIRST_SERVER_PORT; port < ClientTestRestServer.FIRST_SERVER_PORT + ClientTestRestServer.SERVERS_CNT; port++)
+        for (int port = FIRST_SERVER_PORT; port < FIRST_SERVER_PORT + SERVERS_CNT; port++)
             addrs.add(host + ":" + port);
 
         cfg.setServers(addrs);
@@ -86,14 +89,14 @@ public class ClientReconnectionSelfTest extends GridCommonAbstractTest {
      */
     @Test
     public void testNoFailedReconnection() throws Exception {
-        for (int i = 0; i < ClientTestRestServer.SERVERS_CNT; i++)
+        for (int i = 0; i < SERVERS_CNT; i++)
             runServer(i, false);
 
         try (GridClient client = client()) { // Here client opens initial connection and fetches topology.
             // Only first server in list should be contacted.
             assertEquals(1, srvs[0].getConnectCount());
 
-            for (int i = 1; i < ClientTestRestServer.SERVERS_CNT; i++)
+            for (int i = 1; i < SERVERS_CNT; i++)
                 assertEquals(0, srvs[i].getConnectCount());
 
             srvs[0].resetCounters();
@@ -119,7 +122,7 @@ public class ClientReconnectionSelfTest extends GridCommonAbstractTest {
                 // Check which servers where contacted,
                 int connects = 0;
 
-                for (int srv = 0; srv < ClientTestRestServer.SERVERS_CNT; srv++) {
+                for (int srv = 0; srv < SERVERS_CNT; srv++) {
                     if (srvs[srv].getSuccessfulConnectCount() > 0) {
                         assertTrue("Failed server was contacted: " + srv, srv != failed);
 
@@ -144,7 +147,7 @@ public class ClientReconnectionSelfTest extends GridCommonAbstractTest {
      */
     @Test
     public void testCorrectInit() throws Exception {
-        for (int i = 0; i < ClientTestRestServer.SERVERS_CNT; i++)
+        for (int i = 0; i < SERVERS_CNT; i++)
             runServer(i, i == 0);
 
         try (GridClient ignored = client()) { // Here client opens initial connection and fetches topology.
@@ -152,7 +155,7 @@ public class ClientReconnectionSelfTest extends GridCommonAbstractTest {
             for (int i = 0; i < 2; i++)
                 assertEquals("Iteration: " + i, 1, srvs[i].getConnectCount());
 
-            for (int i = 2; i < ClientTestRestServer.SERVERS_CNT; i++)
+            for (int i = 2; i < SERVERS_CNT; i++)
                 assertEquals(0, srvs[i].getConnectCount());
         }
     }
@@ -162,7 +165,7 @@ public class ClientReconnectionSelfTest extends GridCommonAbstractTest {
      */
     @Test
     public void testFailedInit() throws Exception {
-        for (int i = 0; i < ClientTestRestServer.SERVERS_CNT; i++)
+        for (int i = 0; i < SERVERS_CNT; i++)
             runServer(i, true);
 
         GridClient c = client();
@@ -177,7 +180,7 @@ public class ClientReconnectionSelfTest extends GridCommonAbstractTest {
                 X.hasCause(e, GridClientConnectionResetException.class, ClosedChannelException.class));
         }
 
-        for (int i = 0; i < ClientTestRestServer.SERVERS_CNT; i++)
+        for (int i = 0; i < SERVERS_CNT; i++)
             // Connection manager does 3 attempts to get topology before failure.
             assertEquals("Server: " + i, 3, srvs[i].getConnectCount());
     }
@@ -232,7 +235,7 @@ public class ClientReconnectionSelfTest extends GridCommonAbstractTest {
      * @throws IgniteCheckedException If failed.
      */
     private ClientTestRestServer runServer(int idx, boolean failOnConnect) throws IgniteCheckedException {
-        ClientTestRestServer srv = new ClientTestRestServer(ClientTestRestServer.FIRST_SERVER_PORT + idx, failOnConnect, log());
+        ClientTestRestServer srv = new ClientTestRestServer(FIRST_SERVER_PORT + idx, failOnConnect, log());
 
         srv.start();
 
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/client/TaskSingleJobSplitAdapter.java b/modules/clients/src/test/java/org/apache/ignite/internal/client/TaskSingleJobSplitAdapter.java
index 26c2c6c..bdc5bbd 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/client/TaskSingleJobSplitAdapter.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/client/TaskSingleJobSplitAdapter.java
@@ -68,7 +68,8 @@ public abstract class TaskSingleJobSplitAdapter<T, R> extends ComputeTaskSplitAd
      * @param arg Task execution argument. Can be {@code null}.
      * @return Job execution result (possibly {@code null}). This result will be returned
      *      in {@link org.apache.ignite.compute.ComputeJobResult#getData()} method passed into
-     *      {@link org.apache.ignite.compute.ComputeTask#result(org.apache.ignite.compute.ComputeJobResult, List)} method into task on caller node.
+     *      {@link org.apache.ignite.compute.ComputeTask#result(org.apache.ignite.compute.ComputeJobResult, List)}
+     *      method into task on caller node.
      */
     protected abstract Object executeJob(int gridSize, T arg);
 }
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcAbstractDmlStatementSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcAbstractDmlStatementSelfTest.java
index d658934..d06a2f3 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcAbstractDmlStatementSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcAbstractDmlStatementSelfTest.java
@@ -45,10 +45,12 @@ public abstract class JdbcAbstractDmlStatementSelfTest extends GridCommonAbstrac
     private static final String UTF_16 = "UTF-16"; // RAWTOHEX function use UTF-16 for conversion strings to byte arrays.
 
     /** JDBC URL. */
-    private static final String BASE_URL = CFG_URL_PREFIX + "cache=" + DEFAULT_CACHE_NAME + "@modules/clients/src/test/config/jdbc-config.xml";
+    private static final String BASE_URL =
+        CFG_URL_PREFIX + "cache=" + DEFAULT_CACHE_NAME + "@modules/clients/src/test/config/jdbc-config.xml";
 
     /** JDBC URL for tests involving binary objects manipulation. */
-    static final String BASE_URL_BIN = CFG_URL_PREFIX + "cache=" + DEFAULT_CACHE_NAME + "@modules/clients/src/test/config/jdbc-bin-config.xml";
+    static final String BASE_URL_BIN =
+        CFG_URL_PREFIX + "cache=" + DEFAULT_CACHE_NAME + "@modules/clients/src/test/config/jdbc-bin-config.xml";
 
     /** SQL SELECT query for verification. */
     static final String SQL_SELECT = "select _key, id, firstName, lastName, age, data from Person";
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDistributedJoinsQueryTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDistributedJoinsQueryTest.java
index b2c9cc4..18ca4c0 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDistributedJoinsQueryTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcDistributedJoinsQueryTest.java
@@ -40,7 +40,8 @@ import static org.apache.ignite.cache.CacheWriteSynchronizationMode.FULL_SYNC;
  */
 public class JdbcDistributedJoinsQueryTest extends GridCommonAbstractTest {
     /** JDBC URL. */
-    private static final String BASE_URL = CFG_URL_PREFIX + "cache=default:distributedJoins=true@modules/clients/src/test/config/jdbc-config.xml";
+    private static final String BASE_URL =
+        CFG_URL_PREFIX + "cache=default:distributedJoins=true@modules/clients/src/test/config/jdbc-config.xml";
 
     /** Statement. */
     private Statement stmt;
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcMetadataSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcMetadataSelfTest.java
index b5e3714..27df11a 100755
--- a/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcMetadataSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/jdbc2/JdbcMetadataSelfTest.java
@@ -753,7 +753,8 @@ public class JdbcMetadataSelfTest extends GridCommonAbstractTest {
         try (Connection conn = DriverManager.getConnection(BASE_URL)) {
             ResultSet rs = conn.getMetaData().getSchemas();
 
-            Set<String> expectedSchemas = new HashSet<>(Arrays.asList("pers", "org", "metaTest", "dep", "PUBLIC", "SYS", "PREDEFINED_CLIENT_SCHEMA"));
+            Set<String> expectedSchemas =
+                new HashSet<>(Arrays.asList("pers", "org", "metaTest", "dep", "PUBLIC", "SYS", "PREDEFINED_CLIENT_SCHEMA"));
 
             Set<String> schemas = new HashSet<>();
 
diff --git a/modules/clients/src/test/java/org/apache/ignite/jdbc/thin/JdbcThinBatchSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/jdbc/thin/JdbcThinBatchSelfTest.java
index 377bd88..d9664b8 100644
--- a/modules/clients/src/test/java/org/apache/ignite/jdbc/thin/JdbcThinBatchSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/jdbc/thin/JdbcThinBatchSelfTest.java
@@ -367,7 +367,8 @@ public class JdbcThinBatchSelfTest extends JdbcThinAbstractDmlStatementSelfTest
     @Test
     public void testHeterogeneousBatch() throws SQLException {
         stmt.addBatch("insert into Person (_key, id, firstName, lastName, age) values ('p0', 0, 'Name0', 'Lastname0', 10)");
-        stmt.addBatch("insert into Person (_key, id, firstName, lastName, age) values ('p1', 1, 'Name1', 'Lastname1', 20), ('p2', 2, 'Name2', 'Lastname2', 30)");
+        stmt.addBatch("insert into Person (_key, id, firstName, lastName, age) " +
+            "values ('p1', 1, 'Name1', 'Lastname1', 20), ('p2', 2, 'Name2', 'Lastname2', 30)");
         stmt.addBatch("merge into Person (_key, id, firstName, lastName, age) values ('p3', 3, 'Name3', 'Lastname3', 40)");
         stmt.addBatch("update Person set id = 5 where age >= 30");
         stmt.addBatch("merge into Person (_key, id, firstName, lastName, age) values ('p0', 2, 'Name2', 'Lastname2', 50)");
diff --git a/modules/clients/src/test/java/org/apache/ignite/jdbc/thin/JdbcThinConnectionSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/jdbc/thin/JdbcThinConnectionSelfTest.java
index 65aeddb..e0dd414 100644
--- a/modules/clients/src/test/java/org/apache/ignite/jdbc/thin/JdbcThinConnectionSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/jdbc/thin/JdbcThinConnectionSelfTest.java
@@ -694,7 +694,8 @@ public class JdbcThinConnectionSelfTest extends JdbcThinAbstractSelfTest {
             assertEquals("Invalid schema", "PUBLIC", conn.getSchema());
         }
 
-        try (Connection conn = DriverManager.getConnection(urlWithPartitionAwarenessPropSemicolon + ";schema=\"" + DEFAULT_CACHE_NAME + '"')) {
+        try (Connection conn =
+                 DriverManager.getConnection(urlWithPartitionAwarenessPropSemicolon + ";schema=\"" + DEFAULT_CACHE_NAME + '"')) {
             assertEquals("Invalid schema", DEFAULT_CACHE_NAME, conn.getSchema());
         }
 
diff --git a/modules/clients/src/test/java/org/apache/ignite/qa/query/WarningOnBigQueryResultsBaseTest.java b/modules/clients/src/test/java/org/apache/ignite/qa/query/WarningOnBigQueryResultsBaseTest.java
index e2d8054..70f06c4 100644
--- a/modules/clients/src/test/java/org/apache/ignite/qa/query/WarningOnBigQueryResultsBaseTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/qa/query/WarningOnBigQueryResultsBaseTest.java
@@ -63,7 +63,8 @@ public class WarningOnBigQueryResultsBaseTest extends AbstractIndexingCommonTest
 
     /** Log message pattern. */
     private static final Pattern logPtrn = Pattern.compile(
-        "fetched=([0-9]+), duration=([0-9]+)ms, type=(MAP|LOCAL|REDUCE), distributedJoin=(true|false), enforceJoinOrder=(true|false), lazy=(true|false), schema=(\\S+), sql");
+        "fetched=([0-9]+), duration=([0-9]+)ms, type=(MAP|LOCAL|REDUCE), distributedJoin=(true|false), enforceJoinOrder=(true|false), " +
+            "lazy=(true|false), schema=(\\S+), sql");
 
     /** Test log. */
     private static Map<String, BigResultsLogListener> logListeners = new HashMap<>();
diff --git a/modules/compatibility/src/test/java/org/apache/ignite/compatibility/persistence/FoldersReuseCompatibilityTest.java b/modules/compatibility/src/test/java/org/apache/ignite/compatibility/persistence/FoldersReuseCompatibilityTest.java
index cbcaba4..d61560e 100644
--- a/modules/compatibility/src/test/java/org/apache/ignite/compatibility/persistence/FoldersReuseCompatibilityTest.java
+++ b/modules/compatibility/src/test/java/org/apache/ignite/compatibility/persistence/FoldersReuseCompatibilityTest.java
@@ -120,7 +120,8 @@ public class FoldersReuseCompatibilityTest extends IgnitePersistenceCompatibilit
 
         assertEquals(VAL, ignite.cache(CACHE_NAME).get(KEY));
 
-        final PersistenceBasicCompatibilityTest.TestStringContainerToBePrinted actual = (PersistenceBasicCompatibilityTest.TestStringContainerToBePrinted)ignite.cache(CACHE_NAME).get(KEY_OBJ);
+        final PersistenceBasicCompatibilityTest.TestStringContainerToBePrinted actual =
+            (PersistenceBasicCompatibilityTest.TestStringContainerToBePrinted)ignite.cache(CACHE_NAME).get(KEY_OBJ);
         assertEquals(VAL, actual.data);
 
         assertNodeIndexesInFolder(); // should not create any new style directories
diff --git a/modules/control-utility/src/main/java/org/apache/ignite/internal/commandline/CommandHandler.java b/modules/control-utility/src/main/java/org/apache/ignite/internal/commandline/CommandHandler.java
index 14c8799..6775f8e 100644
--- a/modules/control-utility/src/main/java/org/apache/ignite/internal/commandline/CommandHandler.java
+++ b/modules/control-utility/src/main/java/org/apache/ignite/internal/commandline/CommandHandler.java
@@ -149,7 +149,8 @@ public class CommandHandler {
 
         // Adding logging to file.
         try {
-            String absPathPattern = new File(JavaLoggerFileHandler.logDirectory(U.defaultWorkDirectory()), "control-utility-%g.log").getAbsolutePath();
+            String absPathPattern =
+                new File(JavaLoggerFileHandler.logDirectory(U.defaultWorkDirectory()), "control-utility-%g.log").getAbsolutePath();
 
             FileHandler fileHandler = new FileHandler(absPathPattern, 5 * 1024 * 1024, 5);
 
diff --git a/modules/control-utility/src/main/java/org/apache/ignite/internal/commandline/cache/CheckIndexInlineSizes.java b/modules/control-utility/src/main/java/org/apache/ignite/internal/commandline/cache/CheckIndexInlineSizes.java
index 457f189..b74f937 100644
--- a/modules/control-utility/src/main/java/org/apache/ignite/internal/commandline/cache/CheckIndexInlineSizes.java
+++ b/modules/control-utility/src/main/java/org/apache/ignite/internal/commandline/cache/CheckIndexInlineSizes.java
@@ -127,7 +127,9 @@ public class CheckIndexInlineSizes extends AbstractCommand<Void> {
         log.info("");
 
         log.info("Recommendations:");
-        log.info(INDENT + "Check that value of property " + IgniteSystemProperties.IGNITE_MAX_INDEX_PAYLOAD_SIZE + " are the same on all nodes.");
+        log.info(
+            INDENT + "Check that value of property " + IgniteSystemProperties.IGNITE_MAX_INDEX_PAYLOAD_SIZE + " are the same on all nodes."
+        );
         log.info(INDENT + "Recreate indexes (execute DROP INDEX, CREATE INDEX commands) with different inline size.");
     }
 
diff --git a/modules/control-utility/src/test/java/org/apache/ignite/internal/commandline/CommandHandlerParsingTest.java b/modules/control-utility/src/test/java/org/apache/ignite/internal/commandline/CommandHandlerParsingTest.java
index 2d74e02..2401440 100644
--- a/modules/control-utility/src/test/java/org/apache/ignite/internal/commandline/CommandHandlerParsingTest.java
+++ b/modules/control-utility/src/test/java/org/apache/ignite/internal/commandline/CommandHandlerParsingTest.java
@@ -154,8 +154,19 @@ public class CommandHandlerParsingTest {
             e.printStackTrace();
         }
 
-        assertParseArgsThrows("Value for '--check-first' property should be positive.", CACHE.text(), VALIDATE_INDEXES.text(), CHECK_FIRST.toString(), "0");
-        assertParseArgsThrows("Numeric value for '--check-through' parameter expected.", CACHE.text(), VALIDATE_INDEXES.text(), CHECK_THROUGH.toString());
+        assertParseArgsThrows(
+            "Value for '--check-first' property should be positive.",
+            CACHE.text(),
+            VALIDATE_INDEXES.text(),
+            CHECK_FIRST.toString(),
+            "0"
+        );
+        assertParseArgsThrows(
+            "Numeric value for '--check-through' parameter expected.",
+            CACHE.text(),
+            VALIDATE_INDEXES.text(),
+            CHECK_THROUGH.toString()
+        );
     }
 
     /** */
@@ -275,9 +286,17 @@ public class CommandHandlerParsingTest {
 
             assertParseArgsThrows("Expected SSL trust store path", "--truststore");
 
-            ConnectionAndSslParameters args = parseArgs(asList("--keystore", "testKeystore", "--keystore-password", "testKeystorePassword", "--keystore-type", "testKeystoreType",
-                "--truststore", "testTruststore", "--truststore-password", "testTruststorePassword", "--truststore-type", "testTruststoreType",
-                "--ssl-key-algorithm", "testSSLKeyAlgorithm", "--ssl-protocol", "testSSLProtocol", cmd.text()));
+            ConnectionAndSslParameters args = parseArgs(asList(
+                "--keystore", "testKeystore",
+                "--keystore-password", "testKeystorePassword",
+                "--keystore-type", "testKeystoreType",
+                "--truststore", "testTruststore",
+                "--truststore-password", "testTruststorePassword",
+                "--truststore-type", "testTruststoreType",
+                "--ssl-key-algorithm", "testSSLKeyAlgorithm",
+                "--ssl-protocol", "testSSLProtocol",
+                cmd.text())
+            );
 
             assertEquals("testSSLProtocol", args.sslProtocol());
             assertEquals("testSSLKeyAlgorithm", args.sslKeyAlgorithm());
@@ -625,11 +644,14 @@ public class CommandHandlerParsingTest {
      *                 <ul>
      *                     <li>
      *                         if value is missing:
-     *                          IllegalArgumentException (The scope should be specified. The following values can be used: [DISCOVERY, EXCHANGE, COMMUNICATION, TX].")
+     *                          IllegalArgumentException
+     *                          (The scope should be specified.
+     *                          The following values can be used: [DISCOVERY, EXCHANGE, COMMUNICATION, TX].")
      *                     </li>
      *                     <li>
      *                         if unsupported value is used:
-     *                          IllegalArgumentException (Invalid scope 'aaa'. The following values can be used: [DISCOVERY, EXCHANGE, COMMUNICATION, TX])
+     *                          IllegalArgumentException
+     *                          (Invalid scope 'aaa'. The following values can be used: [DISCOVERY, EXCHANGE, COMMUNICATION, TX])
      *                     </li>
      *                 </ul>
      *             </li>
@@ -643,11 +665,14 @@ public class CommandHandlerParsingTest {
      *                 <ul>
      *                     <li>
      *                         if value is missing:
-     *                          IllegalArgumentException (The scope should be specified. The following values can be used: [DISCOVERY, EXCHANGE, COMMUNICATION, TX].")
+     *                          IllegalArgumentException
+     *                          (The scope should be specified.
+     *                          The following values can be used: [DISCOVERY, EXCHANGE, COMMUNICATION, TX].")
      *                     </li>
      *                     <li>
      *                         if unsupported value is used:
-     *                          IllegalArgumentException (Invalid scope 'aaa'. The following values can be used: [DISCOVERY, EXCHANGE, COMMUNICATION, TX])
+     *                          IllegalArgumentException
+     *                          (Invalid scope 'aaa'. The following values can be used: [DISCOVERY, EXCHANGE, COMMUNICATION, TX])
      *                     </li>
      *                 </ul>
      *             </li>
@@ -670,11 +695,14 @@ public class CommandHandlerParsingTest {
      *                 <ul>
      *                     <li>
      *                         if value is missing:
-     *                          IllegalArgumentException (The scope should be specified. The following values can be used: [DISCOVERY, EXCHANGE, COMMUNICATION, TX].")
+     *                          IllegalArgumentException
+     *                          (The scope should be specified.
+     *                          The following values can be used: [DISCOVERY, EXCHANGE, COMMUNICATION, TX].")
      *                     </li>
      *                     <li>
      *                         if unsupported value is used:
-     *                          IllegalArgumentException (Invalid scope 'aaa'. The following values can be used: [DISCOVERY, EXCHANGE, COMMUNICATION, TX])
+     *                          IllegalArgumentException
+     *                          (Invalid scope 'aaa'. The following values can be used: [DISCOVERY, EXCHANGE, COMMUNICATION, TX])
      *                     </li>
      *                 </ul>
      *             </li>
@@ -692,7 +720,8 @@ public class CommandHandlerParsingTest {
      *                 <ul>
      *                     <li>
      *                          if value is missing:
-     *                              IllegalArgumentException (The sampling-rate should be specified. Decimal value between 0 and 1 should be used.)
+     *                              IllegalArgumentException
+     *                              (The sampling-rate should be specified. Decimal value between 0 and 1 should be used.)
      *                     </li>
      *                     <li>
      *                          if unsupported value is used:
@@ -709,7 +738,9 @@ public class CommandHandlerParsingTest {
      *                     </li>
      *                     <li>
      *                          if unsupported value is used:
-     *                              IllegalArgumentException (Invalid supported scope: aaa. The following values can be used: [DISCOVERY, EXCHANGE, COMMUNICATION, TX].)
+     *                              IllegalArgumentException
+     *                              (Invalid supported scope: aaa.
+     *                              The following values can be used: [DISCOVERY, EXCHANGE, COMMUNICATION, TX].)
      *                     </li>
      *                 </ul>
      *             </li>
@@ -846,35 +877,58 @@ public class CommandHandlerParsingTest {
 
         GridTestUtils.assertThrows(
             null,
-            () -> parseArgs(asList("--cache", "indexes_force_rebuild", "--node-id", nodeId, "--group-names", "someNames", "--cache-names", "someNames")),
+            () -> parseArgs(asList(
+                "--cache", "indexes_force_rebuild",
+                "--node-id", nodeId,
+                "--group-names", "someNames",
+                "--cache-names", "someNames"
+            )),
             IllegalArgumentException.class,
             "Either --group-names or --cache-names must be specified."
         );
 
         GridTestUtils.assertThrows(
             null,
-            () -> parseArgs(asList("--cache", "indexes_force_rebuild", "--node-id", nodeId, "--cache-names", "someNames", "--cache-names", "someMoreNames")),
+            () -> parseArgs(asList(
+                "--cache", "indexes_force_rebuild",
+                "--node-id", nodeId,
+                "--cache-names", "someNames",
+                "--cache-names", "someMoreNames"
+            )),
             IllegalArgumentException.class,
             "--cache-names arg specified twice."
         );
 
         GridTestUtils.assertThrows(
             null,
-            () -> parseArgs(asList("--cache", "indexes_force_rebuild", "--node-id", nodeId, "--group-names", "someNames", "--group-names", "someMoreNames")),
+            () -> parseArgs(asList(
+                "--cache", "indexes_force_rebuild",
+                "--node-id", nodeId,
+                "--group-names", "someNames",
+                "--group-names", "someMoreNames"
+            )),
             IllegalArgumentException.class,
             "--group-names arg specified twice."
         );
 
         GridTestUtils.assertThrows(
             null,
-            () -> parseArgs(asList("--cache", "indexes_force_rebuild", "--node-id", nodeId, "--group-names", "--some-other-arg")),
+            () -> parseArgs(asList(
+                "--cache", "indexes_force_rebuild",
+                "--node-id", nodeId,
+                "--group-names", "--some-other-arg"
+            )),
             IllegalArgumentException.class,
             "--group-names not specified."
         );
 
         GridTestUtils.assertThrows(
             null,
-            () -> parseArgs(asList("--cache", "indexes_force_rebuild", "--node-id", nodeId, "--cache-names", "--some-other-arg")),
+            () -> parseArgs(asList(
+                "--cache", "indexes_force_rebuild",
+                "--node-id", nodeId,
+                "--cache-names", "--some-other-arg"
+            )),
             IllegalArgumentException.class,
             "--cache-names not specified."
         );
diff --git a/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerCheckIndexesInlineSizeTest.java b/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerCheckIndexesInlineSizeTest.java
index de33ac6..7f24847 100644
--- a/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerCheckIndexesInlineSizeTest.java
+++ b/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerCheckIndexesInlineSizeTest.java
@@ -142,7 +142,11 @@ public class GridCommandHandlerCheckIndexesInlineSizeTest extends GridCommandHan
      */
     public static void checkUtilityOutput(IgniteLogger log, String output, UUID localNodeId, UUID remoteNodeId) {
         assertContains(log, output, "Found 4 secondary indexes.");
-        assertContains(log, output, "3 index(es) have different effective inline size on nodes. It can lead to performance degradation in SQL queries.");
+        assertContains(
+            log,
+            output,
+            "3 index(es) have different effective inline size on nodes. It can lead to performance degradation in SQL queries."
+        );
         assertContains(log, output, "Index(es):");
         assertContains(log, output, format(INDEX_PROBLEM_FMT, "L_IDX", localNodeId, remoteNodeId));
         assertContains(log, output, format(INDEX_PROBLEM_FMT, "S1_IDX", localNodeId, remoteNodeId));
diff --git a/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerClusterByClassTest.java b/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerClusterByClassTest.java
index 4014d4e..cd97917 100644
--- a/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerClusterByClassTest.java
+++ b/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerClusterByClassTest.java
@@ -1454,7 +1454,8 @@ public class GridCommandHandlerClusterByClassTest extends GridCommandHandlerClus
 
                         doSleep(3000);
 
-                        try (Transaction tx = grid(0).transactions().withLabel("label1").txStart(PESSIMISTIC, READ_COMMITTED, Integer.MAX_VALUE, 0)) {
+                        try (Transaction tx =
+                                 grid(0).transactions().withLabel("label1").txStart(PESSIMISTIC, READ_COMMITTED, Integer.MAX_VALUE, 0)) {
                             grid(0).cache(DEFAULT_CACHE_NAME).putAll(generate(200, 110));
 
                             grid(0).cache(DEFAULT_CACHE_NAME).put(0, 0);
diff --git a/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerTest.java b/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerTest.java
index 80c33ee..33683dd 100644
--- a/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerTest.java
+++ b/modules/control-utility/src/test/java/org/apache/ignite/util/GridCommandHandlerTest.java
@@ -1017,7 +1017,11 @@ public class GridCommandHandlerTest extends GridCommandHandlerClusterPerMethodAb
 
             List<String> nodesInfo = findBaselineNodesInfo();
             assertEquals(1, nodesInfo.size());
-            assertContains(log, nodesInfo.get(0), "Addresses=188.166.164.247.hostname/188.166.164.247,10.19.112.175.hostname/10.19.112.175");
+            assertContains(
+                log,
+                nodesInfo.get(0),
+                "Addresses=188.166.164.247.hostname/188.166.164.247,10.19.112.175.hostname/10.19.112.175"
+            );
         }
 
         { // empty resolved addresses
@@ -2548,7 +2552,8 @@ public class GridCommandHandlerTest extends GridCommandHandlerClusterPerMethodAb
 
                         doSleep(3000);
 
-                        try (Transaction tx = grid(0).transactions().withLabel("label1").txStart(PESSIMISTIC, READ_COMMITTED, Integer.MAX_VALUE, 0)) {
+                        try (Transaction tx =
+                                 grid(0).transactions().withLabel("label1").txStart(PESSIMISTIC, READ_COMMITTED, Integer.MAX_VALUE, 0)) {
                             grid(0).cache(DEFAULT_CACHE_NAME).putAll(generate(200, 110));
 
                             grid(0).cache(DEFAULT_CACHE_NAME).put(0, 0);
diff --git a/modules/core/src/main/java/org/apache/ignite/Ignite.java b/modules/core/src/main/java/org/apache/ignite/Ignite.java
index 32c88d0..9fff224 100644
--- a/modules/core/src/main/java/org/apache/ignite/Ignite.java
+++ b/modules/core/src/main/java/org/apache/ignite/Ignite.java
@@ -56,8 +56,10 @@ import org.jetbrains.annotations.Nullable;
  * <li>{@link IgniteDataStreamer} - functionality for streaming large amounts of data into cache.</li>
  * <li>{@link IgniteCompute} - functionality for executing tasks and closures on all grid nodes (inherited form {@link ClusterGroup}).</li>
  * <li>{@link IgniteServices} - distributed service grid functionality (e.g. singletons on the cluster).</li>
- * <li>{@link IgniteMessaging} - functionality for topic-based message exchange on all grid nodes (inherited form {@link ClusterGroup}).</li>
- * <li>{@link IgniteEvents} - functionality for querying and listening to events on all grid nodes  (inherited form {@link ClusterGroup}).</li>
+ * <li>{@link IgniteMessaging} -
+ * functionality for topic-based message exchange on all grid nodes (inherited form {@link ClusterGroup}).</li>
+ * <li>{@link IgniteEvents} -
+ * functionality for querying and listening to events on all grid nodes  (inherited form {@link ClusterGroup}).</li>
  * <li>{@link ExecutorService} - distributed thread pools.</li>
  * <li>{@link IgniteAtomicLong} - distributed atomic long.</li>
  * <li>{@link IgniteAtomicReference} - distributed atomic reference.</li>
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java b/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
index 382a0c1..64d4ac7 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
@@ -692,8 +692,8 @@ public final class IgniteSystemProperties {
     public static final String IGNITE_LOG_DIR = "IGNITE_LOG_DIR";
 
     /**
-     * Environment variable to set work directory. The property {@link org.apache.ignite.configuration.IgniteConfiguration#setWorkDirectory} has higher
-     * priority.
+     * Environment variable to set work directory.
+     * The property {@link org.apache.ignite.configuration.IgniteConfiguration#setWorkDirectory} has higher priority.
      */
     @SystemProperty(value = "Work directory. The property IgniteConfiguration.setWorkDirectory has higher priority",
         type = String.class)
@@ -1448,7 +1448,8 @@ public final class IgniteSystemProperties {
     @SystemProperty("When property is set false each next exchange will try to compare with previous. " +
         "If last rebalance is equivalent with new possible one, new rebalance does not trigger. " +
         "Set the property true and each exchange will try to trigger new rebalance")
-    public static final String IGNITE_DISABLE_REBALANCING_CANCELLATION_OPTIMIZATION = "IGNITE_DISABLE_REBALANCING_CANCELLATION_OPTIMIZATION";
+    public static final String IGNITE_DISABLE_REBALANCING_CANCELLATION_OPTIMIZATION =
+        "IGNITE_DISABLE_REBALANCING_CANCELLATION_OPTIMIZATION";
 
     /**
      * Sets timeout for TCP client recovery descriptor reservation.
@@ -1619,7 +1620,8 @@ public final class IgniteSystemProperties {
      * Default is {@code false}.
      */
     @SystemProperty("Disables cache interceptor triggering in case of conflicts")
-    public static final String IGNITE_DISABLE_TRIGGERING_CACHE_INTERCEPTOR_ON_CONFLICT = "IGNITE_DISABLE_TRIGGERING_CACHE_INTERCEPTOR_ON_CONFLICT";
+    public static final String IGNITE_DISABLE_TRIGGERING_CACHE_INTERCEPTOR_ON_CONFLICT =
+        "IGNITE_DISABLE_TRIGGERING_CACHE_INTERCEPTOR_ON_CONFLICT";
 
     /**
      * Sets default {@link CacheConfiguration#setDiskPageCompression disk page compression}.
diff --git a/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoStore.java b/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoStore.java
index 51ae71a..c8ad141 100644
--- a/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoStore.java
+++ b/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoStore.java
@@ -237,7 +237,12 @@ public class CacheJdbcPojoStore<K, V> extends CacheAbstractJdbcStore<K, V> {
      * @return Constructed binary object.
      * @throws CacheLoaderException If failed to construct binary object.
      */
-    protected Object buildBinaryObject(String typeName, JdbcTypeField[] fields, Map<String, Integer> loadColIdxs, ResultSet rs) throws CacheLoaderException {
+    protected Object buildBinaryObject(
+        String typeName,
+        JdbcTypeField[] fields,
+        Map<String, Integer> loadColIdxs,
+        ResultSet rs
+    ) throws CacheLoaderException {
         try {
             BinaryObjectBuilder builder = ignite.binary().builder(typeName);
 
diff --git a/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/dialect/BasicJdbcDialect.java b/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/dialect/BasicJdbcDialect.java
index 59361c3..4a434f5b9 100644
--- a/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/dialect/BasicJdbcDialect.java
+++ b/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/dialect/BasicJdbcDialect.java
@@ -160,8 +160,12 @@ public class BasicJdbcDialect implements JdbcDialect {
     @Override public String loadCacheSelectRangeQuery(String fullTblName, Collection<String> keyCols) {
         String cols = mkString(keyCols, ",");
 
-        return String.format("SELECT %1$s FROM (SELECT %1$s, ROW_NUMBER() OVER() AS rn FROM (SELECT %1$s FROM %2$s ORDER BY %1$s) AS tbl) AS tbl WHERE mod(rn, ?) = 0",
-            cols, fullTblName);
+        return String.format(
+            "SELECT %1$s FROM (" +
+                "SELECT %1$s, ROW_NUMBER() OVER() AS rn FROM (SELECT %1$s FROM %2$s ORDER BY %1$s) AS tbl) AS tbl WHERE mod(rn, ?) = 0",
+            cols,
+            fullTblName
+        );
     }
 
     /** {@inheritDoc} */
diff --git a/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/dialect/DB2Dialect.java b/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/dialect/DB2Dialect.java
index 551782e..664ff1b 100644
--- a/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/dialect/DB2Dialect.java
+++ b/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/dialect/DB2Dialect.java
@@ -32,8 +32,11 @@ public class DB2Dialect extends BasicJdbcDialect {
     @Override public String loadCacheSelectRangeQuery(String fullTblName, Collection<String> keyCols) {
         String cols = mkString(keyCols, ",");
 
-        return String.format("SELECT %1$s FROM (SELECT %1$s, ROW_NUMBER() OVER(ORDER BY %1$s) AS rn FROM %2$s) WHERE mod(rn, ?) = 0 ORDER BY %1$s",
-            cols, fullTblName);
+        return String.format(
+            "SELECT %1$s FROM (SELECT %1$s, ROW_NUMBER() OVER(ORDER BY %1$s) AS rn FROM %2$s) WHERE mod(rn, ?) = 0 ORDER BY %1$s",
+            cols,
+            fullTblName
+        );
     }
 
     /** {@inheritDoc} */
diff --git a/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/dialect/SQLServerDialect.java b/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/dialect/SQLServerDialect.java
index ace1d3f..1f7dbe0 100644
--- a/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/dialect/SQLServerDialect.java
+++ b/modules/core/src/main/java/org/apache/ignite/cache/store/jdbc/dialect/SQLServerDialect.java
@@ -37,8 +37,11 @@ public class SQLServerDialect extends BasicJdbcDialect {
     @Override public String loadCacheSelectRangeQuery(String fullTblName, Collection<String> keyCols) {
         String cols = mkString(keyCols, ",");
 
-        return String.format("SELECT %1$s FROM (SELECT %1$s, ROW_NUMBER() OVER(ORDER BY %1$s) AS rn FROM %2$s) tbl WHERE rn %% ? = 0 ORDER BY %1$s",
-            cols, fullTblName);
+        return String.format(
+            "SELECT %1$s FROM (SELECT %1$s, ROW_NUMBER() OVER(ORDER BY %1$s) AS rn FROM %2$s) tbl WHERE rn %% ? = 0 ORDER BY %1$s",
+            cols,
+            fullTblName
+        );
     }
 
     /** {@inheritDoc} */
diff --git a/modules/core/src/main/java/org/apache/ignite/events/CacheConsistencyViolationEvent.java b/modules/core/src/main/java/org/apache/ignite/events/CacheConsistencyViolationEvent.java
index 688ea3b..930811c 100644
--- a/modules/core/src/main/java/org/apache/ignite/events/CacheConsistencyViolationEvent.java
+++ b/modules/core/src/main/java/org/apache/ignite/events/CacheConsistencyViolationEvent.java
@@ -46,7 +46,8 @@ import static org.apache.ignite.events.EventType.EVT_CONSISTENCY_VIOLATION;
  *          listening to local grid events (events from remote nodes not included).
  *      </li>
  * </ul>
- * User can also wait for events using method {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
+ * User can also wait for events using method
+ * {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
  * <h1 class="header">Events and Performance</h1>
  * Note that by default all events in Ignite are enabled and therefore generated and stored
  * by whatever event storage SPI is configured. Ignite can and often does generate thousands events per seconds
@@ -54,8 +55,8 @@ import static org.apache.ignite.events.EventType.EVT_CONSISTENCY_VIOLATION;
  * not needed by the application this load is unnecessary and leads to significant performance degradation.
  * <p>
  * It is <b>highly recommended</b> to enable only those events that your application logic requires
- * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration. Note that certain
- * events are required for Ignite's internal operations and such events will still be generated but not stored by
+ * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration.
+ * Note that certain events are required for Ignite's internal operations and such events will still be generated but not stored by
  * event storage SPI if they are disabled in Ignite configuration.
  *
  * @see EventType#EVT_CONSISTENCY_VIOLATION
diff --git a/modules/core/src/main/java/org/apache/ignite/events/CacheQueryExecutedEvent.java b/modules/core/src/main/java/org/apache/ignite/events/CacheQueryExecutedEvent.java
index 77f7665..01137d2 100644
--- a/modules/core/src/main/java/org/apache/ignite/events/CacheQueryExecutedEvent.java
+++ b/modules/core/src/main/java/org/apache/ignite/events/CacheQueryExecutedEvent.java
@@ -46,7 +46,8 @@ import org.jetbrains.annotations.Nullable;
  *          listening to local grid events (events from remote nodes not included).
  *      </li>
  * </ul>
- * User can also wait for events using method {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
+ * User can also wait for events using method
+ * {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
  * <h1 class="header">Events and Performance</h1>
  * Note that by default all events in Ignite are enabled and therefore generated and stored
  * by whatever event storage SPI is configured. Ignite can and often does generate thousands events per seconds
@@ -54,8 +55,8 @@ import org.jetbrains.annotations.Nullable;
  * not needed by the application this load is unnecessary and leads to significant performance degradation.
  * <p>
  * It is <b>highly recommended</b> to enable only those events that your application logic requires
- * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration. Note that certain
- * events are required for Ignite's internal operations and such events will still be generated but not stored by
+ * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration.
+ * Note that certain events are required for Ignite's internal operations and such events will still be generated but not stored by
  * event storage SPI if they are disabled in Ignite configuration.
  *
  * @see EventType#EVT_CACHE_QUERY_EXECUTED
diff --git a/modules/core/src/main/java/org/apache/ignite/events/CacheQueryReadEvent.java b/modules/core/src/main/java/org/apache/ignite/events/CacheQueryReadEvent.java
index eda7d21..b186c3b 100644
--- a/modules/core/src/main/java/org/apache/ignite/events/CacheQueryReadEvent.java
+++ b/modules/core/src/main/java/org/apache/ignite/events/CacheQueryReadEvent.java
@@ -46,7 +46,8 @@ import org.jetbrains.annotations.Nullable;
  *          listening to local grid events (events from remote nodes not included).
  *      </li>
  * </ul>
- * User can also wait for events using method {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
+ * User can also wait for events using method
+ * {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
  * <h1 class="header">Events and Performance</h1>
  * Note that by default all events in Ignite are enabled and therefore generated and stored
  * by whatever event storage SPI is configured. Ignite can and often does generate thousands events per seconds
@@ -54,8 +55,8 @@ import org.jetbrains.annotations.Nullable;
  * not needed by the application this load is unnecessary and leads to significant performance degradation.
  * <p>
  * It is <b>highly recommended</b> to enable only those events that your application logic requires
- * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration. Note that certain
- * events are required for Ignite's internal operations and such events will still be generated but not stored by
+ * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration.
+ * Note that certain events are required for Ignite's internal operations and such events will still be generated but not stored by
  * event storage SPI if they are disabled in Ignite configuration.
  *
  * @see EventType#EVT_CACHE_QUERY_OBJECT_READ
diff --git a/modules/core/src/main/java/org/apache/ignite/events/CheckpointEvent.java b/modules/core/src/main/java/org/apache/ignite/events/CheckpointEvent.java
index 96cc03e..938e26a 100644
--- a/modules/core/src/main/java/org/apache/ignite/events/CheckpointEvent.java
+++ b/modules/core/src/main/java/org/apache/ignite/events/CheckpointEvent.java
@@ -41,7 +41,8 @@ import org.apache.ignite.internal.util.typedef.internal.U;
  *          listening to local grid events (events from remote nodes not included).
  *      </li>
  * </ul>
- * User can also wait for events using method {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
+ * User can also wait for events using method
+ * {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
  * <h1 class="header">Events and Performance</h1>
  * Note that by default all events in Ignite are enabled and therefore generated and stored
  * by whatever event storage SPI is configured. Ignite can and often does generate thousands events per seconds
@@ -49,8 +50,8 @@ import org.apache.ignite.internal.util.typedef.internal.U;
  * not needed by the application this load is unnecessary and leads to significant performance degradation.
  * <p>
  * It is <b>highly recommended</b> to enable only those events that your application logic requires
- * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration. Note that certain
- * events are required for Ignite's internal operations and such events will still be generated but not stored by
+ * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration.
+ * Note that certain events are required for Ignite's internal operations and such events will still be generated but not stored by
  * event storage SPI if they are disabled in Ignite configuration.
  * @see EventType#EVT_CHECKPOINT_LOADED
  * @see EventType#EVT_CHECKPOINT_REMOVED
diff --git a/modules/core/src/main/java/org/apache/ignite/events/DeploymentEvent.java b/modules/core/src/main/java/org/apache/ignite/events/DeploymentEvent.java
index 7c968ec..b077630 100644
--- a/modules/core/src/main/java/org/apache/ignite/events/DeploymentEvent.java
+++ b/modules/core/src/main/java/org/apache/ignite/events/DeploymentEvent.java
@@ -41,7 +41,8 @@ import org.apache.ignite.internal.util.typedef.internal.U;
  *          listening to local grid events (events from remote nodes not included).
  *      </li>
  * </ul>
- * User can also wait for events using method {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
+ * User can also wait for events using method
+ * {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
  * <h1 class="header">Events and Performance</h1>
  * Note that by default all events in Ignite are enabled and therefore generated and stored
  * by whatever event storage SPI is configured. Ignite can and often does generate thousands events per seconds
@@ -49,8 +50,8 @@ import org.apache.ignite.internal.util.typedef.internal.U;
  * not needed by the application this load is unnecessary and leads to significant performance degradation.
  * <p>
  * It is <b>highly recommended</b> to enable only those events that your application logic requires
- * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration. Note that certain
- * events are required for Ignite's internal operations and such events will still be generated but not stored by
+ * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration.
+ * Note that certain events are required for Ignite's internal operations and such events will still be generated but not stored by
  * event storage SPI if they are disabled in Ignite configuration.
  * @see EventType#EVT_CLASS_DEPLOY_FAILED
  * @see EventType#EVT_CLASS_DEPLOYED
diff --git a/modules/core/src/main/java/org/apache/ignite/events/DiscoveryEvent.java b/modules/core/src/main/java/org/apache/ignite/events/DiscoveryEvent.java
index 16d030c..0f4b004 100644
--- a/modules/core/src/main/java/org/apache/ignite/events/DiscoveryEvent.java
+++ b/modules/core/src/main/java/org/apache/ignite/events/DiscoveryEvent.java
@@ -45,7 +45,8 @@ import org.jetbrains.annotations.Nullable;
  *          listening to local grid events (events from remote nodes not included).
  *      </li>
  * </ul>
- * User can also wait for events using method {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
+ * User can also wait for events using method
+ * {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
  * <h1 class="header">Events and Performance</h1>
  * Note that by default all events in Ignite are enabled and therefore generated and stored
  * by whatever event storage SPI is configured. Ignite can and often does generate thousands events per seconds
@@ -53,8 +54,8 @@ import org.jetbrains.annotations.Nullable;
  * not needed by the application this load is unnecessary and leads to significant performance degradation.
  * <p>
  * It is <b>highly recommended</b> to enable only those events that your application logic requires
- * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration. Note that certain
- * events are required for Ignite's internal operations and such events will still be generated but not stored by
+ * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration.
+ * Note that certain events are required for Ignite's internal operations and such events will still be generated but not stored by
  * event storage SPI if they are disabled in Ignite configuration.
  * @see EventType#EVT_NODE_METRICS_UPDATED
  * @see EventType#EVT_NODE_FAILED
diff --git a/modules/core/src/main/java/org/apache/ignite/events/Event.java b/modules/core/src/main/java/org/apache/ignite/events/Event.java
index 34726d3..d51f823 100644
--- a/modules/core/src/main/java/org/apache/ignite/events/Event.java
+++ b/modules/core/src/main/java/org/apache/ignite/events/Event.java
@@ -47,8 +47,8 @@ import org.jetbrains.annotations.Nullable;
  * not needed by the application this load is unnecessary and leads to significant performance degradation.
  * <p>
  * It is <b>highly recommended</b> to enable only those events that your application logic requires
- * by using either {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration. Note that certain
- * events are required for Ignite's internal operations and such events will still be generated but not stored by
+ * by using either {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration.
+ * Note that certain events are required for Ignite's internal operations and such events will still be generated but not stored by
  * event storage SPI if they are disabled in Ignite configuration.
  * <h1 class="header">Internal and Hidden Events</h1>
  * Also note that some events are considered to be internally used or hidden.
diff --git a/modules/core/src/main/java/org/apache/ignite/events/SqlQueryExecutionEvent.java b/modules/core/src/main/java/org/apache/ignite/events/SqlQueryExecutionEvent.java
index d8feb07..afd91fb 100644
--- a/modules/core/src/main/java/org/apache/ignite/events/SqlQueryExecutionEvent.java
+++ b/modules/core/src/main/java/org/apache/ignite/events/SqlQueryExecutionEvent.java
@@ -50,7 +50,8 @@ import static org.apache.ignite.events.EventType.EVT_SQL_QUERY_EXECUTION;
  *          listening to local grid events (events from remote nodes not included).
  *      </li>
  * </ul>
- * User can also wait for events using method {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
+ * User can also wait for events using method
+ * {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
  * <h1 class="header">Events and Performance</h1>
  * Note that by default all events in Ignite are enabled and therefore generated and stored
  * by whatever event storage SPI is configured. Ignite can and often does generate thousands events per seconds
@@ -58,8 +59,8 @@ import static org.apache.ignite.events.EventType.EVT_SQL_QUERY_EXECUTION;
  * not needed by the application this load is unnecessary and leads to significant performance degradation.
  * <p>
  * It is <b>highly recommended</b> to enable only those events that your application logic requires
- * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration. Note that certain
- * events are required for Ignite's internal operations and such events will still be generated but not stored by
+ * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration.
+ * Note that certain events are required for Ignite's internal operations and such events will still be generated but not stored by
  * event storage SPI if they are disabled in Ignite configuration.
  *
  * @see EventType#EVT_SQL_QUERY_EXECUTION
diff --git a/modules/core/src/main/java/org/apache/ignite/events/TaskEvent.java b/modules/core/src/main/java/org/apache/ignite/events/TaskEvent.java
index 284b7b7..ef958ed 100644
--- a/modules/core/src/main/java/org/apache/ignite/events/TaskEvent.java
+++ b/modules/core/src/main/java/org/apache/ignite/events/TaskEvent.java
@@ -44,7 +44,8 @@ import org.jetbrains.annotations.Nullable;
  *          listening to local grid events (events from remote nodes not included).
  *      </li>
  * </ul>
- * User can also wait for events using method {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
+ * User can also wait for events using method
+ * {@link org.apache.ignite.IgniteEvents#waitForLocal(org.apache.ignite.lang.IgnitePredicate, int...)}.
  * <h1 class="header">Events and Performance</h1>
  * Note that by default all events in Ignite are enabled and therefore generated and stored
  * by whatever event storage SPI is configured. Ignite can and often does generate thousands events per seconds
@@ -52,8 +53,8 @@ import org.jetbrains.annotations.Nullable;
  * not needed by the application this load is unnecessary and leads to significant performance degradation.
  * <p>
  * It is <b>highly recommended</b> to enable only those events that your application logic requires
- * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration. Note that certain
- * events are required for Ignite's internal operations and such events will still be generated but not stored by
+ * by using {@link org.apache.ignite.configuration.IgniteConfiguration#getIncludeEventTypes()} method in Ignite configuration.
+ * Note that certain events are required for Ignite's internal operations and such events will still be generated but not stored by
  * event storage SPI if they are disabled in Ignite configuration.
  * @see EventType#EVT_TASK_FAILED
  * @see EventType#EVT_TASK_FINISHED
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/GridJobExecuteRequest.java b/modules/core/src/main/java/org/apache/ignite/internal/GridJobExecuteRequest.java
index ebfeb01..2507ac4 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/GridJobExecuteRequest.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/GridJobExecuteRequest.java
@@ -39,6 +39,8 @@ import org.apache.ignite.plugin.extensions.communication.MessageReader;
 import org.apache.ignite.plugin.extensions.communication.MessageWriter;
 import org.jetbrains.annotations.Nullable;
 
+import static org.apache.ignite.plugin.extensions.communication.MessageCollectionItemType.IGNITE_UUID;
+
 /**
  * Job execution request.
  */
@@ -586,7 +588,7 @@ public class GridJobExecuteRequest implements ExecutorAwareMessage {
                 writer.incrementState();
 
             case 11:
-                if (!writer.writeMap("ldrParticipants", ldrParticipants, MessageCollectionItemType.UUID, MessageCollectionItemType.IGNITE_UUID))
+                if (!writer.writeMap("ldrParticipants", ldrParticipants, MessageCollectionItemType.UUID, IGNITE_UUID))
                     return false;
 
                 writer.incrementState();
@@ -781,7 +783,7 @@ public class GridJobExecuteRequest implements ExecutorAwareMessage {
                 reader.incrementState();
 
             case 11:
-                ldrParticipants = reader.readMap("ldrParticipants", MessageCollectionItemType.UUID, MessageCollectionItemType.IGNITE_UUID, false);
+                ldrParticipants = reader.readMap("ldrParticipants", MessageCollectionItemType.UUID, IGNITE_UUID, false);
 
                 if (!reader.isLastRead())
                     return false;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
index f63b861..f1e5b69 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
@@ -658,7 +658,11 @@ public class IgnitionEx {
      * @throws IgniteCheckedException If grid could not be started. This exception will be thrown
      *      also if named grid has already been started.
      */
-    public static T2<Ignite, Boolean> start(IgniteConfiguration cfg, @Nullable GridSpringResourceContext springCtx, boolean failIfStarted) throws IgniteCheckedException {
+    public static T2<Ignite, Boolean> start(
+        IgniteConfiguration cfg,
+        @Nullable GridSpringResourceContext springCtx,
+        boolean failIfStarted
+    ) throws IgniteCheckedException {
         A.notNull(cfg, "cfg");
 
         T2<IgniteNamedInstance, Boolean> res = start0(new GridStartContext(cfg, null, springCtx), failIfStarted);
@@ -1098,7 +1102,10 @@ public class IgnitionEx {
      *      the flag is {@code false}.
      * @throws IgniteCheckedException If grid could not be started.
      */
-    private static T2<IgniteNamedInstance, Boolean> start0(GridStartContext startCtx, boolean failIfStarted ) throws IgniteCheckedException {
+    private static T2<IgniteNamedInstance, Boolean> start0(
+        GridStartContext startCtx,
+        boolean failIfStarted
+    ) throws IgniteCheckedException {
         assert startCtx != null;
 
         String name = startCtx.config().getIgniteInstanceName();
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/binary/BinaryUtils.java b/modules/core/src/main/java/org/apache/ignite/internal/binary/BinaryUtils.java
index 22a95fa..c89e82f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/binary/BinaryUtils.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/binary/BinaryUtils.java
@@ -200,11 +200,14 @@ public class BinaryUtils {
         PLAIN_CLASS_TO_FLAG.put(boolean.class, GridBinaryMarshaller.BOOLEAN);
 
         for (byte b : new byte[] {
-            GridBinaryMarshaller.BYTE, GridBinaryMarshaller.SHORT, GridBinaryMarshaller.INT, GridBinaryMarshaller.LONG, GridBinaryMarshaller.FLOAT, GridBinaryMarshaller.DOUBLE,
-            GridBinaryMarshaller.CHAR, GridBinaryMarshaller.BOOLEAN, GridBinaryMarshaller.DECIMAL, GridBinaryMarshaller.STRING, GridBinaryMarshaller.UUID, GridBinaryMarshaller.DATE, GridBinaryMarshaller.TIMESTAMP, GridBinaryMarshaller.TIME,
-            GridBinaryMarshaller.BYTE_ARR, GridBinaryMarshaller.SHORT_ARR, GridBinaryMarshaller.INT_ARR, GridBinaryMarshaller.LONG_ARR, GridBinaryMarshaller.FLOAT_ARR, GridBinaryMarshaller.DOUBLE_ARR, GridBinaryMarshaller.TIME_ARR,
-            GridBinaryMarshaller.CHAR_ARR, GridBinaryMarshaller.BOOLEAN_ARR, GridBinaryMarshaller.DECIMAL_ARR, GridBinaryMarshaller.STRING_ARR, GridBinaryMarshaller.UUID_ARR, GridBinaryMarshaller.DATE_ARR, GridBinaryMarshaller.TIMESTAMP_ARR,
-            GridBinaryMarshaller.ENUM, GridBinaryMarshaller.ENUM_ARR, GridBinaryMarshaller.NULL}) {
+            GridBinaryMarshaller.BYTE, GridBinaryMarshaller.SHORT, GridBinaryMarshaller.INT, GridBinaryMarshaller.LONG,
+            GridBinaryMarshaller.FLOAT, GridBinaryMarshaller.DOUBLE, GridBinaryMarshaller.CHAR, GridBinaryMarshaller.BOOLEAN,
+            GridBinaryMarshaller.DECIMAL, GridBinaryMarshaller.STRING, GridBinaryMarshaller.UUID, GridBinaryMarshaller.DATE,
+            GridBinaryMarshaller.TIMESTAMP, GridBinaryMarshaller.TIME, GridBinaryMarshaller.BYTE_ARR, GridBinaryMarshaller.SHORT_ARR,
+            GridBinaryMarshaller.INT_ARR, GridBinaryMarshaller.LONG_ARR, GridBinaryMarshaller.FLOAT_ARR, GridBinaryMarshaller.DOUBLE_ARR,
+            GridBinaryMarshaller.TIME_ARR, GridBinaryMarshaller.CHAR_ARR, GridBinaryMarshaller.BOOLEAN_ARR,
+            GridBinaryMarshaller.DECIMAL_ARR, GridBinaryMarshaller.STRING_ARR, GridBinaryMarshaller.UUID_ARR, GridBinaryMarshaller.DATE_ARR,
+            GridBinaryMarshaller.TIMESTAMP_ARR, GridBinaryMarshaller.ENUM, GridBinaryMarshaller.ENUM_ARR, GridBinaryMarshaller.NULL}) {
 
             PLAIN_TYPE_FLAG[b] = true;
         }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/binary/streams/BinaryMemoryAllocator.java b/modules/core/src/main/java/org/apache/ignite/internal/binary/streams/BinaryMemoryAllocator.java
index 8993fb3..a49daa7 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/binary/streams/BinaryMemoryAllocator.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/binary/streams/BinaryMemoryAllocator.java
@@ -39,7 +39,8 @@ public abstract class BinaryMemoryAllocator {
     private static final Long CHECK_FREQ = Long.getLong(IGNITE_MARSHAL_BUFFERS_RECHECK, DFLT_MARSHAL_BUFFERS_RECHECK);
 
     /** */
-    private static final int POOL_SIZE = Integer.getInteger(IGNITE_MARSHAL_BUFFERS_PER_THREAD_POOL_SIZE, DFLT_MARSHAL_BUFFERS_PER_THREAD_POOL_SIZE);
+    private static final int POOL_SIZE =
+        Integer.getInteger(IGNITE_MARSHAL_BUFFERS_PER_THREAD_POOL_SIZE, DFLT_MARSHAL_BUFFERS_PER_THREAD_POOL_SIZE);
 
     /** Thread local allocator instance. */
     public static final BinaryMemoryAllocator THREAD_LOCAL = new ThreadLocalAllocator();
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/cache/query/index/sorted/inline/InlineIndexImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/cache/query/index/sorted/inline/InlineIndexImpl.java
index 3a91a34..5dee50e 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/cache/query/index/sorted/inline/InlineIndexImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/cache/query/index/sorted/inline/InlineIndexImpl.java
@@ -89,7 +89,12 @@ public class InlineIndexImpl extends AbstractIndex implements InlineIndex {
     }
 
     /** {@inheritDoc} */
-    @Override public GridCursor<IndexRow> find(IndexRow lower, IndexRow upper, int segment, IndexQueryContext qryCtx) throws IgniteCheckedException {
+    @Override public GridCursor<IndexRow> find(
+        IndexRow lower,
+        IndexRow upper,
+        int segment,
+        IndexQueryContext qryCtx
+    ) throws IgniteCheckedException {
         InlineTreeFilterClosure closure = filterClosure(qryCtx);
 
         // If it is known that only one row will be returned an optimization is employed
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/client/thin/IgniteClientFutureImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/client/thin/IgniteClientFutureImpl.java
index cf12241..64013f9 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/client/thin/IgniteClientFutureImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/client/thin/IgniteClientFutureImpl.java
@@ -138,32 +138,52 @@ public class IgniteClientFutureImpl<T> implements IgniteClientFuture<T> {
     }
 
     /** {@inheritDoc} */
-    @Override public <U, V> CompletableFuture<V> thenCombine(CompletionStage<? extends U> completionStage, BiFunction<? super T, ? super U, ? extends V> biFunction) {
+    @Override public <U, V> CompletableFuture<V> thenCombine(
+        CompletionStage<? extends U> completionStage,
+        BiFunction<? super T, ? super U, ? extends V> biFunction
+    ) {
         return fut.thenCombine(completionStage, biFunction);
     }
 
     /** {@inheritDoc} */
-    @Override public <U, V> CompletableFuture<V> thenCombineAsync(CompletionStage<? extends U> completionStage, BiFunction<? super T, ? super U, ? extends V> biFunction) {
+    @Override public <U, V> CompletableFuture<V> thenCombineAsync(
+        CompletionStage<? extends U> completionStage,
+        BiFunction<? super T, ? super U, ? extends V> biFunction
+    ) {
         return fut.thenCombineAsync(completionStage, biFunction);
     }
 
     /** {@inheritDoc} */
-    @Override public <U, V> CompletableFuture<V> thenCombineAsync(CompletionStage<? extends U> completionStage, BiFunction<? super T, ? super U, ? extends V> biFunction, Executor executor) {
+    @Override public <U, V> CompletableFuture<V> thenCombineAsync(
+        CompletionStage<? extends U> completionStage,
+        BiFunction<? super T, ? super U, ? extends V> biFunction,
+        Executor executor
+    ) {
         return fut.thenCombineAsync(completionStage, biFunction, executor);
     }
 
     /** {@inheritDoc} */
-    @Override public <U> CompletableFuture<Void> thenAcceptBoth(CompletionStage<? extends U> completionStage, BiConsumer<? super T, ? super U> biConsumer) {
+    @Override public <U> CompletableFuture<Void> thenAcceptBoth(
+        CompletionStage<? extends U> completionStage,
+        BiConsumer<? super T, ? super U> biConsumer
+    ) {
         return fut.thenAcceptBoth(completionStage, biConsumer);
     }
 
     /** {@inheritDoc} */
-    @Override public <U> CompletableFuture<Void> thenAcceptBothAsync(CompletionStage<? extends U> completionStage, BiConsumer<? super T, ? super U> biConsumer) {
+    @Override public <U> CompletableFuture<Void> thenAcceptBothAsync(
+        CompletionStage<? extends U> completionStage,
+        BiConsumer<? super T, ? super U> biConsumer
+    ) {
         return fut.thenAcceptBothAsync(completionStage, biConsumer);
     }
 
     /** {@inheritDoc} */
-    @Override public <U> CompletableFuture<Void> thenAcceptBothAsync(CompletionStage<? extends U> completionStage, BiConsumer<? super T, ? super U> biConsumer, Executor executor) {
+    @Override public <U> CompletableFuture<Void> thenAcceptBothAsync(
+        CompletionStage<? extends U> completionStage,
+        BiConsumer<? super T, ? super U> biConsumer,
+        Executor executor
+    ) {
         return fut.thenAcceptBothAsync(completionStage, biConsumer, executor);
     }
 
@@ -188,12 +208,19 @@ public class IgniteClientFutureImpl<T> implements IgniteClientFuture<T> {
     }
 
     /** {@inheritDoc} */
-    @Override public <U> CompletableFuture<U> applyToEitherAsync(CompletionStage<? extends T> completionStage, Function<? super T, U> function) {
+    @Override public <U> CompletableFuture<U> applyToEitherAsync(
+        CompletionStage<? extends T> completionStage,
+        Function<? super T, U> function
+    ) {
         return fut.applyToEitherAsync(completionStage, function);
     }
 
     /** {@inheritDoc} */
-    @Override public <U> CompletableFuture<U> applyToEitherAsync(CompletionStage<? extends T> completionStage, Function<? super T, U> function, Executor executor) {
+    @Override public <U> CompletableFuture<U> applyToEitherAsync(
+        CompletionStage<? extends T> completionStage,
+        Function<? super T, U> function,
+        Executor executor
+    ) {
         return fut.applyToEitherAsync(completionStage, function, executor);
     }
 
@@ -208,7 +235,11 @@ public class IgniteClientFutureImpl<T> implements IgniteClientFuture<T> {
     }
 
     /** {@inheritDoc} */
-    @Override public CompletableFuture<Void> acceptEitherAsync(CompletionStage<? extends T> completionStage, Consumer<? super T> consumer, Executor executor) {
+    @Override public CompletableFuture<Void> acceptEitherAsync(
+        CompletionStage<? extends T> completionStage,
+        Consumer<? super T> consumer,
+        Executor executor
+    ) {
         return fut.acceptEitherAsync(completionStage, consumer, executor);
     }
 
@@ -238,7 +269,10 @@ public class IgniteClientFutureImpl<T> implements IgniteClientFuture<T> {
     }
 
     /** {@inheritDoc} */
-    @Override public <U> CompletableFuture<U> thenComposeAsync(Function<? super T, ? extends CompletionStage<U>> function, Executor executor) {
+    @Override public <U> CompletableFuture<U> thenComposeAsync(
+        Function<? super T, ? extends CompletionStage<U>> function,
+        Executor executor
+    ) {
         return fut.thenComposeAsync(function, executor);
     }
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/cluster/IgniteClusterImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/cluster/IgniteClusterImpl.java
index 3b55295..309172b 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/cluster/IgniteClusterImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/cluster/IgniteClusterImpl.java
@@ -729,8 +729,11 @@ public class IgniteClusterImpl extends ClusterGroupAdapter implements IgniteClus
                 " symbols.");
         }
 
-        if (!ctx.state().publicApiActiveState(true))
-            throw new IgniteCheckedException("Can not change cluster tag on inactive cluster. To activate the cluster call Ignite.active(true).");
+        if (!ctx.state().publicApiActiveState(true)) {
+            throw new IgniteCheckedException(
+                "Can not change cluster tag on inactive cluster. To activate the cluster call Ignite.active(true)."
+            );
+        }
 
         ctx.cluster().updateTag(tag);
     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/jdbc/thin/JdbcThinConnection.java b/modules/core/src/main/java/org/apache/ignite/internal/jdbc/thin/JdbcThinConnection.java
index 4af0d5a..0728589 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/jdbc/thin/JdbcThinConnection.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/jdbc/thin/JdbcThinConnection.java
@@ -2234,7 +2234,11 @@ public class JdbcThinConnection implements Connection {
         /** {@inheritDoc} */
         @Override public String getClassName(byte platformId, int typeId) throws ClassNotFoundException, IgniteCheckedException {
             assert platformId == MarshallerPlatformIds.JAVA_ID
-                : String.format("Only Java platform is supported [expPlatformId=%d, actualPlatformId=%d].", MarshallerPlatformIds.JAVA_ID, platformId);
+                : String.format(
+                    "Only Java platform is supported [expPlatformId=%d, actualPlatformId=%d].",
+                    MarshallerPlatformIds.JAVA_ID,
+                    platformId
+                  );
 
             String clsName = cache.get(typeId);
             if (clsName == null) {
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/managers/GridManagerAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/managers/GridManagerAdapter.java
index ba9a1e5..7329bcf 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/managers/GridManagerAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/managers/GridManagerAdapter.java
@@ -544,7 +544,8 @@ public abstract class GridManagerAdapter<T extends IgniteSpi> implements GridMan
                             if (comp.discoveryDataType() == null)
                                 continue;
 
-                            IgniteNodeValidationResult err = comp.validateNode(node, discoData.newJoinerDiscoveryData(comp.discoveryDataType().ordinal()));
+                            IgniteNodeValidationResult err =
+                                comp.validateNode(node, discoData.newJoinerDiscoveryData(comp.discoveryDataType().ordinal()));
 
                             if (err != null)
                                 return err;
@@ -724,7 +725,10 @@ public abstract class GridManagerAdapter<T extends IgniteSpi> implements GridMan
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public IgniteNodeValidationResult validateNode(ClusterNode node, DiscoveryDataBag.JoiningNodeDiscoveryData discoData) {
+    @Nullable @Override public IgniteNodeValidationResult validateNode(
+        ClusterNode node,
+        DiscoveryDataBag.JoiningNodeDiscoveryData discoData
+    ) {
         return null;
     }
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java b/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java
index 38bf3b5..38a0c3b 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java
@@ -2530,13 +2530,19 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
         DiscoverySpi discoverySpi = cfg.getDiscoverySpi();
 
         if (rslvr != null) {
-            if (!supportsCommunicationErrorResolve(commSpi))
-                throw new IgniteCheckedException("CommunicationFailureResolver is configured, but CommunicationSpi does not support communication" +
-                    "problem resolve: " + commSpi.getClass().getName());
+            if (!supportsCommunicationErrorResolve(commSpi)) {
+                throw new IgniteCheckedException(
+                    "CommunicationFailureResolver is configured, but CommunicationSpi does not support communication" +
+                    "problem resolve: " + commSpi.getClass().getName()
+                );
+            }
 
-            if (!supportsCommunicationErrorResolve(discoverySpi))
-                throw new IgniteCheckedException("CommunicationFailureResolver is configured, but DiscoverySpi does not support communication" +
-                    "problem resolve: " + discoverySpi.getClass().getName());
+            if (!supportsCommunicationErrorResolve(discoverySpi)) {
+                throw new IgniteCheckedException(
+                    "CommunicationFailureResolver is configured, but DiscoverySpi does not support communication" +
+                    "problem resolve: " + discoverySpi.getClass().getName()
+                );
+            }
         }
         else {
             if (supportsCommunicationErrorResolve(commSpi) && supportsCommunicationErrorResolve(discoverySpi))
@@ -2899,7 +2905,14 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
          * @param topSnapshot Topology snapshot.
          */
         @SuppressWarnings("RedundantTypeArguments")
-        private void recordEvent(int type, long topVer, ClusterNode node, DiscoCache discoCache, Collection<ClusterNode> topSnapshot, @Nullable SpanContainer spanContainer) {
+        private void recordEvent(
+            int type,
+            long topVer,
+            ClusterNode node,
+            DiscoCache discoCache,
+            Collection<ClusterNode> topSnapshot,
+            @Nullable SpanContainer spanContainer
+        ) {
             assert node != null;
 
             if (ctx.event().isRecordable(type)) {
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/managers/encryption/GridEncryptionManager.java b/modules/core/src/main/java/org/apache/ignite/internal/managers/encryption/GridEncryptionManager.java
index 0bb90d2..abc626b 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/managers/encryption/GridEncryptionManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/managers/encryption/GridEncryptionManager.java
@@ -103,7 +103,8 @@ import static org.apache.ignite.internal.util.distributed.DistributedProcess.Dis
  *     <li>Joining node:
  *     <ul>
  *         <li>1. Collects and send all stored group keys to coordinator.</li>
- *         <li>2. Generate(but doesn't store locally!) and send keys for all statically configured groups in case the not presented in metastore.</li>
+ *         <li>2. Generate(but doesn't store locally!)
+ *         and send keys for all statically configured groups in case the not presented in metastore.</li>
  *         <li>3. Store all keys received from coordinator to local store.</li>
  *     </ul>
  *     </li>
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/metric/IoStatisticsHolderQuery.java b/modules/core/src/main/java/org/apache/ignite/internal/metric/IoStatisticsHolderQuery.java
index e9ce9ac..b7884e5 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/metric/IoStatisticsHolderQuery.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/metric/IoStatisticsHolderQuery.java
@@ -23,7 +23,8 @@ import org.apache.ignite.internal.util.typedef.internal.S;
 
 /**
  * Query Statistics holder to gather statistics related to concrete query.
- * Used in {@code org.apache.ignite.internal.stat.IoStatisticsHolderIndex} and {@code org.apache.ignite.internal.stat.IoStatisticsHolderCache}.
+ * Used in {@code org.apache.ignite.internal.stat.IoStatisticsHolderIndex}
+ * and {@code org.apache.ignite.internal.stat.IoStatisticsHolderCache}.
  * Query Statistics holder to gather statistics related to concrete query. Used in {@code
  * org.apache.ignite.internal.stat.IoStatisticsHolderIndex} and {@code org.apache.ignite.internal.stat.IoStatisticsHolderCache}.
  */
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/pagemem/store/IgnitePageStoreManager.java b/modules/core/src/main/java/org/apache/ignite/internal/pagemem/store/IgnitePageStoreManager.java
index da606a68..30459e0 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/pagemem/store/IgnitePageStoreManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/pagemem/store/IgnitePageStoreManager.java
@@ -130,7 +130,13 @@ public interface IgnitePageStoreManager extends GridCacheSharedManager, IgniteCh
      * @param pageBuf Page buffer to write.
      * @throws IgniteCheckedException If failed to write page.
      */
-    @Override public PageStore write(int grpId, long pageId, ByteBuffer pageBuf, int tag, boolean calculateCrc) throws IgniteCheckedException;
+    @Override public PageStore write(
+        int grpId,
+        long pageId,
+        ByteBuffer pageBuf,
+        int tag,
+        boolean calculateCrc
+    ) throws IgniteCheckedException;
 
     /**
      * Gets page offset within the page store file.
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/DataEntry.java b/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/DataEntry.java
index 73de55b..9376bb0 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/DataEntry.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/DataEntry.java
@@ -100,7 +100,10 @@ public class DataEntry {
         this.partCnt = partCnt;
 
         // Only READ, CREATE, UPDATE and DELETE operations should be stored in WAL.
-        assert op == GridCacheOperation.READ || op == GridCacheOperation.CREATE || op == GridCacheOperation.UPDATE || op == GridCacheOperation.DELETE : op;
+        assert op == GridCacheOperation.READ
+            || op == GridCacheOperation.CREATE
+            || op == GridCacheOperation.UPDATE
+            || op == GridCacheOperation.DELETE : op;
     }
 
     /**
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/WALRecord.java b/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/WALRecord.java
index 8f49e5d..52461698 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/WALRecord.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/WALRecord.java
@@ -337,7 +337,8 @@ public abstract class WALRecord {
         INTERNAL,
         /**
          * Physical records are needed for correct recovering physical state of {@link org.apache.ignite.internal.pagemem.PageMemory}.
-         * {@link org.apache.ignite.internal.processors.cache.persistence.GridCacheDatabaseSharedManager#restoreBinaryMemory(org.apache.ignite.lang.IgnitePredicate, org.apache.ignite.lang.IgniteBiPredicate)}.
+         * {@link org.apache.ignite.internal.processors.cache.persistence.GridCacheDatabaseSharedManager#restoreBinaryMemory(
+         * org.apache.ignite.lang.IgnitePredicate, org.apache.ignite.lang.IgniteBiPredicate)}.
          */
         PHYSICAL,
         /**
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/delta/MetaPageUpdatePartitionDataRecordV2.java b/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/delta/MetaPageUpdatePartitionDataRecordV2.java
index ab3ccf8..ab0468b 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/delta/MetaPageUpdatePartitionDataRecordV2.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/delta/MetaPageUpdatePartitionDataRecordV2.java
@@ -98,6 +98,13 @@ public class MetaPageUpdatePartitionDataRecordV2 extends MetaPageUpdatePartition
 
     /** {@inheritDoc} */
     @Override public String toString() {
-        return S.toString(MetaPageUpdatePartitionDataRecordV2.class, this, "partId", PageIdUtils.partId(pageId()), "super", super.toString());
+        return S.toString(
+            MetaPageUpdatePartitionDataRecordV2.class,
+            this,
+            "partId",
+            PageIdUtils.partId(pageId()),
+            "super",
+            super.toString()
+        );
     }
 }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/GridProcessorAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/GridProcessorAdapter.java
index 6496b6c..9feb265 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/GridProcessorAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/GridProcessorAdapter.java
@@ -151,7 +151,10 @@ public abstract class GridProcessorAdapter implements GridProcessor {
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public IgniteNodeValidationResult validateNode(ClusterNode node, DiscoveryDataBag.JoiningNodeDiscoveryData discoData) {
+    @Nullable @Override public IgniteNodeValidationResult validateNode(
+        ClusterNode node,
+        DiscoveryDataBag.JoiningNodeDiscoveryData discoData
+    ) {
         return null;
     }
 
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 6f72610..78d3b86 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
@@ -833,8 +833,8 @@ public class GridAffinityAssignmentCache {
             }
         }
 
-        assert cache.topologyVersion().compareTo(lastAffChangeTopVer) >= 0 &&
-            cache.topologyVersion().compareTo(topVer) <= 0 : "Invalid cached affinity: [cache=" + cache + ", topVer=" + topVer + ", lastAffChangedTopVer=" + lastAffChangeTopVer + "]";
+        assert cache.topologyVersion().compareTo(lastAffChangeTopVer) >= 0 && cache.topologyVersion().compareTo(topVer) <= 0
+            : "Invalid cached affinity: [cache=" + cache + ", topVer=" + topVer + ", lastAffChangedTopVer=" + lastAffChangeTopVer + "]";
 
         return cache;
     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/affinity/GridAffinityProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/affinity/GridAffinityProcessor.java
index 64cf18d..1f57c17 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/affinity/GridAffinityProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/affinity/GridAffinityProcessor.java
@@ -613,24 +613,27 @@ public class GridAffinityProcessor extends GridProcessorAdapter {
         IgniteInternalFuture<GridTuple3<GridAffinityMessage, GridAffinityMessage, GridAffinityAssignment>> fut = ctx.closure()
             .callAsyncNoFailover(BROADCAST, affinityJob(cacheName, topVer), F.asList(n), true/*system pool*/, 0, false);
 
-        return fut.chain(new CX1<IgniteInternalFuture<GridTuple3<GridAffinityMessage, GridAffinityMessage, GridAffinityAssignment>>, AffinityInfo>() {
-            @Override public AffinityInfo applyx(IgniteInternalFuture<GridTuple3<GridAffinityMessage, GridAffinityMessage, GridAffinityAssignment>> fut) throws IgniteCheckedException {
-                GridTuple3<GridAffinityMessage, GridAffinityMessage, GridAffinityAssignment> t = fut.get();
+        return fut.chain(
+            new CX1<IgniteInternalFuture<GridTuple3<GridAffinityMessage, GridAffinityMessage, GridAffinityAssignment>>, AffinityInfo>() {
+                @Override public AffinityInfo applyx(
+                    IgniteInternalFuture<GridTuple3<GridAffinityMessage, GridAffinityMessage, GridAffinityAssignment>> fut
+                ) throws IgniteCheckedException {
+                    GridTuple3<GridAffinityMessage, GridAffinityMessage, GridAffinityAssignment> t = fut.get();
 
-                AffinityFunction f = (AffinityFunction)unmarshall(ctx, n.id(), t.get1());
-                AffinityKeyMapper m = (AffinityKeyMapper)unmarshall(ctx, n.id(), t.get2());
+                    AffinityFunction f = (AffinityFunction)unmarshall(ctx, n.id(), t.get1());
+                    AffinityKeyMapper m = (AffinityKeyMapper)unmarshall(ctx, n.id(), t.get2());
 
-                assert m != null;
+                    assert m != null;
 
-                // Bring to initial state.
-                f.reset();
-                m.reset();
+                    // Bring to initial state.
+                    f.reset();
+                    m.reset();
 
-                CacheConfiguration ccfg = ctx.cache().cacheConfiguration(cacheName);
+                    CacheConfiguration ccfg = ctx.cache().cacheConfiguration(cacheName);
 
-                return new AffinityInfo(f, m, t.get3(), ctx.cacheObjects().contextForCache(ccfg));
-            }
-        });
+                    return new AffinityInfo(f, m, t.get3(), ctx.cacheObjects().contextForCache(ccfg));
+                }
+            });
     }
 
     /**
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheGroupMetricsImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheGroupMetricsImpl.java
index b7c0300..10d39eb 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheGroupMetricsImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheGroupMetricsImpl.java
@@ -109,7 +109,8 @@ public class CacheGroupMetricsImpl {
         idxBuildCntPartitionsLeft = mreg.longMetric("IndexBuildCountPartitionsLeft",
             "Number of partitions need processed for finished indexes create or rebuilding.");
 
-        initLocalPartitionsNumber = mreg.longMetric("InitializedLocalPartitionsNumber", "Number of local partitions initialized on current node.");
+        initLocalPartitionsNumber =
+            mreg.longMetric("InitializedLocalPartitionsNumber", "Number of local partitions initialized on current node.");
 
         DataRegion region = ctx.dataRegion();
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheLazyEntry.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheLazyEntry.java
index 45adbfe..9caf383 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheLazyEntry.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheLazyEntry.java
@@ -134,8 +134,13 @@ public class CacheLazyEntry<K, V> extends CacheInterceptorEntry<K, V> {
 
     /** {@inheritDoc} */
     @Override public K getKey() {
-        if (key == null)
-            key = (K)cctx.unwrapBinaryIfNeeded(keyObj, keepBinary, U.deploymentClassLoader(cctx.kernalContext(), U.contextDeploymentClassLoaderId(cctx.kernalContext())));
+        if (key == null) {
+            key = (K)cctx.unwrapBinaryIfNeeded(
+                keyObj,
+                keepBinary,
+                U.deploymentClassLoader(cctx.kernalContext(), U.contextDeploymentClassLoaderId(cctx.kernalContext()))
+            );
+        }
 
         return key;
     }
@@ -152,8 +157,14 @@ public class CacheLazyEntry<K, V> extends CacheInterceptorEntry<K, V> {
      * @return the value corresponding to this entry
      */
     public V getValue(boolean keepBinary) {
-        if (val == null)
-            val = (V)cctx.unwrapBinaryIfNeeded(valObj, keepBinary, true, U.deploymentClassLoader(cctx.kernalContext(), U.contextDeploymentClassLoaderId(cctx.kernalContext())));
+        if (val == null) {
+            val = (V)cctx.unwrapBinaryIfNeeded(
+                valObj,
+                keepBinary,
+                true,
+                U.deploymentClassLoader(cctx.kernalContext(), U.contextDeploymentClassLoaderId(cctx.kernalContext()))
+            );
+        }
 
         return val;
     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheMetricsImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheMetricsImpl.java
index 0b2ee8c..3783870 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheMetricsImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheMetricsImpl.java
@@ -215,7 +215,8 @@ public class CacheMetricsImpl implements CacheMetrics {
     private GridCacheWriteBehindStore store;
 
     /** Tx collisions info. */
-    private volatile Supplier<List<Map.Entry</* Colliding keys. */ GridCacheMapEntry, /* Collisions queue size. */ Integer>>> txKeyCollisionInfo;
+    private volatile Supplier<List<Map.Entry</* Colliding keys. */ GridCacheMapEntry, /* Collisions queue size. */ Integer>>>
+        txKeyCollisionInfo;
 
     /** Offheap entries count. */
     private final LongGauge offHeapEntriesCnt;
@@ -915,7 +916,9 @@ public class CacheMetricsImpl implements CacheMetrics {
      *
      * @param coll Key collisions info holder.
      */
-    public void keyCollisionsInfo(Supplier<List<Map.Entry</* Colliding keys. */ GridCacheMapEntry, /* Collisions queue size. */ Integer>>> coll) {
+    public void keyCollisionsInfo(
+        Supplier<List<Map.Entry</* Colliding keys. */ GridCacheMapEntry, /* Collisions queue size. */ Integer>>> coll
+    ) {
         txKeyCollisionInfo = coll;
 
         if (delegate != null)
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/ClusterCachesInfo.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/ClusterCachesInfo.java
index 236051a..235f69a 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/ClusterCachesInfo.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/ClusterCachesInfo.java
@@ -385,7 +385,8 @@ public class ClusterCachesInfo {
     private void checkCache(CacheJoinNodeDiscoveryData.CacheInfo locInfo, CacheData rmtData, UUID rmt)
         throws IgniteCheckedException {
         GridCacheAttributes rmtAttr = new GridCacheAttributes(rmtData.cacheConfiguration(), rmtData.cacheConfigurationEnrichment());
-        GridCacheAttributes locAttr = new GridCacheAttributes(locInfo.cacheData().config(), locInfo.cacheData().cacheConfigurationEnrichment());
+        GridCacheAttributes locAttr =
+            new GridCacheAttributes(locInfo.cacheData().config(), locInfo.cacheData().cacheConfigurationEnrichment());
 
         CU.checkAttributeMismatch(log, rmtAttr.cacheName(), rmt, "cacheMode", "Cache mode",
             locAttr.cacheMode(), rmtAttr.cacheMode(), true);
@@ -1422,7 +1423,9 @@ public class ClusterCachesInfo {
             if (!cachesToDestroy.isEmpty()) {
                 ctx.cache().dynamicDestroyCaches(cachesToDestroy, false);
 
-                throw new IllegalStateException("Node can't join to cluster in compatibility mode with newly configured caches: " + cachesToDestroy);
+                throw new IllegalStateException(
+                    "Node can't join to cluster in compatibility mode with newly configured caches: " + cachesToDestroy
+                );
             }
         }
     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GatewayProtectedCacheProxy.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GatewayProtectedCacheProxy.java
index af34c12..2cc3b14 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GatewayProtectedCacheProxy.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GatewayProtectedCacheProxy.java
@@ -316,7 +316,10 @@ public class GatewayProtectedCacheProxy<K, V> extends AsyncSupportAdapter<Ignite
     }
 
     /** {@inheritDoc} */
-    @Override public IgniteFuture<Void> loadCacheAsync(@Nullable IgniteBiPredicate<K, V> p, @Nullable Object... args) throws CacheException {
+    @Override public IgniteFuture<Void> loadCacheAsync(
+        @Nullable IgniteBiPredicate<K, V> p,
+        @Nullable Object... args
+    ) throws CacheException {
         CacheOperationGate opGate = onEnter();
 
         try {
@@ -340,7 +343,10 @@ public class GatewayProtectedCacheProxy<K, V> extends AsyncSupportAdapter<Ignite
     }
 
     /** {@inheritDoc} */
-    @Override public IgniteFuture<Void> localLoadCacheAsync(@Nullable IgniteBiPredicate<K, V> p, @Nullable Object... args) throws CacheException {
+    @Override public IgniteFuture<Void> localLoadCacheAsync(
+        @Nullable IgniteBiPredicate<K, V> p,
+        @Nullable Object... args
+    ) throws CacheException {
         CacheOperationGate opGate = onEnter();
 
         try {
@@ -645,7 +651,10 @@ public class GatewayProtectedCacheProxy<K, V> extends AsyncSupportAdapter<Ignite
     }
 
     /** {@inheritDoc} */
-    @Override public <T> Map<K, EntryProcessorResult<T>> invokeAll(Map<? extends K, ? extends EntryProcessor<K, V, T>> map, Object... args) throws TransactionException {
+    @Override public <T> Map<K, EntryProcessorResult<T>> invokeAll(
+        Map<? extends K, ? extends EntryProcessor<K, V, T>> map,
+        Object... args
+    ) throws TransactionException {
         CacheOperationGate opGate = onEnter();
 
         try {
@@ -657,7 +666,10 @@ public class GatewayProtectedCacheProxy<K, V> extends AsyncSupportAdapter<Ignite
     }
 
     /** {@inheritDoc} */
-    @Override public <T> IgniteFuture<Map<K, EntryProcessorResult<T>>> invokeAllAsync(Map<? extends K, ? extends EntryProcessor<K, V, T>> map, Object... args) throws TransactionException {
+    @Override public <T> IgniteFuture<Map<K, EntryProcessorResult<T>>> invokeAllAsync(
+        Map<? extends K, ? extends EntryProcessor<K, V, T>> map,
+        Object... args
+    ) throws TransactionException {
         CacheOperationGate opGate = onEnter();
 
         try {
@@ -1245,7 +1257,11 @@ public class GatewayProtectedCacheProxy<K, V> extends AsyncSupportAdapter<Ignite
     }
 
     /** {@inheritDoc} */
-    @Override public <T> IgniteFuture<T> invokeAsync(K key, EntryProcessor<K, V, T> entryProcessor, Object... arguments) throws TransactionException {
+    @Override public <T> IgniteFuture<T> invokeAsync(
+        K key,
+        EntryProcessor<K, V, T> entryProcessor,
+        Object... arguments
+    ) throws TransactionException {
         CacheOperationGate opGate = onEnter();
 
         try {
@@ -1269,7 +1285,11 @@ public class GatewayProtectedCacheProxy<K, V> extends AsyncSupportAdapter<Ignite
     }
 
     /** {@inheritDoc} */
-    @Override public <T> IgniteFuture<T> invokeAsync(K key, CacheEntryProcessor<K, V, T> entryProcessor, Object... arguments) throws TransactionException {
+    @Override public <T> IgniteFuture<T> invokeAsync(
+        K key,
+        CacheEntryProcessor<K, V, T> entryProcessor,
+        Object... arguments
+    ) throws TransactionException {
         CacheOperationGate opGate = onEnter();
 
         try {
@@ -1281,7 +1301,11 @@ public class GatewayProtectedCacheProxy<K, V> extends AsyncSupportAdapter<Ignite
     }
 
     /** {@inheritDoc} */
-    @Override public <T> Map<K, EntryProcessorResult<T>> invokeAll(Set<? extends K> keys, EntryProcessor<K, V, T> entryProcessor, Object... args) throws TransactionException {
+    @Override public <T> Map<K, EntryProcessorResult<T>> invokeAll(
+        Set<? extends K> keys,
+        EntryProcessor<K, V, T> entryProcessor,
+        Object... args
+    ) throws TransactionException {
         CacheOperationGate opGate = onEnter();
 
         try {
@@ -1293,7 +1317,11 @@ public class GatewayProtectedCacheProxy<K, V> extends AsyncSupportAdapter<Ignite
     }
 
     /** {@inheritDoc} */
-    @Override public <T> IgniteFuture<Map<K, EntryProcessorResult<T>>> invokeAllAsync(Set<? extends K> keys, EntryProcessor<K, V, T> entryProcessor, Object... args) throws TransactionException {
+    @Override public <T> IgniteFuture<Map<K, EntryProcessorResult<T>>> invokeAllAsync(
+        Set<? extends K> keys,
+        EntryProcessor<K, V, T> entryProcessor,
+        Object... args
+    ) throws TransactionException {
         CacheOperationGate opGate = onEnter();
 
         try {
@@ -1305,7 +1333,11 @@ public class GatewayProtectedCacheProxy<K, V> extends AsyncSupportAdapter<Ignite
     }
 
     /** {@inheritDoc} */
-    @Override public <T> Map<K, EntryProcessorResult<T>> invokeAll(Set<? extends K> keys, CacheEntryProcessor<K, V, T> entryProcessor, Object... args) throws TransactionException {
+    @Override public <T> Map<K, EntryProcessorResult<T>> invokeAll(
+        Set<? extends K> keys,
+        CacheEntryProcessor<K, V, T> entryProcessor,
+        Object... args
+    ) throws TransactionException {
         CacheOperationGate opGate = onEnter();
 
         try {
@@ -1317,7 +1349,11 @@ public class GatewayProtectedCacheProxy<K, V> extends AsyncSupportAdapter<Ignite
     }
 
     /** {@inheritDoc} */
-    @Override public <T> IgniteFuture<Map<K, EntryProcessorResult<T>>> invokeAllAsync(Set<? extends K> keys, CacheEntryProcessor<K, V, T> entryProcessor, Object... args) throws TransactionException {
+    @Override public <T> IgniteFuture<Map<K, EntryProcessorResult<T>>> invokeAllAsync(
+        Set<? extends K> keys,
+        CacheEntryProcessor<K, V, T> entryProcessor,
+        Object... args
+    ) throws TransactionException {
         CacheOperationGate opGate = onEnter();
 
         try {
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
index 2eddcad..8a8e204 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
@@ -2885,7 +2885,7 @@ public abstract class GridCacheAdapter<K, V> implements IgniteInternalCache<K, V
 
                 assert ret != null;
 
-                return ret.value() != null ? ret.<Map<K, EntryProcessorResult<T>>>value() : Collections.<K, EntryProcessorResult<T>>emptyMap();
+                return ret.value() != null ? ret.value() : Collections.emptyMap();
             }
         });
     }
@@ -2933,7 +2933,9 @@ public abstract class GridCacheAdapter<K, V> implements IgniteInternalCache<K, V
 
                 assert ret != null;
 
-                return ret.value() != null ? ret.<Map<K, EntryProcessorResult<T>>>value() : Collections.<K, EntryProcessorResult<T>>emptyMap();
+                return ret.value() != null
+                    ? ret.<Map<K, EntryProcessorResult<T>>>value()
+                    : Collections.<K, EntryProcessorResult<T>>emptyMap();
             }
         });
     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheIoManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheIoManager.java
index 80c681d..1615223 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheIoManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheIoManager.java
@@ -1554,7 +1554,11 @@ public class GridCacheIoManager extends GridCacheSharedManagerAdapter {
      * @param topic Topic.
      * @param c Handler.
      */
-    public void addOrderedCacheGroupHandler(GridCacheSharedContext cctx, Object topic, IgniteBiInClosure<UUID, ? extends GridCacheGroupIdMessage> c) {
+    public void addOrderedCacheGroupHandler(
+        GridCacheSharedContext cctx,
+        Object topic,
+        IgniteBiInClosure<UUID, ? extends GridCacheGroupIdMessage> c
+    ) {
         addOrderedHandler(cctx, true, topic, c);
     }
 
@@ -1566,7 +1570,12 @@ public class GridCacheIoManager extends GridCacheSharedManagerAdapter {
      * @param topic Topic.
      * @param c Handler.
      */
-    private void addOrderedHandler(GridCacheSharedContext cctx, boolean cacheGrp, Object topic, IgniteBiInClosure<UUID, ? extends GridCacheMessage> c) {
+    private void addOrderedHandler(
+        GridCacheSharedContext cctx,
+        boolean cacheGrp,
+        Object topic,
+        IgniteBiInClosure<UUID, ? extends GridCacheMessage> c
+    ) {
         MessageHandlers msgHandlers = cacheGrp ? grpHandlers : cacheHandlers;
 
         IgniteLogger log0 = log;
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 2fde831..68c037a 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
@@ -5284,7 +5284,8 @@ public abstract class GridCacheMapEntry extends GridMetadataAwareAdapter impleme
                 else if (res.resultType() == ResultType.LOCKED) {
                     entry.unlockEntry();
 
-                    IgniteInternalFuture<?> lockFuture = cctx.kernalContext().coordinators().waitForLock(cctx, mvccVer, res.resultVersion());
+                    IgniteInternalFuture<?> lockFuture =
+                        cctx.kernalContext().coordinators().waitForLock(cctx, mvccVer, res.resultVersion());
 
                     lockFuture.listen(this);
 
@@ -7022,7 +7023,9 @@ public abstract class GridCacheMapEntry extends GridMetadataAwareAdapter impleme
      * @return Common serialization error.
      */
     private static IgniteTxSerializationCheckedException serializationError() {
-        return new IgniteTxSerializationCheckedException("Cannot serialize transaction due to write conflict (transaction is marked for rollback)");
+        return new IgniteTxSerializationCheckedException(
+            "Cannot serialize transaction due to write conflict (transaction is marked for rollback)"
+        );
     }
 
     /**
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 64bf456..3c831b9 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
@@ -461,8 +461,10 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
                         GridDhtPartitionsExchangeFuture currentExchange = lastTopologyFuture();
 
                         if (currentExchange != null && currentExchange.addOrMergeDelayedFullMessage(node, msg)) {
-                            if (log.isInfoEnabled())
-                                log.info("Delay process full message without exchange id (there is exchange in progress) [nodeId=" + node.id() + "]");
+                            if (log.isInfoEnabled()) {
+                                log.info("Delay process full message without exchange id (there is exchange in progress) " +
+                                    "[nodeId=" + node.id() + "]");
+                            }
 
                             return;
                         }
@@ -625,7 +627,9 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
 
                         baselineChanging = exchActions.changedBaseline()
                             // Or it is the first activation.
-                            || state.state() != ClusterState.INACTIVE && !state.previouslyActive() && state.previousBaselineTopology() == null;
+                            || state.state() != ClusterState.INACTIVE
+                                && !state.previouslyActive()
+                                && state.previousBaselineTopology() == null;
                     }
 
                     exchFut.listen(f -> onClusterStateChangeFinish(f, exchActions, baselineChanging));
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/ValidationOnNodeJoinUtils.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/ValidationOnNodeJoinUtils.java
index e5ef064..4e8f05f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/ValidationOnNodeJoinUtils.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/ValidationOnNodeJoinUtils.java
@@ -114,8 +114,8 @@ public class ValidationOnNodeJoinUtils {
     private static final IgniteProductVersion PRECISION_SCALE_SINCE_VER = IgniteProductVersion.fromString("2.7.0");
 
     /** Invalid region configuration message. */
-    private static final String INVALID_REGION_CONFIGURATION_MESSAGE = "Failed to join node " +
-        "(Incompatible data region configuration [region=%s, locNodeId=%s, isPersistenceEnabled=%s, rmtNodeId=%s, isPersistenceEnabled=%s])";
+    private static final String INVALID_REGION_CONFIGURATION_MESSAGE = "Failed to join node (Incompatible data region configuration " +
+        "[region=%s, locNodeId=%s, isPersistenceEnabled=%s, rmtNodeId=%s, isPersistenceEnabled=%s])";
 
     /**
      * Checks a joining node to configuration consistency.
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/binary/BinaryMetadataTransport.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/binary/BinaryMetadataTransport.java
index aa52237..d96b502 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/binary/BinaryMetadataTransport.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/binary/BinaryMetadataTransport.java
@@ -382,7 +382,8 @@ final class BinaryMetadataTransport {
 
     /** */
     void onDisconnected() {
-        cancelFutures(MetadataUpdateResult.createFailureResult(new BinaryObjectException("Failed to update or wait for metadata, client node disconnected")));
+        cancelFutures(MetadataUpdateResult.createFailureResult(
+                new BinaryObjectException("Failed to update or wait for metadata, client node disconnected")));
     }
 
     /**
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
index 9245f29..fbf14de 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
@@ -1622,7 +1622,11 @@ public class GridDhtAtomicCache<K, V> extends GridDhtCacheAdapter<K, V> {
                                             0,
                                             0,
                                             needVer,
-                                            U.deploymentClassLoader(ctx.kernalContext(), U.contextDeploymentClassLoaderId(ctx.kernalContext())));
+                                            U.deploymentClassLoader(
+                                                ctx.kernalContext(),
+                                                U.contextDeploymentClassLoaderId(ctx.kernalContext())
+                                            )
+                                        );
                                     }
                                 }
                                 else
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtColocatedCache.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtColocatedCache.java
index 298224a..2d1406a 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtColocatedCache.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtColocatedCache.java
@@ -647,7 +647,11 @@ public class GridDhtColocatedCache<K, V> extends GridDhtTransactionalCacheAdapte
                                             0,
                                             0,
                                             needVer,
-                                            U.deploymentClassLoader(ctx.kernalContext(), U.contextDeploymentClassLoaderId(ctx.kernalContext())));
+                                            U.deploymentClassLoader(
+                                                ctx.kernalContext(),
+                                                U.contextDeploymentClassLoaderId(ctx.kernalContext())
+                                            )
+                                        );
                                     }
                                 }
                                 else
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtColocatedLockFuture.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtColocatedLockFuture.java
index ef8bd87..d7e9922 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtColocatedLockFuture.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtColocatedLockFuture.java
@@ -1385,7 +1385,8 @@ public final class GridDhtColocatedLockFuture extends GridCacheCompoundIdentityF
 
         CacheOperationContext opCtx = cctx.operationContextPerCall();
 
-        CacheInvalidStateException validateCacheE = lastFinishedFut.validateCache(cctx, opCtx != null && opCtx.recovery(), read, null, keys);
+        CacheInvalidStateException validateCacheE =
+            lastFinishedFut.validateCache(cctx, opCtx != null && opCtx.recovery(), read, null, keys);
 
         if (validateCacheE != null)
             onDone(validateCacheE);
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtDetachedCacheEntry.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtDetachedCacheEntry.java
index 48b8e8e..080241b 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtDetachedCacheEntry.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtDetachedCacheEntry.java
@@ -73,7 +73,13 @@ public class GridDhtDetachedCacheEntry extends GridDistributedCacheEntry {
     }
 
     /** {@inheritDoc} */
-    @Override protected void logUpdate(GridCacheOperation op, CacheObject val, GridCacheVersion writeVer, long expireTime, long updCntr) throws IgniteCheckedException {
+    @Override protected void logUpdate(
+        GridCacheOperation op,
+        CacheObject val,
+        GridCacheVersion writeVer,
+        long expireTime,
+        long updCntr
+    ) throws IgniteCheckedException {
         // No-op for detached entries, index is updated on primary or backup nodes.
     }
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionFullMap.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionFullMap.java
index d5534c6..068d5a3 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionFullMap.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionFullMap.java
@@ -32,7 +32,8 @@ import org.jetbrains.annotations.NotNull;
 /**
  * Full partition map from all nodes.
  */
-public class GridDhtPartitionFullMap extends HashMap<UUID, GridDhtPartitionMap> implements Comparable<GridDhtPartitionFullMap>, Externalizable {
+public class GridDhtPartitionFullMap
+    extends HashMap<UUID, GridDhtPartitionMap> implements Comparable<GridDhtPartitionFullMap>, Externalizable {
     /** */
     private static final long serialVersionUID = 0L;
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java
index 6826d9d..d6ead0a 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionsExchangeFuture.java
@@ -178,7 +178,8 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
      * See {@link IgniteSystemProperties#IGNITE_SKIP_PARTITION_SIZE_VALIDATION} for details.
      * Default value is {@code false}.
      */
-    private static final boolean SKIP_PARTITION_SIZE_VALIDATION = Boolean.getBoolean(IgniteSystemProperties.IGNITE_SKIP_PARTITION_SIZE_VALIDATION);
+    private static final boolean SKIP_PARTITION_SIZE_VALIDATION =
+        Boolean.getBoolean(IgniteSystemProperties.IGNITE_SKIP_PARTITION_SIZE_VALIDATION);
 
     /** */
     public static final String EXCHANGE_LATCH_ID = "exchange";
@@ -899,7 +900,8 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
                     ", crd=" + crdNode +
                     ", evt=" + IgniteUtils.gridEventName(firstDiscoEvt.type()) +
                     ", evtNode=" + firstDiscoEvt.eventNode().id() +
-                    ", customEvt=" + (firstDiscoEvt.type() == EVT_DISCOVERY_CUSTOM_EVT ? ((DiscoveryCustomEvent)firstDiscoEvt).customMessage() : null) +
+                    ", customEvt=" +
+                    (firstDiscoEvt.type() == EVT_DISCOVERY_CUSTOM_EVT ? ((DiscoveryCustomEvent)firstDiscoEvt).customMessage() : null) +
                     ", allowMerge=" + exchCtx.mergeExchanges() +
                     ", exchangeFreeSwitch=" + exchCtx.exchangeFreeSwitch() + ']');
             }
@@ -4666,7 +4668,8 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
                                     }
                                 }
 
-                                AffinityTopologyVersion resVer = msg.resultTopologyVersion() != null ? msg.resultTopologyVersion() : initialVersion();
+                                AffinityTopologyVersion resVer =
+                                    msg.resultTopologyVersion() != null ? msg.resultTopologyVersion() : initialVersion();
 
                                 if (log.isInfoEnabled()) {
                                     log.info("Received full message, will finish exchange [node=" + node.id() +
@@ -4953,8 +4956,12 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
 
                             updatePartitionFullMap(resTopVer, partsMsg);
 
-                            if (exchActions != null && exchActions.stateChangeRequest() != null && err != null)
-                                cctx.kernalContext().state().onStateChangeError(msg.partitionsMessage().getErrorsMap(), exchActions.stateChangeRequest());
+                            if (exchActions != null && exchActions.stateChangeRequest() != null && err != null) {
+                                cctx.kernalContext().state().onStateChangeError(
+                                    msg.partitionsMessage().getErrorsMap(),
+                                    exchActions.stateChangeRequest()
+                                );
+                            }
                         }
 
                         onDone(resTopVer, err);
@@ -5158,7 +5165,11 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
                                             newCrdFut.init(GridDhtPartitionsExchangeFuture.this);
                                         }
                                         catch (Throwable t) {
-                                            U.error(log, "Failed to initialize new coordinator future [topVer=" + initialVersion() + "]", t);
+                                            U.error(
+                                                log,
+                                                "Failed to initialize new coordinator future [topVer=" + initialVersion() + "]",
+                                                t
+                                            );
 
                                             cctx.kernalContext().failure().process(new FailureContext(FailureType.CRITICAL_ERROR, t));
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPreloader.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPreloader.java
index 0e6222d..5570cc2 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPreloader.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPreloader.java
@@ -188,7 +188,9 @@ public class GridDhtPreloader extends GridCachePreloaderAdapter {
 
         assert exchFut == null ||
             exchFut.context().events().topologyVersion().equals(top.readyTopologyVersion()) ||
-            exchFut.context().events().topologyVersion().equals(ctx.exchange().lastAffinityChangedTopologyVersion(top.readyTopologyVersion())) :
+            exchFut.context().events().topologyVersion().equals(
+                ctx.exchange().lastAffinityChangedTopologyVersion(top.readyTopologyVersion())
+            ) :
             "Topology version mismatch [exchId=" + exchId +
                 ", grp=" + grp.name() +
                 ", topVer=" + top.readyTopologyVersion() + ']';
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionTopologyImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionTopologyImpl.java
index 0e7d8bb..7901d23 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionTopologyImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionTopologyImpl.java
@@ -820,7 +820,8 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
                                 if (grp.rebalanceEnabled()) {
                                     Collection<ClusterNode> owners = owners(p);
 
-                                    // If an owner node left during exchange, then new exchange should be started with detecting lost partitions.
+                                    // If an owner node left during exchange,
+                                    // then new exchange should be started with detecting lost partitions.
                                     if (!F.isEmpty(owners)) {
                                         if (log.isDebugEnabled())
                                             log.debug("Will not own partition (there are owners to rebalance from) " +
@@ -2607,7 +2608,8 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
 
                             if (stateChanged && log.isDebugEnabled()) {
                                 log.debug("Partition has been scheduled for eviction (this node is oldest non-affinity node) " +
-                                    "[grp=" + grp.cacheOrGroupName() + ", p=" + part.id() + ", prevState=" + state0 + ", state=" + part.state() + "]");
+                                    "[grp=" + grp.cacheOrGroupName() + ", p=" + part.id() + ", prevState=" + state0 +
+                                    ", state=" + part.state() + "]");
                             }
 
                             break;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearAtomicCache.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearAtomicCache.java
index 8eb1e0c..d0a9c92 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearAtomicCache.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearAtomicCache.java
@@ -166,7 +166,8 @@ public class GridNearAtomicCache<K, V> extends GridNearCacheAdapter<K, V> {
             if (F.contains(failed, key))
                 continue;
 
-            if (ctx.affinity().partitionBelongs(ctx.localNode(), ctx.affinity().partition(key), req.topologyVersion())) { // Reader became backup.
+            // Reader became backup.
+            if (ctx.affinity().partitionBelongs(ctx.localNode(), ctx.affinity().partition(key), req.topologyVersion())) {
                 GridCacheEntryEx entry = peekEx(key);
 
                 if (entry != null && entry.markObsolete(ver))
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearOptimisticSerializableTxPrepareFuture.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearOptimisticSerializableTxPrepareFuture.java
index 82672e6..3154114 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearOptimisticSerializableTxPrepareFuture.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearOptimisticSerializableTxPrepareFuture.java
@@ -927,14 +927,18 @@ public class GridNearOptimisticSerializableTxPrepareFuture extends GridNearOptim
                                                 parent.remapFut = null;
                                             }
 
-                                            parent.cctx.time().waitAsync(affFut, parent.tx.remainingTime(), new IgniteBiInClosure<IgniteCheckedException, Boolean>() {
-                                                @Override public void apply(IgniteCheckedException e, Boolean timedOut) {
-                                                    if (parent.errorOrTimeoutOnTopologyVersion(e, timedOut))
-                                                        return;
-
-                                                    remap(res);
+                                            parent.cctx.time().waitAsync(
+                                                affFut,
+                                                parent.tx.remainingTime(),
+                                                new IgniteBiInClosure<IgniteCheckedException, Boolean>() {
+                                                    @Override public void apply(IgniteCheckedException e, Boolean timedOut) {
+                                                        if (parent.errorOrTimeoutOnTopologyVersion(e, timedOut))
+                                                            return;
+
+                                                        remap(res);
+                                                    }
                                                 }
-                                            });
+                                            );
                                         }
                                         else {
                                             ClusterTopologyCheckedException err0 = new ClusterTopologyCheckedException(
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearOptimisticTxPrepareFuture.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearOptimisticTxPrepareFuture.java
index 0f875a2..1de3789 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearOptimisticTxPrepareFuture.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearOptimisticTxPrepareFuture.java
@@ -749,7 +749,8 @@ public class GridNearOptimisticTxPrepareFuture extends GridNearOptimisticTxPrepa
                                 "transaction [timeout=" + tx.timeout() + ", tx=" + CU.txString(tx) + ']',
                                 deadlock != null ? new TransactionDeadlockException(deadlock.toString(cctx)) : null);
 
-                            if (!ERR_UPD.compareAndSet(GridNearOptimisticTxPrepareFuture.this, null, e) && err instanceof IgniteTxTimeoutCheckedException) {
+                            if (!ERR_UPD.compareAndSet(GridNearOptimisticTxPrepareFuture.this, null, e)
+                                && err instanceof IgniteTxTimeoutCheckedException) {
                                 err = e;
                             }
                         }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearTxLocal.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearTxLocal.java
index babdf80..b760651 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearTxLocal.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearTxLocal.java
@@ -1587,9 +1587,15 @@ public class GridNearTxLocal extends GridDhtTxLocalAdapter implements GridTimeou
                                 assert !implicit() || !transform : this;
                                 assert txEntry.op() != TRANSFORM : txEntry;
 
-                                if (retval)
-                                    ret.set(cacheCtx, null, true, keepBinary, U.deploymentClassLoader(cctx.kernalContext(), deploymentLdrId));
-                                else
+                                if (retval) {
+                                    ret.set(
+                                        cacheCtx,
+                                        null,
+                                        true,
+                                        keepBinary,
+                                        U.deploymentClassLoader(cctx.kernalContext(), deploymentLdrId)
+                                    );
+                                } else
                                     ret.success(true);
                             }
                         }
@@ -1925,22 +1931,30 @@ public class GridNearTxLocal extends GridDhtTxLocalAdapter implements GridTimeou
                 // with prepare response, if required.
                 assert loadFut.isDone();
 
-                return nonInterruptable(commitNearTxLocalAsync().chain(new CX1<IgniteInternalFuture<IgniteInternalTx>, GridCacheReturn>() {
-                    @Override public GridCacheReturn applyx(IgniteInternalFuture<IgniteInternalTx> txFut)
-                        throws IgniteCheckedException {
-                        try {
-                            txFut.get();
+                return nonInterruptable(commitNearTxLocalAsync().chain(
+                    new CX1<IgniteInternalFuture<IgniteInternalTx>, GridCacheReturn>() {
+                        @Override public GridCacheReturn applyx(IgniteInternalFuture<IgniteInternalTx> txFut)
+                            throws IgniteCheckedException {
+                            try {
+                                txFut.get();
 
-                            return new GridCacheReturn(cacheCtx, true, keepBinary, U.deploymentClassLoader(cctx.kernalContext(), deploymentLdrId),
-                                implicitRes.value(), implicitRes.success());
-                        }
-                        catch (IgniteCheckedException | RuntimeException e) {
-                            rollbackNearTxLocalAsync();
+                                return new GridCacheReturn(
+                                    cacheCtx,
+                                    true,
+                                    keepBinary,
+                                    U.deploymentClassLoader(cctx.kernalContext(), deploymentLdrId),
+                                    implicitRes.value(),
+                                    implicitRes.success()
+                                );
+                            }
+                            catch (IgniteCheckedException | RuntimeException e) {
+                                rollbackNearTxLocalAsync();
 
-                            throw e;
+                                throw e;
+                            }
                         }
                     }
-                }));
+                ));
             }
             else {
                 return nonInterruptable(loadFut.chain(new CX1<IgniteInternalFuture<Void>, GridCacheReturn>() {
@@ -2154,7 +2168,14 @@ public class GridNearTxLocal extends GridDhtTxLocalAdapter implements GridTimeou
                         val = cacheCtx.unwrapInvokeResult((Map)val, keepBinary);
                     }
 
-                    return new GridCacheReturn(cacheCtx, true, keepBinary, U.deploymentClassLoader(cctx.kernalContext(), deploymentLdrId), val, futRes.success());
+                    return new GridCacheReturn(
+                        cacheCtx,
+                        true,
+                        keepBinary,
+                        U.deploymentClassLoader(cctx.kernalContext(), deploymentLdrId),
+                        val,
+                        futRes.success()
+                    );
                 }
             }));
         }
@@ -2994,7 +3015,13 @@ public class GridNearTxLocal extends GridDhtTxLocalAdapter implements GridTimeou
                             else
                                 success = true;
 
-                            ret.set(cacheCtx, cacheVal, success, keepBinary, U.deploymentClassLoader(cctx.kernalContext(), deploymentLdrId));
+                            ret.set(
+                                cacheCtx,
+                                cacheVal,
+                                success,
+                                keepBinary,
+                                U.deploymentClassLoader(cctx.kernalContext(), deploymentLdrId)
+                            );
                         }
                     }
                 }
@@ -3055,7 +3082,14 @@ public class GridNearTxLocal extends GridDhtTxLocalAdapter implements GridTimeou
                                 res = cacheCtx.unwrapInvokeResult((Map)res, keepBinary);
                             }
 
-                            return new GridCacheReturn(cacheCtx, true, keepBinary, U.deploymentClassLoader(cctx.kernalContext(), deploymentLdrId), res, implicitRes.success());
+                            return new GridCacheReturn(
+                                cacheCtx,
+                                true,
+                                keepBinary,
+                                U.deploymentClassLoader(cctx.kernalContext(), deploymentLdrId),
+                                res,
+                                implicitRes.success()
+                            );
                         }
                         catch (IgniteCheckedException | RuntimeException e) {
                             if (!(e instanceof NodeStoppingException))
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/mvcc/MvccProcessorImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/mvcc/MvccProcessorImpl.java
index da9aab5..4d8b681 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/mvcc/MvccProcessorImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/mvcc/MvccProcessorImpl.java
@@ -2381,7 +2381,8 @@ public class MvccProcessorImpl extends GridProcessorAdapter implements MvccProce
         private boolean actualize(GridCacheContext cctx, MvccDataRow row,
             MvccSnapshot snapshot) throws IgniteCheckedException {
             return isVisible(cctx, snapshot, row.mvccCoordinatorVersion(), row.mvccCounter(), row.mvccOperationCounter(), false)
-                && (row.mvccTxState() == TxState.NA || (row.newMvccCoordinatorVersion() != MVCC_CRD_COUNTER_NA && row.newMvccTxState() == TxState.NA));
+                && (row.mvccTxState() == TxState.NA ||
+                    (row.newMvccCoordinatorVersion() != MVCC_CRD_COUNTER_NA && row.newMvccTxState() == TxState.NA));
         }
 
         /**
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/mvcc/MvccUtils.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/mvcc/MvccUtils.java
index bccbb11..fe16f54 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/mvcc/MvccUtils.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/mvcc/MvccUtils.java
@@ -721,7 +721,9 @@ public class MvccUtils {
             if (!tx.isOperationAllowed(true)) {
                 tx.setRollbackOnly();
 
-                throw new TransactionMixedModeException("Operations on MVCC caches are not permitted in transactions spanning non MVCC caches.");
+                throw new TransactionMixedModeException(
+                    "Operations on MVCC caches are not permitted in transactions spanning non MVCC caches."
+                );
             }
         }
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/package-info.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/package-info.java
index ab907a0..b7e27a7 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/package-info.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/package-info.java
@@ -17,7 +17,8 @@
 
 /**
  * This package contain cache-related processors & persistence implementation. <br>
- * See also
- * <a href="https://github.com/apache/ignite/tree/master/modules/core/src/main/java/org/apache/ignite/internal/processors/cache">GitHub Package Readme</a>
+ * See also <a href="
+ * https://github.com/apache/ignite/tree/master/modules/core/src/main/java/org/apache/ignite/internal/processors/cache">
+ * GitHub Package Readme</a>
  */
 package org.apache.ignite.internal.processors.cache;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/GridCacheDatabaseSharedManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/GridCacheDatabaseSharedManager.java
index 42ff08d..33b2467 100755
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/GridCacheDatabaseSharedManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/GridCacheDatabaseSharedManager.java
@@ -1632,7 +1632,8 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
         checkpointReadLock();
 
         try {
-            CheckpointHistoryResult checkpointHistoryResult = checkpointHistory().searchAndReserveCheckpoints(applicableGroupsAndPartitions);
+            CheckpointHistoryResult checkpointHistoryResult =
+                checkpointHistory().searchAndReserveCheckpoints(applicableGroupsAndPartitions);
 
             earliestValidCheckpoints = checkpointHistoryResult.earliestValidCheckpoints();
 
@@ -1645,7 +1646,8 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
 
         Map</*grpId*/Integer, Map</*partId*/Integer, /*updCntr*/Long>> grpPartsWithCnts = new HashMap<>();
 
-        for (Map.Entry<Integer, T2</*reason*/ReservationReason, Map</*partId*/Integer, CheckpointEntry>>> e : earliestValidCheckpoints.entrySet()) {
+        for (Map.Entry<Integer, T2</*reason*/ReservationReason, Map</*partId*/Integer, CheckpointEntry>>> e :
+            earliestValidCheckpoints.entrySet()) {
             int grpId = e.getKey();
 
             if (e.getValue().get2() == null)
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/GridCacheOffheapManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/GridCacheOffheapManager.java
index 485883b..9dbf87a 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/GridCacheOffheapManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/GridCacheOffheapManager.java
@@ -1702,8 +1702,8 @@ public class GridCacheOffheapManager extends IgniteCacheOffheapManagerImpl imple
                             int p = partMap.partitionAt(i);
 
                             if (!doneParts.contains(p)) {
-                                log.warning("Some partition entries were missed during historical rebalance [grp=" + grp + ", part=" + p + ", missed=" +
-                                    (partMap.updateCounterAt(i) - rebalancedCntrs[i]) + ']');
+                                log.warning("Some partition entries were missed during historical rebalance " +
+                                    "[grp=" + grp + ", part=" + p + ", missed=" + (partMap.updateCounterAt(i) - rebalancedCntrs[i]) + ']');
 
                                 doneParts.add(p);
                             }
@@ -2341,8 +2341,8 @@ public class GridCacheOffheapManager extends IgniteCacheOffheapManagerImpl imple
                                 + U.hexLong(partMetaStoreReuseListRoot) + ", part=" + partId + ", grpId=" + grpId);
                     }
 
-                    if ((allocated || pageUpgraded || pendingTreeAllocated || partMetastoreReuseListAllocated || updateLogTreeRootAllocated) &&
-                        isWalDeltaRecordNeeded(pageMem, grpId, partMetaId, partMetaPage, wal, null)) {
+                    if ((allocated || pageUpgraded || pendingTreeAllocated || partMetastoreReuseListAllocated || updateLogTreeRootAllocated)
+                        && isWalDeltaRecordNeeded(pageMem, grpId, partMetaId, partMetaPage, wal, null)) {
                         wal.log(new PageSnapshot(new FullPageId(partMetaId, grpId), pageAddr,
                             pageMem.pageSize(), pageMem.realPageSize(grpId)));
                     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/checkpoint/CheckpointPagesWriter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/checkpoint/CheckpointPagesWriter.java
index 79f774c..b6f55fc 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/checkpoint/CheckpointPagesWriter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/checkpoint/CheckpointPagesWriter.java
@@ -201,7 +201,8 @@ public class CheckpointPagesWriter implements Runnable {
 
             tmpWriteBuf.rewind();
 
-            PageStoreWriter pageStoreWriter = pageStoreWriters.computeIfAbsent(pageMem, pageMemEx -> createPageStoreWriter(pageMemEx, pagesToRetry));
+            PageStoreWriter pageStoreWriter =
+                pageStoreWriters.computeIfAbsent(pageMem, pageMemEx -> createPageStoreWriter(pageMemEx, pagesToRetry));
 
             pageMem.checkpointWritePage(fullId, tmpWriteBuf, pageStoreWriter, tracker);
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/defragmentation/CachePartitionDefragmentationManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/defragmentation/CachePartitionDefragmentationManager.java
index a61390e..dc930fc 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/defragmentation/CachePartitionDefragmentationManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/defragmentation/CachePartitionDefragmentationManager.java
@@ -970,7 +970,11 @@ public class CachePartitionDefragmentationManager {
         }
 
         /** */
-        public PageStore createPageStore(IgniteOutClosure<Path> pathProvider, AtomicLong pagesAllocated, PageMemoryEx pageMemory) throws IgniteCheckedException {
+        public PageStore createPageStore(
+            IgniteOutClosure<Path> pathProvider,
+            AtomicLong pagesAllocated,
+            PageMemoryEx pageMemory
+        ) throws IgniteCheckedException {
             PageStore partPageStore;
 
             defragmentationCheckpoint.checkpointTimeoutLock().checkpointReadLock();
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/defragmentation/LinkMap.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/defragmentation/LinkMap.java
index a796ab9..8815f1d 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/defragmentation/LinkMap.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/defragmentation/LinkMap.java
@@ -159,7 +159,21 @@ public class LinkMap {
            @Nullable PageLockListener lockLsnr,
            boolean initNew
         ) throws IgniteCheckedException {
-            super(name, cacheGrpId, cacheGrpName, pageMem, wal, globalRmvId, metaPageId, reuseList, innerIos, leafIos, FLAG_AUX, failureProcessor, lockLsnr);
+            super(
+                name,
+                cacheGrpId,
+                cacheGrpName,
+                pageMem,
+                wal,
+                globalRmvId,
+                metaPageId,
+                reuseList,
+                innerIos,
+                leafIos,
+                FLAG_AUX,
+                failureProcessor,
+                lockLsnr
+            );
 
             PageIO.registerTest(latestInnerIO(), latestLeafIO());
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FilePageStoreManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FilePageStoreManager.java
index 05730f3..5a92f1c6e 100755
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FilePageStoreManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FilePageStoreManager.java
@@ -627,7 +627,13 @@ public class FilePageStoreManager extends GridCacheSharedManagerAdapter implemen
     }
 
     /** {@inheritDoc} */
-    @Override public PageStore write(int grpId, long pageId, ByteBuffer pageBuf, int tag, boolean calculateCrc) throws IgniteCheckedException {
+    @Override public PageStore write(
+        int grpId,
+        long pageId,
+        ByteBuffer pageBuf,
+        int tag,
+        boolean calculateCrc
+    ) throws IgniteCheckedException {
         return pmPageMgr.write(grpId, pageId, pageBuf, tag, calculateCrc);
     }
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FileVersionCheckingFactory.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FileVersionCheckingFactory.java
index 5208ad2..3a79f49 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FileVersionCheckingFactory.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/FileVersionCheckingFactory.java
@@ -159,7 +159,9 @@ public class FileVersionCheckingFactory {
                 return new FilePageStoreV2(type, pathProvider, fileIOFactory, pageSize, allocatedTracker);
 
             default:
-                throw new IllegalArgumentException("Unknown version of file page store: " + ver + " for file [" + pathProvider.apply().toAbsolutePath() + "]");
+                throw new IllegalArgumentException(
+                    "Unknown version of file page store: " + ver + " for file [" + pathProvider.apply().toAbsolutePath() + "]"
+                );
         }
     }
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/freelist/PagesList.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/freelist/PagesList.java
index a7166a6..06ccdda 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/freelist/PagesList.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/freelist/PagesList.java
@@ -2066,7 +2066,8 @@ public abstract class PagesList extends DataStructure {
         @SystemProperty(value = "The threshold of flush calls on empty caches to allow GC of stripes " +
             "(the flush is triggered two times per checkpoint)", type = Long.class,
             defaults = "" + DFLT_PAGES_LIST_CACHING_EMPTY_FLUSH_GC_THRESHOLD)
-        public static final String IGNITE_PAGES_LIST_CACHING_EMPTY_FLUSH_GC_THRESHOLD = "IGNITE_PAGES_LIST_CACHING_EMPTY_FLUSH_GC_THRESHOLD";
+        public static final String IGNITE_PAGES_LIST_CACHING_EMPTY_FLUSH_GC_THRESHOLD =
+            "IGNITE_PAGES_LIST_CACHING_EMPTY_FLUSH_GC_THRESHOLD";
 
         /** Pages cache max size. */
         private static final int MAX_SIZE = IgniteSystemProperties.getInteger(IGNITE_PAGES_LIST_CACHING_MAX_CACHE_SIZE,
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/metastorage/MetaStorage.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/metastorage/MetaStorage.java
index 3a4eae0..2e098bf 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/metastorage/MetaStorage.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/metastorage/MetaStorage.java
@@ -201,8 +201,10 @@ public class MetaStorage implements CheckpointListener, ReadWriteMetastorage {
                         int partTag = ((PageMemoryEx)dataRegion.pageMemory()).invalidate(METASTORAGE_CACHE_ID, OLD_METASTORE_PARTITION);
                         cctx.pageStore().onPartitionDestroyed(METASTORAGE_CACHE_ID, OLD_METASTORE_PARTITION, partTag);
 
-                        int idxTag = ((PageMemoryEx)dataRegion.pageMemory()).invalidate(METASTORAGE_CACHE_ID, PageIdAllocator.INDEX_PARTITION);
-                        PageStore store = ((FilePageStoreManager)cctx.pageStore()).getStore(METASTORAGE_CACHE_ID, PageIdAllocator.INDEX_PARTITION);
+                        int idxTag =
+                            ((PageMemoryEx)dataRegion.pageMemory()).invalidate(METASTORAGE_CACHE_ID, PageIdAllocator.INDEX_PARTITION);
+                        PageStore store =
+                            ((FilePageStoreManager)cctx.pageStore()).getStore(METASTORAGE_CACHE_ID, PageIdAllocator.INDEX_PARTITION);
                         store.truncate(idxTag);
 
                         db.removeCheckpointListener(this);
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/package-info.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/package-info.java
index 8e99ca0..8cf0fe2 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/package-info.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/package-info.java
@@ -17,7 +17,8 @@
 
 /**
  * This package contain cache with persistence implementation. <br>
- * See also
- * <a href="https://github.com/apache/ignite/tree/master/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence">GitHub Package Readme</a>
+ * See also <a href="
+ * https://github.com/apache/ignite/tree/master/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence">
+ * GitHub Package Readme</a>
  */
 package org.apache.ignite.internal.processors.cache.persistence;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryImpl.java
index 4e102ff..f9c84c0 100755
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryImpl.java
@@ -229,8 +229,8 @@ public class PageMemoryImpl implements PageMemoryEx {
     private final PageStoreWriter flushDirtyPage;
 
     /**
-     * Delayed page replacement (rotation with disk) tracker. Because other thread may require exactly the same page to be loaded from store,
-     * reads are protected by locking.
+     * Delayed page replacement (rotation with disk) tracker.
+     * Because other thread may require exactly the same page to be loaded from store, reads are protected by locking.
      * {@code Null} if delayed write functionality is disabled.
      */
     @Nullable private final DelayedPageReplacementTracker delayedPageReplacementTracker;
@@ -1653,7 +1653,8 @@ public class PageMemoryImpl implements PageMemoryEx {
             );
 
             assert PageIO.getType(tmpAbsPtr + PAGE_OVERHEAD) != 0 : "Invalid state. Type is 0! pageId = " + U.hexLong(fullId.pageId());
-            assert PageIO.getVersion(tmpAbsPtr + PAGE_OVERHEAD) != 0 : "Invalid state. Version is 0! pageId = " + U.hexLong(fullId.pageId());
+            assert PageIO.getVersion(tmpAbsPtr + PAGE_OVERHEAD) != 0
+                : "Invalid state. Version is 0! pageId = " + U.hexLong(fullId.pageId());
 
             PageHeader.dirty(absPtr, false);
             PageHeader.tempBufferPointer(absPtr, tmpRelPtr);
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageReadWriteManagerImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageReadWriteManagerImpl.java
index 5fbd7c1..63ff696 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageReadWriteManagerImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageReadWriteManagerImpl.java
@@ -78,7 +78,13 @@ public class PageReadWriteManagerImpl implements PageReadWriteManager {
     }
 
     /** {@inheritDoc} */
-    @Override public PageStore write(int grpId, long pageId, ByteBuffer pageBuf, int tag, boolean calculateCrc) throws IgniteCheckedException {
+    @Override public PageStore write(
+        int grpId,
+        long pageId,
+        ByteBuffer pageBuf,
+        int tag,
+        boolean calculateCrc
+    ) throws IgniteCheckedException {
         int partId = PageIdUtils.partId(pageId);
 
         PageStore store = pageStores.getStore(grpId, partId);
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/package-info.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/package-info.java
index 5bc3a20..4fda1b3 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/package-info.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/package-info.java
@@ -24,7 +24,8 @@
  *  <li>Pages replacement with disk.</li>
  * </ul>
  *
- * See also
- * <a href="https://github.com/apache/ignite/tree/master/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem">Package description</a>
+ * See also <a href="
+ * https://github.com/apache/ignite/tree/master/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem">
+ * Package description</a>
  */
 package org.apache.ignite.internal.processors.cache.persistence.pagemem;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/snapshot/IgniteCacheSnapshotManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/snapshot/IgniteCacheSnapshotManager.java
index c377582..5c751fd 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/snapshot/IgniteCacheSnapshotManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/snapshot/IgniteCacheSnapshotManager.java
@@ -39,7 +39,8 @@ import org.jetbrains.annotations.Nullable;
  * @deprecated Use {@link IgniteSnapshotManager}.
  */
 @Deprecated
-public class IgniteCacheSnapshotManager<T extends SnapshotOperation> extends GridCacheSharedManagerAdapter implements IgniteChangeGlobalStateSupport {
+public class IgniteCacheSnapshotManager<T extends SnapshotOperation>
+    extends GridCacheSharedManagerAdapter implements IgniteChangeGlobalStateSupport {
     /** Snapshot started lock filename. */
     public static final String SNAPSHOT_RESTORE_STARTED_LOCK_FILENAME = "snapshot-started.loc";
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/snapshot/IgniteSnapshotManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/snapshot/IgniteSnapshotManager.java
index 01a39fd..924a719 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/snapshot/IgniteSnapshotManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/snapshot/IgniteSnapshotManager.java
@@ -997,8 +997,11 @@ public class IgniteSnapshotManager extends GridCacheSharedManagerAdapter
         try (InputStream in = new BufferedInputStream(new FileInputStream(smf))) {
             SnapshotMetadata meta = marsh.unmarshal(in, U.resolveClassLoader(cctx.gridConfig()));
 
-            if (!U.maskForFileName(meta.consistentId()).equals(smfName))
-                throw new IgniteException("Error reading snapshot metadata [smfName=" + smfName + ", consId=" + U.maskForFileName(meta.consistentId()));
+            if (!U.maskForFileName(meta.consistentId()).equals(smfName)) {
+                throw new IgniteException(
+                    "Error reading snapshot metadata [smfName=" + smfName + ", consId=" + U.maskForFileName(meta.consistentId())
+                );
+            }
 
             return meta;
         }
@@ -1095,17 +1098,26 @@ public class IgniteSnapshotManager extends GridCacheSharedManagerAdapter
             ClusterSnapshotFuture snpFut0;
 
             synchronized (snpOpMux) {
-                if (clusterSnpFut != null && !clusterSnpFut.isDone())
-                    throw new IgniteException("Create snapshot request has been rejected. The previous snapshot operation was not completed.");
+                if (clusterSnpFut != null && !clusterSnpFut.isDone()) {
+                    throw new IgniteException(
+                        "Create snapshot request has been rejected. The previous snapshot operation was not completed."
+                    );
+                }
 
                 if (clusterSnpReq != null)
                     throw new IgniteException("Create snapshot request has been rejected. Parallel snapshot processes are not allowed.");
 
-                if (localSnapshotNames().contains(name))
-                    throw new IgniteException("Create snapshot request has been rejected. Snapshot with given name already exists on local node.");
+                if (localSnapshotNames().contains(name)) {
+                    throw new IgniteException(
+                        "Create snapshot request has been rejected. Snapshot with given name already exists on local node."
+                    );
+                }
 
-                if (isRestoring())
-                    throw new IgniteException("Snapshot operation has been rejected. Cache group restore operation is currently in progress.");
+                if (isRestoring()) {
+                    throw new IgniteException(
+                        "Snapshot operation has been rejected. Cache group restore operation is currently in progress."
+                    );
+                }
 
                 snpFut0 = new ClusterSnapshotFuture(UUID.randomUUID(), name);
 
@@ -1285,11 +1297,18 @@ public class IgniteSnapshotManager extends GridCacheSharedManagerAdapter
 
         List<File> grps = cacheDirectories(nodePath, name -> name.equals(grpName));
 
-        if (F.isEmpty(grps))
-            throw new IgniteCheckedException("The snapshot cache group not found [dir=" + snpDir.getAbsolutePath() + ", grpName=" + grpName + ']');
+        if (F.isEmpty(grps)) {
+            throw new IgniteCheckedException(
+                "The snapshot cache group not found [dir=" + snpDir.getAbsolutePath() + ", grpName=" + grpName + ']'
+            );
+        }
 
-        if (grps.size() > 1)
-            throw new IgniteCheckedException("The snapshot cache group directory cannot be uniquely identified [dir=" + snpDir.getAbsolutePath() + ", grpName=" + grpName + ']');
+        if (grps.size() > 1) {
+            throw new IgniteCheckedException(
+                "The snapshot cache group directory cannot be uniquely identified [dir=" + snpDir.getAbsolutePath() +
+                    ", grpName=" + grpName + ']'
+            );
+        }
 
         File snpPart = getPartitionFile(new File(snapshotLocalDir(snpName), databaseRelativePath(folderName)),
             grps.get(0).getName(), partId);
@@ -1331,8 +1350,10 @@ public class IgniteSnapshotManager extends GridCacheSharedManagerAdapter
         boolean withMetaStorage,
         SnapshotSender snpSndr
     ) {
-        if (!busyLock.enterBusy())
-            return new SnapshotFutureTask(new IgniteCheckedException("Snapshot manager is stopping [locNodeId=" + cctx.localNodeId() + ']'));
+        if (!busyLock.enterBusy()) {
+            return new SnapshotFutureTask(
+                new IgniteCheckedException("Snapshot manager is stopping [locNodeId=" + cctx.localNodeId() + ']'));
+        }
 
         try {
             if (locSnpTasks.containsKey(snpName))
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/BPlusTree.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/BPlusTree.java
index 97ee910..a44378d 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/BPlusTree.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/BPlusTree.java
@@ -3751,7 +3751,8 @@ public abstract class BPlusTree<L, T extends L> extends DataStructure implements
                         if (idx == cnt && !io.isLeaf()) {
                             inner(io).setLeft(fwdPageAddr, 0, rightId);
 
-                            if (needWalDeltaRecord(fwdId, fwdPage, fwdPageWalPlc)) // Rare case, we can afford separate WAL record to avoid complexity.
+                            // Rare case, we can afford separate WAL record to avoid complexity.
+                            if (needWalDeltaRecord(fwdId, fwdPage, fwdPageWalPlc))
                                 wal.log(new FixLeftmostChildRecord(grpId, fwdId, rightId));
                         }
                     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/AbstractDataPageIO.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/AbstractDataPageIO.java
index 20e43ae..0c976fd 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/AbstractDataPageIO.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/AbstractDataPageIO.java
@@ -884,7 +884,8 @@ public abstract class AbstractDataPageIO<T extends Storable> extends PageIO impl
 
             // Increase free space.
             setRealFreeSpace(pageAddr,
-                getRealFreeSpace(pageAddr) + rmvEntrySize + ITEM_SIZE * (directCnt - getDirectCount(pageAddr) + indirectCnt - getIndirectCount(pageAddr)),
+                getRealFreeSpace(pageAddr) + rmvEntrySize +
+                    ITEM_SIZE * (directCnt - getDirectCount(pageAddr) + indirectCnt - getIndirectCount(pageAddr)),
                 pageSize);
         }
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/PageIO.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/PageIO.java
index eb90b2f..6d88643 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/PageIO.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/PageIO.java
@@ -156,7 +156,8 @@ public abstract class PageIO {
     private static final int RESERVED_3_OFF = RESERVED_2_OFF + 8;
 
     /** */
-    public static final int COMMON_HEADER_END = RESERVED_3_OFF + 8; // 40=type(2)+ver(2)+crc(4)+pageId(8)+rotatedIdPart(1)+reserved(1+2+4+2*8)
+    // 40=type(2)+ver(2)+crc(4)+pageId(8)+rotatedIdPart(1)+reserved(1+2+4+2*8)
+    public static final int COMMON_HEADER_END = RESERVED_3_OFF + 8;
 
     /* All the page types. */
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/util/PageHandler.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/util/PageHandler.java
index 9461cca..02d8238 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/util/PageHandler.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/util/PageHandler.java
@@ -240,7 +240,21 @@ public abstract class PageHandler<X, R> {
         PageLockListener lsnr,
         IoStatisticsHolder statHolder
     ) throws IgniteCheckedException {
-        Boolean res = writePage(pageMem, grpId, pageId, lsnr, PageHandler.NO_OP, init, wal, null, null, 0, FALSE, statHolder, DEFAULT_PAGE_IO_RESOLVER);
+        Boolean res = writePage(
+            pageMem,
+            grpId,
+            pageId,
+            lsnr,
+            PageHandler.NO_OP,
+            init,
+            wal,
+            null,
+            null,
+            0,
+            FALSE,
+            statHolder,
+            DEFAULT_PAGE_IO_RESOLVER
+        );
 
         assert res != FALSE;
     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/StandaloneWalRecordsIterator.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/StandaloneWalRecordsIterator.java
index 472afba..db46d6f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/StandaloneWalRecordsIterator.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/StandaloneWalRecordsIterator.java
@@ -161,7 +161,11 @@ class StandaloneWalRecordsIterator extends AbstractWalRecordsIterator {
      *
      * @throws IgniteCheckedException if failed
      */
-    private static void strictCheck(List<FileDescriptor> walFiles, WALPointer lowBound, WALPointer highBound) throws IgniteCheckedException {
+    private static void strictCheck(
+        List<FileDescriptor> walFiles,
+        WALPointer lowBound,
+        WALPointer highBound
+    ) throws IgniteCheckedException {
         int idx = 0;
 
         if (lowBound.index() > Long.MIN_VALUE) {
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordV1Serializer.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordV1Serializer.java
index a55a11f..295e174 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordV1Serializer.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordV1Serializer.java
@@ -71,7 +71,8 @@ public class RecordV1Serializer implements RecordSerializer {
     public static final int CRC_SIZE = 4;
 
     /** Total length of HEADER record. */
-    public static final int HEADER_RECORD_SIZE = REC_TYPE_SIZE + FILE_WAL_POINTER_SIZE + CRC_SIZE + RecordDataV1Serializer.HEADER_RECORD_DATA_SIZE;
+    public static final int HEADER_RECORD_SIZE =
+        REC_TYPE_SIZE + FILE_WAL_POINTER_SIZE + CRC_SIZE + RecordDataV1Serializer.HEADER_RECORD_DATA_SIZE;
 
     /** Skip CRC calculation/check flag */
     public static boolean skipCrc = IgniteSystemProperties.getBoolean(IGNITE_PDS_SKIP_CRC, false);
@@ -123,7 +124,10 @@ public class RecordV1Serializer implements RecordSerializer {
         }
 
         /** {@inheritDoc} */
-        @Override public WALRecord readWithHeaders(ByteBufferBackedDataInput in, WALPointer expPtr) throws IOException, IgniteCheckedException {
+        @Override public WALRecord readWithHeaders(
+            ByteBufferBackedDataInput in,
+            WALPointer expPtr
+        ) throws IOException, IgniteCheckedException {
             RecordType recType = readRecordType(in);
 
             if (recType == RecordType.SWITCH_SEGMENT_RECORD)
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/GridCacheQueryManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/GridCacheQueryManager.java
index f0d0552..81b53b0 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/GridCacheQueryManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/GridCacheQueryManager.java
@@ -182,7 +182,8 @@ public abstract class GridCacheQueryManager<K, V> extends GridCacheManagerAdapte
         QRY_DETAIL_METRICS_MERGE_FX = GridCacheQueryDetailMetricsAdapter::aggregate;
 
     /** */
-    private final boolean isIndexingSpiAllowsBinary = !IgniteSystemProperties.getBoolean(IgniteSystemProperties.IGNITE_UNWRAP_BINARY_FOR_INDEXING_SPI);
+    private final boolean isIndexingSpiAllowsBinary =
+        !IgniteSystemProperties.getBoolean(IgniteSystemProperties.IGNITE_UNWRAP_BINARY_FOR_INDEXING_SPI);
 
     /** */
     private GridQueryProcessor qryProc;
@@ -1875,14 +1876,16 @@ public abstract class GridCacheQueryManager<K, V> extends GridCacheManagerAdapte
             if (rmtFut == null)
                 return new GridFinishedFuture<>(convertMetadata(res));
 
-            return rmtFut.chain(new IgniteClosureX<IgniteInternalFuture<Collection<Collection<CacheSqlMetadata>>>, Collection<GridCacheSqlMetadata>>() {
-                @Override public Collection<GridCacheSqlMetadata> applyx(
-                    IgniteInternalFuture<Collection<Collection<CacheSqlMetadata>>> fut) throws IgniteCheckedException {
-                    res.addAll(fut.get());
+            return rmtFut.chain(
+                new IgniteClosureX<IgniteInternalFuture<Collection<Collection<CacheSqlMetadata>>>, Collection<GridCacheSqlMetadata>>() {
+                    @Override public Collection<GridCacheSqlMetadata> applyx(
+                        IgniteInternalFuture<Collection<Collection<CacheSqlMetadata>>> fut) throws IgniteCheckedException {
+                        res.addAll(fut.get());
 
-                    return convertMetadata(res);
+                        return convertMetadata(res);
+                    }
                 }
-            });
+            );
         }
         finally {
             leaveBusy();
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxHandler.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxHandler.java
index cc5370b..f11d553 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxHandler.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxHandler.java
@@ -178,7 +178,10 @@ public class IgniteTxHandler {
      * @param nearNode Sender node.
      * @param req Request.
      */
-    private IgniteInternalFuture<GridNearTxPrepareResponse> processNearTxPrepareRequest0(ClusterNode nearNode, GridNearTxPrepareRequest req) {
+    private IgniteInternalFuture<GridNearTxPrepareResponse> processNearTxPrepareRequest0(
+        ClusterNode nearNode,
+        GridNearTxPrepareRequest req
+    ) {
         IgniteInternalFuture<GridNearTxPrepareResponse> fut;
 
         if (req.firstClientRequest() && req.allowWaitTopologyFuture()) {
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxManager.java
index c153caa..3f25582 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxManager.java
@@ -958,7 +958,8 @@ public class IgniteTxManager extends GridCacheSharedManagerAdapter {
         for (IgniteInternalTx tx : activeTransactions()) {
             if (tx.transactionNodes() != null && tx.transactionNodes().containsKey(node.id()) // One of tx primaries failed.
                 && (tx.dht() // Local node is a primary (not on originating) or backup.
-                || (tx.near() && tx.local() && ((GridNearTxLocal)tx).colocatedLocallyMapped()))) { // Local node is a primary (on originating).
+                // Local node is a primary (on originating).
+                || (tx.near() && tx.local() && ((GridNearTxLocal)tx).colocatedLocallyMapped()))) {
                 assert needWaitTransaction(tx, topVer);
 
                 res.add(tx.finishFuture());
@@ -975,7 +976,8 @@ public class IgniteTxManager extends GridCacheSharedManagerAdapter {
      *
      * NOTE:
      * As we send finish request to backup nodes after transaction successfully completed on primary node
-     * it's important to ensure that all updates from primary to backup are finished or at least remote transaction has created on backup node.
+     * it's important to ensure that all updates from primary to backup are finished or at least remote transaction has created
+     * on backup node.
      *
      * @param finishLocalTxsFuture Local transactions finish future.
      * @param topVer Topology version.
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/tree/CacheDataRowStore.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/tree/CacheDataRowStore.java
index f066771..0a9f3fb 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/tree/CacheDataRowStore.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/tree/CacheDataRowStore.java
@@ -88,7 +88,15 @@ public class CacheDataRowStore extends RowStore {
      * @param opCntr Mvcc operation counter.
      * @return Search row.
      */
-    protected MvccDataRow mvccRow(int cacheId, int hash, long link, CacheDataRowAdapter.RowData rowData, long crdVer, long mvccCntr, int opCntr) {
+    protected MvccDataRow mvccRow(
+        int cacheId,
+        int hash,
+        long link,
+        CacheDataRowAdapter.RowData rowData,
+        long crdVer,
+        long mvccCntr,
+        int opCntr
+    ) {
         MvccDataRow row = new MvccDataRow(
             grp,
             hash,
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/tree/mvcc/data/MvccUpdateDataRow.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/tree/mvcc/data/MvccUpdateDataRow.java
index d9ef5a8..37352d5 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/tree/mvcc/data/MvccUpdateDataRow.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/tree/mvcc/data/MvccUpdateDataRow.java
@@ -283,7 +283,8 @@ public class MvccUpdateDataRow extends MvccDataRow implements MvccUpdateResult,
                         oldRow = row;
                 }
 
-                // TODO: IGNITE-9689: optimize filter usage here. See {@link org.apache.ignite.internal.processors.cache.CacheOperationFilter}.
+                // TODO: IGNITE-9689: optimize filter usage here.
+                //  See {@link org.apache.ignite.internal.processors.cache.CacheOperationFilter}.
                 if (filter != null && !applyFilter(res == ResultType.PREV_NOT_NULL ? oldRow.value() : null))
                     res = FILTERED;
 
@@ -392,7 +393,8 @@ public class MvccUpdateDataRow extends MvccDataRow implements MvccUpdateResult,
                         }
                     }
 
-                    // TODO: IGNITE-9689: optimize filter usage here. See {@link org.apache.ignite.internal.processors.cache.CacheOperationFilter}.
+                    // TODO: IGNITE-9689: optimize filter usage here.
+                    //  See {@link org.apache.ignite.internal.processors.cache.CacheOperationFilter}.
                     if (filter != null && !applyFilter(res == ResultType.PREV_NOT_NULL ? oldRow.value() : null))
                         res = FILTERED;
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/ClusterMetricsUpdateMessage.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/ClusterMetricsUpdateMessage.java
index 5c3044b..39c34a3 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/ClusterMetricsUpdateMessage.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/ClusterMetricsUpdateMessage.java
@@ -29,6 +29,8 @@ import org.apache.ignite.plugin.extensions.communication.MessageReader;
 import org.apache.ignite.plugin.extensions.communication.MessageWriter;
 import org.jetbrains.annotations.Nullable;
 
+import static org.apache.ignite.plugin.extensions.communication.MessageCollectionItemType.BYTE_ARR;
+
 /**
  *
  */
@@ -91,7 +93,7 @@ public class ClusterMetricsUpdateMessage implements Message {
 
         switch (writer.state()) {
             case 0:
-                if (!writer.writeMap("allNodesMetrics", allNodesMetrics, MessageCollectionItemType.UUID, MessageCollectionItemType.BYTE_ARR))
+                if (!writer.writeMap("allNodesMetrics", allNodesMetrics, MessageCollectionItemType.UUID, BYTE_ARR))
                     return false;
 
                 writer.incrementState();
@@ -116,7 +118,7 @@ public class ClusterMetricsUpdateMessage implements Message {
 
         switch (reader.state()) {
             case 0:
-                allNodesMetrics = reader.readMap("allNodesMetrics", MessageCollectionItemType.UUID, MessageCollectionItemType.BYTE_ARR, false);
+                allNodesMetrics = reader.readMap("allNodesMetrics", MessageCollectionItemType.UUID, BYTE_ARR, false);
 
                 if (!reader.isLastRead())
                     return false;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/GridClusterStateProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/GridClusterStateProcessor.java
index b7ff732..b839a6c 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/GridClusterStateProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/GridClusterStateProcessor.java
@@ -723,7 +723,9 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
                 DiscoveryDataClusterState newState = globalState = DiscoveryDataClusterState.createTransitionState(
                     msg.state(),
                     state,
-                    activate(state.state(), msg.state()) || msg.forceChangeBaselineTopology() ? msg.baselineTopology() : state.baselineTopology(),
+                    activate(state.state(), msg.state()) || msg.forceChangeBaselineTopology()
+                        ? msg.baselineTopology()
+                        : state.baselineTopology(),
                     msg.requestId(),
                     topVer,
                     nodeIds
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastreamer/DataStreamerRequest.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastreamer/DataStreamerRequest.java
index 87313de..92d5ad6 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastreamer/DataStreamerRequest.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastreamer/DataStreamerRequest.java
@@ -35,6 +35,8 @@ import org.apache.ignite.plugin.extensions.communication.MessageWriter;
 import org.jetbrains.annotations.NotNull;
 import org.jetbrains.annotations.Nullable;
 
+import static org.apache.ignite.plugin.extensions.communication.MessageCollectionItemType.IGNITE_UUID;
+
 /**
  *
  */
@@ -333,7 +335,7 @@ public class DataStreamerRequest implements Message {
                 writer.incrementState();
 
             case 7:
-                if (!writer.writeMap("ldrParticipants", ldrParticipants, MessageCollectionItemType.UUID, MessageCollectionItemType.IGNITE_UUID))
+                if (!writer.writeMap("ldrParticipants", ldrParticipants, MessageCollectionItemType.UUID, IGNITE_UUID))
                     return false;
 
                 writer.incrementState();
@@ -460,7 +462,7 @@ public class DataStreamerRequest implements Message {
                 reader.incrementState();
 
             case 7:
-                ldrParticipants = reader.readMap("ldrParticipants", MessageCollectionItemType.UUID, MessageCollectionItemType.IGNITE_UUID, false);
+                ldrParticipants = reader.readMap("ldrParticipants", MessageCollectionItemType.UUID, IGNITE_UUID, false);
 
                 if (!reader.isLastRead())
                     return false;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/DataStructuresProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/DataStructuresProcessor.java
index 8731e6e..aae3358 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/DataStructuresProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/DataStructuresProcessor.java
@@ -622,7 +622,11 @@ public final class DataStructuresProcessor extends GridProcessorAdapter implemen
         final long initVal,
         final boolean create) throws IgniteCheckedException {
         return getAtomic(new AtomicAccessor<GridCacheAtomicLongEx>() {
-            @Override public T2<GridCacheAtomicLongEx, AtomicDataStructureValue> get(GridCacheInternalKey key, AtomicDataStructureValue val, IgniteInternalCache cache) throws IgniteCheckedException {
+            @Override public T2<GridCacheAtomicLongEx, AtomicDataStructureValue> get(
+                GridCacheInternalKey key,
+                AtomicDataStructureValue val,
+                IgniteInternalCache cache
+            ) throws IgniteCheckedException {
                 // Check that atomic long hasn't been created in other thread yet.
                 GridCacheAtomicLongEx a = cast(dsMap.get(key), GridCacheAtomicLongEx.class);
 
@@ -925,7 +929,11 @@ public final class DataStructuresProcessor extends GridProcessorAdapter implemen
         throws IgniteCheckedException
     {
         return getAtomic(new AtomicAccessor<GridCacheAtomicReferenceEx>() {
-            @Override public T2<GridCacheAtomicReferenceEx, AtomicDataStructureValue> get(GridCacheInternalKey key, AtomicDataStructureValue val, IgniteInternalCache cache) throws IgniteCheckedException {
+            @Override public T2<GridCacheAtomicReferenceEx, AtomicDataStructureValue> get(
+                GridCacheInternalKey key,
+                AtomicDataStructureValue val,
+                IgniteInternalCache cache
+            ) throws IgniteCheckedException {
                 // Check that atomic reference hasn't been created in other thread yet.
                 GridCacheAtomicReferenceEx ref = cast(dsMap.get(key),
                     GridCacheAtomicReferenceEx.class);
@@ -976,7 +984,11 @@ public final class DataStructuresProcessor extends GridProcessorAdapter implemen
     public final <T, S> IgniteAtomicStamped<T, S> atomicStamped(final String name, @Nullable AtomicConfiguration cfg,
         final T initVal, final S initStamp, final boolean create) throws IgniteCheckedException {
         return getAtomic(new AtomicAccessor<GridCacheAtomicStampedEx>() {
-            @Override public T2<GridCacheAtomicStampedEx, AtomicDataStructureValue> get(GridCacheInternalKey key, AtomicDataStructureValue val, IgniteInternalCache cache) throws IgniteCheckedException {
+            @Override public T2<GridCacheAtomicStampedEx, AtomicDataStructureValue> get(
+                GridCacheInternalKey key,
+                AtomicDataStructureValue val,
+                IgniteInternalCache cache
+            ) throws IgniteCheckedException {
                 // Check that atomic stamped hasn't been created in other thread yet.
                 GridCacheAtomicStampedEx stmp = cast(dsMap.get(key),
                     GridCacheAtomicStampedEx.class);
@@ -1368,7 +1380,11 @@ public final class DataStructuresProcessor extends GridProcessorAdapter implemen
             A.ensure(cnt >= 0, "count can not be negative");
 
         return getAtomic(new AtomicAccessor<GridCacheCountDownLatchEx>() {
-            @Override public T2<GridCacheCountDownLatchEx, AtomicDataStructureValue> get(GridCacheInternalKey key, AtomicDataStructureValue val, IgniteInternalCache cache) throws IgniteCheckedException {
+            @Override public T2<GridCacheCountDownLatchEx, AtomicDataStructureValue> get(
+                GridCacheInternalKey key,
+                AtomicDataStructureValue val,
+                IgniteInternalCache cache
+            ) throws IgniteCheckedException {
                 // Check that count down hasn't been created in other thread yet.
                 GridCacheCountDownLatchEx latch = cast(dsMap.get(key), GridCacheCountDownLatchEx.class);
 
@@ -1440,7 +1456,11 @@ public final class DataStructuresProcessor extends GridProcessorAdapter implemen
         final boolean failoverSafe, final boolean create)
         throws IgniteCheckedException {
         return getAtomic(new AtomicAccessor<GridCacheSemaphoreEx>() {
-            @Override public T2<GridCacheSemaphoreEx, AtomicDataStructureValue> get(GridCacheInternalKey key, AtomicDataStructureValue val, IgniteInternalCache cache) throws IgniteCheckedException {
+            @Override public T2<GridCacheSemaphoreEx, AtomicDataStructureValue> get(
+                GridCacheInternalKey key,
+                AtomicDataStructureValue val,
+                IgniteInternalCache cache
+            ) throws IgniteCheckedException {
                 // Check that semaphore hasn't been created in other thread yet.
                 GridCacheSemaphoreEx sem = cast(dsMap.get(key), GridCacheSemaphoreEx.class);
 
@@ -1532,7 +1552,11 @@ public final class DataStructuresProcessor extends GridProcessorAdapter implemen
     public IgniteLock reentrantLock(final String name, @Nullable AtomicConfiguration cfg, final boolean failoverSafe,
         final boolean fair, final boolean create) throws IgniteCheckedException {
         return getAtomic(new AtomicAccessor<GridCacheLockEx>() {
-            @Override public T2<GridCacheLockEx, AtomicDataStructureValue> get(GridCacheInternalKey key, AtomicDataStructureValue val, IgniteInternalCache cache) throws IgniteCheckedException {
+            @Override public T2<GridCacheLockEx, AtomicDataStructureValue> get(
+                GridCacheInternalKey key,
+                AtomicDataStructureValue val,
+                IgniteInternalCache cache
+            ) throws IgniteCheckedException {
                 // Check that reentrant lock hasn't been created in other thread yet.
                 GridCacheLockEx reentrantLock = cast(dsMap.get(key), GridCacheLockEx.class);
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicReferenceImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicReferenceImpl.java
index d21def0..ef95298 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicReferenceImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicReferenceImpl.java
@@ -46,8 +46,8 @@ import static org.apache.ignite.transactions.TransactionIsolation.REPEATABLE_REA
 /**
  * Cache atomic reference implementation.
  */
-public final class GridCacheAtomicReferenceImpl<T> extends AtomicDataStructureProxy<GridCacheAtomicReferenceValue<T>> implements GridCacheAtomicReferenceEx<T>,
-    IgniteChangeGlobalStateSupport, Externalizable {
+public final class GridCacheAtomicReferenceImpl<T> extends AtomicDataStructureProxy<GridCacheAtomicReferenceValue<T>>
+    implements GridCacheAtomicReferenceEx<T>, IgniteChangeGlobalStateSupport, Externalizable {
     /** */
     private static final long serialVersionUID = 0L;
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/marshaller/MarshallerMappingTransport.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/marshaller/MarshallerMappingTransport.java
index b80ae36..eb50850 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/marshaller/MarshallerMappingTransport.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/marshaller/MarshallerMappingTransport.java
@@ -96,7 +96,10 @@ public final class MarshallerMappingTransport {
      * @param item Item.
      * @param cache Cache.
      */
-    public GridFutureAdapter<MappingExchangeResult> proposeMapping(MarshallerMappingItem item, ConcurrentMap<Integer, MappedName> cache) throws IgniteCheckedException {
+    public GridFutureAdapter<MappingExchangeResult> proposeMapping(
+        MarshallerMappingItem item,
+        ConcurrentMap<Integer, MappedName> cache
+    ) throws IgniteCheckedException {
         GridFutureAdapter<MappingExchangeResult> fut = new MappingExchangeResultFuture(item);
 
         GridFutureAdapter<MappingExchangeResult> oldFut = mappingExchSyncMap.putIfAbsent(item, fut);
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/offheap/GridOffHeapProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/offheap/GridOffHeapProcessor.java
index 6118b31..583ca25 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/offheap/GridOffHeapProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/offheap/GridOffHeapProcessor.java
@@ -238,7 +238,12 @@ public class GridOffHeapProcessor extends GridProcessorAdapter {
      * @return Value bytes.
      * @throws IgniteCheckedException If failed.
      */
-    @Nullable public byte[] remove(@Nullable String spaceName, int part, KeyCacheObject key, byte[] keyBytes) throws IgniteCheckedException {
+    @Nullable public byte[] remove(
+        @Nullable String spaceName,
+        int part,
+        KeyCacheObject key,
+        byte[] keyBytes
+    ) throws IgniteCheckedException {
         GridOffHeapPartitionedMap m = offheap(spaceName);
 
         if (log.isTraceEnabled())
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/package-info.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/package-info.java
index 843b08e..a9cff8b 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/package-info.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/package-info.java
@@ -19,8 +19,8 @@
  * Package with Apache Ignite internal Processors.
  * Processor is Ignite component with lifecycle associated with node lifecycle.
  *
- * See also
- * <a href='https://github.com/apache/ignite/tree/master/modules/core/src/main/java/org/apache/ignite/internal/processors/'>Package Readme</a>
+ * See also <a href='https://github.com/apache/ignite/tree/master/modules/core/src/main/java/org/apache/ignite/internal/processors/'>
+ *     Package Readme</a>
  *
  */
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformProcessorImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformProcessorImpl.java
index 266b9de..71baa87 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformProcessorImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformProcessorImpl.java
@@ -573,7 +573,11 @@ public class PlatformProcessorImpl extends GridProcessorAdapter implements Platf
     }
 
     /** {@inheritDoc} */
-    @Override public void processInStreamOutStream(int type, BinaryRawReaderEx reader, BinaryRawWriterEx writer) throws IgniteCheckedException {
+    @Override public void processInStreamOutStream(
+        int type,
+        BinaryRawReaderEx reader,
+        BinaryRawWriterEx writer
+    ) throws IgniteCheckedException {
         if (type == OP_GET_CACHE_CONFIG) {
             int cacheId = reader.readInt();
             CacheConfiguration cfg = ctx.cache().cacheDescriptor(cacheId).cacheConfiguration();
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/client/ClientConnectionContext.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/client/ClientConnectionContext.java
index fa4b663..de346f4 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/client/ClientConnectionContext.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/client/ClientConnectionContext.java
@@ -143,7 +143,13 @@ public class ClientConnectionContext extends ClientListenerAbstractConnectionCon
      * @param maxCursors Max active cursors.
      * @param thinCfg Thin-client configuration.
      */
-    public ClientConnectionContext(GridKernalContext ctx, GridNioSession ses, long connId, int maxCursors, ThinClientConfiguration thinCfg) {
+    public ClientConnectionContext(
+        GridKernalContext ctx,
+        GridNioSession ses,
+        long connId,
+        int maxCursors,
+        ThinClientConfiguration thinCfg
+    ) {
         super(ctx, ses, connId);
 
         this.maxCursors = maxCursors;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/transactions/PlatformTransactions.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/transactions/PlatformTransactions.java
index fa61f441..5e5ad9e 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/transactions/PlatformTransactions.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/transactions/PlatformTransactions.java
@@ -253,7 +253,11 @@ public class PlatformTransactions extends PlatformAbstractTarget {
     }
 
     /** {@inheritDoc} */
-    @Override public void processInStreamOutStream(int type, BinaryRawReaderEx reader, BinaryRawWriterEx writer) throws IgniteCheckedException {
+    @Override public void processInStreamOutStream(
+        int type,
+        BinaryRawReaderEx reader,
+        BinaryRawWriterEx writer
+    ) throws IgniteCheckedException {
         switch (type) {
             case OP_START: {
                 TransactionConcurrency txConcurrency = TransactionConcurrency.fromOrdinal(reader.readInt());
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/query/GridQueryProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/query/GridQueryProcessor.java
index 6f99fdd..8348ad3 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/query/GridQueryProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/query/GridQueryProcessor.java
@@ -156,7 +156,8 @@ public class GridQueryProcessor extends GridProcessorAdapter {
     private static final String INLINE_SIZES_DISCO_BAG_KEY = "inline_sizes";
 
     /** Warn message if some indexes have different inline sizes on the nodes. */
-    public static final String INLINE_SIZES_DIFFER_WARN_MSG_FORMAT = "Inline sizes on local node and node %s are different. Please drop and create again these indexes to avoid performance problems with SQL queries. Problem indexes: %s";
+    public static final String INLINE_SIZES_DIFFER_WARN_MSG_FORMAT = "Inline sizes on local node and node %s are different. " +
+        "Please drop and create again these indexes to avoid performance problems with SQL queries. Problem indexes: %s";
 
     /** Queries detail metrics eviction frequency. */
     private static final int QRY_DETAIL_METRICS_EVICTION_FREQ = 3_000;
@@ -2481,7 +2482,10 @@ public class GridQueryProcessor extends GridProcessorAdapter {
                     LT.warn(log, "Key-value pair is not inserted into any SQL table [cacheName=" + cacheName +
                         ", " + describeTypeMismatch(cacheName, val) + "]");
 
-                    LT.warn(log, "  ^-- Value type(s) are specified via CacheConfiguration.indexedTypes or CacheConfiguration.queryEntities");
+                    LT.warn(
+                        log,
+                        "  ^-- Value type(s) are specified via CacheConfiguration.indexedTypes or CacheConfiguration.queryEntities"
+                    );
                     LT.warn(log, "  ^-- Make sure that same type(s) used when adding Object or BinaryObject to cache");
                     LT.warn(log, "  ^-- Otherwise, entries will be stored in cache, but not appear as SQL Table rows");
                 }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/probe/GridProbeCommandHandler.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/probe/GridProbeCommandHandler.java
index 844dd5b..4198c41 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/probe/GridProbeCommandHandler.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/probe/GridProbeCommandHandler.java
@@ -60,7 +60,11 @@ public class GridProbeCommandHandler extends GridRestCommandHandlerAdapter {
                 if (log.isDebugEnabled())
                     log.debug("probe command handler invoked.");
 
-                return new GridFinishedFuture<>(IgnitionEx.hasKernalStarted(ctx.igniteInstanceName()) ? new GridRestResponse("grid has started") : new GridRestResponse(GridRestResponse.SERVICE_UNAVAILABLE, "grid has not started"));
+                return new GridFinishedFuture<>(
+                    IgnitionEx.hasKernalStarted(ctx.igniteInstanceName())
+                        ? new GridRestResponse("grid has started")
+                        : new GridRestResponse(GridRestResponse.SERVICE_UNAVAILABLE, "grid has not started")
+                );
 
             }
         }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/subscription/GridInternalSubscriptionProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/subscription/GridInternalSubscriptionProcessor.java
index 7f89ed1..f27bdc0 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/subscription/GridInternalSubscriptionProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/subscription/GridInternalSubscriptionProcessor.java
@@ -46,7 +46,8 @@ public class GridInternalSubscriptionProcessor extends GridProcessorAdapter {
     private final List<DatabaseLifecycleListener> dbListeners = new ArrayList<>();
 
     /**
-     * Listeners of distributed configuration controlled by {@link org.apache.ignite.internal.processors.configuration.distributed.DistributedConfigurationProcessor}.
+     * Listeners of distributed configuration controlled by
+     * {@link org.apache.ignite.internal.processors.configuration.distributed.DistributedConfigurationProcessor}.
      */
     private List<DistributedConfigurationLifecycleListener> distributedConfigurationListeners = new ArrayList<>();
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/tracing/configuration/GridTracingConfigurationManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/tracing/configuration/GridTracingConfigurationManager.java
index 9ffd33f..2620b89 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/tracing/configuration/GridTracingConfigurationManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/tracing/configuration/GridTracingConfigurationManager.java
@@ -171,8 +171,12 @@ public class GridTracingConfigurationManager implements TracingConfigurationMana
 
         if (coordinates.label() != null)
             newTracingConfiguration.remove(coordinates);
-        else
-            newTracingConfiguration.put(coordinates, DEFAULT_CONFIGURATION_MAP.get(new TracingConfigurationCoordinates.Builder(coordinates.scope()).build()));
+        else {
+            newTracingConfiguration.put(
+                coordinates,
+                DEFAULT_CONFIGURATION_MAP.get(new TracingConfigurationCoordinates.Builder(coordinates.scope()).build())
+            );
+        }
 
         try {
             distributedTracingConfiguration.propagate(newTracingConfiguration);
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/GridUnsafe.java b/modules/core/src/main/java/org/apache/ignite/internal/util/GridUnsafe.java
index 95f848d..19f7f64 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/GridUnsafe.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/GridUnsafe.java
@@ -207,8 +207,11 @@ public abstract class GridUnsafe {
             return wrapPointerJavaNio(ptr, len, NEW_DIRECT_BUF_MTD, JAVA_NIO_ACCESS_OBJ);
         else if (NEW_DIRECT_BUF_CONSTRUCTOR != null)
             return wrapPointerDirectBufCtor(ptr, len, NEW_DIRECT_BUF_CONSTRUCTOR);
-        else
-            throw new RuntimeException("All alternative for a new DirectByteBuffer() creation failed: " + FeatureChecker.JAVA_VER_SPECIFIC_WARN);
+        else {
+            throw new RuntimeException(
+                "All alternative for a new DirectByteBuffer() creation failed: " + FeatureChecker.JAVA_VER_SPECIFIC_WARN
+            );
+        }
     }
 
     /**
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/IgniteUtils.java b/modules/core/src/main/java/org/apache/ignite/internal/util/IgniteUtils.java
index 37d6505..3ddea5d 100755
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/IgniteUtils.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/IgniteUtils.java
@@ -1663,7 +1663,8 @@ public abstract class IgniteUtils {
      *
      * @param cls Class.
      * @param dflt Default class to return.
-     * @param includePrimitiveTypes Whether class resolution should include primitive types (i.e. "int" will resolve to int.class if flag is set)
+     * @param includePrimitiveTypes Whether class resolution should include primitive types
+     *                              (i.e. "int" will resolve to int.class if flag is set)
      * @return Class or default given class if it can't be found.
      */
     @Nullable public static Class<?> classForName(
@@ -8993,7 +8994,11 @@ public abstract class IgniteUtils {
      * @return Class.
      * @throws ClassNotFoundException If class not found.
      */
-    public static Class<?> forName(String clsName, @Nullable ClassLoader ldr, IgnitePredicate<String> clsFilter) throws ClassNotFoundException {
+    public static Class<?> forName(
+        String clsName,
+        @Nullable ClassLoader ldr,
+        IgnitePredicate<String> clsFilter
+    ) throws ClassNotFoundException {
         return forName(clsName, ldr, clsFilter, GridBinaryMarshaller.USE_CACHE.get());
     }
 
@@ -9002,11 +9007,16 @@ public abstract class IgniteUtils {
      *
      * @param clsName Class name.
      * @param ldr Class loader.
-    * @param useCache If true class loader and result should be cached internally, false otherwise.
+     * @param useCache If true class loader and result should be cached internally, false otherwise.
      * @return Class.
      * @throws ClassNotFoundException If class not found.
      */
-    public static Class<?> forName(String clsName, @Nullable ClassLoader ldr, IgnitePredicate<String> clsFilter, boolean useCache) throws ClassNotFoundException {
+    public static Class<?> forName(
+        String clsName,
+        @Nullable ClassLoader ldr,
+        IgnitePredicate<String> clsFilter,
+        boolean useCache
+    ) throws ClassNotFoundException {
         assert clsName != null;
 
         Class<?> cls = primitiveMap.get(clsName);
@@ -9331,8 +9341,8 @@ public abstract class IgniteUtils {
     }
 
     /**
-     * For each object provided by the given {@link Iterable} checks if it implements
-     * {@link org.apache.ignite.lifecycle.LifecycleAware} interface and executes {@link org.apache.ignite.lifecycle.LifecycleAware#stop} method.
+     * For each object provided by the given {@link Iterable} checks if it implements {@link org.apache.ignite.lifecycle.LifecycleAware}
+     * interface and executes {@link org.apache.ignite.lifecycle.LifecycleAware#stop} method.
      *
      * @param log Logger used to log error message in case of stop failure.
      * @param objs Object passed to Ignite configuration.
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/tostring/GridToStringBuilder.java b/modules/core/src/main/java/org/apache/ignite/internal/util/tostring/GridToStringBuilder.java
index a526764..b901b13 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/tostring/GridToStringBuilder.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/tostring/GridToStringBuilder.java
@@ -140,11 +140,8 @@ public class GridToStringBuilder {
      * have to keep a map of this objects pointed to the position of previous occurrence
      * and remove/add them in each {@code toString()} apply.
      */
-    private static ThreadLocal<IdentityHashMap<Object, EntryReference>> savedObjects = new ThreadLocal<IdentityHashMap<Object, EntryReference>>() {
-        @Override protected IdentityHashMap<Object, EntryReference> initialValue() {
-            return new IdentityHashMap<>();
-        }
-    };
+    private static ThreadLocal<IdentityHashMap<Object, EntryReference>> savedObjects =
+        ThreadLocal.withInitial(() -> new IdentityHashMap<>());
 
     /**
      * Implementation of the <a href=
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CIX1.java b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CIX1.java
index 1c8bf77..6f93e5d 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CIX1.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CIX1.java
@@ -21,9 +21,10 @@ import org.apache.ignite.internal.util.lang.GridFunc;
 import org.apache.ignite.internal.util.lang.IgniteInClosureX;
 
 /**
- * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteInClosureX} by extending it. Since Java doesn't provide type aliases
- * (like Scala, for example) we resort to these types of measures. This is intended to provide for more
- * concise code in cases when readability won't be sacrificed. For more information see {@link org.apache.ignite.internal.util.lang.IgniteInClosureX}.
+ * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteInClosureX} by extending it.
+ * Since Java doesn't provide type aliases (like Scala, for example) we resort to these types of measures.
+ * This is intended to provide for more concise code in cases when readability won't be sacrificed.
+ * For more information see {@link org.apache.ignite.internal.util.lang.IgniteInClosureX}.
  * @param <T> Type of the factory closure.
  * @see GridFunc
  * @see org.apache.ignite.internal.util.lang.IgniteInClosureX
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CIX2.java b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CIX2.java
index 87fd443..2f48e1d 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CIX2.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CIX2.java
@@ -21,9 +21,10 @@ import org.apache.ignite.internal.util.lang.GridFunc;
 import org.apache.ignite.internal.util.lang.IgniteInClosure2X;
 
 /**
- * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteInClosure2X} by extending it. Since Java doesn't provide type aliases
- * (like Scala, for example) we resort to these types of measures. This is intended to provide for more
- * concise code in cases when readability won't be sacrificed. For more information see {@link org.apache.ignite.internal.util.lang.IgniteInClosure2X}.
+ * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteInClosure2X} by extending it.
+ * Since Java doesn't provide type aliases (like Scala, for example) we resort to these types of measures.
+ * This is intended to provide for more concise code in cases when readability won't be sacrificed.
+ * For more information see {@link org.apache.ignite.internal.util.lang.IgniteInClosure2X}.
  * @see GridFunc
  * @see org.apache.ignite.internal.util.lang.IgniteInClosure2X
  */
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/COX.java b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/COX.java
index d176fb9..90e5c09 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/COX.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/COX.java
@@ -21,9 +21,10 @@ import org.apache.ignite.internal.util.lang.GridFunc;
 import org.apache.ignite.internal.util.lang.IgniteOutClosureX;
 
 /**
- * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteOutClosureX} by extending it. Since Java doesn't provide type aliases
- * (like Scala, for example) we resort to these types of measures. This is intended to provide for more
- * concise code in cases when readability won't be sacrificed. For more information see {@link org.apache.ignite.internal.util.lang.IgniteOutClosureX}.
+ * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteOutClosureX} by extending it.
+ * Since Java doesn't provide type aliases (like Scala, for example) we resort to these types of measures.
+ * This is intended to provide for more concise code in cases when readability won't be sacrificed.
+ * For more information see {@link org.apache.ignite.internal.util.lang.IgniteOutClosureX}.
  * @param <T> Type of the factory closure.
  * @see GridFunc
  * @see org.apache.ignite.internal.util.lang.IgniteOutClosureX
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CX1.java b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CX1.java
index da113c1..eb4e714 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CX1.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CX1.java
@@ -21,9 +21,10 @@ import org.apache.ignite.internal.util.lang.GridFunc;
 import org.apache.ignite.internal.util.lang.IgniteClosureX;
 
 /**
- * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteClosureX} by extending it. Since Java doesn't provide type aliases
- * (like Scala, for example) we resort to these types of measures. This is intended to provide for more
- * concise code in cases when readability won't be sacrificed. For more information see {@link org.apache.ignite.internal.util.lang.IgniteClosureX}.
+ * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteClosureX} by extending it.
+ * Since Java doesn't provide type aliases (like Scala, for example) we resort to these types of measures.
+ * This is intended to provide for more concise code in cases when readability won't be sacrificed.
+ * For more information see {@link org.apache.ignite.internal.util.lang.IgniteClosureX}.
  * @param <E1> Type of the free variable, i.e. the element the closure is called or closed on.
  * @param <R> Type of the closure's return value.
  * @see GridFunc
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CX2.java b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CX2.java
index 96abfb9..7ec3e43 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CX2.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/CX2.java
@@ -21,9 +21,10 @@ import org.apache.ignite.internal.util.lang.GridFunc;
 import org.apache.ignite.internal.util.lang.IgniteClosure2X;
 
 /**
- * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteClosure2X} by extending it. Since Java doesn't provide type aliases
- * (like Scala, for example) we resort to these types of measures. This is intended to provide for more
- * concise code in cases when readability won't be sacrificed. For more information see {@link org.apache.ignite.internal.util.lang.IgniteClosure2X}.
+ * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteClosure2X} by extending it.
+ * Since Java doesn't provide type aliases (like Scala, for example) we resort to these types of measures.
+ * This is intended to provide for more concise code in cases when readability won't be sacrificed.
+ * For more information see {@link org.apache.ignite.internal.util.lang.IgniteClosure2X}.
  * @param <E1> Type of the first free variable, i.e. the element the closure is called or closed on.
  * @param <E2> Type of the second free variable, i.e. the element the closure is called or closed on.
  * @param <R> Type of the closure's return value.
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/PX1.java b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/PX1.java
index 506f23b..1a27b0f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/PX1.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/PX1.java
@@ -21,9 +21,10 @@ import org.apache.ignite.internal.util.lang.GridFunc;
 import org.apache.ignite.internal.util.lang.IgnitePredicateX;
 
 /**
- * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgnitePredicateX} by extending it. Since Java doesn't provide type aliases
- * (like Scala, for example) we resort to these types of measures. This is intended to provide for more
- * concise code in cases when readability won't be sacrificed. For more information see {@link org.apache.ignite.internal.util.lang.IgnitePredicateX}.
+ * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgnitePredicateX} by extending it.
+ * Since Java doesn't provide type aliases (like Scala, for example) we resort to these types of measures.
+ * This is intended to provide for more concise code in cases when readability won't be sacrificed.
+ * For more information see {@link org.apache.ignite.internal.util.lang.IgnitePredicateX}.
  * @param <E1> Type of the free variable, i.e. the element the predicate is called on.
  * @see GridFunc
  * @see org.apache.ignite.internal.util.lang.IgnitePredicateX
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/PX2.java b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/PX2.java
index 8176c3f..759a5c5 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/PX2.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/PX2.java
@@ -21,9 +21,10 @@ import org.apache.ignite.internal.util.lang.GridFunc;
 import org.apache.ignite.internal.util.lang.IgnitePredicate2X;
 
 /**
- * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgnitePredicate2X} by extending it. Since Java doesn't provide type aliases
- * (like Scala, for example) we resort to these types of measures. This is intended to provide for more
- * concise code in cases when readability won't be sacrificed. For more information see {@link org.apache.ignite.internal.util.lang.IgnitePredicate2X}.
+ * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgnitePredicate2X} by extending it.
+ * Since Java doesn't provide type aliases (like Scala, for example) we resort to these types of measures.
+ * This is intended to provide for more concise code in cases when readability won't be sacrificed.
+ * For more information see {@link org.apache.ignite.internal.util.lang.IgnitePredicate2X}.
  * @param <T1> Type of the first free variable, i.e. the element the closure is called on.
  * @param <T2> Type of the second free variable, i.e. the element the closure is called on.
  * @see GridFunc
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/R2.java b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/R2.java
index 9c1f335..147e783 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/R2.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/R2.java
@@ -21,9 +21,10 @@ import org.apache.ignite.internal.util.lang.GridFunc;
 import org.apache.ignite.internal.util.lang.IgniteReducer2;
 
 /**
- * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteReducer2} by extending it. Since Java doesn't provide type aliases
- * (like Scala, for example) we resort to these types of measures. This is intended to provide for more
- * concise code in cases when readability won't be sacrificed. For more information see {@link org.apache.ignite.internal.util.lang.IgniteReducer2}.
+ * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteReducer2} by extending it.
+ * Since Java doesn't provide type aliases (like Scala, for example) we resort to these types of measures.
+ * This is intended to provide for more concise code in cases when readability won't be sacrificed.
+ * For more information see {@link org.apache.ignite.internal.util.lang.IgniteReducer2}.
  * @param <E1> Type of the free variable, i.e. the element the closure is called or closed on.
  * @param <R> Type of the closure's return value.
  * @see GridFunc
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/R3.java b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/R3.java
index ac4884b..17ebf6c 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/R3.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/R3.java
@@ -21,9 +21,10 @@ import org.apache.ignite.internal.util.lang.GridFunc;
 import org.apache.ignite.internal.util.lang.IgniteReducer3;
 
 /**
- * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteReducer3} by extending it. Since Java doesn't provide type aliases
- * (like Scala, for example) we resort to these types of measures. This is intended to provide for more
- * concise code in cases when readability won't be sacrificed. For more information see {@link org.apache.ignite.internal.util.lang.IgniteReducer3}.
+ * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteReducer3} by extending it.
+ * Since Java doesn't provide type aliases (like Scala, for example) we resort to these types of measures.
+ * This is intended to provide for more concise code in cases when readability won't be sacrificed.
+ * For more information see {@link org.apache.ignite.internal.util.lang.IgniteReducer3}.
  * @param <E1> Type of the free variable, i.e. the element the closure is called or closed on.
  * @param <R> Type of the closure's return value.
  * @see GridFunc
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/RX1.java b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/RX1.java
index 329bd93..f5ee827 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/RX1.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/RX1.java
@@ -21,9 +21,10 @@ import org.apache.ignite.internal.util.lang.GridFunc;
 import org.apache.ignite.internal.util.lang.IgniteReducerX;
 
 /**
- * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteReducerX} by extending it. Since Java doesn't provide type aliases
- * (like Scala, for example) we resort to these types of measures. This is intended to provide for more
- * concise code in cases when readability won't be sacrificed. For more information see {@link org.apache.ignite.internal.util.lang.IgniteReducerX}.
+ * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteReducerX} by extending it.
+ * Since Java doesn't provide type aliases (like Scala, for example) we resort to these types of measures.
+ * This is intended to provide for more concise code in cases when readability won't be sacrificed.
+ * For more information see {@link org.apache.ignite.internal.util.lang.IgniteReducerX}.
  * @param <E1> Type of the free variable, i.e. the element the closure is called or closed on.
  * @param <R> Type of the closure's return value.
  * @see GridFunc
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/RX2.java b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/RX2.java
index 840b437..b522757 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/RX2.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/RX2.java
@@ -21,9 +21,10 @@ import org.apache.ignite.internal.util.lang.GridFunc;
 import org.apache.ignite.internal.util.lang.IgniteReducer2X;
 
 /**
- * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteReducer2X} by extending it. Since Java doesn't provide type aliases
- * (like Scala, for example) we resort to these types of measures. This is intended to provide for more
- * concise code in cases when readability won't be sacrificed. For more information see {@link org.apache.ignite.internal.util.lang.IgniteReducer2X}.
+ * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteReducer2X} by extending it.
+ * Since Java doesn't provide type aliases (like Scala, for example) we resort to these types of measures.
+ * This is intended to provide for more concise code in cases when readability won't be sacrificed.
+ * For more information see {@link org.apache.ignite.internal.util.lang.IgniteReducer2X}.
  * @param <E1> Type of the free variable, i.e. the element the closure is called or closed on.
  * @param <R> Type of the closure's return value.
  * @see GridFunc
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/RX3.java b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/RX3.java
index 70da220..1efec94 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/RX3.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/typedef/RX3.java
@@ -21,9 +21,10 @@ import org.apache.ignite.internal.util.lang.GridFunc;
 import org.apache.ignite.internal.util.lang.IgniteReducer3X;
 
 /**
- * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteReducer3X} by extending it. Since Java doesn't provide type aliases
- * (like Scala, for example) we resort to these types of measures. This is intended to provide for more
- * concise code in cases when readability won't be sacrificed. For more information see {@link org.apache.ignite.internal.util.lang.IgniteReducer3X}.
+ * Defines {@code alias} for {@link org.apache.ignite.internal.util.lang.IgniteReducer3X} by extending it.
+ * Since Java doesn't provide type aliases (like Scala, for example) we resort to these types of measures.
+ * This is intended to provide for more concise code in cases when readability won't be sacrificed.
+ * For more information see {@link org.apache.ignite.internal.util.lang.IgniteReducer3X}.
  * @param <E1> Type of the free variable, i.e. the element the closure is called or closed on.
  * @param <R> Type of the closure's return value.
  * @see GridFunc
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/worker/GridWorker.java b/modules/core/src/main/java/org/apache/ignite/internal/util/worker/GridWorker.java
index 3e61137..5926b9c 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/worker/GridWorker.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/worker/GridWorker.java
@@ -132,7 +132,9 @@ public abstract class GridWorker implements Runnable, WorkProgressDispatcher {
         // Catch everything to make sure that it gets logged properly and
         // not to kill any threads from the underlying thread pool.
         catch (Throwable e) {
-            if (!X.hasCause(e, InterruptedException.class) && !X.hasCause(e, IgniteInterruptedCheckedException.class) && !X.hasCause(e, IgniteInterruptedException.class))
+            if (!X.hasCause(e, InterruptedException.class) &&
+                !X.hasCause(e, IgniteInterruptedCheckedException.class) &&
+                !X.hasCause(e, IgniteInterruptedException.class))
                 U.error(log, "Runtime error caught during grid runnable execution: " + this, e);
             else
                 U.warn(log, "Runtime exception occurred during grid runnable execution caused by thread interruption: " + e.getMessage());
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorFindAndDeleteGarbageInPersistenceTask.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorFindAndDeleteGarbageInPersistenceTask.java
index ad167e3..7c09a51 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorFindAndDeleteGarbageInPersistenceTask.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorFindAndDeleteGarbageInPersistenceTask.java
@@ -44,7 +44,9 @@ public class VisorFindAndDeleteGarbageInPersistenceTask extends VisorMultiNodeTa
     private static final long serialVersionUID = 0L;
 
     /** {@inheritDoc} */
-    @Nullable @Override protected VisorFindAndDeleteGarbageInPersistenceTaskResult reduce0(List<ComputeJobResult> list) throws IgniteException {
+    @Nullable @Override protected VisorFindAndDeleteGarbageInPersistenceTaskResult reduce0(
+        List<ComputeJobResult> list
+    ) throws IgniteException {
         Map<UUID, Exception> exceptions = new HashMap<>();
         Map<UUID, VisorFindAndDeleteGarbageInPersistenceJobResult> jobResults = new HashMap<>();
 
@@ -59,7 +61,9 @@ public class VisorFindAndDeleteGarbageInPersistenceTask extends VisorMultiNodeTa
     }
 
     /** {@inheritDoc} */
-    @Override protected VisorJob<VisorFindAndDeleteGarbageInPersistenceTaskArg, VisorFindAndDeleteGarbageInPersistenceJobResult> job(VisorFindAndDeleteGarbageInPersistenceTaskArg arg) {
+    @Override protected VisorJob<VisorFindAndDeleteGarbageInPersistenceTaskArg, VisorFindAndDeleteGarbageInPersistenceJobResult> job(
+        VisorFindAndDeleteGarbageInPersistenceTaskArg arg
+    ) {
         return new FindAndDeleteGarbageInPersistenceJob(arg, debug);
     }
 
@@ -87,7 +91,8 @@ public class VisorFindAndDeleteGarbageInPersistenceTask extends VisorMultiNodeTa
     /**
      *
      */
-    private static class FindAndDeleteGarbageInPersistenceJob extends VisorJob<VisorFindAndDeleteGarbageInPersistenceTaskArg, VisorFindAndDeleteGarbageInPersistenceJobResult> {
+    private static class FindAndDeleteGarbageInPersistenceJob
+        extends VisorJob<VisorFindAndDeleteGarbageInPersistenceTaskArg, VisorFindAndDeleteGarbageInPersistenceJobResult> {
         /** */
         private static final long serialVersionUID = 0L;
 
@@ -100,9 +105,11 @@ public class VisorFindAndDeleteGarbageInPersistenceTask extends VisorMultiNodeTa
         }
 
         /** {@inheritDoc} */
-        @Override protected VisorFindAndDeleteGarbageInPersistenceJobResult run(@Nullable VisorFindAndDeleteGarbageInPersistenceTaskArg arg) throws IgniteException {
+        @Override protected VisorFindAndDeleteGarbageInPersistenceJobResult run(@Nullable VisorFindAndDeleteGarbageInPersistenceTaskArg arg)
+            throws IgniteException {
             try {
-                VisorFindAndDeleteGarbageInPersistenceClosure closure = new VisorFindAndDeleteGarbageInPersistenceClosure(arg.getGrpNames(), arg.deleteFoundGarbage());
+                VisorFindAndDeleteGarbageInPersistenceClosure closure =
+                    new VisorFindAndDeleteGarbageInPersistenceClosure(arg.getGrpNames(), arg.deleteFoundGarbage());
 
                 ignite.context().resource().injectGeneric(closure);
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/index/IndexRebuildStatusTask.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/index/IndexRebuildStatusTask.java
index 1e0c90d..ae2486c4 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/index/IndexRebuildStatusTask.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/index/IndexRebuildStatusTask.java
@@ -41,7 +41,10 @@ import org.jetbrains.annotations.Nullable;
  * Task that collects caches that have index rebuild in progress.
  */
 @GridInternal
-public class IndexRebuildStatusTask extends VisorMultiNodeTask<IndexRebuildStatusTaskArg, Map<UUID, Set<IndexRebuildStatusInfoContainer>>, Set<IndexRebuildStatusInfoContainer>> {
+public class IndexRebuildStatusTask extends VisorMultiNodeTask<
+    IndexRebuildStatusTaskArg,
+    Map<UUID, Set<IndexRebuildStatusInfoContainer>>,
+    Set<IndexRebuildStatusInfoContainer>> {
     /** */
     private static final long serialVersionUID = 0L;
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorCacheRebalanceCollectorTask.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorCacheRebalanceCollectorTask.java
index e0bc5c1..484150e 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorCacheRebalanceCollectorTask.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorCacheRebalanceCollectorTask.java
@@ -90,7 +90,8 @@ public class VisorCacheRebalanceCollectorTask extends VisorMultiNodeTask<VisorCa
     /**
      * Job that collects rebalance metrics.
      */
-    private static class VisorCacheRebalanceCollectorJob extends VisorJob<VisorCacheRebalanceCollectorTaskArg, VisorCacheRebalanceCollectorJobResult> {
+    private static class VisorCacheRebalanceCollectorJob
+        extends VisorJob<VisorCacheRebalanceCollectorTaskArg, VisorCacheRebalanceCollectorJobResult> {
         /** */
         private static final long serialVersionUID = 0L;
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/query/VisorRunningQueriesCollectorTask.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/query/VisorRunningQueriesCollectorTask.java
index 9d1da00..0abc657 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/query/VisorRunningQueriesCollectorTask.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/query/VisorRunningQueriesCollectorTask.java
@@ -36,7 +36,9 @@ import org.jetbrains.annotations.Nullable;
  * Task to collect currently running queries.
  */
 @GridInternal
-public class VisorRunningQueriesCollectorTask extends VisorMultiNodeTask<VisorRunningQueriesCollectorTaskArg, Map<UUID, Collection<VisorRunningQuery>>, Collection<VisorRunningQuery>> {
+public class VisorRunningQueriesCollectorTask
+    extends VisorMultiNodeTask<VisorRunningQueriesCollectorTaskArg, Map<UUID, Collection<VisorRunningQuery>>, Collection<VisorRunningQuery>>
+{
     /** */
     private static final long serialVersionUID = 0L;
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/tracing/configuration/VisorTracingConfigurationTask.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/tracing/configuration/VisorTracingConfigurationTask.java
index d7b0bc2..22c10f3 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/tracing/configuration/VisorTracingConfigurationTask.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/tracing/configuration/VisorTracingConfigurationTask.java
@@ -49,7 +49,8 @@ public class VisorTracingConfigurationTask
     /**
      * Job that will collect and update tracing configuration.
      */
-    private static class VisorTracingConfigurationJob extends VisorJob<VisorTracingConfigurationTaskArg, VisorTracingConfigurationTaskResult> {
+    private static class VisorTracingConfigurationJob
+        extends VisorJob<VisorTracingConfigurationTaskArg, VisorTracingConfigurationTaskResult> {
         /** */
         private static final long serialVersionUID = 0L;
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/util/VisorMimeTypes.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/util/VisorMimeTypes.java
index 81c6bf8..449395d 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/util/VisorMimeTypes.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/util/VisorMimeTypes.java
@@ -917,8 +917,10 @@ public class VisorMimeTypes {
 
         if (c1 == '<') {
             if (c2 == '!' ||
-                ((c2 == 'h' && (c3 == 't' && c4 == 'm' && c5 == 'l' || c3 == 'e' && c4 == 'a' && c5 == 'd') || (c2 == 'b' && c3 == 'o' && c4 == 'd' && c5 == 'y'))) ||
-                ((c2 == 'H' && (c3 == 'T' && c4 == 'M' && c5 == 'L' || c3 == 'E' && c4 == 'A' && c5 == 'D') || (c2 == 'B' && c3 == 'O' && c4 == 'D' && c5 == 'Y'))))
+                ((c2 == 'h' && (c3 == 't' && c4 == 'm' && c5 == 'l' || c3 == 'e' && c4 == 'a' && c5 == 'd') ||
+                    (c2 == 'b' && c3 == 'o' && c4 == 'd' && c5 == 'y'))) ||
+                ((c2 == 'H' && (c3 == 'T' && c4 == 'M' && c5 == 'L' || c3 == 'E' && c4 == 'A' && c5 == 'D') ||
+                    (c2 == 'B' && c3 == 'O' && c4 == 'D' && c5 == 'Y'))))
                 return "text/html";
 
             if (c2 == '?' && c3 == 'x' && c4 == 'm' && c5 == 'l' && c6 == ' ')
@@ -961,7 +963,8 @@ public class VisorMimeTypes {
             if (c4 == 0xE0)
                 return "image/jpeg";
 
-            // File format used by digital cameras to store images. Exif Format can be read by any application supporting JPEG. Exif Spec can be found at:
+            // File format used by digital cameras to store images.
+            // Exif Format can be read by any application supporting JPEG. Exif Spec can be found at:
             // http://www.pima.net/standards/it10/PIMA15740/Exif_2-1.PDF
             if ((c4 == 0xE1) && (c7 == 'E' && c8 == 'x' && c9 == 'i' && c10 == 'f' && c11 == 0))
                 return "image/jpeg";
diff --git a/modules/core/src/main/java/org/apache/ignite/mxbean/DataRegionMetricsMXBean.java b/modules/core/src/main/java/org/apache/ignite/mxbean/DataRegionMetricsMXBean.java
index 18531fb..71e5c54 100644
--- a/modules/core/src/main/java/org/apache/ignite/mxbean/DataRegionMetricsMXBean.java
+++ b/modules/core/src/main/java/org/apache/ignite/mxbean/DataRegionMetricsMXBean.java
@@ -130,7 +130,9 @@ public interface DataRegionMetricsMXBean extends DataRegionMetrics {
     @Override public int getPageSize();
 
     /** {@inheritDoc} */
-    @MXBeanDescription("The total size of pages loaded to the RAM. When persistence is disabled, this metric is equal to TotalAllocatedSize.")
+    @MXBeanDescription(
+        "The total size of pages loaded to the RAM. When persistence is disabled, this metric is equal to TotalAllocatedSize."
+    )
     @Override public long getPhysicalMemorySize();
 
     /** {@inheritDoc} */
diff --git a/modules/core/src/main/java/org/apache/ignite/mxbean/DefragmentationMXBean.java b/modules/core/src/main/java/org/apache/ignite/mxbean/DefragmentationMXBean.java
index 22a5e2d..220f684 100644
--- a/modules/core/src/main/java/org/apache/ignite/mxbean/DefragmentationMXBean.java
+++ b/modules/core/src/main/java/org/apache/ignite/mxbean/DefragmentationMXBean.java
@@ -29,7 +29,9 @@ public interface DefragmentationMXBean {
      * @return {@code true} if defragmentation is scheduled, {@code false} otherwise.
      */
     @MXBeanDescription("Schedule defragmentation.")
-    public boolean schedule(@MXBeanParameter(name = "cacheNames", description = "Names of caches to run defragmentation on.") String cacheNames);
+    public boolean schedule(
+        @MXBeanParameter(name = "cacheNames", description = "Names of caches to run defragmentation on.") String cacheNames
+    );
 
     /**
      * Cancel defragmentation.
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/checkpoint/CheckpointSpi.java b/modules/core/src/main/java/org/apache/ignite/spi/checkpoint/CheckpointSpi.java
index abb461b..348e3c0 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/checkpoint/CheckpointSpi.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/checkpoint/CheckpointSpi.java
@@ -38,8 +38,12 @@ import org.jetbrains.annotations.Nullable;
  * <li>{@link org.apache.ignite.compute.ComputeTaskSession#loadCheckpoint(String)}</li>
  * <li>{@link org.apache.ignite.compute.ComputeTaskSession#removeCheckpoint(String)}</li>
  * <li>{@link org.apache.ignite.compute.ComputeTaskSession#saveCheckpoint(String, Object)}</li>
- * <li>{@link org.apache.ignite.compute.ComputeTaskSession#saveCheckpoint(String, Object, org.apache.ignite.compute.ComputeTaskSessionScope, long)}</li>
- * <li>{@link org.apache.ignite.compute.ComputeTaskSession#saveCheckpoint(String, Object, org.apache.ignite.compute.ComputeTaskSessionScope, long, boolean)}</li>
+ * <li>{@link
+ * org.apache.ignite.compute.ComputeTaskSession#saveCheckpoint(String, Object, org.apache.ignite.compute.ComputeTaskSessionScope, long)}
+ * </li>
+ * <li>{@link
+ * org.apache.ignite.compute.ComputeTaskSession#saveCheckpoint(String, Object, org.apache.ignite.compute.ComputeTaskSessionScope,
+ * long, boolean)}</li>
  * </ul>
  * <p>
  * Ignite provides the following {@code GridCheckpointSpi} implementations:
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/collision/jobstealing/JobStealingCollisionSpi.java b/modules/core/src/main/java/org/apache/ignite/spi/collision/jobstealing/JobStealingCollisionSpi.java
index 01e4f6e..34d5c2f 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/collision/jobstealing/JobStealingCollisionSpi.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/collision/jobstealing/JobStealingCollisionSpi.java
@@ -87,8 +87,8 @@ import static org.apache.ignite.events.EventType.EVT_NODE_LEFT;
  * Note that this SPI must always be used in conjunction with
  * {@link org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi JobStealingFailoverSpi}.
  * Also note that job metrics update should be enabled in order for this SPI
- * to work properly (i.e. {@link org.apache.ignite.configuration.IgniteConfiguration#getMetricsUpdateFrequency() IgniteConfiguration#getMetricsUpdateFrequency()}
- * should be set to positive value).
+ * to work properly (i.e. {@link org.apache.ignite.configuration.IgniteConfiguration#getMetricsUpdateFrequency()
+ * IgniteConfiguration#getMetricsUpdateFrequency()} should be set to positive value).
  * The responsibility of Job Stealing Failover SPI is to properly route <b>stolen</b>
  * jobs to the nodes that initially requested (<b>stole</b>) these jobs. The
  * SPI maintains a counter of how many times a jobs was stolen and
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java
index 59dfe6c..4aaee1a 100755
--- a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java
@@ -638,7 +638,8 @@ public class TcpCommunicationSpi extends TcpCommunicationConfigInitializer {
         final Supplier<ClusterNode> locNodeSupplier = () -> getSpiContext().localNode();
         final Supplier<Ignite> igniteExSupplier = this::ignite;
         final Function<UUID, Boolean> pingNode = (nodeId) -> getSpiContext().pingNode(nodeId);
-        final Supplier<FailureProcessor> failureProcessorSupplier = () -> ignite instanceof IgniteEx ? ((IgniteEx)ignite).context().failure() : null;
+        final Supplier<FailureProcessor> failureProcessorSupplier =
+            () -> ignite instanceof IgniteEx ? ((IgniteEx)ignite).context().failure() : null;
         final Supplier<Boolean> isStopped = () -> getSpiContext().isStopping();
 
         this.igniteInstanceName = igniteInstanceName;
@@ -946,7 +947,11 @@ public class TcpCommunicationSpi extends TcpCommunicationConfigInitializer {
 
         metricsLsnr = new TcpCommunicationMetricsListener(ignite, spiCtx);
 
-        registerMBean(igniteInstanceName, new TcpCommunicationSpiMBeanImpl(this, metricsLsnr, cfg, stateProvider), TcpCommunicationSpiMBean.class);
+        registerMBean(
+            igniteInstanceName,
+            new TcpCommunicationSpiMBeanImpl(this, metricsLsnr, cfg, stateProvider),
+            TcpCommunicationSpiMBean.class
+        );
 
         srvLsnr.metricsListener(metricsLsnr);
         clientPool.metricsListener(metricsLsnr);
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/CommunicationWorker.java b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/CommunicationWorker.java
index 9856879..77ead15 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/CommunicationWorker.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/CommunicationWorker.java
@@ -227,7 +227,9 @@ public class CommunicationWorker extends GridWorker {
 
                 GridNioRecoveryDescriptor recovery = null;
 
-                if (!(cfg.usePairedConnections() && usePairedConnections(node, attrs.pairedConnection())) && client instanceof GridTcpNioCommunicationClient) {
+                if (!(cfg.usePairedConnections()
+                    && usePairedConnections(node, attrs.pairedConnection()))
+                    && client instanceof GridTcpNioCommunicationClient) {
                     recovery = nioSrvWrapper.recoveryDescs().get(new ConnectionKey(
                         node.id(), client.connectionIndex(), -1)
                     );
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/ConnectionClientPool.java b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/ConnectionClientPool.java
index 0a412af..915f84d 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/ConnectionClientPool.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/ConnectionClientPool.java
@@ -197,7 +197,8 @@ public class ConnectionClientPool {
      */
     public GridCommunicationClient reserveClient(ClusterNode node, int connIdx) throws IgniteCheckedException {
         assert node != null;
-        assert (connIdx >= 0 && connIdx < cfg.connectionsPerNode()) || !(cfg.usePairedConnections() && usePairedConnections(node, attrs.pairedConnection())) : connIdx;
+        assert (connIdx >= 0 && connIdx < cfg.connectionsPerNode())
+            || !(cfg.usePairedConnections() && usePairedConnections(node, attrs.pairedConnection())) : connIdx;
 
         if (locNodeSupplier.get().isClient()) {
             if (node.isClient()) {
@@ -304,8 +305,12 @@ public class ConnectionClientPool {
                     catch (IgniteFutureTimeoutCheckedException ignored) {
                         currTimeout += clientReserveWaitTimeout;
 
-                        if (log.isDebugEnabled())
-                            log.debug("Still waiting for reestablishing connection to node [nodeId=" + node.id() + ", waitingTime=" + currTimeout + "ms]");
+                        if (log.isDebugEnabled()) {
+                            log.debug(
+                                "Still waiting for reestablishing connection to node " +
+                                    "[nodeId=" + node.id() + ", waitingTime=" + currTimeout + "ms]"
+                            );
+                        }
 
                         if (registry != null) {
                             GridWorker wrkr = registry.worker(Thread.currentThread().getName());
@@ -342,8 +347,8 @@ public class ConnectionClientPool {
     }
 
     /**
-     * Handles {@link NodeUnreachableException}. This means that the method will try to trigger client itself to open
-     * connection. The only possible way of doing this is to use {@link TcpCommunicationConfiguration#connectionRequestor()}'s trigger and wait.
+     * Handles {@link NodeUnreachableException}. This means that the method will try to trigger client itself to open connection.
+     * The only possible way of doing this is to use {@link TcpCommunicationConfiguration#connectionRequestor()}'s trigger and wait.
      * Specifics of triggers implementation technically should be considered unknown, but for now it's not true and we
      * expect that {@link NodeUnreachableException} won't be thrown in {@link IgniteDiscoveryThread}.
      *
@@ -619,8 +624,12 @@ public class ConnectionClientPool {
         assert cfg.connectionsPerNode() > 0 : cfg.connectionsPerNode();
         assert connIdx == addClient.connectionIndex() : addClient;
 
-        if (log.isDebugEnabled())
-            log.debug("The node client is going to create a connection [nodeId=" + node.id() + ", connIdx=" + connIdx + ", client=" + addClient + "]");
+        if (log.isDebugEnabled()) {
+            log.debug(
+                "The node client is going to create a connection " +
+                    "[nodeId=" + node.id() + ", connIdx=" + connIdx + ", client=" + addClient + "]"
+            );
+        }
 
         if (connIdx >= cfg.connectionsPerNode()) {
             assert !(cfg.usePairedConnections() && usePairedConnections(node, attrs.pairedConnection()));
@@ -670,7 +679,9 @@ public class ConnectionClientPool {
         for (; ; ) {
             GridCommunicationClient[] curClients = clients.get(nodeId);
 
-            if (curClients == null || rmvClient.connectionIndex() >= curClients.length || curClients[rmvClient.connectionIndex()] != rmvClient)
+            if (curClients == null
+                || rmvClient.connectionIndex() >= curClients.length
+                || curClients[rmvClient.connectionIndex()] != rmvClient)
                 return false;
 
             GridCommunicationClient[] newClients = Arrays.copyOf(curClients, curClients.length);
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/GridNioServerWrapper.java b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/GridNioServerWrapper.java
index ca78aa0..ae6f6d3 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/GridNioServerWrapper.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/GridNioServerWrapper.java
@@ -540,7 +540,8 @@ public class GridNioServerWrapper {
                         ses = null;
                     }
 
-                    eRegistrySupplier.get().onException("Handshake timed out (will retry with increased timeout) [connTimeoutStrategy=" + connTimeoutStgy +
+                    eRegistrySupplier.get().onException(
+                        "Handshake timed out (will retry with increased timeout) [connTimeoutStrategy=" + connTimeoutStgy +
                         ", addr=" + addr + ']', e);
 
                     if (log.isDebugEnabled())
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/TcpCommunicationConfigInitializer.java b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/TcpCommunicationConfigInitializer.java
index 3d5ff70..8b2a86c 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/TcpCommunicationConfigInitializer.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/TcpCommunicationConfigInitializer.java
@@ -867,7 +867,8 @@ cfg.socketSendBuffer(sockSndBuf);
             Map<String, Object> res = new HashMap<>(5);
 
             boolean setEmptyHostNamesAttr = !getBoolean(IGNITE_TCP_COMM_SET_ATTR_HOST_NAMES, false) &&
-                (!F.isEmpty(cfg.localAddress()) && cfg.localHost().getHostAddress().equals(cfg.localAddress())) && !cfg.localHost().isAnyLocalAddress() &&
+                (!F.isEmpty(cfg.localAddress()) && cfg.localHost().getHostAddress().equals(cfg.localAddress())) &&
+                !cfg.localHost().isAnyLocalAddress() &&
                 !cfg.localHost().isLoopbackAddress();
 
             res.put(createSpiAttributeName(ATTR_ADDRS), addrs.get1());
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/TcpCommunicationConnectionCheckFuture.java b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/TcpCommunicationConnectionCheckFuture.java
index fd8beb4..177dabb 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/TcpCommunicationConnectionCheckFuture.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/internal/TcpCommunicationConnectionCheckFuture.java
@@ -50,7 +50,8 @@ import static org.apache.ignite.events.EventType.EVT_NODE_LEFT;
 /**
  * Tcp Communication Connection Check Future.
  */
-public class TcpCommunicationConnectionCheckFuture extends GridFutureAdapter<BitSet> implements IgniteSpiTimeoutObject, GridLocalEventListener {
+public class TcpCommunicationConnectionCheckFuture
+    extends GridFutureAdapter<BitSet> implements IgniteSpiTimeoutObject, GridLocalEventListener {
     /** Session future. */
     public static final int SES_FUT_META = GridNioSessionMetaKey.nextUniqueKey();
 
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
index 530253f..9f59ded 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
@@ -3540,7 +3540,8 @@ class ServerImpl extends TcpDiscoveryImpl {
                                 if (log.isDebugEnabled())
                                     log.debug("Handshake response: " + res);
 
-                                // We should take previousNodeAlive flag into account only if we received the response from the correct node.
+                                // We should take previousNodeAlive flag into account
+                                // only if we received the response from the correct node.
                                 if (res.creatorNodeId().equals(next.id()) && res.previousNodeAlive() && sndState != null) {
                                     sndState.checkTimeout();
 
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpiMBean.java b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpiMBean.java
index 4c9143f..df0043a 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpiMBean.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpiMBean.java
@@ -100,7 +100,8 @@ public interface TcpDiscoverySpiMBean extends IgniteSpiManagementMBean, Discover
      *
      * @return IP finder clean frequency.
      */
-    @MXBeanDescription("The frequency with which coordinator cleans IP finder and keeps it in the correct state, unregistering addresses of the nodes that have left the topology.")
+    @MXBeanDescription("The frequency with which coordinator cleans IP finder and keeps it in the correct state, " +
+        "unregistering addresses of the nodes that have left the topology.")
     public long getIpFinderCleanFrequency();
 
     /**
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/multicast/TcpDiscoveryMulticastIpFinder.java b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/multicast/TcpDiscoveryMulticastIpFinder.java
index b1c85a6..5fab967 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/multicast/TcpDiscoveryMulticastIpFinder.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/multicast/TcpDiscoveryMulticastIpFinder.java
@@ -253,8 +253,8 @@ public class TcpDiscoveryMulticastIpFinder extends TcpDiscoveryVmIpFinder {
      * socket is bound to this interface. If local address is not set or is any local address then IP finder
      * creates multicast sockets for all found non-loopback addresses.
      * <p>
-     * If not provided then this property is initialized by the local address set in {@link org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi}
-     * configuration.
+     * If not provided then this property is initialized by the local address set in
+     * {@link org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi} configuration.
      *
      * @param locAddr Local host address.
      * @see org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi#setLocalAddress(String)
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/failover/FailoverSpi.java b/modules/core/src/main/java/org/apache/ignite/spi/failover/FailoverSpi.java
index 158420a..f251670 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/failover/FailoverSpi.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/failover/FailoverSpi.java
@@ -51,7 +51,8 @@ import org.apache.ignite.spi.IgniteSpi;
  */
 public interface FailoverSpi extends IgniteSpi {
     /**
-     * This method is called when method {@link org.apache.ignite.compute.ComputeTask#result(org.apache.ignite.compute.ComputeJobResult, List)} returns
+     * This method is called when method
+     * {@link org.apache.ignite.compute.ComputeTask#result(org.apache.ignite.compute.ComputeJobResult, List)} returns
      * value {@link org.apache.ignite.compute.ComputeJobResultPolicy#FAILOVER} policy indicating that the result of
      * job execution must be failed over. Implementation of this method should examine failover
      * context and choose one of the grid nodes from supplied {@code topology} to retry job execution
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/failover/jobstealing/JobStealingFailoverSpi.java b/modules/core/src/main/java/org/apache/ignite/spi/failover/jobstealing/JobStealingFailoverSpi.java
index d188dea..112d64f 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/failover/jobstealing/JobStealingFailoverSpi.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/failover/jobstealing/JobStealingFailoverSpi.java
@@ -43,14 +43,16 @@ import static org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSp
 
 /**
  * Job stealing failover SPI needs to always be used in conjunction with
- * {@link org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi} SPI. When {@link org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi}
+ * {@link org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi} SPI.
+ * When {@link org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi}
  * receives a <b>steal</b> request and rejects jobs so they can be routed to the
  * appropriate node, it is the responsibility of this {@code JobStealingFailoverSpi}
  * SPI to make sure that the job is indeed re-routed to the node that has sent the initial
  * request to <b>steal</b> it.
  * <p>
  * {@code JobStealingFailoverSpi} knows where to route a job based on the
- * {@link org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi#THIEF_NODE_ATTR} job context attribute (see {@link org.apache.ignite.compute.ComputeJobContext}).
+ * {@link org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi#THIEF_NODE_ATTR} job context attribute
+ * (see {@link org.apache.ignite.compute.ComputeJobContext}).
  * Prior to rejecting a job,  {@link org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi} will populate this
  * attribute with the ID of the node that wants to <b>steal</b> this job.
  * Then {@code JobStealingFailoverSpi} will read the value of this attribute and
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/systemview/view/datastructures/ReentrantLockView.java b/modules/core/src/main/java/org/apache/ignite/spi/systemview/view/datastructures/ReentrantLockView.java
index 75e3573..c28be14 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/systemview/view/datastructures/ReentrantLockView.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/systemview/view/datastructures/ReentrantLockView.java
@@ -72,7 +72,8 @@ public class ReentrantLockView extends AbstractDataStructureView<GridCacheLockIm
     }
 
     /**
-     * @return {@code True} if a node failed on this semaphore and {@link #failoverSafe} flag was set to {@code false}, {@code false} otherwise.
+     * @return {@code True} if a node failed on this semaphore and {@link #failoverSafe} flag was set to {@code false},
+     * {@code false} otherwise.
      * @see IgniteLock#isBroken()
      */
     @Order(5)
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/systemview/view/datastructures/SemaphoreView.java b/modules/core/src/main/java/org/apache/ignite/spi/systemview/view/datastructures/SemaphoreView.java
index ce36674..65895b4 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/systemview/view/datastructures/SemaphoreView.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/systemview/view/datastructures/SemaphoreView.java
@@ -72,7 +72,8 @@ public class SemaphoreView extends AbstractDataStructureView<GridCacheSemaphoreI
     }
 
     /**
-     * @return {@code True} if a node failed on this semaphore and {@link #failoverSafe} flag was set to {@code false}, {@code false} otherwise.
+     * @return {@code True} if a node failed on this semaphore and {@link #failoverSafe} flag was set to {@code false},
+     * {@code false} otherwise.
      * @see IgniteSemaphore#isBroken()
      */
     @Order(5)
diff --git a/modules/core/src/test/java/org/apache/ignite/cache/store/CacheStoreListenerRWThroughDisabledTransactionalCacheTest.java b/modules/core/src/test/java/org/apache/ignite/cache/store/CacheStoreListenerRWThroughDisabledTransactionalCacheTest.java
index 4ebbfed..86f0ab3 100644
--- a/modules/core/src/test/java/org/apache/ignite/cache/store/CacheStoreListenerRWThroughDisabledTransactionalCacheTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/cache/store/CacheStoreListenerRWThroughDisabledTransactionalCacheTest.java
@@ -39,7 +39,8 @@ import static org.apache.ignite.transactions.TransactionIsolation.SERIALIZABLE;
  * This class tests that redundant calls of {@link CacheStoreSessionListener#onSessionStart(CacheStoreSession)}
  * and {@link CacheStoreSessionListener#onSessionEnd(CacheStoreSession, boolean)} are not executed.
  */
-public class CacheStoreListenerRWThroughDisabledTransactionalCacheTest extends CacheStoreSessionListenerReadWriteThroughDisabledAbstractTest {
+public class CacheStoreListenerRWThroughDisabledTransactionalCacheTest
+    extends CacheStoreSessionListenerReadWriteThroughDisabledAbstractTest {
     /** */
     @Before
     public void beforeCacheStoreListenerRWThroughDisabledTransactionalCacheTest() {
diff --git a/modules/core/src/test/java/org/apache/ignite/cache/store/CacheStoreSessionListenerLifecycleSelfTest.java b/modules/core/src/test/java/org/apache/ignite/cache/store/CacheStoreSessionListenerLifecycleSelfTest.java
index dea439a..4fee3db 100644
--- a/modules/core/src/test/java/org/apache/ignite/cache/store/CacheStoreSessionListenerLifecycleSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/cache/store/CacheStoreSessionListenerLifecycleSelfTest.java
@@ -237,7 +237,10 @@ public class CacheStoreSessionListenerLifecycleSelfTest extends GridCommonAbstra
 
                 CacheConfiguration cacheCfg = cacheConfiguration(name);
 
-                cacheCfg.setCacheStoreSessionListenerFactories(new SessionListenerFactory(name + " 1"), new SessionListenerFactory(name + " 2"));
+                cacheCfg.setCacheStoreSessionListenerFactories(
+                    new SessionListenerFactory(name + " 1"),
+                    new SessionListenerFactory(name + " 2")
+                );
 
                 ignite.createCache(cacheCfg);
             }
diff --git a/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoStoreBinaryMarshallerStoreKeepBinaryWithSqlEscapeSelfTest.java b/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoStoreBinaryMarshallerStoreKeepBinaryWithSqlEscapeSelfTest.java
index c7e1f79..734e2b9 100644
--- a/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoStoreBinaryMarshallerStoreKeepBinaryWithSqlEscapeSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoStoreBinaryMarshallerStoreKeepBinaryWithSqlEscapeSelfTest.java
@@ -20,7 +20,8 @@ package org.apache.ignite.cache.store.jdbc;
 /**
  *
  */
-public class CacheJdbcPojoStoreBinaryMarshallerStoreKeepBinaryWithSqlEscapeSelfTest extends CacheJdbcPojoStoreBinaryMarshallerWithSqlEscapeSelfTest {
+public class CacheJdbcPojoStoreBinaryMarshallerStoreKeepBinaryWithSqlEscapeSelfTest
+    extends CacheJdbcPojoStoreBinaryMarshallerWithSqlEscapeSelfTest {
     /** {@inheritDoc} */
     @Override protected boolean storeKeepBinary() {
         return true;
diff --git a/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoStoreTest.java b/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoStoreTest.java
index 985b289..01e0ee0 100644
--- a/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoStoreTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/CacheJdbcPojoStoreTest.java
@@ -306,7 +306,8 @@ public class CacheJdbcPojoStoreTest extends GridAbstractCacheStoreSelfTest<Cache
 
         U.closeQuiet(prnStmt);
 
-        PreparedStatement prnComplexStmt = conn.prepareStatement("INSERT INTO Person_Complex(id, org_id, city_id, name, salary) VALUES (?, ?, ?, ?, ?)");
+        PreparedStatement prnComplexStmt =
+            conn.prepareStatement("INSERT INTO Person_Complex(id, org_id, city_id, name, salary) VALUES (?, ?, ?, ?, ?)");
 
         for (int i = 0; i < PERSON_CNT; i++) {
             prnComplexStmt.setInt(1, i);
@@ -448,7 +449,8 @@ public class CacheJdbcPojoStoreTest extends GridAbstractCacheStoreSelfTest<Cache
     public void testParallelLoad() throws Exception {
         Connection conn = store.openConnection(false);
 
-        PreparedStatement prnComplexStmt = conn.prepareStatement("INSERT INTO Person_Complex(id, org_id, city_id, name, salary) VALUES (?, ?, ?, ?, ?)");
+        PreparedStatement prnComplexStmt =
+            conn.prepareStatement("INSERT INTO Person_Complex(id, org_id, city_id, name, salary) VALUES (?, ?, ?, ?, ?)");
 
         for (int i = 0; i < 8; i++) {
 
diff --git a/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/JdbcTypesDefaultTransformerTest.java b/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/JdbcTypesDefaultTransformerTest.java
index ab52ed7..52b251f 100644
--- a/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/JdbcTypesDefaultTransformerTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/JdbcTypesDefaultTransformerTest.java
@@ -92,8 +92,8 @@ public class JdbcTypesDefaultTransformerTest extends GridCommonAbstractTest {
 
             // Create table in ORACLE.
 //                stmt.executeUpdate("CREATE TABLE TEST_TRANSFORMER(id INTEGER, " +
-//                    "c1 NUMBER(1), c2 INTEGER, c3 NUMBER(3), c4 NUMBER(4), c5 NUMBER(20), c6 NUMBER(20, 2), c7 NUMBER(20, 2), c8 NUMBER(10, 2), " +
-//                    "c9 TIMESTAMP, c10 DATE, c11 TIMESTAMP, c12 VARCHAR(100), c13 VARCHAR(36))");
+//                    "c1 NUMBER(1), c2 INTEGER, c3 NUMBER(3), c4 NUMBER(4), c5 NUMBER(20), c6 NUMBER(20, 2), c7 NUMBER(20, 2), " +
+//                    "c8 NUMBER(10, 2), c9 TIMESTAMP, c10 DATE, c11 TIMESTAMP, c12 VARCHAR(100), c13 VARCHAR(36))");
 
             // Create table in MS SQL.
 //            stmt.executeUpdate("CREATE TABLE TEST_TRANSFORMER(id INTEGER, " +
@@ -148,7 +148,8 @@ public class JdbcTypesDefaultTransformerTest extends GridCommonAbstractTest {
             stmt.executeUpdate("INSERT INTO TEST_TRANSFORMER(id, c1, c2, c3, c4, c5, c6, c7, c8, c9, c10, c11, c12, c13) " +
                 "VALUES (3, null, null, null, null, null, null, null, null, null, null, null, null, null)");
 
-            ResultSet rs = stmt.executeQuery("select c1, c2, c3, c4, c5, c6, c7, c8, c9, c10, c11, c12, c13 from TEST_TRANSFORMER order by id");
+            ResultSet rs =
+                stmt.executeQuery("select c1, c2, c3, c4, c5, c6, c7, c8, c9, c10, c11, c12, c13 from TEST_TRANSFORMER order by id");
 
             assertTrue(rs.next());
 
diff --git a/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/model/TestJdbcPojoStoreFactoryWithHangWriteAll.java b/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/model/TestJdbcPojoStoreFactoryWithHangWriteAll.java
index cc57690..5ef86b3 100644
--- a/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/model/TestJdbcPojoStoreFactoryWithHangWriteAll.java
+++ b/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/model/TestJdbcPojoStoreFactoryWithHangWriteAll.java
@@ -58,7 +58,12 @@ public class TestJdbcPojoStoreFactoryWithHangWriteAll<K, V> extends CacheJdbcPoj
     /** */
     public static class TestJdbcPojoStoreWithHangWriteAll<K, V> extends CacheJdbcPojoStore<K, V> {
         /** {@inheritDoc} */
-        @Override protected void fillParameter(PreparedStatement stmt, int idx, JdbcTypeField field, @Nullable Object fieldVal) throws CacheException {
+        @Override protected void fillParameter(
+            PreparedStatement stmt,
+            int idx,
+            JdbcTypeField field,
+            @Nullable Object fieldVal
+        ) throws CacheException {
             try {
                 super.fillParameter(stmt, idx, field, fieldVal);
             }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/ClusterNodeMetricsSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/ClusterNodeMetricsSelfTest.java
index bf53322..14a44e3 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/ClusterNodeMetricsSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/ClusterNodeMetricsSelfTest.java
@@ -480,7 +480,10 @@ public class ClusterNodeMetricsSelfTest extends GridCommonAbstractTest {
          * @param cfg Ignite configuration.
          * @throws MalformedObjectNameException Thrown in case of any errors.
          */
-        private JmxClusterMetricsHelper(IgniteConfiguration cfg, Class<? extends ClusterMetricsMXBean> clazz) throws MalformedObjectNameException {
+        private JmxClusterMetricsHelper(
+            IgniteConfiguration cfg,
+            Class<? extends ClusterMetricsMXBean> clazz
+        ) throws MalformedObjectNameException {
             this.mbeanSrv = cfg.getMBeanServer();
 
             this.mbean = U.makeMBeanName(cfg.getIgniteInstanceName(), "Kernal", clazz.getSimpleName());
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/GridContinuousTaskSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/GridContinuousTaskSelfTest.java
index 37c2a0c..339e43b 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/GridContinuousTaskSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/GridContinuousTaskSelfTest.java
@@ -201,9 +201,9 @@ public class GridContinuousTaskSelfTest extends GridCommonAbstractTest {
     @Test
     public void testClosureWithNestedInternalTask() throws Exception {
         try {
-            IgniteEx ignite = startGrid(0);
+            IgniteEx ign = startGrid(0);
 
-            ComputeTaskInternalFuture<String> fut = ignite.context().closure().callAsync(GridClosureCallMode.BALANCE, new Callable<String>() {
+            ComputeTaskInternalFuture<String> fut = ign.context().closure().callAsync(GridClosureCallMode.BALANCE, new Callable<String>() {
                 /** */
                 @IgniteInstanceResource
                 private IgniteEx g;
@@ -211,7 +211,7 @@ public class GridContinuousTaskSelfTest extends GridCommonAbstractTest {
                 @Override public String call() throws Exception {
                     return g.compute(g.cluster()).execute(NestedHoldccTask.class, null);
                 }
-            }, ignite.cluster().nodes());
+            }, ign.cluster().nodes());
 
             assertEquals("DONE", fut.get(3000));
         }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/GridJobMasterLeaveAwareSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/GridJobMasterLeaveAwareSelfTest.java
index f29ebff..4764bd3 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/GridJobMasterLeaveAwareSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/GridJobMasterLeaveAwareSelfTest.java
@@ -169,7 +169,8 @@ public class GridJobMasterLeaveAwareSelfTest extends GridCommonAbstractTest {
     }
 
     /**
-     * Ensure that {@link org.apache.ignite.compute.ComputeJobMasterLeaveAware} callback is invoked when master node leaves topology normally.
+     * Ensure that {@link org.apache.ignite.compute.ComputeJobMasterLeaveAware} callback is invoked
+     * when master node leaves topology normally.
      *
      * @throws Exception If failed.
      */
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/IgniteClientFailuresTest.java b/modules/core/src/test/java/org/apache/ignite/internal/IgniteClientFailuresTest.java
index 1ebfa55..66a3716 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/IgniteClientFailuresTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/IgniteClientFailuresTest.java
@@ -111,7 +111,8 @@ public class IgniteClientFailuresTest extends GridCommonAbstractTest {
     }
 
     /**
-     * Test verifies that when client node failed but not yet cleaned up from topology (because {@link IgniteConfiguration#clientFailureDetectionTimeout} has not been reached yet)
+     * Test verifies that when client node failed but not yet cleaned up from topology
+     * (because {@link IgniteConfiguration#clientFailureDetectionTimeout} has not been reached yet)
      * it doesn't affect new client connected from the same address.
      *
      * @throws Exception If failed.
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryClassLoaderMultiJvmTest.java b/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryClassLoaderMultiJvmTest.java
index ff4b60c..e00dc45 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryClassLoaderMultiJvmTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryClassLoaderMultiJvmTest.java
@@ -274,7 +274,8 @@ public class BinaryClassLoaderMultiJvmTest extends GridCommonAbstractTest {
 
         Constructor personConstructor = testClsLdr.loadClass(PERSON_CLASS_NAME).getConstructor(String.class);
         Constructor addrConstructor = testClsLdr.loadClass(ADDRESS_CLASS_NAME).getConstructor(String.class, Integer.TYPE);
-        Constructor organizationConstructor = testClsLdr.loadClass(ORGANIZATION_CLASS_NAME).getConstructor(String.class, personCls, addrCls);
+        Constructor organizationConstructor =
+            testClsLdr.loadClass(ORGANIZATION_CLASS_NAME).getConstructor(String.class, personCls, addrCls);
 
         IgniteCache<Integer, Object> cache = ignite.cache("OrganizationCache");
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryClassLoaderTest.java b/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryClassLoaderTest.java
index b3b0d54..6811724 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryClassLoaderTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryClassLoaderTest.java
@@ -218,7 +218,8 @@ public class BinaryClassLoaderTest extends GridCommonAbstractTest {
 
         Constructor personConstructor = testClsLdr.loadClass(PERSON_CLASS_NAME).getConstructor(String.class);
         Constructor addrConstructor = testClsLdr.loadClass(ADDRESS_CLASS_NAME).getConstructor(String.class, Integer.TYPE);
-        Constructor organizationConstructor = testClsLdr.loadClass(ORGANIZATION_CLASS_NAME).getConstructor(String.class, personCls, addrCls);
+        Constructor organizationConstructor =
+            testClsLdr.loadClass(ORGANIZATION_CLASS_NAME).getConstructor(String.class, personCls, addrCls);
 
         IgniteCache<Integer, Object> cache = ignite.cache("OrganizationCache");
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryObjectBuilderAdditionalSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryObjectBuilderAdditionalSelfTest.java
index eaef10e..f707cdb 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryObjectBuilderAdditionalSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryObjectBuilderAdditionalSelfTest.java
@@ -893,7 +893,8 @@ public class BinaryObjectBuilderAdditionalSelfTest extends GridCommonAbstractTes
     public void testEnumArrayModification() {
         GridBinaryTestClasses.TestObjectAllTypes obj = new GridBinaryTestClasses.TestObjectAllTypes();
 
-        obj.enumArr = new GridBinaryTestClasses.TestObjectEnum[] {GridBinaryTestClasses.TestObjectEnum.A, GridBinaryTestClasses.TestObjectEnum.B};
+        obj.enumArr =
+            new GridBinaryTestClasses.TestObjectEnum[] {GridBinaryTestClasses.TestObjectEnum.A, GridBinaryTestClasses.TestObjectEnum.B};
 
         BinaryObjectBuilderImpl mutObj = wrap(obj);
 
@@ -902,7 +903,10 @@ public class BinaryObjectBuilderAdditionalSelfTest extends GridCommonAbstractTes
 
         GridBinaryTestClasses.TestObjectAllTypes res = mutObj.build().deserialize();
 
-        Assert.assertArrayEquals(new GridBinaryTestClasses.TestObjectEnum[] {GridBinaryTestClasses.TestObjectEnum.A, GridBinaryTestClasses.TestObjectEnum.B}, res.enumArr);
+        Assert.assertArrayEquals(
+            new GridBinaryTestClasses.TestObjectEnum[] {GridBinaryTestClasses.TestObjectEnum.A, GridBinaryTestClasses.TestObjectEnum.B},
+            res.enumArr
+        );
     }
 
     /**
@@ -1324,7 +1328,8 @@ public class BinaryObjectBuilderAdditionalSelfTest extends GridCommonAbstractTes
      */
     @Test
     public void testBinaryObjectField() {
-        GridBinaryTestClasses.TestObjectContainer container = new GridBinaryTestClasses.TestObjectContainer(toBinary(new GridBinaryTestClasses.TestObjectArrayList()));
+        GridBinaryTestClasses.TestObjectContainer container =
+            new GridBinaryTestClasses.TestObjectContainer(toBinary(new GridBinaryTestClasses.TestObjectArrayList()));
 
         BinaryObjectBuilderImpl wrapper = wrap(container);
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryObjectBuilderDefaultMappersSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryObjectBuilderDefaultMappersSelfTest.java
index 8351442..b73b389 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryObjectBuilderDefaultMappersSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/binary/BinaryObjectBuilderDefaultMappersSelfTest.java
@@ -957,7 +957,8 @@ public class BinaryObjectBuilderDefaultMappersSelfTest extends GridCommonAbstrac
      */
     @Test
     public void testPlainBinaryObjectCopyFrom() {
-        GridBinaryTestClasses.TestObjectPlainBinary obj = new GridBinaryTestClasses.TestObjectPlainBinary(toBinary(new GridBinaryTestClasses.TestObjectAllTypes()));
+        GridBinaryTestClasses.TestObjectPlainBinary obj =
+            new GridBinaryTestClasses.TestObjectPlainBinary(toBinary(new GridBinaryTestClasses.TestObjectAllTypes()));
 
         BinaryObjectBuilderImpl builder = builder(toBinary(obj));
         assertTrue(builder.getField("plainBinary") instanceof BinaryObject);
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/cache/query/index/sorted/inline/InlineIndexKeyTypeRegistryTest.java b/modules/core/src/test/java/org/apache/ignite/internal/cache/query/index/sorted/inline/InlineIndexKeyTypeRegistryTest.java
index 8e4e688..b3ea2f7 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/cache/query/index/sorted/inline/InlineIndexKeyTypeRegistryTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/cache/query/index/sorted/inline/InlineIndexKeyTypeRegistryTest.java
@@ -60,10 +60,18 @@ public class InlineIndexKeyTypeRegistryTest extends GridCommonAbstractTest {
         InlineIndexKeyType t = InlineIndexKeyTypeRegistry.get(new IntegerIndexKey(3), IndexKeyTypes.JAVA_OBJECT, pojoArrayKeyTypeSettings);
         assertEquals(IndexKeyTypes.INT, t.type());
 
-        t = InlineIndexKeyTypeRegistry.get(new PlainJavaObjectIndexKey(new BinaryObjectImpl(), null), IndexKeyTypes.JAVA_OBJECT, pojoArrayKeyTypeSettings);
+        t = InlineIndexKeyTypeRegistry.get(
+            new PlainJavaObjectIndexKey(new BinaryObjectImpl(), null),
+            IndexKeyTypes.JAVA_OBJECT,
+            pojoArrayKeyTypeSettings
+        );
         assertEquals(IndexKeyTypes.JAVA_OBJECT, t.type());
 
-        t = InlineIndexKeyTypeRegistry.get(new PlainJavaObjectIndexKey(new BinaryObjectImpl(), null), IndexKeyTypes.INT, pojoArrayKeyTypeSettings);
+        t = InlineIndexKeyTypeRegistry.get(
+            new PlainJavaObjectIndexKey(new BinaryObjectImpl(), null),
+            IndexKeyTypes.INT,
+            pojoArrayKeyTypeSettings
+        );
         assertEquals(IndexKeyTypes.JAVA_OBJECT, t.type());
 
         t = InlineIndexKeyTypeRegistry.get(new IntegerIndexKey(3), IndexKeyTypes.JAVA_OBJECT, pojoHashKeyTypeSettings);
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/managers/GridManagerMxBeanIllegalArgumentHandleTest.java b/modules/core/src/test/java/org/apache/ignite/internal/managers/GridManagerMxBeanIllegalArgumentHandleTest.java
index 691c2e2..10e6f2d 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/managers/GridManagerMxBeanIllegalArgumentHandleTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/managers/GridManagerMxBeanIllegalArgumentHandleTest.java
@@ -72,7 +72,9 @@ public class GridManagerMxBeanIllegalArgumentHandleTest {
     @NotNull private MemoryMXBean createAlwaysFailingMxBean() {
         final Answer<MemoryUsage> failingAnswer = new Answer<MemoryUsage>() {
             @Override public MemoryUsage answer(InvocationOnMock invocationOnMock) throws Throwable {
-                throw new IllegalArgumentException("java.lang.IllegalArgumentException: committed = 5274103808 should be < max = 5274095616");
+                throw new IllegalArgumentException(
+                    "java.lang.IllegalArgumentException: committed = 5274103808 should be < max = 5274095616"
+                );
             }
         };
         final MemoryMXBean memoryMXBean = Mockito.mock(MemoryMXBean.class);
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/managers/IgniteDiagnosticMessagesTest.java b/modules/core/src/test/java/org/apache/ignite/internal/managers/IgniteDiagnosticMessagesTest.java
index df6dcf7..b1a1ce4 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/managers/IgniteDiagnosticMessagesTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/managers/IgniteDiagnosticMessagesTest.java
@@ -729,9 +729,12 @@ public class IgniteDiagnosticMessagesTest extends GridCommonAbstractTest {
 
                     String msg = fut.get();
 
+                    String searchMsg = "General node info [id=" + dstNode.id() + ", client=" + dstNode.isClient() +
+                        ", discoTopVer=AffinityTopologyVersion [topVer=5, minorTopVer=";
+
                     assertTrue("Unexpected message: " + msg,
                         msg.contains("Test diagnostic") &&
-                            msg.contains("General node info [id=" + dstNode.id() + ", client=" + dstNode.isClient() + ", discoTopVer=AffinityTopologyVersion [topVer=5, minorTopVer=") &&
+                            msg.contains(searchMsg) &&
                             msg.contains("Partitions exchange info [readyVer=AffinityTopologyVersion [topVer=5, minorTopVer="));
                 }
             }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/managers/communication/IgniteCommunicationBalanceTest.java b/modules/core/src/test/java/org/apache/ignite/internal/managers/communication/IgniteCommunicationBalanceTest.java
index 2d78277..59e6b79 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/managers/communication/IgniteCommunicationBalanceTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/managers/communication/IgniteCommunicationBalanceTest.java
@@ -122,7 +122,8 @@ public class IgniteCommunicationBalanceTest extends GridCommonAbstractTest {
 
             waitNioBalanceStop(Collections.singletonList(client), 10_000);
 
-            final GridNioServer srv = ((GridNioServerWrapper) GridTestUtils.getFieldValue(client.configuration().getCommunicationSpi(), "nioSrvWrapper")).nio();
+            final GridNioServer srv =
+                ((GridNioServerWrapper) GridTestUtils.getFieldValue(client.configuration().getCommunicationSpi(), "nioSrvWrapper")).nio();
 
             ThreadLocalRandom rnd = ThreadLocalRandom.current();
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/managers/deployment/P2PCacheOperationIntoComputeTest.java b/modules/core/src/test/java/org/apache/ignite/internal/managers/deployment/P2PCacheOperationIntoComputeTest.java
index 8062e1f..e0a5e79 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/managers/deployment/P2PCacheOperationIntoComputeTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/managers/deployment/P2PCacheOperationIntoComputeTest.java
@@ -115,8 +115,9 @@ public class P2PCacheOperationIntoComputeTest extends GridCommonAbstractTest {
     ) throws Exception {
         Constructor personCtor = getExternalClassLoader().loadClass(PERSON_CLASS_NAME).getConstructor(String.class);
 
-        IgniteCallable<Double> avgSalaryClosure = (IgniteCallable<Double>)getExternalClassLoader().loadClass(AVERAGE_PERSON_SALARY_CLOSURE_NAME)
-            .getConstructor(String.class, int.class, int.class).newInstance(cacheName, 0, 10);
+        IgniteCallable<Double> avgSalaryClosure =
+            (IgniteCallable<Double>)getExternalClassLoader().loadClass(AVERAGE_PERSON_SALARY_CLOSURE_NAME)
+                .getConstructor(String.class, int.class, int.class).newInstance(cacheName, 0, 10);
 
         IgniteCache cache = client.cache(cacheName);
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/pagemem/wal/record/WALRecordSerializationTest.java b/modules/core/src/test/java/org/apache/ignite/internal/pagemem/wal/record/WALRecordSerializationTest.java
index 3c652a4..e83782e 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/pagemem/wal/record/WALRecordSerializationTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/pagemem/wal/record/WALRecordSerializationTest.java
@@ -42,7 +42,8 @@ import static org.apache.ignite.configuration.DataStorageConfiguration.DFLT_PAGE
 import static org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager.ZIP_SUFFIX;
 
 /**
- * Tests of serialization and deserialization of all WAL record types {@link org.apache.ignite.internal.pagemem.wal.record.WALRecord.RecordType}.
+ * Tests of serialization and deserialization of all WAL record types
+ * {@link org.apache.ignite.internal.pagemem.wal.record.WALRecord.RecordType}.
  *
  * It checks that all records can be successfully deserialized from early serialized record included serialization via
  * compaction.
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheMetricsManageTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheMetricsManageTest.java
index 26ba004..286b1ba 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheMetricsManageTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheMetricsManageTest.java
@@ -173,7 +173,8 @@ public class CacheMetricsManageTest extends GridCommonAbstractTest {
 
         IgniteCache<Object, Object> cache1 = ig1.cache(CACHE1);
 
-        CacheConfiguration<Object, Object> cacheCfg2 = new CacheConfiguration<Object, Object>(cache1.getConfiguration(CacheConfiguration.class));
+        CacheConfiguration<Object, Object> cacheCfg2 =
+            new CacheConfiguration<Object, Object>(cache1.getConfiguration(CacheConfiguration.class));
 
         cacheCfg2.setName(CACHE2);
         cacheCfg2.setStatisticsEnabled(true);
@@ -200,7 +201,8 @@ public class CacheMetricsManageTest extends GridCommonAbstractTest {
 
         IgniteCache<?, ?> cache1 = grid(0).cache(CACHE1);
 
-        CacheConfiguration<Object, Object> cacheCfg2 = new CacheConfiguration<Object, Object>(cache1.getConfiguration(CacheConfiguration.class));
+        CacheConfiguration<Object, Object> cacheCfg2 =
+            new CacheConfiguration<Object, Object>(cache1.getConfiguration(CacheConfiguration.class));
 
         cacheCfg2.setName(CACHE2);
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterStateTestUtils.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterStateTestUtils.java
index 6a3fe1b..738b339 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterStateTestUtils.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterStateTestUtils.java
@@ -88,7 +88,10 @@ public class ClusterStateTestUtils {
                         log,
                         () -> crd.cache(cacheName),
                         IgniteException.class,
-                        "Can not perform the operation because the cluster is inactive. Note, that the cluster is considered inactive by default if Ignite Persistent Store is used to let all the nodes join the cluster. To activate the cluster call Ignite.active(true)."
+                        "Can not perform the operation because the cluster is inactive. " +
+                            "Note, that the cluster is considered inactive by default " +
+                            "if Ignite Persistent Store is used to let all the nodes join the cluster. " +
+                            "To activate the cluster call Ignite.active(true)."
                     ));
 
                     break;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheConfigurationConsistencySelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheConfigurationConsistencySelfTest.java
index 2776aa6..5164140 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheConfigurationConsistencySelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheConfigurationConsistencySelfTest.java
@@ -57,6 +57,7 @@ import static org.apache.ignite.cache.CacheRebalanceMode.ASYNC;
 import static org.apache.ignite.cache.CacheRebalanceMode.NONE;
 import static org.apache.ignite.cache.CacheWriteSynchronizationMode.FULL_ASYNC;
 import static org.apache.ignite.cache.CacheWriteSynchronizationMode.FULL_SYNC;
+import static org.apache.ignite.configuration.CacheConfiguration.DFLT_CACHE_MODE;
 import static org.apache.ignite.configuration.DeploymentMode.CONTINUOUS;
 import static org.apache.ignite.configuration.DeploymentMode.SHARED;
 
@@ -188,7 +189,7 @@ public class GridCacheConfigurationConsistencySelfTest extends GridCommonAbstrac
         cacheMode = null;
         depMode = SHARED;
 
-        assert startGrid(1).cache("myCache").getConfiguration(CacheConfiguration.class).getCacheMode() == CacheConfiguration.DFLT_CACHE_MODE;
+        assert startGrid(1).cache("myCache").getConfiguration(CacheConfiguration.class).getCacheMode() == DFLT_CACHE_MODE;
     }
 
     /**
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePartitionedWritesTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePartitionedWritesTest.java
index 5c7029b..95ce475 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePartitionedWritesTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePartitionedWritesTest.java
@@ -36,8 +36,8 @@ import static org.apache.ignite.cache.CacheAtomicityMode.TRANSACTIONAL;
 
 /**
  * Test that in {@link CacheMode#PARTITIONED} mode cache writes values only to the near cache store. <p/> This check
- * is needed because in current implementation if {@link org.apache.ignite.internal.processors.cache.store.GridCacheWriteBehindStore} assumes that and user store is
- * wrapped only in near cache (see {@link GridCacheProcessor} init logic).
+ * is needed because in current implementation if {@link org.apache.ignite.internal.processors.cache.store.GridCacheWriteBehindStore}
+ * assumes that and user store is wrapped only in near cache (see {@link GridCacheProcessor} init logic).
  */
 @SuppressWarnings({"unchecked"})
 public class GridCachePartitionedWritesTest extends GridCommonAbstractTest {
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheClusterReadOnlyModeSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheClusterReadOnlyModeSelfTest.java
index 26d3369..cd9a330 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheClusterReadOnlyModeSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheClusterReadOnlyModeSelfTest.java
@@ -216,7 +216,8 @@ public class IgniteCacheClusterReadOnlyModeSelfTest extends IgniteCacheClusterRe
                         }
                         catch (Exception e) {
                             RuntimeException ex = new RuntimeException(new AssertionError(
-                                "Got exception on node: " + node.name() + " cache: " + cache.getName() + " isolation: " + isolation + " txLevel: " + level,
+                                "Got exception on node: " + node.name() + " cache: " + cache.getName() + " isolation: " + isolation +
+                                    " txLevel: " + level,
                                 e
                             ));
 
@@ -258,7 +259,8 @@ public class IgniteCacheClusterReadOnlyModeSelfTest extends IgniteCacheClusterRe
                         }
                         catch (Exception e) {
                             RuntimeException ex = new RuntimeException(new AssertionError(
-                                "Got exception on node: " + node.name() + " cache: " + cache.getName() + " isolation: " + isolation + " txLevel: " + level,
+                                "Got exception on node: " + node.name() + " cache: " + cache.getName() + " isolation: " + isolation +
+                                    " txLevel: " + level,
                                 e
                             ));
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteClientCacheStartFailoverTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteClientCacheStartFailoverTest.java
index 2626459..8844d7b 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteClientCacheStartFailoverTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteClientCacheStartFailoverTest.java
@@ -382,9 +382,11 @@ public class IgniteClientCacheStartFailoverTest extends GridCommonAbstractTest {
 
                             TransactionSerializationException txEx = X.cause(e, TransactionSerializationException.class);
 
-                            if (txEx == null ||
-                                ccfg.getAtomicityMode() != TRANSACTIONAL_SNAPSHOT ||
-                                !txEx.getMessage().contains("Cannot serialize transaction due to write conflict (transaction is marked for rollback)"))
+                            boolean notContains = !txEx.getMessage().contains(
+                                "Cannot serialize transaction due to write conflict (transaction is marked for rollback)"
+                            );
+
+                            if (txEx == null || ccfg.getAtomicityMode() != TRANSACTIONAL_SNAPSHOT || notContains)
                                 fail("Assert violated because exception was thrown [e=" + e.getMessage() + ']');
                         }
                     }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteDynamicCacheStartSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteDynamicCacheStartSelfTest.java
index 7648ec6..68334fa 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteDynamicCacheStartSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteDynamicCacheStartSelfTest.java
@@ -1440,7 +1440,13 @@ public class IgniteDynamicCacheStartSelfTest extends GridCommonAbstractTest {
         StoredCacheData storedCacheData = new StoredCacheData(ccfg);
 
         try {
-            kernal.context().cache().dynamicStartCachesByStoredConf(Collections.singleton(storedCacheData), true, true, false, IgniteUuid.randomUuid()).get();
+            kernal.context().cache().dynamicStartCachesByStoredConf(
+                Collections.singleton(storedCacheData),
+                true,
+                true,
+                false,
+                IgniteUuid.randomUuid()
+            ).get();
 
             fail();
         }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteExchangeLatchManagerCoordinatorFailTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteExchangeLatchManagerCoordinatorFailTest.java
index a2c99f5..484ba5f 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteExchangeLatchManagerCoordinatorFailTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteExchangeLatchManagerCoordinatorFailTest.java
@@ -256,7 +256,9 @@ public class IgniteExchangeLatchManagerCoordinatorFailTest extends GridCommonAbs
      * @param nodeScenarios Node scenarios.
      * @throws Exception If failed.
      */
-    private void doTestCoordinatorFail(List<IgniteBiClosure<ExchangeLatchManager, CountDownLatch, Boolean>> nodeScenarios) throws Exception {
+    private void doTestCoordinatorFail(
+        List<IgniteBiClosure<ExchangeLatchManager, CountDownLatch, Boolean>> nodeScenarios
+    ) throws Exception {
         IgniteEx latchCrd = grid(LATCH_CRD_INDEX);
 
         // Latch to synchronize node states.
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteSemaphoreAbstractSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteSemaphoreAbstractSelfTest.java
index 3b95a8e..2ba0eba 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteSemaphoreAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteSemaphoreAbstractSelfTest.java
@@ -250,11 +250,13 @@ public abstract class IgniteSemaphoreAbstractSelfTest extends IgniteAtomicsAbstr
 
                             assert semaphore != null && semaphore.availablePermits() == -2;
 
-                            log.info("Thread is going to wait on semaphore: " + Thread.currentThread().getName() + ", node = " + ignite.cluster().localNode() + ", sem = " + semaphore);
+                            log.info("Thread is going to wait on semaphore: " + Thread.currentThread().getName() +
+                                ", node = " + ignite.cluster().localNode() + ", sem = " + semaphore);
 
                             assert semaphore.tryAcquire(1, 1, MINUTES);
 
-                            log.info("Thread is again runnable: " + Thread.currentThread().getName() + ", node = " + ignite.cluster().localNode() + ", sem = " + semaphore);
+                            log.info("Thread is again runnable: " + Thread.currentThread().getName() +
+                                ", node = " + ignite.cluster().localNode() + ", sem = " + semaphore);
 
                             semaphore.release();
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/partitioned/GridCachePartitionedNodeRestartTxSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/partitioned/GridCachePartitionedNodeRestartTxSelfTest.java
index b826376..f4ef208 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/partitioned/GridCachePartitionedNodeRestartTxSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/partitioned/GridCachePartitionedNodeRestartTxSelfTest.java
@@ -263,7 +263,10 @@ public class GridCachePartitionedNodeRestartTxSelfTest extends GridCommonAbstrac
 
         try (Transaction tx = grid(0).transactions().txStart(PESSIMISTIC, REPEATABLE_READ)) {
             // Put custom data
-            grid(0).cache(DEFAULT_CACHE_NAME).put(new GridCacheInternalKeyImpl(key, "testGroup"), new GridCacheAtomicLongValue(INIT_GRID_NUM));
+            grid(0).cache(DEFAULT_CACHE_NAME).put(
+                new GridCacheInternalKeyImpl(key, "testGroup"),
+                new GridCacheAtomicLongValue(INIT_GRID_NUM)
+            );
 
             tx.commit();
         }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheBaselineTopologyTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheBaselineTopologyTest.java
index 3039c63..cd94e68 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheBaselineTopologyTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheBaselineTopologyTest.java
@@ -977,8 +977,12 @@ public class CacheBaselineTopologyTest extends GridCommonAbstractTest {
         for (int i = 1; i < 4; i++) {
             IgniteEx ig0 = grid(i);
 
-            for (int p = 0; p < 32; p++)
-                assertEqualsCollections(ig.affinity(cacheName).mapPartitionToPrimaryAndBackups(p), ig0.affinity(cacheName).mapPartitionToPrimaryAndBackups(p));
+            for (int p = 0; p < 32; p++) {
+                assertEqualsCollections(
+                    ig.affinity(cacheName).mapPartitionToPrimaryAndBackups(p),
+                    ig0.affinity(cacheName).mapPartitionToPrimaryAndBackups(p)
+                );
+            }
         }
 
         for (Map.Entry<Integer, String> e : keyToConsId.entrySet()) {
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheClientsConcurrentStartTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheClientsConcurrentStartTest.java
index 7b9244a..d12f5b6 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheClientsConcurrentStartTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheClientsConcurrentStartTest.java
@@ -75,7 +75,12 @@ public class CacheClientsConcurrentStartTest extends GridCommonAbstractTest {
         IgniteConfiguration cfg = super.getConfiguration(gridName);
 
         TcpDiscoverySpi testSpi = new TcpDiscoverySpi() {
-            @Override protected void writeToSocket(Socket sock, OutputStream out, TcpDiscoveryAbstractMessage msg, long timeout) throws IOException, IgniteCheckedException {
+            @Override protected void writeToSocket(
+                Socket sock,
+                OutputStream out,
+                TcpDiscoveryAbstractMessage msg,
+                long timeout
+            ) throws IOException, IgniteCheckedException {
                 if (msg instanceof TcpDiscoveryCustomEventMessage && msg.verified()) {
                     try {
                         System.out.println(Thread.currentThread().getName() + " delay custom message");
@@ -138,19 +143,20 @@ public class CacheClientsConcurrentStartTest extends GridCommonAbstractTest {
         startGrids(SRV_CNT);
 
         for (int i = 0; i < SRV_CNT; i++) {
-            ((TestRecordingCommunicationSpi)ignite(i).configuration().getCommunicationSpi()).blockMessages(new IgniteBiPredicate<ClusterNode, Message>() {
-                @Override public boolean apply(ClusterNode node, Message msg) {
-                    if (msg instanceof GridDhtPartitionsFullMessage) {
-                        try {
-                            U.sleep(ThreadLocalRandom.current().nextLong(500) + 100);
+            ((TestRecordingCommunicationSpi)ignite(i).configuration().getCommunicationSpi()).blockMessages(
+                new IgniteBiPredicate<ClusterNode, Message>() {
+                    @Override public boolean apply(ClusterNode node, Message msg) {
+                        if (msg instanceof GridDhtPartitionsFullMessage) {
+                            try {
+                                U.sleep(ThreadLocalRandom.current().nextLong(500) + 100);
+                            }
+                            catch (Exception e) {
+                                e.printStackTrace();
+                            }
                         }
-                        catch (Exception e) {
-                            e.printStackTrace();
-                        }
-                    }
 
-                    return false;
-                }
+                        return false;
+                    }
             });
         }
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheStartOnJoinTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheStartOnJoinTest.java
index 37faf5b..1b65f55 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheStartOnJoinTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheStartOnJoinTest.java
@@ -63,7 +63,12 @@ public class CacheStartOnJoinTest extends GridCommonAbstractTest {
             /** */
             private boolean delay = true;
 
-            @Override protected void writeToSocket(Socket sock, OutputStream out, TcpDiscoveryAbstractMessage msg, long timeout) throws IOException, IgniteCheckedException {
+            @Override protected void writeToSocket(
+                Socket sock,
+                OutputStream out,
+                TcpDiscoveryAbstractMessage msg,
+                long timeout
+            ) throws IOException, IgniteCheckedException {
                 super.writeToSocket(sock, out, msg, timeout);
             }
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCachePartitionEvictionDuringReadThroughSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCachePartitionEvictionDuringReadThroughSelfTest.java
index 370782c..923fcd9 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCachePartitionEvictionDuringReadThroughSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCachePartitionEvictionDuringReadThroughSelfTest.java
@@ -107,8 +107,11 @@ public class GridCachePartitionEvictionDuringReadThroughSelfTest extends GridCom
                     catch (Throwable ignore) {
                         // No-op.
                     }
-                    if (Thread.currentThread().isInterrupted())
-                        throw new IgniteInterruptedCheckedException("Execution of [" + Thread.currentThread().getName() + "] Interrupted. Test is probably timed out");
+                    if (Thread.currentThread().isInterrupted()) {
+                        throw new IgniteInterruptedCheckedException(
+                            "Execution of [" + Thread.currentThread().getName() + "] Interrupted. Test is probably timed out"
+                        );
+                    }
                 }
 
                 return null;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridExchangeFreeCellularSwitchIsolationTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridExchangeFreeCellularSwitchIsolationTest.java
index 6d93e89..9bb0e8b 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridExchangeFreeCellularSwitchIsolationTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridExchangeFreeCellularSwitchIsolationTest.java
@@ -326,7 +326,8 @@ public class GridExchangeFreeCellularSwitchIsolationTest extends GridExchangeFre
             aliveCellNodes, orig == failed ? 1 : nodes,
             replTxVers);
 
-        BiConsumer<T2<Ignite, String>, T3<CountDownLatch, CountDownLatch, CountDownLatch>> txRun = // Counts tx's creations and preparations.
+        // Counts tx's creations and preparations.
+        BiConsumer<T2<Ignite, String>, T3<CountDownLatch, CountDownLatch, CountDownLatch>> txRun =
             (T2<Ignite, String> pair, T3</*create*/CountDownLatch, /*put*/CountDownLatch, /*commit*/CountDownLatch> latches) -> {
                 try {
                     Ignite ignite = pair.get1();
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCachePartitionLossPolicySelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCachePartitionLossPolicySelfTest.java
index 7e4d832..d5c88c3 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCachePartitionLossPolicySelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCachePartitionLossPolicySelfTest.java
@@ -509,7 +509,9 @@ public class IgniteCachePartitionLossPolicySelfTest extends GridCommonAbstractTe
             int c = 0;
 
             for (int idx = 0; idx < nodes; idx++) {
-                if (Arrays.binarySearch(stopNodesSorted, idx) < 0 && !aff.isPrimary(grid(idx).localNode(), i) && !aff.isBackup(grid(idx).localNode(), i))
+                if (Arrays.binarySearch(stopNodesSorted, idx) < 0
+                    && !aff.isPrimary(grid(idx).localNode(), i)
+                    && !aff.isBackup(grid(idx).localNode(), i))
                     c++;
             }
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCachePartitionedNearDisabledAtomicOnheapMultiNodeFullApiSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCachePartitionedNearDisabledAtomicOnheapMultiNodeFullApiSelfTest.java
index eb5a1dd..7167089 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCachePartitionedNearDisabledAtomicOnheapMultiNodeFullApiSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCachePartitionedNearDisabledAtomicOnheapMultiNodeFullApiSelfTest.java
@@ -20,7 +20,8 @@ package org.apache.ignite.internal.processors.cache.distributed.dht;
 
 import org.apache.ignite.cache.CacheAtomicityMode;
 
-public class GridCachePartitionedNearDisabledAtomicOnheapMultiNodeFullApiSelfTest extends GridCachePartitionedNearDisabledOnheapMultiNodeFullApiSelfTest {
+public class GridCachePartitionedNearDisabledAtomicOnheapMultiNodeFullApiSelfTest
+    extends GridCachePartitionedNearDisabledOnheapMultiNodeFullApiSelfTest {
     /** {@inheritDoc} */
     @Override protected CacheAtomicityMode atomicityMode() {
         return CacheAtomicityMode.ATOMIC;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCachePartitionsStateValidationTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCachePartitionsStateValidationTest.java
index de88bb2..22f8f4a 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCachePartitionsStateValidationTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCachePartitionsStateValidationTest.java
@@ -53,10 +53,11 @@ import org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi;
 import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
 import org.apache.ignite.transactions.Transaction;
-import org.apache.ignite.transactions.TransactionConcurrency;
-import org.apache.ignite.transactions.TransactionIsolation;
 import org.junit.Test;
 
+import static org.apache.ignite.transactions.TransactionConcurrency.OPTIMISTIC;
+import static org.apache.ignite.transactions.TransactionIsolation.READ_COMMITTED;
+
 /**
  *
  */
@@ -157,7 +158,8 @@ public class GridCachePartitionsStateValidationTest extends GridCommonAbstractTe
         );
 
         for (int it = 0; it < 10; it++) {
-            SingleMessageInterceptorCommunicationSpi spi = (SingleMessageInterceptorCommunicationSpi) ignite.configuration().getCommunicationSpi();
+            SingleMessageInterceptorCommunicationSpi spi =
+                (SingleMessageInterceptorCommunicationSpi) ignite.configuration().getCommunicationSpi();
             spi.clear();
 
             // Stop load future.
@@ -185,7 +187,7 @@ public class GridCachePartitionsStateValidationTest extends GridCommonAbstractTe
                         .sorted()
                         .collect(Collectors.toList());
 
-                    try (Transaction tx = ignite.transactions().txStart(TransactionConcurrency.OPTIMISTIC, TransactionIsolation.READ_COMMITTED)) {
+                    try (Transaction tx = ignite.transactions().txStart(OPTIMISTIC, READ_COMMITTED)) {
                         for (Integer key : randomKeys)
                             txCache.put(key, key);
 
@@ -214,11 +216,20 @@ public class GridCachePartitionsStateValidationTest extends GridCommonAbstractTe
                 for (int i = 0; i < interceptedMessages.size(); i++)
                     messagesMap.put(grid(i + 1).context().localNodeId(), interceptedMessages.get(i));
 
-                GridDhtPartitionsStateValidator validator = new GridDhtPartitionsStateValidator(ignite.context().cache().context());
+                GridDhtPartitionsStateValidator validator =
+                    new GridDhtPartitionsStateValidator(ignite.context().cache().context());
 
                 // Validate partition update counters. If counters are not consistent, exception will be thrown.
-                validator.validatePartitionsUpdateCounters(ignite.cachex(atomicCacheName).context().topology(), messagesMap, Collections.emptySet());
-                validator.validatePartitionsUpdateCounters(ignite.cachex(txCacheName).context().topology(), messagesMap, Collections.emptySet());
+                validator.validatePartitionsUpdateCounters(
+                    ignite.cachex(atomicCacheName).context().topology(),
+                    messagesMap,
+                    Collections.emptySet()
+                );
+                validator.validatePartitionsUpdateCounters(
+                    ignite.cachex(txCacheName).context().topology(),
+                    messagesMap,
+                    Collections.emptySet()
+                );
 
             } finally {
                 // Stop load and resume exchange.
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCachePartitionsStateValidatorSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCachePartitionsStateValidatorSelfTest.java
index 7c6a512..5fad31e 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCachePartitionsStateValidatorSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridCachePartitionsStateValidatorSelfTest.java
@@ -128,7 +128,8 @@ public class GridCachePartitionsStateValidatorSelfTest extends GridCommonAbstrac
         GridDhtPartitionsStateValidator validator = new GridDhtPartitionsStateValidator(cctxMock);
 
         // (partId, (nodeId, updateCounter))
-        Map<Integer, Map<UUID, Long>> result = validator.validatePartitionsUpdateCounters(topologyMock, messages, Sets.newHashSet(ignoreNode));
+        Map<Integer, Map<UUID, Long>> result =
+            validator.validatePartitionsUpdateCounters(topologyMock, messages, Sets.newHashSet(ignoreNode));
 
         // Check that validation result contains all necessary information.
         Assert.assertEquals(2, result.size());
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteCacheStartWithLoadTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteCacheStartWithLoadTest.java
index ff2e3e5..3a1d6c4 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteCacheStartWithLoadTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteCacheStartWithLoadTest.java
@@ -36,11 +36,12 @@ import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.GridTestUtils.SF;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
 import org.apache.ignite.transactions.Transaction;
-import org.apache.ignite.transactions.TransactionConcurrency;
-import org.apache.ignite.transactions.TransactionIsolation;
 import org.junit.Assert;
 import org.junit.Test;
 
+import static org.apache.ignite.transactions.TransactionConcurrency.PESSIMISTIC;
+import static org.apache.ignite.transactions.TransactionIsolation.REPEATABLE_READ;
+
 /**
  *
  */
@@ -96,7 +97,7 @@ public class IgniteCacheStartWithLoadTest extends GridCommonAbstractTest {
             final int keysSpace = 10_000;
 
             while (!txLoadStop.get()) {
-                try (Transaction tx = node.transactions().txStart(TransactionConcurrency.PESSIMISTIC, TransactionIsolation.REPEATABLE_READ)) {
+                try (Transaction tx = node.transactions().txStart(PESSIMISTIC, REPEATABLE_READ)) {
                     for (int it = 0; it < keys; it++) {
                         int key = rnd.nextInt(keysSpace);
                         byte[] value = new byte[2048];
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/BlockedEvictionsTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/BlockedEvictionsTest.java
index ab728b1..d45382e 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/BlockedEvictionsTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/BlockedEvictionsTest.java
@@ -422,7 +422,12 @@ public class BlockedEvictionsTest extends GridCommonAbstractTest {
                     GridDhtPartitionTopologyImpl top = (GridDhtPartitionTopologyImpl) instance;
 
                     top.partitionFactory(new GridDhtPartitionTopologyImpl.PartitionFactory() {
-                        @Override public GridDhtLocalPartition create(GridCacheSharedContext ctx, CacheGroupContext grp, int id, boolean recovery) {
+                        @Override public GridDhtLocalPartition create(
+                            GridCacheSharedContext ctx,
+                            CacheGroupContext grp,
+                            int id,
+                            boolean recovery
+                        ) {
                             return new GridDhtLocalPartitionSyncEviction(ctx, grp, id, recovery, mode, l1, l2) {
                                 /** */
                                 @Override protected void sync() {
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/MovingPartitionIsEvictedDuringClearingTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/MovingPartitionIsEvictedDuringClearingTest.java
index a660533..9a44e10 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/MovingPartitionIsEvictedDuringClearingTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/MovingPartitionIsEvictedDuringClearingTest.java
@@ -121,7 +121,12 @@ public class MovingPartitionIsEvictedDuringClearingTest extends GridCommonAbstra
                     GridDhtPartitionTopologyImpl top = (GridDhtPartitionTopologyImpl) instance;
 
                     top.partitionFactory(new GridDhtPartitionTopologyImpl.PartitionFactory() {
-                        @Override public GridDhtLocalPartition create(GridCacheSharedContext ctx, CacheGroupContext grp, int id, boolean recovery) {
+                        @Override public GridDhtLocalPartition create(
+                            GridCacheSharedContext ctx,
+                            CacheGroupContext grp,
+                            int id,
+                            boolean recovery
+                        ) {
                             return id == evictingPart ?
                                 new GridDhtLocalPartitionSyncEviction(ctx, grp, id, recovery, 2, lock, unlock) :
                                 new GridDhtLocalPartition(ctx, grp, id, recovery);
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/PreloadingRestartWhileClearingPartitionTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/PreloadingRestartWhileClearingPartitionTest.java
index c318d46..ef20ef3 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/PreloadingRestartWhileClearingPartitionTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/PreloadingRestartWhileClearingPartitionTest.java
@@ -121,7 +121,12 @@ public class PreloadingRestartWhileClearingPartitionTest extends GridCommonAbstr
                     GridDhtPartitionTopologyImpl top = (GridDhtPartitionTopologyImpl) instance;
 
                     top.partitionFactory(new GridDhtPartitionTopologyImpl.PartitionFactory() {
-                        @Override public GridDhtLocalPartition create(GridCacheSharedContext ctx, CacheGroupContext grp, int id, boolean recovery) {
+                        @Override public GridDhtLocalPartition create(
+                            GridCacheSharedContext ctx,
+                            CacheGroupContext grp,
+                            int id,
+                            boolean recovery
+                        ) {
                             return id == clearingPart ?
                                 new GridDhtLocalPartitionSyncEviction(ctx, grp, id, recovery, 1, lock, unlock) :
                                 new GridDhtLocalPartition(ctx, grp, id, recovery);
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedFilteredPutSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedFilteredPutSelfTest.java
index 7023ef2..eb31ff2 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedFilteredPutSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedFilteredPutSelfTest.java
@@ -87,8 +87,9 @@ public class GridCachePartitionedFilteredPutSelfTest extends GridCommonAbstractT
     public void testPutAndRollbackCheckDht() throws Exception {
         doPutAndRollback();
 
+        IgniteKernal grid = (IgniteKernal)grid();
         GridCacheAdapter<Integer, Integer> c =
-            ((GridNearCacheAdapter<Integer, Integer>)((IgniteKernal)grid()).internalCache(DEFAULT_CACHE_NAME).<Integer, Integer>cache()).dht();
+            ((GridNearCacheAdapter<Integer, Integer>)grid.internalCache(DEFAULT_CACHE_NAME).<Integer, Integer>cache()).dht();
 
         assert c.entrySet().isEmpty() : "Actual size: " + c.entrySet().size();
     }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/multijvm/GridCachePartitionedNearDisabledAtomicOnheapMultiJvmFullApiSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/multijvm/GridCachePartitionedNearDisabledAtomicOnheapMultiJvmFullApiSelfTest.java
index 0ce6ada..7ac4e4d 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/multijvm/GridCachePartitionedNearDisabledAtomicOnheapMultiJvmFullApiSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/multijvm/GridCachePartitionedNearDisabledAtomicOnheapMultiJvmFullApiSelfTest.java
@@ -20,7 +20,8 @@ package org.apache.ignite.internal.processors.cache.multijvm;
 
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedNearDisabledAtomicOnheapMultiNodeFullApiSelfTest;
 
-public class GridCachePartitionedNearDisabledAtomicOnheapMultiJvmFullApiSelfTest extends GridCachePartitionedNearDisabledAtomicOnheapMultiNodeFullApiSelfTest {
+public class GridCachePartitionedNearDisabledAtomicOnheapMultiJvmFullApiSelfTest
+    extends GridCachePartitionedNearDisabledAtomicOnheapMultiNodeFullApiSelfTest {
     /** {@inheritDoc} */
     @Override protected boolean isMultiJvm() {
         return true;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/multijvm/GridCachePartitionedNearDisabledOnheapMultiJvmFullApiSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/multijvm/GridCachePartitionedNearDisabledOnheapMultiJvmFullApiSelfTest.java
index e2d716f..fef23ad 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/multijvm/GridCachePartitionedNearDisabledOnheapMultiJvmFullApiSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/multijvm/GridCachePartitionedNearDisabledOnheapMultiJvmFullApiSelfTest.java
@@ -20,7 +20,8 @@ package org.apache.ignite.internal.processors.cache.multijvm;
 
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedNearDisabledOnheapMultiNodeFullApiSelfTest;
 
-public class GridCachePartitionedNearDisabledOnheapMultiJvmFullApiSelfTest extends GridCachePartitionedNearDisabledOnheapMultiNodeFullApiSelfTest {
+public class GridCachePartitionedNearDisabledOnheapMultiJvmFullApiSelfTest
+    extends GridCachePartitionedNearDisabledOnheapMultiNodeFullApiSelfTest {
     /** {@inheritDoc} */
     @Override protected boolean isMultiJvm() {
         return true;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccAbstractBasicCoordinatorFailoverTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccAbstractBasicCoordinatorFailoverTest.java
index 081e3db..619a049 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccAbstractBasicCoordinatorFailoverTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccAbstractBasicCoordinatorFailoverTest.java
@@ -265,7 +265,10 @@ public abstract class CacheMvccAbstractBasicCoordinatorFailoverTest extends Cach
                                     res = readAllByMode(cache, vals.keySet(), readMode, INTEGER_CODEC);
 
                                 if (readInTx) { // TODO IGNITE-8841
-                                    assertTrue("res.size=" + (res == null ? 0 : res.size()) + ", res=" + res, res == null || vals.size() == res.size());
+                                    assertTrue(
+                                        "res.size=" + (res == null ? 0 : res.size()) + ", res=" + res,
+                                        res == null || vals.size() == res.size()
+                                    );
                                 }
                                 else {
                                     assertEquals(vals.size(), res.size());
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccTxFailoverTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccTxFailoverTest.java
index 8878c6f..5d7a74c 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccTxFailoverTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccTxFailoverTest.java
@@ -159,7 +159,8 @@ public class CacheMvccTxFailoverTest extends GridCommonAbstractTest {
             ((GridCacheDatabaseSharedManager)node.context().cache().context().database()).enableCheckpoints(false).get();
         }
 
-        GridTimeoutProcessor.CancelableTask flushTask = GridTestUtils.getFieldValue(wal, FileWriteAheadLogManager.class, "backgroundFlushSchedule");
+        GridTimeoutProcessor.CancelableTask flushTask =
+            GridTestUtils.getFieldValue(wal, FileWriteAheadLogManager.class, "backgroundFlushSchedule");
         WalStateManager.WALDisableContext wctx = GridTestUtils.getFieldValue(wal, FileWriteAheadLogManager.class, "walDisableContext");
 
         // Disable checkpoint and WAL flusher.
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsBinaryMetadataOnClusterRestartTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsBinaryMetadataOnClusterRestartTest.java
index 3c289eff..c0286b4 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsBinaryMetadataOnClusterRestartTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsBinaryMetadataOnClusterRestartTest.java
@@ -111,7 +111,8 @@ public class IgnitePdsBinaryMetadataOnClusterRestartTest extends GridCommonAbstr
     }
 
     /**
-     * @see <a href="https://issues.apache.org/jira/browse/IGNITE-7258">IGNITE-7258</a> refer to the following JIRA for more context about the problem verified by the test.
+     * @see <a href="https://issues.apache.org/jira/browse/IGNITE-7258">IGNITE-7258</a>
+     * refer to the following JIRA for more context about the problem verified by the test.
      */
     @Test
     public void testUpdatedBinaryMetadataIsPreservedOnJoinToOldCoordinator() throws Exception {
@@ -165,7 +166,8 @@ public class IgnitePdsBinaryMetadataOnClusterRestartTest extends GridCommonAbstr
     }
 
     /**
-     * @see <a href="https://issues.apache.org/jira/browse/IGNITE-7258">IGNITE-7258</a> refer to the following JIRA for more context about the problem verified by the test.
+     * @see <a href="https://issues.apache.org/jira/browse/IGNITE-7258">IGNITE-7258</a>
+     * refer to the following JIRA for more context about the problem verified by the test.
      */
     @Test
     public void testNewBinaryMetadataIsWrittenOnOldCoordinator() throws Exception {
@@ -220,7 +222,8 @@ public class IgnitePdsBinaryMetadataOnClusterRestartTest extends GridCommonAbstr
      * after full cluster restart it starts second (so it doesn't take the role of coordinator)
      * but metadata update is propagated to it anyway.
      *
-     * @see <a href="https://issues.apache.org/jira/browse/IGNITE-7258">IGNITE-7258</a> refer to the following JIRA for more context about the problem verified by the test.
+     * @see <a href="https://issues.apache.org/jira/browse/IGNITE-7258">IGNITE-7258</a>
+     * refer to the following JIRA for more context about the problem verified by the test.
      */
     @Test
     public void testNewBinaryMetadataIsPropagatedToAllOutOfDataNodes() throws Exception {
@@ -288,7 +291,8 @@ public class IgnitePdsBinaryMetadataOnClusterRestartTest extends GridCommonAbstr
      * If joining node has incompatible BinaryMetadata (e.g. when user manually copies binary_meta file),
      * coordinator detects it and fails the node providing information about conflict.
      *
-     * @see <a href="https://issues.apache.org/jira/browse/IGNITE-7258">IGNITE-7258</a> refer to the following JIRA for more context about the problem verified by the test.
+     * @see <a href="https://issues.apache.org/jira/browse/IGNITE-7258">IGNITE-7258</a>
+     * refer to the following JIRA for more context about the problem verified by the test.
      */
     @Test
     public void testNodeWithIncompatibleMetadataIsProhibitedToJoinTheCluster() throws Exception {
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/MaintenanceRegistrySimpleTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/MaintenanceRegistrySimpleTest.java
index f64d568..57ab147 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/MaintenanceRegistrySimpleTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/MaintenanceRegistrySimpleTest.java
@@ -185,14 +185,20 @@ public class MaintenanceRegistrySimpleTest {
         MaintenanceProcessor proc = new MaintenanceProcessor(initContext(true));
 
         // attempt to register callback with actions with non-unique names throws exception
-        GridTestUtils.assertThrows(log, () ->
-                proc.registerWorkflowCallback(name0, new SimpleMaintenanceCallback(Arrays.asList(new SimpleAction(actionName0), new SimpleAction(actionName0))
-                )),
+        GridTestUtils.assertThrows(
+            log,
+            () -> proc.registerWorkflowCallback(
+                name0,
+                new SimpleMaintenanceCallback(Arrays.asList(new SimpleAction(actionName0), new SimpleAction(actionName0)))
+            ),
             IgniteException.class,
             "unique names: " + actionName0 + ", " + actionName0);
 
         // Attempt to register callback with actions with unique names finishes succesfully
-        proc.registerWorkflowCallback(name1, new SimpleMaintenanceCallback(Arrays.asList(new SimpleAction(actionName0), new SimpleAction(actionName1))));
+        proc.registerWorkflowCallback(
+            name1,
+            new SimpleMaintenanceCallback(Arrays.asList(new SimpleAction(actionName0), new SimpleAction(actionName1)))
+        );
     }
 
     /**
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/baseline/IgniteChangingBaselineDownCacheRemoveFailoverTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/baseline/IgniteChangingBaselineDownCacheRemoveFailoverTest.java
index 609180d..cdb2b80 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/baseline/IgniteChangingBaselineDownCacheRemoveFailoverTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/baseline/IgniteChangingBaselineDownCacheRemoveFailoverTest.java
@@ -112,7 +112,10 @@ public class IgniteChangingBaselineDownCacheRemoveFailoverTest extends GridCache
     }
 
     /** {@inheritDoc} */
-    @Override protected IgniteInternalFuture createAndRunConcurrentAction(final AtomicBoolean stop, final AtomicReference<CyclicBarrier> cmp) {
+    @Override protected IgniteInternalFuture createAndRunConcurrentAction(
+        final AtomicBoolean stop,
+        final AtomicReference<CyclicBarrier> cmp
+    ) {
         return GridTestUtils.runAsync(new Callable<Void>() {
             @Override public Void call() throws Exception {
                 Thread.currentThread().setName("restart-thread");
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/baseline/IgniteChangingBaselineUpCacheRemoveFailoverTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/baseline/IgniteChangingBaselineUpCacheRemoveFailoverTest.java
index 560e85b7..d723bb9 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/baseline/IgniteChangingBaselineUpCacheRemoveFailoverTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/baseline/IgniteChangingBaselineUpCacheRemoveFailoverTest.java
@@ -108,7 +108,10 @@ public class IgniteChangingBaselineUpCacheRemoveFailoverTest extends GridCacheAb
     }
 
     /** {@inheritDoc} */
-    @Override protected IgniteInternalFuture createAndRunConcurrentAction(final AtomicBoolean stop, final AtomicReference<CyclicBarrier> cmp) {
+    @Override protected IgniteInternalFuture createAndRunConcurrentAction(
+        final AtomicBoolean stop,
+        final AtomicReference<CyclicBarrier> cmp
+    ) {
         return GridTestUtils.runAsync(new Callable<Void>() {
             @Override public Void call() throws Exception {
                 Thread.currentThread().setName("restart-thread");
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/baseline/IgniteStableBaselineCacheRemoveFailoverTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/baseline/IgniteStableBaselineCacheRemoveFailoverTest.java
index de92749..193a67e 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/baseline/IgniteStableBaselineCacheRemoveFailoverTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/baseline/IgniteStableBaselineCacheRemoveFailoverTest.java
@@ -100,7 +100,10 @@ public class IgniteStableBaselineCacheRemoveFailoverTest extends GridCacheAbstra
     }
 
     /** {@inheritDoc} */
-    @Override protected IgniteInternalFuture createAndRunConcurrentAction(final AtomicBoolean stop, final AtomicReference<CyclicBarrier> cmp) {
+    @Override protected IgniteInternalFuture createAndRunConcurrentAction(
+        final AtomicBoolean stop,
+        final AtomicReference<CyclicBarrier> cmp
+    ) {
         return GridTestUtils.runAsync(new Callable<Void>() {
             @Override public Void call() throws Exception {
                 Thread.currentThread().setName("restart-thread");
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgniteLogicalRecoveryTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgniteLogicalRecoveryTest.java
index 3f8f853..51d2114 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgniteLogicalRecoveryTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgniteLogicalRecoveryTest.java
@@ -149,7 +149,12 @@ public class IgniteLogicalRecoveryTest extends GridCommonAbstractTest {
      * @param cacheMode Cache mode.
      * @param atomicityMode Atomicity mode.
      */
-    protected CacheConfiguration<Object, Object> cacheConfiguration(String name, @Nullable String groupName, CacheMode cacheMode, CacheAtomicityMode atomicityMode) {
+    protected CacheConfiguration<Object, Object> cacheConfiguration(
+        String name,
+        @Nullable String groupName,
+        CacheMode cacheMode,
+        CacheAtomicityMode atomicityMode
+    ) {
         CacheConfiguration<Object, Object> cfg = new CacheConfiguration<>(name)
             .setGroupName(groupName)
             .setCacheMode(cacheMode)
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgnitePdsTransactionsHangTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgnitePdsTransactionsHangTest.java
index 3af55e0..cd868df 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgnitePdsTransactionsHangTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/IgnitePdsTransactionsHangTest.java
@@ -228,7 +228,9 @@ public class IgnitePdsTransactionsHangTest extends GridCommonAbstractTest {
                     max = Math.max(max, sum);
                     min = Math.min(min, sum);
 
-                    log.info("Operation count: " + sum + " min=" + min + " max=" + max + " avg=" + totalOperations / (periods - WARM_UP_PERIOD));
+                    log.info(
+                        "Operation count: " + sum + " min=" + min + " max=" + max + " avg=" + totalOperations / (periods - WARM_UP_PERIOD)
+                    );
                 }
             }
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/checkpoint/CheckpointFreeListTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/checkpoint/CheckpointFreeListTest.java
index d26c415..d487e86 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/checkpoint/CheckpointFreeListTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/checkpoint/CheckpointFreeListTest.java
@@ -255,7 +255,8 @@ public class CheckpointFreeListTest extends GridCommonAbstractTest {
 
         entriesToRemove.forEach(t2 -> cache.remove(t2.get1()));
 
-        //During removing of entries free list grab a lot of free pages to itself so will do put/remove again for stabilization of free pages.
+        //During removing of entries free list grab a lot of free pages to itself
+        //so will do put/remove again for stabilization of free pages.
         entriesToRemove.forEach(t2 -> cache.put(t2.get1(), t2.get2()));
 
         entriesToRemove.forEach(t2 -> cache.remove(t2.get1()));
@@ -303,7 +304,8 @@ public class CheckpointFreeListTest extends GridCommonAbstractTest {
 
         Optional<Long> totalPartSizeAfterRestore = totalPartitionsSize(cacheFolder);
 
-        //It allow that size after repeated put operations should be not more than on 15%(heuristic value) greater than before operations. In fact, it should not be multiplied in twice every time.
+        //It allow that size after repeated put operations should be not more than on 15%(heuristic value) greater than before operations.
+        //In fact, it should not be multiplied in twice every time.
         long correctedRestoreSize = totalPartSizeAfterRestore.get() - (long)(totalPartSizeBeforeStop.get() * 0.15);
 
         assertTrue("Size after repeated put operations should be not more than on 15% greater. " +
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/file/IgnitePdsCheckpointSimulationWithRealCpDisabledTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/file/IgnitePdsCheckpointSimulationWithRealCpDisabledTest.java
index f829b90..a5d89eb 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/file/IgnitePdsCheckpointSimulationWithRealCpDisabledTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/file/IgnitePdsCheckpointSimulationWithRealCpDisabledTest.java
@@ -528,7 +528,9 @@ public class IgnitePdsCheckpointSimulationWithRealCpDisabledTest extends GridCom
                 PageSnapshot snap = (PageSnapshot)tup.get2();
 
                 //there are extra tracking pages, skip them
-                if (TrackingPageIO.VERSIONS.latest().trackingPageFor(snap.fullPageId().pageId(), pageMem.pageSize()) == snap.fullPageId().pageId()) {
+                long trackingPageFor = TrackingPageIO.VERSIONS.latest().trackingPageFor(snap.fullPageId().pageId(), pageMem.pageSize());
+
+                if (trackingPageFor == snap.fullPageId().pageId()) {
                     tup = it.next();
 
                     assertTrue(tup.get2() instanceof PageSnapshot);
@@ -1110,7 +1112,8 @@ public class IgnitePdsCheckpointSimulationWithRealCpDisabledTest extends GridCom
     /**
      *
      */
-    private static class PartitionMetaStateRecordExcludeIterator extends GridFilteredClosableIterator<IgniteBiTuple<WALPointer, WALRecord>> {
+    private static class PartitionMetaStateRecordExcludeIterator
+        extends GridFilteredClosableIterator<IgniteBiTuple<WALPointer, WALRecord>> {
         private PartitionMetaStateRecordExcludeIterator(
             GridCloseableIterator<? extends IgniteBiTuple<WALPointer, WALRecord>> it) {
             super(it);
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/file/IgnitePdsDiskErrorsRecoveringTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/file/IgnitePdsDiskErrorsRecoveringTest.java
index 8af8903..861d58c 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/file/IgnitePdsDiskErrorsRecoveringTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/file/IgnitePdsDiskErrorsRecoveringTest.java
@@ -171,7 +171,10 @@ public class IgnitePdsDiskErrorsRecoveringTest extends GridCommonAbstractTest {
     @Test
     public void testRecoveringOnCheckpointBeginFail() throws Exception {
         // Fail to write checkpoint start marker tmp file at the second checkpoint. Pass only initial checkpoint.
-        ioFactory = new FilteringFileIOFactory("START.bin" + FilePageStoreManager.TMP_SUFFIX, new LimitedSizeFileIOFactory(new RandomAccessFileIOFactory(), 20));
+        ioFactory = new FilteringFileIOFactory(
+            "START.bin" + FilePageStoreManager.TMP_SUFFIX,
+            new LimitedSizeFileIOFactory(new RandomAccessFileIOFactory(), 20)
+        );
 
         final IgniteEx grid = startGrid(0);
         grid.cluster().active(true);
@@ -285,7 +288,10 @@ public class IgnitePdsDiskErrorsRecoveringTest extends GridCommonAbstractTest {
     @Test
     public void testRecoveringOnWALWritingFail2() throws Exception {
         // Fail somewhere on the second wal segment.
-        ioFactory = new FilteringFileIOFactory(".wal", new LimitedSizeFileIOFactory(new RandomAccessFileIOFactory(), (long) (1.5 * WAL_SEGMENT_SIZE)));
+        ioFactory = new FilteringFileIOFactory(
+            ".wal",
+            new LimitedSizeFileIOFactory(new RandomAccessFileIOFactory(), (long) (1.5 * WAL_SEGMENT_SIZE))
+        );
 
         System.setProperty(IGNITE_WAL_MMAP, "false");
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/reader/IgniteWalReaderTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/reader/IgniteWalReaderTest.java
index 76188f5..77e25c3 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/reader/IgniteWalReaderTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/reader/IgniteWalReaderTest.java
@@ -618,7 +618,8 @@ public class IgniteWalReaderTest extends GridCommonAbstractTest {
 
         TestStringContainerToBePrinted val = new TestStringContainerToBePrinted(search2);
 
-        ctrlStringsToSearch.add("v = [ " + val.getClass().getSimpleName() + "{data='" + search2 + "'}]"); //will validate original toString() was called
+        //will validate original toString() was called
+        ctrlStringsToSearch.add("v = [ " + val.getClass().getSimpleName() + "{data='" + search2 + "'}]");
         ctrlStringsForBinaryObjSearch.add(search2);
 
         addlCache.put("SearchValue", val);
@@ -627,7 +628,8 @@ public class IgniteWalReaderTest extends GridCommonAbstractTest {
 
         TestStringContainerToBePrinted key = new TestStringContainerToBePrinted(search3);
 
-        ctrlStringsToSearch.add("k = " + key.getClass().getSimpleName() + "{data='" + search3 + "'}"); //will validate original toString() was called
+        //will validate original toString() was called
+        ctrlStringsToSearch.add("k = " + key.getClass().getSimpleName() + "{data='" + search3 + "'}");
         ctrlStringsForBinaryObjSearch.add(search3); //validate only string itself
 
         addlCache.put(key, "SearchKey");
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/NoOpPageStoreManager.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/NoOpPageStoreManager.java
index c5cc372..05e9235 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/NoOpPageStoreManager.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/NoOpPageStoreManager.java
@@ -104,7 +104,13 @@ public class NoOpPageStoreManager implements IgnitePageStoreManager {
     }
 
     /** {@inheritDoc} */
-    @Override public PageStore write(int grpId, long pageId, ByteBuffer pageBuf, int tag, boolean calculateCrc) throws IgniteCheckedException {
+    @Override public PageStore write(
+        int grpId,
+        long pageId,
+        ByteBuffer pageBuf,
+        int tag,
+        boolean calculateCrc
+    ) throws IgniteCheckedException {
         // No-op.
         return null;
     }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/NoOpWALManager.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/NoOpWALManager.java
index 035f289..f571d6b 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/NoOpWALManager.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/NoOpWALManager.java
@@ -80,7 +80,10 @@ public class NoOpWALManager implements IgniteWriteAheadLogManager {
     }
 
     /** {@inheritDoc} */
-    @Override public WALIterator replay(WALPointer start, @Nullable IgniteBiPredicate<WALRecord.RecordType, WALPointer> recordDeserializeFilter) throws IgniteCheckedException, StorageException {
+    @Override public WALIterator replay(
+        WALPointer start,
+        @Nullable IgniteBiPredicate<WALRecord.RecordType, WALPointer> recordDeserializeFilter
+    ) throws IgniteCheckedException, StorageException {
         return null;
     }
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryImplTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryImplTest.java
index 90aba97..b85b96d 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryImplTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryImplTest.java
@@ -720,7 +720,13 @@ public class PageMemoryImplTest extends GridCommonAbstractTest {
         }
 
         /** {@inheritDoc} */
-        @Override public PageStore write(int grpId, long pageId, ByteBuffer pageBuf, int tag, boolean calculateCrc) throws IgniteCheckedException {
+        @Override public PageStore write(
+            int grpId,
+            long pageId,
+            ByteBuffer pageBuf,
+            int tag,
+            boolean calculateCrc
+        ) throws IgniteCheckedException {
             byte[] data = new byte[PAGE_SIZE];
 
             pageBuf.get(data);
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 1e8e64d..3814bdd 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
@@ -159,7 +159,8 @@ public class PagesWriteThrottleSandboxTest extends GridCommonAbstractTest {
                             e.printStackTrace();
                         }
 
-                        System.out.println("@@@ putsPerSec=," + (putRate.value()) + ", getsPerSec=," + (getRate.value()) + ", dirtyPages=," + dirtyPages + ", cpWrittenPages=," + cpWrittenPages + ", cpBufPages=," + cpBufPages);
+                        System.out.println("@@@ putsPerSec=," + (putRate.value()) + ", getsPerSec=," + (getRate.value()) + ", dirtyPages=,"
+                            + dirtyPages + ", cpWrittenPages=," + cpWrittenPages + ", cpBufPages=," + cpBufPages);
 
                         try {
                             Thread.sleep(1000);
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/snapshot/IgniteClusterSnapshotCheckTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/snapshot/IgniteClusterSnapshotCheckTest.java
index 4527125..b986745 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/snapshot/IgniteClusterSnapshotCheckTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/snapshot/IgniteClusterSnapshotCheckTest.java
@@ -76,6 +76,8 @@ import org.jetbrains.annotations.Nullable;
 import org.junit.Before;
 import org.junit.Test;
 
+import static java.util.Collections.singletonList;
+import static java.util.Collections.singletonMap;
 import static org.apache.ignite.cluster.ClusterState.ACTIVE;
 import static org.apache.ignite.configuration.IgniteConfiguration.DFLT_SNAPSHOT_DIRECTORY;
 import static org.apache.ignite.internal.processors.cache.GridCacheUtils.TTL_ETERNAL;
@@ -474,15 +476,15 @@ public class IgniteClusterSnapshotCheckTest extends AbstractSnapshotSelfTest {
         ignite.snapshot().createSnapshot(SNAPSHOT_NAME).get();
 
         IdleVerifyResultV2 idleVerifyRes = ignite.compute().execute(new TestVisorBackupPartitionsTask(),
-            new VisorIdleVerifyTaskArg(new HashSet<>(Collections.singletonList(ccfg.getName())),
+            new VisorIdleVerifyTaskArg(new HashSet<>(singletonList(ccfg.getName())),
             new HashSet<>(),
             false,
             CacheFilterEnum.USER,
             true));
 
         IdleVerifyResultV2 snpVerifyRes = ignite.compute().execute(new TestSnapshotPartitionsVerifyTask(),
-            Collections.singletonMap(ignite.cluster().localNode(),
-                Collections.singletonList(snp(ignite).readSnapshotMetadata(SNAPSHOT_NAME, (String)ignite.configuration().getConsistentId()))));
+            singletonMap(ignite.cluster().localNode(),
+                singletonList(snp(ignite).readSnapshotMetadata(SNAPSHOT_NAME, (String)ignite.configuration().getConsistentId()))));
 
         Map<PartitionKeyV2, List<PartitionHashRecordV2>> idleVerifyHashes = jobResults.get(TestVisorBackupPartitionsTask.class);
         Map<PartitionKeyV2, List<PartitionHashRecordV2>> snpCheckHashes = jobResults.get(TestVisorBackupPartitionsTask.class);
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/standbycluster/join/persistence/JoinActiveNodeToActiveClusterWithPersistence.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/standbycluster/join/persistence/JoinActiveNodeToActiveClusterWithPersistence.java
index a61c4ef..8efb86c 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/standbycluster/join/persistence/JoinActiveNodeToActiveClusterWithPersistence.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/standbycluster/join/persistence/JoinActiveNodeToActiveClusterWithPersistence.java
@@ -117,12 +117,14 @@ public class JoinActiveNodeToActiveClusterWithPersistence extends JoinActiveNode
     }
 
     /** {@inheritDoc} */
-    @Override public AbstractNodeJoinTemplate.JoinNodeTestPlanBuilder joinClientStaticCacheConfigurationInClusterTemplate() throws Exception {
+    @Override public AbstractNodeJoinTemplate.JoinNodeTestPlanBuilder joinClientStaticCacheConfigurationInClusterTemplate()
+        throws Exception {
         return persistent(super.joinClientStaticCacheConfigurationInClusterTemplate());
     }
 
     /** {@inheritDoc} */
-    @Override public AbstractNodeJoinTemplate.JoinNodeTestPlanBuilder joinClientStaticCacheConfigurationDifferentOnBothTemplate() throws Exception {
+    @Override public AbstractNodeJoinTemplate.JoinNodeTestPlanBuilder joinClientStaticCacheConfigurationDifferentOnBothTemplate()
+        throws Exception {
         return persistent(super.joinClientStaticCacheConfigurationDifferentOnBothTemplate());
     }
 }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/standbycluster/join/persistence/JoinInActiveNodeToActiveClusterWithPersistence.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/standbycluster/join/persistence/JoinInActiveNodeToActiveClusterWithPersistence.java
index 24251e8..f420827 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/standbycluster/join/persistence/JoinInActiveNodeToActiveClusterWithPersistence.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/standbycluster/join/persistence/JoinInActiveNodeToActiveClusterWithPersistence.java
@@ -60,11 +60,13 @@ public class JoinInActiveNodeToActiveClusterWithPersistence extends JoinInActive
         return b;
     }
 
-    @Override public AbstractNodeJoinTemplate.JoinNodeTestPlanBuilder joinClientStaticCacheConfigurationInClusterTemplate() throws Exception {
+    @Override public AbstractNodeJoinTemplate.JoinNodeTestPlanBuilder joinClientStaticCacheConfigurationInClusterTemplate()
+        throws Exception {
         return persistent(super.joinClientStaticCacheConfigurationInClusterTemplate());
     }
 
-    @Override public AbstractNodeJoinTemplate.JoinNodeTestPlanBuilder joinClientStaticCacheConfigurationDifferentOnBothTemplate() throws Exception {
+    @Override public AbstractNodeJoinTemplate.JoinNodeTestPlanBuilder joinClientStaticCacheConfigurationDifferentOnBothTemplate()
+        throws Exception {
         return persistent(super.joinClientStaticCacheConfigurationDifferentOnBothTemplate());
     }
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/SegmentedRingByteBufferTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/SegmentedRingByteBufferTest.java
index 68ef542..197842a 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/SegmentedRingByteBufferTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/SegmentedRingByteBufferTest.java
@@ -310,7 +310,9 @@ public class SegmentedRingByteBufferTest extends GridCommonAbstractTest {
     /**
      * @param mode Mode.
      */
-    private void doTestNoOverflowMultiThreaded(SegmentedRingByteBuffer.BufferMode mode) throws org.apache.ignite.IgniteCheckedException, BrokenBarrierException, InterruptedException {
+    private void doTestNoOverflowMultiThreaded(
+        SegmentedRingByteBuffer.BufferMode mode
+    ) throws org.apache.ignite.IgniteCheckedException, BrokenBarrierException, InterruptedException {
         int producerCnt = 16;
 
         final int cap = 256 * 1024;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/StandaloneWalRecordsIteratorTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/StandaloneWalRecordsIteratorTest.java
index a8ca6a2..b490543 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/StandaloneWalRecordsIteratorTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/StandaloneWalRecordsIteratorTest.java
@@ -138,7 +138,10 @@ public class StandaloneWalRecordsIteratorTest extends GridCommonAbstractTest {
 
         assertTrue("At least one WAL file must be opened!", CountedFileIO.getCountOpenedWalFiles() > 0);
 
-        assertTrue("All WAL files must be closed at least ones!", CountedFileIO.getCountOpenedWalFiles() <= CountedFileIO.getCountClosedWalFiles());
+        assertTrue(
+            "All WAL files must be closed at least ones!",
+            CountedFileIO.getCountOpenedWalFiles() <= CountedFileIO.getCountClosedWalFiles()
+        );
     }
 
     /**
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryFailoverAbstractSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryFailoverAbstractSelfTest.java
index 5b872ca..96d8df1 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryFailoverAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryFailoverAbstractSelfTest.java
@@ -261,7 +261,8 @@ public abstract class CacheContinuousQueryFailoverAbstractSelfTest extends GridC
         assertFalse(top0.rebalanceFinished(new AffinityTopologyVersion(2)));
 
         Ignite ignite1 = startGrid(1);
-        GridDhtPartitionTopology top1 = ((IgniteKernal)ignite1).context().cache().context().cacheContext(CU.cacheId(DEFAULT_CACHE_NAME)).topology();
+        GridDhtPartitionTopology top1 =
+            ((IgniteKernal)ignite1).context().cache().context().cacheContext(CU.cacheId(DEFAULT_CACHE_NAME)).topology();
 
         waitRebalanceFinished(ignite0, 2, minorVer);
         waitRebalanceFinished(ignite1, 2, minorVer);
@@ -270,7 +271,8 @@ public abstract class CacheContinuousQueryFailoverAbstractSelfTest extends GridC
         assertFalse(top1.rebalanceFinished(new AffinityTopologyVersion(3)));
 
         Ignite ignite2 = startGrid(2);
-        GridDhtPartitionTopology top2 = ((IgniteKernal)ignite2).context().cache().context().cacheContext(CU.cacheId(DEFAULT_CACHE_NAME)).topology();
+        GridDhtPartitionTopology top2 =
+            ((IgniteKernal)ignite2).context().cache().context().cacheContext(CU.cacheId(DEFAULT_CACHE_NAME)).topology();
 
         waitRebalanceFinished(ignite0, 3, minorVer);
         waitRebalanceFinished(ignite1, 3, minorVer);
@@ -281,7 +283,8 @@ public abstract class CacheContinuousQueryFailoverAbstractSelfTest extends GridC
         assertFalse(top2.rebalanceFinished(new AffinityTopologyVersion(4)));
 
         Ignite ignite3 = startClientGrid(3);
-        GridDhtPartitionTopology top3 = ((IgniteKernal)ignite3).context().cache().context().cacheContext(CU.cacheId(DEFAULT_CACHE_NAME)).topology();
+        GridDhtPartitionTopology top3 =
+            ((IgniteKernal)ignite3).context().cache().context().cacheContext(CU.cacheId(DEFAULT_CACHE_NAME)).topology();
 
         assertTrue(top0.rebalanceFinished(new AffinityTopologyVersion(4)));
         assertTrue(top1.rebalanceFinished(new AffinityTopologyVersion(4)));
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryRandomOperationsTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryRandomOperationsTest.java
index 9400e5e..c9e9a4c 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryRandomOperationsTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryRandomOperationsTest.java
@@ -579,12 +579,13 @@ public class CacheContinuousQueryRandomOperationsTest extends GridCommonAbstract
                 qry.setRemoteFilterFactory(noOpFilterFactory());
 
             if (qry instanceof ContinuousQuery) {
-                ((ContinuousQuery<QueryTestKey, QueryTestValue>)qry).setLocalListener(new CacheEntryUpdatedListener<QueryTestKey, QueryTestValue>() {
-                    @Override public void onUpdated(Iterable<CacheEntryEvent<? extends QueryTestKey,
-                        ? extends QueryTestValue>> events) throws CacheEntryListenerException {
-                        for (CacheEntryEvent<? extends QueryTestKey, ? extends QueryTestValue> e : events)
-                            evts.add(e);
-                    }
+                ((ContinuousQuery<QueryTestKey, QueryTestValue>)qry).setLocalListener(
+                    new CacheEntryUpdatedListener<QueryTestKey, QueryTestValue>() {
+                        @Override public void onUpdated(Iterable<CacheEntryEvent<? extends QueryTestKey,
+                            ? extends QueryTestValue>> events) throws CacheEntryListenerException {
+                            for (CacheEntryEvent<? extends QueryTestKey, ? extends QueryTestValue> e : events)
+                                evts.add(e);
+                        }
                 });
             }
             else if (qry instanceof ContinuousQueryWithTransformer)
@@ -717,12 +718,13 @@ public class CacheContinuousQueryRandomOperationsTest extends GridCommonAbstract
                 qry.setRemoteFilterFactory(noOpFilterFactory());
 
             if (qry instanceof ContinuousQuery) {
-                ((ContinuousQuery<QueryTestKey, QueryTestValue>)qry).setLocalListener(new CacheEntryUpdatedListener<QueryTestKey, QueryTestValue>() {
-                    @Override public void onUpdated(Iterable<CacheEntryEvent<? extends QueryTestKey,
-                        ? extends QueryTestValue>> events) throws CacheEntryListenerException {
-                        for (CacheEntryEvent<? extends QueryTestKey, ? extends QueryTestValue> e : events)
-                            evts.add(e);
-                    }
+                ((ContinuousQuery<QueryTestKey, QueryTestValue>)qry).setLocalListener(
+                    new CacheEntryUpdatedListener<QueryTestKey, QueryTestValue>() {
+                        @Override public void onUpdated(Iterable<CacheEntryEvent<? extends QueryTestKey,
+                            ? extends QueryTestValue>> events) throws CacheEntryListenerException {
+                            for (CacheEntryEvent<? extends QueryTestKey, ? extends QueryTestValue> e : events)
+                                evts.add(e);
+                        }
                 });
             }
             else if (qry instanceof ContinuousQueryWithTransformer)
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousWithTransformerFailoverTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousWithTransformerFailoverTest.java
index 71686f3..8445215 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousWithTransformerFailoverTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousWithTransformerFailoverTest.java
@@ -162,13 +162,14 @@ public class CacheContinuousWithTransformerFailoverTest extends GridCommonAbstra
                 }
             });
 
-            qry.setRemoteTransformerFactory(FactoryBuilder.factoryOf(new IgniteClosure<CacheEntryEvent<? extends Integer, ? extends Integer>, Integer>() {
-                @Override public Integer apply(CacheEntryEvent<? extends Integer, ? extends Integer> evt) {
-                    latch.countDown();
+            qry.setRemoteTransformerFactory(FactoryBuilder.factoryOf(
+                new IgniteClosure<CacheEntryEvent<? extends Integer, ? extends Integer>, Integer>() {
+                    @Override public Integer apply(CacheEntryEvent<? extends Integer, ? extends Integer> evt) {
+                        latch.countDown();
 
-                    throw new RuntimeException("Test error.");
-                }
-            }));
+                        throw new RuntimeException("Test error.");
+                    }
+                }));
 
             qry.setRemoteFilterFactory(FactoryBuilder.factoryOf(new CacheEntryEventSerializableFilter<Integer, Integer>() {
                 @Override public boolean evaluate(CacheEntryEvent<? extends Integer, ? extends Integer> evt) {
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/store/GridCacheWriteBehindStoreSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/store/GridCacheWriteBehindStoreSelfTest.java
index be4d6f7..5a00327 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/store/GridCacheWriteBehindStoreSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/store/GridCacheWriteBehindStoreSelfTest.java
@@ -312,7 +312,10 @@ public class GridCacheWriteBehindStoreSelfTest extends GridCacheWriteBehindStore
                 assertTrue("Too many puts were made to the underlying store", delegatePutCnt < actualPutCnt.get() / 10);
             }
             else {
-                assertTrue("Too few puts cnt=" + actualPutCnt.get() + " << storePutCnt=" + delegatePutCnt, delegatePutCnt > actualPutCnt.get() / 2);
+                assertTrue(
+                    "Too few puts cnt=" + actualPutCnt.get() + " << storePutCnt=" + delegatePutCnt,
+                    delegatePutCnt > actualPutCnt.get() / 2
+                );
             }
         }
         finally {
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/AbstractTransactionIntergrityTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/AbstractTransactionIntergrityTest.java
index b375eb6..99fc774 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/AbstractTransactionIntergrityTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/AbstractTransactionIntergrityTest.java
@@ -256,7 +256,8 @@ public class AbstractTransactionIntergrityTest extends GridCommonAbstractTest {
     }
 
     /**
-     * Calculates total amount of coins for every thread for every node and checks that coins difference is zero (transaction integrity is saved).
+     * Calculates total amount of coins for every thread for every node and checks that coins difference is zero
+     * (transaction integrity is saved).
      */
     private void consistencyCheck(int[] initAmount) {
         for (Ignite node : G.allGrids()) {
@@ -273,7 +274,10 @@ public class AbstractTransactionIntergrityTest extends GridCommonAbstractTest {
                     for (int i = 0; i < accountsCount(); i++) {
                         AccountState state = cache.get(i);
 
-                        Assert.assertNotNull("Account state has lost [node=" + node.name() + ", cache=" + cacheName + ", accNo=" + i + "]", state);
+                        Assert.assertNotNull(
+                            "Account state has lost [node=" + node.name() + ", cache=" + cacheName + ", accNo=" + i + "]",
+                            state
+                        );
 
                         totalCoins.addAll(state.coins);
 
@@ -299,7 +303,8 @@ public class AbstractTransactionIntergrityTest extends GridCommonAbstractTest {
 
                     log.error("Transaction integrity failed for [node=" + node.name() + ", cache=" + cacheName + "]");
 
-                    log.error(String.format("Total amount of coins before and after transfers are not same. Lost coins: %s. Duplicate coins: %s.",
+                    log.error(
+                        String.format("Total amount of coins before and after transfers are not same. Lost coins: %s. Duplicate coins: %s.",
                         Objects.toString(lostCoins),
                         Objects.toString(duplicateCoins)));
 
@@ -441,7 +446,13 @@ public class AbstractTransactionIntergrityTest extends GridCommonAbstractTest {
          * @param after2 After 2.
          * @param transferredCoins Transferred coins.
          */
-        public TxState(AccountState before1, AccountState before2, AccountState after1, AccountState after2, Set<Integer> transferredCoins) {
+        public TxState(
+            AccountState before1,
+            AccountState before2,
+            AccountState after1,
+            AccountState after2,
+            Set<Integer> transferredCoins
+        ) {
             this.before1 = before1;
             this.before2 = before2;
             this.after1 = after1;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxCrossCacheMapOnInvalidTopologyTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxCrossCacheMapOnInvalidTopologyTest.java
index 1d94ed1..08baae2 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxCrossCacheMapOnInvalidTopologyTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxCrossCacheMapOnInvalidTopologyTest.java
@@ -142,7 +142,10 @@ public class TxCrossCacheMapOnInvalidTopologyTest extends GridCommonAbstractTest
      * @param concurrency Concurrency.
      * @param isolation Isolation.
      */
-    private void doTestCrossCacheTxMapOnInvalidTopology(TransactionConcurrency concurrency, TransactionIsolation isolation) throws Exception {
+    private void doTestCrossCacheTxMapOnInvalidTopology(
+        TransactionConcurrency concurrency,
+        TransactionIsolation isolation
+    ) throws Exception {
         try {
             IgniteEx crd = startGrid(0);
             IgniteEx g1 = startGrid(1);
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxDeadlockCauseTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxDeadlockCauseTest.java
index 9f9e169..2cae055 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxDeadlockCauseTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxDeadlockCauseTest.java
@@ -154,10 +154,17 @@ public class TxDeadlockCauseTest extends GridCommonAbstractTest {
      * @param timeout Timeout.
      * @param isolation TransactionIsolation.
      * @param oneOp Determines whether {@link IgniteCache#getAndPut(java.lang.Object, java.lang.Object)}
-     *              instead of {@link IgniteCache#get(java.lang.Object)} and {@link IgniteCache#put(java.lang.Object, java.lang.Object)} operations sequence.
+     *              instead of {@link IgniteCache#get(java.lang.Object)} and {@link IgniteCache#put(java.lang.Object, java.lang.Object)}
+     *              operations sequence.
      * @throws Exception If failed.
      */
-    private void checkCauseObject(int nodes, final int keysCnt, final long timeout, final TransactionIsolation isolation, final boolean oneOp) throws Exception {
+    private void checkCauseObject(
+        int nodes,
+        final int keysCnt,
+        final long timeout,
+        final TransactionIsolation isolation,
+        final boolean oneOp
+    ) throws Exception {
         final Ignite ignite = grid(new Random().nextInt(nodes));
 
         final IgniteCache<Integer, Account> cache = ignite.cache(DEFAULT_CACHE_NAME);
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxDeadlockOnEntryToStringTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxDeadlockOnEntryToStringTest.java
index a402ec3..1f73651 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxDeadlockOnEntryToStringTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxDeadlockOnEntryToStringTest.java
@@ -101,7 +101,10 @@ public class TxDeadlockOnEntryToStringTest extends GridCommonAbstractTest {
 
             pool.forceCloseConnection(incomingNode.localNode().id());
 
-            nearNode.configuration().getCommunicationSpi().sendMessage(incomingNode.localNode(), UUIDCollectionMessage.of(UUID.randomUUID()));
+            nearNode.configuration().getCommunicationSpi().sendMessage(
+                incomingNode.localNode(),
+                UUIDCollectionMessage.of(UUID.randomUUID())
+            );
 
             // Check
             assertTrue(GridTestUtils.waitForCondition(() -> entryPrinted.getCount() == 0, 5_000));
@@ -182,7 +185,24 @@ public class TxDeadlockOnEntryToStringTest extends GridCommonAbstractTest {
         if (instance instanceof InboundConnectionHandler) {
             InboundConnectionHandler hnd = (InboundConnectionHandler)instance;
 
-            return (T)(new InboundConnectionHandler(null, null, null, null, null, null, null, null, null, null, null, null, null, false, null, null) {
+            return (T)(new InboundConnectionHandler(
+                null,
+                null,
+                null,
+                null,
+                null,
+                null,
+                null,
+                null,
+                null,
+                null,
+                null,
+                null,
+                null,
+                false,
+                null,
+                null
+            ) {
                 @Override public void setNioSrvWrapper(GridNioServerWrapper nioSrvWrapper) {
                     hnd.setNioSrvWrapper(nioSrvWrapper);
                 }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxPartitionCounterStateOnePrimaryTwoBackupsTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxPartitionCounterStateOnePrimaryTwoBackupsTest.java
index e3cfdca..1ce5ef6 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxPartitionCounterStateOnePrimaryTwoBackupsTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxPartitionCounterStateOnePrimaryTwoBackupsTest.java
@@ -493,7 +493,8 @@ public class TxPartitionCounterStateOnePrimaryTwoBackupsTest extends TxPartition
                                 assertEquals(SIZES[BACKUP_COMMIT_ORDER[0]], upd[1]);
 
                                 runAsync(() -> {
-                                    stopGrid(skipCheckpointOnNodeStop, backup.name()); // Will stop backup node before all commits are applied.
+                                    // Will stop backup node before all commits are applied.
+                                    stopGrid(skipCheckpointOnNodeStop, backup.name());
                                 });
 
                                 return true;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxPartitionCounterStateTwoPrimaryTwoBackupsTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxPartitionCounterStateTwoPrimaryTwoBackupsTest.java
index e93079f..78038b6 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxPartitionCounterStateTwoPrimaryTwoBackupsTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/TxPartitionCounterStateTwoPrimaryTwoBackupsTest.java
@@ -215,7 +215,10 @@ public class TxPartitionCounterStateTwoPrimaryTwoBackupsTest extends TxPartition
         assertEqualsCollections(expKeys, keys);
 
         // Expect only one committed tx.
-        assertEquals(PRELOAD_KEYS_CNT + SIZES[finishedTxIdx] + 1 /** Key for part2. */, grid(CLIENT_GRID_NAME).cache(DEFAULT_CACHE_NAME).size());
+        assertEquals(
+            PRELOAD_KEYS_CNT + SIZES[finishedTxIdx] + 1 /** Key for part2. */,
+            grid(CLIENT_GRID_NAME).cache(DEFAULT_CACHE_NAME).size()
+        );
 
         // Expect consistent partitions.
         assertPartitionsSame(idleVerify(grid(CLIENT_GRID_NAME), DEFAULT_CACHE_NAME));
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/warmup/LoadAllWarmUpStrategySelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/warmup/LoadAllWarmUpStrategySelfTest.java
index 9a318b5..5495037 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/warmup/LoadAllWarmUpStrategySelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/warmup/LoadAllWarmUpStrategySelfTest.java
@@ -186,7 +186,8 @@ public class LoadAllWarmUpStrategySelfTest extends GridCommonAbstractTest {
 
         dr_0 = n.context().cache().context().database().dataRegion("dr_0");
 
-        long warmUpPageCnt = loadDataInfoMap.get("dr_0").values().stream().flatMap(Collection::stream).mapToLong(LoadPartition::pages).sum();
+        long warmUpPageCnt =
+            loadDataInfoMap.get("dr_0").values().stream().flatMap(Collection::stream).mapToLong(LoadPartition::pages).sum();
         long maxLoadPages = minMemSize / dr_0.pageMemory().systemPageSize();
         long minLoadPages = maxLoadPages - 100;
         long loadPages = dr_0.pageMemory().loadedPages();
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/database/IgniteDbMemoryLeakAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/database/IgniteDbMemoryLeakAbstractTest.java
index 56f3017..e8a0176 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/database/IgniteDbMemoryLeakAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/database/IgniteDbMemoryLeakAbstractTest.java
@@ -254,7 +254,10 @@ public abstract class IgniteDbMemoryLeakAbstractTest extends IgniteDbAbstractTes
 
         long pagesAllowed = pagesMax();
 
-        assertTrue("Allocated pages count is more than expected [allowed=" + pagesAllowed + ", actual=" + pagesActual + "]", pagesActual < pagesAllowed);
+        assertTrue(
+            "Allocated pages count is more than expected [allowed=" + pagesAllowed + ", actual=" + pagesActual + "]",
+            pagesActual < pagesAllowed
+        );
 
         loadedPages = pagesActual;
     }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/failure/FailureProcessorLoggingTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/failure/FailureProcessorLoggingTest.java
index 2638545..0322421 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/failure/FailureProcessorLoggingTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/failure/FailureProcessorLoggingTest.java
@@ -100,7 +100,9 @@ public class FailureProcessorLoggingTest extends GridCommonAbstractTest {
 
         testLog.expectedWarnMessage(IGNORED_FAILURE_LOG_MSG);
 
-        ignite.context().failure().process(new FailureContext(FailureType.SYSTEM_CRITICAL_OPERATION_TIMEOUT, new Throwable("Failure context error")));
+        ignite.context().failure().process(
+            new FailureContext(FailureType.SYSTEM_CRITICAL_OPERATION_TIMEOUT, new Throwable("Failure context error"))
+        );
 
         assertTrue(testLog.warnFlag().get());
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/service/GridServiceDeploymentCompoundFutureSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/service/GridServiceDeploymentCompoundFutureSelfTest.java
index 231f556..46e55dd 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/service/GridServiceDeploymentCompoundFutureSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/service/GridServiceDeploymentCompoundFutureSelfTest.java
@@ -59,7 +59,8 @@ public class GridServiceDeploymentCompoundFutureSelfTest extends GridCommonAbstr
         List<GridFutureAdapter<Object>> futs = new ArrayList<>(completingFutsNum);
 
         for (int i = 0; i < completingFutsNum; i++) {
-            GridServiceDeploymentFuture<IgniteUuid> fut = new GridServiceDeploymentFuture<>(config(String.valueOf(i)), IgniteUuid.randomUuid());
+            GridServiceDeploymentFuture<IgniteUuid> fut =
+                new GridServiceDeploymentFuture<>(config(String.valueOf(i)), IgniteUuid.randomUuid());
 
             futs.add(fut);
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/service/ServiceDeploymentProcessIdSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/service/ServiceDeploymentProcessIdSelfTest.java
index 5ed1f63..c6ed874 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/service/ServiceDeploymentProcessIdSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/service/ServiceDeploymentProcessIdSelfTest.java
@@ -91,8 +91,10 @@ public class ServiceDeploymentProcessIdSelfTest {
         customEvt.eventNode(node);
 
         return Arrays.asList(new Object[][] {
-            {customEvt.getClass().getSimpleName(), new IgniteBiTuple<>(customEvt, new AffinityTopologyVersion(ThreadLocalRandom.current().nextLong()))},
-            {evt.getClass().getSimpleName(), new IgniteBiTuple<>(evt, new AffinityTopologyVersion(ThreadLocalRandom.current().nextLong()))}});
+            {customEvt.getClass().getSimpleName(),
+                new IgniteBiTuple<>(customEvt, new AffinityTopologyVersion(ThreadLocalRandom.current().nextLong()))},
+            {evt.getClass().getSimpleName(),
+                new IgniteBiTuple<>(evt, new AffinityTopologyVersion(ThreadLocalRandom.current().nextLong()))}});
     }
 
     /** */
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/sql/SqlParserCreateIndexSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/sql/SqlParserCreateIndexSelfTest.java
index 8d1840a..bed4f1d 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/sql/SqlParserCreateIndexSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/sql/SqlParserCreateIndexSelfTest.java
@@ -142,9 +142,18 @@ public class SqlParserCreateIndexSelfTest extends SqlParserAbstractSelfTest {
         parseValidate(null, "CREATE INDEX idx ON tbl(a DESC) PARALLEL  3", null, "TBL", "IDX", getProps(3, null), "A", true);
         parseValidate(null, "CREATE INDEX idx ON tbl(a DESC)   PARALLEL  7", null, "TBL", "IDX", getProps(7, null), "A", true);
         parseValidate(null, "CREATE INDEX idx ON tbl(a DESC)   PARALLEL  0", null, "TBL", "IDX", getProps(0, null), "A", true);
-        assertParseError(null, "CREATE INDEX idx ON tbl(a DESC) PARALLEL ", "Failed to parse SQL statement \"CREATE INDEX idx ON tbl(a DESC) PARALLEL [*]\"");
+        assertParseError(
+            null,
+            "CREATE INDEX idx ON tbl(a DESC) PARALLEL ",
+            "Failed to parse SQL statement \"CREATE INDEX idx ON tbl(a DESC) PARALLEL [*]\""
+        );
         assertParseError(null, "CREATE INDEX idx ON tbl(a DESC) PARALLEL abc", "Unexpected token: \"ABC\"");
-        assertParseError(null, "CREATE INDEX idx ON tbl(a DESC) PARALLEL -2", "Failed to parse SQL statement \"CREATE INDEX idx ON tbl(a DESC) PARALLEL -[*]2\": Illegal PARALLEL value. Should be positive: -2");
+        assertParseError(
+            null,
+            "CREATE INDEX idx ON tbl(a DESC) PARALLEL -2",
+            "Failed to parse SQL statement " +
+                "\"CREATE INDEX idx ON tbl(a DESC) PARALLEL -[*]2\": Illegal PARALLEL value. Should be positive: -2"
+        );
 
         // INLINE_SIZE option
         assertParseError(null, "CREATE INDEX ON tbl(a) INLINE_SIZE",
@@ -162,7 +171,11 @@ public class SqlParserCreateIndexSelfTest extends SqlParserAbstractSelfTest {
         assertParseError(null, "CREATE INDEX ON tbl(a) INLINE_SIZE " + Integer.MIN_VALUE,
             "Illegal INLINE_SIZE value. Should be positive: " + Integer.MIN_VALUE);
 
-        assertParseError(null, "CREATE INDEX ON tbl(a) INLINE_SIZE -1", "Failed to parse SQL statement \"CREATE INDEX ON tbl(a) INLINE_SIZE -[*]1\": Illegal INLINE_SIZE value. Should be positive: -1");
+        assertParseError(
+            null,
+            "CREATE INDEX ON tbl(a) INLINE_SIZE -1",
+            "Failed to parse SQL statement \"CREATE INDEX ON tbl(a) INLINE_SIZE -[*]1\": Illegal INLINE_SIZE value. Should be positive: -1"
+        );
 
         parseValidate(null, "CREATE INDEX idx ON schema.tbl(a) INLINE_SIZE 0", "SCHEMA", "TBL", "IDX", getProps(null, 0), "A", false);
         parseValidate(null, "CREATE INDEX idx ON schema.tbl(a) INLINE_SIZE 1", "SCHEMA", "TBL", "IDX", getProps(null, 1), "A", false);
@@ -170,13 +183,48 @@ public class SqlParserCreateIndexSelfTest extends SqlParserAbstractSelfTest {
             "SCHEMA", "TBL", "IDX", getProps(null, Integer.MAX_VALUE), "A", false);
 
         // Both parallel and inline size
-        parseValidate(null, "CREATE INDEX idx ON schema.tbl(a) INLINE_SIZE 5 PARALLEL 7", "SCHEMA", "TBL", "IDX", getProps(7, 5), "A", false);
-        parseValidate(null, "CREATE INDEX idx ON schema.tbl(a) PARALLEL 3 INLINE_SIZE 9 ", "SCHEMA", "TBL", "IDX", getProps(3, 9), "A", false);
-
-        assertParseError(null, "CREATE INDEX idx ON schema.tbl(a) PARALLEL 3 INLINE_SIZE 9 PARALLEL 2", "Failed to parse SQL statement \"CREATE INDEX idx ON schema.tbl(a) PARALLEL 3 INLINE_SIZE [*]9 PARALLEL 2\": Only one PARALLEL clause may be specified.");
-        assertParseError(null, "CREATE INDEX idx ON schema.tbl(a) PARALLEL 3 INLINE_SIZE 9 abc ", "Failed to parse SQL statement \"CREATE INDEX idx ON schema.tbl(a) PARALLEL 3 INLINE_SIZE 9 [*]abc \": Unexpected token: \"ABC\"");
-        assertParseError(null, "CREATE INDEX idx ON schema.tbl(a) PARALLEL  INLINE_SIZE 9 abc ", "Failed to parse SQL statement \"CREATE INDEX idx ON schema.tbl(a) PARALLEL  [*]INLINE_SIZE 9 abc \": Unexpected token: \"INLINE_SIZE\" (expected: \"[integer]\")");
-        assertParseError(null, "CREATE INDEX idx ON schema.tbl(a) PARALLEL 3 INLINE_SIZE abc ", "Failed to parse SQL statement \"CREATE INDEX idx ON schema.tbl(a) PARALLEL 3 INLINE_SIZE [*]abc \": Unexpected token: \"ABC\" (expected: \"[integer]\")");
+        parseValidate(
+            null,
+            "CREATE INDEX idx ON schema.tbl(a) INLINE_SIZE 5 PARALLEL 7",
+            "SCHEMA",
+            "TBL",
+            "IDX",
+            getProps(7, 5),
+            "A",
+            false
+        );
+        parseValidate(
+            null,
+            "CREATE INDEX idx ON schema.tbl(a) PARALLEL 3 INLINE_SIZE 9 ",
+            "SCHEMA",
+            "TBL",
+            "IDX",
+            getProps(3, 9),
+            "A",
+            false
+        );
+
+        assertParseError(
+            null,
+            "CREATE INDEX idx ON schema.tbl(a) PARALLEL 3 INLINE_SIZE 9 PARALLEL 2",
+            "Failed to parse SQL statement " +
+                "\"CREATE INDEX idx ON schema.tbl(a) PARALLEL 3 INLINE_SIZE [*]9 PARALLEL 2\": Only one PARALLEL clause may be specified."
+        );
+        assertParseError(
+            null, "CREATE INDEX idx ON schema.tbl(a) PARALLEL 3 INLINE_SIZE 9 abc ",
+            "Failed to parse SQL statement " +
+                "\"CREATE INDEX idx ON schema.tbl(a) PARALLEL 3 INLINE_SIZE 9 [*]abc \": Unexpected token: \"ABC\""
+        );
+        assertParseError(
+            null, "CREATE INDEX idx ON schema.tbl(a) PARALLEL  INLINE_SIZE 9 abc ",
+            "Failed to parse SQL statement \"CREATE INDEX idx ON schema.tbl(a) PARALLEL  [*]INLINE_SIZE 9 abc \": " +
+                "Unexpected token: \"INLINE_SIZE\" (expected: \"[integer]\")"
+        );
+        assertParseError(
+            null, "CREATE INDEX idx ON schema.tbl(a) PARALLEL 3 INLINE_SIZE abc ",
+            "Failed to parse SQL statement " +
+                "\"CREATE INDEX idx ON schema.tbl(a) PARALLEL 3 INLINE_SIZE [*]abc \": Unexpected token: \"ABC\" (expected: \"[integer]\")"
+        );
 
     }
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/sql/SqlParserKillQuerySelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/sql/SqlParserKillQuerySelfTest.java
index 99c45b3..9a179ec 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/sql/SqlParserKillQuerySelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/sql/SqlParserKillQuerySelfTest.java
@@ -91,14 +91,16 @@ public class SqlParserKillQuerySelfTest extends SqlParserAbstractSelfTest {
      * @return Expected exception message.
      */
     private String expectedExceptionMessageNoAsyncAndQueryId() {
-        return "Expected ASYNC token or global query id. Global query id should have format '{node_id}_{query_id}', e.g. '6fa749ee-7cf8-4635-be10-36a1c75267a7_54321'";
+        return "Expected ASYNC token or global query id. " +
+            "Global query id should have format '{node_id}_{query_id}', e.g. '6fa749ee-7cf8-4635-be10-36a1c75267a7_54321'";
     }
 
     /**
      * @return Expected exception message.
      */
     private String expectedExceptionMessageNoQueryId() {
-        return "Expected global query id. Global query id should have format '{node_id}_{query_id}', e.g. '6fa749ee-7cf8-4635-be10-36a1c75267a7_54321'";
+        return "Expected global query id. " +
+            "Global query id should have format '{node_id}_{query_id}', e.g. '6fa749ee-7cf8-4635-be10-36a1c75267a7_54321'";
     }
 
     /**
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/util/IgniteUtilsWorkDirectoryTest.java b/modules/core/src/test/java/org/apache/ignite/internal/util/IgniteUtilsWorkDirectoryTest.java
index 03092b4..6fb9872 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/util/IgniteUtilsWorkDirectoryTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/util/IgniteUtilsWorkDirectoryTest.java
@@ -122,7 +122,8 @@ public class IgniteUtilsWorkDirectoryTest {
      * @param userWorkDirFlag need or not to pass userWorkDir to {@link IgniteUtils#workDirectory(java.lang.String, java.lang.String)}
      * @param userIgniteHomeFlag need or not to pass userIgniteHome to {@link IgniteUtils#workDirectory(java.lang.String, java.lang.String)}
      * @param userDirPropFlag need to set or clear "user.dir" system property
-     * @param expWorkDir expected Ignite work directory that will be returned by {@link IgniteUtils#workDirectory(java.lang.String, java.lang.String)}
+     * @param expWorkDir expected Ignite work directory that will be returned by
+     * {@link IgniteUtils#workDirectory(java.lang.String, java.lang.String)}
      */
     private void executeGenericTest(boolean userWorkDirFlag, boolean userIgniteHomeFlag,
         boolean userDirPropFlag, String expWorkDir) {
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/util/nio/impl/GridNioFilterChainSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/util/nio/impl/GridNioFilterChainSelfTest.java
index f91e670..42a3bed 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/util/nio/impl/GridNioFilterChainSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/util/nio/impl/GridNioFilterChainSelfTest.java
@@ -114,7 +114,12 @@ public class GridNioFilterChainSelfTest extends GridCommonAbstractTest {
                 proceedExceptionCaught(ses, ex);
             }
 
-            @Override public GridNioFuture<?> onSessionWrite(GridNioSession ses, Object msg, boolean fut, IgniteInClosure<IgniteException> ackC) {
+            @Override public GridNioFuture<?> onSessionWrite(
+                GridNioSession ses,
+                Object msg,
+                boolean fut,
+                IgniteInClosure<IgniteException> ackC
+            ) {
                 sndEvt.compareAndSet(null, ses.<String>meta(MESSAGE_WRITE_META_NAME));
 
                 sndMsgObj.compareAndSet(null, msg);
@@ -210,7 +215,12 @@ public class GridNioFilterChainSelfTest extends GridCommonAbstractTest {
         }
 
         /** {@inheritDoc} */
-        @Override public GridNioFuture<?> onSessionWrite(GridNioSession ses, Object msg, boolean fut, IgniteInClosure<IgniteException> ackC) throws IgniteCheckedException {
+        @Override public GridNioFuture<?> onSessionWrite(
+            GridNioSession ses,
+            Object msg,
+            boolean fut,
+            IgniteInClosure<IgniteException> ackC
+        ) throws IgniteCheckedException {
             chainMeta(ses, MESSAGE_WRITE_META_NAME);
 
             return proceedSessionWrite(ses, msg, fut, ackC);
diff --git a/modules/core/src/test/java/org/apache/ignite/loadtests/colocation/GridTestCacheStore.java b/modules/core/src/test/java/org/apache/ignite/loadtests/colocation/GridTestCacheStore.java
index a3c02f1..51e8067 100644
--- a/modules/core/src/test/java/org/apache/ignite/loadtests/colocation/GridTestCacheStore.java
+++ b/modules/core/src/test/java/org/apache/ignite/loadtests/colocation/GridTestCacheStore.java
@@ -85,7 +85,8 @@ public class GridTestCacheStore extends CacheStoreAdapter<GridTestKey, Long> {
                             end += mod;
 
                         for (long i = start; i < end; i++) {
-                            if (ignite.affinity(cache.getName()).mapKeyToNode(GridTestKey.affinityKey(i)).isLocal()) { // Only add if key is local.
+                            // Only add if key is local.
+                            if (ignite.affinity(cache.getName()).mapKeyToNode(GridTestKey.affinityKey(i)).isLocal()) {
                                 clo.apply(new GridTestKey(i), i);
 
                                 adder.increment();
diff --git a/modules/core/src/test/java/org/apache/ignite/loadtests/job/GridJobLoadTest.java b/modules/core/src/test/java/org/apache/ignite/loadtests/job/GridJobLoadTest.java
index 8d7bbff..3231200 100644
--- a/modules/core/src/test/java/org/apache/ignite/loadtests/job/GridJobLoadTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/loadtests/job/GridJobLoadTest.java
@@ -183,7 +183,8 @@ public class GridJobLoadTest implements Runnable {
      *
      * @param igniteInstanceName name of new node.
      * @param springCfg file with spring configuration to use for this node.
-     * @return a grid instance local to new node {@link org.apache.ignite.Ignition#start(org.apache.ignite.configuration.IgniteConfiguration)}.
+     * @return a grid instance local to new node
+     * {@link org.apache.ignite.Ignition#start(org.apache.ignite.configuration.IgniteConfiguration)}.
      * @throws Exception if node run failed.
      */
     protected Ignite startNode(String igniteInstanceName, File springCfg) throws Exception {
diff --git a/modules/core/src/test/java/org/apache/ignite/loadtests/lang/GridConcurrentLinkedHashMapBenchmark.java b/modules/core/src/test/java/org/apache/ignite/loadtests/lang/GridConcurrentLinkedHashMapBenchmark.java
index 3d59a12..f026cd9 100644
--- a/modules/core/src/test/java/org/apache/ignite/loadtests/lang/GridConcurrentLinkedHashMapBenchmark.java
+++ b/modules/core/src/test/java/org/apache/ignite/loadtests/lang/GridConcurrentLinkedHashMapBenchmark.java
@@ -152,8 +152,15 @@ public class GridConcurrentLinkedHashMapBenchmark {
         for (TestThread th : threads)
             iters += th.iterations();
 
-        System.out.printf("%8s, %8d, %12d, %12d, %12d, %8.3f, %8.2f\n",
-            readOp.toString(), threadCnt, 1000 * iters / time, 1000 * iters / (time * threadCnt), iters, time / (double)1000, writeProportion);
+        System.out.printf(
+            "%8s, %8d, %12d, %12d, %12d, %8.3f, %8.2f\n",
+            readOp.toString(),
+            threadCnt,
+            1000 * iters / time,
+            1000 * iters / (time * threadCnt),
+            iters, time / (double)1000,
+            writeProportion
+        );
     }
 
     /**
diff --git a/modules/core/src/test/java/org/apache/ignite/marshaller/MarshallerContextTestImpl.java b/modules/core/src/test/java/org/apache/ignite/marshaller/MarshallerContextTestImpl.java
index 8d98b0d..ae023eb 100644
--- a/modules/core/src/test/java/org/apache/ignite/marshaller/MarshallerContextTestImpl.java
+++ b/modules/core/src/test/java/org/apache/ignite/marshaller/MarshallerContextTestImpl.java
@@ -72,7 +72,12 @@ public class MarshallerContextTestImpl extends MarshallerContextImpl {
     }
 
     /** {@inheritDoc} */
-    @Override public boolean registerClassName(byte platformId, int typeId, String clsName, boolean failIfUnregistered) throws IgniteCheckedException {
+    @Override public boolean registerClassName(
+        byte platformId,
+        int typeId,
+        String clsName,
+        boolean failIfUnregistered
+    ) throws IgniteCheckedException {
         if (excluded != null && excluded.contains(clsName))
             return false;
 
diff --git a/modules/core/src/test/java/org/apache/ignite/messaging/GridMessagingSelfTest.java b/modules/core/src/test/java/org/apache/ignite/messaging/GridMessagingSelfTest.java
index 29dedeb..96f5ddd 100644
--- a/modules/core/src/test/java/org/apache/ignite/messaging/GridMessagingSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/messaging/GridMessagingSelfTest.java
@@ -661,7 +661,9 @@ public class GridMessagingSelfTest extends GridCommonAbstractTest implements Ser
 
         UUID id1 = ignite2.message().remoteListen(topic1, new P2<UUID, Object>() {
             @Override public boolean apply(UUID nodeId, Object msg) {
-                System.out.println(Thread.currentThread().getName() + " Listener1 received new message [msg=" + msg + ", senderNodeId=" + nodeId + ']');
+                System.out.println(
+                    Thread.currentThread().getName() + " Listener1 received new message [msg=" + msg + ", senderNodeId=" + nodeId + ']'
+                );
 
                 msgCnt1.incrementAndGet();
 
@@ -671,7 +673,9 @@ public class GridMessagingSelfTest extends GridCommonAbstractTest implements Ser
 
         UUID id2 = ignite2.message().remoteListen(topic2, new P2<UUID, Object>() {
             @Override public boolean apply(UUID nodeId, Object msg) {
-                System.out.println(Thread.currentThread().getName() + " Listener2 received new message [msg=" + msg + ", senderNodeId=" + nodeId + ']');
+                System.out.println(
+                    Thread.currentThread().getName() + " Listener2 received new message [msg=" + msg + ", senderNodeId=" + nodeId + ']'
+                );
 
                 msgCnt2.incrementAndGet();
 
@@ -681,7 +685,9 @@ public class GridMessagingSelfTest extends GridCommonAbstractTest implements Ser
 
         UUID id3 = ignite2.message().remoteListen(topic3, new P2<UUID, Object>() {
             @Override public boolean apply(UUID nodeId, Object msg) {
-                System.out.println(Thread.currentThread().getName() + " Listener3 received new message [msg=" + msg + ", senderNodeId=" + nodeId + ']');
+                System.out.println(
+                    Thread.currentThread().getName() + " Listener3 received new message [msg=" + msg + ", senderNodeId=" + nodeId + ']'
+                );
 
                 msgCnt3.incrementAndGet();
 
diff --git a/modules/core/src/test/java/org/apache/ignite/p2p/GridP2PContinuousDeploymentClientDisconnectTest.java b/modules/core/src/test/java/org/apache/ignite/p2p/GridP2PContinuousDeploymentClientDisconnectTest.java
index 75594ab..84d799f0 100644
--- a/modules/core/src/test/java/org/apache/ignite/p2p/GridP2PContinuousDeploymentClientDisconnectTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/p2p/GridP2PContinuousDeploymentClientDisconnectTest.java
@@ -60,16 +60,19 @@ public class GridP2PContinuousDeploymentClientDisconnectTest extends GridCommonA
     private ListeningTestLogger testLog;
 
     /** The resource name which is used in static initializer block. */
-    private static final String P2P_TEST_OBJ_RSRC_NAME = "org/apache/ignite/tests/p2p/GridP2PTestObjectWithStaticInitializer$GridP2PTestObject.class";
+    private static final String P2P_TEST_OBJ_RSRC_NAME =
+        "org/apache/ignite/tests/p2p/GridP2PTestObjectWithStaticInitializer$GridP2PTestObject.class";
 
     /** */
     private static final String REMOTE_FILTER_CLS_NAME = "org.apache.ignite.tests.p2p.GridP2PSerializableRemoteFilterWithStaticInitializer";
 
     /** */
-    private static final String REMOTE_FILTER_FACTORY_CLS_NAME = "org.apache.ignite.tests.p2p.GridP2PRemoteFilterWithStaticInitializerFactory";
+    private static final String REMOTE_FILTER_FACTORY_CLS_NAME =
+        "org.apache.ignite.tests.p2p.GridP2PRemoteFilterWithStaticInitializerFactory";
 
     /** */
-    private static final String REMOTE_TRANSFORMER_FACTORY_CLS_NAME = "org.apache.ignite.tests.p2p.GridP2PRemoteTransformerWithStaticInitializerFactory";
+    private static final String REMOTE_TRANSFORMER_FACTORY_CLS_NAME =
+        "org.apache.ignite.tests.p2p.GridP2PRemoteTransformerWithStaticInitializerFactory";
 
     /** */
     private static final String EVT_REMOTE_FILTER_CLS_NAME = "org.apache.ignite.tests.p2p.GridP2PEventRemoteFilterWithStaticInitializer";
diff --git a/modules/core/src/test/java/org/apache/ignite/session/GridSessionWaitAttributeSelfTest.java b/modules/core/src/test/java/org/apache/ignite/session/GridSessionWaitAttributeSelfTest.java
index 06e5250..2e3e935 100644
--- a/modules/core/src/test/java/org/apache/ignite/session/GridSessionWaitAttributeSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/session/GridSessionWaitAttributeSelfTest.java
@@ -269,7 +269,10 @@ public class GridSessionWaitAttributeSelfTest extends GridCommonAbstractTest {
                         assert val.equals(obj) :
                             "Failed to wait for attribute [key=" + key + ", val=" + val + ", receivedVal=" + obj + ']';
 
-                        //System.out.println(Thread.currentThread().getName() + ":: Waited for attribute [key=" + key + ", val=" + obj + ", ses=" + ses + ']');
+                        //System.out.println(
+                        //    Thread.currentThread().getName() +
+                        //        ":: Waited for attribute [key=" + key + ", val=" + obj + ", ses=" + ses + ']'
+                        //);
                     }
 
                     break;
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/GridTcpCommunicationSpiLogTest.java b/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/GridTcpCommunicationSpiLogTest.java
index 1642384..bef2d9e 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/GridTcpCommunicationSpiLogTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/GridTcpCommunicationSpiLogTest.java
@@ -198,7 +198,8 @@ public class GridTcpCommunicationSpiLogTest extends GridCommonAbstractTest {
         TcpCommunicationSpi clientSpi = (TcpCommunicationSpi) ((IgniteEx)client).context().config().getCommunicationSpi();
 
         ConcurrentMap<UUID, GridCommunicationClient[]> clients = GridTestUtils.getFieldValue(clientSpi, "clientPool", "clients");
-        ConcurrentMap<?, GridNioRecoveryDescriptor> recoveryDescs = GridTestUtils.getFieldValue(clientSpi, "nioSrvWrapper", "recoveryDescs");
+        ConcurrentMap<?, GridNioRecoveryDescriptor> recoveryDescs =
+            GridTestUtils.getFieldValue(clientSpi, "nioSrvWrapper", "recoveryDescs");
         ConcurrentMap<?, GridNioRecoveryDescriptor> outRecDescs = GridTestUtils.getFieldValue(clientSpi, "nioSrvWrapper", "outRecDescs");
         ConcurrentMap<?, GridNioRecoveryDescriptor> inRecDescs = GridTestUtils.getFieldValue(clientSpi, "nioSrvWrapper", "inRecDescs");
         GridNioServerListener<Message> lsnr = U.field(clientSpi, "srvLsnr");
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/IgniteTcpCommunicationConnectOnInitTest.java b/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/IgniteTcpCommunicationConnectOnInitTest.java
index fc92500..93f6bc5 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/IgniteTcpCommunicationConnectOnInitTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/IgniteTcpCommunicationConnectOnInitTest.java
@@ -181,14 +181,21 @@ public class IgniteTcpCommunicationConnectOnInitTest extends GridCommonAbstractT
      */
     private class TestDiscoverySpi extends TcpDiscoverySpi {
         /** {@inheritDoc} */
-        @Override protected Socket openSocket(InetSocketAddress sockAddr, IgniteSpiOperationTimeoutHelper timeoutHelper) throws IOException, IgniteSpiOperationTimeoutException {
+        @Override protected Socket openSocket(
+            InetSocketAddress sockAddr,
+            IgniteSpiOperationTimeoutHelper timeoutHelper
+        ) throws IOException, IgniteSpiOperationTimeoutException {
             awaitLatch();
 
             return super.openSocket(sockAddr, timeoutHelper);
         }
 
         /** {@inheritDoc} */
-        @Override protected Socket openSocket(Socket sock, InetSocketAddress remAddr, IgniteSpiOperationTimeoutHelper timeoutHelper) throws IOException, IgniteSpiOperationTimeoutException {
+        @Override protected Socket openSocket(
+            Socket sock,
+            InetSocketAddress remAddr,
+            IgniteSpiOperationTimeoutHelper timeoutHelper
+        ) throws IOException, IgniteSpiOperationTimeoutException {
             awaitLatch();
 
             return super.openSocket(sock, remAddr, timeoutHelper);
@@ -202,21 +209,36 @@ public class IgniteTcpCommunicationConnectOnInitTest extends GridCommonAbstractT
         }
 
         /** {@inheritDoc} */
-        @Override protected void writeToSocket(Socket sock, TcpDiscoveryAbstractMessage msg, long timeout) throws IOException, IgniteCheckedException {
+        @Override protected void writeToSocket(
+            Socket sock,
+            TcpDiscoveryAbstractMessage msg,
+            long timeout
+        ) throws IOException, IgniteCheckedException {
             awaitLatch();
 
             super.writeToSocket(sock, msg, timeout);
         }
 
         /** {@inheritDoc} */
-        @Override protected void writeToSocket(ClusterNode node, Socket sock, OutputStream out, TcpDiscoveryAbstractMessage msg, long timeout) throws IOException, IgniteCheckedException {
+        @Override protected void writeToSocket(
+            ClusterNode node,
+            Socket sock,
+            OutputStream out,
+            TcpDiscoveryAbstractMessage msg,
+            long timeout
+        ) throws IOException, IgniteCheckedException {
             awaitLatch();
 
             super.writeToSocket(node, sock, out, msg, timeout);
         }
 
         /** {@inheritDoc} */
-        @Override protected void writeToSocket(Socket sock, OutputStream out, TcpDiscoveryAbstractMessage msg, long timeout) throws IOException, IgniteCheckedException {
+        @Override protected void writeToSocket(
+            Socket sock,
+            OutputStream out,
+            TcpDiscoveryAbstractMessage msg,
+            long timeout
+        ) throws IOException, IgniteCheckedException {
             awaitLatch();
 
             super.writeToSocket(sock, out, msg, timeout);
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationStatisticsTest.java b/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationStatisticsTest.java
index 9a54271..b7ed589 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationStatisticsTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationStatisticsTest.java
@@ -137,7 +137,12 @@ public class TcpCommunicationStatisticsTest extends GridCommonAbstractTest {
             );
 
             // Send custom message from node0 to node1.
-            grid(0).context().io().sendToGridTopic(grid(1).cluster().localNode(), GridTopic.TOPIC_IO_TEST, new GridTestMessage(), GridIoPolicy.PUBLIC_POOL);
+            grid(0).context().io().sendToGridTopic(
+                grid(1).cluster().localNode(),
+                GridTopic.TOPIC_IO_TEST,
+                new GridTestMessage(),
+                GridIoPolicy.PUBLIC_POOL
+            );
 
             latch.await(10, TimeUnit.SECONDS);
 
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/IgniteClientConnectTest.java b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/IgniteClientConnectTest.java
index 14069f7..2315de3 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/IgniteClientConnectTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/IgniteClientConnectTest.java
@@ -211,8 +211,12 @@ public class IgniteClientConnectTest extends GridCommonAbstractTest {
      */
     class TestTcpDiscoverySpi extends TcpDiscoverySpi {
         /** {@inheritDoc} */
-        @Override protected void writeToSocket(Socket sock, OutputStream out, TcpDiscoveryAbstractMessage msg, long timeout) throws IOException,
-                IgniteCheckedException {
+        @Override protected void writeToSocket(
+            Socket sock,
+            OutputStream out,
+            TcpDiscoveryAbstractMessage msg,
+            long timeout
+        ) throws IOException, IgniteCheckedException {
             if (msg instanceof TcpDiscoveryNodeAddFinishedMessage) {
                 if (msg.senderNodeId() != null && clientJustStarted.get())
                     try {
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpClientDiscoverySpiSelfTest.java b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpClientDiscoverySpiSelfTest.java
index 291cc9e..b93ae8b 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpClientDiscoverySpiSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpClientDiscoverySpiSelfTest.java
@@ -1129,15 +1129,17 @@ public class TcpClientDiscoverySpiSelfTest extends GridCommonAbstractTest {
 
         attachListeners(1, 1);
 
-        ((TcpDiscoverySpi)G.ignite("server-1").configuration().getDiscoverySpi()).addSendMessageListener(new IgniteInClosure<TcpDiscoveryAbstractMessage>() {
-            @Override public void apply(TcpDiscoveryAbstractMessage msg) {
-                try {
-                    Thread.sleep(1000000);
-                } catch (InterruptedException ignored) {
-                    Thread.interrupted();
+        ((TcpDiscoverySpi)G.ignite("server-1").configuration().getDiscoverySpi()).addSendMessageListener(
+            new IgniteInClosure<TcpDiscoveryAbstractMessage>() {
+                @Override public void apply(TcpDiscoveryAbstractMessage msg) {
+                    try {
+                        Thread.sleep(1000000);
+                    }
+                    catch (InterruptedException ignored) {
+                        Thread.interrupted();
+                    }
                 }
-            }
-        });
+            });
         failClient(1);
         failServer(1);
 
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryCoordinatorFailureTest.java b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryCoordinatorFailureTest.java
index 89f968c..0b0c68c 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryCoordinatorFailureTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryCoordinatorFailureTest.java
@@ -206,14 +206,21 @@ public class TcpDiscoveryCoordinatorFailureTest extends GridCommonAbstractTest {
         private volatile CountDownLatch stallLatch;
 
         /** {@inheritDoc} */
-        @Override protected Socket openSocket(InetSocketAddress sockAddr, IgniteSpiOperationTimeoutHelper timeoutHelper) throws IOException, IgniteSpiOperationTimeoutException {
+        @Override protected Socket openSocket(
+            InetSocketAddress sockAddr,
+            IgniteSpiOperationTimeoutHelper timeoutHelper
+        ) throws IOException, IgniteSpiOperationTimeoutException {
             checkStall();
 
             return super.openSocket(sockAddr, timeoutHelper);
         }
 
         /** {@inheritDoc} */
-        @Override protected Socket openSocket(Socket sock, InetSocketAddress remAddr, IgniteSpiOperationTimeoutHelper timeoutHelper) throws IOException, IgniteSpiOperationTimeoutException {
+        @Override protected Socket openSocket(
+            Socket sock,
+            InetSocketAddress remAddr,
+            IgniteSpiOperationTimeoutHelper timeoutHelper
+        ) throws IOException, IgniteSpiOperationTimeoutException {
             checkStall();
 
             return super.openSocket(sock, remAddr, timeoutHelper);
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryIpFinderFailureTest.java b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryIpFinderFailureTest.java
index 2f899d5..ead7c1c 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryIpFinderFailureTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryIpFinderFailureTest.java
@@ -378,7 +378,11 @@ public class TcpDiscoveryIpFinderFailureTest extends GridCommonAbstractTest {
     /**
      * Gets node configuration with dynamic IP finder.
      */
-    private IgniteConfiguration getConfigurationDynamicIpFinder(String instanceName, boolean clientMode, TcpDiscoverySpi discoverySpi) throws Exception {
+    private IgniteConfiguration getConfigurationDynamicIpFinder(
+        String instanceName,
+        boolean clientMode,
+        TcpDiscoverySpi discoverySpi
+    ) throws Exception {
         IgniteConfiguration cfg = getConfiguration();
         cfg.setNodeId(null);
         cfg.setLocalHost("127.0.0.1");
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryNodeJoinAndFailureTest.java b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryNodeJoinAndFailureTest.java
index d4aac51..d187dac 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryNodeJoinAndFailureTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryNodeJoinAndFailureTest.java
@@ -103,7 +103,8 @@ public class TcpDiscoveryNodeJoinAndFailureTest extends GridCommonAbstractTest {
      * If whole ring fails but two server nodes both in CONNECTING state remain alive they should not hang
      * indefinitely sending join requests to each other.
      *
-     * @see <a href="https://issues.apache.org/jira/browse/IGNITE-11621">IGNITE-11621</a> with comments provides detailed description of this corner case.
+     * @see <a href="https://issues.apache.org/jira/browse/IGNITE-11621">IGNITE-11621</a>
+     * with comments provides detailed description of this corner case.
      *
      * @throws Exception If failed.
      */
@@ -240,7 +241,10 @@ public class TcpDiscoveryNodeJoinAndFailureTest extends GridCommonAbstractTest {
 
             String errorMsg = cause1.getMessage();
 
-            assertTrue("Expected error message was not found: " + errorMsg, errorMsg.contains("Failed to connect to any address from IP finder"));
+            assertTrue(
+                "Expected error message was not found: " + errorMsg,
+                errorMsg.contains("Failed to connect to any address from IP finder")
+            );
 
             expectedExceptionThrown = true;
         }
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryPendingMessageDeliveryTest.java b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryPendingMessageDeliveryTest.java
index af458fa..93236a2 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryPendingMessageDeliveryTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryPendingMessageDeliveryTest.java
@@ -130,7 +130,8 @@ public class TcpDiscoveryPendingMessageDeliveryTest extends GridCommonAbstractTe
 
         assertTrue("Sent: " + sentEnsuredMsgs + "; received: " + receivedEnsuredMsgs,
             GridTestUtils.waitForCondition(() -> {
-                log.info("Waiting for messages delivery [sentSize=" + sentEnsuredMsgs.size() + ", rcvdSize=" + receivedEnsuredMsgs.size() + ']');
+                log.info("Waiting for messages delivery [sentSize=" + sentEnsuredMsgs.size() +
+                    ", rcvdSize=" + receivedEnsuredMsgs.size() + ']');
 
                 return receivedEnsuredMsgs.equals(sentEnsuredMsgs);
             }, 10000));
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySslParametersTest.java b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySslParametersTest.java
index 63832b3..131a6ed 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySslParametersTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySslParametersTest.java
@@ -255,7 +255,12 @@ public class TcpDiscoverySslParametersTest extends GridCommonAbstractTest {
      * @param msg exception message
      * @throws Exception If failed.
      */
-    private void checkDiscoveryFailure(String[][] cipherSuites, String[][] protocols, Class<? extends Throwable> ex, String msg) throws Exception {
+    private void checkDiscoveryFailure(
+        String[][] cipherSuites,
+        String[][] protocols,
+        Class<? extends Throwable> ex,
+        String msg
+    ) throws Exception {
         this.cipherSuites = cipherSuites != null ? cipherSuites[0] : null;
         this.protocols = protocols != null ? protocols[0] : null;
 
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/vm/TcpDiscoveryVmIpFinderDnsResolveTest.java b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/vm/TcpDiscoveryVmIpFinderDnsResolveTest.java
index 371cdc7..86d5ffa 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/vm/TcpDiscoveryVmIpFinderDnsResolveTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/vm/TcpDiscoveryVmIpFinderDnsResolveTest.java
@@ -291,8 +291,8 @@ public class TcpDiscoveryVmIpFinderDnsResolveTest extends GridCommonAbstractTest
     }
 
     /**
-     * Current test checks that in case if TcpDiscoveryVmIpFinder has MULTI_FQDN (resolved to two ip) name and additional one "registeredAddress"
-     * then both of them can be resolved. There are no ports will be used, only hostname.
+     * Current test checks that in case if TcpDiscoveryVmIpFinder has MULTI_FQDN (resolved to two ip) name
+     * and additional one "registeredAddress" then both of them can be resolved. There are no ports will be used, only hostname.
      *
      * @throws Exception if failed.
      */
@@ -313,8 +313,8 @@ public class TcpDiscoveryVmIpFinderDnsResolveTest extends GridCommonAbstractTest
     }
 
     /**
-     * Current test checks that in case if TcpDiscoveryVmIpFinder has MULTI_FQDN (resolved to two ip) name and additional one "registeredAddress"
-     * then both of them can be resolved. Port will be used.
+     * Current test checks that in case if TcpDiscoveryVmIpFinder has MULTI_FQDN (resolved to two ip) name
+     * and additional one "registeredAddress" then both of them can be resolved. Port will be used.
      *
      * @throws Exception if failed.
      */
@@ -335,8 +335,8 @@ public class TcpDiscoveryVmIpFinderDnsResolveTest extends GridCommonAbstractTest
     }
 
     /**
-     * Current test checks that in case if TcpDiscoveryVmIpFinder has MULTI_FQDN (resolved to two ip) name and additional one "registeredAddress"
-     * then both of them can be resolved. Port range will be used.
+     * Current test checks that in case if TcpDiscoveryVmIpFinder has MULTI_FQDN (resolved to two ip) name
+     * and additional one "registeredAddress" then both of them can be resolved. Port range will be used.
      *
      * @throws Exception if failed.
      */
@@ -528,7 +528,8 @@ public class TcpDiscoveryVmIpFinderDnsResolveTest extends GridCommonAbstractTest
     public interface INameService extends InvocationHandler {
         /** */
         static void install(
-            INameService dns) throws IllegalArgumentException, IllegalAccessException, NoSuchFieldException, SecurityException, ClassNotFoundException {
+            INameService dns
+        ) throws IllegalArgumentException, IllegalAccessException, NoSuchFieldException, SecurityException, ClassNotFoundException {
             final Class<?> inetAddrCls = InetAddress.class;
 
             Object neu;
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/loadbalancing/internal/GridInternalTasksLoadBalancingSelfTest.java b/modules/core/src/test/java/org/apache/ignite/spi/loadbalancing/internal/GridInternalTasksLoadBalancingSelfTest.java
index 325e994..f2b51a5 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/loadbalancing/internal/GridInternalTasksLoadBalancingSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/loadbalancing/internal/GridInternalTasksLoadBalancingSelfTest.java
@@ -113,7 +113,8 @@ public class GridInternalTasksLoadBalancingSelfTest extends GridCommonAbstractTe
             ignite.compute().execute(CustomTestTask.class.getName(), null);
         }
         catch (IgniteException e) {
-            assertTrue(e.getMessage().startsWith("Node can not be null [mappedJob=org.apache.ignite.spi.loadbalancing.internal.GridInternalTasksLoadBalancingSelfTest$CustomTestJob"));
+            assertTrue(e.getMessage().startsWith("Node can not be null " +
+                "[mappedJob=org.apache.ignite.spi.loadbalancing.internal.GridInternalTasksLoadBalancingSelfTest$CustomTestJob"));
         }
     }
 
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/metric/jmx/DummyMBeanServer.java b/modules/core/src/test/java/org/apache/ignite/spi/metric/jmx/DummyMBeanServer.java
index 4d9c467..b50ef8f 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/metric/jmx/DummyMBeanServer.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/metric/jmx/DummyMBeanServer.java
@@ -201,7 +201,12 @@ class DummyMBeanServer implements MBeanServer {
     /**
      * {@inheritDoc}
      */
-    @Override public void removeNotificationListener(ObjectName name, NotificationListener lsnr, NotificationFilter filter, Object handback) {
+    @Override public void removeNotificationListener(
+        ObjectName name,
+        NotificationListener lsnr,
+        NotificationFilter filter,
+        Object handback
+    ) {
 
     }
 
diff --git a/modules/core/src/test/java/org/apache/ignite/startup/servlet/GridServletLoaderTest.java b/modules/core/src/test/java/org/apache/ignite/startup/servlet/GridServletLoaderTest.java
index 58afa10..8de7b94 100644
--- a/modules/core/src/test/java/org/apache/ignite/startup/servlet/GridServletLoaderTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/startup/servlet/GridServletLoaderTest.java
@@ -56,7 +56,8 @@ import org.junit.Test;
  * 4. Change ports in {@code $TOMCAT_HOME/conf/server.xml} to 8006, 8084, 8446.
  *
  * 5. Add in {@code $TOMCAT_HOME/bin/catalina.sh} where script {@code start} argument handled
- * {@code JAVA_OPTS="${JAVA_OPTS} "-Dcom.sun.management.jmxremote.port=1097" "-Dcom.sun.management.jmxremote.ssl=false" "-Dcom.sun.management.jmxremote.authenticate=false" "}
+ * {@code JAVA_OPTS="${JAVA_OPTS} "-Dcom.sun.management.jmxremote.port=1097" "-Dcom.sun.management.jmxremote.ssl=false"
+ * "-Dcom.sun.management.jmxremote.authenticate=false" "}
  */
 @GridCommonTest(group = "Loaders")
 public class GridServletLoaderTest extends GridCommonAbstractTest {
diff --git a/modules/core/src/test/java/org/apache/ignite/testframework/junits/GridAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/testframework/junits/GridAbstractTest.java
index 7b2c317..6b3fc7f 100755
--- a/modules/core/src/test/java/org/apache/ignite/testframework/junits/GridAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/testframework/junits/GridAbstractTest.java
@@ -1200,7 +1200,11 @@ public abstract class GridAbstractTest extends JUnitAssertAware {
      * @return Started grid.
      * @throws Exception If anything failed.
      */
-    protected Ignite startGrid(String igniteInstanceName, UnaryOperator<IgniteConfiguration> cfgOp, GridSpringResourceContext ctx) throws Exception {
+    protected Ignite startGrid(
+        String igniteInstanceName,
+        UnaryOperator<IgniteConfiguration> cfgOp,
+        GridSpringResourceContext ctx
+    ) throws Exception {
         IgniteConfiguration cfg = optimize(getConfiguration(igniteInstanceName));
 
         if (cfgOp != null)
diff --git a/modules/core/src/test/java/org/apache/ignite/testframework/wal/record/RecordUtils.java b/modules/core/src/test/java/org/apache/ignite/testframework/wal/record/RecordUtils.java
index 27aa08a..8fc3076 100644
--- a/modules/core/src/test/java/org/apache/ignite/testframework/wal/record/RecordUtils.java
+++ b/modules/core/src/test/java/org/apache/ignite/testframework/wal/record/RecordUtils.java
@@ -159,7 +159,8 @@ import static org.apache.ignite.internal.pagemem.wal.record.WALRecord.RecordType
 import static org.apache.ignite.internal.processors.cache.tree.DataInnerIO.VERSIONS;
 
 /**
- * Class contains builder methods for at least one record of each type{@link org.apache.ignite.internal.pagemem.wal.record.WALRecord.RecordType}.
+ * Class contains builder methods for at least one record of each type
+ * {@link org.apache.ignite.internal.pagemem.wal.record.WALRecord.RecordType}.
  * NOTE!!: It is better to rewrite these builder methods to the builder of each record for flexible use where it is
  * required.
  */
diff --git a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMvccTestSuite2.java b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMvccTestSuite2.java
index b9768c2..49a1779 100644
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMvccTestSuite2.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMvccTestSuite2.java
@@ -203,7 +203,8 @@ public class IgniteCacheMvccTestSuite2 {
         ignoredTests.add(GridCachePartitionedTxSingleThreadedSelfTest.class); // See GridCachePartitionedMvccTxSingleThreadedSelfTest
         ignoredTests.add(GridCacheColocatedTxSingleThreadedSelfTest.class); // See GridCacheColocatedMvccTxSingleThreadedSelfTest
         ignoredTests.add(GridCachePartitionedTxMultiThreadedSelfTest.class); // See GridCachePartitionedMvccTxMultiThreadedSelfTest
-        ignoredTests.add(GridCachePartitionedNearDisabledTxMultiThreadedSelfTest.class); // See GridCachePartitionedNearDisabledMvccTxMultiThreadedSelfTest
+        // See GridCachePartitionedNearDisabledMvccTxMultiThreadedSelfTest
+        ignoredTests.add(GridCachePartitionedNearDisabledTxMultiThreadedSelfTest.class);
         ignoredTests.add(GridCachePartitionedTxTimeoutSelfTest.class); // See GridCachePartitionedMvccTxTimeoutSelfTest
 
         ignoredTests.add(GridCacheColocatedDebugTest.class);
diff --git a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMvccTestSuite6.java b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMvccTestSuite6.java
index 4294a3b..e7278bd 100644
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMvccTestSuite6.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMvccTestSuite6.java
@@ -99,8 +99,10 @@ public class IgniteCacheMvccTestSuite6 {
         ignoredTests.add(TxLocalDhtMixedCacheModesTest.class);
 
         // Skip tests that has Mvcc clones.
-        ignoredTests.add(PartitionedTransactionalPessimisticCacheGetsDistributionTest.class); // See PartitionedMvccTxPessimisticCacheGetsDistributionTest.
-        ignoredTests.add(ReplicatedTransactionalPessimisticCacheGetsDistributionTest.class); //See ReplicatedMvccTxPessimisticCacheGetsDistributionTest
+        // See PartitionedMvccTxPessimisticCacheGetsDistributionTest.
+        ignoredTests.add(PartitionedTransactionalPessimisticCacheGetsDistributionTest.class);
+        //See ReplicatedMvccTxPessimisticCacheGetsDistributionTest
+        ignoredTests.add(ReplicatedTransactionalPessimisticCacheGetsDistributionTest.class);
 
         // Read-through is not allowed with MVCC and transactional cache.
         ignoredTests.add(TxOptimisticReadThroughTest.class);
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 9e570a9..f6330fc 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
@@ -80,11 +80,12 @@ public class IgniteWalConverter {
 
         final WalStat stat = params.isPrintStat() ? new WalStat() : null;
 
-        IgniteWalIteratorFactory.IteratorParametersBuilder iteratorParametersBuilder = new IgniteWalIteratorFactory.IteratorParametersBuilder()
-            .pageSize(params.getPageSize())
-            .binaryMetadataFileStoreDir(params.getBinaryMetadataFileStoreDir())
-            .marshallerMappingFileStoreDir(params.getMarshallerMappingFileStoreDir())
-            .keepBinary(params.isKeepBinary());
+        IgniteWalIteratorFactory.IteratorParametersBuilder iteratorParametersBuilder =
+            new IgniteWalIteratorFactory.IteratorParametersBuilder()
+                .pageSize(params.getPageSize())
+                .binaryMetadataFileStoreDir(params.getBinaryMetadataFileStoreDir())
+                .marshallerMappingFileStoreDir(params.getMarshallerMappingFileStoreDir())
+                .keepBinary(params.isKeepBinary());
 
         if (params.getWalDir() != null)
             iteratorParametersBuilder.filesOrDirs(params.getWalDir());
diff --git a/modules/dev-utils/src/main/java/org/apache/ignite/development/utils/IgniteWalConverterArguments.java b/modules/dev-utils/src/main/java/org/apache/ignite/development/utils/IgniteWalConverterArguments.java
index 3e368cc..ae44e72 100644
--- a/modules/dev-utils/src/main/java/org/apache/ignite/development/utils/IgniteWalConverterArguments.java
+++ b/modules/dev-utils/src/main/java/org/apache/ignite/development/utils/IgniteWalConverterArguments.java
@@ -306,16 +306,20 @@ public class IgniteWalConverterArguments {
             out.println("Print WAL log data in human-readable form.");
             out.println("You need to provide:");
             out.println("    walDir                           Path to dir with wal files.");
-            out.println("    walArchiveDir                    Path to dir with archive wal files. walDir or walArchiveDir must be specified.");
-            out.println("    pageSize                         Size of pages, which was selected for file store (1024, 2048, 4096, etc). Default 4096.");
+            out.println("    walArchiveDir                    " +
+                "Path to dir with archive wal files. walDir or walArchiveDir must be specified.");
+            out.println("    pageSize                         " +
+                "Size of pages, which was selected for file store (1024, 2048, 4096, etc). Default 4096.");
             out.println("    binaryMetadataFileStoreDir       (Optional) Path to binary meta.");
             out.println("    marshallerMappingFileStoreDir    (Optional) Path to marshaller dir.");
             out.println("    keepBinary                       Keep binary flag. Default true.");
-            out.println("    recordTypes                      (Optional) Comma-separated WAL record types (TX_RECORD, DATA_RECORD, etc). Default all.");
+            out.println("    recordTypes                      " +
+                "(Optional) Comma-separated WAL record types (TX_RECORD, DATA_RECORD, etc). Default all.");
             out.println("    walTimeFromMillis                (Optional) The start time interval for the record time in milliseconds.");
             out.println("    walTimeToMillis                  (Optional) The end time interval for the record time in milliseconds.");
             out.println("    recordContainsText               (Optional) Filter by substring in the WAL record.");
-            out.println("    processSensitiveData             (Optional) Strategy for the processing of sensitive data (SHOW, HIDE, HASH, MD5). Default SHOW.");
+            out.println("    processSensitiveData             " +
+                "(Optional) Strategy for the processing of sensitive data (SHOW, HIDE, HASH, MD5). Default SHOW.");
             out.println("    printStat                        Write summary statistics for WAL. Default false.");
             out.println("    skipCrc                          Skip CRC calculation/check flag. Default false.");
             out.println("    pages                            (Optional) Comma-separated pages or path to file with " +
diff --git a/modules/dev-utils/src/test/java/org/apache/ignite/development/utils/IgniteWalConverterTest.java b/modules/dev-utils/src/test/java/org/apache/ignite/development/utils/IgniteWalConverterTest.java
index 896dc67..8edd16b 100644
--- a/modules/dev-utils/src/test/java/org/apache/ignite/development/utils/IgniteWalConverterTest.java
+++ b/modules/dev-utils/src/test/java/org/apache/ignite/development/utils/IgniteWalConverterTest.java
@@ -149,7 +149,8 @@ public class IgniteWalConverterTest extends GridCommonAbstractTest {
      * Checking utility IgniteWalConverter
      * <ul>
      *     <li>Start node</li>
-     *     <li>Create cache with <a href="https://apacheignite.readme.io/docs/indexes#section-registering-indexed-types">Registering Indexed Types</a></li>
+     *     <li>Create cache with
+     *     <a href="https://apacheignite.readme.io/docs/indexes#section-registering-indexed-types">Registering Indexed Types</a></li>
      *     <li>Put several entity</li>
      *     <li>Stop node</li>
      *     <li>Read wal with specifying binaryMetadata</li>
@@ -212,7 +213,8 @@ public class IgniteWalConverterTest extends GridCommonAbstractTest {
      * Checking utility IgniteWalConverter with out binary_meta
      * <ul>
      *     <li>Start node</li>
-     *     <li>Create cache with <a href="https://apacheignite.readme.io/docs/indexes#section-registering-indexed-types">Registering Indexed Types</a></li>
+     *     <li>Create cache with
+     *     <a href="https://apacheignite.readme.io/docs/indexes#section-registering-indexed-types">Registering Indexed Types</a></li>
      *     <li>Put several entity</li>
      *     <li>Stop node</li>
      *     <li>Read wal with <b>out</b> specifying binaryMetadata</li>
@@ -277,7 +279,8 @@ public class IgniteWalConverterTest extends GridCommonAbstractTest {
      * Checking utility IgniteWalConverter on broken WAL
      * <ul>
      *     <li>Start node</li>
-     *     <li>Create cache with <a href="https://apacheignite.readme.io/docs/indexes#section-registering-indexed-types">Registering Indexed Types</a></li>
+     *     <li>Create cache with
+     *     <a href="https://apacheignite.readme.io/docs/indexes#section-registering-indexed-types">Registering Indexed Types</a></li>
      *     <li>Put several entity</li>
      *     <li>Stop node</li>
      *     <li>Change byte in DataRecord value</li>
@@ -395,7 +398,8 @@ public class IgniteWalConverterTest extends GridCommonAbstractTest {
      * Checking utility IgniteWalConverter on unreadable WAL
      * <ul>
      *     <li>Start node</li>
-     *     <li>Create cache with <a href="https://apacheignite.readme.io/docs/indexes#section-registering-indexed-types">Registering Indexed Types</a></li>
+     *     <li>Create cache with
+     *     <a href="https://apacheignite.readme.io/docs/indexes#section-registering-indexed-types">Registering Indexed Types</a></li>
      *     <li>Put several entity</li>
      *     <li>Stop node</li>
      *     <li>Change byte RecordType in second DataRecord</li>
@@ -555,7 +559,8 @@ public class IgniteWalConverterTest extends GridCommonAbstractTest {
      * Common part
      * <ul>
      *    <li>Start node</li>
-     *    <li>Create cache with <a href="https://apacheignite.readme.io/docs/indexes#section-registering-indexed-types">Registering Indexed Types</a></li>
+     *    <li>Create cache with
+     *    <a href="https://apacheignite.readme.io/docs/indexes#section-registering-indexed-types">Registering Indexed Types</a></li>
      *    <li>Put several entity</li>
      * </ul>
      *
diff --git a/modules/direct-io/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/IgniteNativeIoLib.java b/modules/direct-io/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/IgniteNativeIoLib.java
index d1b489d..2aecf90 100644
--- a/modules/direct-io/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/IgniteNativeIoLib.java
+++ b/modules/direct-io/src/main/java/org/apache/ignite/internal/processors/cache/persistence/file/IgniteNativeIoLib.java
@@ -317,7 +317,8 @@ public class IgniteNativeIoLib {
     /**
      * Synchronize a file's in-core state with storage device. See "man 2 fsync".
      *
-     * Similar to {@link #fsync(int)}, but does not flush modified metadata unless that metadata is needed in order to allow a subsequent data retrieval to be correctly handled
+     * Similar to {@link #fsync(int)}, but does not flush modified metadata unless that metadata is needed in order to allow a subsequent
+     * data retrieval to be correctly handled.
      *
      * @param fd file descriptor.
      * @return On success return zero. On error, -1 is returned, and errno is set appropriately.
diff --git a/modules/extdata/p2p/src/main/java/org/apache/ignite/tests/p2p/GridP2PRemoteTransformerWithStaticInitializerFactory.java b/modules/extdata/p2p/src/main/java/org/apache/ignite/tests/p2p/GridP2PRemoteTransformerWithStaticInitializerFactory.java
index 90a9fbf..02fe9f6 100644
--- a/modules/extdata/p2p/src/main/java/org/apache/ignite/tests/p2p/GridP2PRemoteTransformerWithStaticInitializerFactory.java
+++ b/modules/extdata/p2p/src/main/java/org/apache/ignite/tests/p2p/GridP2PRemoteTransformerWithStaticInitializerFactory.java
@@ -24,7 +24,8 @@ import org.apache.ignite.lang.IgniteClosure;
 /**
  * Remote transformer with static initializer factory.
  */
-public class GridP2PRemoteTransformerWithStaticInitializerFactory implements Factory<IgniteClosure<CacheEntryEvent<Integer, Integer>, String>> {
+public class GridP2PRemoteTransformerWithStaticInitializerFactory
+    implements Factory<IgniteClosure<CacheEntryEvent<Integer, Integer>, String>> {
     /** {@inheritDoc} */
     @Override public IgniteClosure<CacheEntryEvent<Integer, Integer>, String> create() {
         return new GridP2PRemoteTransformerWithStaticInitializer();
diff --git a/modules/hibernate-5.1/src/main/java/org/apache/ignite/cache/hibernate/HibernateEntityRegion.java b/modules/hibernate-5.1/src/main/java/org/apache/ignite/cache/hibernate/HibernateEntityRegion.java
index f1659c7..5e00177 100644
--- a/modules/hibernate-5.1/src/main/java/org/apache/ignite/cache/hibernate/HibernateEntityRegion.java
+++ b/modules/hibernate-5.1/src/main/java/org/apache/ignite/cache/hibernate/HibernateEntityRegion.java
@@ -120,7 +120,14 @@ public class HibernateEntityRegion extends HibernateTransactionalDataRegion impl
         }
 
         /** {@inheritDoc} */
-        @Override public boolean afterUpdate(SessionImplementor ses, Object key, Object val, Object currVer, Object previousVer, SoftLock lock)
+        @Override public boolean afterUpdate(
+            SessionImplementor ses,
+            Object key,
+            Object val,
+            Object currVer,
+            Object previousVer,
+            SoftLock lock
+        )
             throws CacheException {
             return stgy.afterUpdate(key, val);
         }
diff --git a/modules/hibernate-5.3/src/main/java/org/apache/ignite/cache/hibernate/IgniteCachedDomainDataAccess.java b/modules/hibernate-5.3/src/main/java/org/apache/ignite/cache/hibernate/IgniteCachedDomainDataAccess.java
index 4003418..fcf211a 100644
--- a/modules/hibernate-5.3/src/main/java/org/apache/ignite/cache/hibernate/IgniteCachedDomainDataAccess.java
+++ b/modules/hibernate-5.3/src/main/java/org/apache/ignite/cache/hibernate/IgniteCachedDomainDataAccess.java
@@ -60,13 +60,24 @@ public abstract class IgniteCachedDomainDataAccess extends HibernateRegion imple
     }
 
     /** {@inheritDoc} */
-    @Override public boolean putFromLoad(SharedSessionContractImplementor ses, Object key, Object value, Object version) throws CacheException {
+    @Override public boolean putFromLoad(
+        SharedSessionContractImplementor ses,
+        Object key,
+        Object value,
+        Object version
+    ) throws CacheException {
         stgy.putFromLoad(key, value);
         return true;
     }
 
     /** {@inheritDoc} */
-    @Override public boolean putFromLoad(SharedSessionContractImplementor ses, Object key, Object value, Object version, boolean minimalPutOverride) throws CacheException {
+    @Override public boolean putFromLoad(
+        SharedSessionContractImplementor ses,
+        Object key,
+        Object value,
+        Object version,
+        boolean minimalPutOverride
+    ) throws CacheException {
         stgy.putFromLoad(key, value);
         return true;
     }
diff --git a/modules/hibernate-5.3/src/main/java/org/apache/ignite/cache/hibernate/IgniteEntityDataAccess.java b/modules/hibernate-5.3/src/main/java/org/apache/ignite/cache/hibernate/IgniteEntityDataAccess.java
index dee21fb..da1fcd7 100644
--- a/modules/hibernate-5.3/src/main/java/org/apache/ignite/cache/hibernate/IgniteEntityDataAccess.java
+++ b/modules/hibernate-5.3/src/main/java/org/apache/ignite/cache/hibernate/IgniteEntityDataAccess.java
@@ -75,7 +75,14 @@ public class IgniteEntityDataAccess extends IgniteCachedDomainDataAccess impleme
     }
 
     /** {@inheritDoc} */
-    @Override public boolean afterUpdate(SharedSessionContractImplementor ses, Object key, Object val, Object curVer, Object prevVer, SoftLock lock) {
+    @Override public boolean afterUpdate(
+        SharedSessionContractImplementor ses,
+        Object key,
+        Object val,
+        Object curVer,
+        Object prevVer,
+        SoftLock lock
+    ) {
         return stgy.afterUpdate(key, val);
     }
 
diff --git a/modules/hibernate-5.3/src/main/java/org/apache/ignite/cache/hibernate/IgniteNaturalIdDataAccess.java b/modules/hibernate-5.3/src/main/java/org/apache/ignite/cache/hibernate/IgniteNaturalIdDataAccess.java
index c09f501..cc2075b 100644
--- a/modules/hibernate-5.3/src/main/java/org/apache/ignite/cache/hibernate/IgniteNaturalIdDataAccess.java
+++ b/modules/hibernate-5.3/src/main/java/org/apache/ignite/cache/hibernate/IgniteNaturalIdDataAccess.java
@@ -80,7 +80,12 @@ public class IgniteNaturalIdDataAccess extends IgniteCachedDomainDataAccess impl
     }
 
     /** {@inheritDoc} */
-    @Override public boolean afterUpdate(SharedSessionContractImplementor ses, Object key, Object val, SoftLock lock) throws CacheException {
+    @Override public boolean afterUpdate(
+        SharedSessionContractImplementor ses,
+        Object key,
+        Object val,
+        SoftLock lock
+    ) throws CacheException {
         return stgy.afterUpdate(key, val);
     }
 }
diff --git a/modules/hibernate-5.3/src/test/java/org/apache/ignite/cache/hibernate/HibernateL2CacheConfigurationSelfTest.java b/modules/hibernate-5.3/src/test/java/org/apache/ignite/cache/hibernate/HibernateL2CacheConfigurationSelfTest.java
index 708830a..bcb7360 100644
--- a/modules/hibernate-5.3/src/test/java/org/apache/ignite/cache/hibernate/HibernateL2CacheConfigurationSelfTest.java
+++ b/modules/hibernate-5.3/src/test/java/org/apache/ignite/cache/hibernate/HibernateL2CacheConfigurationSelfTest.java
@@ -161,8 +161,14 @@ public class HibernateL2CacheConfigurationSelfTest extends GridCommonAbstractTes
 
         cfg.setProperty(REGION_CACHE_PROPERTY + ENTITY1_NAME, "cache1");
         cfg.setProperty(REGION_CACHE_PROPERTY + ENTITY2_NAME, "cache2");
-        cfg.setProperty(REGION_CACHE_PROPERTY + DEFAULT_UPDATE_TIMESTAMPS_REGION_UNQUALIFIED_NAME, DEFAULT_UPDATE_TIMESTAMPS_REGION_UNQUALIFIED_NAME);
-        cfg.setProperty(REGION_CACHE_PROPERTY + DEFAULT_QUERY_RESULTS_REGION_UNQUALIFIED_NAME, DEFAULT_QUERY_RESULTS_REGION_UNQUALIFIED_NAME);
+        cfg.setProperty(
+            REGION_CACHE_PROPERTY + DEFAULT_UPDATE_TIMESTAMPS_REGION_UNQUALIFIED_NAME,
+            DEFAULT_UPDATE_TIMESTAMPS_REGION_UNQUALIFIED_NAME
+        );
+        cfg.setProperty(
+            REGION_CACHE_PROPERTY + DEFAULT_QUERY_RESULTS_REGION_UNQUALIFIED_NAME,
+            DEFAULT_QUERY_RESULTS_REGION_UNQUALIFIED_NAME
+        );
 
         return cfg;
     }
diff --git a/modules/hibernate-5.3/src/test/java/org/apache/ignite/cache/hibernate/HibernateL2CacheStrategySelfTest.java b/modules/hibernate-5.3/src/test/java/org/apache/ignite/cache/hibernate/HibernateL2CacheStrategySelfTest.java
index a94d4f4..dbd51f8 100644
--- a/modules/hibernate-5.3/src/test/java/org/apache/ignite/cache/hibernate/HibernateL2CacheStrategySelfTest.java
+++ b/modules/hibernate-5.3/src/test/java/org/apache/ignite/cache/hibernate/HibernateL2CacheStrategySelfTest.java
@@ -294,8 +294,14 @@ public class HibernateL2CacheStrategySelfTest extends GridCommonAbstractTest {
         builder.applySetting(USE_STRUCTURED_CACHE, "true");
         builder.applySetting(REGION_CACHE_PROPERTY + ENTITY1_NAME, "cache1");
         builder.applySetting(REGION_CACHE_PROPERTY + ENTITY2_NAME, "cache2");
-        builder.applySetting(REGION_CACHE_PROPERTY + DEFAULT_UPDATE_TIMESTAMPS_REGION_UNQUALIFIED_NAME, DEFAULT_UPDATE_TIMESTAMPS_REGION_UNQUALIFIED_NAME);
-        builder.applySetting(REGION_CACHE_PROPERTY + DEFAULT_QUERY_RESULTS_REGION_UNQUALIFIED_NAME, DEFAULT_QUERY_RESULTS_REGION_UNQUALIFIED_NAME);
+        builder.applySetting(
+            REGION_CACHE_PROPERTY + DEFAULT_UPDATE_TIMESTAMPS_REGION_UNQUALIFIED_NAME,
+            DEFAULT_UPDATE_TIMESTAMPS_REGION_UNQUALIFIED_NAME
+        );
+        builder.applySetting(
+            REGION_CACHE_PROPERTY + DEFAULT_QUERY_RESULTS_REGION_UNQUALIFIED_NAME,
+            DEFAULT_QUERY_RESULTS_REGION_UNQUALIFIED_NAME
+        );
 
         MetadataSources metadataSources = new MetadataSources(builder.build());
 
diff --git a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java
index 50d9970..7543c27 100644
--- a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java
+++ b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java
@@ -3067,8 +3067,12 @@ public class IgniteH2Indexing implements GridQueryIndexing {
         Map<String, Integer> map = new HashMap<>();
         for (GridH2Table table : schemaMgr.dataTables()) {
             for (Index index : table.getIndexes()) {
-                if (index instanceof H2TreeIndexBase && !index.getIndexType().isPrimaryKey())
-                    map.put(index.getSchema().getName() + "#" + index.getTable().getName() + "#" + index.getName(), ((H2TreeIndexBase)index).inlineSize());
+                if (index instanceof H2TreeIndexBase && !index.getIndexType().isPrimaryKey()) {
+                    map.put(
+                        index.getSchema().getName() + "#" + index.getTable().getName() + "#" + index.getName(),
+                        ((H2TreeIndexBase)index).inlineSize()
+                    );
+                }
             }
 
         }
diff --git a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/database/H2PkHashIndex.java b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/database/H2PkHashIndex.java
index 2349559..c84ba57 100644
--- a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/database/H2PkHashIndex.java
+++ b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/database/H2PkHashIndex.java
@@ -170,7 +170,14 @@ public class H2PkHashIndex extends GridH2IndexBase {
     }
 
     /** {@inheritDoc} */
-    @Override public double getCost(Session ses, int[] masks, TableFilter[] filters, int filter, SortOrder sortOrder, HashSet<Column> allColumnsSet) {
+    @Override public double getCost(
+        Session ses,
+        int[] masks,
+        TableFilter[] filters,
+        int filter,
+        SortOrder sortOrder,
+        HashSet<Column> allColumnsSet
+    ) {
         return Double.MAX_VALUE;
     }
 
diff --git a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/opt/GridH2ProxyIndex.java b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/opt/GridH2ProxyIndex.java
index 5174277..2559ecc 100644
--- a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/opt/GridH2ProxyIndex.java
+++ b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/opt/GridH2ProxyIndex.java
@@ -99,7 +99,14 @@ public class GridH2ProxyIndex extends H2IndexCostedBase {
     }
 
     /** {@inheritDoc} */
-    @Override public double getCost(Session session, int[] masks, TableFilter[] filters, int filter, SortOrder sortOrder, HashSet<Column> allColumnsSet) {
+    @Override public double getCost(
+        Session session,
+        int[] masks,
+        TableFilter[] filters,
+        int filter,
+        SortOrder sortOrder,
+        HashSet<Column> allColumnsSet
+    ) {
         long rowCnt = getRowCountApproximation();
 
         double baseCost = getCostRangeIndexEx(masks, rowCnt, filters, filter, sortOrder, false, allColumnsSet);
diff --git a/modules/indexing/src/test/java/org/apache/ignite/client/FunctionalQueryTest.java b/modules/indexing/src/test/java/org/apache/ignite/client/FunctionalQueryTest.java
index 8614086..28ffaa7 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/client/FunctionalQueryTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/client/FunctionalQueryTest.java
@@ -153,7 +153,8 @@ public class FunctionalQueryTest {
      */
     @Test
     public void testSql() throws Exception {
-        try (Ignite ignored = Ignition.start(Config.getServerConfiguration()); Ignite ignored2 = Ignition.start(Config.getServerConfiguration());
+        try (Ignite ignored = Ignition.start(Config.getServerConfiguration());
+             Ignite ignored2 = Ignition.start(Config.getServerConfiguration());
              IgniteClient client = Ignition.startClient(new ClientConfiguration().setAddresses(Config.SERVER))
         ) {
             client.query(
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/AffinityKeyNameAndValueFieldNameConflictTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/AffinityKeyNameAndValueFieldNameConflictTest.java
index 8447677..e78821b 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/AffinityKeyNameAndValueFieldNameConflictTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/AffinityKeyNameAndValueFieldNameConflictTest.java
@@ -158,7 +158,8 @@ public class AffinityKeyNameAndValueFieldNameConflictTest extends GridCommonAbst
 
         personCache.put(keyProducer.apply(1, "o1"), new Person("p1"));
 
-        SqlFieldsQuery query = new SqlFieldsQuery("select * from \"" + PERSON_CACHE + "\"." + Person.class.getSimpleName() + " it where it.name=?");
+        SqlFieldsQuery query =
+            new SqlFieldsQuery("select * from \"" + PERSON_CACHE + "\"." + Person.class.getSimpleName() + " it where it.name=?");
 
         List<List<?>> result = personCache.query(query.setArgs(keyFieldSpecified ? "o1" : "p1")).getAll();
 
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/BinaryTypeMismatchLoggingTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/BinaryTypeMismatchLoggingTest.java
index 0e892d3..4f0c6ea 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/BinaryTypeMismatchLoggingTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/BinaryTypeMismatchLoggingTest.java
@@ -41,7 +41,8 @@ import org.junit.Test;
  */
 public class BinaryTypeMismatchLoggingTest extends GridCommonAbstractTest {
     /** */
-    public static final String MESSAGE_PAYLOAD_VALUE = "expValType=Payload, actualValType=o.a.i.i.processors.cache.BinaryTypeMismatchLoggingTest$Payload";
+    public static final String MESSAGE_PAYLOAD_VALUE =
+        "expValType=Payload, actualValType=o.a.i.i.processors.cache.BinaryTypeMismatchLoggingTest$Payload";
 
     /** */
     private GridStringLogger capture;
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/CacheRegisterMetadataLocallyTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/CacheRegisterMetadataLocallyTest.java
index 65d6a75..f7c079b 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/CacheRegisterMetadataLocallyTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/CacheRegisterMetadataLocallyTest.java
@@ -229,7 +229,9 @@ public class CacheRegisterMetadataLocallyTest extends GridCommonAbstractTest {
     private void assertCustomMessages(int expMsgCnt) {
         assertEquals(customMessages.toString(), expMsgCnt, customMessages.size());
 
-        customMessages.forEach(cm -> assertTrue(cm.toString(), cm instanceof DynamicCacheChangeBatch || cm instanceof MetadataUpdateProposedMessage));
+        customMessages.forEach(
+            cm -> assertTrue(cm.toString(), cm instanceof DynamicCacheChangeBatch || cm instanceof MetadataUpdateProposedMessage)
+        );
     }
 
     /**
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/CheckIndexesInlineSizeOnNodeJoinMultiJvmTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/CheckIndexesInlineSizeOnNodeJoinMultiJvmTest.java
index 3dd4be6..68346cd 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/CheckIndexesInlineSizeOnNodeJoinMultiJvmTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/CheckIndexesInlineSizeOnNodeJoinMultiJvmTest.java
@@ -52,7 +52,8 @@ public class CheckIndexesInlineSizeOnNodeJoinMultiJvmTest extends GridCommonAbst
     private static final String STR = "abcdefghijklmnopqrstuvwxyzABCDEFGHIJKLMNOPQRSTUVWXYZ";
 
     /** */
-    private static final String INDEXES_WARN_MSG_FORMAT = "PUBLIC#TEST_TABLE#L_IDX(%d,%d),PUBLIC#TEST_TABLE#S1_IDX(%d,%d),PUBLIC#TEST_TABLE#I_IDX(%d,%d)";
+    private static final String INDEXES_WARN_MSG_FORMAT =
+        "PUBLIC#TEST_TABLE#L_IDX(%d,%d),PUBLIC#TEST_TABLE#S1_IDX(%d,%d),PUBLIC#TEST_TABLE#I_IDX(%d,%d)";
 
     /** Nodes count. */
     private static final int NODES_CNT = 3;
@@ -209,7 +210,15 @@ public class CheckIndexesInlineSizeOnNodeJoinMultiJvmTest extends GridCommonAbst
 
     /** */
     private String generateIndexesWarnMessage(UUID nodeId, int payloadSize1, int payloadSize2) {
-        String indexesInfo = format(INDEXES_WARN_MSG_FORMAT, payloadSize1, payloadSize2, payloadSize1, payloadSize2, payloadSize1, payloadSize2);
+        String indexesInfo = format(
+            INDEXES_WARN_MSG_FORMAT,
+            payloadSize1,
+            payloadSize2,
+            payloadSize1,
+            payloadSize2,
+            payloadSize1,
+            payloadSize2
+        );
 
         return format(INLINE_SIZES_DIFFER_WARN_MSG_FORMAT, nodeId, indexesInfo);
     }
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheDynamicLoadOnClientTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheDynamicLoadOnClientTest.java
index 8ff986d..228bd2f 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheDynamicLoadOnClientTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheDynamicLoadOnClientTest.java
@@ -203,7 +203,9 @@ public class GridCacheDynamicLoadOnClientTest extends GridCommonAbstractTest {
      */
     @Test
     public void testDropIdxOnClient() {
-        srvNode.getOrCreateCache(DEFAULT_CACHE_NAME).query(new SqlFieldsQuery("CREATE INDEX IDX_TST ON " + FULL_TABLE_NAME + " (name desc)")).getAll();
+        srvNode.getOrCreateCache(DEFAULT_CACHE_NAME).query(
+            new SqlFieldsQuery("CREATE INDEX IDX_TST ON " + FULL_TABLE_NAME + " (name desc)")
+        ).getAll();
 
         //Due to client receive created index asynchronously we need add the ugly sleep.
         doSleep(2000);
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheAbstractFieldsQuerySelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheAbstractFieldsQuerySelfTest.java
index b4497c2..cd1fb05 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheAbstractFieldsQuerySelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheAbstractFieldsQuerySelfTest.java
@@ -209,8 +209,12 @@ public abstract class IgniteCacheAbstractFieldsQuerySelfTest extends GridCommonA
     public void testCacheMetaData() throws Exception {
         // Put internal key to test filtering of internal objects.
 
-        for (String cacheName : grid(0).cacheNames())
-            ((IgniteKernal)grid(0)).getCache(cacheName).getAndPut(new GridCacheInternalKeyImpl("LONG", ""), new GridCacheAtomicLongValue(0));
+        for (String cacheName : grid(0).cacheNames()) {
+            ((IgniteKernal)grid(0)).getCache(cacheName).getAndPut(
+                new GridCacheInternalKeyImpl("LONG", ""),
+                new GridCacheAtomicLongValue(0)
+            );
+        }
 
         try {
             Collection<GridCacheSqlMetadata> metas =
@@ -730,10 +734,11 @@ public abstract class IgniteCacheAbstractFieldsQuerySelfTest extends GridCommonA
     /** @throws Exception If failed. */
     @Test
     public void testSelectAllJoined() throws Exception {
-        QueryCursor<List<?>> qry =
-            personCache.query(sqlFieldsQuery(
-                String.format("select p._key, p._val, p.*, o._key, o._val, o.* from \"%s\".Person p, \"%s\".Organization o where p.orgId = o.id",
-                    personCache.getName(), orgCache.getName())));
+        QueryCursor<List<?>> qry = personCache.query(sqlFieldsQuery(String.format(
+            "select p._key, p._val, p.*, o._key, o._val, o.* from \"%s\".Person p, \"%s\".Organization o where p.orgId = o.id",
+            personCache.getName(),
+            orgCache.getName()
+        )));
 
         List<List<?>> res = new ArrayList<>(qry.getAll());
 
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheConfigurationPrimitiveTypesSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheConfigurationPrimitiveTypesSelfTest.java
index 69599dd..3d6e357 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheConfigurationPrimitiveTypesSelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheConfigurationPrimitiveTypesSelfTest.java
@@ -64,7 +64,8 @@ public class IgniteCacheConfigurationPrimitiveTypesSelfTest extends GridCommonAb
         double d = 6;
         cacheDouble.put(d, d);
 
-        IgniteCache<Boolean, Boolean> cacheBoolean = jcache(ignite, new CacheConfiguration(DEFAULT_CACHE_NAME), boolean.class, boolean.class);
+        IgniteCache<Boolean, Boolean> cacheBoolean =
+            jcache(ignite, new CacheConfiguration(DEFAULT_CACHE_NAME), boolean.class, boolean.class);
         boolean bool = true;
         cacheBoolean.put(bool, bool);
 
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteDynamicSqlRestoreTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteDynamicSqlRestoreTest.java
index 321fc28..600cbdf 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteDynamicSqlRestoreTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteDynamicSqlRestoreTest.java
@@ -190,7 +190,8 @@ public class IgniteDynamicSqlRestoreTest extends GridCommonAbstractTest implemen
                 " LANG VARCHAR,\n" +
                 " BIRTH_DATE TIMESTAMP,\n" +
                 " CONSTRAINT PK_PERSON PRIMARY KEY (FIRST_NAME,LAST_NAME,ADDRESS,LANG)\n" +
-                " ) WITH \"key_type=PersonKeyType, CACHE_NAME=PersonCache, value_type=PersonValueType, AFFINITY_KEY=FIRST_NAME,template=PARTITIONED,backups=1\"");
+                " ) WITH \"key_type=PersonKeyType, " +
+                    "CACHE_NAME=PersonCache, value_type=PersonValueType, AFFINITY_KEY=FIRST_NAME,template=PARTITIONED,backups=1\"");
 
             try (PreparedStatement stmt = conn.prepareStatement(
                 "insert into Person(LANG, FIRST_NAME, ADDRESS, LAST_NAME, BIRTH_DATE) values(?,?,?,?,?)")) {
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/QueryJoinWithDifferentNodeFiltersTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/QueryJoinWithDifferentNodeFiltersTest.java
index 2813342..5233785 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/QueryJoinWithDifferentNodeFiltersTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/QueryJoinWithDifferentNodeFiltersTest.java
@@ -106,7 +106,9 @@ public class QueryJoinWithDifferentNodeFiltersTest extends AbstractIndexingCommo
             cache2.put(i, new Person(i, i, "Person-" + i));
         }
 
-        info(cache2.query(new SqlFieldsQuery("select * from \"cache\".Organization r, \"cache2\".Person p where p.orgId=r.orgId")).getAll().toString());
+        info(cache2.query(
+            new SqlFieldsQuery("select * from \"cache\".Organization r, \"cache2\".Person p where p.orgId=r.orgId")
+        ).getAll().toString());
     }
 
     /**
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/BasicIndexTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/BasicIndexTest.java
index 8c0c67b..c2722f9 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/BasicIndexTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/BasicIndexTest.java
@@ -572,7 +572,9 @@ public class BasicIndexTest extends AbstractIndexingCommonTest {
 
         System.err.println(plan);
 
-        return idxName != null ? (!plan.contains(SCAN_INDEX_NAME_SUFFIX) && plan.contains(idxName.toUpperCase())) : !plan.contains(SCAN_INDEX_NAME_SUFFIX);
+        return idxName != null
+            ? (!plan.contains(SCAN_INDEX_NAME_SUFFIX) && plan.contains(idxName.toUpperCase()))
+            : !plan.contains(SCAN_INDEX_NAME_SUFFIX);
     }
 
     /** */
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/H2RowExpireTimeIndexSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/H2RowExpireTimeIndexSelfTest.java
index 3f759b1..597feb4 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/H2RowExpireTimeIndexSelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/H2RowExpireTimeIndexSelfTest.java
@@ -144,13 +144,15 @@ public class H2RowExpireTimeIndexSelfTest extends GridCommonAbstractTest {
         }
 
         {
-            List<List<?>> expired = cache.query(new SqlFieldsQuery("SELECT * FROM \"notEager\".Integer where id >= 42 and id <= 42")).getAll();
+            List<List<?>> expired =
+                cache.query(new SqlFieldsQuery("SELECT * FROM \"notEager\".Integer where id >= 42 and id <= 42")).getAll();
 
             Assert.assertTrue("Expired row should not be returned by sql. Result = " + expired, expired.isEmpty());
         }
 
         {
-            List<List<?>> expired = cache.query(new SqlFieldsQuery("SELECT * FROM \"notEager\".Integer where id >= 5 and id <= 5")).getAll();
+            List<List<?>> expired =
+                cache.query(new SqlFieldsQuery("SELECT * FROM \"notEager\".Integer where id >= 5 and id <= 5")).getAll();
 
             assertEqualsCollections(Collections.singletonList(asList(5, 6)), expired);
         }
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/QueryEntityValidationSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/QueryEntityValidationSelfTest.java
index 4bcfd82..13ea5f4 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/QueryEntityValidationSelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/QueryEntityValidationSelfTest.java
@@ -228,7 +228,8 @@ public class QueryEntityValidationSelfTest extends AbstractIndexingCommonTest {
      */
     @Test
     public void testUniqueNameInAnnotation() {
-        final CacheConfiguration<TestKeyWithUniqueName, TestValueWithUniqueName> ccfg = new CacheConfiguration<TestKeyWithUniqueName, TestValueWithUniqueName>().setName(CACHE_NAME);
+        final CacheConfiguration<TestKeyWithUniqueName, TestValueWithUniqueName> ccfg =
+            new CacheConfiguration<TestKeyWithUniqueName, TestValueWithUniqueName>().setName(CACHE_NAME);
 
         assertNotNull(ccfg.setIndexedTypes(TestKeyWithUniqueName.class, TestValueWithUniqueName.class));
     }
@@ -260,7 +261,8 @@ public class QueryEntityValidationSelfTest extends AbstractIndexingCommonTest {
      */
     @Test
     public void testNotUniqueNameInAnnotation() {
-        final CacheConfiguration<TestKeyWithNotUniqueName, TestValueWithNotUniqueName> ccfg = new CacheConfiguration<TestKeyWithNotUniqueName, TestValueWithNotUniqueName>().setName(CACHE_NAME);
+        final CacheConfiguration<TestKeyWithNotUniqueName, TestValueWithNotUniqueName> ccfg =
+            new CacheConfiguration<TestKeyWithNotUniqueName, TestValueWithNotUniqueName>().setName(CACHE_NAME);
 
         GridTestUtils.assertThrows(log, (Callable<Void>)() -> {
             ccfg.setIndexedTypes(TestKeyWithNotUniqueName.class, TestValueWithNotUniqueName.class);
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccAbstractSqlCoordinatorFailoverTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccAbstractSqlCoordinatorFailoverTest.java
index 5fb718b..732bfd8 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccAbstractSqlCoordinatorFailoverTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccAbstractSqlCoordinatorFailoverTest.java
@@ -351,7 +351,9 @@ public abstract class CacheMvccAbstractSqlCoordinatorFailoverTest extends CacheM
 
             GridTestUtils.assertThrows(log, new Callable<Void>() {
                 @Override public Void call() throws Exception {
-                    clientCache.query(new SqlFieldsQuery("UPDATE Integer SET _val=42 WHERE _key IN (SELECT DISTINCT _val FROM INTEGER)")).getAll();
+                    clientCache.query(
+                        new SqlFieldsQuery("UPDATE Integer SET _val=42 WHERE _key IN (SELECT DISTINCT _val FROM INTEGER)")
+                    ).getAll();
 
                     return null;
                 }
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccBasicContinuousQueryTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccBasicContinuousQueryTest.java
index 76b780d..3ae0c56 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccBasicContinuousQueryTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccBasicContinuousQueryTest.java
@@ -105,7 +105,8 @@ public class CacheMvccBasicContinuousQueryTest extends CacheMvccAbstractTest {
             assertEquals(0, ((Map)U.field(proc, "stopFuts")).size());
             assertEquals(0, ((Map)U.field(proc, "bufCheckThreads")).size());
 
-            CacheContinuousQueryManager mgr = ((IgniteEx)node).context().cache().internalCache(DEFAULT_CACHE_NAME).context().continuousQueries();
+            CacheContinuousQueryManager mgr =
+                ((IgniteEx)node).context().cache().internalCache(DEFAULT_CACHE_NAME).context().continuousQueries();
 
             assertEquals(0, ((Map)U.field(mgr, "lsnrs")).size());
 
@@ -376,7 +377,8 @@ public class CacheMvccBasicContinuousQueryTest extends CacheMvccAbstractTest {
                 boolean allRolledBack = true;
 
                 for (int i = 1; i < srvCnt; i++) {
-                    boolean rolledBack = grid(i).context().cache().context().tm().activeTransactions().stream().allMatch(tx -> tx.state() == ROLLED_BACK);
+                    boolean rolledBack =
+                        grid(i).context().cache().context().tm().activeTransactions().stream().allMatch(tx -> tx.state() == ROLLED_BACK);
 
                     allRolledBack &= rolledBack;
                 }
@@ -539,7 +541,8 @@ public class CacheMvccBasicContinuousQueryTest extends CacheMvccAbstractTest {
                 boolean allRolledBack = true;
 
                 for (int i = 1; i < srvCnt; i++) {
-                    boolean rolledBack = grid(i).context().cache().context().tm().activeTransactions().stream().allMatch(tx -> tx.state() == ROLLED_BACK);
+                    boolean rolledBack =
+                        grid(i).context().cache().context().tm().activeTransactions().stream().allMatch(tx -> tx.state() == ROLLED_BACK);
 
                     allRolledBack &= rolledBack;
                 }
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccPartitionedSqlCoordinatorFailoverTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccPartitionedSqlCoordinatorFailoverTest.java
index 60ecd46..b30ec98 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccPartitionedSqlCoordinatorFailoverTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccPartitionedSqlCoordinatorFailoverTest.java
@@ -169,7 +169,15 @@ public class CacheMvccPartitionedSqlCoordinatorFailoverTest extends CacheMvccAbs
      */
     @Test
     public void testSqlReadInProgressCoordinatorFails() throws Exception {
-        readInProgressCoordinatorFails(false, false, PESSIMISTIC, REPEATABLE_READ, SQL, DML, new InitIndexing(Integer.class, Integer.class));
+        readInProgressCoordinatorFails(
+            false,
+            false,
+            PESSIMISTIC,
+            REPEATABLE_READ,
+            SQL,
+            DML,
+            new InitIndexing(Integer.class, Integer.class)
+        );
     }
 
     /**
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccSqlConfigurationValidationTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccSqlConfigurationValidationTest.java
index 3a4b39f..63251f9 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccSqlConfigurationValidationTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccSqlConfigurationValidationTest.java
@@ -24,10 +24,11 @@ import org.apache.ignite.cache.CacheMode;
 import org.apache.ignite.cache.query.SqlFieldsQuery;
 import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.transactions.Transaction;
-import org.apache.ignite.transactions.TransactionConcurrency;
-import org.apache.ignite.transactions.TransactionIsolation;
 import org.junit.Test;
 
+import static org.apache.ignite.transactions.TransactionConcurrency.PESSIMISTIC;
+import static org.apache.ignite.transactions.TransactionIsolation.REPEATABLE_READ;
+
 /**
  * Configuration validation for SQL configured caches.
  */
@@ -102,7 +103,7 @@ public class CacheMvccSqlConfigurationValidationTest extends CacheMvccAbstractTe
 
         GridTestUtils.assertThrows(log, new Callable<Object>() {
             @Override public Object call() throws Exception {
-                try (Transaction tx = node.transactions().txStart(TransactionConcurrency.PESSIMISTIC, TransactionIsolation.REPEATABLE_READ)) {
+                try (Transaction tx = node.transactions().txStart(PESSIMISTIC, REPEATABLE_READ)) {
                     cache.query(new SqlFieldsQuery("SELECT * FROM Person, City")).getAll();
 
                     tx.commit();
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccSqlQueriesAbstractTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccSqlQueriesAbstractTest.java
index a9a703dc..7593e3d 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccSqlQueriesAbstractTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccSqlQueriesAbstractTest.java
@@ -248,7 +248,9 @@ public abstract class CacheMvccSqlQueriesAbstractTest extends CacheMvccAbstractT
                     fieldsQrys.add(
                         new SqlFieldsQuery("select _key, idxVal1 from MvccTestSqlIndexValue where idxVal1=?").setLocal(locQry));
 
-                    fieldsQrys.add(new SqlFieldsQuery("select _key, idxVal1 from MvccTestSqlIndexValue where idxVal1=? or idxVal1=?").setLocal(locQry));
+                    fieldsQrys.add(
+                        new SqlFieldsQuery("select _key, idxVal1 from MvccTestSqlIndexValue where idxVal1=? or idxVal1=?").setLocal(locQry)
+                    );
 
                     fieldsQrys.add(new SqlFieldsQuery("select _key, idxVal1 from MvccTestSqlIndexValue where _key=?").setLocal(locQry));
 
@@ -256,7 +258,9 @@ public abstract class CacheMvccSqlQueriesAbstractTest extends CacheMvccAbstractT
 
                     sqlQrys.add(new SqlQuery<Integer, MvccTestSqlIndexValue>(MvccTestSqlIndexValue.class, "idxVal1=?").setLocal(locQry));
 
-                    sqlQrys.add(new SqlQuery<Integer, MvccTestSqlIndexValue>(MvccTestSqlIndexValue.class, "idxVal1=? or idxVal1=?").setLocal(locQry));
+                    sqlQrys.add(
+                        new SqlQuery<Integer, MvccTestSqlIndexValue>(MvccTestSqlIndexValue.class, "idxVal1=? or idxVal1=?").setLocal(locQry)
+                    );
 
                     sqlQrys.add(new SqlQuery<Integer, MvccTestSqlIndexValue>(MvccTestSqlIndexValue.class, "_key=?").setLocal(locQry));
 
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccSqlTxQueriesAbstractTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccSqlTxQueriesAbstractTest.java
index 7b1fe65..6374682 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccSqlTxQueriesAbstractTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccSqlTxQueriesAbstractTest.java
@@ -1669,7 +1669,10 @@ public abstract class CacheMvccSqlTxQueriesAbstractTest extends CacheMvccAbstrac
 
             assertTrue(cache0.query(qry.setSql("SELECT _key, _val FROM Integer")).getAll().isEmpty());
 
-            assertEquals(3L, cache0.query(qry.setSql("INSERT INTO Integer (_key, _val) values (1,1),(2,2),(3,3)")).getAll().iterator().next().get(0));
+            assertEquals(
+                3L,
+                cache0.query(qry.setSql("INSERT INTO Integer (_key, _val) values (1,1),(2,2),(3,3)")).getAll().iterator().next().get(0)
+            );
 
             tx.commit();
         }
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/LongDestroyDurableBackgroundTaskTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/LongDestroyDurableBackgroundTaskTest.java
index 5fdfa62..b24ddee 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/LongDestroyDurableBackgroundTaskTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/LongDestroyDurableBackgroundTaskTest.java
@@ -114,7 +114,8 @@ public class LongDestroyDurableBackgroundTaskTest extends GridCommonAbstractTest
 
     /** */
     private final LogListener blockedSysCriticalThreadLsnr =
-        LogListener.matches("Blocked system-critical thread has been detected. This can lead to cluster-wide undefined behaviour [workerName=db-checkpoint-thread").build();
+        LogListener.matches("Blocked system-critical thread has been detected. " +
+            "This can lead to cluster-wide undefined behaviour [workerName=db-checkpoint-thread").build();
 
     /** Latch that waits for execution of durable background task. */
     private CountDownLatch pendingDelLatch;
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/database/RebuildIndexWithHistoricalRebalanceTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/database/RebuildIndexWithHistoricalRebalanceTest.java
index 1bd2da7..49ddec7 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/database/RebuildIndexWithHistoricalRebalanceTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/database/RebuildIndexWithHistoricalRebalanceTest.java
@@ -82,7 +82,7 @@ public class RebuildIndexWithHistoricalRebalanceTest extends GridCommonAbstractT
         private int account;
 
         /**
-         * @param a A.
+         * @param account A.
          */
         public UserKey(int account) {
             this.account = account;
@@ -238,7 +238,8 @@ public class RebuildIndexWithHistoricalRebalanceTest extends GridCommonAbstractT
 
     /** */
     private LogListener finishIndexRebuildLsnr(String cacheName) {
-        LogListener lsnr = LogListener.matches(s -> s.startsWith("Finished indexes rebuilding for cache [name=" + cacheName)).times(1).build();
+        LogListener lsnr =
+            LogListener.matches(s -> s.startsWith("Finished indexes rebuilding for cache [name=" + cacheName)).times(1).build();
 
         log.registerListener(lsnr);
 
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/database/baseline/IgniteChangingBaselineCacheQueryNodeRestartSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/database/baseline/IgniteChangingBaselineCacheQueryNodeRestartSelfTest.java
index 8acb09f..2b76f65 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/database/baseline/IgniteChangingBaselineCacheQueryNodeRestartSelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/database/baseline/IgniteChangingBaselineCacheQueryNodeRestartSelfTest.java
@@ -71,7 +71,10 @@ public class IgniteChangingBaselineCacheQueryNodeRestartSelfTest extends IgniteC
     }
 
     /** {@inheritDoc} */
-    @Override protected IgniteInternalFuture createRestartAction(final AtomicBoolean done, final AtomicInteger restartCnt) throws Exception {
+    @Override protected IgniteInternalFuture createRestartAction(
+        final AtomicBoolean done,
+        final AtomicInteger restartCnt
+    ) throws Exception {
         return multithreadedAsync(new Callable<Object>() {
             /** */
             private final long baselineTopChangeInterval = 10 * 1000;
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/database/baseline/IgniteStableBaselineCacheQueryNodeRestartsSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/database/baseline/IgniteStableBaselineCacheQueryNodeRestartsSelfTest.java
index 24d2b49..f9b91fb 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/database/baseline/IgniteStableBaselineCacheQueryNodeRestartsSelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/database/baseline/IgniteStableBaselineCacheQueryNodeRestartsSelfTest.java
@@ -63,7 +63,10 @@ public class IgniteStableBaselineCacheQueryNodeRestartsSelfTest extends IgniteCa
     }
 
     /** {@inheritDoc} */
-    @Override protected IgniteInternalFuture createRestartAction(final AtomicBoolean done, final AtomicInteger restartCnt) throws Exception {
+    @Override protected IgniteInternalFuture createRestartAction(
+        final AtomicBoolean done,
+        final AtomicInteger restartCnt
+    ) throws Exception {
         return multithreadedAsync(new Callable<Object>() {
             /** */
             private final int logFreq = 50;
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/IgniteSqlKeyValueFieldsTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/IgniteSqlKeyValueFieldsTest.java
index b5c5406..6d9851e 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/IgniteSqlKeyValueFieldsTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/IgniteSqlKeyValueFieldsTest.java
@@ -308,7 +308,8 @@ public class IgniteSqlKeyValueFieldsTest extends AbstractIndexingCommonTest {
         checkInsert(cache2, "insert into Integer (_key, _val) values (?, ?)", 100, 1);
         checkInsert(cache2, "insert into Integer (_key, _val) values (?, ?)", 200, 2);
 
-        QueryCursor<List<?>> cursor = cache.query(new SqlFieldsQuery("select p.id, j._key from Person p, \"" + CACHE_JOB + "\".Integer j where p.id = j._val"));
+        QueryCursor<List<?>> cursor =
+            cache.query(new SqlFieldsQuery("select p.id, j._key from Person p, \"" + CACHE_JOB + "\".Integer j where p.id = j._val"));
         List<List<?>> results = cursor.getAll();
         assertEquals(2, results.size());
         assertEquals(1, results.get(0).get(0));
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/IgniteSqlSplitterSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/IgniteSqlSplitterSelfTest.java
index 7f83c36..26b6a7f 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/IgniteSqlSplitterSelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/IgniteSqlSplitterSelfTest.java
@@ -847,7 +847,8 @@ public class IgniteSqlSplitterSelfTest extends AbstractIndexingCommonTest {
             c1.put(4, new Person2(2, "p2"));
             c1.put(5, new Person2(3, "p3"));
 
-            String select0 = "select o.name n1, p.name n2 from \"pers\".Person2 p, \"org\".Organization o where p.orgId = o._key and o._key=1" +
+            String select0 =
+                "select o.name n1, p.name n2 from \"pers\".Person2 p, \"org\".Organization o where p.orgId = o._key and o._key=1" +
                 " union select o.name n1, p.name n2 from \"org\".Organization o, \"pers\".Person2 p where p.orgId = o._key and o._key=2";
 
             String plan = (String)c1.query(new SqlFieldsQuery("explain " + select0)
@@ -870,8 +871,10 @@ public class IgniteSqlSplitterSelfTest extends AbstractIndexingCommonTest {
             assertEquals(0, StringUtils.countOccurrencesOf(plan, "batched"));
             assertEquals(2, c1.query(new SqlFieldsQuery(select).setDistributedJoins(true)).getAll().size());
 
-            String select1 = "select o.name n1, p.name n2 from \"pers\".Person2 p, \"org\".Organization o where p.orgId = o._key and o._key=1" +
-                " union select * from (select o.name n1, p.name n2 from \"org\".Organization o, \"pers\".Person2 p where p.orgId = o._key and o._key=2)";
+            String select1 =
+                "select o.name n1, p.name n2 from \"pers\".Person2 p, \"org\".Organization o where p.orgId = o._key and o._key=1" +
+                " union select * from (" +
+                    "select o.name n1, p.name n2 from \"org\".Organization o, \"pers\".Person2 p where p.orgId = o._key and o._key=2)";
 
             plan = (String)c1.query(new SqlFieldsQuery("explain " + select1)
                 .setDistributedJoins(true)).getAll().get(0).get(0);
@@ -1089,8 +1092,8 @@ public class IgniteSqlSplitterSelfTest extends AbstractIndexingCommonTest {
 
             {
                 String sql = "select * from " +
-                    "(select o1._key k1, o2._key k2 from \"orgRepl\".Organization o1, \"orgRepl2\".Organization o2 where o1._key > o2._key) o, " +
-                    "\"persPart\".Person2 p where p.orgId = o.k1";
+                    "(select o1._key k1, o2._key k2 from \"orgRepl\".Organization o1, \"orgRepl2\".Organization o2 " +
+                    "where o1._key > o2._key) o, \"persPart\".Person2 p where p.orgId = o.k1";
 
                 checkQueryPlan(persPart,
                     false,
@@ -1373,7 +1376,8 @@ public class IgniteSqlSplitterSelfTest extends AbstractIndexingCommonTest {
             c1.put(4, new Person2(2, "p2"));
             c1.put(5, new Person2(3, "p3"));
 
-            String select0 = "select o.name n1, p.name n2 from \"pers\".Person2 p, \"org\".Organization o where p.orgId = o._key and o._key=1";
+            String select0 =
+                "select o.name n1, p.name n2 from \"pers\".Person2 p, \"org\".Organization o where p.orgId = o._key and o._key=1";
 
             checkQueryPlan(c1, true, 1, new SqlFieldsQuery(select0));
 
@@ -1489,7 +1493,8 @@ public class IgniteSqlSplitterSelfTest extends AbstractIndexingCommonTest {
             c1.put(4, new Person2(2, "p2"));
             c1.put(5, new Person2(3, "p3"));
 
-            String select0 = "select o.name n1, p.name n2 from \"pers\".Person2 p, \"org\".Organization o where p.orgId = o._key and o._key=1";
+            String select0 =
+                "select o.name n1, p.name n2 from \"pers\".Person2 p, \"org\".Organization o where p.orgId = o._key and o._key=1";
 
             final SqlFieldsQuery qry = new SqlFieldsQuery(select0);
 
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/KillQueryOnClientDisconnectTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/KillQueryOnClientDisconnectTest.java
index 18bac34..cab832c 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/KillQueryOnClientDisconnectTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/KillQueryOnClientDisconnectTest.java
@@ -188,14 +188,21 @@ public class KillQueryOnClientDisconnectTest extends GridCommonAbstractTest {
                 assertEquals(1, runningQueries.size());
 
                 IgniteInternalFuture fut = GridTestUtils.runAsync(() -> {
-                    clientNode().cache(DEFAULT_CACHE_NAME).query(new SqlFieldsQuery("KILL QUERY '" + runningQueries.get(0).globalQueryId() + "'"));
+                    clientNode().cache(DEFAULT_CACHE_NAME).query(
+                        new SqlFieldsQuery("KILL QUERY '" + runningQueries.get(0).globalQueryId() + "'")
+                    );
                 });
 
                 doSleep(500);
 
                 TestSQLFunctions.reqLatch.countDown();
 
-                GridTestUtils.assertThrows(log, () -> fut.get(TIMEOUT), IgniteCheckedException.class, "Failed to cancel query because local client node has been disconnected from the cluster");
+                GridTestUtils.assertThrows(
+                    log,
+                    () -> fut.get(TIMEOUT),
+                    IgniteCheckedException.class,
+                    "Failed to cancel query because local client node has been disconnected from the cluster"
+                );
             }
             catch (Exception e) {
                 log.error("Unexpected exception.", e);
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/SqlSystemViewsSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/SqlSystemViewsSelfTest.java
index 1aff1e8..3ff00b9 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/SqlSystemViewsSelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/SqlSystemViewsSelfTest.java
@@ -256,7 +256,9 @@ public class SqlSystemViewsSelfTest extends AbstractIndexingCommonTest {
 
         execSql("CREATE INDEX IDX_3 ON PUBLIC.DFLT_CACHE(MY_VAL)");
 
-        execSql("CREATE TABLE PUBLIC.DFLT_AFF_CACHE (ID1 INT, ID2 INT, MY_VAL VARCHAR, PRIMARY KEY (ID1 DESC, ID2)) WITH \"affinity_key=ID1\"");
+        execSql(
+            "CREATE TABLE PUBLIC.DFLT_AFF_CACHE (ID1 INT, ID2 INT, MY_VAL VARCHAR, PRIMARY KEY (ID1 DESC, ID2)) WITH \"affinity_key=ID1\""
+        );
 
         execSql("CREATE INDEX IDX_AFF_1 ON PUBLIC.DFLT_AFF_CACHE(ID2 DESC, ID1, MY_VAL DESC)");
 
@@ -282,27 +284,37 @@ public class SqlSystemViewsSelfTest extends AbstractIndexingCommonTest {
         //ToDo: As of now we can see duplicates columns within index due to https://issues.apache.org/jira/browse/IGNITE-11125
 
         Object[][] expectedResults = {
-                {-825022849, "SQL_PUBLIC_AFF_CACHE", "PUBLIC", "AFF_CACHE", "AFFINITY_KEY", "BTREE", "\"ID2\" ASC, \"ID1\" ASC", false, false, 10},
+                {-825022849, "SQL_PUBLIC_AFF_CACHE", "PUBLIC", "AFF_CACHE", "AFFINITY_KEY", "BTREE", "\"ID2\" ASC, \"ID1\" ASC",
+                    false, false, 10},
                 {-825022849, "SQL_PUBLIC_AFF_CACHE", "PUBLIC", "AFF_CACHE", "__SCAN_", "SCAN", null, false, false, null},
                 {-825022849, "SQL_PUBLIC_AFF_CACHE", "PUBLIC", "AFF_CACHE", "_key_PK", "BTREE", "\"ID1\" ASC, \"ID2\" ASC", true, true, 10},
-                {-825022849, "SQL_PUBLIC_AFF_CACHE", "PUBLIC", "AFF_CACHE", "_key_PK_hash", "HASH", "\"ID1\" ASC, \"ID2\" ASC, \"ID2\" ASC", false, true, null},
+                {-825022849, "SQL_PUBLIC_AFF_CACHE", "PUBLIC", "AFF_CACHE", "_key_PK_hash", "HASH",
+                    "\"ID1\" ASC, \"ID2\" ASC, \"ID2\" ASC", false, true, null},
 
                 {707660652, "SQL_PUBLIC_CACHE_SQL", "PUBLIC", "CACHE_SQL", "IDX_2", "BTREE", "\"ID\" DESC, \"ID\" ASC", false, false, 13},
                 {707660652, "SQL_PUBLIC_CACHE_SQL", "PUBLIC", "CACHE_SQL", "__SCAN_", "SCAN", null, false, false, null},
                 {707660652, "SQL_PUBLIC_CACHE_SQL", "PUBLIC", "CACHE_SQL", "_key_PK", "BTREE", "\"ID\" ASC", true, true, 5},
                 {707660652, "SQL_PUBLIC_CACHE_SQL", "PUBLIC", "CACHE_SQL", "_key_PK_hash", "HASH", "\"ID\" ASC", false, true, null},
 
-                {1374144180, "SQL_PUBLIC_DFLT_AFF_CACHE", "PUBLIC", "DFLT_AFF_CACHE", "AFFINITY_KEY", "BTREE", "\"ID1\" ASC, \"ID2\" ASC", false, false, 10},
-                {1374144180, "SQL_PUBLIC_DFLT_AFF_CACHE", "PUBLIC", "DFLT_AFF_CACHE", "IDX_AFF_1", "BTREE", "\"ID2\" DESC, \"ID1\" ASC, \"MY_VAL\" DESC", false, false, 10},
+                {1374144180, "SQL_PUBLIC_DFLT_AFF_CACHE", "PUBLIC", "DFLT_AFF_CACHE", "AFFINITY_KEY", "BTREE",
+                    "\"ID1\" ASC, \"ID2\" ASC", false, false, 10},
+                {1374144180, "SQL_PUBLIC_DFLT_AFF_CACHE", "PUBLIC", "DFLT_AFF_CACHE", "IDX_AFF_1", "BTREE",
+                    "\"ID2\" DESC, \"ID1\" ASC, \"MY_VAL\" DESC", false, false, 10},
                 {1374144180, "SQL_PUBLIC_DFLT_AFF_CACHE", "PUBLIC", "DFLT_AFF_CACHE", "__SCAN_", "SCAN", null, false, false, null},
-                {1374144180, "SQL_PUBLIC_DFLT_AFF_CACHE", "PUBLIC", "DFLT_AFF_CACHE", "_key_PK", "BTREE", "\"ID1\" ASC, \"ID2\" ASC", true, true, 10},
-                {1374144180, "SQL_PUBLIC_DFLT_AFF_CACHE", "PUBLIC", "DFLT_AFF_CACHE", "_key_PK_hash", "HASH", "\"ID1\" ASC, \"ID2\" ASC, \"ID1\" ASC", false, true, null},
-
-                {1102275506, "SQL_PUBLIC_DFLT_CACHE", "PUBLIC", "DFLT_CACHE", "IDX_1", "BTREE", "\"ID2\" DESC, \"ID1\" ASC, \"MY_VAL\" DESC, \"ID1\" ASC, \"ID2\" ASC", false, false, 10},
-                {1102275506, "SQL_PUBLIC_DFLT_CACHE", "PUBLIC", "DFLT_CACHE", "IDX_3", "BTREE", "\"MY_VAL\" ASC, \"ID1\" ASC, \"ID2\" ASC, \"ID1\" ASC, \"ID2\" ASC", false, false, 10},
+                {1374144180, "SQL_PUBLIC_DFLT_AFF_CACHE", "PUBLIC", "DFLT_AFF_CACHE", "_key_PK", "BTREE",
+                    "\"ID1\" ASC, \"ID2\" ASC", true, true, 10},
+                {1374144180, "SQL_PUBLIC_DFLT_AFF_CACHE", "PUBLIC", "DFLT_AFF_CACHE", "_key_PK_hash", "HASH",
+                    "\"ID1\" ASC, \"ID2\" ASC, \"ID1\" ASC", false, true, null},
+
+                {1102275506, "SQL_PUBLIC_DFLT_CACHE", "PUBLIC", "DFLT_CACHE", "IDX_1", "BTREE",
+                    "\"ID2\" DESC, \"ID1\" ASC, \"MY_VAL\" DESC, \"ID1\" ASC, \"ID2\" ASC", false, false, 10},
+                {1102275506, "SQL_PUBLIC_DFLT_CACHE", "PUBLIC", "DFLT_CACHE", "IDX_3", "BTREE",
+                    "\"MY_VAL\" ASC, \"ID1\" ASC, \"ID2\" ASC, \"ID1\" ASC, \"ID2\" ASC", false, false, 10},
                 {1102275506, "SQL_PUBLIC_DFLT_CACHE", "PUBLIC", "DFLT_CACHE", "__SCAN_", "SCAN", null, false, false, null},
-                {1102275506, "SQL_PUBLIC_DFLT_CACHE", "PUBLIC", "DFLT_CACHE", "_key_PK", "BTREE", "\"ID1\" ASC, \"ID2\" ASC", true, true, 10},
-                {1102275506, "SQL_PUBLIC_DFLT_CACHE", "PUBLIC", "DFLT_CACHE", "_key_PK_hash", "HASH", "\"ID1\" ASC, \"ID2\" ASC", false, true, null},
+                {1102275506, "SQL_PUBLIC_DFLT_CACHE", "PUBLIC", "DFLT_CACHE", "_key_PK", "BTREE",
+                    "\"ID1\" ASC, \"ID2\" ASC", true, true, 10},
+                {1102275506, "SQL_PUBLIC_DFLT_CACHE", "PUBLIC", "DFLT_CACHE", "_key_PK_hash", "HASH",
+                    "\"ID1\" ASC, \"ID2\" ASC", false, true, null},
 
                 {2584860, "TST1", "TST1", "VALUECLASS", "TST1_INDEX", "BTREE", "\"KEY\" ASC, \"_KEY\" ASC", false, false, 10},
                 {2584860, "TST1", "TST1", "VALUECLASS", "__SCAN_", "SCAN", null, false, false, null},
@@ -413,7 +425,9 @@ public class SqlSystemViewsSelfTest extends AbstractIndexingCommonTest {
     /**
      * @return Default cache configuration.
      */
-    protected CacheConfiguration<AbstractSchemaSelfTest.KeyClass, AbstractSchemaSelfTest.ValueClass> cacheConfiguration(String cacheName) throws Exception {
+    protected CacheConfiguration<AbstractSchemaSelfTest.KeyClass, AbstractSchemaSelfTest.ValueClass> cacheConfiguration(
+        String cacheName
+    ) throws Exception {
         CacheConfiguration ccfg = new CacheConfiguration().setName(cacheName);
 
         QueryEntity entity = new QueryEntity();
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/database/inlinecolumn/InlineIndexColumnTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/database/inlinecolumn/InlineIndexColumnTest.java
index 474f727..3223f33 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/database/inlinecolumn/InlineIndexColumnTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/database/inlinecolumn/InlineIndexColumnTest.java
@@ -182,13 +182,28 @@ public class InlineIndexColumnTest extends AbstractIndexingCommonTest {
 
         assertEquals(0, putAndCompare("\ud802\udd20\ud802\udd20", "\ud802\udd20\ud802\udd20", String.class, maxSize));
         assertEquals(-1, putAndCompare("\ud802\udd20\ud802\udd20", "\ud802\udd21\ud802\udd21", String.class, maxSize));
-        assertEquals(-1, putAndCompare("\ud802\udd20\ud802\udd20\ud802\udd20", "\ud802\udd21\ud802\udd21\ud802\udd21", String.class, maxSize));
-        assertEquals(1, putAndCompare("\ud802\udd21\ud802\udd21\ud802\udd21", "\ud802\udd20\ud802\udd20\ud802\udd20", String.class, maxSize));
+        assertEquals(
+            -1,
+            putAndCompare("\ud802\udd20\ud802\udd20\ud802\udd20", "\ud802\udd21\ud802\udd21\ud802\udd21", String.class, maxSize)
+        );
+        assertEquals(
+            1,
+            putAndCompare("\ud802\udd21\ud802\udd21\ud802\udd21", "\ud802\udd20\ud802\udd20\ud802\udd20", String.class, maxSize)
+        );
         assertEquals(1, putAndCompare("\ud802\udd20\ud802\udd20\ud802\udd20", "\ud802\udd20\ud802\udd20", String.class, maxSize));
         assertEquals(1, putAndCompare("\ud802\udd20\ud802\udd20\ud802\udd20", "\ud802\udd20", String.class, maxSize));
-        assertEquals(-2, putAndCompare("\ud802\udd20\ud802\udd20\ud802\udd20", "\ud802\udd20\ud802\udd20\ud802\udd20", String.class, maxSize));
-        assertEquals(-2, putAndCompare("\ud802\udd20\ud802\udd20\ud802\udd20", "\ud802\udd20\ud802\udd20\ud802\udd21", String.class, maxSize));
-        assertEquals(-2, putAndCompare("\ud802\udd20\ud802\udd20\ud802\udd21", "\ud802\udd20\ud802\udd20\ud802\udd20", String.class, maxSize));
+        assertEquals(
+            -2,
+            putAndCompare("\ud802\udd20\ud802\udd20\ud802\udd20", "\ud802\udd20\ud802\udd20\ud802\udd20", String.class, maxSize)
+        );
+        assertEquals(
+            -2,
+            putAndCompare("\ud802\udd20\ud802\udd20\ud802\udd20", "\ud802\udd20\ud802\udd20\ud802\udd21", String.class, maxSize)
+        );
+        assertEquals(
+            -2,
+            putAndCompare("\ud802\udd20\ud802\udd20\ud802\udd21", "\ud802\udd20\ud802\udd20\ud802\udd20", String.class, maxSize)
+        );
     }
 
     /** */
@@ -706,8 +721,15 @@ public class InlineIndexColumnTest extends AbstractIndexingCommonTest {
         assertEquals(-1, putAndCompare(Date.valueOf("2017-02-16"), Date.valueOf("2017-02-24"), Date.class, maxSize));
         assertEquals(0, putAndCompare(Date.valueOf("2017-02-24"), Date.valueOf("2017-02-24"), Date.class, maxSize));
         assertEquals(-2, putAndCompare(Date.valueOf("2017-02-24"), Date.valueOf("2017-02-20"), Date.class, maxSize - 1));
-        assertEquals(-1, putAndCompare(new Date(Long.MIN_VALUE - DateTimeUtils.getTimeZoneOffsetMillis(TimeZone.getDefault(), Long.MIN_VALUE, 0)),
-            new Date(Long.MAX_VALUE - DateTimeUtils.getTimeZoneOffsetMillis(TimeZone.getDefault(), Long.MAX_VALUE, 0)), Date.class, maxSize));
+        assertEquals(
+            -1,
+            putAndCompare(
+                new Date(Long.MIN_VALUE - DateTimeUtils.getTimeZoneOffsetMillis(TimeZone.getDefault(), Long.MIN_VALUE, 0)),
+                new Date(Long.MAX_VALUE - DateTimeUtils.getTimeZoneOffsetMillis(TimeZone.getDefault(), Long.MAX_VALUE, 0)),
+                Date.class,
+                maxSize
+            )
+        );
     }
 
     /** */
@@ -736,16 +758,47 @@ public class InlineIndexColumnTest extends AbstractIndexingCommonTest {
 
         int maxSize = 1 + 16; // 1 byte header + 16 bytes value.
 
-        assertEquals(1, putAndCompare(Timestamp.valueOf("2017-02-20 4:20:00"), null, Timestamp.class, maxSize));
-        assertEquals(1, putAndCompare(Timestamp.valueOf("2017-02-20 4:20:00"), Timestamp.valueOf("2017-02-19 4:20:00"), Timestamp.class, maxSize));
-        assertEquals(-1, putAndCompare(Timestamp.valueOf("2017-02-19 4:20:00"), Timestamp.valueOf("2017-02-20 4:20:00"), Timestamp.class, maxSize));
-        assertEquals(1, putAndCompare(Timestamp.valueOf("2017-02-20 4:20:00"), Timestamp.valueOf("2017-02-20 4:19:59"), Timestamp.class, maxSize));
-        assertEquals(-1, putAndCompare(Timestamp.valueOf("2017-02-20 4:19:59"), Timestamp.valueOf("2017-02-20 4:20:00"), Timestamp.class, maxSize));
-        assertEquals(0, putAndCompare(Timestamp.valueOf("2017-02-20 4:20:00"), Timestamp.valueOf("2017-02-20 4:20:00"), Timestamp.class, maxSize));
-        assertEquals(-2, putAndCompare(Timestamp.valueOf("2017-02-20 4:19:59"), Timestamp.valueOf("2017-02-20 4:20:00"), Timestamp.class, maxSize - 1));
-        assertEquals(-1, putAndCompare(Timestamp.valueOf("2017-02-20 00:00:00"), Timestamp.valueOf("2017-02-20 23:59:59"), Timestamp.class, maxSize));
-        assertEquals(-1, putAndCompare(new Timestamp(Long.MIN_VALUE - DateTimeUtils.getTimeZoneOffsetMillis(TimeZone.getDefault(), Long.MAX_VALUE, 0)),
-            new Timestamp(Long.MAX_VALUE - DateTimeUtils.getTimeZoneOffsetMillis(TimeZone.getDefault(), Long.MAX_VALUE, 0)), Timestamp.class, maxSize));
+        assertEquals(
+            1,
+            putAndCompare(Timestamp.valueOf("2017-02-20 4:20:00"), null, Timestamp.class, maxSize)
+        );
+        assertEquals(
+            1,
+            putAndCompare(Timestamp.valueOf("2017-02-20 4:20:00"), Timestamp.valueOf("2017-02-19 4:20:00"), Timestamp.class, maxSize)
+        );
+        assertEquals(
+            -1,
+            putAndCompare(Timestamp.valueOf("2017-02-19 4:20:00"), Timestamp.valueOf("2017-02-20 4:20:00"), Timestamp.class, maxSize)
+        );
+        assertEquals(
+            1,
+            putAndCompare(Timestamp.valueOf("2017-02-20 4:20:00"), Timestamp.valueOf("2017-02-20 4:19:59"), Timestamp.class, maxSize)
+        );
+        assertEquals(
+            -1,
+            putAndCompare(Timestamp.valueOf("2017-02-20 4:19:59"), Timestamp.valueOf("2017-02-20 4:20:00"), Timestamp.class, maxSize)
+        );
+        assertEquals(
+            0,
+            putAndCompare(Timestamp.valueOf("2017-02-20 4:20:00"), Timestamp.valueOf("2017-02-20 4:20:00"), Timestamp.class, maxSize)
+        );
+        assertEquals(
+            -2,
+            putAndCompare(Timestamp.valueOf("2017-02-20 4:19:59"), Timestamp.valueOf("2017-02-20 4:20:00"), Timestamp.class, maxSize - 1)
+        );
+        assertEquals(
+            -1,
+            putAndCompare(Timestamp.valueOf("2017-02-20 00:00:00"), Timestamp.valueOf("2017-02-20 23:59:59"), Timestamp.class, maxSize)
+        );
+        assertEquals(
+            -1,
+            putAndCompare(
+                new Timestamp(Long.MIN_VALUE - DateTimeUtils.getTimeZoneOffsetMillis(TimeZone.getDefault(), Long.MAX_VALUE, 0)),
+                new Timestamp(Long.MAX_VALUE - DateTimeUtils.getTimeZoneOffsetMillis(TimeZone.getDefault(), Long.MAX_VALUE, 0)),
+                Timestamp.class,
+                maxSize
+            )
+        );
     }
 
     /** */
@@ -782,7 +835,10 @@ public class InlineIndexColumnTest extends AbstractIndexingCommonTest {
         assertEquals(-1, putAndCompare(new TestPojo(16, 16L), new TestPojo(42, 16L), TestPojo.class, maxSize));
         assertEquals(-2, putAndCompare(new TestPojo(42, 16L), new TestPojo(42, 16L), TestPojo.class, maxSize));
         assertEquals(1, putAndCompare(new TestPojo(Integer.MAX_VALUE, 16L), new TestPojo(Integer.MIN_VALUE, 16L), TestPojo.class, maxSize));
-        assertEquals(-1, putAndCompare(new TestPojo(Integer.MIN_VALUE, 16L), new TestPojo(Integer.MAX_VALUE, 16L), TestPojo.class, maxSize));
+        assertEquals(
+            -1,
+            putAndCompare(new TestPojo(Integer.MIN_VALUE, 16L), new TestPojo(Integer.MAX_VALUE, 16L), TestPojo.class, maxSize)
+        );
         assertEquals(-2, putAndCompare(new TestPojo(42, 16L), new TestPojo(16, 16L), TestPojo.class, maxSize - 1));
     }
 
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/sql/BaseH2CompareQueryTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/sql/BaseH2CompareQueryTest.java
index 3546df6..390093c 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/sql/BaseH2CompareQueryTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/sql/BaseH2CompareQueryTest.java
@@ -117,7 +117,13 @@ public class BaseH2CompareQueryTest extends AbstractH2CompareQueryTest {
 
     /** {@inheritDoc} */
     @Override protected void createCaches() {
-        cacheOrg = jcache(ignite, cacheConfiguration(ORG, CacheMode.PARTITIONED, Integer.class, Organization.class), ORG, Integer.class, Organization.class);
+        cacheOrg = jcache(
+            ignite,
+            cacheConfiguration(ORG, CacheMode.PARTITIONED, Integer.class, Organization.class),
+            ORG,
+            Integer.class,
+            Organization.class
+        );
         cachePers = ignite.cache(PERS);
         cachePurch = ignite.cache(PURCH);
         cacheProd = ignite.cache(PROD);
@@ -317,7 +323,9 @@ public class BaseH2CompareQueryTest extends AbstractH2CompareQueryTest {
         compareQueryRes0(cachePers, "select distinct firstName, street from \"pers\".Person, " +
             "\"addr\".Address");
         // TODO uncomment and investigate (Rows count has to be equal.: Expected :2500, Actual :900)
-//        compareQueryRes0("select p1.firstName, a2.street from \"part\".Person p1, \"repl\".Address a1, \"part\".Person p2, \"repl\".Address a2");
+        //compareQueryRes0(
+        //    "select p1.firstName, a2.street from \"part\".Person p1, \"repl\".Address a1, \"part\".Person p2, \"repl\".Address a2"
+        //);
 
         //TODO look at it (org.h2.jdbc.JdbcSQLException: Feature not supported: "VARCHAR +" // at H2)
 //        compareQueryRes0("select p.firstName n, a.street s from \"part\".Person p, \"repl\".Address a");
@@ -347,7 +355,8 @@ public class BaseH2CompareQueryTest extends AbstractH2CompareQueryTest {
 
         // TODO analyse
 //        compareQueryRes0("select " + star + " from \"part\".Person p where p.firstName in ('a', 'b', '_' + RAND())"); // test ConditionIn
-        compareQueryRes0(cachePers, "select " + star + " from \"pers\".Person p where p.firstName in ('a', 'b', 'c')"); // test ConditionInConstantSet
+        // test ConditionInConstantSet
+        compareQueryRes0(cachePers, "select " + star + " from \"pers\".Person p where p.firstName in ('a', 'b', 'c')");
         compareQueryRes0(cachePers, "select " + star + " from \"pers\".Person p " +
             "where p.firstName in (select a.street from \"addr\".Address a)"); // test ConditionInConstantSet
 
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/sql/H2CompareBigQueryTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/sql/H2CompareBigQueryTest.java
index 073594c..5d7dd32 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/sql/H2CompareBigQueryTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/sql/H2CompareBigQueryTest.java
@@ -104,8 +104,18 @@ public class H2CompareBigQueryTest extends AbstractH2CompareQueryTest {
 
         cfg.setCacheConfiguration(
             cacheConfiguration("custord", CacheMode.PARTITIONED, Integer.class, CustOrder.class),
-            cacheConfiguration("replord", CacheMode.PARTITIONED, useColocatedData() ? AffinityKey.class : Integer.class, ReplaceOrder.class),
-            cacheConfiguration("ordparam", CacheMode.PARTITIONED, useColocatedData() ? AffinityKey.class : Integer.class, OrderParams.class),
+            cacheConfiguration(
+                "replord",
+                CacheMode.PARTITIONED,
+                useColocatedData() ? AffinityKey.class : Integer.class,
+                ReplaceOrder.class
+            ),
+            cacheConfiguration(
+                "ordparam",
+                CacheMode.PARTITIONED,
+                useColocatedData() ? AffinityKey.class : Integer.class,
+                OrderParams.class
+            ),
             cacheConfiguration("cancel", CacheMode.PARTITIONED, useColocatedData() ? AffinityKey.class : Integer.class, Cancel.class),
             cacheConfiguration("exec", CacheMode.REPLICATED, useColocatedData() ? AffinityKey.class : Integer.class, Exec.class));
 
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/twostep/DisappearedCacheCauseRetryMessageSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/twostep/DisappearedCacheCauseRetryMessageSelfTest.java
index 521721d..0054b28 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/twostep/DisappearedCacheCauseRetryMessageSelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/twostep/DisappearedCacheCauseRetryMessageSelfTest.java
@@ -74,7 +74,10 @@ public class DisappearedCacheCauseRetryMessageSelfTest extends AbstractIndexingC
             if (!e.getMessage().contains("Failed to reserve partitions for query (cache is not found on local node) ["))
                 e.printStackTrace();
 
-            assertTrue(e.getMessage(), e.getMessage().contains("Failed to reserve partitions for query (cache is not found on local node) ["));
+            assertTrue(
+                e.getMessage(),
+                e.getMessage().contains("Failed to reserve partitions for query (cache is not found on local node) [")
+            );
         }
     }
 
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/twostep/RetryCauseMessageSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/twostep/RetryCauseMessageSelfTest.java
index a1f670e..ba605ff 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/twostep/RetryCauseMessageSelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/twostep/RetryCauseMessageSelfTest.java
@@ -116,7 +116,10 @@ public class RetryCauseMessageSelfTest extends AbstractIndexingCommonTest {
             personCache.query(qry).getAll();
         }
         catch (CacheException e) {
-            assertTrue(e.getMessage(), e.getMessage().contains("Failed to reserve partitions for query (cache is not found on local node) ["));
+            assertTrue(
+                e.getMessage(),
+                e.getMessage().contains("Failed to reserve partitions for query (cache is not found on local node) [")
+            );
 
             return;
         }
@@ -206,7 +209,9 @@ public class RetryCauseMessageSelfTest extends AbstractIndexingCommonTest {
             orgCache.query(qry).getAll();
         }
         catch (CacheException e) {
-            assertTrue(e.getMessage().contains("Failed to reserve partitions for query (partition of REPLICATED cache is not in OWNING state) ["));
+            assertTrue(
+                e.getMessage().contains("Failed to reserve partitions for query (partition of REPLICATED cache is not in OWNING state) [")
+            );
 
             return;
         }
diff --git a/modules/ml/spark-model-parser/src/main/java/org/apache/ignite/ml/sparkmodelparser/SparkModelParser.java b/modules/ml/spark-model-parser/src/main/java/org/apache/ignite/ml/sparkmodelparser/SparkModelParser.java
index 373da3a..203cfd5 100644
--- a/modules/ml/spark-model-parser/src/main/java/org/apache/ignite/ml/sparkmodelparser/SparkModelParser.java
+++ b/modules/ml/spark-model-parser/src/main/java/org/apache/ignite/ml/sparkmodelparser/SparkModelParser.java
@@ -315,7 +315,10 @@ public class SparkModelParser {
         }
 
         String ignitePathToMdlMetaData = mdlRsrc2.getPath();
-        learningEnvironment.logger().log(MLLogger.VerboseLevel.LOW, "Starting loading model metadata by the path: " + ignitePathToMdlMetaData);
+        learningEnvironment.logger().log(
+            MLLogger.VerboseLevel.LOW,
+            "Starting loading model metadata by the path: " + ignitePathToMdlMetaData
+        );
 
         switch (parsedSparkMdl) {
             case GRADIENT_BOOSTED_TREES:
diff --git a/modules/ml/spark-model-parser/src/test/java/org/apache/ignite/ml/sparkmodelparser/SparkModelParserTest.java b/modules/ml/spark-model-parser/src/test/java/org/apache/ignite/ml/sparkmodelparser/SparkModelParserTest.java
index e8a0f2b..cb49382 100644
--- a/modules/ml/spark-model-parser/src/test/java/org/apache/ignite/ml/sparkmodelparser/SparkModelParserTest.java
+++ b/modules/ml/spark-model-parser/src/test/java/org/apache/ignite/ml/sparkmodelparser/SparkModelParserTest.java
@@ -35,8 +35,9 @@ import static org.junit.Assert.assertTrue;
  */
 public class SparkModelParserTest {
     /** Learning environment. */
-    LearningEnvironment env = LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
-        .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
+    LearningEnvironment env =
+        LearningEnvironmentBuilder.defaultBuilder().withParallelismStrategyTypeDependency(ParallelismStrategy.ON_DEFAULT_POOL)
+            .withLoggingFactoryDependency(ConsoleLogger.Factory.HIGH).buildForTrainer();
 
     /** Expected exception. */
     @Rule
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/clustering/kmeans/KMeansModel.java b/modules/ml/src/main/java/org/apache/ignite/ml/clustering/kmeans/KMeansModel.java
index de473c9..d682de0 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/clustering/kmeans/KMeansModel.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/clustering/kmeans/KMeansModel.java
@@ -195,7 +195,11 @@ public final class KMeansModel implements ClusterizationModel<Vector, Integer>,
             ObjectMapper mapper = new ObjectMapper();
 
             try {
-                KMeansJSONExportModel exportModel = new KMeansJSONExportModel(System.currentTimeMillis(), "ann_" + UUID.randomUUID().toString(), KMeansModel.class.getSimpleName());
+                KMeansJSONExportModel exportModel = new KMeansJSONExportModel(
+                    System.currentTimeMillis(),
+                    "ann_" + UUID.randomUUID().toString(),
+                    KMeansModel.class.getSimpleName()
+                );
                 List<double[]> listOfCenters = new ArrayList<>();
                 for (int i = 0; i < centers.length; i++) {
                     listOfCenters.add(centers[i].asArray());
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/composition/ModelsComposition.java b/modules/ml/src/main/java/org/apache/ignite/ml/composition/ModelsComposition.java
index 190203c..c3a13a1 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/composition/ModelsComposition.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/composition/ModelsComposition.java
@@ -32,8 +32,8 @@ import org.apache.ignite.ml.util.ModelTrace;
 /**
  * Model consisting of several models and prediction aggregation strategy.
  */
-public class ModelsComposition<M extends IgniteModel<Vector, Double>> implements IgniteModel<Vector, Double>, Exportable<ModelsCompositionFormat>,
-    DeployableObject {
+public class ModelsComposition<M extends IgniteModel<Vector, Double>>
+    implements IgniteModel<Vector, Double>, Exportable<ModelsCompositionFormat>, DeployableObject {
     /**
      * Predictions aggregator.
      */
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/composition/bagging/BaggedTrainer.java b/modules/ml/src/main/java/org/apache/ignite/ml/composition/bagging/BaggedTrainer.java
index 456eeed..360659a 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/composition/bagging/BaggedTrainer.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/composition/bagging/BaggedTrainer.java
@@ -126,8 +126,8 @@ public class BaggedTrainer<L> extends
             .map(CompositionUtils::unsafeCoerce)
             .collect(Collectors.toList());
 
-        AdaptableDatasetTrainer<Vector, Double, Vector, List<Double>, IgniteModel<Vector, List<Double>>, L> finalTrainer = AdaptableDatasetTrainer.of(
-            new TrainersParallelComposition<>(
+        AdaptableDatasetTrainer<Vector, Double, Vector, List<Double>, IgniteModel<Vector, List<Double>>, L> finalTrainer =
+            AdaptableDatasetTrainer.of(new TrainersParallelComposition<>(
                 subspaceTrainers)).afterTrainedModel(l -> aggregator.apply(l.stream().mapToDouble(Double::valueOf).toArray()));
 
         return CompositionUtils.unsafeCoerce(finalTrainer);
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/dataset/impl/cache/CacheBasedDataset.java b/modules/ml/src/main/java/org/apache/ignite/ml/dataset/impl/cache/CacheBasedDataset.java
index 66d2a36..500057f 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/dataset/impl/cache/CacheBasedDataset.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/dataset/impl/cache/CacheBasedDataset.java
@@ -204,7 +204,8 @@ public class CacheBasedDataset<K, V, C extends Serializable, D extends AutoClose
      */
     private <R> R computeForAllPartitions(IgniteFunction<Integer, R> fun, IgniteBinaryOperator<R> reduce, R identity) {
         Collection<String> cacheNames = Arrays.asList(datasetCache.getName(), upstreamCache.getName());
-        Collection<R> results = ComputeUtils.affinityCallWithRetries(ignite, cacheNames, fun, retries, RETRY_INTERVAL, locLearningEnv.deployingContext());
+        Collection<R> results =
+            ComputeUtils.affinityCallWithRetries(ignite, cacheNames, fun, retries, RETRY_INTERVAL, locLearningEnv.deployingContext());
 
         R res = identity;
         for (R partRes : results)
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/dataset/impl/cache/CacheBasedDatasetBuilder.java b/modules/ml/src/main/java/org/apache/ignite/ml/dataset/impl/cache/CacheBasedDatasetBuilder.java
index 1604aa9bd..c3d4135 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/dataset/impl/cache/CacheBasedDatasetBuilder.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/dataset/impl/cache/CacheBasedDatasetBuilder.java
@@ -164,7 +164,19 @@ public class CacheBasedDatasetBuilder<K, V> implements DatasetBuilder<K, V> {
             localLearningEnv.deployingContext()
         );
 
-        return new CacheBasedDataset<>(ignite, upstreamCache, filter, transformerBuilder, datasetCache, envBuilder, partDataBuilder, datasetId, upstreamKeepBinary, localLearningEnv, retries);
+        return new CacheBasedDataset<>(
+            ignite,
+            upstreamCache,
+            filter,
+            transformerBuilder,
+            datasetCache,
+            envBuilder,
+            partDataBuilder,
+            datasetId,
+            upstreamKeepBinary,
+            localLearningEnv,
+            retries
+        );
     }
 
     /** {@inheritDoc} */
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/dataset/impl/local/LocalDatasetBuilder.java b/modules/ml/src/main/java/org/apache/ignite/ml/dataset/impl/local/LocalDatasetBuilder.java
index b00d480..14a1e49 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/dataset/impl/local/LocalDatasetBuilder.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/dataset/impl/local/LocalDatasetBuilder.java
@@ -137,8 +137,9 @@ public class LocalDatasetBuilder<K, V> implements DatasetBuilder<K, V> {
 
             int cnt = (int)transformer1.transform(Utils.asStream(new IteratorWindow<>(thirdKeysIter, k -> k, cntBeforeTransform))).count();
 
-            Iterator<UpstreamEntry> iter =
-                transformer2.transform(Utils.asStream(new IteratorWindow<>(firstKeysIter, k -> k, cntBeforeTransform)).map(x -> (UpstreamEntry)x)).iterator();
+            Iterator<UpstreamEntry> iter = transformer2.transform(
+                Utils.asStream(new IteratorWindow<>(firstKeysIter, k -> k, cntBeforeTransform)).map(x -> (UpstreamEntry)x)
+            ).iterator();
             Iterator<UpstreamEntry<K, V>> convertedBack = Utils.asStream(iter).map(x -> (UpstreamEntry<K, V>)x).iterator();
 
             C ctx = cntBeforeTransform > 0 ? partCtxBuilder.build(env, convertedBack, cnt) : null;
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/knn/ann/ANNClassificationModel.java b/modules/ml/src/main/java/org/apache/ignite/ml/knn/ann/ANNClassificationModel.java
index 6015900..ac70874 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/knn/ann/ANNClassificationModel.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/knn/ann/ANNClassificationModel.java
@@ -249,7 +249,11 @@ public final class ANNClassificationModel extends NNClassificationModel implemen
         ObjectMapper mapper = new ObjectMapper().configure(SerializationFeature.FAIL_ON_EMPTY_BEANS, false);
 
         try {
-            ANNJSONExportModel exportModel = new ANNJSONExportModel(System.currentTimeMillis(), "ann_" + UUID.randomUUID().toString(), ANNClassificationModel.class.getSimpleName());
+            ANNJSONExportModel exportModel = new ANNJSONExportModel(
+                System.currentTimeMillis(),
+                "ann_" + UUID.randomUUID(),
+                ANNClassificationModel.class.getSimpleName()
+            );
             List<double[]> listOfCandidates = new ArrayList<>();
             ProbableLabel[] labels = new ProbableLabel[candidates.rowSize()];
             for (int i = 0; i < candidates.rowSize(); i++) {
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/knn/ann/ANNClassificationTrainer.java b/modules/ml/src/main/java/org/apache/ignite/ml/knn/ann/ANNClassificationTrainer.java
index eec8713..d69adc4 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/knn/ann/ANNClassificationTrainer.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/knn/ann/ANNClassificationTrainer.java
@@ -160,7 +160,11 @@ public class ANNClassificationTrainer extends SingleLabelDatasetTrainer<ANNClass
                 .get(centroidIdx);
 
             clsLbls.keySet().forEach(
-                (label) -> clsLbls.put(label, centroidLbDistribution.containsKey(label) ? ((double)(centroidLbDistribution.get(label)) / clusterSize) : 0.0)
+                (label) -> clsLbls.put(
+                    label,
+                    centroidLbDistribution.containsKey(label)
+                        ? ((double)(centroidLbDistribution.get(label)) / clusterSize)
+                        : 0.0)
             );
         }
         return new ProbableLabel(clsLbls);
@@ -171,7 +175,8 @@ public class ANNClassificationTrainer extends SingleLabelDatasetTrainer<ANNClass
                                                 Preprocessor<K, V> vectorizer,
                                                 List<Vector> centers) {
 
-        PartitionDataBuilder<K, V, EmptyContext, LabeledVectorSet<LabeledVector>> partDataBuilder = new LabeledDatasetPartitionDataBuilderOnHeap<>(vectorizer);
+        PartitionDataBuilder<K, V, EmptyContext, LabeledVectorSet<LabeledVector>> partDataBuilder =
+            new LabeledDatasetPartitionDataBuilderOnHeap<>(vectorizer);
 
         try (Dataset<EmptyContext, LabeledVectorSet<LabeledVector>> dataset = datasetBuilder.build(
             envBuilder,
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/math/exceptions/preprocessing/IllegalFeatureTypeException.java b/modules/ml/src/main/java/org/apache/ignite/ml/math/exceptions/preprocessing/IllegalFeatureTypeException.java
index 4c5ed6e..8bb1b6f 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/math/exceptions/preprocessing/IllegalFeatureTypeException.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/math/exceptions/preprocessing/IllegalFeatureTypeException.java
@@ -32,6 +32,7 @@ public class IllegalFeatureTypeException extends IgniteException {
      * @param desiredCls The desired type.
      */
     public IllegalFeatureTypeException(Class illegalCls, Object illegalVal, Class desiredCls) {
-        super("The type of feature " + illegalCls + " is illegal. The found value is: " + illegalVal + " The type of label should be " + desiredCls);
+        super("The type of feature " + illegalCls + " is illegal. " +
+            "The found value is: " + illegalVal + " The type of label should be " + desiredCls);
     }
 }
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/math/exceptions/preprocessing/IllegalLabelTypeException.java b/modules/ml/src/main/java/org/apache/ignite/ml/math/exceptions/preprocessing/IllegalLabelTypeException.java
index 8817403..1830b05 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/math/exceptions/preprocessing/IllegalLabelTypeException.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/math/exceptions/preprocessing/IllegalLabelTypeException.java
@@ -32,6 +32,7 @@ public class IllegalLabelTypeException extends IgniteException {
      * @param desiredCls The desired type.
      */
     public IllegalLabelTypeException(Class illegalCls, Object illegalVal, Class desiredCls) {
-        super("The type of label " + illegalCls + " is illegal. The found value is: " + illegalVal + " The type of label should be " + desiredCls);
+        super("The type of label " + illegalCls + " is illegal. " +
+            "The found value is: " + illegalVal + " The type of label should be " + desiredCls);
     }
 }
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/multiclass/MultiClassModel.java b/modules/ml/src/main/java/org/apache/ignite/ml/multiclass/MultiClassModel.java
index 78d1cda..07ff1be 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/multiclass/MultiClassModel.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/multiclass/MultiClassModel.java
@@ -28,7 +28,8 @@ import org.apache.ignite.ml.IgniteModel;
 import org.apache.ignite.ml.math.primitives.vector.Vector;
 
 /** Base class for multi-classification model for set of classifiers. */
-public final class MultiClassModel<M extends IgniteModel<Vector, Double>> implements IgniteModel<Vector, Double>, Exportable<MultiClassModel> {
+public final class MultiClassModel<M extends IgniteModel<Vector, Double>>
+    implements IgniteModel<Vector, Double>, Exportable<MultiClassModel> {
     /** */
     private static final long serialVersionUID = -114986533359917L;
 
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/multiclass/OneVsRestTrainer.java b/modules/ml/src/main/java/org/apache/ignite/ml/multiclass/OneVsRestTrainer.java
index d4f1867..f6f2a37 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/multiclass/OneVsRestTrainer.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/multiclass/OneVsRestTrainer.java
@@ -76,7 +76,8 @@ public class OneVsRestTrainer<M extends IgniteModel<Vector, Double>>
         classes.forEach(clsLb -> {
             IgniteFunction<Double, Double> lbTransformer = lb -> lb.equals(clsLb) ? 1.0 : 0.0;
 
-            IgniteFunction<LabeledVector<Double>, LabeledVector<Double>> func = lv -> new LabeledVector<>(lv.features(), lbTransformer.apply(lv.label()));
+            IgniteFunction<LabeledVector<Double>, LabeledVector<Double>> func =
+                lv -> new LabeledVector<>(lv.features(), lbTransformer.apply(lv.label()));
 
             PatchedPreprocessor<K, V, Double, Double> patchedPreprocessor = new PatchedPreprocessor<>(func, extractor);
 
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/naivebayes/compound/CompoundNaiveBayesTrainer.java b/modules/ml/src/main/java/org/apache/ignite/ml/naivebayes/compound/CompoundNaiveBayesTrainer.java
index e7aa81d..2168963 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/naivebayes/compound/CompoundNaiveBayesTrainer.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/naivebayes/compound/CompoundNaiveBayesTrainer.java
@@ -83,7 +83,11 @@ public class CompoundNaiveBayesTrainer extends SingleLabelDatasetTrainer<Compoun
 
             GaussianNaiveBayesModel model = (mdl == null)
                 ? gaussianNaiveBayesTrainer.fit(datasetBuilder, extractor.map(skipFeatures(gaussianFeatureIdsToSkip)))
-                : gaussianNaiveBayesTrainer.update(mdl.getGaussianModel(), datasetBuilder, extractor.map(skipFeatures(gaussianFeatureIdsToSkip)));
+                : gaussianNaiveBayesTrainer.update(
+                    mdl.getGaussianModel(),
+                    datasetBuilder,
+                    extractor.map(skipFeatures(gaussianFeatureIdsToSkip))
+                );
 
             compoundModel.withGaussianModel(model)
                 .withGaussianFeatureIdsToSkip(gaussianFeatureIdsToSkip)
@@ -97,7 +101,11 @@ public class CompoundNaiveBayesTrainer extends SingleLabelDatasetTrainer<Compoun
 
             DiscreteNaiveBayesModel model = (mdl == null)
                 ? discreteNaiveBayesTrainer.fit(datasetBuilder, extractor.map(skipFeatures(discreteFeatureIdsToSkip)))
-                : discreteNaiveBayesTrainer.update(mdl.getDiscreteModel(), datasetBuilder, extractor.map(skipFeatures(discreteFeatureIdsToSkip)));
+                : discreteNaiveBayesTrainer.update(
+                    mdl.getDiscreteModel(),
+                    datasetBuilder,
+                    extractor.map(skipFeatures(discreteFeatureIdsToSkip))
+                  );
 
             compoundModel.withDiscreteModel(model)
                 .withDiscreteFeatureIdsToSkip(discreteFeatureIdsToSkip)
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/nn/MultilayerPerceptron.java b/modules/ml/src/main/java/org/apache/ignite/ml/nn/MultilayerPerceptron.java
index 3fcf0cd..10583fd 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/nn/MultilayerPerceptron.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/nn/MultilayerPerceptron.java
@@ -536,7 +536,8 @@ public final class MultilayerPerceptron implements SmoothParametrized<Multilayer
         Matrix diff = groundTruth.like(groundTruth.rowSize(), groundTruth.columnSize());
 
         for (int col = 0; col < groundTruth.columnSize(); col++) {
-            // TODO: IGNITE-7155 Couldn't use views here because copy on views doesn't do actual copy and all changes are propagated to original.
+            // TODO: IGNITE-7155 Couldn't use views here because
+            //  copy on views doesn't do actual copy and all changes are propagated to original.
             Vector gtCol = groundTruth.getCol(col);
             Vector predCol = lastLayerOutput.getCol(col);
             diff.assignColumn(col, loss.apply(gtCol).differential(predCol));
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/optimization/updatecalculators/SimpleGDParameterUpdate.java b/modules/ml/src/main/java/org/apache/ignite/ml/optimization/updatecalculators/SimpleGDParameterUpdate.java
index c367b59..4469fa0 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/optimization/updatecalculators/SimpleGDParameterUpdate.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/optimization/updatecalculators/SimpleGDParameterUpdate.java
@@ -33,7 +33,8 @@ public class SimpleGDParameterUpdate implements Serializable {
     public static final IgniteFunction<List<SimpleGDParameterUpdate>, SimpleGDParameterUpdate> AVG = SimpleGDParameterUpdate::avg;
 
     /** Method used to get total update of all parallel trainings. */
-    public static final IgniteFunction<List<SimpleGDParameterUpdate>, SimpleGDParameterUpdate> SUM_LOCAL = SimpleGDParameterUpdate::sumLocal;
+    public static final IgniteFunction<List<SimpleGDParameterUpdate>, SimpleGDParameterUpdate> SUM_LOCAL =
+        SimpleGDParameterUpdate::sumLocal;
 
     /** */
     private static final long serialVersionUID = -8732955283436005621L;
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/encoding/EncoderTrainer.java b/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/encoding/EncoderTrainer.java
index c9679cc..aa18997 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/encoding/EncoderTrainer.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/encoding/EncoderTrainer.java
@@ -343,7 +343,9 @@ public class EncoderTrainer<K, V> implements PreprocessingTrainer<K, V> {
     private Map<String, Integer> transformFrequenciesToEncodingValues(Map<String, Integer> frequencies) {
         Comparator<Map.Entry<String, Integer>> comp;
 
-        comp = encoderSortingStgy == EncoderSortingStrategy.FREQUENCY_DESC ? Map.Entry.comparingByValue() : Collections.reverseOrder(Map.Entry.comparingByValue());
+        comp = encoderSortingStgy == EncoderSortingStrategy.FREQUENCY_DESC
+            ? Map.Entry.comparingByValue()
+            : Collections.reverseOrder(Map.Entry.comparingByValue());
 
         final HashMap<String, Integer> resMap = frequencies.entrySet()
             .stream()
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/encoding/onehotencoder/OneHotEncoderPreprocessor.java b/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/encoding/onehotencoder/OneHotEncoderPreprocessor.java
index 657eaa7..3eab1ac 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/encoding/onehotencoder/OneHotEncoderPreprocessor.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/encoding/onehotencoder/OneHotEncoderPreprocessor.java
@@ -39,7 +39,8 @@ import org.apache.ignite.ml.structures.LabeledVector;
  *
  * This preprocessor can transform multiple columns which indices are handled during training process.
  *
- * Each one-hot encoded binary vector adds its cells to the end of the current feature vector according the order of handled categorial features.
+ * Each one-hot encoded binary vector adds its cells to the end of the current feature vector
+ * according the order of handled categorial features.
  *
  * @param <K> Type of a key in {@code upstream} data.
  * @param <V> Type of a value in {@code upstream} data.
@@ -96,7 +97,8 @@ public final class OneHotEncoderPreprocessor<K, V> extends EncoderPreprocessor<K
                     if (encodingValues[i].containsKey(key)) {
                         final Integer indexedVal = encodingValues[i].get(key);
 
-                        res[tmp.size() - amountOfCategorialFeatures + getIdxOffset(categorialFeatureCntr, indexedVal, encodingValues)] = 1.0;
+                        res[tmp.size() - amountOfCategorialFeatures + getIdxOffset(categorialFeatureCntr, indexedVal, encodingValues)] =
+                            1.0;
 
                     } else
                         throw new UnknownCategorialValueException(tmpObj.toString());
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/encoding/stringencoder/StringEncoderPreprocessor.java b/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/encoding/stringencoder/StringEncoderPreprocessor.java
index 1368d1d..f7e7afd 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/encoding/stringencoder/StringEncoderPreprocessor.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/encoding/stringencoder/StringEncoderPreprocessor.java
@@ -36,7 +36,8 @@ import org.apache.ignite.ml.structures.LabeledVector;
  * in range [0.0, amountOfCategories), where the most popular value will be presented as 0.0 and
  * the least popular value presented with amountOfCategories-1 value.
  * <p>
- * This preprocessor can transform multiple columns which indices are handled during training process. These indexes could be defined via .withEncodedFeature(featureIndex) call.
+ * This preprocessor can transform multiple columns which indices are handled during training process.
+ * These indexes could be defined via .withEncodedFeature(featureIndex) call.
  * </p>
  * <p>
  * NOTE: it does not add new column but change data in-place.
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/imputing/ImputingStrategy.java b/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/imputing/ImputingStrategy.java
index cfb0dc0..d7385c6 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/imputing/ImputingStrategy.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/preprocessing/imputing/ImputingStrategy.java
@@ -19,7 +19,10 @@ package org.apache.ignite.ml.preprocessing.imputing;
 
 /** This enum contains settings for imputing preprocessor. */
 public enum ImputingStrategy {
-    /** The default strategy. If this strategy is chosen, then replace missing values using the mean for the numeric features along the axis. */
+    /**
+     * The default strategy. If this strategy is chosen, then replace missing values using the mean for the numeric features along the
+     * axis.
+     */
     MEAN,
 
     /** If this strategy is chosen, then replace missing using the most frequent value along the axis. */
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/regressions/linear/LinearRegressionLSQRTrainer.java b/modules/ml/src/main/java/org/apache/ignite/ml/regressions/linear/LinearRegressionLSQRTrainer.java
index d28a2a9..dfa82d2 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/regressions/linear/LinearRegressionLSQRTrainer.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/regressions/linear/LinearRegressionLSQRTrainer.java
@@ -63,7 +63,8 @@ public class LinearRegressionLSQRTrainer extends SingleLabelDatasetTrainer<Linea
                                                                  Preprocessor<K, V> extractor) {
         LSQRResult res;
 
-        PatchedPreprocessor<K, V, Double, double[]> patchedPreprocessor = new PatchedPreprocessor<>(LinearRegressionLSQRTrainer::extendLabeledVector, extractor);
+        PatchedPreprocessor<K, V, Double, double[]> patchedPreprocessor =
+            new PatchedPreprocessor<>(LinearRegressionLSQRTrainer::extendLabeledVector, extractor);
 
         try (LSQROnHeap<K, V> lsqr = new LSQROnHeap<>(
             datasetBuilder, envBuilder,
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/regressions/linear/LinearRegressionSGDTrainer.java b/modules/ml/src/main/java/org/apache/ignite/ml/regressions/linear/LinearRegressionSGDTrainer.java
index d982671..918ba6c 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/regressions/linear/LinearRegressionSGDTrainer.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/regressions/linear/LinearRegressionSGDTrainer.java
@@ -126,7 +126,8 @@ public class LinearRegressionSGDTrainer<P extends Serializable> extends SingleLa
             seed
         );
 
-        IgniteFunction<LabeledVector<Double>, LabeledVector<double[]>> func = lv -> new LabeledVector<>(lv.features(), new double[] { lv.label()});
+        IgniteFunction<LabeledVector<Double>, LabeledVector<double[]>> func =
+            lv -> new LabeledVector<>(lv.features(), new double[] { lv.label()});
 
         PatchedPreprocessor<K, V, Double, double[]> patchedPreprocessor = new PatchedPreprocessor<>(func, extractor);
 
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/regressions/logistic/LogisticRegressionSGDTrainer.java b/modules/ml/src/main/java/org/apache/ignite/ml/regressions/logistic/LogisticRegressionSGDTrainer.java
index c0404db..000e64d 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/regressions/logistic/LogisticRegressionSGDTrainer.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/regressions/logistic/LogisticRegressionSGDTrainer.java
@@ -107,7 +107,8 @@ public class LogisticRegressionSGDTrainer extends SingleLabelDatasetTrainer<Logi
 
         MultilayerPerceptron mlp;
 
-        IgniteFunction<LabeledVector<Double>, LabeledVector<double[]>> func = lv -> new LabeledVector<>(lv.features(), new double[] { lv.label()});
+        IgniteFunction<LabeledVector<Double>, LabeledVector<double[]>> func =
+            lv -> new LabeledVector<>(lv.features(), new double[] { lv.label()});
 
         PatchedPreprocessor<K, V, Double, double[]> patchedPreprocessor = new PatchedPreprocessor<>(func, extractor);
 
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/selection/cv/AbstractCrossValidation.java b/modules/ml/src/main/java/org/apache/ignite/ml/selection/cv/AbstractCrossValidation.java
index df5d050..4d411c5 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/selection/cv/AbstractCrossValidation.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/selection/cv/AbstractCrossValidation.java
@@ -146,7 +146,8 @@ public abstract class AbstractCrossValidation<M extends IgniteModel<Vector, Doub
             return Arrays.stream(tr.locScores).average().orElse(Double.MIN_VALUE);
         };
 
-        Random rnd = new Random(stgy.getSeed()); //TODO: common seed for shared lambdas can produce the same value on each function call? or sequent?
+        //TODO: common seed for shared lambdas can produce the same value on each function call? or sequent?
+        Random rnd = new Random(stgy.getSeed());
 
         BiFunction<Integer, Double, Double> mutator = (Integer geneIdx, Double geneValue) -> {
             Double newGeneVal;
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/aggregator/BinaryClassificationPointwiseMetricStatsAggregator.java b/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/aggregator/BinaryClassificationPointwiseMetricStatsAggregator.java
index 2be9e6d..fac6010 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/aggregator/BinaryClassificationPointwiseMetricStatsAggregator.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/aggregator/BinaryClassificationPointwiseMetricStatsAggregator.java
@@ -28,7 +28,8 @@ import org.apache.ignite.ml.structures.LabeledVector;
  * This class represents statistics for pointwise metrics evaluation for binary classification like TruePositive,
  * FalsePositive, TrueNegative and FalseNegative.
  */
-public class BinaryClassificationPointwiseMetricStatsAggregator<L extends Serializable> implements MetricStatsAggregator<L, BinaryClassificationEvaluationContext<L>, BinaryClassificationPointwiseMetricStatsAggregator<L>> {
+public class BinaryClassificationPointwiseMetricStatsAggregator<L extends Serializable>
+    implements MetricStatsAggregator<L, BinaryClassificationEvaluationContext<L>, BinaryClassificationPointwiseMetricStatsAggregator<L>> {
     /**
      * Serial version uid.
      */
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/aggregator/ClassificationMetricsAggregator.java b/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/aggregator/ClassificationMetricsAggregator.java
index ce5873f..2fa7ea6 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/aggregator/ClassificationMetricsAggregator.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/aggregator/ClassificationMetricsAggregator.java
@@ -29,7 +29,8 @@ import org.apache.ignite.ml.structures.LabeledVector;
  *
  * @param <L> Type of label.
  */
-public class ClassificationMetricsAggregator<L extends Serializable> implements MetricStatsAggregator<L, EmptyContext<L>, ClassificationMetricsAggregator<L>> {
+public class ClassificationMetricsAggregator<L extends Serializable>
+    implements MetricStatsAggregator<L, EmptyContext<L>, ClassificationMetricsAggregator<L>> {
     /**
      * Serial version uid.
      */
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/aggregator/RegressionMetricStatsAggregator.java b/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/aggregator/RegressionMetricStatsAggregator.java
index ae25f66..2c46c74 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/aggregator/RegressionMetricStatsAggregator.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/aggregator/RegressionMetricStatsAggregator.java
@@ -26,7 +26,8 @@ import org.apache.ignite.ml.structures.LabeledVector;
 /**
  * Class represents statistics aggregator for regression estimation.
  */
-public class RegressionMetricStatsAggregator implements MetricStatsAggregator<Double, EmptyContext<Double>, RegressionMetricStatsAggregator> {
+public class RegressionMetricStatsAggregator
+    implements MetricStatsAggregator<Double, EmptyContext<Double>, RegressionMetricStatsAggregator> {
     /**
      * Serial version uid.
      */
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/context/BinaryClassificationEvaluationContext.java b/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/context/BinaryClassificationEvaluationContext.java
index f7c686e..d1a2220 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/context/BinaryClassificationEvaluationContext.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/evaluator/context/BinaryClassificationEvaluationContext.java
@@ -29,7 +29,8 @@ import org.apache.ignite.ml.structures.LabeledVector;
 /**
  * This context tries to define positive and negative labels for estimation of binary classifier.
  */
-public class BinaryClassificationEvaluationContext<L extends Serializable> implements EvaluationContext<L, BinaryClassificationEvaluationContext<L>> {
+public class BinaryClassificationEvaluationContext<L extends Serializable>
+    implements EvaluationContext<L, BinaryClassificationEvaluationContext<L>> {
     /**
      * Serial version uid.
      */
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/metric/classification/BinaryClassificationMetric.java b/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/metric/classification/BinaryClassificationMetric.java
index 7d42c69..db5558c 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/metric/classification/BinaryClassificationMetric.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/selection/scoring/metric/classification/BinaryClassificationMetric.java
@@ -24,7 +24,8 @@ import org.apache.ignite.ml.selection.scoring.metric.Metric;
 /**
  * Common abstract class for all binary classification metrics.
  */
-public abstract class BinaryClassificationMetric<L extends Serializable> implements Metric<L, BinaryClassificationEvaluationContext<L>, BinaryClassificationPointwiseMetricStatsAggregator<L>> {
+public abstract class BinaryClassificationMetric<L extends Serializable>
+    implements Metric<L, BinaryClassificationEvaluationContext<L>, BinaryClassificationPointwiseMetricStatsAggregator<L>> {
     /**
      * Serial version uid.
      */
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/svm/SVMLinearClassificationTrainer.java b/modules/ml/src/main/java/org/apache/ignite/ml/svm/SVMLinearClassificationTrainer.java
index 266403f..b4d838f 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/svm/SVMLinearClassificationTrainer.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/svm/SVMLinearClassificationTrainer.java
@@ -81,7 +81,8 @@ public class SVMLinearClassificationTrainer extends SingleLabelDatasetTrainer<SV
                 return lb;
         };
 
-        IgniteFunction<LabeledVector<Double>, LabeledVector<Double>> func = lv -> new LabeledVector<>(lv.features(), lbTransformer.apply(lv.label()));
+        IgniteFunction<LabeledVector<Double>, LabeledVector<Double>> func =
+            lv -> new LabeledVector<>(lv.features(), lbTransformer.apply(lv.label()));
 
         PatchedPreprocessor<K, V, Double, Double> patchedPreprocessor = new PatchedPreprocessor<>(func, preprocessor);
 
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/trainers/AdaptableDatasetTrainer.java b/modules/ml/src/main/java/org/apache/ignite/ml/trainers/AdaptableDatasetTrainer.java
index 5285b58..1f78650 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/trainers/AdaptableDatasetTrainer.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/trainers/AdaptableDatasetTrainer.java
@@ -165,7 +165,10 @@ public class AdaptableDatasetTrainer<I, O, IW, OW, M extends IgniteModel<IW, OW>
     public AdaptableDatasetTrainer<I, O, IW, OW, M, L> withDatasetMapping(DatasetMapping<L, L> mapping) {
         return of(new DatasetTrainer<M, L>() {
             /** {@inheritDoc} */
-            @Override public <K, V> M fitWithInitializedDeployingContext(DatasetBuilder<K, V> datasetBuilder, Preprocessor<K, V> extractor) {
+            @Override public <K, V> M fitWithInitializedDeployingContext(
+                DatasetBuilder<K, V> datasetBuilder,
+                Preprocessor<K, V> extractor
+            ) {
                 return wrapped.fit(datasetBuilder, extractor.map(lv -> new LabeledVector<>(
                     mapping.mapFeatures(lv.features()),
                     mapping.mapLabels((L)lv.label())
@@ -220,8 +223,9 @@ public class AdaptableDatasetTrainer<I, O, IW, OW, M extends IgniteModel<IW, OW>
      * feature extractor.
      */
     public AdaptableDatasetTrainer<I, O, IW, OW, M, L> afterFeatureExtractor(IgniteFunction<Vector, Vector> after) {
-        IgniteFunction<LabeledVector<L>, LabeledVector<L>> newExtractor = afterExtractor.andThen((IgniteFunction<LabeledVector<L>, LabeledVector<L>>)
-            slv -> new LabeledVector<>(after.apply(slv.features()), slv.label()));
+        IgniteFunction<LabeledVector<L>, LabeledVector<L>> newExtractor =
+            afterExtractor.andThen((IgniteFunction<LabeledVector<L>, LabeledVector<L>>)
+                slv -> new LabeledVector<>(after.apply(slv.features()), slv.label()));
         return new AdaptableDatasetTrainer<>(before,
             wrapped,
             this.after,
@@ -237,8 +241,9 @@ public class AdaptableDatasetTrainer<I, O, IW, OW, M extends IgniteModel<IW, OW>
      * label extractor.
      */
     public AdaptableDatasetTrainer<I, O, IW, OW, M, L> afterLabelExtractor(IgniteFunction<L, L> after) {
-        IgniteFunction<LabeledVector<L>, LabeledVector<L>> newExtractor = afterExtractor.andThen((IgniteFunction<LabeledVector<L>, LabeledVector<L>>)
-            slv -> new LabeledVector<>(slv.features(), after.apply(slv.label())));
+        IgniteFunction<LabeledVector<L>, LabeledVector<L>> newExtractor =
+            afterExtractor.andThen((IgniteFunction<LabeledVector<L>, LabeledVector<L>>)
+                slv -> new LabeledVector<>(slv.features(), after.apply(slv.label())));
         return new AdaptableDatasetTrainer<>(before,
             wrapped,
             this.after,
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/trainers/DatasetTrainer.java b/modules/ml/src/main/java/org/apache/ignite/ml/trainers/DatasetTrainer.java
index 9268a01..89654de 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/trainers/DatasetTrainer.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/trainers/DatasetTrainer.java
@@ -367,7 +367,8 @@ public abstract class DatasetTrainer<M extends IgniteModel, L> {
         return new DatasetTrainer<M, L1>() {
             private <K, V> Preprocessor<K, V> getNewExtractor(
                 Preprocessor<K, V> extractor) {
-                IgniteFunction<LabeledVector<L1>, LabeledVector<L>> func = lv -> new LabeledVector<>(lv.features(), new2Old.apply(lv.label()));
+                IgniteFunction<LabeledVector<L1>, LabeledVector<L>> func =
+                    lv -> new LabeledVector<>(lv.features(), new2Old.apply(lv.label()));
                 return new PatchedPreprocessor<>(func, extractor);
             }
 
@@ -383,7 +384,11 @@ public abstract class DatasetTrainer<M extends IgniteModel, L> {
                 return old.updateModel(mdl, datasetBuilder, getNewExtractor(preprocessor));
             }
 
-            @Override public <K, V> M fitWithInitializedDeployingContext(DatasetBuilder<K, V> datasetBuilder, Preprocessor<K, V> preprocessor) {
+            /** {@inheritDoc} */
+            @Override public <K, V> M fitWithInitializedDeployingContext(
+                DatasetBuilder<K, V> datasetBuilder,
+                Preprocessor<K, V> preprocessor
+            ) {
                 return old.fit(datasetBuilder, getNewExtractor(preprocessor));
             }
 
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/tree/NodeData.java b/modules/ml/src/main/java/org/apache/ignite/ml/tree/NodeData.java
index 885a14d..eb5be6a 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/tree/NodeData.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/tree/NodeData.java
@@ -66,11 +66,15 @@ public class NodeData {
      */
     public static DecisionTreeNode buildTree(Map<Integer, NodeData> nodes,
                                              NodeData rootNodeData) {
-        return rootNodeData.isLeafNode ? new DecisionTreeLeafNode(rootNodeData.prediction) : new DecisionTreeConditionalNode(rootNodeData.featureIdx,
+        return rootNodeData.isLeafNode
+            ? new DecisionTreeLeafNode(rootNodeData.prediction)
+            : new DecisionTreeConditionalNode(
+                rootNodeData.featureIdx,
                 rootNodeData.threshold,
                 buildTree(nodes, nodes.get(rootNodeData.rightChildId)),
                 buildTree(nodes, nodes.get(rootNodeData.leftChildId)),
-                null);
+                null
+            );
     }
 
     /**
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/util/genetic/GeneticAlgorithm.java b/modules/ml/src/main/java/org/apache/ignite/ml/util/genetic/GeneticAlgorithm.java
index 0312d01..2008f6a 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/util/genetic/GeneticAlgorithm.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/util/genetic/GeneticAlgorithm.java
@@ -149,7 +149,8 @@ public class GeneticAlgorithm {
                 for (int j = amountOfEliteChromosomes; j < populationSize; j++) {
                     int finalJ = j;
                     Population finalNewPopulation1 = newPopulation;
-                    IgniteSupplier<Pair<Integer, Double>> task = () -> new Pair<>(finalJ, fitnessFunction.apply(finalNewPopulation1.getChromosome(finalJ)));
+                    IgniteSupplier<Pair<Integer, Double>> task =
+                        () -> new Pair<>(finalJ, fitnessFunction.apply(finalNewPopulation1.getChromosome(finalJ)));
                     tasks.add(task);
                 }
 
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/TestUtils.java b/modules/ml/src/test/java/org/apache/ignite/ml/TestUtils.java
index b0b30b0..f300001 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/TestUtils.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/TestUtils.java
@@ -453,7 +453,11 @@ public class TestUtils {
                 return ml;
             }
 
-            @Override public <K, V> M fitWithInitializedDeployingContext(DatasetBuilder<K, V> datasetBuilder, Preprocessor<K, V> preprocessor) {
+            /** {@inheritDoc} */
+            @Override public <K, V> M fitWithInitializedDeployingContext(
+                DatasetBuilder<K, V> datasetBuilder,
+                Preprocessor<K, V> preprocessor
+            ) {
                 return null;
             }
 
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/clustering/KMeansTrainerTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/clustering/KMeansTrainerTest.java
index 27a2227..43a37c5 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/clustering/KMeansTrainerTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/clustering/KMeansTrainerTest.java
@@ -76,7 +76,8 @@ public class KMeansTrainerTest extends TrainerTest {
     @Test
     public void testUpdateMdl() {
         KMeansTrainer trainer = createAndCheckTrainer();
-        Vectorizer<Integer, double[], Integer, Double> vectorizer = new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.LAST);
+        Vectorizer<Integer, double[], Integer, Double> vectorizer =
+            new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.LAST);
         KMeansModel originalMdl = trainer.withAmountOfClusters(1).fit(
             new LocalDatasetBuilder<>(data, parts),
             vectorizer
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/common/LocalModelsTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/common/LocalModelsTest.java
index e81400b..019d02a 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/common/LocalModelsTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/common/LocalModelsTest.java
@@ -174,10 +174,11 @@ public class LocalModelsTest {
 
             Assert.assertNotNull(load);
 
-            NNClassificationModel importedMdl = new ANNClassificationModel(load.getCandidates(), new ANNClassificationTrainer.CentroidStat())
-                .withK(load.getK())
-                .withDistanceMeasure(load.getDistanceMeasure())
-                .withWeighted(true);
+            NNClassificationModel importedMdl =
+                new ANNClassificationModel(load.getCandidates(), new ANNClassificationTrainer.CentroidStat())
+                    .withK(load.getK())
+                    .withDistanceMeasure(load.getDistanceMeasure())
+                    .withWeighted(true);
 
             Assert.assertEquals("", mdl, importedMdl);
 
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/composition/boosting/GDBTrainerTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/composition/boosting/GDBTrainerTest.java
index 9bd9509..950e59d 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/composition/boosting/GDBTrainerTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/composition/boosting/GDBTrainerTest.java
@@ -193,7 +193,8 @@ public class GDBTrainerTest extends TrainerTest {
 
         LocalDatasetBuilder<Integer, double[]> epmtyDataset = new LocalDatasetBuilder<>(new HashMap<>(), 1);
         FeatureLabelExtractor<Integer, double[], Double> extractor = (k, v) -> new LabeledVector<>(fExtr.apply(k, v), lExtr.apply(k, v));
-        ModelsComposition updatedOnEmptyDataset = trainer.updateModel(originalMdl, emptyDataset, new FeatureLabelExtractorWrapper<>(extractor));
+        ModelsComposition updatedOnEmptyDataset =
+            trainer.updateModel(originalMdl, emptyDataset, new FeatureLabelExtractorWrapper<>(extractor));
 
         dataset.forEach((k,v) -> {
             Vector features = fExtr.apply(k, v);
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/dataset/primitive/SimpleLabeledDatasetTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/dataset/primitive/SimpleLabeledDatasetTest.java
index 7185c7f..eff9216 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/dataset/primitive/SimpleLabeledDatasetTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/dataset/primitive/SimpleLabeledDatasetTest.java
@@ -53,7 +53,8 @@ public class SimpleLabeledDatasetTest {
 
         Vectorizer<Integer, Vector, Integer, Double> vectorizer = new DummyVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
 
-        IgniteFunction<LabeledVector<Double>, LabeledVector<double[]>> func = lv -> new LabeledVector<>(lv.features(), new double[] { lv.label()});
+        IgniteFunction<LabeledVector<Double>, LabeledVector<double[]>> func =
+            lv -> new LabeledVector<>(lv.features(), new double[] { lv.label()});
 
         PatchedPreprocessor<Integer, Vector, Double, double[]> patchedPreprocessor = new PatchedPreprocessor<>(func, vectorizer);
 
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/environment/LearningEnvironmentBuilderTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/environment/LearningEnvironmentBuilderTest.java
index 0590636..dd440dc 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/environment/LearningEnvironmentBuilderTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/environment/LearningEnvironmentBuilderTest.java
@@ -70,11 +70,11 @@ public class LearningEnvironmentBuilderTest {
     /** */
     @Test
     public void withLoggingFactory() {
-        assertTrue(LearningEnvironmentBuilder.defaultBuilder().withLoggingFactoryDependency(part -> ConsoleLogger.factory(MLLogger.VerboseLevel.HIGH))
-            .buildForTrainer().logger() instanceof ConsoleLogger);
+        assertTrue(LearningEnvironmentBuilder.defaultBuilder().withLoggingFactoryDependency(
+            part -> ConsoleLogger.factory(MLLogger.VerboseLevel.HIGH)).buildForTrainer().logger() instanceof ConsoleLogger);
 
-        assertTrue(LearningEnvironmentBuilder.defaultBuilder().withLoggingFactoryDependency(part -> ConsoleLogger.factory(MLLogger.VerboseLevel.HIGH))
-            .buildForTrainer().logger(this.getClass()) instanceof ConsoleLogger);
+        assertTrue(LearningEnvironmentBuilder.defaultBuilder().withLoggingFactoryDependency(
+            part -> ConsoleLogger.factory(MLLogger.VerboseLevel.HIGH)).buildForTrainer().logger(this.getClass()) instanceof ConsoleLogger);
 
         assertTrue(LearningEnvironmentBuilder.defaultBuilder().withLoggingFactoryDependency(part -> NoOpLogger.factory())
             .buildForTrainer().logger() instanceof NoOpLogger);
@@ -82,10 +82,10 @@ public class LearningEnvironmentBuilderTest {
         assertTrue(LearningEnvironmentBuilder.defaultBuilder().withLoggingFactoryDependency(part -> NoOpLogger.factory())
             .buildForTrainer().logger(this.getClass()) instanceof NoOpLogger);
 
-        assertTrue(LearningEnvironmentBuilder.defaultBuilder().withLoggingFactoryDependency(part -> CustomMLLogger.factory(new NullLogger()))
-            .buildForTrainer().logger() instanceof CustomMLLogger);
+        assertTrue(LearningEnvironmentBuilder.defaultBuilder().withLoggingFactoryDependency(
+            part -> CustomMLLogger.factory(new NullLogger())).buildForTrainer().logger() instanceof CustomMLLogger);
 
-        assertTrue(LearningEnvironmentBuilder.defaultBuilder().withLoggingFactoryDependency(part -> CustomMLLogger.factory(new NullLogger()))
-            .buildForTrainer().logger(this.getClass()) instanceof CustomMLLogger);
+        assertTrue(LearningEnvironmentBuilder.defaultBuilder().withLoggingFactoryDependency(
+            part -> CustomMLLogger.factory(new NullLogger())).buildForTrainer().logger(this.getClass()) instanceof CustomMLLogger);
     }
 }
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/environment/LearningEnvironmentTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/environment/LearningEnvironmentTest.java
index 374646e..4592f1c 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/environment/LearningEnvironmentTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/environment/LearningEnvironmentTest.java
@@ -87,7 +87,10 @@ public class LearningEnvironmentTest {
 
         DatasetTrainer<IgniteModel<Object, Vector>, Void> trainer = new DatasetTrainer<IgniteModel<Object, Vector>, Void>() {
             /** {@inheritDoc} */
-             @Override public <K, V> IgniteModel<Object, Vector> fitWithInitializedDeployingContext(DatasetBuilder<K, V> datasetBuilder, Preprocessor<K, V> preprocessor) {
+             @Override public <K, V> IgniteModel<Object, Vector> fitWithInitializedDeployingContext(
+                 DatasetBuilder<K, V> datasetBuilder,
+                 Preprocessor<K, V> preprocessor
+             ) {
                 Dataset<EmptyContext, TestUtils.DataWrapper<Integer>> ds = datasetBuilder.build(envBuilder,
                     new EmptyContextBuilder<>(),
                     (PartitionDataBuilder<K, V, EmptyContext, TestUtils.DataWrapper<Integer>>)(env, upstreamData, upstreamDataSize, ctx) ->
@@ -96,8 +99,10 @@ public class LearningEnvironmentTest {
 
                 Vector v = null;
                 for (int iter = 0; iter < iterations; iter++) {
-                    v = ds.compute((dw, env) -> VectorUtils.fill(-1, partitions).set(env.partition(), env.randomNumbersGenerator().nextInt()),
-                        (v1, v2) -> zipOverridingEmpty(v1, v2, -1));
+                    v = ds.compute(
+                        (dw, env) -> VectorUtils.fill(-1, partitions).set(env.partition(), env.randomNumbersGenerator().nextInt()),
+                        (v1, v2) -> zipOverridingEmpty(v1, v2, -1)
+                    );
                 }
                 return constantModel(v);
             }
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/environment/deploy/MLDeployingTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/environment/deploy/MLDeployingTest.java
index f22ce8a..7859501 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/environment/deploy/MLDeployingTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/environment/deploy/MLDeployingTest.java
@@ -177,7 +177,9 @@ public class MLDeployingTest extends GridCommonAbstractTest {
     }
 
     /** */
-    private Vectorizer<Integer, Vector, Integer, Double> createVectorizer() throws ClassNotFoundException, NoSuchMethodException, InstantiationException, IllegalAccessException, java.lang.reflect.InvocationTargetException {
+    private Vectorizer<Integer, Vector, Integer, Double> createVectorizer()
+        throws ClassNotFoundException, NoSuchMethodException, InstantiationException, IllegalAccessException,
+        java.lang.reflect.InvocationTargetException {
         ClassLoader ldr = getExternalClassLoader();
         Class<?> clazz = ldr.loadClass(EXT_VECTORIZER);
 
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/math/isolve/lsqr/LSQROnHeapTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/math/isolve/lsqr/LSQROnHeapTest.java
index 2c70935..1db735c 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/math/isolve/lsqr/LSQROnHeapTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/math/isolve/lsqr/LSQROnHeapTest.java
@@ -55,7 +55,8 @@ public class LSQROnHeapTest extends TrainerTest {
         Vectorizer<Integer, Vector, Integer, Double> vectorizer = new DummyVectorizer<Integer>()
             .labeled(Vectorizer.LabelCoordinate.LAST);
 
-        IgniteFunction<LabeledVector<Double>, LabeledVector<double[]>> func = lv -> new LabeledVector<>(lv.features(), new double[]{lv.label()});
+        IgniteFunction<LabeledVector<Double>, LabeledVector<double[]>> func =
+            lv -> new LabeledVector<>(lv.features(), new double[]{lv.label()});
 
         Preprocessor<Integer, Vector> prerocessor = new PatchedPreprocessor<>(func, vectorizer);
 
@@ -94,7 +95,8 @@ public class LSQROnHeapTest extends TrainerTest {
         Vectorizer<Integer, Vector, Integer, Double> vectorizer = new DummyVectorizer<Integer>()
             .labeled(Vectorizer.LabelCoordinate.LAST);
 
-        IgniteFunction<LabeledVector<Double>, LabeledVector<double[]>> func = lv -> new LabeledVector<>(lv.features(), new double[]{lv.label()});
+        IgniteFunction<LabeledVector<Double>, LabeledVector<double[]>> func =
+            lv -> new LabeledVector<>(lv.features(), new double[]{lv.label()});
 
         Preprocessor<Integer, Vector> prerocessor = new PatchedPreprocessor<>(func, vectorizer);
 
@@ -133,7 +135,8 @@ public class LSQROnHeapTest extends TrainerTest {
         Vectorizer<Integer, Vector, Integer, Double> vectorizer = new DummyVectorizer<Integer>()
             .labeled(Vectorizer.LabelCoordinate.LAST);
 
-        IgniteFunction<LabeledVector<Double>, LabeledVector<double[]>> func = lv -> new LabeledVector<>(lv.features(), new double[]{lv.label()});
+        IgniteFunction<LabeledVector<Double>, LabeledVector<double[]>> func =
+            lv -> new LabeledVector<>(lv.features(), new double[]{lv.label()});
 
         Preprocessor<Integer, Vector> prerocessor = new PatchedPreprocessor<>(func, vectorizer);
 
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/matrix/MatrixStorageFixtures.java b/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/matrix/MatrixStorageFixtures.java
index f064aee..ec239a3 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/matrix/MatrixStorageFixtures.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/matrix/MatrixStorageFixtures.java
@@ -60,7 +60,8 @@ class MatrixStorageFixtures {
         private final Integer[] cols = new Integer[] {1, 2, 4, 8, 16, 32, 64, 128, 256, 512, 1024, 1024, 512, null};
 
         /** */
-        private final Integer[] randomAccess = new Integer[] {StorageConstants.SEQUENTIAL_ACCESS_MODE, StorageConstants.RANDOM_ACCESS_MODE, null};
+        private final Integer[] randomAccess =
+            new Integer[] {StorageConstants.SEQUENTIAL_ACCESS_MODE, StorageConstants.RANDOM_ACCESS_MODE, null};
 
         /** */
         private final Integer[] rowStorage = new Integer[] {StorageConstants.ROW_STORAGE_MODE, StorageConstants.COLUMN_STORAGE_MODE, null};
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/matrix/MatrixStorageImplementationTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/matrix/MatrixStorageImplementationTest.java
index b8c3989..91fef7f 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/matrix/MatrixStorageImplementationTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/matrix/MatrixStorageImplementationTest.java
@@ -38,11 +38,16 @@ public class MatrixStorageImplementationTest extends ExternalizeTest<MatrixStora
         final AtomicReference<Integer> expRowSize = new AtomicReference<>(0);
         final AtomicReference<Integer> expColSize = new AtomicReference<>(0);
 
-        consumeSampleStorages((x, y) -> {
+        consumeSampleStorages(
+            (x, y) -> {
                 expRowSize.set(x);
                 expColSize.set(y);
             },
-            (ms, desc) -> assertTrue("Expected size for " + desc, expColSize.get().equals(ms.columnSize()) && expRowSize.get().equals(ms.rowSize())));
+            (ms, desc) -> assertTrue(
+                "Expected size for " + desc,
+                expColSize.get().equals(ms.columnSize()) && expRowSize.get().equals(ms.rowSize())
+            )
+        );
     }
 
     /** */
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/vector/AbstractVectorTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/vector/AbstractVectorTest.java
index ac9e4a4..bf06a5f 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/vector/AbstractVectorTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/vector/AbstractVectorTest.java
@@ -265,7 +265,11 @@ public class AbstractVectorTest {
         for (int i = 0; i < data0.length; i++)
             testVal.append(data0[i] + data1[i]);
 
-        assertEquals(MathTestConstants.VAL_NOT_EQUALS, testVector.foldMap(testVector1, (string, xi) -> string + xi.toString(), Functions.PLUS, ""), testVal.toString());
+        assertEquals(
+            MathTestConstants.VAL_NOT_EQUALS,
+            testVector.foldMap(testVector1, (string, xi) -> string + xi.toString(), Functions.PLUS, ""),
+            testVal.toString()
+        );
     }
 
     /** */
@@ -277,11 +281,19 @@ public class AbstractVectorTest {
 
         assertNotNull(MathTestConstants.NULL_VAL, testVector.nonZeroes());
 
-        Assert.assertEquals(MathTestConstants.VAL_NOT_EQUALS, StreamSupport.stream(testVector.nonZeroes().spliterator(), false).count(), Arrays.stream(data).filter(x -> x != 0d).count());
+        Assert.assertEquals(
+            MathTestConstants.VAL_NOT_EQUALS,
+            StreamSupport.stream(testVector.nonZeroes().spliterator(), false).count(),
+            Arrays.stream(data).filter(x -> x != 0d).count()
+        );
 
         addNilValues(data);
 
-        Assert.assertEquals(MathTestConstants.VAL_NOT_EQUALS, StreamSupport.stream(testVector.nonZeroes().spliterator(), false).count(), Arrays.stream(data).filter(x -> x != 0d).count());
+        Assert.assertEquals(
+            MathTestConstants.VAL_NOT_EQUALS,
+            StreamSupport.stream(testVector.nonZeroes().spliterator(), false).count(),
+            Arrays.stream(data).filter(x -> x != 0d).count()
+        );
     }
 
     /** */
@@ -319,7 +331,12 @@ public class AbstractVectorTest {
     public void dotSelf() {
         double[] data = initVector();
 
-        assertEquals(MathTestConstants.VAL_NOT_EQUALS, testVector.dotSelf(), Arrays.stream(data).reduce(0, (x, y) -> x + y * y), MathTestConstants.NIL_DELTA);
+        assertEquals(
+            MathTestConstants.VAL_NOT_EQUALS,
+            testVector.dotSelf(),
+            Arrays.stream(data).reduce(0, (x, y) -> x + y * y),
+            MathTestConstants.NIL_DELTA
+        );
     }
 
     /** */
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/vector/VectorNormTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/vector/VectorNormTest.java
index fa25925..23c9e6f 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/vector/VectorNormTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/vector/VectorNormTest.java
@@ -155,7 +155,8 @@ public class VectorNormTest {
             final double[] ref = new double[size];
             final boolean nonNegative = pow != (int)pow;
 
-            final VectorImplementationsTest.ElementsChecker checker = new VectorImplementationsTest.ElementsChecker(v, ref, desc + ", pow = " + pow, nonNegative);
+            final VectorImplementationsTest.ElementsChecker checker =
+                new VectorImplementationsTest.ElementsChecker(v, ref, desc + ", pow = " + pow, nonNegative);
             final double norm = new Norm(ref, pow).calculate();
 
             for (int idx = 0; idx < size; idx++)
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/multiclass/OneVsRestTrainerTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/multiclass/OneVsRestTrainerTest.java
index 44eebf0..d9c97b7 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/multiclass/OneVsRestTrainerTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/multiclass/OneVsRestTrainerTest.java
@@ -90,7 +90,8 @@ public class OneVsRestTrainerTest extends TrainerTest {
 
         OneVsRestTrainer<LogisticRegressionModel> trainer = new OneVsRestTrainer<>(binaryTrainer);
 
-        Vectorizer<Integer, double[], Integer, Double> vectorizer = new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
+        Vectorizer<Integer, double[], Integer, Double> vectorizer =
+            new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
         MultiClassModel originalMdl = trainer.fit(
             cacheMock, parts,
             vectorizer
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/naivebayes/gaussian/GaussianNaiveBayesTrainerTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/naivebayes/gaussian/GaussianNaiveBayesTrainerTest.java
index 8756b83..2d13a72 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/naivebayes/gaussian/GaussianNaiveBayesTrainerTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/naivebayes/gaussian/GaussianNaiveBayesTrainerTest.java
@@ -164,7 +164,8 @@ public class GaussianNaiveBayesTrainerTest extends TrainerTest {
     /** Test. */
     @Test
     public void testUpdatingModel() {
-        Vectorizer<Integer, double[], Integer, Double> vectorizer = new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.LAST);
+        Vectorizer<Integer, double[], Integer, Double> vectorizer =
+            new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.LAST);
 
         GaussianNaiveBayesModel mdl = trainer.fit(
             new LocalDatasetBuilder<>(singleLabeldata1, parts),
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/nn/MLPTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/nn/MLPTest.java
index 2d4b674..1bb3b62 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/nn/MLPTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/nn/MLPTest.java
@@ -151,8 +151,10 @@ public class MLPTest {
             withAddedLayer(layerWithBiasNeuronsCnt, true, Activators.SIGMOID).
             withAddedLayer(layerWithoutBiasNeuronsCnt, false, Activators.SIGMOID);
 
-        Assert.assertEquals(layerWithBiasNeuronsCnt * inputSize + layerWithBiasNeuronsCnt + (layerWithoutBiasNeuronsCnt * layerWithBiasNeuronsCnt),
-            conf.parametersCount());
+        Assert.assertEquals(
+            layerWithBiasNeuronsCnt * inputSize + layerWithBiasNeuronsCnt + (layerWithoutBiasNeuronsCnt * layerWithBiasNeuronsCnt),
+            conf.parametersCount()
+        );
     }
 
     /**
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/nn/MLPTrainerTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/nn/MLPTrainerTest.java
index d007dfe..e1185b3 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/nn/MLPTrainerTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/nn/MLPTrainerTest.java
@@ -205,8 +205,16 @@ public class MLPTrainerTest {
                 {1.0, 1.0}
             });
 
-            TestUtils.checkIsInEpsilonNeighbourhood(originalMdl.predict(matrix).getRow(0), updatedOnSameDS.predict(matrix).getRow(0), 1E-1);
-            TestUtils.checkIsInEpsilonNeighbourhood(originalMdl.predict(matrix).getRow(0), updatedOnEmptyDS.predict(matrix).getRow(0), 1E-1);
+            TestUtils.checkIsInEpsilonNeighbourhood(
+                originalMdl.predict(matrix).getRow(0),
+                updatedOnSameDS.predict(matrix).getRow(0),
+                1E-1
+            );
+            TestUtils.checkIsInEpsilonNeighbourhood(
+                originalMdl.predict(matrix).getRow(0),
+                updatedOnEmptyDS.predict(matrix).getRow(0),
+                1E-1
+            );
         }
     }
 
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/nn/performance/MnistMLPTestUtil.java b/modules/ml/src/test/java/org/apache/ignite/ml/nn/performance/MnistMLPTestUtil.java
index dd934ab..ed6ce71 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/nn/performance/MnistMLPTestUtil.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/nn/performance/MnistMLPTestUtil.java
@@ -63,7 +63,12 @@ public class MnistMLPTestUtil {
      */
     public static List<MnistUtils.MnistLabeledImage> loadTrainingSet(int cnt) throws IOException {
         Properties props = loadMNISTProperties();
-        return MnistUtils.mnistAsList(props.getProperty(PROP_TRAINING_IMAGES), props.getProperty(PROP_TRAINING_LABELS), new Random(123L), cnt);
+        return MnistUtils.mnistAsList(
+            props.getProperty(PROP_TRAINING_IMAGES),
+            props.getProperty(PROP_TRAINING_LABELS),
+            new Random(123L),
+            cnt
+        );
     }
 
     /**
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/preprocessing/encoding/EncoderTrainerTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/preprocessing/encoding/EncoderTrainerTest.java
index a58e96e..faae560 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/preprocessing/encoding/EncoderTrainerTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/preprocessing/encoding/EncoderTrainerTest.java
@@ -67,7 +67,11 @@ public class EncoderTrainerTest extends TrainerTest {
             vectorizer
         );
 
-        assertArrayEquals(new double[] {0.0, 2.0}, preprocessor.apply(7, new DenseVector(new Serializable[] {7.0, "Monday", "September"})).features().asArray(), 1e-8);
+        assertArrayEquals(
+            new double[] {0.0, 2.0},
+            preprocessor.apply(7, new DenseVector(new Serializable[] {7.0, "Monday", "September"})).features().asArray(),
+            1e-8
+        );
     }
 
     /** Tests {@code fit()} method. */
@@ -95,8 +99,16 @@ public class EncoderTrainerTest extends TrainerTest {
             datasetBuilder,
             vectorizer
         );
-        assertArrayEquals(new double[] {1.0, 0.0, 0.0, 0.0, 0.0, 1.0}, preprocessor.apply(7, VectorUtils.of(3.0, 0.0)).features().asArray(), 1e-8);
-        assertArrayEquals(new double[] {0.0, 1.0, 0.0, 1.0, 0.0, 0.0}, preprocessor.apply(8, VectorUtils.of(2.0, 12.0)).features().asArray(), 1e-8);
+        assertArrayEquals(
+            new double[] {1.0, 0.0, 0.0, 0.0, 0.0, 1.0},
+            preprocessor.apply(7, VectorUtils.of(3.0, 0.0)).features().asArray(),
+            1e-8
+        );
+        assertArrayEquals(
+            new double[] {0.0, 1.0, 0.0, 1.0, 0.0, 0.0},
+            preprocessor.apply(8, VectorUtils.of(2.0, 12.0)).features().asArray(),
+            1e-8
+        );
     }
 
     /** Tests {@code fit()} method. */
@@ -162,7 +174,11 @@ public class EncoderTrainerTest extends TrainerTest {
             vectorizer
         );
 
-        assertArrayEquals(new double[] {2.0, 0.0}, preprocessor.apply(7, new DenseVector(new Serializable[] {"Monday", "September"})).features().asArray(), 1e-8);
+        assertArrayEquals(
+            new double[] {2.0, 0.0},
+            preprocessor.apply(7, new DenseVector(new Serializable[] {"Monday", "September"})).features().asArray(),
+            1e-8
+        );
     }
 
     /** Tests {@code fit()} method. */
@@ -191,9 +207,21 @@ public class EncoderTrainerTest extends TrainerTest {
             vectorizer
         );
 
-        assertArrayEquals(new double[] {0.5, 0.166}, preprocessor.apply(7, new DenseVector(new Serializable[] {"Monday", "September"})).features().asArray(), 0.1);
-        assertArrayEquals(new double[] {0.33, 0.5}, preprocessor.apply(7, new DenseVector(new Serializable[] {"Friday", "August"})).features().asArray(), 0.1);
-        assertArrayEquals(new double[] {0.166, 0.33}, preprocessor.apply(7, new DenseVector(new Serializable[] {"Sunday", "June"})).features().asArray(), 0.1);
+        assertArrayEquals(
+            new double[] {0.5, 0.166},
+            preprocessor.apply(7, new DenseVector(new Serializable[] {"Monday", "September"})).features().asArray(),
+            0.1
+        );
+        assertArrayEquals(
+            new double[] {0.33, 0.5},
+            preprocessor.apply(7, new DenseVector(new Serializable[] {"Friday", "August"})).features().asArray(),
+            0.1
+        );
+        assertArrayEquals(
+            new double[] {0.166, 0.33},
+            preprocessor.apply(7, new DenseVector(new Serializable[] {"Sunday", "June"})).features().asArray(),
+            0.1
+        );
     }
 
     /** Tests {@code fit()} method. */
@@ -248,6 +276,10 @@ public class EncoderTrainerTest extends TrainerTest {
             vectorizer
         );
 
-        assertArrayEquals(new double[] {0.0, 2.0}, preprocessor.apply(7, new DenseVector(new Serializable[] {7.0, "Monday", "September"})).features().asArray(), 1e-8);
+        assertArrayEquals(
+            new double[] {0.0, 2.0},
+            preprocessor.apply(7, new DenseVector(new Serializable[] {7.0, "Monday", "September"})).features().asArray(),
+            1e-8
+        );
     }
 }
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/preprocessing/imputing/ImputerTrainerTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/preprocessing/imputing/ImputerTrainerTest.java
index cd88be9..3ed2049 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/preprocessing/imputing/ImputerTrainerTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/preprocessing/imputing/ImputerTrainerTest.java
@@ -57,7 +57,11 @@ public class ImputerTrainerTest extends TrainerTest {
             vectorizer
         );
 
-        assertArrayEquals(new double[] {1, 0, 100}, preprocessor.apply(5, VectorUtils.of(Double.NaN, 0, Double.NaN)).features().asArray(), 1e-8);
+        assertArrayEquals(
+            new double[] {1, 0, 100},
+            preprocessor.apply(5, VectorUtils.of(Double.NaN, 0, Double.NaN)).features().asArray(),
+            1e-8
+        );
     }
 
 
@@ -83,7 +87,11 @@ public class ImputerTrainerTest extends TrainerTest {
             vectorizer
         );
 
-        assertArrayEquals(new double[] {0, 0, 22}, preprocessor.apply(5, VectorUtils.of(Double.NaN, 0, Double.NaN)).features().asArray(), 1e-8);
+        assertArrayEquals(
+            new double[] {0, 0, 22},
+            preprocessor.apply(5, VectorUtils.of(Double.NaN, 0, Double.NaN)).features().asArray(),
+            1e-8
+        );
     }
 
     /** Tests {@code fit()} method. */
@@ -108,7 +116,11 @@ public class ImputerTrainerTest extends TrainerTest {
             vectorizer
         );
 
-        assertArrayEquals(new double[] {-1, 0, 22}, preprocessor.apply(5, VectorUtils.of(Double.NaN, 0, Double.NaN)).features().asArray(), 1e-8);
+        assertArrayEquals(
+            new double[] {-1, 0, 22},
+            preprocessor.apply(5, VectorUtils.of(Double.NaN, 0, Double.NaN)).features().asArray(),
+            1e-8
+        );
     }
 
     /** Tests {@code fit()} method. */
@@ -133,7 +145,11 @@ public class ImputerTrainerTest extends TrainerTest {
             vectorizer
         );
 
-        assertArrayEquals(new double[] {0, 0, 100}, preprocessor.apply(5, VectorUtils.of(Double.NaN, 0, Double.NaN)).features().asArray(), 1e-8);
+        assertArrayEquals(
+            new double[] {0, 0, 100},
+            preprocessor.apply(5, VectorUtils.of(Double.NaN, 0, Double.NaN)).features().asArray(),
+            1e-8
+        );
     }
 
     /** Tests {@code fit()} method. */
@@ -158,6 +174,10 @@ public class ImputerTrainerTest extends TrainerTest {
             vectorizer
         );
 
-        assertArrayEquals(new double[] {3, 0, 3}, preprocessor.apply(5, VectorUtils.of(Double.NaN, 0, Double.NaN)).features().asArray(), 1e-8);
+        assertArrayEquals(
+            new double[] {3, 0, 3},
+            preprocessor.apply(5, VectorUtils.of(Double.NaN, 0, Double.NaN)).features().asArray(),
+            1e-8
+        );
     }
 }
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/regressions/linear/LinearRegressionLSQRTrainerTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/regressions/linear/LinearRegressionLSQRTrainerTest.java
index a64651a..0325d37 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/regressions/linear/LinearRegressionLSQRTrainerTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/regressions/linear/LinearRegressionLSQRTrainerTest.java
@@ -121,7 +121,8 @@ public class LinearRegressionLSQRTrainerTest extends TrainerTest {
 
         LinearRegressionLSQRTrainer trainer = new LinearRegressionLSQRTrainer();
 
-        Vectorizer<Integer, double[], Integer, Double> vectorizer = new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.LAST);
+        Vectorizer<Integer, double[], Integer, Double> vectorizer =
+            new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.LAST);
         LinearRegressionModel originalMdl = trainer.fit(
             data,
             parts,
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/regressions/logistic/LogisticRegressionSGDTrainerTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/regressions/logistic/LogisticRegressionSGDTrainerTest.java
index 4375586..1c7e647 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/regressions/logistic/LogisticRegressionSGDTrainerTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/regressions/logistic/LogisticRegressionSGDTrainerTest.java
@@ -80,7 +80,8 @@ public class LogisticRegressionSGDTrainerTest extends TrainerTest {
             new DoubleArrayVectorizer<Integer>().labeled(0)
         );
 
-        Vectorizer<Integer, double[], Integer, Double> vectorizer = new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
+        Vectorizer<Integer, double[], Integer, Double> vectorizer =
+            new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
         LogisticRegressionModel updatedOnSameDS = trainer.update(
             originalMdl,
             cacheMock,
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/selection/cv/CrossValidationTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/selection/cv/CrossValidationTest.java
index bfccc71..87addb0 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/selection/cv/CrossValidationTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/selection/cv/CrossValidationTest.java
@@ -56,7 +56,8 @@ public class CrossValidationTest {
         DebugCrossValidation<DecisionTreeModel, Integer, double[]> scoreCalculator =
             new DebugCrossValidation<>();
 
-        Vectorizer<Integer, double[], Integer, Double> vectorizer = new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
+        Vectorizer<Integer, double[], Integer, Double> vectorizer =
+            new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
 
         int folds = 4;
 
@@ -80,7 +81,8 @@ public class CrossValidationTest {
         for (int i = 0; i < 1000; i++)
             data.put(i, new double[] {i > 500 ? 1.0 : 0.0, i});
 
-        Vectorizer<Integer, double[], Integer, Double> vectorizer = new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
+        Vectorizer<Integer, double[], Integer, Double> vectorizer =
+            new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
 
         DecisionTreeClassificationTrainer trainer = new DecisionTreeClassificationTrainer(1, 0);
 
@@ -119,7 +121,8 @@ public class CrossValidationTest {
             .withBatchSize(14)
             .withSeed(123L);
 
-        Vectorizer<Integer, double[], Integer, Double> vectorizer = new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
+        Vectorizer<Integer, double[], Integer, Double> vectorizer =
+            new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
 
         DebugCrossValidation<LogisticRegressionModel, Integer, double[]> scoreCalculator =
             new DebugCrossValidation<>();
@@ -161,7 +164,8 @@ public class CrossValidationTest {
             .withBatchSize(14)
             .withSeed(123L);
 
-        Vectorizer<Integer, double[], Integer, Double> vectorizer = new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
+        Vectorizer<Integer, double[], Integer, Double> vectorizer =
+            new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
 
         ParamGrid paramGrid = new ParamGrid()
             .addHyperParam("maxIterations", trainer::withMaxIterations, new Double[]{10.0, 100.0, 1000.0, 10000.0})
@@ -169,19 +173,24 @@ public class CrossValidationTest {
             .addHyperParam("batchSize", trainer::withBatchSize, new Double[]{1.0, 2.0, 4.0, 8.0, 16.0});
 
         DebugCrossValidation<LogisticRegressionModel, Integer, double[]> scoreCalculator =
-            (DebugCrossValidation<LogisticRegressionModel, Integer, double[]>) new DebugCrossValidation<LogisticRegressionModel, Integer, double[]>()
-                .withUpstreamMap(data)
-                .withAmountOfParts(1)
-                .withTrainer(trainer)
-                .withMetric(MetricName.ACCURACY)
-                .withPreprocessor(vectorizer)
-                .withAmountOfFolds(4)
-                .isRunningOnPipeline(false)
-                .withParamGrid(paramGrid);
+            (DebugCrossValidation<LogisticRegressionModel, Integer, double[]>)
+                new DebugCrossValidation<LogisticRegressionModel, Integer, double[]>()
+                    .withUpstreamMap(data)
+                    .withAmountOfParts(1)
+                    .withTrainer(trainer)
+                    .withMetric(MetricName.ACCURACY)
+                    .withPreprocessor(vectorizer)
+                    .withAmountOfFolds(4)
+                    .isRunningOnPipeline(false)
+                    .withParamGrid(paramGrid);
 
         CrossValidationResult crossValidationRes = scoreCalculator.tuneHyperParameters();
 
-        assertArrayEquals(crossValidationRes.getBestScore(), new double[]{0.9745762711864406, 1.0, 0.8968253968253969, 0.8661417322834646}, 1e-6);
+        assertArrayEquals(
+            crossValidationRes.getBestScore(),
+            new double[]{0.9745762711864406, 1.0, 0.8968253968253969, 0.8661417322834646},
+            1e-6
+        );
         assertEquals(crossValidationRes.getBestAvgScore(), 0.9343858500738256, 1e-6);
         assertEquals(crossValidationRes.getScoringBoard().size(), 80);
     }
@@ -204,7 +213,8 @@ public class CrossValidationTest {
             .withBatchSize(14)
             .withSeed(123L);
 
-        Vectorizer<Integer, double[], Integer, Double> vectorizer = new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
+        Vectorizer<Integer, double[], Integer, Double> vectorizer =
+            new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
 
         ParamGrid paramGrid = new ParamGrid()
             .withParameterSearchStrategy(
@@ -218,15 +228,16 @@ public class CrossValidationTest {
             .addHyperParam("batchSize", trainer::withBatchSize, new Double[]{1.0, 2.0, 4.0, 8.0, 16.0});
 
         DebugCrossValidation<LogisticRegressionModel, Integer, double[]> scoreCalculator =
-            (DebugCrossValidation<LogisticRegressionModel, Integer, double[]>) new DebugCrossValidation<LogisticRegressionModel, Integer, double[]>()
-                .withUpstreamMap(data)
-                .withAmountOfParts(1)
-                .withTrainer(trainer)
-                .withMetric(MetricName.ACCURACY)
-                .withPreprocessor(vectorizer)
-                .withAmountOfFolds(4)
-                .isRunningOnPipeline(false)
-                .withParamGrid(paramGrid);
+            (DebugCrossValidation<LogisticRegressionModel, Integer, double[]>)
+                new DebugCrossValidation<LogisticRegressionModel, Integer, double[]>()
+                    .withUpstreamMap(data)
+                    .withAmountOfParts(1)
+                    .withTrainer(trainer)
+                    .withMetric(MetricName.ACCURACY)
+                    .withPreprocessor(vectorizer)
+                    .withAmountOfFolds(4)
+                    .isRunningOnPipeline(false)
+                    .withParamGrid(paramGrid);
 
         CrossValidationResult crossValidationRes = scoreCalculator.tuneHyperParameters();
 
@@ -252,7 +263,8 @@ public class CrossValidationTest {
             .withBatchSize(14)
             .withSeed(123L);
 
-        Vectorizer<Integer, double[], Integer, Double> vectorizer = new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
+        Vectorizer<Integer, double[], Integer, Double> vectorizer =
+            new DoubleArrayVectorizer<Integer>().labeled(Vectorizer.LabelCoordinate.FIRST);
 
         ParamGrid paramGrid = new ParamGrid()
             .withParameterSearchStrategy(
@@ -270,15 +282,16 @@ public class CrossValidationTest {
             .addTrainer(trainer);
 
         DebugCrossValidation<LogisticRegressionModel, Integer, double[]> scoreCalculator =
-            (DebugCrossValidation<LogisticRegressionModel, Integer, double[]>) new DebugCrossValidation<LogisticRegressionModel, Integer, double[]>()
-                .withUpstreamMap(data)
... 309 lines suppressed ...