You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by am...@apache.org on 2019/04/26 10:18:37 UTC

[ignite] branch gg-17462 created (now b204c10)

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

amashenkov pushed a change to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git.


      at b204c10  GG-17462: Mute failed test.

This branch includes the following new commits:

     new a263e1e  Licensed under the GridGain Community Edition License (the "License");
     new b33f3d2  "README.md", "README.txt", "NOTICE_HADOOP", "NOTICE_IGNITE", "LICENSE", "NOTICE", "LICENSE_HADOOP", "LICENSE_IGNITE"
     new bb2905d  Additional Readme
     new be3f3de  Ignoring RST files with unapproved licenses, temp fix until correct solution is found
     new 0f056b2  Update Ignite version in properties
     new 58ae2a8  Copyright 2019 GridGain Systems, Inc. and Contributors.
     new 8ac0294  WC-1051 Web Console: Fixed Wrong layout for grids and "no-data" component.
     new e5673e4  WC-902 Web Console: Re-implemented "Profile" page on Angular.
     new 86b691a  WC-930 Web Console: Use native select for "form-field-dropdown" component.
     new 9fdf980  GG-17378: Port IGNITE-11787: Changed Affinity Awareness version to 1.4
     new f188175  GG-17387 Transactional Datacenter Replication implemented
     new 4173880  GG-17382 Fixed whitespaces
     new a0b683e  gg-17381 GridCompatibilityJdbcFromCurClientToPrevSrvTest#runJdbcThinTests fails in master fixed
     new 7515a29  GG-17352I .NET: Add baseline auto-adjust parameters (definition, run-time change)
     new 39e77bd  GG-17387 Minor cleanup after TX DR merge
     new 88b7a5c  GG-17393 [IGNITE-11277] Use maven plugin as default code style checker for project (#11)
     new b204c10  GG-17462: Mute failed test.

The 17 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.



[ignite] 15/17: GG-17387 Minor cleanup after TX DR merge

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 39e77bdce45488db2396fbff35d083d0a0fffe6c
Author: Ivan Rakov <ir...@apache.org>
AuthorDate: Thu Apr 25 17:24:17 2019 +0300

    GG-17387 Minor cleanup after TX DR merge
---
 .../pagemem/wal/record/ConsistentCutRecord.java    |  2 +-
 .../cache/GridCachePartitionExchangeManager.java   | 71 +---------------------
 .../distributed/dht/preloader/ExchangeType.java    |  8 +--
 .../dht/preloader/PartitionsExchangeAware.java     | 32 +++++++++-
 .../cache/persistence/tree/BPlusTree.java          | 10 +--
 .../cache/transactions/IgniteTxManager.java        |  2 +-
 6 files changed, 44 insertions(+), 81 deletions(-)

diff --git a/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/ConsistentCutRecord.java b/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/ConsistentCutRecord.java
index 66741fe..9b93d23 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/ConsistentCutRecord.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/ConsistentCutRecord.java
@@ -16,7 +16,7 @@
 package org.apache.ignite.internal.pagemem.wal.record;
 
 /**
- * todo GG-13416 doc
+ * Empty record which is logged to WAL to obtain pointer to consistent cut border.
  */
 public class ConsistentCutRecord extends WALRecord {
     /** {@inheritDoc} */
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 4750663..bcb1dc5 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
@@ -1155,7 +1155,7 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
      * @param comp Component to be registered.
      */
     public void registerExchangeAwareComponent(PartitionsExchangeAware comp) {
-        exchangeAwareComps.add(new PartitionsExchangeAwareWrapper(comp));
+        exchangeAwareComps.add(comp);
     }
 
     /**
@@ -1164,7 +1164,7 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
      * @param comp Component to be registered.
      */
     public void unregisterExchangeAwareComponent(PartitionsExchangeAware comp) {
-        exchangeAwareComps.remove(new PartitionsExchangeAwareWrapper(comp));
+        exchangeAwareComps.remove(comp);
     }
 
     /**
@@ -3651,73 +3651,6 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
     }
 
     /**
-     * That wrapper class allows avoiding the propagation of the user's exceptions into the Exchange thread.
-     */
-    private class PartitionsExchangeAwareWrapper implements PartitionsExchangeAware {
-        /** */
-        private final PartitionsExchangeAware delegate;
-
-        /**
-         * Creates a new wrapper.
-         * @param delegate Delegate.
-         */
-        public PartitionsExchangeAwareWrapper(PartitionsExchangeAware delegate) {
-            this.delegate = delegate;
-        }
-
-        /** {@inheritDoc} */
-        @Override public void onInitBeforeTopologyLock(GridDhtPartitionsExchangeFuture fut) {
-            try {
-                delegate.onInitBeforeTopologyLock(fut);
-            }
-            catch (Exception e) {
-                U.warn(log, "Failed to execute exchange callback.", e);
-            }
-        }
-
-        /** {@inheritDoc} */
-        @Override public void onInitAfterTopologyLock(GridDhtPartitionsExchangeFuture fut) {
-            try {
-                delegate.onInitAfterTopologyLock(fut);
-            }
-            catch (Exception e) {
-                U.warn(log, "Failed to execute exchange callback.", e);
-            }
-        }
-
-        /** {@inheritDoc} */
-        @Override public void onDoneBeforeTopologyUnlock(GridDhtPartitionsExchangeFuture fut) {
-            try {
-                delegate.onDoneBeforeTopologyUnlock(fut);
-            }
-            catch (Exception e) {
-                U.warn(log, "Failed to execute exchange callback.", e);
-            }
-        }
-
-        /** {@inheritDoc} */
-        @Override public void onDoneAfterTopologyUnlock(GridDhtPartitionsExchangeFuture fut) {
-            try {
-                delegate.onDoneAfterTopologyUnlock(fut);
-            }
-            catch (Exception e) {
-                U.warn(log, "Failed to execute exchange callback.", e);
-            }
-        }
-
-        /** {@inheritDoc} */
-        @Override public int hashCode() {
-            return delegate.hashCode();
-        }
-
-        /** {@inheritDoc} */
-        @SuppressWarnings("EqualsWhichDoesntCheckParameterClass")
-        @Override public boolean equals(Object obj) {
-            return delegate.equals(obj);
-        }
-    }
-
-    /**
      * Class to limit action count for unique objects.
      * <p>
      * NO guarantees of thread safety are provided.
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/ExchangeType.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/ExchangeType.java
index f7d1e35..a80e2cf 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/ExchangeType.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/ExchangeType.java
@@ -16,15 +16,15 @@
 package org.apache.ignite.internal.processors.cache.distributed.dht.preloader;
 
 /**
- * todo javadoc
+ * Enumerates possible types of partition map exchange process.
  */
 public enum ExchangeType {
-    /** */
+    /** Local join of client node: used only on joining node, completed locally. */
     CLIENT,
 
-    /** */
+    /** Distributed partition map exchange, assumes distributed messaging involving coordinator node. */
     ALL,
 
-    /** */
+    /** Leave/join of another client node, completed locally. */
     NONE
 }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/PartitionsExchangeAware.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/PartitionsExchangeAware.java
index ffe5766..dd2dffb 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/PartitionsExchangeAware.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/PartitionsExchangeAware.java
@@ -15,22 +15,52 @@
  */
 package org.apache.ignite.internal.processors.cache.distributed.dht.preloader;
 
+import org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager;
+
 /**
- * todo javadocs
+ * Interface which allows to subscribe a component for partition map exchange events
+ * (via {@link GridCachePartitionExchangeManager#registerExchangeAwareComponent(PartitionsExchangeAware)}).
+ * Heavy computations shouldn't be performed in listener methods: aware components will be notified
+ * synchronously from exchange thread.
+ * Runtime exceptions thrown by listener methods will trigger failure handler (as per exchange thread is critical).
+ * Please ensure that your implementation will never throw an exception if you subscribe to exchange events for
+ * non-system-critical activities.
  */
 public interface PartitionsExchangeAware {
+    /**
+     * Callback from exchange process initialization; called before topology is locked.
+     *
+     * @param fut Partition map exchange future.
+     */
     public default void onInitBeforeTopologyLock(GridDhtPartitionsExchangeFuture fut) {
         // No-op.
     }
 
+    /**
+     * Callback from exchange process initialization; called after topology is locked.
+     * Guarantees that no more data updates will be performed on local node until exchange process is completed.
+     *
+     * @param fut Partition map exchange future.
+     */
     public default void onInitAfterTopologyLock(GridDhtPartitionsExchangeFuture fut) {
         // No-op.
     }
 
+    /**
+     * Callback from exchange process completion; called before topology is unlocked.
+     * Guarantees that no updates were performed on local node since exchange process started.
+     *
+     * @param fut Partition map exchange future.
+     */
     public default void onDoneBeforeTopologyUnlock(GridDhtPartitionsExchangeFuture fut) {
         // No-op.
     }
 
+    /**
+     * Callback from exchange process completion; called after topology is unlocked.
+     *
+     * @param fut Partition map exchange future.
+     */
     public default void onDoneAfterTopologyUnlock(GridDhtPartitionsExchangeFuture fut) {
         // No-op.
     }
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 977d9b6..9fbd608 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
@@ -5839,18 +5839,18 @@ public abstract class BPlusTree<L, T extends L> extends DataStructure implements
     /**
      * Creates a new instance of {@link CorruptedTreeException}.
      *
-     * @param message Detailed error message.
+     * @param msg Detailed error message.
      * @param cause The cause.
      * @param rows Optional parameters.
      * @return New instance of {@link CorruptedTreeException}.
      */
-    private CorruptedTreeException createCorruptedTreeException(String message, Throwable cause, Object... rows) {
+    private CorruptedTreeException createCorruptedTreeException(String msg, Throwable cause, Object... rows) {
         try {
-            return new CorruptedTreeException(String.format(message, rows), cause);
+            return new CorruptedTreeException(String.format(msg, rows), cause);
         }
-        catch (Throwable t) {
+        catch (Throwable ignored) {
             // Failed to create string representation of optional parameters.
-            return new CorruptedTreeException("", cause);
+            return new CorruptedTreeException(msg + " <failed to create rows string representation>", cause);
         }
     }
 }
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 9527956..798d605 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
@@ -2505,7 +2505,7 @@ public class IgniteTxManager extends GridCacheSharedManagerAdapter {
     }
 
     /**
-     *
+     * @return Tracker that is aware of pending transactions state.
      */
     public LocalPendingTransactionsTracker pendingTxsTracker() {
         return pendingTracker;


[ignite] 11/17: GG-17387 Transactional Datacenter Replication implemented

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit f188175382dab58e0c04321659e9ff1d03019a64
Author: Andrey Gura <ag...@apache.org>
AuthorDate: Wed Apr 24 20:44:55 2019 +0300

    GG-17387 Transactional Datacenter Replication implemented
    
    Contributors list:
    
    Aleksey Plekhanov <Pl...@gmail.com>
    Andey Gura <ag...@apache.org>
    Andrey Kuznetsov <st...@gmail.com>
    Dmitriy Sorokin <d....@gmail.com>
    Ivan Daschinskiy <iv...@gmail.com>
    Ivan Rakov <iv...@gmail.com>
    Sergey Antonov <an...@gmail.com>
    Sergey Kosarev <sk...@gridgain.com>
    Vyacheslav Koptilin <sl...@gmail.com>
---
 .../org/apache/ignite/IgniteSystemProperties.java  |   2 +
 .../org/apache/ignite/internal/GridComponent.java  |   5 +-
 .../apache/ignite/internal/GridKernalContext.java  |   8 +
 .../ignite/internal/GridKernalContextImpl.java     |  12 +
 .../java/org/apache/ignite/internal/GridTopic.java |   5 +-
 .../org/apache/ignite/internal/IgniteKernal.java   |  21 +-
 .../ignite/internal/cluster/IgniteClusterImpl.java |  15 +-
 .../communication/GridIoMessageFactory.java        |   1 +
 .../managers/discovery/GridDiscoveryManager.java   |  20 +
 .../pagemem/wal/record/ConsistentCutRecord.java    |  26 +
 .../internal/pagemem/wal/record/DataEntry.java     |   5 +-
 .../internal/pagemem/wal/record/WALRecord.java     |   5 +-
 .../processors/cache/CacheGroupContext.java        |   1 +
 .../processors/cache/GridCacheMapEntry.java        |   2 +
 .../cache/GridCachePartitionExchangeManager.java   | 118 ++-
 .../internal/processors/cache/WalStateManager.java |   2 +-
 .../cache/binary/BinaryMetadataHolder.java         |   4 +-
 .../GridDistributedTxRemoteAdapter.java            |  23 +
 .../dht/GridDhtTopologyFutureAdapter.java          |  10 +-
 .../dht/IgniteClusterReadOnlyException.java        |  41 +
 .../distributed/dht/preloader/ExchangeType.java    |  30 +
 .../dht/preloader/GridDhtPartitionDemander.java    |   6 +-
 .../dht/preloader/GridDhtPartitionSupplier.java    |  45 +-
 .../preloader/GridDhtPartitionsExchangeFuture.java |  74 +-
 .../dht/preloader/GridDhtPreloader.java            |   6 +
 .../dht/preloader/PartitionsExchangeAware.java     |  37 +
 .../dht/topology/GridClientPartitionTopology.java  |   7 +-
 .../dht/topology/GridDhtPartitionTopology.java     |   8 +-
 .../dht/topology/GridDhtPartitionTopologyImpl.java |  29 +-
 .../near/GridNearTxPrepareFutureAdapter.java       |   1 +
 .../GridCacheDatabaseSharedManager.java            | 348 ++++++---
 .../cache/persistence/metastorage/MetaStorage.java |  12 +-
 .../cache/persistence/tree/BPlusTree.java          |  30 +-
 .../wal/AbstractWalRecordsIterator.java            |  11 +-
 .../persistence/wal/FileWriteAheadLogManager.java  |   4 +-
 .../cache/persistence/wal/aware/SegmentAware.java  |   6 +-
 .../wal/aware/SegmentCompressStorage.java          |  39 +-
 .../wal/reader/IgniteWalIteratorFactory.java       |  46 +-
 .../wal/reader/StandaloneGridKernalContext.java    |   6 +
 .../wal/reader/StandaloneWalRecordsIterator.java   |  11 +-
 .../wal/serializer/RecordDataV2Serializer.java     |  10 +
 .../wal/serializer/RecordSerializerFactory.java    |   5 +
 .../serializer/RecordSerializerFactoryImpl.java    |   8 +
 .../cache/transactions/IgniteTxLocalAdapter.java   |   3 +
 .../cache/transactions/IgniteTxManager.java        |  42 +-
 .../LocalPendingTransactionsTracker.java           | 590 ++++++++++++++
 .../cache/transactions/TrackCommittedResult.java   |  57 ++
 .../cache/version/GridCacheVersionManager.java     |  16 +-
 .../cluster/BaselineTopologyHistoryItem.java       |  20 +
 .../cluster/ChangeGlobalStateMessage.java          |   8 +
 .../cluster/GridClusterStateProcessor.java         | 234 ++++--
 .../txdr/NoOpTransactionalDrProcessor.java         |  82 ++
 .../processors/txdr/TransactionalDrProcessor.java  |  77 ++
 .../ignite/internal/util/GridCircularBuffer.java   |  68 +-
 .../apache/ignite/internal/util/IgniteUtils.java   |  37 +
 .../ignite/internal/util/StripedExecutor.java      |  10 +
 .../org/apache/ignite/logger/EchoingLogger.java    | 144 ++++
 .../ignite/spi/discovery/tcp/TcpDiscoverySpi.java  |  10 +
 .../cache/ClusterReadOnlyModeAbstractTest.java     |  10 +
 .../processors/cache/ClusterReadOnlyModeTest.java  |  12 +-
 ...ocalWalModeChangeDuringRebalancingSelfTest.java |   2 +
 .../wal/IgniteNodeStoppedDuringDisableWALTest.java |   2 +-
 .../persistence/wal/aware/SegmentAwareTest.java    |  57 +-
 .../reader/StandaloneWalRecordsIteratorTest.java   | 213 ++++-
 .../LocalPendingTransactionsTrackerTest.java       | 853 +++++++++++++++++++++
 .../lang/utils/GridCircularBufferSelfTest.java     |  79 ++
 .../junits/common/GridCommonAbstractTest.java      |  16 +
 .../apache/ignite/util/GridCommandHandlerTest.java |   2 +-
 .../cache/ClusterReadOnlyModeSqlTest.java          |  16 +-
 .../spi/discovery/zk/ZookeeperDiscoverySpi.java    |  11 +
 .../spi/discovery/zk/internal/ZkRuntimeState.java  |   2 +-
 .../zk/internal/ZookeeperDiscoveryImpl.java        |   9 +
 .../zk/ZookeeperDiscoverySpiTestUtil.java          |  11 +-
 parent/pom.xml                                     |   2 +-
 74 files changed, 3462 insertions(+), 338 deletions(-)

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 886e8c1..85b44f6 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
@@ -265,6 +265,8 @@ public final class IgniteSystemProperties {
      * System property to enable pending transaction tracker.
      * Affects impact of {@link IgniteSystemProperties#IGNITE_DISABLE_WAL_DURING_REBALANCING} property:
      * if this property is set, WAL anyway won't be disabled during rebalancing triggered by baseline topology change.
+     * Now it is not nessessary setting this property before grid starting because enabling of pendingTxTracker happens
+     * automatically if needed, and it should be used for test purposes only.
      */
     public static final String IGNITE_PENDING_TX_TRACKER_ENABLED = "IGNITE_PENDING_TX_TRACKER_ENABLED";
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/GridComponent.java b/modules/core/src/main/java/org/apache/ignite/internal/GridComponent.java
index 6f6f8d1..5861665 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/GridComponent.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/GridComponent.java
@@ -75,7 +75,10 @@ public interface GridComponent {
         SERVICE_PROC,
 
         /** Distributed MetaStorage processor. */
-        META_STORAGE;
+        META_STORAGE,
+
+        /** Transactional data replication processor. */
+        TX_DR_PROC;
 
         /** Cached values array. */
         public static final DiscoveryDataExchangeType[] VALUES = values();
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContext.java b/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContext.java
index 6906ea0..c89831e 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContext.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContext.java
@@ -71,6 +71,7 @@ import org.apache.ignite.internal.processors.session.GridTaskSessionProcessor;
 import org.apache.ignite.internal.processors.subscription.GridInternalSubscriptionProcessor;
 import org.apache.ignite.internal.processors.task.GridTaskProcessor;
 import org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor;
+import org.apache.ignite.internal.processors.txdr.TransactionalDrProcessor;
 import org.apache.ignite.internal.stat.IoStatisticsManager;
 import org.apache.ignite.internal.suggestions.GridPerformanceSuggestions;
 import org.apache.ignite.internal.util.IgniteExceptionRegistry;
@@ -429,6 +430,13 @@ public interface GridKernalContext extends Iterable<GridComponent> {
     public GridSecurityProcessor security();
 
     /**
+     * Gets transactional data replication processor.
+     *
+     * @return Transactional data replication processor.
+     */
+    public TransactionalDrProcessor txDr();
+
+    /**
      * Gets load balancing manager.
      *
      * @return Load balancing manager.
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java
index 4c900a2..e5fddfd 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java
@@ -90,6 +90,7 @@ import org.apache.ignite.internal.processors.session.GridTaskSessionProcessor;
 import org.apache.ignite.internal.processors.subscription.GridInternalSubscriptionProcessor;
 import org.apache.ignite.internal.processors.task.GridTaskProcessor;
 import org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor;
+import org.apache.ignite.internal.processors.txdr.TransactionalDrProcessor;
 import org.apache.ignite.internal.stat.IoStatisticsManager;
 import org.apache.ignite.internal.suggestions.GridPerformanceSuggestions;
 import org.apache.ignite.internal.util.IgniteExceptionRegistry;
@@ -321,6 +322,10 @@ public class GridKernalContextImpl implements GridKernalContext, Externalizable
 
     /** */
     @GridToStringExclude
+    private TransactionalDrProcessor txDrProc;
+
+    /** */
+    @GridToStringExclude
     private List<GridComponent> comps = new LinkedList<>();
 
     /** */
@@ -672,6 +677,8 @@ public class GridKernalContextImpl implements GridKernalContext, Externalizable
             authProc = (IgniteAuthenticationProcessor)comp;
         else if (comp instanceof CompressionProcessor)
             compressProc = (CompressionProcessor)comp;
+        else if (comp instanceof TransactionalDrProcessor)
+            txDrProc = (TransactionalDrProcessor)comp;
         else if (!(comp instanceof DiscoveryNodeValidationProcessor
             || comp instanceof PlatformPluginProcessor))
             assert (comp instanceof GridPluginComponent) : "Unknown manager class: " + comp.getClass();
@@ -845,6 +852,11 @@ public class GridKernalContextImpl implements GridKernalContext, Externalizable
     }
 
     /** {@inheritDoc} */
+    @Override public TransactionalDrProcessor txDr() {
+        return txDrProc;
+    }
+
+    /** {@inheritDoc} */
     @Override public GridLoadBalancerManager loadBalancing() {
         return loadMgr;
     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/GridTopic.java b/modules/core/src/main/java/org/apache/ignite/internal/GridTopic.java
index 4450166..2d25ef2 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/GridTopic.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/GridTopic.java
@@ -141,7 +141,10 @@ public enum GridTopic {
     TOPIC_SERVICES,
 
     /** */
-    TOPIC_DEADLOCK_DETECTION;
+    TOPIC_DEADLOCK_DETECTION,
+
+    /** */
+    TOPIC_TXDR;
 
     /** Enum values. */
     private static final GridTopic[] VALS = values();
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java b/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
index 638755f..fa242cd 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
@@ -81,7 +81,6 @@ import org.apache.ignite.Ignition;
 import org.apache.ignite.MemoryMetrics;
 import org.apache.ignite.PersistenceMetrics;
 import org.apache.ignite.cache.affinity.Affinity;
-import org.apache.ignite.cluster.BaselineNode;
 import org.apache.ignite.cluster.ClusterGroup;
 import org.apache.ignite.cluster.ClusterMetrics;
 import org.apache.ignite.cluster.ClusterNode;
@@ -170,6 +169,8 @@ import org.apache.ignite.internal.processors.session.GridTaskSessionProcessor;
 import org.apache.ignite.internal.processors.subscription.GridInternalSubscriptionProcessor;
 import org.apache.ignite.internal.processors.task.GridTaskProcessor;
 import org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor;
+import org.apache.ignite.internal.processors.txdr.NoOpTransactionalDrProcessor;
+import org.apache.ignite.internal.processors.txdr.TransactionalDrProcessor;
 import org.apache.ignite.internal.suggestions.GridPerformanceSuggestions;
 import org.apache.ignite.internal.suggestions.JvmConfigurationSuggestions;
 import org.apache.ignite.internal.suggestions.OsConfigurationSuggestions;
@@ -1031,6 +1032,9 @@ public class IgniteKernal implements IgniteEx, IgniteMXBean, Externalizable {
                 startProcessor(new DistributedMetaStorageImpl(ctx));
                 startProcessor(new DistributedConfigurationProcessor(ctx));
 
+                // Start transactional data replication processor.
+                startProcessor(createComponent(TransactionalDrProcessor.class, ctx));
+
                 // Start plugins.
                 for (PluginProvider provider : ctx.plugins().allProviders()) {
                     ctx.add(new GridPluginComponent(provider));
@@ -3658,18 +3662,6 @@ public class IgniteKernal implements IgniteEx, IgniteMXBean, Externalizable {
         cluster().active(active);
     }
 
-    /** */
-    private Collection<BaselineNode> baselineNodes() {
-        Collection<ClusterNode> srvNodes = cluster().forServers().nodes();
-
-        ArrayList baselineNodes = new ArrayList(srvNodes.size());
-
-        for (ClusterNode clN : srvNodes)
-            baselineNodes.add(clN);
-
-        return baselineNodes;
-    }
-
     /** {@inheritDoc} */
     @Override public void resetLostPartitions(Collection<String> cacheNames) {
         CU.validateCacheNames(cacheNames);
@@ -4149,6 +4141,9 @@ public class IgniteKernal implements IgniteEx, IgniteMXBean, Externalizable {
         if (cls.equals(IGridClusterStateProcessor.class))
             return (T)new GridClusterStateProcessor(ctx);
 
+        if (cls.equals(TransactionalDrProcessor.class))
+            return (T)new NoOpTransactionalDrProcessor(ctx);
+
         Class<T> implCls = null;
 
         try {
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 32691db..69f8f05 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
@@ -1,12 +1,12 @@
 /*
  * Copyright 2019 GridGain Systems, Inc. and Contributors.
- * 
+ *
  * Licensed under the GridGain Community Edition License (the "License");
  * you may not use this file except in compliance with the License.
  * You may obtain a copy of the License at
- * 
+ *
  *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
- * 
+ *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
@@ -43,8 +43,6 @@ import org.apache.ignite.cluster.ClusterGroupEmptyException;
 import org.apache.ignite.cluster.ClusterNode;
 import org.apache.ignite.cluster.ClusterStartNodeResult;
 import org.apache.ignite.configuration.IgniteConfiguration;
-import org.apache.ignite.events.ClusterActivationEvent;
-import org.apache.ignite.events.EventType;
 import org.apache.ignite.internal.GridKernalContext;
 import org.apache.ignite.internal.IgniteComponentType;
 import org.apache.ignite.internal.IgniteInternalFuture;
@@ -479,7 +477,7 @@ public class IgniteClusterImpl extends ClusterGroupAdapter implements IgniteClus
                     target.add(node);
             }
 
-            validateBeforeBaselineChange(target);
+            ctx.state().validateBeforeBaselineChange(target);
 
             ctx.state().changeGlobalState(true, target, true, isBaselineAutoAdjust).get();
         }
@@ -767,8 +765,7 @@ public class IgniteClusterImpl extends ClusterGroupAdapter implements IgniteClus
 
             // If there is nothing to start, return finished future with empty result.
             if (nodeCallCnt == 0)
-                return new GridFinishedFuture<Collection<ClusterStartNodeResult>>(
-                    Collections.<ClusterStartNodeResult>emptyList());
+                return new GridFinishedFuture<>(Collections.emptyList());
 
             // Exceeding max line width for readability.
             GridCompoundFuture<ClusterStartNodeResult, Collection<ClusterStartNodeResult>> fut =
@@ -887,4 +884,4 @@ public class IgniteClusterImpl extends ClusterGroupAdapter implements IgniteClus
     @Override public String toString() {
         return "IgniteCluster [igniteInstanceName=" + ctx.igniteInstanceName() + ']';
     }
-}
\ No newline at end of file
+}
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/managers/communication/GridIoMessageFactory.java b/modules/core/src/main/java/org/apache/ignite/internal/managers/communication/GridIoMessageFactory.java
index d716e84..31b06fa 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/managers/communication/GridIoMessageFactory.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/managers/communication/GridIoMessageFactory.java
@@ -1159,6 +1159,7 @@ public class GridIoMessageFactory implements MessageFactory {
             // [120..123] - DR
             // [-4..-22, -30..-35] - SQL
             // [2048..2053] - Snapshots
+            // [4096..4096] - TxDR
             default:
                 if (ext != null) {
                     for (MessageFactory factory : ext) {
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 aa39f8f..a5725a7 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
@@ -24,6 +24,7 @@ import java.lang.management.MemoryUsage;
 import java.lang.management.OperatingSystemMXBean;
 import java.lang.management.RuntimeMXBean;
 import java.lang.management.ThreadMXBean;
+import java.lang.reflect.InvocationTargetException;
 import java.util.ArrayDeque;
 import java.util.ArrayList;
 import java.util.Collection;
@@ -2343,6 +2344,25 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
     }
 
     /**
+     * Sets grid start time.
+     *
+     * @param val New time value.
+     */
+    public void setGridStartTime(long val) {
+        DiscoverySpi spi = getSpi();
+
+        try {
+            spi.getClass().getMethod("setGridStartTime", long.class).invoke(spi, val);
+        }
+        catch (NoSuchMethodException e) {
+            U.error(log, "Discovery SPI has no 'setGridStartTime(long)' method [class=" + spi.getClass() + ']', e);
+        }
+        catch (IllegalAccessException | InvocationTargetException e) {
+            throw new IgniteException(e);
+        }
+    }
+
+    /**
      * @param nodeId Node ID.
      * @param warning Warning message to be shown on all nodes.
      * @return Whether node is failed.
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/ConsistentCutRecord.java b/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/ConsistentCutRecord.java
new file mode 100644
index 0000000..822efd6f
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/pagemem/wal/record/ConsistentCutRecord.java
@@ -0,0 +1,26 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.ignite.internal.pagemem.wal.record;
+
+/**
+ * todo GG-13416 doc
+ */
+public class ConsistentCutRecord extends WALRecord {
+    /** {@inheritDoc} */
+    @Override public RecordType type() {
+        return RecordType.CONSISTENT_CUT;
+    }
+}
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 add5b70..7c039e1 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
@@ -97,8 +97,9 @@ public class DataEntry {
         this.partId = partId;
         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 :
+            "Only READ, CREATE, UPDATE and DELETE operations should be stored in WAL [op=" + 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 4406ffa..4751502 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
@@ -207,7 +207,10 @@ public abstract class WALRecord {
         MVCC_DATA_RECORD (LOGICAL),
 
         /** Mvcc Tx state change record. */
-        MVCC_TX_RECORD (LOGICAL);
+        MVCC_TX_RECORD (LOGICAL),
+
+        /** Consistent cut record. */
+        CONSISTENT_CUT;
 
         /**
          * When you're adding a new record don't forget to choose record purpose explicitly
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheGroupContext.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheGroupContext.java
index f1cfc85..582c444 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheGroupContext.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheGroupContext.java
@@ -864,6 +864,7 @@ public class CacheGroupContext {
     }
 
     /**
+
      * @return {@code True} if current cache group is in recovery mode.
      */
     public boolean isRecoveryMode() {
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 4889153..81872fe 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
@@ -4332,6 +4332,8 @@ public abstract class GridCacheMapEntry extends GridMetadataAwareAdapter impleme
             else
                 op = this.val == null ? GridCacheOperation.CREATE : UPDATE;
 
+            cctx.tm().pendingTxsTracker().onKeysWritten(tx.nearXidVersion(), Collections.singletonList(key));
+
             return cctx.shared().wal().log(new DataRecord(new DataEntry(
                 cctx.cacheId(),
                 key,
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 ee81b06..c606a2c 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
@@ -93,6 +93,7 @@ import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.Gri
 import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPreloaderAssignments;
 import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.IgniteDhtPartitionHistorySuppliersMap;
 import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.IgniteDhtPartitionsToReloadMap;
+import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.PartitionsExchangeAware;
 import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.RebalanceReassignExchangeTask;
 import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.StopCachesOnClientReconnectExchangeTask;
 import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.latch.ExchangeLatchManager;
@@ -260,6 +261,9 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
     /** Distributed latch manager. */
     private ExchangeLatchManager latchMgr;
 
+    /** List of exchange aware components. */
+    private final List<PartitionsExchangeAware> exchangeAwareComps = new ArrayList<>();
+
     /** Discovery listener. */
     private final DiscoveryEventListener discoLsnr = new DiscoveryEventListener() {
         @Override public void onEvent(DiscoveryEvent evt, DiscoCache cache) {
@@ -1146,6 +1150,31 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
     }
 
     /**
+     * Registers component that will be notified on every partition map exchange.
+     *
+     * @param comp Component to be registered.
+     */
+    public void registerExchangeAwareComponent(PartitionsExchangeAware comp) {
+        exchangeAwareComps.add(new PartitionsExchangeAwareWrapper(comp));
+    }
+
+    /**
+     * Removes exchange aware component from list of listeners.
+     *
+     * @param comp Component to be registered.
+     */
+    public void unregisterExchangeAwareComponent(PartitionsExchangeAware comp) {
+        exchangeAwareComps.remove(new PartitionsExchangeAwareWrapper(comp));
+    }
+
+    /**
+     * @return List of registered exchange listeners.
+     */
+    public List<PartitionsExchangeAware> exchangeAwareComponents() {
+        return U.sealList(exchangeAwareComps);
+    }
+
+    /**
      * Partition refresh callback for selected cache groups.
      * For coordinator causes {@link GridDhtPartitionsFullMessage FullMessages} send,
      * for non coordinator -  {@link GridDhtPartitionsSingleMessage SingleMessages} send
@@ -1239,9 +1268,8 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
     ) {
         long time = System.currentTimeMillis();
 
-        GridDhtPartitionsFullMessage m = createPartitionsFullMessage(true, false, null, null, null, null, grps);
-
-        m.topologyVersion(msgTopVer);
+        GridDhtPartitionsFullMessage m = createPartitionsFullMessage(true, false, null,
+            msgTopVer, null, null, null, grps);
 
         if (log.isInfoEnabled()) {
             long latency = System.currentTimeMillis() - time;
@@ -1306,13 +1334,14 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
         boolean compress,
         boolean newCntrMap,
         @Nullable final GridDhtPartitionExchangeId exchId,
+        @Nullable AffinityTopologyVersion msgTopVer,
         @Nullable GridCacheVersion lastVer,
         @Nullable IgniteDhtPartitionHistorySuppliersMap partHistSuppliers,
         @Nullable IgniteDhtPartitionsToReloadMap partsToReload
     ) {
         Collection<CacheGroupContext> grps = cctx.cache().cacheGroups();
 
-        return createPartitionsFullMessage(compress, newCntrMap, exchId, lastVer, partHistSuppliers, partsToReload, grps);
+        return createPartitionsFullMessage(compress, newCntrMap, exchId, msgTopVer, lastVer, partHistSuppliers, partsToReload, grps);
     }
 
     /**
@@ -1332,15 +1361,21 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
         boolean compress,
         boolean newCntrMap,
         @Nullable final GridDhtPartitionExchangeId exchId,
+        @Nullable AffinityTopologyVersion msgTopVer,
         @Nullable GridCacheVersion lastVer,
         @Nullable IgniteDhtPartitionHistorySuppliersMap partHistSuppliers,
         @Nullable IgniteDhtPartitionsToReloadMap partsToReload,
         Collection<CacheGroupContext> grps
     ) {
-        AffinityTopologyVersion ver = exchId != null ? exchId.topologyVersion() : AffinityTopologyVersion.NONE;
+        assert (exchId != null) ^ (msgTopVer != null): "Topology version of full map message must be specified" +
+            " either via exchangeId=[" + exchId + "], or via msgTopVer=[" + msgTopVer + "].";
 
-        final GridDhtPartitionsFullMessage m =
-            new GridDhtPartitionsFullMessage(exchId, lastVer, ver, partHistSuppliers, partsToReload);
+        final GridDhtPartitionsFullMessage m = new GridDhtPartitionsFullMessage(exchId,
+            lastVer,
+            exchId != null ? exchId.topologyVersion() : msgTopVer,
+            partHistSuppliers,
+            partsToReload
+            );
 
         m.compress(compress);
 
@@ -1396,6 +1431,8 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
             }
         }
 
+        cctx.kernalContext().txDr().onPartitionsFullMessagePrepared(exchId, m);
+
         return m;
     }
 
@@ -3614,6 +3651,73 @@ public class GridCachePartitionExchangeManager<K, V> extends GridCacheSharedMana
     }
 
     /**
+     * That wrapper class allows avoiding the propagation of the user's exceptions into the Exchange thread.
+     */
+    private class PartitionsExchangeAwareWrapper implements PartitionsExchangeAware {
+        /** */
+        private final PartitionsExchangeAware delegate;
+
+        /**
+         * Creates a new wrapper.
+         * @param delegate Delegate.
+         */
+        public PartitionsExchangeAwareWrapper(PartitionsExchangeAware delegate) {
+            this.delegate = delegate;
+        }
+
+        /** {@inheritDoc} */
+        @Override public void onInitBeforeTopologyLock(GridDhtPartitionsExchangeFuture fut) {
+            try {
+                delegate.onInitBeforeTopologyLock(fut);
+            }
+            catch (Exception e) {
+                U.warn(log, "Failed to execute exchange callback.", e);
+            }
+        }
+
+        /** {@inheritDoc} */
+        @Override public void onInitAfterTopologyLock(GridDhtPartitionsExchangeFuture fut) {
+            try {
+                delegate.onInitAfterTopologyLock(fut);
+            }
+            catch (Exception e) {
+                U.warn(log, "Failed to execute exchange callback.", e);
+            }
+        }
+
+        /** {@inheritDoc} */
+        @Override public void onDoneBeforeTopologyUnlock(GridDhtPartitionsExchangeFuture fut) {
+            try {
+                delegate.onDoneBeforeTopologyUnlock(fut);
+            }
+            catch (Exception e) {
+                U.warn(log, "Failed to execute exchange callback.", e);
+            }
+        }
+
+        /** {@inheritDoc} */
+        @Override public void onDoneAfterTopologyUnlock(GridDhtPartitionsExchangeFuture fut) {
+            try {
+                delegate.onDoneAfterTopologyUnlock(fut);
+            }
+            catch (Exception e) {
+                U.warn(log, "Failed to execute exchange callback.", e);
+            }
+        }
+
+        /** {@inheritDoc} */
+        @Override public int hashCode() {
+            return delegate.hashCode();
+        }
+
+        /** {@inheritDoc} */
+        @SuppressWarnings("EqualsWhichDoesntCheckParameterClass")
+        @Override public boolean equals(Object obj) {
+            return delegate.equals(obj);
+        }
+    }
+
+    /**
      * Class to limit action count for unique objects.
      * <p>
      * NO guarantees of thread safety are provided.
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/WalStateManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/WalStateManager.java
index 2156d33..14f0399 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/WalStateManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/WalStateManager.java
@@ -390,7 +390,7 @@ public class WalStateManager extends GridCacheSharedManagerAdapter {
      */
     public void changeLocalStatesOnExchangeDone(AffinityTopologyVersion topVer, boolean changedBaseline) {
         if (changedBaseline
-            && IgniteSystemProperties.getBoolean(IgniteSystemProperties.IGNITE_PENDING_TX_TRACKER_ENABLED)
+            && cctx.tm().pendingTxsTracker().enabled()
             || !IgniteSystemProperties.getBoolean(IgniteSystemProperties.IGNITE_DISABLE_WAL_DURING_REBALANCING, true))
             return;
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/binary/BinaryMetadataHolder.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/binary/BinaryMetadataHolder.java
index f850d34..2a9834a 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/binary/BinaryMetadataHolder.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/binary/BinaryMetadataHolder.java
@@ -38,8 +38,8 @@ final class BinaryMetadataHolder implements Serializable {
 
     /**
      * @param metadata Metadata.
-     * @param pendingVer Version of this metadata - how many updates were issued for this type.
-     * @param acceptedVer Pending updates count.
+     * @param pendingVer Pending updates count.
+     * @param acceptedVer Version of this metadata - how many updates were issued for this type.
      */
     BinaryMetadataHolder(BinaryMetadata metadata, int pendingVer, int acceptedVer) {
         assert metadata != null;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/GridDistributedTxRemoteAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/GridDistributedTxRemoteAdapter.java
index d3b573c..3e24968 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/GridDistributedTxRemoteAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/GridDistributedTxRemoteAdapter.java
@@ -775,6 +775,8 @@ public abstract class GridDistributedTxRemoteAdapter extends IgniteTxAdapter
                                 .map(tuple -> tuple.get1().partitionCounter(tuple.get2().updateCounter()))
                                 .collect(Collectors.toList());
 
+                            logKeysToPendingTxsTracker(entriesWithCounters);
+
                             cctx.wal().log(new DataRecord(entriesWithCounters));
                         }
 
@@ -817,6 +819,27 @@ public abstract class GridDistributedTxRemoteAdapter extends IgniteTxAdapter
         }
     }
 
+    /**
+     * @param dataEntries Data entries.
+     */
+    private void logKeysToPendingTxsTracker(List<DataEntry> dataEntries) {
+        for (DataEntry dataEntry : dataEntries) {
+            List<KeyCacheObject> readKeys = new ArrayList<>();
+            List<KeyCacheObject> writeKeys = new ArrayList<>();
+
+            if (dataEntry.op() == READ)
+                readKeys.add(dataEntry.key());
+            else
+                writeKeys.add(dataEntry.key());
+
+            if (!readKeys.isEmpty())
+                cctx.tm().pendingTxsTracker().onKeysRead(nearXidVersion(), readKeys);
+
+            if (!writeKeys.isEmpty())
+                cctx.tm().pendingTxsTracker().onKeysWritten(nearXidVersion(), writeKeys);
+        }
+    }
+
     /** {@inheritDoc} */
     @Override public final void commitRemoteTx() throws IgniteCheckedException {
         if (optimistic())
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtTopologyFutureAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtTopologyFutureAdapter.java
index db097af..41e7fdd 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtTopologyFutureAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtTopologyFutureAdapter.java
@@ -29,12 +29,15 @@ import org.apache.ignite.internal.processors.cache.CacheInvalidStateException;
 import org.apache.ignite.internal.processors.cache.GridCacheContext;
 import org.apache.ignite.internal.util.future.GridFutureAdapter;
 import org.apache.ignite.internal.util.typedef.F;
+import org.apache.ignite.internal.util.typedef.internal.CU;
 import org.jetbrains.annotations.Nullable;
 
 import static org.apache.ignite.cache.PartitionLossPolicy.READ_ONLY_ALL;
 import static org.apache.ignite.cache.PartitionLossPolicy.READ_ONLY_SAFE;
 import static org.apache.ignite.cache.PartitionLossPolicy.READ_WRITE_SAFE;
+import static org.apache.ignite.internal.processors.cache.GridCacheUtils.isSystemCache;
 import static org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtTopologyFutureAdapter.OperationType.WRITE;
+import static org.apache.ignite.internal.processors.datastructures.DataStructuresProcessor.DEFAULT_VOLATILE_DS_GROUP_NAME;
 
 /**
  *
@@ -93,8 +96,11 @@ public abstract class GridDhtTopologyFutureAdapter extends GridFutureAdapter<Aff
 
         PartitionLossPolicy lossPlc = grp.config().getPartitionLossPolicy();
 
-        if (cctx.shared().readOnlyMode() && opType == WRITE)
-            return new IgniteCheckedException("Failed to perform cache operation (cluster is in read only mode)");
+        if (cctx.shared().readOnlyMode() && opType == WRITE && !isSystemCache(cctx.name())
+                && cctx.group().groupId() != CU.cacheId(DEFAULT_VOLATILE_DS_GROUP_NAME)) {
+            return new IgniteClusterReadOnlyException("Failed to perform cache operation (cluster is in read only mode) " +
+                    "[cacheGrp=" + cctx.group().name() + ", cache=" + cctx.name() + ']');
+        }
 
         if (grp.needsRecovery() && !recovery) {
             if (opType == WRITE && (lossPlc == READ_ONLY_SAFE || lossPlc == READ_ONLY_ALL))
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteClusterReadOnlyException.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteClusterReadOnlyException.java
new file mode 100644
index 0000000..b83eb5c
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteClusterReadOnlyException.java
@@ -0,0 +1,41 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.ignite.internal.processors.cache.distributed.dht;
+
+import org.apache.ignite.IgniteCheckedException;
+
+/**
+ This exception is used to indicate that the cluster is in a read-only state
+ */
+public class IgniteClusterReadOnlyException extends IgniteCheckedException {
+    /** */
+    private static final long serialVersionUID = 0L;
+    
+    /**
+     * Create empty exception.
+     */
+    public IgniteClusterReadOnlyException() {
+    }
+
+    /**
+     * Creates new exception with given error message.
+     *
+     * @param msg Error message.
+     */
+    public IgniteClusterReadOnlyException(String msg) {
+        super(msg);
+    }
+}
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/ExchangeType.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/ExchangeType.java
new file mode 100644
index 0000000..f7d1e35
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/ExchangeType.java
@@ -0,0 +1,30 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.ignite.internal.processors.cache.distributed.dht.preloader;
+
+/**
+ * todo javadoc
+ */
+public enum ExchangeType {
+    /** */
+    CLIENT,
+
+    /** */
+    ALL,
+
+    /** */
+    NONE
+}
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemander.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemander.java
index 6b97678..47b9c0c 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemander.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemander.java
@@ -318,9 +318,8 @@ public class GridDhtPartitionDemander {
                     metrics.clearRebalanceCounters();
 
                     for (GridDhtPartitionDemandMessage msg : assignments.values()) {
-                        for (Integer partId : msg.partitions().fullSet()) {
+                        for (Integer partId : msg.partitions().fullSet())
                             metrics.onRebalancingKeysCountEstimateReceived(grp.topology().globalPartSizes().get(partId));
-                        }
 
                         CachePartitionPartialCountersMap histMap = msg.partitions().historicalMap();
 
@@ -783,6 +782,9 @@ public class GridDhtPartitionDemander {
                             // If message was last for this partition,
                             // then we take ownership.
                             if (last) {
+                                if (ctx.kernalContext().txDr().shouldApplyUpdateCounterOnRebalance())
+                                    grp.offheap().onPartitionInitialCounterUpdated(p, supplyMsg.last().get(p));
+
                                 fut.partitionDone(nodeId, p, true);
 
                                 if (log.isDebugEnabled())
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionSupplier.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionSupplier.java
index 59d8463..cd3ecc8 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionSupplier.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionSupplier.java
@@ -222,6 +222,8 @@ class GridDhtPartitionSupplier {
 
         SupplyContext sctx = null;
 
+        Map<Integer, Long> initUpdateCntrs;
+
         try {
             synchronized (scMap) {
                 sctx = scMap.remove(contextId);
@@ -274,12 +276,26 @@ class GridDhtPartitionSupplier {
             Set<Integer> remainingParts;
 
             if (sctx == null || sctx.iterator == null) {
-                iter = grp.offheap().rebalanceIterator(demandMsg.partitions(), demandMsg.topologyVersion());
-
                 remainingParts = new HashSet<>(demandMsg.partitions().fullSet());
 
+                Set<Integer> demandParts = new HashSet<>(demandMsg.partitions().fullSet());
+
                 CachePartitionPartialCountersMap histMap = demandMsg.partitions().historicalMap();
 
+                for (int i = 0; i < histMap.size(); ++i)
+                    demandParts.add(histMap.partitionAt(i));
+
+                initUpdateCntrs = new HashMap<>(demandParts.size());
+
+                for (Integer part : demandParts) {
+                    GridDhtLocalPartition loc = top.localPartition(part, demandMsg.topologyVersion(), false);
+
+                    if (loc != null && loc.state() == GridDhtPartitionState.OWNING)
+                        initUpdateCntrs.put(part, loc.updateCounter());
+                }
+
+                iter = grp.offheap().rebalanceIterator(demandMsg.partitions(), demandMsg.topologyVersion());
+
                 for (int i = 0; i < histMap.size(); i++) {
                     int p = histMap.partitionAt(i);
 
@@ -311,6 +327,8 @@ class GridDhtPartitionSupplier {
                 iter = sctx.iterator;
 
                 remainingParts = sctx.remainingParts;
+
+                initUpdateCntrs = sctx.initUpdateCntrs;
             }
 
             final int msgMaxSize = grp.config().getRebalanceBatchSize();
@@ -332,7 +350,8 @@ class GridDhtPartitionSupplier {
                         saveSupplyContext(contextId,
                             iter,
                             remainingParts,
-                            demandMsg.rebalanceId()
+                            demandMsg.rebalanceId(),
+                            initUpdateCntrs
                         );
 
                         reply(topicId, demanderNode, demandMsg, supplyMsg, contextId);
@@ -393,7 +412,7 @@ class GridDhtPartitionSupplier {
                 }
 
                 if (iter.isPartitionDone(part)) {
-                    supplyMsg.last(part, loc.updateCounter());
+                    supplyMsg.last(part, initUpdateCntrs.get(part));
 
                     remainingParts.remove(part);
 
@@ -595,17 +614,19 @@ class GridDhtPartitionSupplier {
      * @param entryIt Entries rebalance iterator.
      * @param remainingParts Set of partitions that weren't sent yet.
      * @param rebalanceId Rebalance id.
+     * @param initUpdateCntrs Collection of update counters that corresponds to the beginning of rebalance.
      */
     private void saveSupplyContext(
         T3<UUID, Integer, AffinityTopologyVersion> contextId,
         IgniteRebalanceIterator entryIt,
         Set<Integer> remainingParts,
-        long rebalanceId
+        long rebalanceId,
+        Map<Integer, Long> initUpdateCntrs
     ) {
         synchronized (scMap) {
             assert scMap.get(contextId) == null;
 
-            scMap.put(contextId, new SupplyContext(entryIt, remainingParts, rebalanceId));
+            scMap.put(contextId, new SupplyContext(entryIt, remainingParts, rebalanceId, initUpdateCntrs));
         }
     }
 
@@ -623,17 +644,27 @@ class GridDhtPartitionSupplier {
         /** Rebalance id. */
         private final long rebalanceId;
 
+        /** Update counters for rebalanced partitions. */
+        private final Map<Integer, Long> initUpdateCntrs;
+
         /**
          * Constructor.
          *
          * @param iterator Entries rebalance iterator.
          * @param remainingParts Set of partitions which weren't sent yet.
          * @param rebalanceId Rebalance id.
+         * @param initUpdateCntrs Collection of update counters that corresponds to the beginning of rebalance.
          */
-        SupplyContext(IgniteRebalanceIterator iterator, Set<Integer> remainingParts, long rebalanceId) {
+        SupplyContext(
+            IgniteRebalanceIterator iterator,
+            Set<Integer> remainingParts,
+            long rebalanceId,
+            Map<Integer, Long> initUpdateCntrs
+        ) {
             this.iterator = iterator;
             this.remainingParts = remainingParts;
             this.rebalanceId = rebalanceId;
+            this.initUpdateCntrs = initUpdateCntrs;
         }
 
         /** {@inheritDoc} */
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 4e223c4..a819b8b 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
@@ -104,6 +104,7 @@ import org.apache.ignite.internal.processors.cluster.ChangeGlobalStateMessage;
 import org.apache.ignite.internal.processors.cluster.DiscoveryDataClusterState;
 import org.apache.ignite.internal.processors.cluster.IgniteChangeGlobalStateSupport;
 import org.apache.ignite.internal.processors.service.GridServiceProcessor;
+import org.apache.ignite.internal.processors.txdr.TransactionalDrProcessor;
 import org.apache.ignite.internal.util.IgniteUtils;
 import org.apache.ignite.internal.util.TimeBag;
 import org.apache.ignite.internal.util.future.GridFutureAdapter;
@@ -204,6 +205,9 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
     /** */
     private AtomicBoolean added = new AtomicBoolean(false);
 
+    /** Exchange type. */
+    private volatile ExchangeType exchangeType;
+
     /**
      * Discovery event receive latch. There is a race between discovery event processing and single message
      * processing, so it is possible to create an exchange future before the actual discovery event is received.
@@ -496,6 +500,13 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
     }
 
     /**
+     * @return Exchange type or <code>null</code> if not determined yet.
+     */
+    public ExchangeType exchangeType() {
+        return exchangeType;
+    }
+
+    /**
      * Retreives the node which has WAL history since {@code cntrSince}.
      *
      * @param grpId Cache group ID.
@@ -852,6 +863,11 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
 
             cctx.cache().registrateProxyRestart(resolveCacheRequests(exchActions), afterLsnrCompleteFut);
 
+            exchangeType = exchange;
+
+            for (PartitionsExchangeAware comp : cctx.exchange().exchangeAwareComponents())
+                comp.onInitBeforeTopologyLock(this);
+
             updateTopologies(crdNode);
 
             timeBag.finishGlobalStage("Determine exchange type");
@@ -899,6 +915,9 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
                 }
             }
 
+            for (PartitionsExchangeAware comp : cctx.exchange().exchangeAwareComponents())
+                comp.onInitAfterTopologyLock(this);
+
             if (exchLog.isInfoEnabled())
                 exchLog.info("Finished exchange init [topVer=" + topVer + ", crd=" + crdNode + ']');
         }
@@ -1185,6 +1204,8 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
                 cctx.exchange().exchangerBlockingSectionBegin();
 
                 try {
+                    kctx.txDr().onDeActivate(cctx.kernalContext());
+
                     kctx.dataStructures().onDeActivate(kctx);
 
                     if (cctx.kernalContext().service() instanceof GridServiceProcessor)
@@ -1938,6 +1959,7 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
             compress,
             newCntrMap,
             exchangeId(),
+            null,
             last != null ? last : cctx.versions().last(),
             partHistSuppliers,
             partsToReload);
@@ -2207,6 +2229,9 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
             if (err == null)
                 cctx.coordinators().onExchangeDone(events().discoveryCache());
 
+            for (PartitionsExchangeAware comp : cctx.exchange().exchangeAwareComponents())
+                comp.onDoneBeforeTopologyUnlock(this);
+
             // Create and destory caches and cache proxies.
             cctx.cache().onExchangeDone(initialVersion(), exchActions, err);
 
@@ -2308,6 +2333,9 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
                 }
             }
 
+            for (PartitionsExchangeAware comp : cctx.exchange().exchangeAwareComponents())
+                comp.onDoneAfterTopologyUnlock(this);
+
             if (firstDiscoEvt instanceof DiscoveryCustomEvent)
                 ((DiscoveryCustomEvent)firstDiscoEvt).customMessage(null);
 
@@ -3150,7 +3178,19 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
 
         top.globalPartSizes(partSizes);
 
-        Map<UUID, Set<Integer>> partitionsToRebalance = top.resetOwners(ownersByUpdCounters, haveHistory);
+        TransactionalDrProcessor txDrProc = cctx.kernalContext().txDr();
+
+        boolean skipResetOwners = txDrProc != null && txDrProc.shouldIgnoreAssignPartitionStates(this);
+
+        Set<UUID> joinedNodes = new HashSet<>();
+
+        for (DiscoveryEvent evt : events().events()) {
+            if (evt.type() == EVT_NODE_JOINED)
+                joinedNodes.add(evt.eventNode().id());
+        }
+
+        Map<UUID, Set<Integer>> partitionsToRebalance = top.resetOwners(
+            ownersByUpdCounters, haveHistory, joinedNodes, skipResetOwners);
 
         for (Map.Entry<UUID, Set<Integer>> e : partitionsToRebalance.entrySet()) {
             UUID nodeId = e.getKey();
@@ -3413,6 +3453,10 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
                     });
             }
 
+            TransactionalDrProcessor txDrProc = cctx.kernalContext().txDr();
+
+            boolean skipResetOwners = txDrProc != null && txDrProc.shouldIgnoreAssignPartitionStates(this);
+
             timeBag.finishGlobalStage("Affinity recalculation (crd)");
 
             Map<Integer, CacheGroupAffinityMessage> joinedNodeAff = new ConcurrentHashMap<>(cctx.cache().cacheGroups().size());
@@ -3469,9 +3513,11 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
                 timeBag.finishGlobalStage("Ideal affinity diff calculation (enforced)");
             }
 
-            for (CacheGroupContext grpCtx : cctx.cache().cacheGroups()) {
-                if (!grpCtx.isLocal())
-                    grpCtx.topology().applyUpdateCounters();
+            if (!skipResetOwners) {
+                for (CacheGroupContext grpCtx : cctx.cache().cacheGroups()) {
+                    if (!grpCtx.isLocal())
+                        grpCtx.topology().applyUpdateCounters();
+                }
             }
 
             timeBag.finishGlobalStage("Apply update counters");
@@ -3639,6 +3685,10 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
         GridDhtPartitionsSingleMessage msg,
         Map<Integer, CacheGroupAffinityMessage> messageAccumulator
     ) {
+        TransactionalDrProcessor txDrProc = cctx.kernalContext().txDr();
+
+        boolean skipResetOwners = txDrProc != null && txDrProc.shouldIgnoreAssignPartitionStates(this);
+
         for (Map.Entry<Integer, GridDhtPartitionMap> e : msg.partitions().entrySet()) {
             Integer grpId = e.getKey();
 
@@ -3650,7 +3700,7 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
 
             CachePartitionPartialCountersMap cntrs = msg.partitionUpdateCounters(grpId, top.partitions());
 
-            if (cntrs != null)
+            if (cntrs != null && !skipResetOwners)
                 top.collectUpdateCounters(cntrs);
         }
 
@@ -5034,20 +5084,6 @@ public class GridDhtPartitionsExchangeFuture extends GridDhtTopologyFutureAdapte
     /**
      *
      */
-    enum ExchangeType {
-        /** */
-        CLIENT,
-
-        /** */
-        ALL,
-
-        /** */
-        NONE
-    }
-
-    /**
-     *
-     */
     private enum ExchangeLocalState {
         /** Local node is coordinator. */
         CRD,
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 5181e90..2c99314 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
@@ -40,6 +40,7 @@ import org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtFuture
 import org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtPartitionTopology;
 import org.apache.ignite.internal.processors.cache.distributed.dht.atomic.GridNearAtomicAbstractUpdateRequest;
 import org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtLocalPartition;
+import org.apache.ignite.internal.processors.txdr.TransactionalDrProcessor;
 import org.apache.ignite.internal.util.future.GridCompoundFuture;
 import org.apache.ignite.internal.util.future.GridFinishedFuture;
 import org.apache.ignite.internal.util.future.GridFutureAdapter;
@@ -182,6 +183,11 @@ public class GridDhtPreloader extends GridCachePreloaderAdapter {
         if (exchFut.localJoinExchange())
             return true; // Required, can have outdated updSeq partition counter if node reconnects.
 
+        TransactionalDrProcessor txDrProc = ctx.kernalContext().txDr();
+
+        if (txDrProc != null && txDrProc.shouldScheduleRebalance(exchFut))
+            return true;
+
         if (!grp.affinity().cachedVersions().contains(rebTopVer)) {
             assert rebTopVer.compareTo(grp.localStartVersion()) <= 0 :
                 "Empty hisroty allowed only for newly started cache group [rebTopVer=" + rebTopVer +
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/PartitionsExchangeAware.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/PartitionsExchangeAware.java
new file mode 100644
index 0000000..ffe5766
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/PartitionsExchangeAware.java
@@ -0,0 +1,37 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.ignite.internal.processors.cache.distributed.dht.preloader;
+
+/**
+ * todo javadocs
+ */
+public interface PartitionsExchangeAware {
+    public default void onInitBeforeTopologyLock(GridDhtPartitionsExchangeFuture fut) {
+        // No-op.
+    }
+
+    public default void onInitAfterTopologyLock(GridDhtPartitionsExchangeFuture fut) {
+        // No-op.
+    }
+
+    public default void onDoneBeforeTopologyUnlock(GridDhtPartitionsExchangeFuture fut) {
+        // No-op.
+    }
+
+    public default void onDoneAfterTopologyUnlock(GridDhtPartitionsExchangeFuture fut) {
+        // No-op.
+    }
+}
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridClientPartitionTopology.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridClientPartitionTopology.java
index e9b8b6b..e3d06c3 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridClientPartitionTopology.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridClientPartitionTopology.java
@@ -1161,7 +1161,12 @@ public class GridClientPartitionTopology implements GridDhtPartitionTopology {
     }
 
     /** {@inheritDoc} */
-    @Override public Map<UUID, Set<Integer>> resetOwners(Map<Integer, Set<UUID>> ownersByUpdCounters, Set<Integer> haveHistory) {
+    @Override public Map<UUID, Set<Integer>> resetOwners(
+        Map<Integer, Set<UUID>> ownersByUpdCounters,
+        Set<Integer> haveHistory,
+        Set<UUID> joinedNodes,
+        boolean skipResetOwners
+    ) {
         Map<UUID, Set<Integer>> result = new HashMap<>();
 
         lock.writeLock().lock();
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionTopology.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionTopology.java
index 890693b..61a5408 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionTopology.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionTopology.java
@@ -423,9 +423,15 @@ public interface GridDhtPartitionTopology {
      * @param ownersByUpdCounters Map (partition, set of node IDs that have most actual state about partition
      *                            (update counter is maximal) and should hold OWNING state for such partition).
      * @param haveHistory Set of partitions which have WAL history to rebalance.
+     * @param joinedNodes Set of nodes that joined topology in case of distributed exchange.
+     * @param skipResetOwners If true, resetting owner will skipped for all nodes except joined ones.
      * @return Map (nodeId, set of partitions that should be rebalanced <b>fully</b> by this node).
      */
-    public Map<UUID, Set<Integer>> resetOwners(Map<Integer, Set<UUID>> ownersByUpdCounters, Set<Integer> haveHistory);
+    public Map<UUID, Set<Integer>> resetOwners(
+        Map<Integer, Set<UUID>> ownersByUpdCounters,
+        Set<Integer> haveHistory,
+        Set<UUID> joinedNodes,
+        boolean skipResetOwners);
 
     /**
      * Callback on exchange done.
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 aed494d..fbddb1d 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
@@ -882,8 +882,12 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
         try {
             GridDhtLocalPartition part = locParts.get(p);
 
-            if (part != null && part.state() != EVICTED)
-                return part;
+            if (part != null) {
+                if (part.state() != EVICTED)
+                    return part;
+                else
+                    part.awaitDestroy();
+            }
 
             part = new GridDhtLocalPartition(ctx, grp, p, true);
 
@@ -2187,7 +2191,12 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
     }
 
     /** {@inheritDoc} */
-    @Override public Map<UUID, Set<Integer>> resetOwners(Map<Integer, Set<UUID>> ownersByUpdCounters, Set<Integer> haveHistory) {
+    @Override public Map<UUID, Set<Integer>> resetOwners(
+        Map<Integer, Set<UUID>> ownersByUpdCounters,
+        Set<Integer> haveHistory,
+        Set<UUID> joinedNodes,
+        boolean skipResetOwners
+    ) {
         Map<UUID, Set<Integer>> result = new HashMap<>();
 
         ctx.database().checkpointReadLock();
@@ -2197,6 +2206,8 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
 
             try {
                 // First process local partitions.
+                UUID locNodeId = ctx.localNodeId();
+
                 for (Map.Entry<Integer, Set<UUID>> entry : ownersByUpdCounters.entrySet()) {
                     int part = entry.getKey();
                     Set<UUID> newOwners = entry.getValue();
@@ -2206,11 +2217,11 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
                     if (locPart == null || locPart.state() != OWNING)
                         continue;
 
-                    if (!newOwners.contains(ctx.localNodeId())) {
+                    if ((joinedNodes.contains(locNodeId) || !skipResetOwners) && !newOwners.contains(locNodeId)) {
                         rebalancePartition(part, haveHistory.contains(part));
 
-                        result.computeIfAbsent(ctx.localNodeId(), n -> new HashSet<>());
-                        result.get(ctx.localNodeId()).add(part);
+                        result.computeIfAbsent(locNodeId, n -> new HashSet<>());
+                        result.get(locNodeId).add(part);
                     }
                 }
 
@@ -2221,6 +2232,10 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
 
                     for (Map.Entry<UUID, GridDhtPartitionMap> remotes : node2part.entrySet()) {
                         UUID remoteNodeId = remotes.getKey();
+
+                        if (!joinedNodes.contains(remoteNodeId) && skipResetOwners)
+                            continue;
+
                         GridDhtPartitionMap partMap = remotes.getValue();
 
                         GridDhtPartitionState state = partMap.get(part);
@@ -2233,7 +2248,7 @@ public class GridDhtPartitionTopologyImpl implements GridDhtPartitionTopology {
 
                             partMap.updateSequence(partMap.updateSequence() + 1, partMap.topologyVersion());
 
-                            if (partMap.nodeId().equals(ctx.localNodeId()))
+                            if (partMap.nodeId().equals(locNodeId))
                                 updateSeq.setIfGreater(partMap.updateSequence());
 
                             result.computeIfAbsent(remoteNodeId, n -> new HashSet<>());
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearTxPrepareFutureAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearTxPrepareFutureAdapter.java
index 0b75dfc..12793da 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearTxPrepareFutureAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearTxPrepareFutureAdapter.java
@@ -23,6 +23,7 @@ import java.util.concurrent.atomic.AtomicReference;
 import java.util.concurrent.atomic.AtomicReferenceFieldUpdater;
 import javax.cache.expiry.ExpiryPolicy;
 import org.apache.ignite.IgniteLogger;
+import org.apache.ignite.IgniteSystemProperties;
 import org.apache.ignite.internal.processors.cache.GridCacheCompoundFuture;
 import org.apache.ignite.internal.processors.cache.GridCacheContext;
 import org.apache.ignite.internal.processors.cache.GridCacheEntryRemovedException;
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 a300447..7251794 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
@@ -45,6 +45,7 @@ import java.util.UUID;
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.ConcurrentMap;
 import java.util.concurrent.CopyOnWriteArrayList;
+import java.util.concurrent.CountDownLatch;
 import java.util.concurrent.ExecutionException;
 import java.util.concurrent.Executor;
 import java.util.concurrent.ExecutorService;
@@ -59,6 +60,7 @@ import java.util.concurrent.atomic.AtomicInteger;
 import java.util.concurrent.atomic.AtomicLong;
 import java.util.concurrent.atomic.AtomicReference;
 import java.util.concurrent.atomic.LongAdder;
+import java.util.concurrent.locks.LockSupport;
 import java.util.concurrent.locks.ReentrantReadWriteLock;
 import java.util.function.Consumer;
 import java.util.function.Predicate;
@@ -121,6 +123,7 @@ import org.apache.ignite.internal.processors.cache.CacheGroupDescriptor;
 import org.apache.ignite.internal.processors.cache.DynamicCacheDescriptor;
 import org.apache.ignite.internal.processors.cache.ExchangeActions;
 import org.apache.ignite.internal.processors.cache.GridCacheContext;
+import org.apache.ignite.internal.processors.cache.GridCacheEntryEx;
 import org.apache.ignite.internal.processors.cache.GridCacheSharedContext;
 import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture;
 import org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtLocalPartition;
@@ -174,6 +177,7 @@ import org.apache.ignite.internal.util.worker.GridWorker;
 import org.apache.ignite.lang.IgniteBiPredicate;
 import org.apache.ignite.lang.IgniteBiTuple;
 import org.apache.ignite.lang.IgniteFuture;
+import org.apache.ignite.lang.IgniteInClosure;
 import org.apache.ignite.lang.IgniteOutClosure;
 import org.apache.ignite.lang.IgnitePredicate;
 import org.apache.ignite.mxbean.DataStorageMetricsMXBean;
@@ -224,7 +228,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
     private final int walRebalanceThreshold = getInteger(IGNITE_PDS_WAL_REBALANCE_THRESHOLD, 500_000);
 
     /** Value of property for throttling policy override. */
-    private final String throttlingPolicyOverride = IgniteSystemProperties.getString(
+    private final String throttlingPlcOverride = IgniteSystemProperties.getString(
         IgniteSystemProperties.IGNITE_OVERRIDE_WRITE_THROTTLING_ENABLED);
 
     /** */
@@ -270,6 +274,12 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
     /** */
     private static final String CHECKPOINT_RUNNER_THREAD_PREFIX = "checkpoint-runner";
 
+    /** Throttle logging threshold. Warning will be raised if thread is being parked for this long. */
+    private static final long THROTTLE_LOGGING_THRESHOLD = TimeUnit.SECONDS.toNanos(5);
+
+    /** Throttle queue size threshold. Async applying will be throttled starting from this queue size. */
+    private static final int THROTTLE_QUEUE_SIZE_THRESHOLD = 10_000;
+
     /** This number of threads will be created and used for parallel sorting. */
     private static final int PARALLEL_SORT_THREADS = Math.min(Runtime.getRuntime().availableProcessors(), 8);
 
@@ -292,7 +302,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
     private long checkpointFreq;
 
     /** */
-    private CheckpointHistory cpHistory;
+    private CheckpointHistory cpHist;
 
     /** */
     private FilePageStoreManager storeMgr;
@@ -378,7 +388,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
     private Collection<Integer> initiallyGlobalWalDisabledGrps = new HashSet<>();
 
     /** Initially local wal disabled groups. */
-    private Collection<Integer> initiallyLocalWalDisabledGrps = new HashSet<>();
+    private Collection<Integer> initiallyLocWalDisabledGrps = new HashSet<>();
 
     /** File I/O factory for writing checkpoint markers. */
     private final FileIOFactory ioFactory;
@@ -536,7 +546,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
 
             checkpointer = new Checkpointer(cctx.igniteInstanceName(), "db-checkpoint-thread", log);
 
-            cpHistory = new CheckpointHistory(kernalCtx);
+            cpHist = new CheckpointHistory(kernalCtx);
 
             IgnitePageStoreManager store = cctx.pageStore();
 
@@ -629,8 +639,8 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
 
     /** {@inheritDoc} */
     @Override public void cleanupCheckpointDirectory() throws IgniteCheckedException {
-        if (cpHistory != null)
-            cpHistory = new CheckpointHistory(cctx.kernalContext());
+        if (cpHist != null)
+            cpHist = new CheckpointHistory(cctx.kernalContext());
 
         try {
             try (DirectoryStream<Path> files = Files.newDirectoryStream(cpDir.toPath())) {
@@ -1139,17 +1149,17 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
 
         GridInClosure3X<Long, FullPageId, PageMemoryEx> changeTracker;
 
-        if (trackable)
+        if (trackable) {
             changeTracker = new GridInClosure3X<Long, FullPageId, PageMemoryEx>() {
                 @Override public void applyx(
                     Long page,
                     FullPageId fullId,
                     PageMemoryEx pageMem
                 ) throws IgniteCheckedException {
-                    if (trackable)
-                        snapshotMgr.onChangeTrackerPage(page, fullId, pageMem);
+                    snapshotMgr.onChangeTrackerPage(page, fullId, pageMem);
                 }
             };
+        }
         else
             changeTracker = null;
 
@@ -1241,13 +1251,13 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
             ? PageMemoryImpl.ThrottlingPolicy.SPEED_BASED
             : PageMemoryImpl.ThrottlingPolicy.CHECKPOINT_BUFFER_ONLY;
 
-        if (throttlingPolicyOverride != null) {
+        if (throttlingPlcOverride != null) {
             try {
-                plc = PageMemoryImpl.ThrottlingPolicy.valueOf(throttlingPolicyOverride.toUpperCase());
+                plc = PageMemoryImpl.ThrottlingPolicy.valueOf(throttlingPlcOverride.toUpperCase());
             }
             catch (IllegalArgumentException e) {
                 log.error("Incorrect value of IGNITE_OVERRIDE_WRITE_THROTTLING_ENABLED property. " +
-                    "The default throttling policy will be used [plc=" + throttlingPolicyOverride +
+                    "The default throttling policy will be used [plc=" + throttlingPlcOverride +
                     ", defaultPlc=" + plc + ']');
             }
         }
@@ -1731,7 +1741,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
         checkpointReadLock();
 
         try {
-            earliestValidCheckpoints = cpHistory.searchAndReserveCheckpoints(applicableGroupsAndPartitions);
+            earliestValidCheckpoints = cpHist.searchAndReserveCheckpoints(applicableGroupsAndPartitions);
         }
         finally {
             checkpointReadUnlock();
@@ -1817,7 +1827,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
 
     /** {@inheritDoc} */
     @Override public boolean reserveHistoryForPreloading(int grpId, int partId, long cntr) {
-        CheckpointEntry cpEntry = cpHistory.searchCheckpointEntry(grpId, partId, cntr);
+        CheckpointEntry cpEntry = cpHist.searchCheckpointEntry(grpId, partId, cntr);
 
         if (cpEntry == null)
             return false;
@@ -1898,7 +1908,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
 
     /** {@inheritDoc} */
     @Override public WALPointer lastCheckpointMarkWalPointer() {
-        CheckpointEntry lastCheckpointEntry = cpHistory == null ? null : cpHistory.lastCheckpoint();
+        CheckpointEntry lastCheckpointEntry = cpHist == null ? null : cpHist.lastCheckpoint();
 
         return lastCheckpointEntry == null ? null : lastCheckpointEntry.checkpointMark();
     }
@@ -2380,7 +2390,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
             finalizeCheckpointOnRecovery(status.cpStartTs, status.cpStartId, status.startPtr, exec);
         }
 
-        cpHistory.initialize(retreiveHistory());
+        cpHist.initialize(retreiveHistory());
 
         return restoreBinaryState;
     }
@@ -2596,52 +2606,81 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
     /**
      * Apply update from some iterator and with specific filters.
      *
-     * @param it WalIterator.
-     * @param recPredicate Wal record filter.
-     * @param entryPredicate Entry filter.
+     * @param it WAL iterator.
+     * @param stopPred WAL record stop predicate.
+     * @param entryPred Entry filter.
      */
     public void applyUpdatesOnRecovery(
         @Nullable WALIterator it,
-        IgniteBiPredicate<WALPointer, WALRecord> recPredicate,
-        IgnitePredicate<DataEntry> entryPredicate
+        IgniteBiPredicate<WALPointer, WALRecord> stopPred,
+        IgniteBiPredicate<WALRecord, DataEntry> entryPred
     ) throws IgniteCheckedException {
         if (it == null)
             return;
 
         cctx.walState().runWithOutWAL(() -> {
-            while (it.hasNext()) {
-                IgniteBiTuple<WALPointer, WALRecord> next = it.next();
+            if (it != null)
+                applyUpdates(it, stopPred, entryPred, false, null, false);
+        });
+    }
 
-                WALRecord rec = next.get2();
+    /**
+     * Applies data entries updates from given WAL iterator if entry satisfies to provided predicates.
+     * @param it WAL iterator.
+     * @param stopPred WAL record predicate for stopping iteration.
+     * @param entryPred Data record and corresponding data entries predicate.
+     * @param lockEntries If true, update will be performed under entry lock.
+     * @param onWalPointerApplied Listener to be invoked after every WAL record applied.
+     * @param asyncApply If true, updates applying will be delegated to the striped executor.
+     */
+    public void applyUpdates(
+        WALIterator it,
+        @Nullable IgniteBiPredicate<WALPointer, WALRecord> stopPred,
+        IgniteBiPredicate<WALRecord, DataEntry> entryPred,
+        boolean lockEntries,
+        IgniteInClosure<WALPointer> onWalPointerApplied,
+        boolean asyncApply
+    ) {
+        StripedExecutor exec = cctx.kernalContext().getStripedExecutorService();
 
-                if (!recPredicate.apply(next.get1(), rec))
-                    break;
+        AtomicReference<IgniteCheckedException> applyError = new AtomicReference<>();
 
-                switch (rec.type()) {
-                    case MVCC_DATA_RECORD:
-                    case DATA_RECORD:
+        int[] stripesThrottleAccumulator = new int[exec.stripes()];
+
+        while (it.hasNext()) {
+            IgniteBiTuple<WALPointer, WALRecord> next = it.next();
+
+            WALRecord rec = next.get2();
+
+            if (stopPred != null && stopPred.apply(next.get1(), rec))
+                break;
+
+            switch (rec.type()) {
+                case MVCC_DATA_RECORD:
+                case DATA_RECORD:
+                    if (entryPred.apply(rec, null)) {
                         checkpointReadLock();
 
                         try {
                             DataRecord dataRec = (DataRecord)rec;
 
                             for (DataEntry dataEntry : dataRec.writeEntries()) {
-                                if (entryPredicate.apply(dataEntry)) {
-                                    checkpointReadLock();
-
-                                    try {
-                                        int cacheId = dataEntry.cacheId();
+                                if (entryPred.apply(rec, dataEntry)) {
+                                    int cacheId = dataEntry.cacheId();
 
-                                        GridCacheContext cacheCtx = cctx.cacheContext(cacheId);
+                                    GridCacheContext cacheCtx = cctx.cacheContext(cacheId);
 
-                                        if (cacheCtx != null)
-                                            applyUpdate(cacheCtx, dataEntry);
-                                        else if (log != null)
-                                            log.warning("Cache is not started. Updates cannot be applied " +
-                                                "[cacheId=" + cacheId + ']');
+                                    if (cacheCtx != null) {
+                                        if (asyncApply) {
+                                            applyUpdateAsync(cacheCtx, dataEntry, lockEntries, exec,
+                                                applyError, stripesThrottleAccumulator);
+                                        }
+                                        else
+                                            applyUpdate(cacheCtx, dataEntry, lockEntries);
                                     }
-                                    finally {
-                                        checkpointReadUnlock();
+                                    else if (log != null) {
+                                        log.warning("Cache is not started. Updates cannot be applied " +
+                                            "[cacheId=" + cacheId + ']');
                                     }
                                 }
                             }
@@ -2652,10 +2691,12 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
                         finally {
                             checkpointReadUnlock();
                         }
+                    }
 
-                        break;
+                    break;
 
-                    case MVCC_TX_RECORD:
+                case MVCC_TX_RECORD:
+                    if (entryPred.apply(rec, null)) {
                         checkpointReadLock();
 
                         try {
@@ -2668,12 +2709,96 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
                         finally {
                             checkpointReadUnlock();
                         }
+                    }
 
-                        break;
+                    break;
 
-                    default:
-                        // Skip other records.
+                default:
+                    // Skip other records.
+            }
+
+            if (onWalPointerApplied != null)
+                onWalPointerApplied.apply(rec.position());
+        }
+
+        if (applyError.get() != null)
+            throw new IgniteException(applyError.get()); // Fail-fast check.
+        else {
+            CountDownLatch stripesClearLatch = new CountDownLatch(exec.stripes());
+
+            // We have to ensure that all asynchronous updates are done.
+            // StripedExecutor guarantees ordering inside stripe - it would enough to await "finishing" tasks.
+            for (int i = 0; i < exec.stripes(); i++)
+                exec.execute(i, stripesClearLatch::countDown);
+
+            try {
+                stripesClearLatch.await();
+            }
+            catch (InterruptedException e) {
+                throw new IgniteInterruptedException(e);
+            }
+        }
+
+        if (applyError.get() != null)
+            throw new IgniteException(applyError.get());
+    }
+
+    /**
+     * Applies update in given striped executor.
+     *
+     * @param cacheCtx Cache context.
+     * @param dataEntry Data entry.
+     * @param lockEntries Lock entries.
+     * @param exec Executor.
+     * @param applyError Apply error reference.
+     * @param stripesThrottleAccumulator Array with accumulated throttle powers for each stripe.
+     */
+    private void applyUpdateAsync(
+        GridCacheContext cacheCtx,
+        DataEntry dataEntry,
+        boolean lockEntries,
+        StripedExecutor exec,
+        AtomicReference<IgniteCheckedException> applyError,
+        int[] stripesThrottleAccumulator
+    ) throws IgniteCheckedException {
+        if (applyError.get() != null)
+            throw applyError.get();
+
+        int stripeIdx = dataEntry.partitionId() % exec.stripes();
+
+        assert stripeIdx >= 0 : "Stripe index should be non-negative: " + stripeIdx;
+
+        if (exec.queueSize(stripeIdx) > THROTTLE_QUEUE_SIZE_THRESHOLD) {
+            int throttlePower = ++stripesThrottleAccumulator[stripeIdx];
+
+            long throttleParkTimeNs = (long)(1000L * Math.pow(1.05, throttlePower));
+
+            if (throttleParkTimeNs > THROTTLE_LOGGING_THRESHOLD) {
+                U.warn(log, "Parking thread=" + Thread.currentThread().getName()
+                    + " for timeout(ms)=" + (throttleParkTimeNs / 1_000_000));
+            }
+
+            LockSupport.parkNanos(throttleParkTimeNs);
+        }
+        else
+            stripesThrottleAccumulator[stripeIdx] = 0;
+
+        exec.execute(stripeIdx, () -> {
+            try {
+                if (applyError.get() != null)
+                    return;
+
+                checkpointReadLock();
+
+                try {
+                    applyUpdate(cacheCtx, dataEntry, lockEntries);
                 }
+                finally {
+                    checkpointReadUnlock();
+                }
+            }
+            catch (IgniteCheckedException e) {
+                applyError.compareAndSet(null, e);
             }
         });
     }
@@ -2741,7 +2866,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
                                     cctx.kernalContext().query().markAsRebuildNeeded(cacheCtx);
 
                                 try {
-                                    applyUpdate(cacheCtx, dataEntry);
+                                    applyUpdate(cacheCtx, dataEntry, false);
                                 }
                                 catch (IgniteCheckedException e) {
                                     U.error(log, "Failed to apply data entry, dataEntry=" + dataEntry +
@@ -2859,18 +2984,23 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
      * @param highBound WALPointer.
      */
     public void onWalTruncated(WALPointer highBound) throws IgniteCheckedException {
-        List<CheckpointEntry> removedFromHistory = cpHistory.onWalTruncated(highBound);
+        List<CheckpointEntry> rmvFromHist = cpHist.onWalTruncated(highBound);
 
-        for (CheckpointEntry cp : removedFromHistory)
+        for (CheckpointEntry cp : rmvFromHist)
             removeCheckpointFiles(cp);
     }
 
     /**
      * @param cacheCtx Cache context to apply an update.
      * @param dataEntry Data entry to apply.
+     * @param lockEntry If true, update will be performed under entry lock.
      * @throws IgniteCheckedException If failed to restore.
      */
-    private void applyUpdate(GridCacheContext cacheCtx, DataEntry dataEntry) throws IgniteCheckedException {
+    private void applyUpdate(
+        GridCacheContext cacheCtx,
+        DataEntry dataEntry,
+        boolean lockEntry
+    ) throws IgniteCheckedException {
         int partId = dataEntry.partitionId();
 
         if (partId == -1)
@@ -2878,51 +3008,85 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
 
         GridDhtLocalPartition locPart = cacheCtx.isLocal() ? null : cacheCtx.topology().forceCreatePartition(partId);
 
+        GridCacheEntryEx entryEx = null;
+
         switch (dataEntry.op()) {
             case CREATE:
             case UPDATE:
-                if (dataEntry instanceof MvccDataEntry) {
-                    cacheCtx.offheap().mvccApplyUpdate(
-                        cacheCtx,
-                        dataEntry.key(),
-                        dataEntry.value(),
-                        dataEntry.writeVersion(),
-                        dataEntry.expireTime(),
-                        locPart,
-                        ((MvccDataEntry)dataEntry).mvccVer());
+                if (lockEntry) {
+                    entryEx = cacheCtx.isNear() ? cacheCtx.near().dht().entryEx(dataEntry.key()) :
+                        cacheCtx.cache().entryEx(dataEntry.key());
+
+                    entryEx.lockEntry();
                 }
-                else {
-                    cacheCtx.offheap().update(
-                        cacheCtx,
-                        dataEntry.key(),
-                        dataEntry.value(),
-                        dataEntry.writeVersion(),
-                        dataEntry.expireTime(),
-                        locPart,
-                        null);
+
+                try {
+                    if (dataEntry instanceof MvccDataEntry) {
+                        cacheCtx.offheap().mvccApplyUpdate(
+                            cacheCtx,
+                            dataEntry.key(),
+                            dataEntry.value(),
+                            dataEntry.writeVersion(),
+                            dataEntry.expireTime(),
+                            locPart,
+                            ((MvccDataEntry)dataEntry).mvccVer());
+                    }
+                    else {
+                        cacheCtx.offheap().update(
+                            cacheCtx,
+                            dataEntry.key(),
+                            dataEntry.value(),
+                            dataEntry.writeVersion(),
+                            dataEntry.expireTime(),
+                            locPart,
+                            null);
+                    }
+
+                    if (dataEntry.partitionCounter() != 0)
+                        cacheCtx.offheap().onPartitionInitialCounterUpdated(partId, dataEntry.partitionCounter());
                 }
+                finally {
+                    if (lockEntry) {
+                        entryEx.unlockEntry();
 
-                if (dataEntry.partitionCounter() != 0)
-                    cacheCtx.offheap().onPartitionInitialCounterUpdated(partId, dataEntry.partitionCounter());
+                        entryEx.context().evicts().touch(entryEx);
+                    }
+                }
 
                 break;
 
             case DELETE:
-                if (dataEntry instanceof MvccDataEntry) {
-                    cacheCtx.offheap().mvccApplyUpdate(
-                        cacheCtx,
-                        dataEntry.key(),
-                        null,
-                        dataEntry.writeVersion(),
-                        0L,
-                        locPart,
-                        ((MvccDataEntry)dataEntry).mvccVer());
+                if (lockEntry) {
+                    entryEx = cacheCtx.isNear() ? cacheCtx.near().dht().entryEx(dataEntry.key()) :
+                        cacheCtx.cache().entryEx(dataEntry.key());
+
+                    entryEx.lockEntry();
                 }
-                else
-                    cacheCtx.offheap().remove(cacheCtx, dataEntry.key(), partId, locPart);
 
-                if (dataEntry.partitionCounter() != 0)
-                    cacheCtx.offheap().onPartitionInitialCounterUpdated(partId, dataEntry.partitionCounter());
+                try {
+                    if (dataEntry instanceof MvccDataEntry) {
+                        cacheCtx.offheap().mvccApplyUpdate(
+                            cacheCtx,
+                            dataEntry.key(),
+                            null,
+                            dataEntry.writeVersion(),
+                            0L,
+                            locPart,
+                            ((MvccDataEntry)dataEntry).mvccVer());
+                    }
+                    else
+                        cacheCtx.offheap().remove(cacheCtx, dataEntry.key(), partId, locPart);
+
+                    if (dataEntry.partitionCounter() != 0)
+                        cacheCtx.offheap().onPartitionInitialCounterUpdated(partId, dataEntry.partitionCounter());
+                }
+                finally {
+                    if (lockEntry) {
+                        entryEx.unlockEntry();
+
+                        entryEx.context().evicts().touch(entryEx);
+                    }
+                }
 
                 break;
 
@@ -3227,7 +3391,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
 
         // Do not hold groups state in-memory if there is no space in the checkpoint history to prevent possible OOM.
         // In this case the actual group states will be readed from WAL by demand.
-        if (rec != null && cpHistory.hasSpace())
+        if (rec != null && cpHist.hasSpace())
             cacheGrpStates = rec.cacheGroupStates();
 
         return new CheckpointEntry(cpTs, ptr, cpId, cacheGrpStates);
@@ -3237,7 +3401,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
      * @return Checkpoint history.
      */
     @Nullable public CheckpointHistory checkpointHistory() {
-        return cpHistory;
+        return cpHist;
     }
 
     /**
@@ -4038,7 +4202,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
                         cpRec,
                         CheckpointEntryType.START);
 
-                    cpHistory.addCheckpoint(cp);
+                    cpHist.addCheckpoint(cp);
                 }
             }
             finally {
@@ -4375,7 +4539,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
                 cctx.wal().notchLastCheckpointPtr(chp.cpEntry.checkpointMark());
             }
 
-            List<CheckpointEntry> removedFromHistory = cpHistory.onCheckpointFinished(chp, truncateWalOnCpFinish);
+            List<CheckpointEntry> removedFromHistory = cpHist.onCheckpointFinished(chp, truncateWalOnCpFinish);
 
             for (CheckpointEntry cp : removedFromHistory)
                 removeCheckpointFiles(cp);
@@ -5166,7 +5330,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
     /** {@inheritDoc} */
     @Override public boolean walEnabled(int grpId, boolean local) {
         if (local)
-            return !initiallyLocalWalDisabledGrps.contains(grpId);
+            return !initiallyLocWalDisabledGrps.contains(grpId);
         else
             return !initiallyGlobalWalDisabledGrps.contains(grpId);
     }
@@ -5216,7 +5380,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
         checkpointReadLock();
 
         try {
-            CheckpointEntry lastCp = cpHistory.lastCheckpoint();
+            CheckpointEntry lastCp = cpHist.lastCheckpoint();
             long lastCpTs = lastCp != null ? lastCp.timestamp() : 0;
 
             if (lastCpTs != 0)
@@ -5242,7 +5406,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
 
                 if (t2 != null) {
                     if (t2.get2())
-                        initiallyLocalWalDisabledGrps.add(t2.get1());
+                        initiallyLocWalDisabledGrps.add(t2.get1());
                     else
                         initiallyGlobalWalDisabledGrps.add(t2.get1());
                 }
@@ -5412,7 +5576,7 @@ public class GridCacheDatabaseSharedManager extends IgniteCacheDatabaseSharedMan
      */
     private IgnitePredicate<Integer> groupsWithEnabledWal() {
         return groupId -> !initiallyGlobalWalDisabledGrps.contains(groupId)
-            && !initiallyLocalWalDisabledGrps.contains(groupId);
+            && !initiallyLocWalDisabledGrps.contains(groupId);
     }
 
     /**
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 d583a04..ad1bc91 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
@@ -452,11 +452,11 @@ public class MetaStorage implements DbCheckpointListener, ReadWriteMetastorage {
 
     /** */
     private void checkRootsPageIdFlag(long treeRoot, long reuseListRoot) throws StorageException {
-        if (PageIdUtils.flag(treeRoot) != PageMemory.FLAG_DATA)
+        if (PageIdUtils.flag(treeRoot) != FLAG_DATA)
             throw new StorageException("Wrong tree root page id flag: treeRoot="
                 + U.hexLong(treeRoot) + ", METASTORAGE_CACHE_ID=" + METASTORAGE_CACHE_ID);
 
-        if (PageIdUtils.flag(reuseListRoot) != PageMemory.FLAG_DATA)
+        if (PageIdUtils.flag(reuseListRoot) != FLAG_DATA)
             throw new StorageException("Wrong reuse list root page id flag: reuseListRoot="
                 + U.hexLong(reuseListRoot) + ", METASTORAGE_CACHE_ID=" + METASTORAGE_CACHE_ID);
     }
@@ -515,11 +515,11 @@ public class MetaStorage implements DbCheckpointListener, ReadWriteMetastorage {
                         //MetaStorage never encrypted so realPageSize == pageSize.
                         io.initNewPage(pageAddr, partMetaId, pageMem.pageSize());
 
-                        treeRoot = pageMem.allocatePage(METASTORAGE_CACHE_ID, partId, PageMemory.FLAG_DATA);
-                        reuseListRoot = pageMem.allocatePage(METASTORAGE_CACHE_ID, partId, PageMemory.FLAG_DATA);
+                        treeRoot = pageMem.allocatePage(METASTORAGE_CACHE_ID, partId, FLAG_DATA);
+                        reuseListRoot = pageMem.allocatePage(METASTORAGE_CACHE_ID, partId, FLAG_DATA);
 
-                        assert PageIdUtils.flag(treeRoot) == PageMemory.FLAG_DATA;
-                        assert PageIdUtils.flag(reuseListRoot) == PageMemory.FLAG_DATA;
+                        assert PageIdUtils.flag(treeRoot) == FLAG_DATA;
+                        assert PageIdUtils.flag(reuseListRoot) == FLAG_DATA;
 
                         io.setTreeRoot(pageAddr, treeRoot);
                         io.setReuseListRoot(pageAddr, reuseListRoot);
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 f1a26be..a86cc25 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
@@ -1017,7 +1017,7 @@ public abstract class BPlusTree<L, T extends L> extends DataStructure implements
             throw new IgniteCheckedException("Runtime failure on bounds: [lower=" + lower + ", upper=" + upper + "]", e);
         }
         catch (RuntimeException | AssertionError e) {
-            throw new CorruptedTreeException("Runtime failure on bounds: [lower=" + lower + ", upper=" + upper + "]", e);
+            throw createCorruptedTreeException("Runtime failure on bounds: [lower=%s, upper=%s]", e, lower, upper);
         }
         finally {
             checkDestroyed();
@@ -1182,7 +1182,7 @@ public abstract class BPlusTree<L, T extends L> extends DataStructure implements
             throw new IgniteCheckedException("Runtime failure on first row lookup", e);
         }
         catch (RuntimeException | AssertionError e) {
-            throw new CorruptedTreeException("Runtime failure on first row lookup", e);
+            throw createCorruptedTreeException("Runtime failure on first row lookup", e);
         }
         finally {
             checkDestroyed();
@@ -1253,7 +1253,7 @@ public abstract class BPlusTree<L, T extends L> extends DataStructure implements
             throw new IgniteCheckedException("Runtime failure on lookup row: " + row, e);
         }
         catch (RuntimeException | AssertionError e) {
-            throw new CorruptedTreeException("Runtime failure on lookup row: " + row, e);
+            throw createCorruptedTreeException("Runtime failure on lookup row: %s", e, row);
         }
         finally {
             checkDestroyed();
@@ -1813,7 +1813,7 @@ public abstract class BPlusTree<L, T extends L> extends DataStructure implements
             throw new IgniteCheckedException("Runtime failure on search row: " + row, e);
         }
         catch (RuntimeException | AssertionError e) {
-            throw new CorruptedTreeException("Runtime failure on search row: " + row, e);
+            throw createCorruptedTreeException("Runtime failure on search row: %s", e, row);
         }
         finally {
             x.releaseAll();
@@ -1970,7 +1970,7 @@ public abstract class BPlusTree<L, T extends L> extends DataStructure implements
             throw new IgniteCheckedException("Runtime failure on search row: " + row, e);
         }
         catch (RuntimeException | AssertionError e) {
-            throw new CorruptedTreeException("Runtime failure on search row: " + row, e);
+            throw createCorruptedTreeException("Runtime failure on search row: %s", e, row);
         }
         finally {
             r.releaseAll();
@@ -2322,7 +2322,7 @@ public abstract class BPlusTree<L, T extends L> extends DataStructure implements
             throw new IgniteCheckedException("Runtime failure on row: " + row, e);
         }
         catch (RuntimeException | AssertionError e) {
-            throw new CorruptedTreeException("Runtime failure on row: " + row, e);
+            throw createCorruptedTreeException("Runtime failure on row: %s", e, row);
         }
         finally {
             checkDestroyed();
@@ -5835,4 +5835,22 @@ public abstract class BPlusTree<L, T extends L> extends DataStructure implements
     protected IoStatisticsHolder statisticsHolder() {
         return IoStatisticsHolderNoOp.INSTANCE;
     }
+
+    /**
+     * Creates a new instance of {@link CorruptedTreeException}.
+     *
+     * @param message Detailed error message.
+     * @param cause The cause.
+     * @param rows Optional parameters.
+     * @return New instance of {@link CorruptedTreeException}.
+     */
+    private CorruptedTreeException createCorruptedTreeException(String message, Throwable cause, Object... rows) {
+        try {
+            return new CorruptedTreeException(String.format(message, rows), cause);
+        }
+        catch (Throwable t) {
+            // Failed to create string representation of optional parameters.
+            return new CorruptedTreeException("", cause);
+        }
+    }
 }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/AbstractWalRecordsIterator.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/AbstractWalRecordsIterator.java
index f744b3f..9af42d2 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/AbstractWalRecordsIterator.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/AbstractWalRecordsIterator.java
@@ -310,7 +310,7 @@ public abstract class AbstractWalRecordsIterator
      * @param desc File descriptor.
      * @param start Optional start pointer. Null means read from the beginning.
      * @param fileIO fileIO associated with file descriptor
-     * @param segmentHeader read segment header from fileIO
+     * @param segmentHdr read segment header from fileIO
      * @return Initialized file read header.
      * @throws IgniteCheckedException If initialized failed due to another unexpected error.
      */
@@ -318,10 +318,10 @@ public abstract class AbstractWalRecordsIterator
         @NotNull final AbstractFileDescriptor desc,
         @Nullable final FileWALPointer start,
         @NotNull final SegmentIO fileIO,
-        @NotNull final SegmentHeader segmentHeader
+        @NotNull final SegmentHeader segmentHdr
     ) throws IgniteCheckedException {
         try {
-            boolean isCompacted = segmentHeader.isCompacted();
+            boolean isCompacted = segmentHdr.isCompacted();
 
             if (isCompacted)
                 serializerFactory.skipPositionCheck(true);
@@ -341,7 +341,7 @@ public abstract class AbstractWalRecordsIterator
                 }
             }
 
-            int serVer = segmentHeader.getSerializerVersion();
+            int serVer = segmentHdr.getSerializerVersion();
 
             return createReadFileHandle(fileIO, serializerFactory.createSerializer(serVer), in);
         }
@@ -366,6 +366,9 @@ public abstract class AbstractWalRecordsIterator
             throw new IgniteCheckedException(
                 "Failed to initialize WAL segment after reading segment header: " + desc.file().getAbsolutePath(), e);
         }
+        finally {
+            serializerFactory.clearSegmentLocalState();
+        }
     }
 
     /**
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/FileWriteAheadLogManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/FileWriteAheadLogManager.java
index 094ade7..3aa85ff 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/FileWriteAheadLogManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/FileWriteAheadLogManager.java
@@ -29,7 +29,6 @@ import java.io.IOException;
 import java.nio.ByteBuffer;
 import java.nio.ByteOrder;
 import java.nio.channels.ClosedByInterruptException;
-import java.nio.channels.FileChannel;
 import java.nio.file.FileAlreadyExistsException;
 import java.nio.file.Files;
 import java.sql.Time;
@@ -127,7 +126,6 @@ import org.jetbrains.annotations.NotNull;
 import org.jetbrains.annotations.Nullable;
 
 import static java.nio.file.StandardOpenOption.CREATE;
-import static java.nio.file.StandardOpenOption.CREATE_NEW;
 import static java.nio.file.StandardOpenOption.READ;
 import static java.nio.file.StandardOpenOption.WRITE;
 import static org.apache.ignite.IgniteSystemProperties.IGNITE_CHECKPOINT_TRIGGER_ARCHIVE_SIZE_PERCENTAGE;
@@ -449,7 +447,7 @@ public class FileWriteAheadLogManager extends GridCacheSharedManagerAdapter impl
                     }
                 });
 
-            segmentAware = new SegmentAware(dsCfg.getWalSegments(), dsCfg.isWalCompactionEnabled());
+            segmentAware = new SegmentAware(dsCfg.getWalSegments(), dsCfg.isWalCompactionEnabled(), log);
 
             if (isArchiverEnabled())
                 archiver = new FileArchiver(segmentAware, log);
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/aware/SegmentAware.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/aware/SegmentAware.java
index 3281d7c..7e01728 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/aware/SegmentAware.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/aware/SegmentAware.java
@@ -16,6 +16,7 @@
 
 package org.apache.ignite.internal.processors.cache.persistence.wal.aware;
 
+import org.apache.ignite.IgniteLogger;
 import org.apache.ignite.internal.IgniteInterruptedCheckedException;
 
 import static org.apache.ignite.internal.processors.cache.persistence.wal.aware.SegmentArchivedStorage.buildArchivedStorage;
@@ -40,10 +41,11 @@ public class SegmentAware {
     /**
      * @param walSegmentsCnt Total WAL segments count.
      * @param compactionEnabled Is wal compaction enabled.
+     * @param log Logger.
      */
-    public SegmentAware(int walSegmentsCnt, boolean compactionEnabled) {
+    public SegmentAware(int walSegmentsCnt, boolean compactionEnabled, IgniteLogger log) {
         segmentCurrStateStorage = buildCurrentStateStorage(walSegmentsCnt, segmentArchivedStorage);
-        segmentCompressStorage = buildCompressStorage(segmentArchivedStorage, compactionEnabled);
+        segmentCompressStorage = buildCompressStorage(segmentArchivedStorage, compactionEnabled, log);
     }
 
     /**
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/aware/SegmentCompressStorage.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/aware/SegmentCompressStorage.java
index 458f119..c565bf0 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/aware/SegmentCompressStorage.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/aware/SegmentCompressStorage.java
@@ -16,11 +16,12 @@
 
 package org.apache.ignite.internal.processors.cache.persistence.wal.aware;
 
-import org.apache.ignite.internal.IgniteInterruptedCheckedException;
 import java.util.ArrayDeque;
 import java.util.ArrayList;
 import java.util.List;
 import java.util.Queue;
+import org.apache.ignite.IgniteLogger;
+import org.apache.ignite.internal.IgniteInterruptedCheckedException;
 
 /**
  * Storage of actual information about current index of compressed segments.
@@ -53,25 +54,37 @@ public class SegmentCompressStorage {
     /** Min uncompressed index to keep. */
     private volatile long minUncompressedIdxToKeep = -1L;
 
+    /** Logger. */
+    private final IgniteLogger log;
+
     /**
      * @param segmentArchivedStorage Storage of last archived segment.
      * @param compactionEnabled If WAL compaction enabled.
+     * @param log Logger.
      */
-    private SegmentCompressStorage(SegmentArchivedStorage segmentArchivedStorage, boolean compactionEnabled) {
+    private SegmentCompressStorage(
+        SegmentArchivedStorage segmentArchivedStorage,
+        boolean compactionEnabled,
+        IgniteLogger log) {
         this.segmentArchivedStorage = segmentArchivedStorage;
 
         this.compactionEnabled = compactionEnabled;
 
         this.segmentArchivedStorage.addObserver(this::onSegmentArchived);
+
+        this.log = log;
     }
 
     /**
      * @param segmentArchivedStorage Storage of last archived segment.
      * @param compactionEnabled If WAL compaction enabled.
+     * @param log Logger.
      */
-    static SegmentCompressStorage buildCompressStorage(SegmentArchivedStorage segmentArchivedStorage,
-                                                       boolean compactionEnabled) {
-        SegmentCompressStorage storage = new SegmentCompressStorage(segmentArchivedStorage, compactionEnabled);
+    static SegmentCompressStorage buildCompressStorage(
+        SegmentArchivedStorage segmentArchivedStorage,
+        boolean compactionEnabled,
+        IgniteLogger log) {
+        SegmentCompressStorage storage = new SegmentCompressStorage(segmentArchivedStorage, compactionEnabled, log);
 
         segmentArchivedStorage.addObserver(storage::onSegmentArchived);
 
@@ -79,11 +92,22 @@ public class SegmentCompressStorage {
     }
 
     /**
+     * Sets the largest index of previously compressed segment.
+     *
+     * @param idx Segment index.
+     */
+    synchronized void lastSegmentCompressed(long idx) {
+        onSegmentCompressed(lastEnqueuedToCompressIdx = idx);
+    }
+
+    /**
      * Callback after segment compression finish.
      *
      * @param compressedIdx Index of compressed segment.
      */
     synchronized void onSegmentCompressed(long compressedIdx) {
+        log.info("Segment compressed notification [idx=" + compressedIdx + ']');
+
         if (compressedIdx > lastMaxCompressedIdx)
             lastMaxCompressedIdx = compressedIdx;
 
@@ -150,8 +174,11 @@ public class SegmentCompressStorage {
      * Callback for waking up compressor when new segment is archived.
      */
     private synchronized void onSegmentArchived(long lastAbsArchivedIdx) {
-        while (lastEnqueuedToCompressIdx < lastAbsArchivedIdx && compactionEnabled)
+        while (lastEnqueuedToCompressIdx < lastAbsArchivedIdx && compactionEnabled) {
+            log.info("Enqueuing segment for compression [idx=" + (lastEnqueuedToCompressIdx + 1) + ']');
+
             segmentsToCompress.add(++lastEnqueuedToCompressIdx);
+        }
 
         notifyAll();
     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/IgniteWalIteratorFactory.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/IgniteWalIteratorFactory.java
index e3f1499..9e4305a 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/IgniteWalIteratorFactory.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/IgniteWalIteratorFactory.java
@@ -22,13 +22,16 @@ import java.io.IOException;
 import java.io.PrintStream;
 import java.nio.ByteOrder;
 import java.nio.file.FileVisitResult;
+import java.nio.file.NoSuchFileException;
 import java.nio.file.Path;
 import java.nio.file.SimpleFileVisitor;
 import java.nio.file.attribute.BasicFileAttributes;
 import java.util.ArrayList;
+import java.util.Collection;
 import java.util.Collections;
 import java.util.Iterator;
 import java.util.List;
+import java.util.Optional;
 import java.util.TreeSet;
 import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.IgniteLogger;
@@ -265,20 +268,24 @@ public class IgniteWalIteratorFactory {
         if (filesOrDirs == null || filesOrDirs.length == 0)
             return Collections.emptyList();
 
-        final FileIOFactory ioFactory = iteratorParametersBuilder.ioFactory;
-
         final TreeSet<FileDescriptor> descriptors = new TreeSet<>();
 
         for (File file : filesOrDirs) {
             if (file.isDirectory()) {
                 try {
                     walkFileTree(file.toPath(), new SimpleFileVisitor<Path>() {
-                        @Override
-                        public FileVisitResult visitFile(Path path, BasicFileAttributes attrs) {
-                            addFileDescriptor(path.toFile(), ioFactory, descriptors);
+                        @Override public FileVisitResult visitFile(Path path, BasicFileAttributes attrs) {
+                            addFileDescriptor(path.toFile(), descriptors, iteratorParametersBuilder);
 
                             return FileVisitResult.CONTINUE;
                         }
+
+                        @Override public FileVisitResult visitFileFailed(Path file, IOException exc) throws IOException {
+                            if (exc instanceof NoSuchFileException)
+                                return FileVisitResult.CONTINUE;
+
+                            return super.visitFileFailed(file, exc);
+                        }
                     });
                 }
                 catch (IOException e) {
@@ -288,31 +295,42 @@ public class IgniteWalIteratorFactory {
                 continue;
             }
 
-            addFileDescriptor(file, ioFactory, descriptors);
+            addFileDescriptor(file, descriptors, iteratorParametersBuilder);
         }
 
         return new ArrayList<>(descriptors);
     }
 
     /**
+     * @param file File
+     * @param descriptors List of descriptors
+     * @param params IteratorParametersBuilder.
+     */
+    private void addFileDescriptor(
+        File file,
+        Collection<FileDescriptor> descriptors,
+        IteratorParametersBuilder params)
+    {
+        Optional.ofNullable(getFileDescriptor(file, params.ioFactory))
+            .filter(desc -> desc.idx() >= params.lowBound.index() && desc.idx() <= params.highBound.index())
+            .ifPresent(descriptors::add);
+    }
+
+    /**
      * @param file File.
      * @param ioFactory IO factory.
-     * @param descriptors List of descriptors.
      */
-    private void addFileDescriptor(File file, FileIOFactory ioFactory, TreeSet<FileDescriptor> descriptors) {
+    private FileDescriptor getFileDescriptor(File file, FileIOFactory ioFactory) {
         if (file.length() < HEADER_RECORD_SIZE)
-            return; // Filter out this segment as it is too short.
+            return null; // Filter out this segment as it is too short.
 
         String fileName = file.getName();
 
         if (!WAL_NAME_PATTERN.matcher(fileName).matches() &&
             !WAL_SEGMENT_FILE_COMPACTED_PATTERN.matcher(fileName).matches())
-            return;  // Filter out this because it is not segment file.
-
-        FileDescriptor desc = readFileDescriptor(file, ioFactory);
+            return null;  // Filter out this because it is not segment file.
 
-        if (desc != null)
-            descriptors.add(desc);
+        return readFileDescriptor(file, ioFactory);
     }
 
     /**
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/StandaloneGridKernalContext.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/StandaloneGridKernalContext.java
index f14bcac..293b961 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/StandaloneGridKernalContext.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/reader/StandaloneGridKernalContext.java
@@ -87,6 +87,7 @@ import org.apache.ignite.internal.processors.session.GridTaskSessionProcessor;
 import org.apache.ignite.internal.processors.subscription.GridInternalSubscriptionProcessor;
 import org.apache.ignite.internal.processors.task.GridTaskProcessor;
 import org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor;
+import org.apache.ignite.internal.processors.txdr.TransactionalDrProcessor;
 import org.apache.ignite.internal.stat.IoStatisticsManager;
 import org.apache.ignite.internal.suggestions.GridPerformanceSuggestions;
 import org.apache.ignite.internal.util.IgniteExceptionRegistry;
@@ -463,6 +464,11 @@ public class StandaloneGridKernalContext implements GridKernalContext {
     }
 
     /** {@inheritDoc} */
+    @Override public TransactionalDrProcessor txDr() {
+        return null;
+    }
+
+    /** {@inheritDoc} */
     @Override public GridLoadBalancerManager loadBalancing() {
         return null;
     }
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 4044f3a..5bd5a21 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
@@ -283,9 +283,14 @@ class StandaloneWalRecordsIterator extends AbstractWalRecordsIterator {
         if (tup == null)
             return tup;
 
-        if (!checkBounds(tup.get1())) {
+        if (tup.get2() instanceof FilteredRecord)
+            return new T2<>(tup.get1(), FilteredRecord.INSTANCE);
+
+        WALPointer originalPtr = tup.get2().position();
+
+        if (!checkBounds(originalPtr)) {
             if (curRec != null) {
-                FileWALPointer prevRecPtr = (FileWALPointer)curRec.get1();
+                FileWALPointer prevRecPtr = (FileWALPointer)curRec.get2().position();
 
                 // Fast stop condition, after high bound reached.
                 if (prevRecPtr != null && prevRecPtr.compareTo(highBound) > 0)
@@ -471,7 +476,7 @@ class StandaloneWalRecordsIterator extends AbstractWalRecordsIterator {
      * @param keepBinary Don't convert non primitive types.
      * @return Unwrapped entry.
      */
-    private DataEntry unwrapDataEntry(CacheObjectContext coCtx, DataEntry dataEntry,
+    private @NotNull DataEntry unwrapDataEntry(CacheObjectContext coCtx, DataEntry dataEntry,
         KeyCacheObject key, CacheObject val, boolean keepBinary) {
         if (dataEntry instanceof MvccDataEntry)
             return new UnwrapMvccDataEntry(
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataV2Serializer.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataV2Serializer.java
index 5e84253..f8285d9 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataV2Serializer.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordDataV2Serializer.java
@@ -28,6 +28,7 @@ import java.util.UUID;
 import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.internal.pagemem.wal.record.CacheState;
 import org.apache.ignite.internal.pagemem.wal.record.CheckpointRecord;
+import org.apache.ignite.internal.pagemem.wal.record.ConsistentCutRecord;
 import org.apache.ignite.internal.pagemem.wal.record.DataEntry;
 import org.apache.ignite.internal.pagemem.wal.record.DataRecord;
 import org.apache.ignite.internal.pagemem.wal.record.ExchangeRecord;
@@ -108,6 +109,9 @@ public class RecordDataV2Serializer extends RecordDataV1Serializer {
             case MVCC_TX_RECORD:
                 return txRecordSerializer.size((MvccTxRecord)rec);
 
+            case CONSISTENT_CUT:
+                return 0;
+
             default:
                 return super.plainSize(rec);
         }
@@ -192,6 +196,9 @@ public class RecordDataV2Serializer extends RecordDataV1Serializer {
             case MVCC_TX_RECORD:
                 return txRecordSerializer.readMvccTx(in);
 
+            case CONSISTENT_CUT:
+                return new ConsistentCutRecord();
+
             default:
                 return super.readPlainRecord(type, in, encrypted);
         }
@@ -274,6 +281,9 @@ public class RecordDataV2Serializer extends RecordDataV1Serializer {
 
                 break;
 
+            case CONSISTENT_CUT:
+                break;
+
             default:
                 super.writePlainRecord(rec, buf);
         }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordSerializerFactory.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordSerializerFactory.java
index 923949c..6921b3d 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordSerializerFactory.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordSerializerFactory.java
@@ -69,4 +69,9 @@ public interface RecordSerializerFactory {
      * @param skipPositionCheck Skip position check.
      */
     public RecordSerializerFactory skipPositionCheck(boolean skipPositionCheck);
+
+    /**
+     * Clears factory parameters that are actual only for specific WAL segment.
+     */
+    public RecordSerializerFactory clearSegmentLocalState();
 }
\ No newline at end of file
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordSerializerFactoryImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordSerializerFactoryImpl.java
index bf9c3cd..4a93d55 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordSerializerFactoryImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/wal/serializer/RecordSerializerFactoryImpl.java
@@ -148,4 +148,12 @@ public class RecordSerializerFactoryImpl implements RecordSerializerFactory {
 
         return this;
     }
+
+    /** {@inheritDoc} */
+    @Override public RecordSerializerFactory clearSegmentLocalState() {
+        skipPositionCheck = false;
+        recordDeserializeFilter = null;
+
+        return this;
+    }
 }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxLocalAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxLocalAdapter.java
index ed8923b..9c89cfb 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxLocalAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxLocalAdapter.java
@@ -835,6 +835,9 @@ public abstract class IgniteTxLocalAdapter extends IgniteTxAdapter implements Ig
 
                                     if (grp.persistenceEnabled() && grp.walEnabled() &&
                                         cctx.snapshot().needTxReadLogging()) {
+                                        cctx.tm().pendingTxsTracker().onKeysRead(
+                                            nearXidVersion(), Collections.singletonList(txEntry.key()));
+
                                         ptr = cctx.wal().log(new DataRecord(new DataEntry(
                                             cacheCtx.cacheId(),
                                             txEntry.key(),
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 12ea9d9..ed8f010 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
@@ -232,7 +232,10 @@ public class IgniteTxManager extends GridCacheSharedManagerAdapter {
     private TxDeadlockDetection txDeadlockDetection;
 
     /** Flag indicates that {@link TxRecord} records will be logged to WAL. */
-    private boolean logTxRecords;
+    private volatile boolean logTxRecords;
+
+    /** Pending transactions tracker. */
+    private LocalPendingTransactionsTracker pendingTracker;
 
     /** {@inheritDoc} */
     @Override protected void onKernalStop0(boolean cancel) {
@@ -307,6 +310,9 @@ public class IgniteTxManager extends GridCacheSharedManagerAdapter {
 
         cctx.gridIO().addMessageListener(TOPIC_TX, new DeadlockDetectionListener());
 
+        this.pendingTracker = new LocalPendingTransactionsTracker(cctx);
+
+        // todo gg-13416 unhardcode
         this.logTxRecords = IgniteSystemProperties.getBoolean(IGNITE_WAL_LOG_TX_RECORDS, false);
     }
 
@@ -2499,6 +2505,27 @@ public class IgniteTxManager extends GridCacheSharedManagerAdapter {
     }
 
     /**
+     *
+     */
+    public LocalPendingTransactionsTracker pendingTxsTracker() {
+        return pendingTracker;
+    }
+
+    /**
+     * Enables pending transactions tracker.
+     * Also enables transaction wal logging, if it was disabled.
+     */
+    public void trackPendingTxs() {
+        pendingTracker.enable();
+
+        if (!logTxRecords) {
+            logTxRecords = true;
+
+            U.warn(log, "Transaction wal logging is enabled, because pending transaction tracker is enabled.");
+        }
+    }
+
+    /**
      * Sets MVCC state.
      *
      * @param tx Transaction.
@@ -2555,7 +2582,18 @@ public class IgniteTxManager extends GridCacheSharedManagerAdapter {
             record = new TxRecord(tx.state(), tx.nearXidVersion(), tx.writeVersion(), nodes);
 
         try {
-            return cctx.wal().log(record);
+            WALPointer ptr = cctx.wal().log(record);
+
+            TransactionState txState = tx.state();
+
+            if (txState == PREPARED)
+                cctx.tm().pendingTxsTracker().onTxPrepared(tx.nearXidVersion());
+            else if (txState == ROLLED_BACK)
+                cctx.tm().pendingTxsTracker().onTxRolledBack(tx.nearXidVersion());
+            else
+                cctx.tm().pendingTxsTracker().onTxCommitted(tx.nearXidVersion());
+
+            return ptr;
         }
         catch (IgniteCheckedException e) {
             U.error(log, "Failed to log TxRecord: " + record, e);
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/LocalPendingTransactionsTracker.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/LocalPendingTransactionsTracker.java
new file mode 100644
index 0000000..3aa179e
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/LocalPendingTransactionsTracker.java
@@ -0,0 +1,590 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.ignite.internal.processors.cache.transactions;
+
+import java.util.Collections;
+import java.util.HashSet;
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
+import java.util.concurrent.ConcurrentHashMap;
+import java.util.concurrent.atomic.AtomicBoolean;
+import java.util.concurrent.locks.ReentrantReadWriteLock;
+import org.apache.ignite.IgniteLogger;
+import org.apache.ignite.IgniteSystemProperties;
+import org.apache.ignite.internal.GridKernalState;
+import org.apache.ignite.internal.IgniteInternalFuture;
+import org.apache.ignite.internal.processors.cache.GridCacheSharedContext;
+import org.apache.ignite.internal.processors.cache.KeyCacheObject;
+import org.apache.ignite.internal.processors.cache.version.GridCacheVersion;
+import org.apache.ignite.internal.processors.timeout.GridTimeoutObjectAdapter;
+import org.apache.ignite.internal.util.GridConcurrentHashSet;
+import org.apache.ignite.internal.util.future.GridFutureAdapter;
+import org.apache.ignite.internal.util.typedef.internal.U;
+
+import static org.apache.ignite.IgniteSystemProperties.IGNITE_PENDING_TX_TRACKER_ENABLED;
+
+/**
+ * Tracks pending transactions for purposes of consistent cut algorithm.
+ */
+public class LocalPendingTransactionsTracker {
+    /** Cctx. */
+    private final GridCacheSharedContext<?, ?> cctx;
+
+    /** Logger. */
+    private final IgniteLogger log;
+
+    /** Currently committing transactions. */
+    private final Set<GridCacheVersion> currentlyCommittingTxs = U.newConcurrentHashSet();
+
+    /** Tracker enabled. */
+    private volatile boolean enabled = IgniteSystemProperties.getBoolean(IGNITE_PENDING_TX_TRACKER_ENABLED, false);
+
+    /** Currently prepared transactions. Counters are incremented on prepare, decremented on commit/rollback. */
+    private final ConcurrentHashMap<GridCacheVersion, Integer> preparedCommittedTxsCounters = new ConcurrentHashMap<>();
+
+    /**
+     * Transactions that were transitioned to pending state since last {@link #startTrackingPrepared()} call.
+     * Transaction remains in this map after commit/rollback.
+     */
+    private volatile GridConcurrentHashSet<GridCacheVersion> trackedPreparedTxs = new GridConcurrentHashSet<>();
+
+    /** Transactions that were transitioned to committed state since last {@link #startTrackingCommitted()} call. */
+    private volatile GridConcurrentHashSet<GridCacheVersion> trackedCommittedTxs = new GridConcurrentHashSet<>();
+
+    /** Written keys to near xid version. */
+    private volatile ConcurrentHashMap<KeyCacheObject, Set<GridCacheVersion>> writtenKeysToNearXidVer = new ConcurrentHashMap<>();
+
+    /** Graph of dependent (by keys) transactions. */
+    private volatile ConcurrentHashMap<GridCacheVersion, Set<GridCacheVersion>> dependentTransactionsGraph = new ConcurrentHashMap<>();
+    // todo GG-13416: maybe handle local sequential consistency with threadId
+
+    /** State rw-lock. */
+    private final ReentrantReadWriteLock stateLock = new ReentrantReadWriteLock();
+
+    /** Track prepared flag. */
+    private final AtomicBoolean trackPrepared = new AtomicBoolean(false);
+
+    /** Track committed flag. */
+    private final AtomicBoolean trackCommitted = new AtomicBoolean(false);
+
+    /** Tx finish awaiting. */
+    private volatile TxFinishAwaiting txFinishAwaiting;
+
+    /**
+     * Tx finish awaiting facility.
+     */
+    private class TxFinishAwaiting {
+        /** Future. */
+        private final GridFutureAdapter<Set<GridCacheVersion>> fut;
+
+        /** Not committed in timeout txs. */
+        private final Set<GridCacheVersion> notCommittedInTimeoutTxs;
+
+        /** Committing txs. */
+        private final Set<GridCacheVersion> committingTxs;
+
+        /** Global committing txs added. */
+        private volatile boolean globalCommittingTxsAdded;
+
+        /** Awaiting prepared is done. */
+        private volatile boolean awaitingPreparedIsDone;
+
+        /** Timeout. */
+        private volatile boolean timeout;
+
+        /**
+         * @param preparedTxsTimeout Prepared txs timeout.
+         * @param committingTxsTimeout Committing txs timeout.
+         */
+        private TxFinishAwaiting(final long preparedTxsTimeout, final long committingTxsTimeout) {
+            assert preparedTxsTimeout > 0 : preparedTxsTimeout;
+            assert committingTxsTimeout > 0 : committingTxsTimeout;
+            assert committingTxsTimeout >= preparedTxsTimeout : committingTxsTimeout + " < " + preparedTxsTimeout;
+
+            fut = new GridFutureAdapter<>();
+
+            notCommittedInTimeoutTxs = new GridConcurrentHashSet<>(preparedCommittedTxsCounters.keySet());
+
+            committingTxs = U.newConcurrentHashSet(currentlyCommittingTxs);
+
+            if (committingTxsTimeout > preparedTxsTimeout) {
+                cctx.time().addTimeoutObject(new GridTimeoutObjectAdapter(preparedTxsTimeout) {
+                    @Override public void onTimeout() {
+                        awaitingPreparedIsDone = true;
+
+                        if (TxFinishAwaiting.this != txFinishAwaiting || fut.isDone())
+                            return;
+
+                        stateLock.readLock().lock();
+
+                        try {
+                            if (allCommittingIsFinished())
+                                finish();
+                            else
+                                log.warning("Committing transactions not completed in " + preparedTxsTimeout + " ms: "
+                                    + committingTxs);
+                        }
+                        finally {
+                            stateLock.readLock().unlock();
+                        }
+                    }
+                });
+            }
+
+            cctx.time().addTimeoutObject(new GridTimeoutObjectAdapter(committingTxsTimeout) {
+                @Override public void onTimeout() {
+                    timeout = true;
+
+                    if (committingTxsTimeout == preparedTxsTimeout)
+                        awaitingPreparedIsDone = true;
+
+                    if (TxFinishAwaiting.this != txFinishAwaiting || fut.isDone())
+                        return;
+
+                    stateLock.readLock().lock();
+
+                    try {
+                        if (!allCommittingIsFinished())
+                            log.warning("Committing transactions not completed in " + committingTxsTimeout + " ms: "
+                                + committingTxs);
+
+                        finish();
+                    }
+                    finally {
+                        stateLock.readLock().unlock();
+                    }
+                }
+            });
+        }
+
+        /**
+         * @param nearXidVer Near xid version.
+         */
+        void onTxFinished(GridCacheVersion nearXidVer) {
+            notCommittedInTimeoutTxs.remove(nearXidVer);
+
+            checkTxsFinished();
+        }
+
+        /**
+         *
+         */
+        void checkTxsFinished() {
+            if (notCommittedInTimeoutTxs.isEmpty() || awaitingPreparedIsDone && allCommittingIsFinished())
+                finish();
+        }
+
+        /**
+         *
+         */
+        void finish() {
+            if (globalCommittingTxsAdded || timeout) {
+                txFinishAwaiting = null;
+
+                fut.onDone(notCommittedInTimeoutTxs.isEmpty() ?
+                    Collections.emptySet() :
+                    U.sealSet(notCommittedInTimeoutTxs));
+            }
+        }
+
+        /**
+         * @return {@code true} if the set of committing transactions {@code committingTxs} is empty.
+         */
+        boolean allCommittingIsFinished() {
+            committingTxs.retainAll(notCommittedInTimeoutTxs);
+
+            return committingTxs.isEmpty();
+        }
+
+        /**
+         * @param globalCommittingTxs Global committing txs.
+         */
+        void addGlobalCommittingTxs(Set<GridCacheVersion> globalCommittingTxs) {
+            assert stateLock.writeLock().isHeldByCurrentThread();
+
+            notCommittedInTimeoutTxs.addAll(preparedCommittedTxsCounters.keySet());
+
+            Set<GridCacheVersion> pendingTxs = new HashSet<>(notCommittedInTimeoutTxs);
+
+            pendingTxs.retainAll(globalCommittingTxs);
+
+            committingTxs.addAll(pendingTxs);
+
+            globalCommittingTxsAdded = true;
+
+            assert !fut.isDone() || timeout;
+
+            checkTxsFinished();
+        }
+    }
+
+    /**
+     * @param cctx Cctx.
+     */
+    public LocalPendingTransactionsTracker(GridCacheSharedContext<?, ?> cctx) {
+        this.cctx = cctx;
+
+        log = cctx.logger(getClass());
+    }
+
+    /**
+     * Enable pending transactions tracking.
+     */
+    void enable() {
+        assert cctx.kernalContext().gateway().getState() == GridKernalState.STARTING;
+
+        enabled = true;
+    }
+
+    /**
+     * @return whether this tracker is enabled or not.
+     */
+    public boolean enabled() {
+        return enabled;
+    }
+
+    /**
+     * Returns a collection of  transactions {@code P2} that are prepared but yet not committed
+     * between phase {@code Cut1} and phase {@code Cut2}.
+     *
+     * @return Collection of prepared transactions.
+     */
+    public Set<GridCacheVersion> currentlyPreparedTxs() {
+        assert stateLock.writeLock().isHeldByCurrentThread();
+
+        return U.sealSet(preparedCommittedTxsCounters.keySet());
+    }
+
+    /**
+     * Starts tracking transactions that will form a set of transactions {@code P23}
+     * that were prepared since phase {@code Cut2} to phase {@code Cut3}.
+     */
+    public void startTrackingPrepared() {
+        assert stateLock.writeLock().isHeldByCurrentThread();
+        assert !trackPrepared.get(): "Tracking prepared transactions is already initialized.";
+
+        trackPrepared.set(true);
+    }
+
+    /**
+     * @return nearXidVer -> prepared WAL ptr
+     */
+    public Set<GridCacheVersion> stopTrackingPrepared() {
+        assert stateLock.writeLock().isHeldByCurrentThread();
+        assert trackPrepared.get(): "Tracking prepared transactions is not initialized yet.";
+
+        trackPrepared.set(false);
+
+        Set<GridCacheVersion> res = U.sealSet(trackedPreparedTxs);
+
+        trackedPreparedTxs = new GridConcurrentHashSet<>();
+
+        return res;
+    }
+
+    /**
+     * Starts tracking committed transactions {@code C12} between phase {@code Cut1} and phase {@code Cut2}.
+     */
+    public void startTrackingCommitted() {
+        assert stateLock.writeLock().isHeldByCurrentThread();
+        assert !trackCommitted.get() : "Tracking committed transactions is already initialized.";
+
+        trackCommitted.set(true);
+    }
+
+    /**
+     * @return nearXidVer -> prepared WAL ptr
+     */
+    public TrackCommittedResult stopTrackingCommitted() {
+        assert stateLock.writeLock().isHeldByCurrentThread();
+        assert trackCommitted.get() : "Tracking committed transactions is not initialized yet.";
+
+        trackCommitted.set(false);
+
+        Set<GridCacheVersion> committedTxs = U.sealSet(trackedCommittedTxs);
+
+        Map<GridCacheVersion, Set<GridCacheVersion>> dependentTxs = U.sealMap(dependentTransactionsGraph);
+
+        trackedCommittedTxs = new GridConcurrentHashSet<>();
+
+        writtenKeysToNearXidVer = new ConcurrentHashMap<>();
+
+        dependentTransactionsGraph = new ConcurrentHashMap<>();
+
+        return new TrackCommittedResult(committedTxs, dependentTxs);
+    }
+
+    /**
+     * @param preparedTxsTimeout Timeout in milliseconds for awaiting of prepared transactions.
+     * @param committingTxsTimeout Timeout in milliseconds for awaiting of committing transactions.
+     * @return Collection of local transactions in committing state.
+     */
+    public Set<GridCacheVersion> startTxFinishAwaiting(
+        long preparedTxsTimeout, long committingTxsTimeout) {
+
+        assert stateLock.writeLock().isHeldByCurrentThread();
+
+        assert txFinishAwaiting == null : txFinishAwaiting;
+
+        TxFinishAwaiting awaiting = new TxFinishAwaiting(preparedTxsTimeout, committingTxsTimeout);
+
+        txFinishAwaiting = awaiting;
+
+        return awaiting.committingTxs;
+    }
+
+    /**
+     * @param globalCommittingTxs Global committing transactions.
+     * @return Future with collection of transactions that failed to finish within timeout.
+     */
+    public IgniteInternalFuture<Set<GridCacheVersion>> awaitPendingTxsFinished(
+        Set<GridCacheVersion> globalCommittingTxs
+    ) {
+        assert stateLock.writeLock().isHeldByCurrentThread();
+
+        TxFinishAwaiting awaiting = txFinishAwaiting;
+
+        assert awaiting != null;
+
+        awaiting.addGlobalCommittingTxs(globalCommittingTxs);
+
+        return awaiting.fut;
+    }
+
+    /**
+     * Freezes state of all tracker collections. Any active transactions that modify collections will
+     * wait on readLock().
+     * Can be used to obtain consistent snapshot of several collections.
+     */
+    public void writeLockState() {
+        stateLock.writeLock().lock();
+    }
+
+    /**
+     * Unfreezes state of all tracker collections, releases waiting transactions.
+     */
+    public void writeUnlockState() {
+        stateLock.writeLock().unlock();
+    }
+
+    /**
+     * @param nearXidVer Near xid version.
+     */
+    public void onTxPrepared(GridCacheVersion nearXidVer) {
+        if (!enabled)
+            return;
+
+        stateLock.readLock().lock();
+
+        try {
+            preparedCommittedTxsCounters.compute(nearXidVer, (key, value) -> value == null ? 1 : value + 1);
+
+            if (trackPrepared.get())
+                trackedPreparedTxs.add(nearXidVer);
+        }
+        finally {
+            stateLock.readLock().unlock();
+        }
+    }
+
+    /**
+     * @param nearXidVer Near xid version.
+     */
+    public void onTxCommitted(GridCacheVersion nearXidVer) {
+        if (!enabled)
+            return;
+
+        stateLock.readLock().lock();
+
+        try {
+            Integer newCntr = preparedCommittedTxsCounters.compute(nearXidVer, (key, value) -> {
+                if (value == null || value <= 0) {
+                    throw new AssertionError("Committing transaction that was rolled back or concurrently committed " +
+                        "[nearXidVer=" + nearXidVer + ", currentCntr=" + value + ']');
+                }
+
+                if (value == 1)
+                    return null;
+
+                return value - 1;
+            });
+
+            if (newCntr == null) {
+                currentlyCommittingTxs.remove(nearXidVer);
+
+                if (trackCommitted.get())
+                    trackedCommittedTxs.add(nearXidVer);
+
+                checkTxFinishFutureDone(nearXidVer);
+            }
+        }
+        finally {
+            stateLock.readLock().unlock();
+        }
+    }
+
+    /**
+     * @param nearXidVer Near xid version.
+     */
+    public void onTxRolledBack(GridCacheVersion nearXidVer) {
+        if (!enabled)
+            return;
+
+        stateLock.readLock().lock();
+
+        try {
+            Integer newCntr = preparedCommittedTxsCounters.compute(nearXidVer, (key, value) -> {
+                if (value == null || value <= 1)
+                    return null;
+
+                return value - 1;
+            });
+
+            if (newCntr == null) {
+                currentlyCommittingTxs.remove(nearXidVer);
+
+                checkTxFinishFutureDone(nearXidVer);
+            }
+        }
+        finally {
+            stateLock.readLock().unlock();
+        }
+    }
+
+    /**
+     * @param nearXidVer Near xid version.
+     * @param keys Keys.
+     */
+    public void onKeysWritten(GridCacheVersion nearXidVer, List<KeyCacheObject> keys) {
+        if (!enabled)
+            return;
+
+        stateLock.readLock().lock();
+
+        try {
+            if (!preparedCommittedTxsCounters.containsKey(nearXidVer))
+                throw new AssertionError("Tx should be in PREPARED state when logging data records: " + nearXidVer);
+
+            currentlyCommittingTxs.add(nearXidVer);
+
+            if (!trackCommitted.get())
+                return;
+
+            for (KeyCacheObject key : keys) {
+                writtenKeysToNearXidVer.compute(key, (keyObj, keyTxsSet) -> {
+                    Set<GridCacheVersion> keyTxs = keyTxsSet == null ? new HashSet<>() : keyTxsSet;
+
+                    for (GridCacheVersion previousTx : keyTxs) {
+                        dependentTransactionsGraph.compute(previousTx, (tx, depTxsSet) -> {
+                            Set<GridCacheVersion> dependentTxs = depTxsSet == null ? new HashSet<>() : depTxsSet;
+
+                            dependentTxs.add(nearXidVer);
+
+                            return dependentTxs;
+                        });
+                    }
+
+                    keyTxs.add(nearXidVer);
+
+                    return keyTxs;
+                });
+            }
+        }
+        finally {
+            stateLock.readLock().unlock();
+        }
+    }
+
+    /**
+     * @param nearXidVer Near xid version.
+     * @param keys Keys.
+     */
+    public void onKeysRead(GridCacheVersion nearXidVer, List<KeyCacheObject> keys) {
+        if (!enabled)
+            return;
+
+        stateLock.readLock().lock();
+
+        try {
+            if (!preparedCommittedTxsCounters.containsKey(nearXidVer))
+                throw new AssertionError("Tx should be in PREPARED state when logging data records: " + nearXidVer);
+
+            currentlyCommittingTxs.add(nearXidVer);
+
+            if (!trackCommitted.get())
+                return;
+
+            for (KeyCacheObject key : keys) {
+                writtenKeysToNearXidVer.computeIfPresent(key, (keyObj, keyTxsSet) -> {
+                    for (GridCacheVersion previousTx : keyTxsSet) {
+                        dependentTransactionsGraph.compute(previousTx, (tx, depTxsSet) -> {
+                            Set<GridCacheVersion> dependentTxs = depTxsSet == null ? new HashSet<>() : depTxsSet;
+
+                            dependentTxs.add(nearXidVer);
+
+                            return dependentTxs;
+                        });
+                    }
+
+                    return keyTxsSet;
+                });
+            }
+        }
+        finally {
+            stateLock.readLock().unlock();
+        }
+    }
+
+    /**
+     * Resets the state of this tracker.
+     */
+    public void reset() {
+        stateLock.writeLock().lock();
+
+        try {
+            txFinishAwaiting = null;
+
+            trackCommitted.set(false);
+
+            trackedCommittedTxs = new GridConcurrentHashSet<>();
+
+            trackPrepared.set(false);
+
+            trackedPreparedTxs = new GridConcurrentHashSet<>();
+
+            writtenKeysToNearXidVer = new ConcurrentHashMap<>();
+
+            dependentTransactionsGraph = new ConcurrentHashMap<>();
+        }
+        finally {
+            stateLock.writeLock().unlock();
+        }
+    }
+
+    /**
+     * @param nearXidVer Near xid version.
+     */
+    private void checkTxFinishFutureDone(GridCacheVersion nearXidVer) {
+        if (!enabled)
+            return;
+
+        TxFinishAwaiting awaiting = txFinishAwaiting;
+
+        if (awaiting != null)
+            awaiting.onTxFinished(nearXidVer);
+    }
+}
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/TrackCommittedResult.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/TrackCommittedResult.java
new file mode 100644
index 0000000..2ac5097
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/TrackCommittedResult.java
@@ -0,0 +1,57 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.ignite.internal.processors.cache.transactions;
+
+import java.util.Map;
+import java.util.Set;
+import org.apache.ignite.internal.processors.cache.version.GridCacheVersion;
+
+/**
+ * Tuple for result of {@link LocalPendingTransactionsTracker#stopTrackingCommitted()}.
+ */
+public class TrackCommittedResult {
+    /** Transactions committed during tracked period. */
+    private final Set<GridCacheVersion> committedTxs;
+
+    /** Graph of dependent (by keys) transactions. */
+    private final Map<GridCacheVersion, Set<GridCacheVersion>> dependentTxsGraph;
+
+    /**
+     * @param committedTxs Commited txs.
+     * @param dependentTxsGraph Dependent txs graph.
+     */
+    public TrackCommittedResult(
+        Set<GridCacheVersion> committedTxs,
+        Map<GridCacheVersion, Set<GridCacheVersion>> dependentTxsGraph
+    ) {
+        this.committedTxs = committedTxs;
+        this.dependentTxsGraph = dependentTxsGraph;
+    }
+
+    /**
+     *
+     */
+    public Set<GridCacheVersion> committedTxs() {
+        return committedTxs;
+    }
+
+    /**
+     *
+     */
+    public Map<GridCacheVersion, Set<GridCacheVersion>> dependentTxsGraph() {
+        return dependentTxsGraph;
+    }
+}
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/version/GridCacheVersionManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/version/GridCacheVersionManager.java
index 40b20ee..03e6462 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/version/GridCacheVersionManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/version/GridCacheVersionManager.java
@@ -26,6 +26,7 @@ import org.apache.ignite.internal.managers.eventstorage.GridLocalEventListener;
 import org.apache.ignite.internal.processors.affinity.AffinityTopologyVersion;
 import org.apache.ignite.internal.processors.cache.GridCacheSharedManagerAdapter;
 import org.apache.ignite.internal.util.typedef.internal.U;
+import org.apache.ignite.spi.discovery.DiscoverySpi;
 
 import static org.apache.ignite.events.EventType.EVT_NODE_METRICS_UPDATED;
 
@@ -61,8 +62,12 @@ public class GridCacheVersionManager extends GridCacheSharedManagerAdapter {
     /** Data center ID. */
     private byte dataCenterId;
 
-    /** */
-    private long gridStartTime;
+    /**
+     * Oldest cluster node start timestamp, lazily initialized.
+     *
+     * @see DiscoverySpi#getGridStartTime().
+     */
+    private volatile long gridStartTime;
 
     /** */
     private GridCacheVersion ISOLATED_STREAMER_VER;
@@ -324,4 +329,11 @@ public class GridCacheVersionManager extends GridCacheSharedManagerAdapter {
     public boolean isStartVersion(GridCacheVersion ver) {
         return startVer.equals(ver);
     }
+
+    /**
+     * Invalidates first cluster node start timestamp, it can be reinitialized lazily in the future.
+     */
+    public void invalidateGridStartTime() {
+        gridStartTime = 0;
+    }
 }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/BaselineTopologyHistoryItem.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/BaselineTopologyHistoryItem.java
index 7f2b4b0..6a02e42 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/BaselineTopologyHistoryItem.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/BaselineTopologyHistoryItem.java
@@ -19,6 +19,7 @@ import java.io.Serializable;
 import java.util.ArrayList;
 import java.util.Collection;
 import java.util.List;
+
 import org.apache.ignite.internal.util.typedef.internal.U;
 
 /**
@@ -75,4 +76,23 @@ public class BaselineTopologyHistoryItem implements Serializable {
     public List<Long> branchingHistory() {
         return branchingHistory;
     }
+
+    /**
+     * Returns {@code true} if baseline topology history item contains node with given consistent ID.
+     *
+     * @param consistentId Consistent ID.
+     * @return {@code True} if baseline topology history item contains node with given consistent ID.
+     */
+    public boolean containsNode(Object consistentId) {
+        return consIds.contains(consistentId);
+    }
+
+    /**
+     * Returns a copy of consistent ids of nodes that included into this baseline topology item.
+     *
+     * @return Collection of consistent ids.
+     */
+    public Collection<Object> consistentIds() {
+        return U.arrayList(this.consIds);
+    }
 }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/ChangeGlobalStateMessage.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/ChangeGlobalStateMessage.java
index d19585d..d41ff14 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/ChangeGlobalStateMessage.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/ChangeGlobalStateMessage.java
@@ -197,6 +197,14 @@ public class ChangeGlobalStateMessage implements DiscoveryCustomMessage {
     }
 
     /**
+     * Sets timestamp.
+     * @param timestamp Timestamp.
+     */
+    public void timestamp(long timestamp) {
+        this.timestamp = timestamp;
+    }
+
+    /**
      * @return State change request ID.
      */
     public UUID requestId() {
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 c958e17..6357791 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
@@ -1,12 +1,12 @@
 /*
  * Copyright 2019 GridGain Systems, Inc. and Contributors.
- * 
+ *
  * Licensed under the GridGain Community Edition License (the "License");
  * you may not use this file except in compliance with the License.
  * You may obtain a copy of the License at
- * 
+ *
  *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
- * 
+ *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
@@ -78,6 +78,7 @@ import org.apache.ignite.internal.util.typedef.F;
 import org.apache.ignite.internal.util.typedef.internal.A;
 import org.apache.ignite.internal.util.typedef.internal.CU;
 import org.apache.ignite.internal.util.typedef.internal.S;
+import org.apache.ignite.internal.util.typedef.internal.SB;
 import org.apache.ignite.internal.util.typedef.internal.U;
 import org.apache.ignite.lang.IgniteCallable;
 import org.apache.ignite.lang.IgniteFuture;
@@ -335,6 +336,13 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
     }
 
     /**
+     * Returns baseline topology history.
+     */
+    public BaselineTopologyHistory baselineHistory() {
+        return bltHist;
+    }
+
+    /**
      * @param blt Blt.
      */
     private void writeBaselineTopology(BaselineTopology blt, BaselineTopologyHistoryItem prevBltHistItem) throws IgniteCheckedException {
@@ -443,20 +451,16 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
     /**
      * Checks whether all conditions to meet BaselineTopology are satisfied.
      */
-    private boolean isBaselineSatisfied(BaselineTopology blt, List<ClusterNode> serverNodes) {
+    private boolean isBaselineSatisfied(BaselineTopology blt, List<ClusterNode> srvNodes) {
         if (blt == null)
             return false;
 
         if (blt.consistentIds() == null)
             return false;
 
-        if (//only node participating in BaselineTopology is allowed to send activation command...
-            blt.consistentIds().contains(ctx.discovery().localNode().consistentId())
-                //...and with this node BaselineTopology is reached
-                && blt.isSatisfied(serverNodes))
-            return true;
-
-        return false;
+        // Only node participating in BaselineTopology is allowed to send activation command
+        // and with this node BaselineTopology is reached.
+        return blt.consistentIds().contains(ctx.discovery().localNode().consistentId()) && blt.isSatisfied(srvNodes);
     }
 
     /** {@inheritDoc} */
@@ -523,10 +527,11 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
     ) {
         DiscoveryDataClusterState state = globalState;
 
-        if (log.isInfoEnabled())
-            U.log(log, "Received " + prettyStr(msg.activate()) + " request with BaselineTopology" +
-                (msg.baselineTopology() == null ? ": null"
-                    : "[id=" + msg.baselineTopology().id() + "]"));
+        if (log.isInfoEnabled()) {
+            String baseline = msg.baselineTopology() == null ? ": null" : "[id=" + msg.baselineTopology().id() + ']';
+
+            U.log(log, "Received " + prettyStr(msg.activate()) + " request with BaselineTopology" + baseline);
+        }
 
         if (msg.baselineTopology() != null)
             compatibilityMode = false;
@@ -592,7 +597,7 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
                 BaselineTopologyHistoryItem bltHistItem = BaselineTopologyHistoryItem.fromBaseline(
                     globalState.baselineTopology());
 
-                transitionFuts.put(msg.requestId(), new GridFutureAdapter<Void>());
+                transitionFuts.put(msg.requestId(), new GridFutureAdapter<>());
 
                 DiscoveryDataClusterState prevState = globalState;
 
@@ -679,7 +684,7 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
         if (initiatorNode.equals(ctx.localNodeId())) {
             GridChangeGlobalStateFuture fut = stateChangeFut.get();
 
-            if (fut != null && fut.requestId.equals(reqId))
+            if (fut != null && fut.reqId.equals(reqId))
                 return fut;
         }
 
@@ -774,19 +779,19 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
             return;
         }
 
-        BaselineTopologyHistory historyToSend = null;
+        BaselineTopologyHistory histToSnd = null;
 
         if (!bltHist.isEmpty()) {
             if (joiningNodeState != null && joiningNodeState.baselineTopology() != null) {
                 int lastId = joiningNodeState.baselineTopology().id();
 
-                historyToSend = bltHist.tailFrom(lastId);
+                histToSnd = bltHist.tailFrom(lastId);
             }
             else
-                historyToSend = bltHist;
+                histToSnd = bltHist;
         }
 
-        dataBag.addGridCommonData(STATE_PROC.ordinal(), new BaselineStateAndHistoryData(globalState, historyToSend));
+        dataBag.addGridCommonData(STATE_PROC.ordinal(), new BaselineStateAndHistoryData(globalState, histToSnd));
     }
 
     /** {@inheritDoc} */
@@ -811,7 +816,7 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
             DiscoveryDataClusterState state = stateDiscoData.globalState;
 
             if (state.transition())
-                transitionFuts.put(state.transitionRequestId(), new GridFutureAdapter<Void>());
+                transitionFuts.put(state.transitionRequestId(), new GridFutureAdapter<>());
 
             globalState = state;
 
@@ -826,9 +831,9 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
     @Override public IgniteInternalFuture<?> changeGlobalState(
         final boolean activate,
         Collection<? extends BaselineNode> baselineNodes,
-        boolean forceChangeBaselineTopology
+        boolean forceChangeBaselineTop
     ) {
-        return changeGlobalState(activate, baselineNodes, forceChangeBaselineTopology, false);
+        return changeGlobalState(activate, baselineNodes, forceChangeBaselineTop, false);
     }
 
     public IgniteInternalFuture<?> changeGlobalState(
@@ -848,15 +853,16 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
      */
     private BaselineTopology calculateNewBaselineTopology(final boolean activate,
         Collection<? extends BaselineNode> baselineNodes,
-        boolean forceChangeBaselineTopology) {
+        boolean forceChangeBaselineTop
+    ) {
         BaselineTopology newBlt;
 
-        BaselineTopology currentBlt = globalState.baselineTopology();
+        BaselineTopology currBlt = globalState.baselineTopology();
 
         int newBltId = 0;
 
-        if (currentBlt != null)
-            newBltId = activate ? currentBlt.id() + 1 : currentBlt.id();
+        if (currBlt != null)
+            newBltId = activate ? currBlt.id() + 1 : currBlt.id();
 
         if (baselineNodes != null && !baselineNodes.isEmpty()) {
             List<BaselineNode> baselineNodes0 = new ArrayList<>();
@@ -875,16 +881,16 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
             baselineNodes = baselineNodes0;
         }
 
-        if (forceChangeBaselineTopology)
+        if (forceChangeBaselineTop)
             newBlt = BaselineTopology.build(baselineNodes, newBltId);
         else if (activate) {
             if (baselineNodes == null)
                 baselineNodes = baselineNodes();
 
-            if (currentBlt == null)
+            if (currBlt == null)
                 newBlt = BaselineTopology.build(baselineNodes, newBltId);
             else {
-                newBlt = currentBlt;
+                newBlt = currBlt;
 
                 newBlt.updateHistory(baselineNodes);
             }
@@ -899,32 +905,38 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
     private Collection<BaselineNode> baselineNodes() {
         List<ClusterNode> clNodes = ctx.discovery().serverNodes(AffinityTopologyVersion.NONE);
 
-        ArrayList<BaselineNode> bltNodes = new ArrayList<>(clNodes.size());
+        List<BaselineNode> bltNodes = new ArrayList<>(clNodes.size());
 
-        for (ClusterNode clNode : clNodes)
-            bltNodes.add(clNode);
+        bltNodes.addAll(clNodes);
 
         return bltNodes;
     }
 
     /** */
-    private IgniteInternalFuture<?> changeGlobalState0(final boolean activate,
-        BaselineTopology blt, boolean forceChangeBaselineTopology) {
-        return changeGlobalState0(activate, blt, forceChangeBaselineTopology, false);
+    private IgniteInternalFuture<?> changeGlobalState0(
+        final boolean activate,
+        BaselineTopology blt,
+        boolean forceChangeBaselineTop
+    ) {
+        return changeGlobalState0(activate, blt, forceChangeBaselineTop, false);
     }
 
     /** */
-    private IgniteInternalFuture<?> changeGlobalState0(final boolean activate,
-        BaselineTopology blt, boolean forceChangeBaselineTopology, boolean isAutoAdjust) {
+    private IgniteInternalFuture<?> changeGlobalState0(
+        final boolean activate,
+        BaselineTopology blt,
+        boolean forceChangeBaselineTop,
+        boolean isAutoAdjust
+    ) {
         boolean isBaselineAutoAdjustEnabled = isBaselineAutoAdjustEnabled();
 
-        if (forceChangeBaselineTopology && isBaselineAutoAdjustEnabled != isAutoAdjust)
+        if (forceChangeBaselineTop && isBaselineAutoAdjustEnabled != isAutoAdjust)
             throw new BaselineAdjustForbiddenException(isBaselineAutoAdjustEnabled);
 
         if (ctx.isDaemon() || ctx.clientNode()) {
             GridFutureAdapter<Void> fut = new GridFutureAdapter<>();
 
-            sendComputeChangeGlobalState(activate, blt, forceChangeBaselineTopology, fut);
+            sendComputeChangeGlobalState(activate, blt, forceChangeBaselineTop, fut);
 
             return fut;
         }
@@ -995,15 +1007,17 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
             }
         }
 
-        ChangeGlobalStateMessage msg = new ChangeGlobalStateMessage(startedFut.requestId,
+        ChangeGlobalStateMessage msg = new ChangeGlobalStateMessage(startedFut.reqId,
             ctx.localNodeId(),
             storedCfgs,
             activate,
             blt,
-            forceChangeBaselineTopology,
+            forceChangeBaselineTop,
             System.currentTimeMillis()
         );
 
+        ctx.txDr().onChangeGlobalStateMessagePrepared(msg);
+
         IgniteInternalFuture<?> resFut = wrapStateChangeFuture(startedFut, msg);
 
         try {
@@ -1059,16 +1073,17 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
             return null;
 
         if (globalState == null || globalState.baselineTopology() == null) {
-            if (joiningNodeState != null && joiningNodeState.baselineTopology() != null) {
-                String msg = "Node with set up BaselineTopology is not allowed to join cluster without one: " + node.consistentId();
+            if (joiningNodeState.baselineTopology() != null) {
+                String msg = "Node with set up BaselineTopology is not allowed to join cluster without one: " +
+                        node.consistentId();
 
                 return new IgniteNodeValidationResult(node.id(), msg, msg);
             }
         }
 
         if (globalState.transition() && globalState.previousBaselineTopology() == null) {
-            //case when cluster is activating for the first time and other node with existing baseline topology
-            //tries to join
+            // Case when cluster is activating for the first time and other node with existing baseline topology
+            // tries to join.
 
             String msg = "Node with set up BaselineTopology is not allowed " +
                 "to join cluster in the process of first activation: " + node.consistentId();
@@ -1193,12 +1208,12 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
                 ", daemon" + ctx.isDaemon() + "]");
         }
 
-        ClusterGroupAdapter clusterGroupAdapter = (ClusterGroupAdapter)ctx.cluster().get().forServers();
+        ClusterGroupAdapter clusterGrpAdapter = (ClusterGroupAdapter)ctx.cluster().get().forServers();
 
-        if (F.isEmpty(clusterGroupAdapter.nodes()))
+        if (F.isEmpty(clusterGrpAdapter.nodes()))
             return new IgniteFinishedFutureImpl<>(false);
 
-        IgniteCompute comp = clusterGroupAdapter.compute();
+        IgniteCompute comp = clusterGrpAdapter.compute();
 
         return comp.callAsync(new IgniteCallable<Boolean>() {
             @IgniteInstanceResource
@@ -1283,6 +1298,8 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
 
                     distributedBaselineConfiguration.onActivate();
 
+                    ctx.txDr().onActivate(ctx);
+
                     if (log.isInfoEnabled())
                         log.info("Successfully performed final activation steps [nodeId="
                             + ctx.localNodeId() + ", client=" + client + ", topVer=" + req.topologyVersion() + "]");
@@ -1333,6 +1350,92 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
     }
 
     /**
+     * Executes validation checks of cluster state and BaselineTopology before changing BaselineTopology to new one.
+     */
+    public void validateBeforeBaselineChange(Collection<? extends BaselineNode> baselineTop) {
+        verifyBaselineTopologySupport(ctx.discovery().discoCache());
+
+        if (!ctx.state().clusterState().active())
+            throw new IgniteException("Changing BaselineTopology on inactive cluster is not allowed.");
+
+        if (baselineTop != null) {
+            if (baselineTop.isEmpty())
+                throw new IgniteException("BaselineTopology must contain at least one node.");
+
+            Collection<Object> onlineNodes = onlineBaselineNodesRequestedForRemoval(baselineTop);
+
+            if (onlineNodes != null) {
+                if (!onlineNodes.isEmpty()) {
+                    throw new IgniteException("Removing online nodes from BaselineTopology is not supported: " +
+                            onlineNodes);
+                }
+            }
+        }
+    }
+
+    /**
+     * Verifies all nodes in current cluster topology support BaselineTopology feature
+     * so compatibilityMode flag is enabled to reset.
+     *
+     * @param discoCache Discovery cache.
+     */
+    private void verifyBaselineTopologySupport(DiscoCache discoCache) {
+        if (discoCache.minimumServerNodeVersion().compareTo(MIN_BLT_SUPPORTING_VER) < 0) {
+            SB sb = new SB("Cluster contains nodes that don't support BaselineTopology: [");
+
+            for (ClusterNode cn : discoCache.serverNodes()) {
+                if (cn.version().compareTo(MIN_BLT_SUPPORTING_VER) < 0)
+                    sb
+                            .a('[')
+                            .a(cn.consistentId())
+                            .a(':')
+                            .a(cn.version())
+                            .a("], ");
+            }
+
+            sb.d(sb.length() - 2, sb.length());
+
+            throw new IgniteException(sb.a(']').toString());
+        }
+    }
+
+    /** */
+    @Nullable private Collection<Object> onlineBaselineNodesRequestedForRemoval(Collection<? extends BaselineNode> newBlt) {
+        BaselineTopology blt = ctx.state().clusterState().baselineTopology();
+        Set<Object> bltConsIds;
+
+        if (blt == null)
+            return null;
+        else
+            bltConsIds = blt.consistentIds();
+
+        ArrayList<Object> onlineNodesRequestedForRemoval = new ArrayList<>();
+
+        Collection<Object> aliveNodesConsIds = getConsistentIds(ctx.discovery().aliveServerNodes());
+
+        Collection<Object> newBltConsIds = getConsistentIds(newBlt);
+
+        for (Object oldBltConsId : bltConsIds) {
+            if (aliveNodesConsIds.contains(oldBltConsId)) {
+                if (!newBltConsIds.contains(oldBltConsId))
+                    onlineNodesRequestedForRemoval.add(oldBltConsId);
+            }
+        }
+
+        return onlineNodesRequestedForRemoval;
+    }
+
+    /** */
+    private Collection<Object> getConsistentIds(Collection<? extends BaselineNode> nodes) {
+        ArrayList<Object> res = new ArrayList<>(nodes.size());
+
+        for (BaselineNode n : nodes)
+            res.add(n.consistentId());
+
+        return res;
+    }
+
+    /**
      * @param reqId Request ID.
      * @param initNodeId Initialize node id.
      * @param ex Exception.
@@ -1374,14 +1477,14 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
 
         if (log.isDebugEnabled()) {
             log.debug("Received activation response [requestId=" + msg.getRequestId() +
-                ", nodeId=" + nodeId + "]");
+                ", nodeId=" + nodeId + ']');
         }
 
-        UUID requestId = msg.getRequestId();
+        UUID reqId = msg.getRequestId();
 
         final GridChangeGlobalStateFuture fut = stateChangeFut.get();
 
-        if (fut != null && requestId.equals(fut.requestId)) {
+        if (fut != null && reqId.equals(fut.reqId)) {
             if (fut.initFut.isDone())
                 fut.onResponse(nodeId, msg);
             else {
@@ -1403,11 +1506,8 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
     private void onStateRestored(BaselineTopology blt) {
         DiscoveryDataClusterState state = globalState;
 
-        if (!state.active() && !state.transition() && state.baselineTopology() == null) {
-            DiscoveryDataClusterState newState = DiscoveryDataClusterState.createState(false, blt);
-
-            globalState = newState;
-        }
+        if (!state.active() && !state.transition() && state.baselineTopology() == null)
+            globalState = DiscoveryDataClusterState.createState(false, blt);
     }
 
     /**
@@ -1518,7 +1618,7 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
     }
 
     /** {@inheritDoc} */
-    @Override public void onExchangeFinishedOnCoordinator(IgniteInternalFuture exchangeFuture, boolean hasMovingPartitions) {
+    @Override public void onExchangeFinishedOnCoordinator(IgniteInternalFuture exchFut, boolean hasMovingPartitions) {
         // no-op
     }
 
@@ -1627,7 +1727,7 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
     private class GridChangeGlobalStateFuture extends GridFutureAdapter<Void> {
         /** Request id. */
         @GridToStringInclude
-        private final UUID requestId;
+        private final UUID reqId;
 
         /** Activate. */
         private final boolean activate;
@@ -1657,12 +1757,12 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
         private final IgniteLogger log;
 
         /**
-         * @param requestId State change request ID.
+         * @param reqId State change request ID.
          * @param activate New cluster state.
          * @param ctx Context.
          */
-        GridChangeGlobalStateFuture(UUID requestId, boolean activate, GridKernalContext ctx) {
-            this.requestId = requestId;
+        GridChangeGlobalStateFuture(UUID reqId, boolean activate, GridKernalContext ctx) {
+            this.reqId = reqId;
             this.activate = activate;
             this.ctx = ctx;
 
@@ -1670,10 +1770,10 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
         }
 
         /**
-         * @param event Event.
+         * @param evt Event.
          */
-        void onNodeLeft(DiscoveryEvent event) {
-            assert event != null;
+        void onNodeLeft(DiscoveryEvent evt) {
+            assert evt != null;
 
             if (isDone())
                 return;
@@ -1681,7 +1781,7 @@ public class GridClusterStateProcessor extends GridProcessorAdapter implements I
             boolean allReceived = false;
 
             synchronized (mux) {
-                if (remaining.remove(event.eventNode().id()))
+                if (remaining.remove(evt.eventNode().id()))
                     allReceived = remaining.isEmpty();
             }
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/txdr/NoOpTransactionalDrProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/txdr/NoOpTransactionalDrProcessor.java
new file mode 100644
index 0000000..ff82b19
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/txdr/NoOpTransactionalDrProcessor.java
@@ -0,0 +1,82 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.ignite.internal.processors.txdr;
+
+import org.apache.ignite.IgniteCheckedException;
+import org.apache.ignite.internal.GridKernalContext;
+import org.apache.ignite.internal.pagemem.wal.WALPointer;
+import org.apache.ignite.internal.processors.GridProcessorAdapter;
+import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionExchangeId;
+import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture;
+import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsFullMessage;
+import org.apache.ignite.internal.processors.cache.persistence.snapshot.SnapshotOperation;
+import org.apache.ignite.internal.processors.cluster.ChangeGlobalStateMessage;
+import org.jetbrains.annotations.Nullable;
+
+/**
+ *
+ */
+public class NoOpTransactionalDrProcessor extends GridProcessorAdapter implements TransactionalDrProcessor {
+    /**
+     * @param ctx Context.
+     */
+    public NoOpTransactionalDrProcessor(GridKernalContext ctx) {
+        super(ctx);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void onMarkCheckPointBegin(long snapshotId, WALPointer ptr, SnapshotOperation snapshotOperation) {
+        // No-op.
+    }
+
+    /** {@inheritDoc} */
+    @Override public void onActivate(GridKernalContext kctx) throws IgniteCheckedException {
+        // No-op.
+    }
+
+    /** {@inheritDoc} */
+    @Override public void onDeActivate(GridKernalContext kctx) {
+        // No-op.
+    }
+
+    /** {@inheritDoc} */
+    @Override public void onPartitionsFullMessagePrepared(
+            @Nullable GridDhtPartitionExchangeId exchId,
+            GridDhtPartitionsFullMessage fullMsg
+    ) {
+        // No-op.
+    }
+
+    /** {@inheritDoc} */
+    @Override public void onChangeGlobalStateMessagePrepared(ChangeGlobalStateMessage msg) {
+        // No-op.
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean shouldIgnoreAssignPartitionStates(GridDhtPartitionsExchangeFuture fut) {
+        return false;
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean shouldScheduleRebalance(GridDhtPartitionsExchangeFuture fut) {
+        return false;
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean shouldApplyUpdateCounterOnRebalance() {
+        return false;
+    }
+}
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/txdr/TransactionalDrProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/txdr/TransactionalDrProcessor.java
new file mode 100644
index 0000000..8b679a4
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/txdr/TransactionalDrProcessor.java
@@ -0,0 +1,77 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.ignite.internal.processors.txdr;
+
+import org.apache.ignite.internal.pagemem.wal.WALPointer;
+import org.apache.ignite.internal.pagemem.wal.record.SnapshotRecord;
+import org.apache.ignite.internal.processors.GridProcessor;
+import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionExchangeId;
+import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplyMessage;
+import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture;
+import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsFullMessage;
+import org.apache.ignite.internal.processors.cache.persistence.snapshot.SnapshotOperation;
+import org.apache.ignite.internal.processors.cluster.ChangeGlobalStateMessage;
+import org.apache.ignite.internal.processors.cluster.IgniteChangeGlobalStateSupport;
+import org.jetbrains.annotations.Nullable;
+
+/**
+ *
+ */
+public interface TransactionalDrProcessor extends GridProcessor, IgniteChangeGlobalStateSupport {
+    /**
+     * @param snapshotId Snapshot id.
+     * @param ptr Pointer to the {@link SnapshotRecord}.
+     * @param snapshotOperation Snapshot operation.
+     */
+    public void onMarkCheckPointBegin(long snapshotId, WALPointer ptr, SnapshotOperation snapshotOperation);
+
+    /**
+     * @param exchId Partition exchange id.
+     *               This parameter has always a non-null value in case of the message is created for an exchange.
+     * @param fullMsg Partitions full message.
+     */
+    public void onPartitionsFullMessagePrepared(@Nullable GridDhtPartitionExchangeId exchId,
+        GridDhtPartitionsFullMessage fullMsg);
+
+    /**
+     * @param msg Change global state message.
+     */
+    public void onChangeGlobalStateMessagePrepared(ChangeGlobalStateMessage msg);
+
+    /**
+     * Returns true if we should skip assigning MOVING state to partitions due to outdated counters.
+     * The idea is to avoid redundant rebalance in case of random discovery events on REPLICA cluster.
+     * If event is "special" and rebalance really should happen according to REPLICA lifecycle, method will return true.
+     *
+     * @param fut Current exchange future.
+     */
+    public boolean shouldIgnoreAssignPartitionStates(GridDhtPartitionsExchangeFuture fut);
+
+    /**
+     * Returns true if we should schedule rebalance for MOVING partitions even if ideal assignment wasn't changed.
+     *
+     * @param fut Current exchange future.
+     */
+    public boolean shouldScheduleRebalance(GridDhtPartitionsExchangeFuture fut);
+
+    /**
+     * Returns {@code true} if update counters that are placed into {@link GridDhtPartitionSupplyMessage#last()}
+     * should be applied when the rebalance is finished.
+     *
+     * @return {@code true} if update counters should be applied when the rebalance is finished.
+     */
+    public boolean shouldApplyUpdateCounterOnRebalance();
+}
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/GridCircularBuffer.java b/modules/core/src/main/java/org/apache/ignite/internal/util/GridCircularBuffer.java
index 6a271f9..fade773 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/GridCircularBuffer.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/GridCircularBuffer.java
@@ -18,6 +18,8 @@ package org.apache.ignite.internal.util;
 
 import java.util.ArrayList;
 import java.util.Collection;
+import java.util.Iterator;
+import java.util.NoSuchElementException;
 import java.util.concurrent.atomic.AtomicLong;
 import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.internal.util.lang.IgniteInClosureX;
@@ -26,12 +28,13 @@ import org.apache.ignite.internal.util.typedef.T2;
 import org.apache.ignite.internal.util.typedef.internal.A;
 import org.apache.ignite.internal.util.typedef.internal.S;
 import org.apache.ignite.lang.IgniteInClosure;
+import org.jetbrains.annotations.NotNull;
 import org.jetbrains.annotations.Nullable;
 
 /**
  * This class implements a circular buffer for efficient data exchange.
  */
-public class GridCircularBuffer<T> {
+public class GridCircularBuffer<T> implements Iterable<T> {
     /** */
     private final long sizeMask;
 
@@ -129,6 +132,50 @@ public class GridCircularBuffer<T> {
         return arr[idx0].update(idx, t, arr.length, c);
     }
 
+    /**
+     * Returns read-only iterator over the elements.
+     * <p>
+     * The iterator can be used concurrently with adding new elements to the buffer,
+     * but the data read through iteration may be inconsistent then.
+     *
+     * @return Iterator.
+     */
+    @NotNull @Override public Iterator<T> iterator() {
+        return new Iterator<T>() {
+            int i;
+            int rest;
+
+            {
+                int tail = (int)sizeMask;
+
+                while (tail >= 0 && arr[tail].item == null)
+                    tail--;
+
+                rest = tail + 1;
+
+                i = rest <= sizeMask ? 0 : idxGen.intValue() & (int)sizeMask;
+            };
+
+            @Override public boolean hasNext() {
+                return rest > 0;
+            }
+
+            @Override public T next() {
+                if (rest <= 0)
+                    throw new NoSuchElementException();
+
+                T res = arr[i++].item;
+
+                if (i > sizeMask)
+                    i = 0;
+
+                rest--;
+
+                return res;
+            }
+        };
+    }
+
     /** {@inheritDoc} */
     @Override public String toString() {
         return S.toString(GridCircularBuffer.class, this);
@@ -202,16 +249,19 @@ public class GridCircularBuffer<T> {
 
             idx = newIdx; // Index should be updated even if closure fails.
 
-            if (c != null && item != null)
-                c.applyx(item);
+            try {
+                if (c != null && item != null)
+                    c.applyx(item);
 
-            V old = item;
+                V old = item;
 
-            item = newItem;
+                item = newItem;
 
-            notifyAll();
-
-            return old;
+                return old;
+            }
+            finally {
+                notifyAll();
+            }
         }
 
         /**
@@ -226,4 +276,4 @@ public class GridCircularBuffer<T> {
             return S.toString(Item.class, this, "hash=" + System.identityHashCode(this));
         }
     }
-}
\ No newline at end of file
+}
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 84d6510..81a90bf 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
@@ -1928,6 +1928,17 @@ public abstract class IgniteUtils {
      * @param <E> Entry type
      * @return Sealed collection.
      */
+    public static <E> Set<E> sealSet(Collection<E> c) {
+        return Collections.unmodifiableSet(new HashSet<>(c));
+    }
+
+    /**
+     * Seal collection.
+     *
+     * @param c Collection to seal.
+     * @param <E> Entry type
+     * @return Sealed collection.
+     */
     public static <E> List<E> sealList(Collection<E> c) {
         return Collections.unmodifiableList(new ArrayList<>(c));
     }
@@ -9503,6 +9514,32 @@ public abstract class IgniteUtils {
     }
 
     /**
+     * Creates new {@link Set} based on {@link ConcurrentHashMap}.
+     *
+     * @param <T> Type of elements.
+     * @return New concurrent set.
+     */
+    public static <T> Set<T> newConcurrentHashSet() {
+        return Collections.newSetFromMap(new ConcurrentHashMap<>());
+    }
+
+    /**
+     * Constructs a new {@link Set} based on {@link ConcurrentHashMap},
+     * containing the elements in the specified collection.
+     *
+     * @param <T> Type of elements.
+     * @param c Source collection.
+     * @return New concurrent set.
+     */
+    public static <T> Set<T> newConcurrentHashSet(Collection<T> c) {
+        Set<T> set = newConcurrentHashSet();
+
+        set.addAll(c);
+
+        return set;
+    }
+
+    /**
      * Creates new map that limited by size.
      *
      * @param limit Limit for size.
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/StripedExecutor.java b/modules/core/src/main/java/org/apache/ignite/internal/util/StripedExecutor.java
index a57eb95..694636f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/StripedExecutor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/StripedExecutor.java
@@ -290,6 +290,16 @@ public class StripedExecutor implements ExecutorService {
     }
 
     /**
+     * @param idx Stripe index.
+     * @return Queue size of specific stripe.
+     */
+    public int queueSize(int idx) {
+        A.ensure(idx >= 0, "Stripe index should be non-negative: " + idx);
+
+        return stripes[idx % stripes.length].queueSize();
+    }
+
+    /**
      * @return Completed tasks count.
      */
     public long completedTasks() {
diff --git a/modules/core/src/main/java/org/apache/ignite/logger/EchoingLogger.java b/modules/core/src/main/java/org/apache/ignite/logger/EchoingLogger.java
new file mode 100644
index 0000000..ebc8241
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/logger/EchoingLogger.java
@@ -0,0 +1,144 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.ignite.logger;
+
+import java.time.LocalDateTime;
+import java.time.format.DateTimeFormatter;
+import java.util.Arrays;
+import java.util.Objects;
+import java.util.Optional;
+import java.util.function.Consumer;
+import java.util.stream.Collectors;
+import org.apache.ignite.IgniteLogger;
+import org.jetbrains.annotations.NotNull;
+import org.jetbrains.annotations.Nullable;
+
+/**
+ * {@link IgniteLogger} wrapper that echoes log messages to arbitrary target.
+ */
+public class EchoingLogger implements IgniteLogger {
+    /** */
+    private final IgniteLogger delegate;
+
+    /** */
+    private final Consumer<String> echoTo;
+
+    /**
+     * @param echoTo Echo to.
+     * @param delegate Delegate.
+     */
+    public EchoingLogger(@NotNull IgniteLogger delegate, @NotNull Consumer<String> echoTo) {
+        this.delegate = Objects.requireNonNull(delegate);
+        this.echoTo = Objects.requireNonNull(echoTo);
+    }
+
+    /** {@inheritDoc} */
+    @Override public IgniteLogger getLogger(Object ctgr) {
+        return new EchoingLogger(delegate.getLogger(ctgr), echoTo);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void trace(String msg) {
+        if (delegate.isTraceEnabled()) {
+            delegate.trace(msg);
+
+            echoTo.accept(String.format("[%-23s][%-5s] %s", now(), "TRACE", msg));
+        }
+    }
+
+    /** {@inheritDoc} */
+    @Override public void debug(String msg) {
+        if (delegate.isDebugEnabled()) {
+            delegate.debug(msg);
+
+            echoTo.accept(String.format("[%-23s][%-5s] %s", now(), "DEBUG", msg));
+        }
+    }
+
+    /** {@inheritDoc} */
+    @Override public void info(String msg) {
+        if (delegate.isInfoEnabled()) {
+            delegate.info(msg);
+
+            echoTo.accept(String.format("[%-23s][%-5s] %s", now(), "INFO", msg));
+        }
+    }
+
+    /** {@inheritDoc} */
+    @Override public void warning(String msg, @Nullable Throwable e) {
+        delegate.warning(msg, e);
+
+        echoTo.accept(String.format("[%-23s][%-5s] %s%s", now(), "WARN", msg, formatThrowable(Optional.ofNullable(e))));
+    }
+
+    /** {@inheritDoc} */
+    @Override public void error(String msg, @Nullable Throwable e) {
+        delegate.error(msg, e);
+
+        echoTo.accept(String.format("[%-23s][%-5s] %s%s", now(), "ERROR", msg, formatThrowable(Optional.ofNullable(e))));
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean isTraceEnabled() {
+        return delegate.isTraceEnabled();
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean isDebugEnabled() {
+        return delegate.isDebugEnabled();
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean isInfoEnabled() {
+        return delegate.isInfoEnabled();
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean isQuiet() {
+        return delegate.isQuiet();
+    }
+
+    /** {@inheritDoc} */
+    @Override public String fileName() {
+        return delegate.fileName();
+    }
+
+    /**
+     *
+     */
+    private static String now() {
+        return LocalDateTime.now().format(DateTimeFormatter.ISO_LOCAL_DATE_TIME);
+    }
+
+    /**
+     *
+     */
+    private static String formatThrowable(Optional<Throwable> e) {
+        return e.map(EchoingLogger::formatThrowable).orElse("");
+    }
+
+    /**
+     *
+     */
+    private static String formatThrowable(@NotNull Throwable e) {
+        return (e.getMessage() != null ? ": " + e.getMessage() : "") + System.lineSeparator() +
+            Arrays.stream(e.getStackTrace())
+                .map(StackTraceElement::toString)
+                .map(s -> "at " + s)
+                .collect(Collectors.joining(System.lineSeparator()));
+    }
+}
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java
index 77c365d..46beeeb 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java
@@ -1491,6 +1491,16 @@ public class TcpDiscoverySpi extends IgniteSpiAdapter implements IgniteDiscovery
     }
 
     /**
+     * Sets grid start time.
+     *
+     * @param val New time value.
+     */
+    @SuppressWarnings("unused")
+    public void setGridStartTime(long val) {
+        this.gridStartTime = val;
+    }
+
+    /**
      * @param sockAddr Remote address.
      * @param timeoutHelper Timeout helper.
      * @return Opened socket.
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterReadOnlyModeAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterReadOnlyModeAbstractTest.java
index 7d09c23..c0c3289 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterReadOnlyModeAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterReadOnlyModeAbstractTest.java
@@ -24,6 +24,7 @@ import org.apache.ignite.cache.QueryEntity;
 import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.internal.IgniteEx;
+import org.apache.ignite.internal.processors.cache.distributed.dht.IgniteClusterReadOnlyException;
 import org.apache.ignite.internal.util.typedef.F;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
 
@@ -119,4 +120,13 @@ public class ClusterReadOnlyModeAbstractTest extends GridCommonAbstractTest {
             ignite.context().cache().context().readOnlyMode(readOnly);
         }
     }
+
+    /**
+     * @param e Exception.
+     */
+    public static void checkThatRootCauseIsReadOnly(Throwable e) {
+        for (Throwable t = e; t != null; t = t.getCause())
+            if (t.getCause() == null)
+                assertTrue(t.getMessage(), t instanceof IgniteClusterReadOnlyException);
+    }
 }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterReadOnlyModeTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterReadOnlyModeTest.java
index be9bf30..c0f243a 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterReadOnlyModeTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/ClusterReadOnlyModeTest.java
@@ -84,7 +84,7 @@ public class ClusterReadOnlyModeTest extends ClusterReadOnlyModeAbstractTest {
                             fail("Put must fail for cache " + cacheName);
                         }
                         catch (Exception e) {
-                            // No-op.
+                            checkThatRootCauseIsReadOnly(e);
                         }
 
                         // All removes must fail.
@@ -94,7 +94,7 @@ public class ClusterReadOnlyModeTest extends ClusterReadOnlyModeAbstractTest {
                             fail("Remove must fail for cache " + cacheName);
                         }
                         catch (Exception e) {
-                            // No-op.
+                            checkThatRootCauseIsReadOnly(e);
                         }
                     }
                     else {
@@ -115,7 +115,7 @@ public class ClusterReadOnlyModeTest extends ClusterReadOnlyModeAbstractTest {
 
         for (Ignite ignite : G.allGrids()) {
             for (String cacheName : CACHE_NAMES) {
-                boolean failed = false;
+                Throwable failed = null;
 
                 try (IgniteDataStreamer<Integer, Integer> streamer = ignite.dataStreamer(cacheName)) {
                     for (int i = 0; i < 10; i++) {
@@ -125,11 +125,13 @@ public class ClusterReadOnlyModeTest extends ClusterReadOnlyModeAbstractTest {
                     }
                 }
                 catch (CacheException ignored) {
-                    failed = true;
+                    failed = ignored;
                 }
 
-                if (failed != readOnly)
+                if ((failed == null) == readOnly)
                     fail("Streaming to " + cacheName + " must " + (readOnly ? "fail" : "succeed"));
+
+                checkThatRootCauseIsReadOnly(failed);
             }
         }
     }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/LocalWalModeChangeDuringRebalancingSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/LocalWalModeChangeDuringRebalancingSelfTest.java
index 416a726..62863ab 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/LocalWalModeChangeDuringRebalancingSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/LocalWalModeChangeDuringRebalancingSelfTest.java
@@ -166,6 +166,8 @@ public class LocalWalModeChangeDuringRebalancingSelfTest extends GridCommonAbstr
         System.setProperty(IgniteSystemProperties.IGNITE_PENDING_TX_TRACKER_ENABLED,
             Boolean.toString(enablePendingTxTracker));
 
+        System.setProperty(IgniteSystemProperties.IGNITE_WAL_LOG_TX_RECORDS, Boolean.toString(enablePendingTxTracker));
+
         return cfg;
     }
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteNodeStoppedDuringDisableWALTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteNodeStoppedDuringDisableWALTest.java
index 855f3a8..2ef8878 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteNodeStoppedDuringDisableWALTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteNodeStoppedDuringDisableWALTest.java
@@ -170,7 +170,7 @@ public class IgniteNodeStoppedDuringDisableWALTest extends GridCommonAbstractTes
         boolean fail = false;
 
         try (WALIterator it = sharedContext.wal().replay(null)) {
-            dbMgr.applyUpdatesOnRecovery(it, (ptr, rec) -> true, (entry) -> true);
+            dbMgr.applyUpdatesOnRecovery(it, (ptr, rec) -> true, (rec, entry) -> true);
         }
         catch (IgniteCheckedException e) {
             if (nodeStopPoint.needCleanUp)
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/aware/SegmentAwareTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/aware/SegmentAwareTest.java
index a1ae17e..a4c7a13 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/aware/SegmentAwareTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/aware/SegmentAwareTest.java
@@ -20,6 +20,7 @@ import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.internal.IgniteFutureTimeoutCheckedException;
 import org.apache.ignite.internal.IgniteInternalFuture;
 import org.apache.ignite.internal.IgniteInterruptedCheckedException;
+import org.apache.ignite.logger.NullLogger;
 import org.apache.ignite.testframework.GridTestUtils;
 import org.junit.Test;
 
@@ -42,7 +43,7 @@ public class SegmentAwareTest {
      */
     @Test
     public void testAvoidDeadlockArchiverAndLockStorage() throws IgniteCheckedException {
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         int iterationCnt = 100_000;
         int segmentToHandle = 1;
@@ -80,7 +81,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishAwaitSegment_WhenExactWaitingSegmentWasSet() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         IgniteInternalFuture future = awaitThread(() -> aware.awaitSegment(5));
 
@@ -97,7 +98,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishAwaitSegment_WhenGreaterThanWaitingSegmentWasSet() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         IgniteInternalFuture future = awaitThread(() -> aware.awaitSegment(5));
 
@@ -114,7 +115,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishAwaitSegment_WhenNextSegmentEqualToWaitingOne() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         IgniteInternalFuture future = awaitThread(() -> aware.awaitSegment(5));
 
@@ -137,7 +138,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishAwaitSegment_WhenInterruptWasCall() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         IgniteInternalFuture future = awaitThread(() -> aware.awaitSegment(5));
 
@@ -154,7 +155,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishWaitSegmentForArchive_WhenWorkSegmentIncremented() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         aware.curAbsWalIdx(5);
         aware.setLastArchivedAbsoluteIndex(4);
@@ -174,7 +175,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishWaitSegmentForArchive_WhenWorkSegmentGreaterValue() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         aware.curAbsWalIdx(5);
         aware.setLastArchivedAbsoluteIndex(4);
@@ -194,7 +195,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishWaitSegmentForArchive_WhenInterruptWasCall() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         aware.curAbsWalIdx(5);
         aware.setLastArchivedAbsoluteIndex(4);
@@ -214,7 +215,7 @@ public class SegmentAwareTest {
     @Test
     public void testCorrectCalculateNextSegmentIndex() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         aware.curAbsWalIdx(5);
 
@@ -231,7 +232,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishWaitNextAbsoluteIndex_WhenMarkAsArchivedFirstSegment() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(2, false);
+        SegmentAware aware = new SegmentAware(2, false, new NullLogger());
 
         aware.curAbsWalIdx(1);
         aware.setLastArchivedAbsoluteIndex(-1);
@@ -251,7 +252,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishWaitNextAbsoluteIndex_WhenSetToArchivedFirst() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(2, false);
+        SegmentAware aware = new SegmentAware(2, false, new NullLogger());
 
         aware.curAbsWalIdx(1);
         aware.setLastArchivedAbsoluteIndex(-1);
@@ -271,7 +272,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishWaitNextAbsoluteIndex_WhenOnlyForceInterruptWasCall() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(2, false);
+        SegmentAware aware = new SegmentAware(2, false, new NullLogger());
 
         aware.curAbsWalIdx(2);
         aware.setLastArchivedAbsoluteIndex(-1);
@@ -297,7 +298,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishSegmentArchived_WhenSetExactWaitingSegment() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         IgniteInternalFuture future = awaitThread(() -> aware.awaitSegmentArchived(5));
 
@@ -314,7 +315,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishSegmentArchived_WhenMarkExactWaitingSegment() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         IgniteInternalFuture future = awaitThread(() -> aware.awaitSegmentArchived(5));
 
@@ -331,7 +332,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishSegmentArchived_WhenSetGreaterThanWaitingSegment() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         IgniteInternalFuture future = awaitThread(() -> aware.awaitSegmentArchived(5));
 
@@ -348,7 +349,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishSegmentArchived_WhenMarkGreaterThanWaitingSegment() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         IgniteInternalFuture future = awaitThread(() -> aware.awaitSegmentArchived(5));
 
@@ -365,7 +366,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishSegmentArchived_WhenInterruptWasCall() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         aware.curAbsWalIdx(5);
         aware.setLastArchivedAbsoluteIndex(4);
@@ -385,7 +386,7 @@ public class SegmentAwareTest {
     @Test
     public void testMarkAsMovedToArchive_WhenReleaseLockedSegment() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         aware.checkCanReadArchiveOrReserveWorkSegment(5);
 
@@ -404,7 +405,7 @@ public class SegmentAwareTest {
     @Test
     public void testMarkAsMovedToArchive_WhenInterruptWasCall() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
         aware.checkCanReadArchiveOrReserveWorkSegment(5);
 
         IgniteInternalFuture future = awaitThread(() -> aware.markAsMovedToArchive(5));
@@ -425,7 +426,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishWaitSegmentToCompress_WhenSetLastArchivedSegment() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, true);
+        SegmentAware aware = new SegmentAware(10, true, new NullLogger());
 
         aware.onSegmentCompressed(5);
 
@@ -444,7 +445,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishWaitSegmentToCompress_WhenMarkLastArchivedSegment() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, true);
+        SegmentAware aware = new SegmentAware(10, true, new NullLogger());
 
         aware.onSegmentCompressed(5);
 
@@ -462,7 +463,7 @@ public class SegmentAwareTest {
      */
     @Test
     public void testCorrectCalculateNextCompressSegment() throws IgniteCheckedException, InterruptedException {
-        SegmentAware aware = new SegmentAware(10, true);
+        SegmentAware aware = new SegmentAware(10, true, new NullLogger());
 
         aware.setLastArchivedAbsoluteIndex(6);
 
@@ -476,7 +477,7 @@ public class SegmentAwareTest {
     @Test
     public void testFinishWaitSegmentToCompress_WhenInterruptWasCall() throws IgniteCheckedException, InterruptedException {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, true);
+        SegmentAware aware = new SegmentAware(10, true, new NullLogger());
         aware.onSegmentCompressed(5);
 
         IgniteInternalFuture future = awaitThread(aware::waitNextSegmentToCompress);
@@ -493,7 +494,7 @@ public class SegmentAwareTest {
      */
     @Test
     public void testLastCompressedIdxProperOrdering() throws IgniteInterruptedCheckedException {
-        SegmentAware aware = new SegmentAware(10, true);
+        SegmentAware aware = new SegmentAware(10, true, new NullLogger());
 
         for (int i = 0; i < 5; i++) {
             aware.setLastArchivedAbsoluteIndex(i);
@@ -518,7 +519,7 @@ public class SegmentAwareTest {
     @Test
     public void testReserveCorrectly() {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         //when: reserve one segment twice and one segment once.
         aware.reserve(5);
@@ -562,7 +563,7 @@ public class SegmentAwareTest {
     @Test
     public void testAssertFail_WhenReleaseUnreservedSegment() {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         aware.reserve(5);
         try {
@@ -582,7 +583,7 @@ public class SegmentAwareTest {
     @Test
     public void testReserveWorkSegmentCorrectly() {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         //when: lock one segment twice.
         aware.checkCanReadArchiveOrReserveWorkSegment(5);
@@ -616,7 +617,7 @@ public class SegmentAwareTest {
     @Test
     public void testAssertFail_WhenReleaseUnreservedWorkSegment() {
         //given: thread which awaited segment.
-        SegmentAware aware = new SegmentAware(10, false);
+        SegmentAware aware = new SegmentAware(10, false, new NullLogger());
 
         aware.checkCanReadArchiveOrReserveWorkSegment(5);
         try {
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 956014f..a6a9b0b 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
@@ -18,22 +18,32 @@ package org.apache.ignite.internal.processors.cache.persistence.wal.reader;
 
 import java.io.File;
 import java.io.IOException;
+import java.nio.file.Files;
 import java.nio.file.OpenOption;
 import java.util.List;
 import java.util.Random;
+import java.util.TreeSet;
+import java.util.concurrent.atomic.AtomicBoolean;
 import java.util.concurrent.atomic.AtomicInteger;
 import org.apache.ignite.Ignite;
+import org.apache.ignite.IgniteCache;
 import org.apache.ignite.IgniteCheckedException;
+import org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction;
+import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.DataRegionConfiguration;
 import org.apache.ignite.configuration.DataStorageConfiguration;
 import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.internal.IgniteEx;
+import org.apache.ignite.internal.IgniteInternalFuture;
+import org.apache.ignite.internal.IgniteInterruptedCheckedException;
 import org.apache.ignite.internal.pagemem.wal.IgniteWriteAheadLogManager;
 import org.apache.ignite.internal.pagemem.wal.WALIterator;
 import org.apache.ignite.internal.pagemem.wal.WALPointer;
 import org.apache.ignite.internal.pagemem.wal.record.RolloverType;
 import org.apache.ignite.internal.pagemem.wal.record.SnapshotRecord;
 import org.apache.ignite.internal.pagemem.wal.record.WALRecord;
+import org.apache.ignite.internal.pagemem.wal.record.WalRecordCacheGroupAware;
+import org.apache.ignite.internal.pagemem.wal.record.delta.PartitionDestroyRecord;
 import org.apache.ignite.internal.processors.cache.persistence.IgniteCacheDatabaseSharedManager;
 import org.apache.ignite.internal.processors.cache.persistence.file.FileIO;
 import org.apache.ignite.internal.processors.cache.persistence.file.RandomAccessFileIO;
@@ -53,16 +63,24 @@ import static org.apache.ignite.internal.processors.cache.persistence.wal.reader
  * The test check, that StandaloneWalRecordsIterator correctly close file descriptors associated with WAL files.
  */
 public class StandaloneWalRecordsIteratorTest extends GridCommonAbstractTest {
+    /** Wal segment size. */
+    private static final int WAL_SEGMENT_SIZE = 512 * 1024;
+
+    /** Wal compaction enabled. */
+    private boolean walCompactionEnabled;
+
     /** {@inheritDoc} */
     @Override protected IgniteConfiguration getConfiguration(String name) throws Exception {
         IgniteConfiguration cfg = super.getConfiguration(name);
 
         cfg.setDataStorageConfiguration(
-            new DataStorageConfiguration().
-                setDefaultDataRegionConfiguration(
+            new DataStorageConfiguration()
+                .setDefaultDataRegionConfiguration(
                     new DataRegionConfiguration()
                         .setPersistenceEnabled(true)
                 )
+                .setWalSegmentSize(WAL_SEGMENT_SIZE)
+                .setWalCompactionEnabled(walCompactionEnabled)
         );
 
         return cfg;
@@ -70,6 +88,8 @@ public class StandaloneWalRecordsIteratorTest extends GridCommonAbstractTest {
 
     /** {@inheritDoc} */
     @Override protected void beforeTest() throws Exception {
+        walCompactionEnabled = false;
+
         super.beforeTest();
 
         stopAllGrids();
@@ -89,6 +109,195 @@ public class StandaloneWalRecordsIteratorTest extends GridCommonAbstractTest {
     /**
      *
      */
+    public void testBlinkingTemporaryFile() throws Exception {
+        walCompactionEnabled = true;
+
+        IgniteEx ig = (IgniteEx)startGrid();
+
+        String archiveWalDir = getArchiveWalDirPath(ig);
+
+        ig.cluster().active(true);
+
+        IgniteCache<Object, Object> cache = ig.getOrCreateCache(
+            new CacheConfiguration<>().setName("c-n").setAffinity(new RendezvousAffinityFunction(false, 32)));
+
+        IgniteCacheDatabaseSharedManager sharedMgr = ig.context().cache().context().database();
+
+        IgniteWriteAheadLogManager walMgr = ig.context().cache().context().wal();
+
+        WALPointer fromPtr = null;
+
+        int recordsCnt = WAL_SEGMENT_SIZE / 8 /* record size */ * 5;
+
+        AtomicBoolean stopBlinking = new AtomicBoolean(false);
+        AtomicInteger blinkIterations = new AtomicInteger(0);
+
+        IgniteInternalFuture blinkFut = GridTestUtils.runAsync(new Runnable() {
+            @Override public void run() {
+                try {
+                    while (walMgr.lastCompactedSegment() < 2)
+                        U.sleep(10);
+
+                    File walArchive = new File(archiveWalDir);
+                    File consIdFolder = new File(walArchive, "node00-" + ig.cluster().localNode().consistentId().toString());
+                    File compressedWalSegment = new File(consIdFolder, FileDescriptor.fileName(1) + ".zip");
+                    File compressedTmpWalSegment = new File(consIdFolder, FileDescriptor.fileName(1) + ".zip.tmp");
+
+                    while (!stopBlinking.get()) {
+                        Files.copy(compressedWalSegment.toPath(), compressedTmpWalSegment.toPath());
+
+                        U.sleep(10);
+
+                        U.delete(compressedTmpWalSegment);
+
+                        blinkIterations.incrementAndGet();
+                    }
+                }
+                catch (IgniteInterruptedCheckedException | IOException e) {
+                    throw new RuntimeException(e);
+                }
+            }
+        }, "blinky");
+
+        for (int i = 0; i < recordsCnt; i++) {
+            WALPointer ptr = walMgr.log(new PartitionDestroyRecord(i, i));
+
+            if (i == 100)
+                fromPtr = ptr;
+        }
+
+        assertNotNull(fromPtr);
+
+        cache.put(1, 1);
+
+        forceCheckpoint();
+
+        // Generate WAL segments for filling WAL archive folder.
+        for (int i = 0; i < 2 * ig.configuration().getDataStorageConfiguration().getWalSegments(); i++) {
+            sharedMgr.checkpointReadLock();
+
+            try {
+                walMgr.log(new SnapshotRecord(i, false), RolloverType.NEXT_SEGMENT);
+            }
+            finally {
+                sharedMgr.checkpointReadUnlock();
+            }
+        }
+
+        cache.put(2, 2);
+
+        forceCheckpoint();
+
+        System.out.println("@@@ " + blinkIterations.get() + " blink iterations already completed");
+
+        U.sleep(5000);
+
+        stopGrid();
+
+        for (int i = 0; i < 20; i++) {
+            WALIterator it = new IgniteWalIteratorFactory(log)
+                .iterator(new IteratorParametersBuilder().from((FileWALPointer)fromPtr).filesOrDirs(archiveWalDir));
+
+            TreeSet<Integer> foundCounters = new TreeSet<>();
+
+            it.forEach(x -> {
+                WALRecord rec = x.get2();
+
+                if (rec instanceof PartitionDestroyRecord)
+                    foundCounters.add(((WalRecordCacheGroupAware)rec).groupId());
+            });
+
+            assertEquals(new Integer(100), foundCounters.first());
+            assertEquals(new Integer(recordsCnt - 1), foundCounters.last());
+            assertEquals(recordsCnt - 100, foundCounters.size());
+
+            System.out.println("@@@ " + blinkIterations.get() + " blink iterations already completed");
+        }
+
+        stopBlinking.set(true);
+
+        System.out.println("@@@ " + blinkIterations.get() + " blink iterations finally completed");
+
+        blinkFut.get();
+    }
+
+    /**
+     *
+     */
+    public void testBoundedIterationOverSeveralSegments() throws Exception {
+        walCompactionEnabled = true;
+
+        IgniteEx ig = (IgniteEx)startGrid();
+
+        String archiveWalDir = getArchiveWalDirPath(ig);
+
+        ig.cluster().active(true);
+
+        IgniteCache<Object, Object> cache = ig.getOrCreateCache(
+            new CacheConfiguration<>().setName("c-n").setAffinity(new RendezvousAffinityFunction(false, 32)));
+
+        IgniteCacheDatabaseSharedManager sharedMgr = ig.context().cache().context().database();
+
+        IgniteWriteAheadLogManager walMgr = ig.context().cache().context().wal();
+
+        WALPointer fromPtr = null;
+
+        int recordsCnt = WAL_SEGMENT_SIZE / 8 /* record size */ * 5;
+
+        for (int i = 0; i < recordsCnt; i++) {
+            WALPointer ptr = walMgr.log(new PartitionDestroyRecord(i, i));
+
+            if (i == 100)
+                fromPtr = ptr;
+        }
+
+        assertNotNull(fromPtr);
+
+        cache.put(1, 1);
+
+        forceCheckpoint();
+
+        // Generate WAL segments for filling WAL archive folder.
+        for (int i = 0; i < 2 * ig.configuration().getDataStorageConfiguration().getWalSegments(); i++) {
+            sharedMgr.checkpointReadLock();
+
+            try {
+                walMgr.log(new SnapshotRecord(i, false), RolloverType.NEXT_SEGMENT);
+            }
+            finally {
+                sharedMgr.checkpointReadUnlock();
+            }
+        }
+
+        cache.put(2, 2);
+
+        forceCheckpoint();
+
+        U.sleep(5000);
+
+        stopGrid();
+
+        WALIterator it = new IgniteWalIteratorFactory(log)
+            .iterator(new IteratorParametersBuilder().from((FileWALPointer)fromPtr).filesOrDirs(archiveWalDir));
+
+        TreeSet<Integer> foundCounters = new TreeSet<>();
+
+        it.forEach(x -> {
+            WALRecord rec = x.get2();
+
+            if (rec instanceof PartitionDestroyRecord)
+                foundCounters.add(((WalRecordCacheGroupAware)rec).groupId());
+        });
+
+        assertEquals(new Integer(100), foundCounters.first());
+        assertEquals(new Integer(recordsCnt - 1), foundCounters.last());
+        assertEquals(recordsCnt - 100, foundCounters.size());
+    }
+
+    /**
+     * Check correct closing file descriptors.
+     *
+     */
     private String createWalFiles() throws Exception {
         IgniteEx ig = (IgniteEx)startGrid();
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/LocalPendingTransactionsTrackerTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/LocalPendingTransactionsTrackerTest.java
new file mode 100644
index 0000000..39ed106
--- /dev/null
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/transactions/LocalPendingTransactionsTrackerTest.java
@@ -0,0 +1,853 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.ignite.internal.processors.cache.transactions;
+
+import java.io.File;
+import java.nio.ByteBuffer;
+import java.util.Collections;
+import java.util.Set;
+import java.util.concurrent.CountDownLatch;
+import java.util.concurrent.ScheduledExecutorService;
+import java.util.concurrent.ScheduledThreadPoolExecutor;
+import java.util.concurrent.ThreadLocalRandom;
+import java.util.concurrent.TimeUnit;
+import java.util.concurrent.atomic.AtomicInteger;
+import org.apache.ignite.IgniteCheckedException;
+import org.apache.ignite.IgniteSystemProperties;
+import org.apache.ignite.internal.IgniteInternalFuture;
+import org.apache.ignite.internal.processors.cache.GridCacheSharedContext;
+import org.apache.ignite.internal.processors.cache.KeyCacheObjectImpl;
+import org.apache.ignite.internal.processors.cache.version.GridCacheVersion;
+import org.apache.ignite.internal.processors.timeout.GridTimeoutObject;
+import org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor;
+import org.apache.ignite.internal.util.GridDebug;
+import org.apache.ignite.internal.util.typedef.internal.U;
+import org.apache.ignite.testframework.GridTestUtils;
+import org.apache.ignite.testframework.junits.logger.GridTestLog4jLogger;
+import org.junit.AfterClass;
+import org.junit.Before;
+import org.junit.BeforeClass;
+import org.junit.Test;
+import org.mockito.Mockito;
+
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.assertTrue;
+import static org.junit.Assert.fail;
+
+/**
+ * Unit test for {@link LocalPendingTransactionsTracker}
+ */
+public class LocalPendingTransactionsTrackerTest {
+    /** Timeout executor. */
+    private static ScheduledExecutorService timeoutExecutor;
+
+    /** Tracker. */
+    private LocalPendingTransactionsTracker tracker;
+
+    /**
+     *
+     */
+    @BeforeClass
+    public static void setUpClass() {
+        timeoutExecutor = new ScheduledThreadPoolExecutor(1);
+
+        U.onGridStart();
+
+        System.setProperty(IgniteSystemProperties.IGNITE_PENDING_TX_TRACKER_ENABLED, "true");
+    }
+
+    /**
+     *
+     */
+    @AfterClass
+    public static void tearDownClass() {
+        timeoutExecutor.shutdown();
+
+        System.clearProperty(IgniteSystemProperties.IGNITE_PENDING_TX_TRACKER_ENABLED);
+    }
+
+    /**
+     *
+     */
+    @Before
+    public void setUp() {
+        GridTimeoutProcessor time = Mockito.mock(GridTimeoutProcessor.class);
+        Mockito.when(time.addTimeoutObject(Mockito.any())).thenAnswer(mock -> {
+            GridTimeoutObject timeoutObj = (GridTimeoutObject)mock.getArguments()[0];
+
+            long endTime = timeoutObj.endTime();
+
+            timeoutExecutor.schedule(timeoutObj::onTimeout, endTime - U.currentTimeMillis(), TimeUnit.MILLISECONDS);
+
+            return null;
+        });
+
+        GridCacheSharedContext<?, ?> cctx = Mockito.mock(GridCacheSharedContext.class);
+        Mockito.when(cctx.time()).thenReturn(time);
+        Mockito.when(cctx.logger(LocalPendingTransactionsTracker.class)).thenReturn(new GridTestLog4jLogger());
+
+        tracker = new LocalPendingTransactionsTracker(cctx);
+    }
+
+    /**
+     *
+     */
+    @Test
+    public void testCurrentlyPreparedTxs() {
+        txPrepare(1);
+        txKeyWrite(1, 10);
+        txKeyWrite(1, 11);
+
+        txPrepare(2);
+        txKeyWrite(2, 20);
+        txKeyWrite(2, 21);
+        txKeyWrite(2, 22);
+
+        txPrepare(3);
+        txKeyWrite(3, 30);
+
+        txCommit(2);
+
+        tracker.writeLockState();
+
+        try {
+            Set<GridCacheVersion> currentlyPreparedTxs = tracker.currentlyPreparedTxs();
+
+            assertEquals(2, currentlyPreparedTxs.size());
+            assertTrue(currentlyPreparedTxs.contains(nearXidVersion(1)));
+            assertTrue(currentlyPreparedTxs.contains(nearXidVersion(3)));
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+
+        txKeyWrite(3, 31);
+        txCommit(3);
+
+        tracker.writeLockState();
+
+        try {
+            Set<GridCacheVersion> currentlyPreparedTxs = tracker.currentlyPreparedTxs();
+
+            assertEquals(1, currentlyPreparedTxs.size());
+            assertTrue(currentlyPreparedTxs.contains(nearXidVersion(1)));
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+    }
+
+    /**
+     *
+     */
+    @Test
+    public void testMultiplePrepareCommitMarkers() {
+        txPrepare(1);
+        txKeyWrite(1, 10);
+
+        txPrepare(2);
+        txKeyWrite(2, 20);
+        txPrepare(2);
+        txKeyWrite(2, 21);
+        txPrepare(2);
+        txKeyWrite(2, 22);
+
+        txPrepare(3);
+        txKeyWrite(3, 30);
+        txPrepare(3);
+        txKeyWrite(3, 31);
+
+        txCommit(3);
+        txCommit(3);
+
+        txCommit(1);
+
+        txCommit(2);
+        txCommit(2);
+
+        tracker.writeLockState();
+
+        try {
+            Set<GridCacheVersion> currentlyPreparedTxs = tracker.currentlyPreparedTxs();
+
+            assertEquals(1, currentlyPreparedTxs.size());
+            assertTrue(currentlyPreparedTxs.contains(nearXidVersion(2)));
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+    }
+
+    /**
+     *
+     */
+    @Test
+    public void testCommitsMoreThanPreparesForbidden() {
+        txPrepare(1);
+
+        txKeyWrite(1, 10);
+        txKeyWrite(1, 11);
+
+        txCommit(1);
+
+        try {
+            txCommit(1);
+
+            fail("We should fail if number of commits is more than number of prepares.");
+        }
+        catch (Throwable ignored) {
+            // Expected.
+        }
+    }
+
+    /**
+     *
+     */
+    @Test
+    public void testRollback() {
+        txRollback(1); // Tx can be rolled back before prepare.
+
+        txPrepare(2);
+        txKeyWrite(2, 20);
+
+        txPrepare(3);
+        txKeyWrite(3, 30);
+        txPrepare(3);
+        txKeyWrite(3, 31);
+
+        txCommit(3);
+
+        txRollback(2);
+        txRollback(3);
+
+        tracker.writeLockState();
+
+        try {
+            Set<GridCacheVersion> currentlyPreparedTxs = tracker.currentlyPreparedTxs();
+
+            assertEquals(0, currentlyPreparedTxs.size());
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Test(timeout = 10_000)
+    public void testAwaitFinishOfPreparedTxs() throws Exception {
+        txPrepare(1);
+
+        txPrepare(2);
+        txPrepare(2);
+
+        txPrepare(3);
+        txPrepare(3);
+        txCommit(3);
+
+        txPrepare(4);
+        txCommit(4);
+
+        txPrepare(5);
+        txPrepare(5);
+        txPrepare(5);
+        txCommit(5);
+
+        tracker.writeLockState();
+
+        IgniteInternalFuture<Set<GridCacheVersion>> fut;
+        try {
+            tracker.startTxFinishAwaiting(1_000, 10_000);
+
+            fut = tracker.awaitPendingTxsFinished(Collections.emptySet());
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+
+        Thread.sleep(100);
+
+        txCommit(5);
+        txCommit(2);
+        txCommit(2);
+
+        long curTs = U.currentTimeMillis();
+
+        Set<GridCacheVersion> pendingTxs = fut.get();
+
+        assertTrue("Waiting for awaitFinishOfPreparedTxs future too long", U.currentTimeMillis() - curTs < 1_000);
+
+        assertEquals(3, pendingTxs.size());
+        assertTrue(pendingTxs.contains(nearXidVersion(1)));
+        assertTrue(pendingTxs.contains(nearXidVersion(3)));
+        assertTrue(pendingTxs.contains(nearXidVersion(5)));
+
+        txCommit(1);
+        txCommit(3);
+        txCommit(5);
+
+        tracker.writeLockState();
+
+        try {
+            tracker.startTxFinishAwaiting(1_000, 10_000);
+
+            fut = tracker.awaitPendingTxsFinished(Collections.emptySet());
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+
+        assertTrue(fut.get().isEmpty());
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Test(timeout = 10_000)
+    public void testAwaitFinishOfPreparedTxsTimeouts() throws Exception {
+        txPrepare(1);
+        txCommit(1);
+
+        txPrepare(2);
+        txKeyRead(2, 10);
+
+        txPrepare(3);
+        txKeyWrite(3, 11);
+
+        txPrepare(4);
+
+        long curTs, waitMs;
+
+        Set<GridCacheVersion> pendingTxs;
+
+        final CountDownLatch latch1 = new CountDownLatch(1);
+        final CountDownLatch latch2 = new CountDownLatch(1);
+        final CountDownLatch latch3 = new CountDownLatch(1);
+        final CountDownLatch latch4 = new CountDownLatch(1);
+
+        new Thread(() -> {
+            try {
+                latch1.countDown();
+
+                latch2.await();
+
+                txCommit(2);
+
+                latch3.await();
+
+                Thread.sleep(200);
+                txCommit(3);
+
+                latch4.await();
+
+                Thread.sleep(200);
+                txCommit(4);
+            }
+            catch (InterruptedException ignored) {
+                // No-op
+            }
+        }).start();
+
+        latch1.await();
+
+        pendingTxs = awaitFinishOfPreparedTxs(100, 200);
+
+        assertEquals(3, pendingTxs.size());
+        assertTrue(pendingTxs.contains(nearXidVersion(2)));
+        assertTrue(pendingTxs.contains(nearXidVersion(3)));
+        assertTrue(pendingTxs.contains(nearXidVersion(4)));
+
+        latch2.countDown();
+
+        curTs = U.currentTimeMillis();
+
+        pendingTxs = awaitFinishOfPreparedTxs(100, 200);
+
+        waitMs = U.currentTimeMillis() - curTs;
+
+        assertTrue("Waiting for awaitFinishOfPreparedTxs future too short: " + waitMs, waitMs > 200 - 50);
+        assertTrue("Waiting for awaitFinishOfPreparedTxs future too long: " + waitMs, waitMs < 200 + 500);
+
+        assertEquals(2, pendingTxs.size());
+        assertTrue(pendingTxs.contains(nearXidVersion(3)));
+        assertTrue(pendingTxs.contains(nearXidVersion(4)));
+
+        latch3.countDown();
+
+        curTs = U.currentTimeMillis();
+
+        pendingTxs = awaitFinishOfPreparedTxs(100, 300);
+
+        waitMs = U.currentTimeMillis() - curTs;
+
+        assertTrue("Waiting for awaitFinishOfPreparedTxs future too short: " + waitMs, waitMs > 200 - 50);
+        assertTrue("Waiting for awaitFinishOfPreparedTxs future too long: " + waitMs, waitMs < 200 + 500);
+
+        assertEquals(1, pendingTxs.size());
+        assertTrue(pendingTxs.contains(nearXidVersion(4)));
+
+        latch4.countDown();
+
+        curTs = U.currentTimeMillis();
+
+        pendingTxs = awaitFinishOfPreparedTxs(300, 500);
+
+        waitMs = U.currentTimeMillis() - curTs;
+
+        assertTrue("Waiting for awaitFinishOfPreparedTxs future too short: " + waitMs, waitMs > 200 - 50);
+        assertTrue("Waiting for awaitFinishOfPreparedTxs future too long: " + waitMs, waitMs < 200 + 500);
+
+        assertTrue(pendingTxs.isEmpty());
+    }
+
+    /**
+     *
+     */
+    @Test
+    public void trackingCommittedTest() {
+        txPrepare(1);
+        txCommit(1);
+
+        txPrepare(2);
+
+        tracker.writeLockState();
+        try {
+            tracker.startTrackingCommitted();
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+
+        txCommit(2);
+
+        txPrepare(3);
+        txCommit(3);
+
+        txPrepare(4);
+
+        tracker.writeLockState();
+
+        Set<GridCacheVersion> committedTxs;
+        try {
+            committedTxs = tracker.stopTrackingCommitted().committedTxs();
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+
+        assertEquals(2, committedTxs.size());
+        assertTrue(committedTxs.contains(nearXidVersion(2)));
+        assertTrue(committedTxs.contains(nearXidVersion(3)));
+    }
+
+    /**
+     *
+     */
+    @Test
+    public void trackingPreparedTest() {
+        txPrepare(1);
+        txCommit(1);
+
+        txPrepare(2);
+
+        tracker.writeLockState();
+        try {
+            tracker.startTrackingPrepared();
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+
+        txCommit(2);
+
+        txPrepare(3);
+        txCommit(3);
+
+        txPrepare(4);
+
+        tracker.writeLockState();
+
+        Set<GridCacheVersion> committedTxs;
+        try {
+            committedTxs = tracker.stopTrackingPrepared();
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+
+        assertEquals(2, committedTxs.size());
+        assertTrue(committedTxs.contains(nearXidVersion(3)));
+        assertTrue(committedTxs.contains(nearXidVersion(4)));
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Test(timeout = 10_000)
+    public void testConsistentCutUseCase() throws Exception {
+        txPrepare(1);
+        txPrepare(2);
+        txPrepare(3);
+
+        txCommit(3);
+
+        tracker.writeLockState(); // Cut 1.
+
+        IgniteInternalFuture<Set<GridCacheVersion>> awaitFutCut1;
+        try {
+            tracker.startTrackingCommitted();
+
+            tracker.startTxFinishAwaiting(1_000, 10_000);
+
+            awaitFutCut1 = tracker.awaitPendingTxsFinished(Collections.emptySet());
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+
+        txCommit(1);
+
+        Set<GridCacheVersion> failedToFinish = awaitFutCut1.get();
+
+        assertEquals(1, failedToFinish.size());
+        assertTrue(failedToFinish.contains(nearXidVersion(2)));
+
+        txCommit(2);
+
+        txPrepare(4);
+        txCommit(4);
+
+        txPrepare(5);
+
+        txPrepare(6);
+
+        tracker.writeLockState(); // Cut 2.
+
+        Set<GridCacheVersion> committedFrom1to2;
+        Set<GridCacheVersion> preparedOn2;
+        try {
+            committedFrom1to2 = tracker.stopTrackingCommitted().committedTxs();
+
+            preparedOn2 = tracker.currentlyPreparedTxs();
+
+            tracker.startTrackingPrepared();
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+
+        assertEquals(2, preparedOn2.size());
+        assertTrue(preparedOn2.contains(nearXidVersion(5)));
+        assertTrue(preparedOn2.contains(nearXidVersion(6)));
+
+        assertEquals(3, committedFrom1to2.size());
+        assertTrue(committedFrom1to2.contains(nearXidVersion(1)));
+        assertTrue(committedFrom1to2.contains(nearXidVersion(2)));
+        assertTrue(committedFrom1to2.contains(nearXidVersion(4)));
+
+        txPrepare(7);
+        txPrepare(8);
+
+        txCommit(6);
+        txCommit(7);
+
+        tracker.writeLockState(); // Cut 3.
+        Set<GridCacheVersion> preparedFrom2to3;
+        try {
+            preparedFrom2to3 = tracker.stopTrackingPrepared();
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+
+        assertEquals(2, preparedFrom2to3.size());
+        assertTrue(preparedFrom2to3.contains(nearXidVersion(7)));
+        assertTrue(preparedFrom2to3.contains(nearXidVersion(8)));
+    }
+
+    /**
+     *
+     */
+    @Test
+    public void testDependentTransactions() {
+        tracker.writeLockState();
+        try {
+            tracker.startTrackingCommitted();
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+
+        txPrepare(1);
+        txKeyRead(1, 0);
+        txKeyWrite(1, 10);
+        txKeyRead(1, 20);
+        txCommit(1);
+
+        txPrepare(2);
+        txKeyWrite(2, 30);
+        txKeyWrite(2, 40);
+        txCommit(2);
+
+        txPrepare(3);
+        txKeyRead(3, 10); // (w -> r) is a dependency
+        txCommit(3);
+
+        txPrepare(4);
+        txKeyWrite(4, 20); // (r -> w) is not a dependency
+        txCommit(4);
+
+        txPrepare(5);
+        txKeyRead(5, 30); // (w -> r) is a dependency
+        txCommit(5);
+
+        txPrepare(6);
+        txKeyWrite(6, 40); // (w -> w) is a dependency
+        txCommit(6);
+
+        txPrepare(7);
+        txKeyRead(7, 0); // (r -> r) is not a dependency
+        txCommit(7);
+
+        tracker.writeLockState();
+
+        TrackCommittedResult res;
+        try {
+            res = tracker.stopTrackingCommitted();
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+
+        assertEquals(7, res.committedTxs().size());
+        assertEquals(2, res.dependentTxsGraph().size());
+
+        assertTrue(res.dependentTxsGraph().containsKey(nearXidVersion(1)));
+        assertTrue(res.dependentTxsGraph().containsKey(nearXidVersion(2)));
+
+        Set<GridCacheVersion> dependentFrom1 = res.dependentTxsGraph().get(nearXidVersion(1));
+        assertEquals(1, dependentFrom1.size());
+        assertTrue(dependentFrom1.contains(nearXidVersion(3)));
+
+        Set<GridCacheVersion> dependentFrom2 = res.dependentTxsGraph().get(nearXidVersion(2));
+        assertEquals(2, dependentFrom2.size());
+        assertTrue(dependentFrom2.contains(nearXidVersion(5)));
+        assertTrue(dependentFrom2.contains(nearXidVersion(6)));
+    }
+
+    /**
+     * Transaction tracker memory leak test.
+     * @throws Exception If failed.
+     */
+    @Test
+    public void testTrackerMemoryLeak() throws Exception {
+        int allowedLeakSize = 100 * 1024;
+
+        // Warmup phase.
+        long sizeBefore = memoryFootprintForTransactionTracker(1000, 20);
+
+        // Main phase.
+        long sizeAfter = memoryFootprintForTransactionTracker(5000, 20);
+
+        assertTrue("Possible memory leak detected. Memory consumed before transaction tracking: " + sizeBefore +
+            ", memory consumed after transaction tracking: " + sizeAfter, sizeAfter - sizeBefore < allowedLeakSize);
+    }
+
+    /**
+     * @param iterationsCnt Iterations count.
+     * @param threadsCnt Threads count.
+     * @return Length of dump file.
+     * @throws Exception If failed.
+     */
+    private long memoryFootprintForTransactionTracker(int iterationsCnt, int threadsCnt) throws Exception {
+        AtomicInteger txCnt = new AtomicInteger();
+
+        AtomicInteger trackerState = new AtomicInteger();
+
+        File dumpFile = new File(U.defaultWorkDirectory(), "test.hprof");
+
+        String heapDumpFileName = dumpFile.getAbsolutePath();
+
+        Runnable txRunnable = new Runnable() {
+            @Override public void run() {
+                ThreadLocalRandom rnd = ThreadLocalRandom.current();
+
+                for (int iteration = 0; iteration < iterationsCnt; iteration++) {
+                    int txId = txCnt.incrementAndGet();
+
+                    txPrepare(txId);
+
+                    int opCnt = rnd.nextInt(100);
+
+                    for (int i = 0; i < opCnt; i++) {
+                        if (rnd.nextBoolean())
+                            txKeyRead(txId, rnd.nextInt());
+                        else
+                            txKeyWrite(txId, rnd.nextInt());
+                    }
+
+                    if (rnd.nextInt(10) == 0)
+                        txRollback(txId);
+                    else
+                        txCommit(txId);
+
+                    // Change tracker state
+                    if (rnd.nextInt(20) == 0) {
+                        tracker.writeLockState();
+
+                        try {
+                            int state = trackerState.getAndIncrement();
+
+                            switch (state % 4) {
+                                case 0:
+                                    tracker.startTrackingPrepared();
+
+                                    break;
+                                case 1:
+                                    tracker.stopTrackingPrepared();
+
+                                    break;
+                                case 2:
+                                    tracker.startTrackingCommitted();
+
+                                    break;
+                                case 3:
+                                    tracker.stopTrackingCommitted();
+                            }
+                        }
+                        finally {
+                            tracker.writeUnlockState();
+                        }
+                    }
+                }
+            }
+        };
+
+        GridTestUtils.runMultiThreaded(txRunnable, threadsCnt, "tx-runner");
+
+        tracker.writeLockState();
+
+        try {
+            int state = trackerState.get();
+
+            switch (state % 4) {
+                case 0:
+                    break;
+                case 1:
+                    tracker.stopTrackingPrepared();
+                    tracker.startTrackingCommitted();
+                    tracker.stopTrackingCommitted();
+
+                    break;
+                case 2:
+                    tracker.startTrackingCommitted();
+                    tracker.stopTrackingCommitted();
+
+                    break;
+                case 3:
+                    tracker.stopTrackingCommitted();
+            }
+
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+
+        GridDebug.dumpHeap(heapDumpFileName, true);
+
+        long fileSize = dumpFile.length();
+
+        dumpFile.delete();
+
+        return fileSize;
+    }
+
+    /**
+     * @param txId Test transaction ID.
+     */
+    private void txPrepare(int txId) {
+        tracker.onTxPrepared(nearXidVersion(txId));
+    }
+
+    /**
+     * @param txId Test transaction ID.
+     */
+    private void txCommit(int txId) {
+        tracker.onTxCommitted(nearXidVersion(txId));
+    }
+
+    /**
+     * @param txId Test transaction ID.
+     */
+    private void txRollback(int txId) {
+        tracker.onTxRolledBack(nearXidVersion(txId));
+    }
+
+    /**
+     * @param txId Test transaction ID.
+     * @param key Key.
+     */
+    private void txKeyWrite(int txId, int key) {
+        KeyCacheObjectImpl keyCacheObj = new KeyCacheObjectImpl(key, ByteBuffer.allocate(4).putInt(key).array(), 1);
+
+        tracker.onKeysWritten(nearXidVersion(txId), Collections.singletonList(keyCacheObj));
+    }
+
+    /**
+     * @param txId Test transaction ID.
+     * @param key Key.
+     */
+    private void txKeyRead(int txId, int key) {
+        KeyCacheObjectImpl keyCacheObj = new KeyCacheObjectImpl(key, ByteBuffer.allocate(4).putInt(key).array(), 1);
+
+        tracker.onKeysRead(nearXidVersion(txId), Collections.singletonList(keyCacheObj));
+    }
+
+    /**
+     * @param txId Test transaction ID.
+     * @return Version of transaction for the given {@code txId}.
+     */
+    private GridCacheVersion nearXidVersion(int txId) {
+        return new GridCacheVersion(0, txId, 0);
+    }
+
+    /**
+     * @param preparedTxsTimeout Prepared transactions timeout.
+     * @param committingTxsTimeout Committing transactions timeout.
+     * @return Collection of local transactions in committing state.
+     * @throws IgniteCheckedException If failed.
+     */
+    private Set<GridCacheVersion> awaitFinishOfPreparedTxs(
+        long preparedTxsTimeout,
+        long committingTxsTimeout
+    ) throws IgniteCheckedException {
+        IgniteInternalFuture<Set<GridCacheVersion>> fut;
+
+        tracker.writeLockState();
+
+        try {
+            tracker.startTxFinishAwaiting(preparedTxsTimeout, committingTxsTimeout);
+
+            fut = tracker.awaitPendingTxsFinished(Collections.emptySet());
+        }
+        finally {
+            tracker.writeUnlockState();
+        }
+
+        return fut.get();
+    }
+}
diff --git a/modules/core/src/test/java/org/apache/ignite/lang/utils/GridCircularBufferSelfTest.java b/modules/core/src/test/java/org/apache/ignite/lang/utils/GridCircularBufferSelfTest.java
index fc995a8..90dfd98 100644
--- a/modules/core/src/test/java/org/apache/ignite/lang/utils/GridCircularBufferSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/lang/utils/GridCircularBufferSelfTest.java
@@ -17,9 +17,13 @@
 package org.apache.ignite.lang.utils;
 
 import java.util.Deque;
+import java.util.Iterator;
 import java.util.concurrent.Callable;
 import java.util.concurrent.ConcurrentLinkedDeque;
 import java.util.concurrent.atomic.AtomicInteger;
+import java.util.function.IntConsumer;
+import java.util.stream.IntStream;
+import org.apache.ignite.IgniteInterruptedException;
 import org.apache.ignite.internal.util.GridCircularBuffer;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
 import org.junit.Test;
@@ -177,4 +181,79 @@ public class GridCircularBufferSelfTest extends GridCommonAbstractTest {
 
         info("Buffer: " + buf);
     }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Test
+    public void testEmptyBufIterator() throws Exception {
+        assertFalse(new GridCircularBuffer<>(8).iterator().hasNext());
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Test
+    public void testHalfFullBufIterator() throws Exception {
+        int size = 8;
+
+        GridCircularBuffer<Integer> buf = new GridCircularBuffer<>(size);
+
+        IntStream.range(0, size / 2).forEach(makeConsumer(buf));
+
+        checkExpectedRange(0, size / 2, buf);
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Test
+    public void testFullBufIterator() throws Exception {
+        int size = 8;
+
+        GridCircularBuffer<Integer> buf = new GridCircularBuffer<>(size);
+
+        IntStream.range(0, size).forEach(makeConsumer(buf));
+
+        checkExpectedRange(0, size, buf);
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    @Test
+    public void testOverflownBufIterator() throws Exception {
+        int size = 8;
+
+        GridCircularBuffer<Integer> buf = new GridCircularBuffer<>(size);
+
+        IntStream.range(0, 3 * size / 2).forEach(makeConsumer(buf));
+
+        checkExpectedRange(size / 2, 3 * size / 2, buf);
+    }
+
+    /**
+     *
+     */
+    private static IntConsumer makeConsumer(GridCircularBuffer<Integer> buf) {
+        return t -> {
+            try {
+                buf.add(t);
+            }
+            catch (InterruptedException e) {
+                throw new IgniteInterruptedException(e);
+            }
+        };
+    }
+
+    /**
+     *
+     */
+    private void checkExpectedRange(int beginInclusive, int endExclusive, GridCircularBuffer<Integer> buf) {
+        Iterator<Integer> iter = buf.iterator();
+
+        IntStream.range(beginInclusive, endExclusive).forEach(i -> assertEquals(i, iter.next().intValue()));
+
+        assertFalse(iter.hasNext());
+    }
 }
diff --git a/modules/core/src/test/java/org/apache/ignite/testframework/junits/common/GridCommonAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/testframework/junits/common/GridCommonAbstractTest.java
index 7797f23..f45df11 100755
--- a/modules/core/src/test/java/org/apache/ignite/testframework/junits/common/GridCommonAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/testframework/junits/common/GridCommonAbstractTest.java
@@ -32,6 +32,7 @@ import java.util.concurrent.CountDownLatch;
 import java.util.concurrent.TimeUnit;
 import java.util.concurrent.atomic.AtomicInteger;
 import java.util.concurrent.atomic.AtomicReference;
+import java.util.stream.Collectors;
 import javax.cache.Cache;
 import javax.cache.CacheException;
 import javax.cache.integration.CompletionListener;
@@ -590,6 +591,21 @@ public abstract class GridCommonAbstractTest extends GridAbstractTest {
         Ignite crd = null;
 
         for (Ignite g : G.allGrids()) {
+            if (nodes != null) {
+                Set<UUID> gClusterNodeIds = g.cluster().nodes().stream()
+                    .map(ClusterNode::id)
+                    .collect(Collectors.toSet());
+
+                Set<UUID> awaitPmeNodeIds = nodes.stream()
+                    .map(ClusterNode::id)
+                    .collect(Collectors.toSet());
+
+                gClusterNodeIds.retainAll(awaitPmeNodeIds);
+
+                if (gClusterNodeIds.isEmpty())
+                    continue; // Node g is from another cluster and can't be elected as coordinator.
+            }
+
             ClusterNode node = g.cluster().localNode();
 
             if (crd == null || node.order() < crd.cluster().localNode().order()) {
diff --git a/modules/core/src/test/java/org/apache/ignite/util/GridCommandHandlerTest.java b/modules/core/src/test/java/org/apache/ignite/util/GridCommandHandlerTest.java
index 490f7f5..f62d110 100644
--- a/modules/core/src/test/java/org/apache/ignite/util/GridCommandHandlerTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/util/GridCommandHandlerTest.java
@@ -2747,7 +2747,7 @@ public class GridCommandHandlerTest extends GridCommonAbstractTest {
             db.checkpointReadLock();
 
             try {
-                U.invoke(GridCacheDatabaseSharedManager.class, db, "applyUpdate", ctx, dataEntry);
+                U.invoke(GridCacheDatabaseSharedManager.class, db, "applyUpdate", ctx, dataEntry, false);
             }
             finally {
                 db.checkpointReadUnlock();
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/ClusterReadOnlyModeSqlTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/ClusterReadOnlyModeSqlTest.java
index 6fdb03a..c0ec2a6 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/ClusterReadOnlyModeSqlTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/ClusterReadOnlyModeSqlTest.java
@@ -59,7 +59,7 @@ public class ClusterReadOnlyModeSqlTest extends ClusterReadOnlyModeAbstractTest
                     cur.getAll();
                 }
 
-                boolean failed = false;
+                Throwable failed = null;
 
                 try (FieldsQueryCursor<?> cur = cache.query(new SqlFieldsQuery("DELETE FROM Integer"))) {
                     cur.getAll();
@@ -68,13 +68,15 @@ public class ClusterReadOnlyModeSqlTest extends ClusterReadOnlyModeAbstractTest
                     if (!readOnly)
                         log.error("Failed to delete data", ex);
 
-                    failed = true;
+                    failed = ex;
                 }
 
-                if (failed != readOnly)
+                if ((failed == null) == readOnly)
                     fail("SQL delete from " + cacheName + " must " + (readOnly ? "fail" : "succeed"));
 
-                failed = false;
+                checkThatRootCauseIsReadOnly(failed);
+
+                failed = null;
 
                 try (FieldsQueryCursor<?> cur = cache.query(new SqlFieldsQuery(
                     "INSERT INTO Integer(_KEY, _VAL) VALUES (?, ?)").setArgs(rnd.nextInt(1000), rnd.nextInt()))) {
@@ -84,11 +86,13 @@ public class ClusterReadOnlyModeSqlTest extends ClusterReadOnlyModeAbstractTest
                     if (!readOnly)
                         log.error("Failed to insert data", ex);
 
-                    failed = true;
+                    failed = ex;
                 }
 
-                if (failed != readOnly)
+                if ((failed == null) == readOnly)
                     fail("SQL insert into " + cacheName + " must " + (readOnly ? "fail" : "succeed"));
+
+                checkThatRootCauseIsReadOnly(failed);
             }
         }
     }
diff --git a/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/ZookeeperDiscoverySpi.java b/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/ZookeeperDiscoverySpi.java
index 5651060..579eace 100644
--- a/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/ZookeeperDiscoverySpi.java
+++ b/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/ZookeeperDiscoverySpi.java
@@ -410,6 +410,17 @@ public class ZookeeperDiscoverySpi extends IgniteSpiAdapter implements IgniteDis
         return impl.gridStartTime();
     }
 
+
+    /**
+     * Sets grid start time.
+     *
+     * @param val New time value.
+     */
+    @SuppressWarnings("unused")
+    public void setGridStartTime(long val) {
+        impl.setGridStartTime(val);
+    }
+
     /** {@inheritDoc} */
     @Override public void sendCustomEvent(DiscoverySpiCustomMessage msg) {
         IgniteDiscoverySpiInternalListener internalLsnr = impl.internalLsnr;
diff --git a/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/internal/ZkRuntimeState.java b/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/internal/ZkRuntimeState.java
index 92c9658..f894a75 100644
--- a/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/internal/ZkRuntimeState.java
+++ b/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/internal/ZkRuntimeState.java
@@ -47,7 +47,7 @@ class ZkRuntimeState {
     int joinDataPartCnt;
 
     /** */
-    long gridStartTime;
+    volatile long gridStartTime;
 
     /** */
     volatile boolean joined;
diff --git a/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/internal/ZookeeperDiscoveryImpl.java b/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/internal/ZookeeperDiscoveryImpl.java
index c00c637..95fadb7 100644
--- a/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/internal/ZookeeperDiscoveryImpl.java
+++ b/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/internal/ZookeeperDiscoveryImpl.java
@@ -705,6 +705,15 @@ public class ZookeeperDiscoveryImpl {
     }
 
     /**
+     * Sets grid start time.
+     *
+     * @param val New time value.
+     */
+    public void setGridStartTime(long val) {
+        rtState.gridStartTime = val;
+    }
+
+    /**
      * Starts join procedure and waits for {@link EventType#EVT_NODE_JOINED} event for local node.
      *
      * @throws InterruptedException If interrupted.
diff --git a/modules/zookeeper/src/test/java/org/apache/ignite/spi/discovery/zk/ZookeeperDiscoverySpiTestUtil.java b/modules/zookeeper/src/test/java/org/apache/ignite/spi/discovery/zk/ZookeeperDiscoverySpiTestUtil.java
index 9913f61..36b04d9a 100644
--- a/modules/zookeeper/src/test/java/org/apache/ignite/spi/discovery/zk/ZookeeperDiscoverySpiTestUtil.java
+++ b/modules/zookeeper/src/test/java/org/apache/ignite/spi/discovery/zk/ZookeeperDiscoverySpiTestUtil.java
@@ -32,6 +32,15 @@ public class ZookeeperDiscoverySpiTestUtil {
      * @return Test cluster.
      */
     public static TestingCluster createTestingCluster(int instances) {
+        return createTestingCluster(instances, 0);
+    }
+
+    /**
+     * @param instances Number of instances in.
+     * @param firstInstanceIdx First instance index.
+     * @return Test cluster.
+     */
+    public static TestingCluster createTestingCluster(int instances, int firstInstanceIdx) {
         String tmpDir;
 
         tmpDir = System.getenv("TMPFS_ROOT") != null
@@ -39,7 +48,7 @@ public class ZookeeperDiscoverySpiTestUtil {
 
         List<InstanceSpec> specs = new ArrayList<>();
 
-        for (int i = 0; i < instances; i++) {
+        for (int i = firstInstanceIdx, n = firstInstanceIdx + instances; i < n; i++) {
             File file = new File(tmpDir, "apacheIgniteTestZk-" + i);
 
             if (file.isDirectory())
diff --git a/parent/pom.xml b/parent/pom.xml
index 3546ebe..8564221 100644
--- a/parent/pom.xml
+++ b/parent/pom.xml
@@ -490,7 +490,7 @@
                                 <packages>org.apache.ignite.springdata20.repository*</packages>
                             </group>
                             <group>
-                            <title>RocketMQ integration</title>
+                                <title>RocketMQ integration</title>
                                 <packages>org.apache.ignite.stream.rocketmq*</packages>
                             </group>
                             <group>


[ignite] 03/17: Additional Readme

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit bb2905dd86113d2b79c8293f4fa62571db9c941e
Author: mstepachev <ma...@gmail.com>
AuthorDate: Tue Apr 16 19:38:51 2019 +0300

    Additional Readme
---
 .../src/main/java/org/apache/ignite/internal/README.md     | 14 +++++++-------
 .../java/org/apache/ignite/internal/processors/README.md   |  6 +++---
 .../org/apache/ignite/internal/processors/cache/README.md  |  6 +++---
 .../ignite/internal/processors/cache/persistence/README.md |  4 ++--
 .../processors/cache/persistence/pagemem/README.md         |  4 ++--
 modules/dev-utils/ignite-modules-test/README.md            |  8 ++++----
 modules/direct-io/README.md                                | 10 +++++-----
 7 files changed, 26 insertions(+), 26 deletions(-)

diff --git a/modules/core/src/main/java/org/apache/ignite/internal/README.md b/modules/core/src/main/java/org/apache/ignite/internal/README.md
index 0ed8639..380e498 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/README.md
+++ b/modules/core/src/main/java/org/apache/ignite/internal/README.md
@@ -1,19 +1,19 @@
-Apache Ignite Internals
+GridGain Internals
 -----------------------
 
-Contains implementation classes for Apache Ignite.
+Contains implementation classes for GridGain.
 
-### Ignite Components
+### GridGain Components
 
-All internal Ignite components implements [GridComponent.java](GridComponent.java) - interface for
+All internal GridGain components implements [GridComponent.java](GridComponent.java) - interface for
 - [processors](processors) and for
 - [managers](managers) - has associated SPI.
 
-Service Provider Interface (SPI) abbreviation is here because Apache Ignite was designed as a pluggable product. But Ignite users usually do not define own implementations.
+Service Provider Interface (SPI) abbreviation is here because GridGain was designed as a pluggable product. But GridGain users usually do not define own implementations.
 
 ### Contexts
-Ignite manages its components using Context used to access components and binding theirs to each other.
-Component-related context in the Apache Ignite is an implementation of [GridKernalContext.java](GridKernalContext.java).
+GridGain manages its components using Context used to access components and binding theirs to each other.
+Component-related context in the GridGain is an implementation of [GridKernalContext.java](GridKernalContext.java).
 This context instance is usually referred in code as `kctx` or `ctx`.
 
 Higher-level context, cache shared context is also defined in [processors/cache](processors/cache)
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/README.md b/modules/core/src/main/java/org/apache/ignite/internal/processors/README.md
index 05a1feb..2ecf367 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/README.md
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/README.md
@@ -1,9 +1,9 @@
-Apache Ignite Processors
+GridGain Processors
 ------------------------
 
-A processor is Apache Ignite component with the lifecycle. This lifecycle is associated with Ignite Node lifecycle.
+A processor is GridGain component with the lifecycle. This lifecycle is associated with GridGain Node lifecycle.
 
-Despite Managers, Ignite processors are not associated with an SPI.
+Despite Managers, GridGain processors are not associated with an SPI.
 
 Cache Processors and Implementation
 -----------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/README.md b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/README.md
index 19c5d70..33b0ca8 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/README.md
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/README.md
@@ -1,11 +1,11 @@
-Apache Ignite Cache Processors
+GridGain Cache Processors
 ------------------------------
 ### Context
 [GridCacheSharedContext.java](GridCacheSharedContext.java) is a class which is used for binding cache-related managers.
 This context is shared by all caches defined. This context instance is usually referred in code as `sctx`, `cctx` or `ctx`.
 
 ### Native Persistence
-Apache Ignite has its own [Native Persistence](persistence) - Implementation
+GridGain has its own [Native Persistence](persistence) - Implementation
 
-### Ignite Cache Entries
+### GridGain Cache Entries
 Each entry represended by a subclass [GridCacheMapEntry](GridCacheMapEntry.java)
\ No newline at end of file
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/README.md b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/README.md
index 372a108..8a7eed2 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/README.md
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/README.md
@@ -1,6 +1,6 @@
-Apache Ignite Persistence
+GridGain Persistence
 -------------------------
-See Native Persistence introduction in [Ignite Persistent Store - under the hood](https://cwiki.apache.org/confluence/display/IGNITE/Ignite+Persistent+Store+-+under+the+hood)
+See Native Persistence introduction in [GridGain Persistent Store - under the hood](https://cwiki.apache.org/confluence/display/IGNITE/GridGain+Persistent+Store+-+under+the+hood)
 
 Contents
 --------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/README.md b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/README.md
index 0244d45..e23d772 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/README.md
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/README.md
@@ -1,4 +1,4 @@
-Apache Ignite Native Peristence Page Memory
+GridGain Native Peristence Page Memory
 -------------------------------------------
 This package contains page memory implementation for case persitence is enabled.
 
@@ -21,7 +21,7 @@ Throttling is implemented at physical level of operations, so it operates not wi
 For an introduction, please see
 [wiki PagesWriteThrottling](https://cwiki.apache.org/confluence/display/IGNITE/Ignite+Persistent+Store+-+under+the+hood#IgnitePersistentStore-underthehood-PagesWriteThrottling)
 
-There are two types of throttling implemented in Apache Ignite:
+There are two types of throttling implemented in GridGain:
 * Checkpoint buffer overflow protection.
 
 This CP Buffer throttling is enabled by default. It is activated if CP buffer is close to being filled.
diff --git a/modules/dev-utils/ignite-modules-test/README.md b/modules/dev-utils/ignite-modules-test/README.md
index 3f04de4..2544cb7 100644
--- a/modules/dev-utils/ignite-modules-test/README.md
+++ b/modules/dev-utils/ignite-modules-test/README.md
@@ -1,6 +1,6 @@
-# Ignite modular environment test project
+# GridGain modular environment test project
 
-This project intended for testing Ignite artifacts separately from main project.
+This project intended for testing GridGain artifacts separately from main project.
 
 ## Local Setup
 To import project use Import from existing sources, use gradle option:
@@ -11,6 +11,6 @@ Use latest gradle distribution, because older versions may not support modules.
 
 This project is compatible only with Java 11.
 
-## Used Ignite version
-By default this project uses Ignite version of previous released Ignite, but it can be switched to snapshot version if needed.
+## Used GridGain version
+By default this project uses GridGain version of previous released GridGain, but it can be switched to snapshot version if needed.
 
diff --git a/modules/direct-io/README.md b/modules/direct-io/README.md
index ca35214..0e09916 100644
--- a/modules/direct-io/README.md
+++ b/modules/direct-io/README.md
@@ -1,7 +1,7 @@
-Apache Ignite Direct IO Module
+GridGain Direct IO Module
 ------------------------------
 
-Apache Ignite Direct IO is plugin, which provides page store with ability to write and read cache partitions
+GridGain Direct IO is plugin, which provides page store with ability to write and read cache partitions
 in O_DIRECT mode.
 
 
@@ -34,7 +34,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-direct-io</artifactId>
             <version>${ignite.version}</version>
         </dependency>
@@ -49,13 +49,13 @@ Importing Direct I/O Pluging In Gradle Project
 For gradle you can add compile dependency, where igniteVersion is actual Ignite version:
 
 ```groovy
-compile group: 'org.apache.ignite', name: 'ignite-direct-io', version: igniteVersion
+compile group: 'org.gridgain', name: 'ignite-direct-io', version: igniteVersion
 ```
 
 Additional setup is not required. Once plugin is available in classpath, it will be used for Durable Memory IO.
 
 -------------------------------------
-See more information in Apache Ignite documentation:
+See more information in GridGain documentation:
 [How to enable Direct IO](https://apacheignite.readme.io/docs/durable-memory-tuning#section-enabling-direct-i-o)
 
 and description of internal desing can be found in Wiki:


[ignite] 10/17: GG-17378: Port IGNITE-11787: Changed Affinity Awareness version to 1.4

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 9fdf9802db274902802bd2bacc6e5c52c889bcd3
Author: Igor Sapego <is...@apache.org>
AuthorDate: Tue Apr 23 15:23:38 2019 +0300

    GG-17378: Port IGNITE-11787: Changed Affinity Awareness version to 1.4
    
    (cherry picked from commit d6827886a497b87a2449ee3c1b0a378501e7a9b7)
---
 .../processors/platform/client/ClientConnectionContext.java       | 8 ++++++--
 .../internal/processors/platform/client/ClientRequestHandler.java | 4 ++--
 .../internal/processors/platform/client/ClientResponse.java       | 4 ++--
 modules/platforms/cpp/thin-client/src/impl/data_channel.cpp       | 8 ++++----
 modules/platforms/cpp/thin-client/src/impl/data_channel.h         | 4 ++--
 modules/platforms/cpp/thin-client/src/impl/message.cpp            | 2 +-
 6 files changed, 17 insertions(+), 13 deletions(-)

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 5d3171e..81e4bd8 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
@@ -45,14 +45,18 @@ public class ClientConnectionContext extends ClientListenerAbstractConnectionCon
     /** Version 1.2.0. */
     public static final ClientListenerProtocolVersion VER_1_2_0 = ClientListenerProtocolVersion.create(1, 2, 0);
 
-    /** Version 1.3.0. Added: Affinity Awareness support, IEP-23. */
+    /** Version 1.3.0. */
     public static final ClientListenerProtocolVersion VER_1_3_0 = ClientListenerProtocolVersion.create(1, 3, 0);
 
+    /** Version 1.4.0. Added: Affinity Awareness, IEP-23. */
+    public static final ClientListenerProtocolVersion VER_1_4_0 = ClientListenerProtocolVersion.create(1, 4, 0);
+
     /** Default version. */
-    public static final ClientListenerProtocolVersion DEFAULT_VER = VER_1_3_0;
+    public static final ClientListenerProtocolVersion DEFAULT_VER = VER_1_4_0;
 
     /** Supported versions. */
     private static final Collection<ClientListenerProtocolVersion> SUPPORTED_VERS = Arrays.asList(
+        VER_1_4_0,
         VER_1_3_0,
         VER_1_2_0,
         VER_1_1_0,
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/client/ClientRequestHandler.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/client/ClientRequestHandler.java
index 4af438e..4d839ad 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/client/ClientRequestHandler.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/client/ClientRequestHandler.java
@@ -24,7 +24,7 @@ import org.apache.ignite.internal.processors.odbc.ClientListenerRequestHandler;
 import org.apache.ignite.internal.processors.odbc.ClientListenerResponse;
 import org.apache.ignite.plugin.security.SecurityException;
 
-import static org.apache.ignite.internal.processors.platform.client.ClientConnectionContext.VER_1_3_0;
+import static org.apache.ignite.internal.processors.platform.client.ClientConnectionContext.VER_1_4_0;
 
 /**
  * Thin client request handler.
@@ -83,7 +83,7 @@ public class ClientRequestHandler implements ClientListenerRequestHandler {
     @Override public void writeHandshake(BinaryWriterExImpl writer) {
         writer.writeBoolean(true);
 
-        if (ver.compareTo(VER_1_3_0) >= 0) {
+        if (ver.compareTo(VER_1_4_0) >= 0) {
             writer.writeUuid(ctx.kernalContext().localNodeId());
         }
     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/client/ClientResponse.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/client/ClientResponse.java
index cef0d20..0f336b9 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/client/ClientResponse.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/client/ClientResponse.java
@@ -20,7 +20,7 @@ import org.apache.ignite.internal.binary.BinaryRawWriterEx;
 import org.apache.ignite.internal.processors.odbc.ClientListenerProtocolVersion;
 import org.apache.ignite.internal.processors.odbc.ClientListenerResponse;
 
-import static org.apache.ignite.internal.processors.platform.client.ClientConnectionContext.VER_1_3_0;
+import static org.apache.ignite.internal.processors.platform.client.ClientConnectionContext.VER_1_4_0;
 
 /**
  * Thin client response.
@@ -79,7 +79,7 @@ public class ClientResponse extends ClientListenerResponse {
 
         assert ver != null;
 
-        if (ver.compareTo(VER_1_3_0) >= 0) {
+        if (ver.compareTo(VER_1_4_0) >= 0) {
             boolean error = status() != ClientStatus.SUCCESS;
 
             short flags = ClientFlag.makeFlags(error, affinityVer.isChanged());
diff --git a/modules/platforms/cpp/thin-client/src/impl/data_channel.cpp b/modules/platforms/cpp/thin-client/src/impl/data_channel.cpp
index 7f8faac..aef57ca 100644
--- a/modules/platforms/cpp/thin-client/src/impl/data_channel.cpp
+++ b/modules/platforms/cpp/thin-client/src/impl/data_channel.cpp
@@ -30,11 +30,11 @@ namespace ignite
         namespace thin
         {
             const ProtocolVersion DataChannel::VERSION_1_2_0(1, 2, 0);
-            const ProtocolVersion DataChannel::VERSION_1_3_0(1, 3, 0);
-            const ProtocolVersion DataChannel::VERSION_DEFAULT(VERSION_1_3_0);
+            const ProtocolVersion DataChannel::VERSION_1_4_0(1, 4, 0);
+            const ProtocolVersion DataChannel::VERSION_DEFAULT(VERSION_1_4_0);
 
             DataChannel::VersionSet::value_type supportedArray[] = {
-                DataChannel::VERSION_1_3_0,
+                DataChannel::VERSION_1_4_0,
                 DataChannel::VERSION_1_2_0,
             };
 
@@ -322,7 +322,7 @@ namespace ignite
                     return false;
                 }
 
-                if (propVer >= VERSION_1_3_0)
+                if (propVer >= VERSION_1_4_0)
                 {
                     Guid nodeGuid = reader.ReadGuid();
 
diff --git a/modules/platforms/cpp/thin-client/src/impl/data_channel.h b/modules/platforms/cpp/thin-client/src/impl/data_channel.h
index 57ae1cc..8bd5f5c 100644
--- a/modules/platforms/cpp/thin-client/src/impl/data_channel.h
+++ b/modules/platforms/cpp/thin-client/src/impl/data_channel.h
@@ -59,8 +59,8 @@ namespace ignite
                 /** Version 1.2.0. */
                 static const ProtocolVersion VERSION_1_2_0;
                 
-                /** Version 1.3.0. Added: Best Effort Affinity support, IEP-23. */
-                static const ProtocolVersion VERSION_1_3_0;
+                /** Version 1.4.0. Added: Affinity Awareness support, IEP-23. */
+                static const ProtocolVersion VERSION_1_4_0;
 
                 /** Current version. */
                 static const ProtocolVersion VERSION_DEFAULT;
diff --git a/modules/platforms/cpp/thin-client/src/impl/message.cpp b/modules/platforms/cpp/thin-client/src/impl/message.cpp
index 8fe2fec..d1bf8f3 100644
--- a/modules/platforms/cpp/thin-client/src/impl/message.cpp
+++ b/modules/platforms/cpp/thin-client/src/impl/message.cpp
@@ -95,7 +95,7 @@ namespace ignite
 
             void Response::Read(binary::BinaryReaderImpl& reader, const ProtocolVersion& ver)
             {
-                if (ver >= DataChannel::VERSION_1_3_0)
+                if (ver >= DataChannel::VERSION_1_4_0)
                 {
                     flags = reader.ReadInt16();
 


[ignite] 01/17: Licensed under the GridGain Community Edition License (the "License");

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit a263e1e2b5264fc3939b153ebb56328ec3d677cb
Author: mstepachev <ma...@gmail.com>
AuthorDate: Fri Apr 19 08:15:51 2019 +0300

    Licensed under the GridGain Community Edition License (the "License");
---
 CONTRIBUTING.md                                    |  70 -------
 MIGRATION_GUIDE.txt                                |   2 -
 assembly/dependencies-apache-ignite-hadoop.xml     |  39 ++--
 assembly/dependencies-apache-ignite-lgpl.xml       |  83 +++++----
 assembly/dependencies-apache-ignite.xml            |  95 +++++-----
 assembly/dependencies-sqlline.xml                  |  29 ++-
 assembly/dependencies-visor-console.xml            |  33 ++--
 assembly/docfiles/tools.js                         |  17 +-
 assembly/release-apache-ignite-base.xml            |  29 ++-
 assembly/release-apache-ignite-hadoop.xml          |  27 ++-
 assembly/release-apache-ignite-lgpl.xml            |  27 ++-
 assembly/release-apache-ignite.xml                 |  27 ++-
 assembly/release-base.xml                          |  32 ++--
 assembly/release-scala.xml                         |  27 ++-
 assembly/release-yardstick.xml                     |  29 ++-
 assembly/test.xml                                  |  29 ++-
 bin/control.bat                                    |  18 +-
 bin/control.sh                                     |  18 +-
 bin/ignite-tf.sh                                   |  18 +-
 bin/ignite.bat                                     |  18 +-
 bin/ignite.sh                                      |  18 +-
 bin/igniterouter.bat                               |  18 +-
 bin/igniterouter.sh                                |  17 +-
 bin/ignitevisorcmd.bat                             |  18 +-
 bin/ignitevisorcmd.sh                              |  18 +-
 bin/include/build-classpath.bat                    |  18 +-
 bin/include/build-classpath.sh                     |  17 +-
 bin/include/functions.sh                           |  18 +-
 bin/include/parseargs.bat                          |  18 +-
 bin/include/parseargs.sh                           |  18 +-
 bin/include/service.sh                             |  17 +-
 bin/include/setenv.bat                             |  18 +-
 bin/include/setenv.sh                              |  18 +-
 bin/setup-hadoop.bat                               |  18 +-
 bin/setup-hadoop.sh                                |  17 +-
 config/apache-ignite-lgpl/default-config.xml       |  27 ++-
 config/apache-ignite/default-config.xml            |  27 ++-
 config/default-config.xml                          |  27 ++-
 config/example-kube.xml                            |  27 ++-
 config/hadoop/default-config.xml                   |  27 ++-
 config/ignite-log4j.xml                            |  27 ++-
 config/ignite-log4j2.xml                           |  27 ++-
 config/java.util.logging.properties                |  18 +-
 config/router/default-router.xml                   |  27 ++-
 config/visor-cmd/node_startup_by_ssh.sample.ini    |  26 +--
 config/wsl-default-config.xml                      |  27 ++-
 dev-tools/build.gradle                             |  17 +-
 dev-tools/gradle/wrapper/gradle-wrapper.properties |  18 +-
 dev-tools/gradlew                                  |  18 +-
 dev-tools/slurp.sh                                 |  17 +-
 dev-tools/src/main/groovy/jiraslurp.groovy         |  17 +-
 doap_Ignite.rdf                                    |  27 ++-
 docker/apache-ignite/Dockerfile                    |  18 +-
 docker/apache-ignite/run.sh                        |  17 +-
 docker/web-agent/Dockerfile                        |  18 +-
 docker/web-console/standalone/Dockerfile           |  18 +-
 docker/web-console/standalone/docker-entrypoint.sh |  17 +-
 docker/web-console/standalone/nginx/nginx.conf     |  18 +-
 .../web-console/standalone/nginx/web-console.conf  |  18 +-
 .../config/encryption/example-encrypted-store.xml  |  27 ++-
 examples/config/example-cache.xml                  |  27 ++-
 examples/config/example-data-regions.xml           |  27 ++-
 examples/config/example-default.xml                |  27 ++-
 examples/config/example-ignite-ml.xml              |  27 ++-
 examples/config/example-ignite.xml                 |  27 ++-
 examples/config/filesystem/core-site.xml           |  27 ++-
 examples/config/filesystem/example-igfs.xml        |  27 ++-
 .../hibernate/example-hibernate-L2-cache.xml       |  29 ++-
 .../persistentstore/example-persistent-store.xml   |  27 ++-
 examples/config/redis/example-redis.xml            |  27 ++-
 examples/config/servlet/WEB-INF/web.xml            |  27 ++-
 examples/config/spark/example-shared-rdd.xml       |  27 ++-
 examples/memcached/memcached-example.php           |  17 +-
 examples/pom-standalone-lgpl.xml                   |  55 +++---
 examples/pom-standalone.xml                        |  55 +++---
 examples/pom.xml                                   |  63 +++----
 examples/redis/redis-example.php                   |  17 +-
 examples/redis/redis-example.py                    |  18 +-
 examples/rest/http-rest-example.php                |  17 +-
 .../examples/datagrid/SpatialQueryExample.java     |  17 +-
 .../hibernate/HibernateL2CacheExample.java         |  17 +-
 .../ignite/examples/datagrid/hibernate/Post.java   |  17 +-
 .../ignite/examples/datagrid/hibernate/User.java   |  17 +-
 .../examples/datagrid/hibernate/package-info.java  |  17 +-
 .../store/hibernate/CacheHibernatePersonStore.java |  17 +-
 .../hibernate/CacheHibernateStoreExample.java      |  17 +-
 .../datagrid/store/hibernate/Person.hbm.xml        |  27 ++-
 .../datagrid/store/hibernate/hibernate.cfg.xml     |  27 ++-
 .../datagrid/store/hibernate/package-info.java     |  17 +-
 .../misc/schedule/ComputeScheduleExample.java      |  17 +-
 .../examples/misc/schedule/package-info.java       |  17 +-
 .../apache/ignite/examples/ExampleNodeStartup.java |  17 +-
 .../org/apache/ignite/examples/ExamplesUtils.java  |  17 +-
 .../ComputeClientBinaryTaskExecutionExample.java   |  17 +-
 .../binary/computegrid/ComputeClientTask.java      |  17 +-
 .../examples/binary/computegrid/package-info.java  |  17 +-
 .../datagrid/CacheClientBinaryPutGetExample.java   |  17 +-
 .../datagrid/CacheClientBinaryQueryExample.java    |  17 +-
 .../examples/binary/datagrid/package-info.java     |  17 +-
 .../ignite/examples/binary/package-info.java       |  17 +-
 .../examples/client/ClientPutGetExample.java       |  17 +-
 .../examples/cluster/ClusterGroupExample.java      |  17 +-
 .../ignite/examples/cluster/package-info.java      |  17 +-
 .../examples/computegrid/ComputeAsyncExample.java  |  17 +-
 .../computegrid/ComputeBroadcastExample.java       |  17 +-
 .../computegrid/ComputeCallableExample.java        |  17 +-
 .../computegrid/ComputeClosureExample.java         |  17 +-
 .../ComputeContinuousMapperExample.java            |  17 +-
 .../ComputeFibonacciContinuationExample.java       |  17 +-
 .../computegrid/ComputeReducerExample.java         |  17 +-
 .../computegrid/ComputeRunnableExample.java        |  17 +-
 .../computegrid/ComputeTaskMapExample.java         |  17 +-
 .../computegrid/ComputeTaskSplitExample.java       |  17 +-
 .../failover/ComputeFailoverExample.java           |  17 +-
 .../failover/ComputeFailoverNodeStartup.java       |  17 +-
 .../computegrid/failover/package-info.java         |  17 +-
 .../examples/computegrid/montecarlo/Credit.java    |  17 +-
 .../computegrid/montecarlo/CreditRiskExample.java  |  17 +-
 .../computegrid/montecarlo/CreditRiskManager.java  |  17 +-
 .../computegrid/montecarlo/package-info.java       |  17 +-
 .../ignite/examples/computegrid/package-info.java  |  17 +-
 .../examples/datagrid/CacheAffinityExample.java    |  17 +-
 .../ignite/examples/datagrid/CacheApiExample.java  |  17 +-
 .../examples/datagrid/CacheAsyncApiExample.java    |  17 +-
 .../datagrid/CacheContinuousAsyncQueryExample.java |  17 +-
 .../datagrid/CacheContinuousQueryExample.java      |  17 +-
 ...CacheContinuousQueryWithTransformerExample.java |  17 +-
 .../datagrid/CacheDataStreamerExample.java         |  17 +-
 .../datagrid/CacheEntryProcessorExample.java       |  17 +-
 .../examples/datagrid/CacheEventsExample.java      |  17 +-
 .../examples/datagrid/CachePutGetExample.java      |  17 +-
 .../examples/datagrid/CacheQueryExample.java       |  17 +-
 .../examples/datagrid/CacheTransactionExample.java |  17 +-
 .../examples/datagrid/DataRegionsExample.java      |  17 +-
 .../ignite/examples/datagrid/package-info.java     |  17 +-
 .../starschema/CacheStarSchemaExample.java         |  17 +-
 .../examples/datagrid/starschema/DimProduct.java   |  17 +-
 .../examples/datagrid/starschema/DimStore.java     |  17 +-
 .../examples/datagrid/starschema/FactPurchase.java |  17 +-
 .../examples/datagrid/starschema/package-info.java |  17 +-
 .../datagrid/store/CacheLoadOnlyStoreExample.java  |  17 +-
 .../datagrid/store/auto/CacheAutoStoreExample.java |  17 +-
 .../examples/datagrid/store/auto/package-info.java |  17 +-
 .../datagrid/store/jdbc/CacheJdbcPersonStore.java  |  17 +-
 .../datagrid/store/jdbc/CacheJdbcStoreExample.java |  17 +-
 .../examples/datagrid/store/jdbc/package-info.java |  17 +-
 .../examples/datagrid/store/package-info.java      |  17 +-
 .../store/spring/CacheSpringPersonStore.java       |  17 +-
 .../store/spring/CacheSpringStoreExample.java      |  17 +-
 .../datagrid/store/spring/package-info.java        |  17 +-
 .../datastructures/IgniteAtomicLongExample.java    |  17 +-
 .../IgniteAtomicReferenceExample.java              |  17 +-
 .../IgniteAtomicSequenceExample.java               |  17 +-
 .../datastructures/IgniteAtomicStampedExample.java |  17 +-
 .../IgniteCountDownLatchExample.java               |  17 +-
 .../IgniteExecutorServiceExample.java              |  17 +-
 .../examples/datastructures/IgniteLockExample.java |  17 +-
 .../datastructures/IgniteQueueExample.java         |  17 +-
 .../datastructures/IgniteSemaphoreExample.java     |  17 +-
 .../examples/datastructures/IgniteSetExample.java  |  17 +-
 .../examples/datastructures/package-info.java      |  17 +-
 .../examples/encryption/EncryptedCacheExample.java |  17 +-
 .../ignite/examples/events/EventsExample.java      |  17 +-
 .../ignite/examples/events/package-info.java       |  17 +-
 .../apache/ignite/examples/igfs/IgfsExample.java   |  17 +-
 .../ignite/examples/igfs/IgfsMapReduceExample.java |  17 +-
 .../ignite/examples/igfs/IgfsNodeStartup.java      |  17 +-
 .../apache/ignite/examples/igfs/package-info.java  |  17 +-
 .../examples/messaging/MessagingExample.java       |  17 +-
 .../messaging/MessagingPingPongExample.java        |  17 +-
 .../MessagingPingPongListenActorExample.java       |  17 +-
 .../ignite/examples/messaging/package-info.java    |  17 +-
 .../misc/client/memcache/MemcacheRestExample.java  |  17 +-
 .../memcache/MemcacheRestExampleNodeStartup.java   |  17 +-
 .../misc/client/memcache/package-info.java         |  17 +-
 .../ignite/examples/misc/client/package-info.java  |  17 +-
 .../misc/deployment/DeploymentExample.java         |  17 +-
 .../examples/misc/deployment/package-info.java     |  17 +-
 .../examples/misc/lifecycle/LifecycleExample.java  |  17 +-
 .../examples/misc/lifecycle/package-info.java      |  17 +-
 .../apache/ignite/examples/misc/package-info.java  |  17 +-
 .../misc/springbean/SpringBeanExample.java         |  17 +-
 .../examples/misc/springbean/package-info.java     |  17 +-
 .../examples/misc/springbean/spring-bean.xml       |  27 ++-
 .../ml/TrainingWithBinaryObjectExample.java        |  17 +-
 .../clustering/CustomersClusterizationExample.java |  17 +-
 .../ml/clustering/GmmClusterizationExample.java    |  17 +-
 .../ml/clustering/KMeansClusterizationExample.java |  17 +-
 .../examples/ml/clustering/package-info.java       |  17 +-
 .../dataset/AlgorithmSpecificDatasetExample.java   |  17 +-
 .../ml/dataset/CacheBasedDatasetExample.java       |  17 +-
 .../ignite/examples/ml/dataset/model/Person.java   |  17 +-
 .../examples/ml/dataset/model/package-info.java    |  17 +-
 .../ignite/examples/ml/dataset/package-info.java   |  17 +-
 .../ignite/examples/ml/genetic/change/Coin.java    |  17 +-
 .../change/OptimizeMakeChangeFitnessFunction.java  |  17 +-
 .../change/OptimizeMakeChangeGAExample.java        |  17 +-
 .../OptimizeMakeChangeTerminateCriteria.java       |  17 +-
 .../helloworld/HelloWorldFitnessFunction.java      |  17 +-
 .../ml/genetic/helloworld/HelloWorldGAExample.java |  17 +-
 .../helloworld/HelloWorldTerminateCriteria.java    |  17 +-
 .../ignite/examples/ml/genetic/knapsack/Item.java  |  17 +-
 .../genetic/knapsack/KnapsackFitnessFunction.java  |  17 +-
 .../ml/genetic/knapsack/KnapsackGAExample.java     |  17 +-
 .../knapsack/KnapsackTerminateCriteria.java        |  17 +-
 .../ignite/examples/ml/genetic/movie/Movie.java    |  17 +-
 .../ml/genetic/movie/MovieFitnessFunction.java     |  17 +-
 .../examples/ml/genetic/movie/MovieGAExample.java  |  17 +-
 .../ml/genetic/movie/MovieTerminateCriteria.java   |  17 +-
 .../IgniteModelDistributedInferenceExample.java    |  17 +-
 .../examples/ml/inference/ModelStorageExample.java |  17 +-
 .../TensorFlowDistributedInferenceExample.java     |  17 +-
 .../inference/TensorFlowLocalInferenceExample.java |  17 +-
 .../TensorFlowThreadedInferenceExample.java        |  17 +-
 .../ignite/examples/ml/inference/package-info.java |  17 +-
 .../spark/LogRegFromSparkThroughPMMLExample.java   |  17 +-
 .../modelparser/DecisionTreeFromSparkExample.java  |  17 +-
 .../DecisionTreeRegressionFromSparkExample.java    |  17 +-
 .../spark/modelparser/GBTFromSparkExample.java     |  17 +-
 .../modelparser/GBTRegressionFromSparkExample.java |  17 +-
 .../spark/modelparser/KMeansFromSparkExample.java  |  17 +-
 .../LinearRegressionFromSparkExample.java          |  17 +-
 .../spark/modelparser/LogRegFromSparkExample.java  |  17 +-
 .../modelparser/RandomForestFromSparkExample.java  |  17 +-
 .../RandomForestRegressionFromSparkExample.java    |  17 +-
 .../spark/modelparser/SVMFromSparkExample.java     |  17 +-
 .../inference/spark/modelparser/package-info.java  |  17 +-
 .../examples/ml/inference/spark/package-info.java  |  17 +-
 .../examples/ml/knn/ANNClassificationExample.java  |  17 +-
 .../examples/ml/knn/IrisClassificationExample.java |  17 +-
 .../examples/ml/knn/KNNClassificationExample.java  |  17 +-
 .../examples/ml/knn/KNNRegressionExample.java      |  17 +-
 .../ignite/examples/ml/knn/package-info.java       |  17 +-
 .../multiclass/OneVsRestClassificationExample.java |  17 +-
 .../examples/ml/multiclass/package-info.java       |  17 +-
 .../DiscreteNaiveBayesTrainerExample.java          |  17 +-
 .../GaussianNaiveBayesTrainerExample.java          |  17 +-
 .../examples/ml/naivebayes/package-info.java       |  17 +-
 .../ignite/examples/ml/nn/MLPTrainerExample.java   |  17 +-
 .../apache/ignite/examples/ml/nn/package-info.java |  17 +-
 .../apache/ignite/examples/ml/package-info.java    |  17 +-
 .../ml/preprocessing/BinarizationExample.java      |  17 +-
 .../examples/ml/preprocessing/ImputingExample.java |  17 +-
 .../ml/preprocessing/MaxAbsScalerExample.java      |  17 +-
 .../ml/preprocessing/MinMaxScalerExample.java      |  17 +-
 .../ml/preprocessing/NormalizationExample.java     |  17 +-
 .../ml/preprocessing/StandardScalerExample.java    |  17 +-
 .../examples/ml/preprocessing/package-info.java    |  17 +-
 .../linear/BostonHousePricesPredictionExample.java |  17 +-
 .../linear/LinearRegressionLSQRTrainerExample.java |  17 +-
 ...gressionLSQRTrainerWithMinMaxScalerExample.java |  17 +-
 .../linear/LinearRegressionSGDTrainerExample.java  |  17 +-
 .../ml/regression/linear/package-info.java         |  17 +-
 .../BaggedLogisticRegressionSGDTrainerExample.java |  17 +-
 .../regression/logistic/bagged/package-info.java   |  17 +-
 .../LogisticRegressionSGDTrainerExample.java       |  17 +-
 .../regression/logistic/binary/package-info.java   |  17 +-
 .../ml/regression/logistic/package-info.java       |  17 +-
 .../examples/ml/regression/package-info.java       |  17 +-
 .../ml/selection/cv/CrossValidationExample.java    |  17 +-
 .../examples/ml/selection/cv/package-info.java     |  17 +-
 .../ignite/examples/ml/selection/package-info.java |  17 +-
 .../ml/selection/scoring/EvaluatorExample.java     |  17 +-
 .../selection/scoring/MultipleMetricsExample.java  |  17 +-
 .../selection/scoring/RegressionMetricExample.java |  17 +-
 .../split/TrainTestDatasetSplitterExample.java     |  17 +-
 .../examples/ml/selection/split/package-info.java  |  17 +-
 ...eeClassificationTrainerSQLInferenceExample.java |  17 +-
 ...onTreeClassificationTrainerSQLTableExample.java |  17 +-
 .../ignite/examples/ml/sql/package-info.java       |  17 +-
 .../ml/svm/SVMBinaryClassificationExample.java     |  17 +-
 .../ignite/examples/ml/svm/package-info.java       |  17 +-
 .../DecisionTreeClassificationTrainerExample.java  |  17 +-
 .../tree/DecisionTreeRegressionTrainerExample.java |  17 +-
 .../examples/ml/tree/FraudDetectionExample.java    |  17 +-
 .../GDBOnTreesClassificationTrainerExample.java    |  17 +-
 .../GDBOnTreesRegressionTrainerExample.java        |  17 +-
 .../examples/ml/tree/boosting/package-info.java    |  17 +-
 .../ignite/examples/ml/tree/package-info.java      |  17 +-
 .../RandomForestClassificationExample.java         |  17 +-
 .../RandomForestRegressionExample.java             |  17 +-
 .../ml/tree/randomforest/package-info.java         |  17 +-
 .../ml/tutorial/Step_1_Read_and_Learn.java         |  17 +-
 .../examples/ml/tutorial/Step_2_Imputing.java      |  17 +-
 .../examples/ml/tutorial/Step_3_Categorial.java    |  17 +-
 .../Step_3_Categorial_with_One_Hot_Encoder.java    |  17 +-
 .../examples/ml/tutorial/Step_4_Add_age_fare.java  |  17 +-
 .../examples/ml/tutorial/Step_5_Scaling.java       |  17 +-
 .../ml/tutorial/Step_5_Scaling_with_Pipeline.java  |  17 +-
 .../ignite/examples/ml/tutorial/Step_6_KNN.java    |  17 +-
 .../ml/tutorial/Step_7_Split_train_test.java       |  17 +-
 .../ignite/examples/ml/tutorial/Step_8_CV.java     |  17 +-
 .../ml/tutorial/Step_8_CV_with_Param_Grid.java     |  17 +-
 .../Step_8_CV_with_Param_Grid_and_metrics.java     |  17 +-
 ...V_with_Param_Grid_and_metrics_and_pipeline.java |  17 +-
 .../ml/tutorial/Step_9_Scaling_With_Stacking.java  |  17 +-
 .../ignite/examples/ml/tutorial/TitanicUtils.java  |  17 +-
 .../ml/tutorial/TutorialStepByStepExample.java     |  17 +-
 .../ignite/examples/ml/tutorial/package-info.java  |  17 +-
 .../ignite/examples/ml/util/DatasetHelper.java     |  17 +-
 .../examples/ml/util/MLExamplesCommonArgs.java     |  17 +-
 .../ParametricVectorGeneratorExample.java          |  17 +-
 .../util/generators/StandardGeneratorsExample.java |  17 +-
 .../generators/VectorGeneratorFamilyExample.java   |  17 +-
 .../VectorGeneratorPrimitivesExample.java          |  17 +-
 .../examples/ml/util/generators/package-info.java  |  17 +-
 .../ignite/examples/ml/util/package-info.java      |  17 +-
 .../ml/xgboost/XGBoostModelParserExample.java      |  17 +-
 .../ignite/examples/ml/xgboost/package-info.java   |  17 +-
 .../org/apache/ignite/examples/model/Address.java  |  17 +-
 .../org/apache/ignite/examples/model/Employee.java |  17 +-
 .../apache/ignite/examples/model/EmployeeKey.java  |  17 +-
 .../apache/ignite/examples/model/Organization.java |  17 +-
 .../ignite/examples/model/OrganizationType.java    |  17 +-
 .../org/apache/ignite/examples/model/Person.java   |  17 +-
 .../apache/ignite/examples/model/package-info.java |  17 +-
 .../org/apache/ignite/examples/package-info.java   |  17 +-
 .../persistentstore/PersistentStoreExample.java    |  17 +-
 .../PersistentStoreExampleNodeStartup.java         |  17 +-
 .../examples/servicegrid/ServicesExample.java      |  17 +-
 .../examples/servicegrid/SimpleMapService.java     |  17 +-
 .../examples/servicegrid/SimpleMapServiceImpl.java |  17 +-
 .../ignite/examples/servicegrid/package-info.java  |  17 +-
 .../examples/springdata/PersonRepository.java      |  17 +-
 .../ignite/examples/springdata/SpringAppCfg.java   |  17 +-
 .../examples/springdata/SpringDataExample.java     |  17 +-
 .../apache/ignite/examples/sql/SqlDdlExample.java  |  17 +-
 .../apache/ignite/examples/sql/SqlDmlExample.java  |  17 +-
 .../ignite/examples/sql/SqlJdbcCopyExample.java    |  17 +-
 .../apache/ignite/examples/sql/SqlJdbcExample.java |  17 +-
 .../ignite/examples/sql/SqlQueriesExample.java     |  17 +-
 .../apache/ignite/examples/sql/package-info.java   |  17 +-
 .../streaming/StreamTransformerExample.java        |  17 +-
 .../examples/streaming/StreamVisitorExample.java   |  17 +-
 .../ignite/examples/streaming/package-info.java    |  17 +-
 .../examples/streaming/wordcount/CacheConfig.java  |  17 +-
 .../examples/streaming/wordcount/QueryWords.java   |  17 +-
 .../examples/streaming/wordcount/StreamWords.java  |  17 +-
 .../examples/streaming/wordcount/package-info.java |  17 +-
 .../socket/WordsSocketStreamerClient.java          |  17 +-
 .../socket/WordsSocketStreamerServer.java          |  17 +-
 .../streaming/wordcount/socket/package-info.java   |  17 +-
 .../ignite/examples/util/DbH2ServerStartup.java    |  17 +-
 .../apache/ignite/examples/util/package-info.java  |  17 +-
 .../examples/ScalarCacheAffinityExample.scala      |  17 +-
 .../ScalarCacheEntryProcessorExample.scala         |  17 +-
 .../scalar/examples/ScalarCacheExample.scala       |  17 +-
 .../ScalarCachePopularNumbersExample.scala         |  17 +-
 .../scalar/examples/ScalarCacheQueryExample.scala  |  17 +-
 .../scalar/examples/ScalarClosureExample.scala     |  17 +-
 .../examples/ScalarContinuationExample.scala       |  17 +-
 .../scalar/examples/ScalarCreditRiskExample.scala  |  17 +-
 .../scalar/examples/ScalarJvmCloudExample.scala    |  17 +-
 .../scalar/examples/ScalarPingPongExample.scala    |  17 +-
 .../scalar/examples/ScalarPrimeExample.scala       |  17 +-
 .../examples/ScalarSnowflakeSchemaExample.scala    |  17 +-
 .../ignite/scalar/examples/ScalarTaskExample.scala |  17 +-
 .../examples/ScalarWorldShortestMapReduce.scala    |  17 +-
 .../examples/spark/ScalarSharedRDDExample.scala    |  17 +-
 .../examples/ml/mleap/MLeapModelParserExample.java |  17 +-
 .../ignite/examples/ml/mleap/package-info.java     |  17 +-
 .../examples/spark/IgniteCatalogExample.scala      |  17 +-
 .../examples/spark/IgniteDataFrameExample.scala    |  17 +-
 .../spark/IgniteDataFrameWriteExample.scala        |  17 +-
 .../examples/spark/JavaIgniteCatalogExample.java   |  17 +-
 .../examples/spark/JavaIgniteDataFrameExample.java |  17 +-
 .../spark/JavaIgniteDataFrameWriteExample.java     |  17 +-
 .../ignite/examples/spark/SharedRDDExample.java    |  17 +-
 .../apache/ignite/examples/spark/package-info.java |  17 +-
 .../org/apache/ignite/examples/spark/package.scala |  17 +-
 .../ComputeScheduleExampleMultiNodeSelfTest.java   |  17 +-
 .../examples/ComputeScheduleExampleSelfTest.java   |  17 +-
 .../HibernateL2CacheExampleMultiNodeSelfTest.java  |  17 +-
 .../examples/HibernateL2CacheExampleSelfTest.java  |  17 +-
 .../SpatialQueryExampleMultiNodeSelfTest.java      |  17 +-
 .../examples/SpatialQueryExampleSelfTest.java      |  17 +-
 .../IgniteLgplExamplesSelfTestSuite.java           |  27 ++-
 .../examples/BasicExamplesMultiNodeSelfTest.java   |  17 +-
 .../ignite/examples/BasicExamplesSelfTest.java     |  17 +-
 .../examples/CacheClientBinaryExampleTest.java     |  17 +-
 .../CacheContinuousQueryExamplesSelfTest.java      |  17 +-
 .../examples/CacheExamplesMultiNodeSelfTest.java   |  17 +-
 .../ignite/examples/CacheExamplesSelfTest.java     |  17 +-
 .../examples/CheckpointExamplesSelfTest.java       |  17 +-
 .../examples/ClusterGroupExampleSelfTest.java      |  17 +-
 .../examples/ComputeClientBinaryExampleTest.java   |  17 +-
 .../ContinuationExamplesMultiNodeSelfTest.java     |  17 +-
 .../examples/ContinuationExamplesSelfTest.java     |  17 +-
 .../ContinuousMapperExamplesMultiNodeSelfTest.java |  17 +-
 .../examples/ContinuousMapperExamplesSelfTest.java |  17 +-
 .../DeploymentExamplesMultiNodeSelfTest.java       |  17 +-
 .../examples/DeploymentExamplesSelfTest.java       |  17 +-
 .../examples/EncryptedCacheExampleSelfTest.java    |  17 +-
 .../examples/EventsExamplesMultiNodeSelfTest.java  |  17 +-
 .../ignite/examples/EventsExamplesSelfTest.java    |  17 +-
 .../ignite/examples/IgfsExamplesSelfTest.java      |  17 +-
 .../ignite/examples/LifecycleExamplesSelfTest.java |  17 +-
 .../MemcacheRestExamplesMultiNodeSelfTest.java     |  17 +-
 .../examples/MemcacheRestExamplesSelfTest.java     |  17 +-
 .../ignite/examples/MessagingExamplesSelfTest.java |  17 +-
 .../MonteCarloExamplesMultiNodeSelfTest.java       |  17 +-
 .../examples/MonteCarloExamplesSelfTest.java       |  17 +-
 .../examples/SpringBeanExamplesSelfTest.java       |  17 +-
 .../ignite/examples/SpringDataExampleSelfTest.java |  17 +-
 .../ignite/examples/SqlExamplesSelfTest.java       |  17 +-
 .../examples/TaskExamplesMultiNodeSelfTest.java    |  17 +-
 .../ignite/examples/TaskExamplesSelfTest.java      |  17 +-
 .../testsuites/IgniteExamplesMLTestSuite.java      |  17 +-
 .../testsuites/IgniteExamplesSelfTestSuite.java    |  17 +-
 .../examples/ScalarExamplesMultiNodeSelfTest.scala |  17 +-
 .../tests/examples/ScalarExamplesSelfTest.scala    |  17 +-
 .../testsuites/ScalarExamplesSelfTestSuite.scala   |  17 +-
 .../spark/examples/IgniteDataFrameSelfTest.java    |  17 +-
 .../examples/JavaIgniteDataFrameSelfTest.java      |  17 +-
 .../spark/examples/SharedRDDExampleSelfTest.java   |  17 +-
 .../IgniteExamplesSparkSelfTestSuite.java          |  17 +-
 ipc/shmem/Makefile.am                              |  18 +-
 ipc/shmem/igniteshmem/Makefile.am                  |  18 +-
 ...nternal_util_ipc_shmem_IpcSharedMemoryUtils.cpp |  17 +-
 ipc/shmem/include/Makefile.am                      |  18 +-
 modules/aop/licenses/apache-2.0.txt                | 202 ---------------------
 modules/aop/licenses/gg-community.txt              |  13 ++
 modules/aop/pom.xml                                |  39 ++--
 .../gridify/aop/aspectj/GridifyAspectJAspect.java  |  17 +-
 .../aop/aspectj/GridifySetToSetAspectJAspect.java  |  17 +-
 .../aspectj/GridifySetToValueAspectJAspect.java    |  17 +-
 .../compute/gridify/aop/aspectj/package-info.java  |  17 +-
 .../aop/spring/GridifySetToSetSpringAspect.java    |  17 +-
 .../aop/spring/GridifySetToValueSpringAspect.java  |  17 +-
 .../gridify/aop/spring/GridifySpringAspect.java    |  17 +-
 .../gridify/aop/spring/GridifySpringEnhancer.java  |  17 +-
 .../gridify/aop/spring/GridifySpringPointcut.java  |  17 +-
 .../compute/gridify/aop/spring/package-info.java   |  17 +-
 .../src/test/config/aop/aspectj/META-INF/aop.xml   |  27 ++-
 .../org/apache/ignite/gridify/AbstractAopTest.java |  17 +-
 .../apache/ignite/gridify/BasicAopSelfTest.java    |  17 +-
 .../ignite/gridify/GridifySetToSetTarget.java      |  17 +-
 .../gridify/GridifySetToSetTargetInterface.java    |  17 +-
 .../ignite/gridify/GridifySetToValueTarget.java    |  17 +-
 .../gridify/GridifySetToValueTargetInterface.java  |  17 +-
 .../GridifySetToXXXNonSpringAopSelfTest.java       |  17 +-
 .../gridify/GridifySetToXXXSpringAopSelfTest.java  |  17 +-
 .../ignite/gridify/NonSpringAopSelfTest.java       |  17 +-
 .../apache/ignite/gridify/SpringAopSelfTest.java   |  17 +-
 .../org/apache/ignite/gridify/TestAopTarget.java   |  17 +-
 .../ignite/gridify/TestAopTargetInterface.java     |  17 +-
 .../ignite/gridify/TestGridifyException.java       |  17 +-
 .../org/apache/ignite/gridify/TestGridifyJob.java  |  17 +-
 .../org/apache/ignite/gridify/TestGridifyTask.java |  17 +-
 .../gridify/hierarchy/GridifyHierarchyTest.java    |  17 +-
 .../ignite/gridify/hierarchy/SuperTarget.java      |  17 +-
 .../apache/ignite/gridify/hierarchy/Target.java    |  17 +-
 .../ignite/gridify/hierarchy/package-info.java     |  17 +-
 .../org/apache/ignite/gridify/package-info.java    |  17 +-
 .../apache/ignite/gridify/test_resource.properties |  18 +-
 .../optimized/OptimizedMarshallerAopTest.java      |  17 +-
 .../org/apache/ignite/p2p/P2PGridifySelfTest.java  |  17 +-
 .../ignite/testsuites/IgniteAopSelfTestSuite.java  |  17 +-
 .../singlesplit/SingleSplitTestJobTarget.java      |  17 +-
 .../direct/singlesplit/SingleSplitTestTask.java    |  17 +-
 .../direct/singlesplit/SingleSplitsLoadTest.java   |  17 +-
 .../loadtests/direct/singlesplit/package-info.java |  17 +-
 .../gridify/GridifyLoadTestJobTarget.java          |  17 +-
 .../loadtests/gridify/GridifyLoadTestTask.java     |  17 +-
 .../gridify/GridifySingleSplitLoadTest.java        |  17 +-
 .../java/org/test/gridify/ExternalAopTarget.java   |  17 +-
 .../org/test/gridify/ExternalGridifyException.java |  17 +-
 .../java/org/test/gridify/ExternalGridifyTask.java |  17 +-
 .../test/gridify/ExternalNonSpringAopSelfTest.java |  17 +-
 .../test/java/org/test/gridify/package-info.java   |  17 +-
 .../java/org/test/gridify/test_resource.properties |  18 +-
 modules/apache-license-gen/README.txt              |   2 +-
 modules/apache-license-gen/pom.xml                 |  33 ++--
 .../src/main/resources/META-INF/licenses.txt.vm    |  34 ++--
 modules/aws/licenses/apache-2.0.txt                | 202 ---------------------
 modules/aws/licenses/gg-community.txt              |  13 ++
 modules/aws/pom.xml                                |  37 ++--
 .../ignite/spi/checkpoint/s3/S3CheckpointData.java |  17 +-
 .../ignite/spi/checkpoint/s3/S3CheckpointSpi.java  |  17 +-
 .../spi/checkpoint/s3/S3CheckpointSpiMBean.java    |  17 +-
 .../ignite/spi/checkpoint/s3/S3TimeData.java       |  17 +-
 .../ignite/spi/checkpoint/s3/package-info.java     |  17 +-
 .../tcp/ipfinder/elb/TcpDiscoveryElbIpFinder.java  |  17 +-
 .../discovery/tcp/ipfinder/elb/package-info.java   |  17 +-
 .../tcp/ipfinder/s3/TcpDiscoveryS3IpFinder.java    |  17 +-
 .../s3/encrypt/AsymmetricKeyEncryptionService.java |  17 +-
 .../s3/encrypt/AwsKmsEncryptionService.java        |  17 +-
 .../tcp/ipfinder/s3/encrypt/EncryptionService.java |  17 +-
 .../s3/encrypt/SymmetricKeyEncryptionService.java  |  17 +-
 .../tcp/ipfinder/s3/encrypt/package-info.java      |  17 +-
 .../discovery/tcp/ipfinder/s3/package-info.java    |  17 +-
 .../checkpoint/s3/S3CheckpointManagerSelfTest.java |  17 +-
 .../s3/S3CheckpointSpiConfigSelfTest.java          |  17 +-
 .../spi/checkpoint/s3/S3CheckpointSpiSelfTest.java |  17 +-
 ...eckpointSpiStartStopBucketEndpointSelfTest.java |  17 +-
 ...CheckpointSpiStartStopSSEAlgorithmSelfTest.java |  17 +-
 .../s3/S3CheckpointSpiStartStopSelfTest.java       |  17 +-
 .../checkpoint/s3/S3SessionCheckpointSelfTest.java |  17 +-
 .../ignite/spi/checkpoint/s3/package-info.java     |  17 +-
 .../elb/TcpDiscoveryElbIpFinderSelfTest.java       |  17 +-
 .../discovery/tcp/ipfinder/elb/package-info.java   |  17 +-
 .../s3/TcpDiscoveryS3IpFinderAbstractSelfTest.java |  17 +-
 ...ryS3IpFinderAwsCredentialsProviderSelfTest.java |  17 +-
 ...pDiscoveryS3IpFinderAwsCredentialsSelfTest.java |  17 +-
 ...pDiscoveryS3IpFinderBucketEndpointSelfTest.java |  17 +-
 ...veryS3IpFinderClientSideEncryptionSelfTest.java |  17 +-
 .../TcpDiscoveryS3IpFinderKeyPrefixSelfTest.java   |  17 +-
 ...TcpDiscoveryS3IpFinderSSEAlgorithmSelfTest.java |  17 +-
 .../tcp/ipfinder/s3/client/DummyObjectListing.java |  17 +-
 .../ipfinder/s3/client/DummyObjectListingTest.java |  17 +-
 .../tcp/ipfinder/s3/client/DummyS3Client.java      |  17 +-
 .../tcp/ipfinder/s3/client/DummyS3ClientTest.java  |  17 +-
 .../tcp/ipfinder/s3/client/package-info.java       |  17 +-
 .../AsymmetricKeyEncryptionServiceTest.java        |  17 +-
 .../s3/encrypt/AwsKmsEncryptionServiceTest.java    |  17 +-
 .../ipfinder/s3/encrypt/MockEncryptionService.java |  17 +-
 .../s3/encrypt/MockEncryptionServiceTest.java      |  17 +-
 .../encrypt/SymmetricKeyEncryptionServiceTest.java |  17 +-
 .../tcp/ipfinder/s3/encrypt/package-info.java      |  17 +-
 .../discovery/tcp/ipfinder/s3/package-info.java    |  17 +-
 .../ignite/testsuites/IgniteElbTestSuite.java      |  17 +-
 .../ignite/testsuites/IgniteS3TestSuite.java       |  17 +-
 modules/benchmarks/pom.xml                         |  37 ++--
 .../benchmarks/jmh/JmhAbstractBenchmark.java       |  17 +-
 .../internal/benchmarks/jmh/algo/BenchmarkCRC.java |  17 +-
 .../jmh/cache/JmhCacheAbstractBenchmark.java       |  17 +-
 .../benchmarks/jmh/cache/JmhCacheBenchmark.java    |  17 +-
 .../jmh/cache/JmhCacheLocksBenchmark.java          |  17 +-
 .../SmallHashSetsVsReadOnlyViewBenchmark.java      |  17 +-
 .../JmhKeystoreEncryptionSpiBenchmark.java         |  17 +-
 .../jmh/future/JmhFutureAdapterBenchmark.java      |  17 +-
 .../GridDhtPartitionsStateValidatorBenchmark.java  |  17 +-
 .../benchmarks/jmh/misc/JmhIncrementBenchmark.java |  17 +-
 .../jmh/notify/JmhParkVsNotifyBenchmark.java       |  17 +-
 .../jmh/notify/JmhWaitStategyBenchmark.java        |  17 +-
 .../jmh/runner/JmhIdeBenchmarkRunner.java          |  17 +-
 .../jmh/sequence/JmhSequenceBenchmark.java         |  17 +-
 .../jmh/streamer/JmhStreamerAddDataBenchmark.java  |  17 +-
 .../benchmarks/jmh/tree/BPlusTreeBenchmark.java    |  17 +-
 .../jol/GridAffinityAssignmentJolBenchmark.java    |  17 +-
 .../ignite/internal/benchmarks/model/IntValue.java |  17 +-
 .../ignite/internal/benchmarks/model/Node.java     |  17 +-
 modules/camel/licenses/apache-2.0.txt              | 202 ---------------------
 modules/camel/licenses/gg-community.txt            |  13 ++
 modules/camel/pom.xml                              |  41 ++---
 .../apache/ignite/stream/camel/CamelStreamer.java  |  17 +-
 .../apache/ignite/stream/camel/package-info.java   |  27 ++-
 .../stream/camel/IgniteCamelStreamerTest.java      |  17 +-
 .../stream/camel/IgniteCamelStreamerTestSuite.java |  17 +-
 .../apache/ignite/stream/camel/package-info.java   |  27 ++-
 .../camel/src/test/resources/camel.test.properties |  18 +-
 modules/cassandra/pom.xml                          |  35 ++--
 .../cassandra/serializers/licenses/apache-2.0.txt  | 202 ---------------------
 .../serializers/licenses/gg-community.txt          |  13 ++
 modules/cassandra/serializers/pom.xml              |  35 ++--
 .../store/cassandra/serializer/KryoSerializer.java |  17 +-
 .../store/cassandra/serializer/package-info.java   |  17 +-
 .../apache/ignite/tests/KryoSerializerTest.java    |  17 +-
 .../test/java/org/apache/ignite/tests/MyPojo.java  |  17 +-
 modules/cassandra/store/licenses/apache-2.0.txt    | 202 ---------------------
 modules/cassandra/store/licenses/gg-community.txt  |  13 ++
 modules/cassandra/store/pom.xml                    |  39 ++--
 .../cache/store/cassandra/CassandraCacheStore.java |  17 +-
 .../cassandra/CassandraCacheStoreFactory.java      |  17 +-
 .../store/cassandra/common/CassandraHelper.java    |  17 +-
 .../cassandra/common/PropertyMappingHelper.java    |  17 +-
 .../store/cassandra/common/RandomSleeper.java      |  17 +-
 .../cache/store/cassandra/common/SystemHelper.java |  17 +-
 .../cache/store/cassandra/common/package-info.java |  17 +-
 .../store/cassandra/datasource/Credentials.java    |  17 +-
 .../store/cassandra/datasource/DataSource.java     |  17 +-
 .../cassandra/datasource/PlainCredentials.java     |  17 +-
 .../store/cassandra/datasource/package-info.java   |  17 +-
 .../ignite/cache/store/cassandra/package-info.java |  17 +-
 .../persistence/KeyPersistenceSettings.java        |  17 +-
 .../persistence/KeyValuePersistenceSettings.java   |  17 +-
 .../persistence/PersistenceController.java         |  17 +-
 .../cassandra/persistence/PersistenceSettings.java |  17 +-
 .../cassandra/persistence/PersistenceStrategy.java |  17 +-
 .../store/cassandra/persistence/PojoField.java     |  17 +-
 .../cassandra/persistence/PojoFieldAccessor.java   |  17 +-
 .../store/cassandra/persistence/PojoKeyField.java  |  17 +-
 .../cassandra/persistence/PojoValueField.java      |  17 +-
 .../persistence/ValuePersistenceSettings.java      |  17 +-
 .../store/cassandra/persistence/package-info.java  |  17 +-
 .../store/cassandra/serializer/JavaSerializer.java |  17 +-
 .../store/cassandra/serializer/Serializer.java     |  17 +-
 .../store/cassandra/serializer/package-info.java   |  17 +-
 .../cassandra/session/BatchExecutionAssistant.java |  17 +-
 .../cassandra/session/BatchLoaderAssistant.java    |  17 +-
 .../store/cassandra/session/CassandraSession.java  |  17 +-
 .../cassandra/session/CassandraSessionImpl.java    |  17 +-
 .../cassandra/session/ExecutionAssistant.java      |  17 +-
 .../session/GenericBatchExecutionAssistant.java    |  17 +-
 .../session/LoadCacheCustomQueryWorker.java        |  17 +-
 .../session/WrappedPreparedStatement.java          |  17 +-
 .../store/cassandra/session/WrappedSession.java    |  17 +-
 .../store/cassandra/session/package-info.java      |  17 +-
 .../store/cassandra/session/pool/IdleSession.java  |  17 +-
 .../store/cassandra/session/pool/SessionPool.java  |  17 +-
 .../store/cassandra/session/pool/package-info.java |  17 +-
 .../session/transaction/BaseMutation.java          |  17 +-
 .../session/transaction/DeleteMutation.java        |  17 +-
 .../cassandra/session/transaction/Mutation.java    |  17 +-
 .../session/transaction/WriteMutation.java         |  17 +-
 .../session/transaction/package-info.java          |  17 +-
 .../cache/store/cassandra/utils/DDLGenerator.java  |  17 +-
 .../cache/store/cassandra/utils/package-info.java  |  17 +-
 .../bootstrap/aws/cassandra/cassandra-bootstrap.sh |  18 +-
 .../test/bootstrap/aws/cassandra/cassandra-env.sh  |  16 +-
 .../bootstrap/aws/cassandra/cassandra-start.sh     |  18 +-
 .../aws/cassandra/cassandra-template.yaml          |  18 +-
 .../store/src/test/bootstrap/aws/common.sh         |  18 +-
 .../cassandra/store/src/test/bootstrap/aws/env.sh  |  18 +-
 .../src/test/bootstrap/aws/ganglia/agent-start.sh  |  18 +-
 .../bootstrap/aws/ganglia/ganglia-bootstrap.sh     |  18 +-
 .../test/bootstrap/aws/ignite/ignite-bootstrap.sh  |  18 +-
 .../ignite/ignite-cassandra-server-template.xml    |  27 ++-
 .../src/test/bootstrap/aws/ignite/ignite-env.sh    |  18 +-
 .../src/test/bootstrap/aws/ignite/ignite-start.sh  |  18 +-
 .../store/src/test/bootstrap/aws/logs-collector.sh |  18 +-
 .../aws/tests/ignite-cassandra-client-template.xml |  27 ++-
 .../test/bootstrap/aws/tests/tests-bootstrap.sh    |  18 +-
 .../src/test/bootstrap/aws/tests/tests-manager.sh  |  18 +-
 .../src/test/bootstrap/aws/tests/tests-report.sh   |  18 +-
 .../apache/ignite/tests/CassandraConfigTest.java   |  17 +-
 .../tests/CassandraDirectPersistenceLoadTest.java  |  17 +-
 .../tests/CassandraDirectPersistenceTest.java      |  17 +-
 .../apache/ignite/tests/CassandraLocalServer.java  |  17 +-
 .../ignite/tests/CassandraSessionImplTest.java     |  29 ++-
 .../org/apache/ignite/tests/DDLGeneratorTest.java  |  17 +-
 .../ignite/tests/DatasourceSerializationTest.java  |  17 +-
 .../tests/IgnitePersistentStoreLoadTest.java       |  17 +-
 .../ignite/tests/IgnitePersistentStoreTest.java    |  17 +-
 .../tests/LoadTestsCassandraArtifactsCreator.java  |  17 +-
 .../org/apache/ignite/tests/load/Generator.java    |  17 +-
 .../org/apache/ignite/tests/load/IntGenerator.java |  17 +-
 .../apache/ignite/tests/load/LoadTestDriver.java   |  17 +-
 .../apache/ignite/tests/load/LongGenerator.java    |  17 +-
 .../apache/ignite/tests/load/PersonGenerator.java  |  17 +-
 .../ignite/tests/load/PersonIdGenerator.java       |  17 +-
 .../apache/ignite/tests/load/StringGenerator.java  |  17 +-
 .../java/org/apache/ignite/tests/load/Worker.java  |  17 +-
 .../tests/load/cassandra/BulkReadWorker.java       |  17 +-
 .../tests/load/cassandra/BulkWriteWorker.java      |  17 +-
 .../ignite/tests/load/cassandra/ReadWorker.java    |  17 +-
 .../ignite/tests/load/cassandra/WriteWorker.java   |  17 +-
 .../ignite/tests/load/cassandra/package-info.java  |  17 +-
 .../ignite/tests/load/ignite/BulkReadWorker.java   |  17 +-
 .../ignite/tests/load/ignite/BulkWriteWorker.java  |  17 +-
 .../ignite/tests/load/ignite/ReadWorker.java       |  17 +-
 .../ignite/tests/load/ignite/WriteWorker.java      |  17 +-
 .../ignite/tests/load/ignite/package-info.java     |  17 +-
 .../org/apache/ignite/tests/load/package-info.java |  17 +-
 .../java/org/apache/ignite/tests/package-info.java |  17 +-
 .../java/org/apache/ignite/tests/pojos/Person.java |  17 +-
 .../org/apache/ignite/tests/pojos/PersonId.java    |  17 +-
 .../org/apache/ignite/tests/pojos/Product.java     |  17 +-
 .../apache/ignite/tests/pojos/ProductOrder.java    |  17 +-
 .../apache/ignite/tests/pojos/SimplePerson.java    |  17 +-
 .../apache/ignite/tests/pojos/SimplePersonId.java  |  17 +-
 .../apache/ignite/tests/pojos/package-info.java    |  17 +-
 .../ignite/tests/utils/CacheStoreHelper.java       |  17 +-
 .../tests/utils/CassandraAdminCredentials.java     |  17 +-
 .../apache/ignite/tests/utils/CassandraHelper.java |  17 +-
 .../ignite/tests/utils/CassandraLifeCycleBean.java |  17 +-
 .../tests/utils/CassandraRegularCredentials.java   |  17 +-
 .../ignite/tests/utils/TestCacheSession.java       |  17 +-
 .../apache/ignite/tests/utils/TestTransaction.java |  17 +-
 .../org/apache/ignite/tests/utils/TestsHelper.java |  17 +-
 .../apache/ignite/tests/utils/package-info.java    |  17 +-
 .../store/IgniteCassandraStoreTestSuite.java       |  17 +-
 .../testsuites/cassandra/store/package-info.java   |  17 +-
 .../store/src/test/resources/log4j.properties      |  18 +-
 .../ignite/tests/cassandra/connection-settings.xml |  27 ++-
 .../ignite/tests/cassandra/connection.properties   |  18 +-
 .../ignite/tests/cassandra/credentials.properties  |  18 +-
 .../ignite/tests/cassandra/embedded-cassandra.yaml |  18 +-
 .../ignite/tests/cassandra/keyspaces.properties    |  18 +-
 .../tests/persistence/blob/ignite-config.xml       |  27 ++-
 .../persistence/blob/persistence-settings-1.xml    |  27 ++-
 .../persistence/blob/persistence-settings-2.xml    |  27 ++-
 .../persistence/blob/persistence-settings-3.xml    |  27 ++-
 .../persistence/loadall_blob/ignite-config.xml     |  29 ++-
 .../loadall_blob/persistence-settings.xml          |  27 ++-
 .../tests/persistence/pojo/ignite-config.xml       |  27 ++-
 .../apache/ignite/tests/persistence/pojo/order.xml |  27 ++-
 .../persistence/pojo/persistence-settings-1.xml    |  27 ++-
 .../persistence/pojo/persistence-settings-2.xml    |  27 ++-
 .../persistence/pojo/persistence-settings-3.xml    |  27 ++-
 .../persistence/pojo/persistence-settings-4.xml    |  27 ++-
 .../persistence/pojo/persistence-settings-5.xml    |  27 ++-
 .../persistence/pojo/persistence-settings-6.xml    |  27 ++-
 .../ignite/tests/persistence/pojo/product.xml      |  27 ++-
 .../tests/persistence/primitive/ignite-config.xml  |  27 ++-
 .../primitive/ignite-remote-client-config.xml      |  27 ++-
 .../primitive/ignite-remote-server-config.xml      |  27 ++-
 .../primitive/persistence-settings-1.xml           |  27 ++-
 .../primitive/persistence-settings-2.xml           |  27 ++-
 .../store/src/test/resources/tests.properties      |  18 +-
 .../src/test/scripts/cassandra-load-tests.bat      |  18 +-
 .../store/src/test/scripts/cassandra-load-tests.sh |  17 +-
 .../store/src/test/scripts/ignite-load-tests.bat   |  18 +-
 .../store/src/test/scripts/ignite-load-tests.sh    |  17 +-
 .../cassandra/store/src/test/scripts/jvm-opt.sh    |  17 +-
 .../cassandra/store/src/test/scripts/jvm-opts.bat  |  18 +-
 .../test/scripts/recreate-cassandra-artifacts.bat  |  18 +-
 .../test/scripts/recreate-cassandra-artifacts.sh   |  17 +-
 .../clients/config/grid-client-config.properties   |  18 +-
 .../clients/config/grid-client-spring-config.xml   |  27 ++-
 modules/clients/php/licenses/apache-2.0.txt        | 202 ---------------------
 modules/clients/php/licenses/gg-community.txt      |  13 ++
 modules/clients/php/src/GridClient.php             |  17 +-
 modules/clients/php/src/GridClientCompute.php      |  17 +-
 .../clients/php/src/GridClientComputeBalancer.php  |  17 +-
 modules/clients/php/src/GridClientData.php         |  17 +-
 modules/clients/php/src/GridClientDataAffinity.php |  17 +-
 modules/clients/php/src/GridClientNode.php         |  17 +-
 modules/clients/php/src/GridClientNodeFilter.php   |  17 +-
 modules/clients/pom.xml                            |  47 +++--
 modules/clients/src/test/bin/start-nodes-ssh.sh    |  17 +-
 modules/clients/src/test/bin/start-nodes.cmd       |  18 +-
 modules/clients/src/test/bin/start-nodes.sh        |  17 +-
 modules/clients/src/test/bin/stop-nodes.cmd        |  18 +-
 modules/clients/src/test/bin/stop-nodes.sh         |  17 +-
 .../clients/src/test/config/jdbc-bin-config.xml    |  27 ++-
 .../src/test/config/jdbc-config-cache-store.xml    |  27 ++-
 modules/clients/src/test/config/jdbc-config.xml    |  27 ++-
 .../internal/TaskEventSubjectIdSelfTest.java       |  17 +-
 .../ClientAbstractMultiThreadedSelfTest.java       |  17 +-
 .../client/ClientDefaultCacheSelfTest.java         |  17 +-
 .../internal/client/ClientGetAffinityTask.java     |  17 +-
 .../ignite/internal/client/ClientHttpTask.java     |  17 +-
 .../ignite/internal/client/ClientNodeStartup.java  |  17 +-
 .../client/ClientReconnectionSelfTest.java         |  17 +-
 .../internal/client/ClientSslNodeStartup.java      |  17 +-
 .../internal/client/ClientSslParametersTest.java   |  17 +-
 .../internal/client/ClientStartNodeTask.java       |  17 +-
 .../ignite/internal/client/ClientStopNodeTask.java |  17 +-
 .../internal/client/ClientStringLengthTask.java    |  17 +-
 .../client/ClientTcpMultiThreadedSelfTest.java     |  17 +-
 .../client/ClientTcpSslAuthenticationSelfTest.java |  17 +-
 .../client/ClientTcpSslMultiThreadedSelfTest.java  |  17 +-
 .../ignite/internal/client/ClientTcpTask.java      |  17 +-
 ...pTaskExecutionAfterTopologyRestartSelfTest.java |  17 +-
 .../internal/client/ClientTestRestServer.java      |  17 +-
 .../ignite/internal/client/HashMapStore.java       |  17 +-
 .../ignite/internal/client/SleepTestTask.java      |  17 +-
 .../internal/client/TaskSingleJobSplitAdapter.java |  17 +-
 .../client/impl/ClientCacheFlagsCodecTest.java     |  17 +-
 .../client/impl/ClientComputeImplSelfTest.java     |  17 +-
 .../client/impl/ClientDataImplSelfTest.java        |  17 +-
 .../client/impl/ClientFutureAdapterSelfTest.java   |  17 +-
 .../ClientPropertiesConfigurationSelfTest.java     |  17 +-
 .../ClientAbstractConnectivitySelfTest.java        |  17 +-
 .../ClientAbstractMultiNodeSelfTest.java           |  17 +-
 .../client/integration/ClientAbstractSelfTest.java |  17 +-
 .../integration/ClientPreferDirectSelfTest.java    |  17 +-
 .../integration/ClientTcpConnectivitySelfTest.java |  17 +-
 .../ClientTcpDirectMultiNodeSelfTest.java          |  17 +-
 .../integration/ClientTcpDirectSelfTest.java       |  17 +-
 .../integration/ClientTcpMultiNodeSelfTest.java    |  17 +-
 .../client/integration/ClientTcpSelfTest.java      |  17 +-
 .../ClientTcpSslDirectMultiNodeSelfTest.java       |  17 +-
 .../integration/ClientTcpSslDirectSelfTest.java    |  17 +-
 .../integration/ClientTcpSslMultiNodeSelfTest.java |  17 +-
 .../client/integration/ClientTcpSslSelfTest.java   |  17 +-
 .../ClientTcpUnreachableMultiNodeSelfTest.java     |  17 +-
 .../client/router/ClientFailedInitSelfTest.java    |  17 +-
 .../client/router/RouterFactorySelfTest.java       |  17 +-
 .../client/router/TcpRouterAbstractSelfTest.java   |  17 +-
 .../client/router/TcpRouterMultiNodeSelfTest.java  |  17 +-
 .../internal/client/router/TcpRouterSelfTest.java  |  17 +-
 .../client/router/TcpSslRouterSelfTest.java        |  17 +-
 .../client/suite/IgniteClientTestSuite.java        |  17 +-
 .../internal/client/util/ClientByteUtilsTest.java  |  17 +-
 .../client/util/ClientConsistentHashSelfTest.java  |  17 +-
 .../client/util/ClientJavaHasherSelfTest.java      |  17 +-
 .../jdbc2/JdbcAbstractDmlStatementSelfTest.java    |  17 +-
 .../internal/jdbc2/JdbcAbstractSchemaCaseTest.java |  17 +-
 .../jdbc2/JdbcAbstractUpdateStatementSelfTest.java |  17 +-
 ...dbcBinaryMarshallerInsertStatementSelfTest.java |  17 +-
 ...JdbcBinaryMarshallerMergeStatementSelfTest.java |  17 +-
 .../apache/ignite/internal/jdbc2/JdbcBlobTest.java |  17 +-
 .../internal/jdbc2/JdbcBulkLoadSelfTest.java       |  17 +-
 .../internal/jdbc2/JdbcComplexQuerySelfTest.java   |  17 +-
 .../internal/jdbc2/JdbcConnectionReopenTest.java   |  17 +-
 .../internal/jdbc2/JdbcConnectionSelfTest.java     |  17 +-
 .../jdbc2/JdbcDeleteStatementSelfTest.java         |  17 +-
 .../jdbc2/JdbcDistributedJoinsQueryTest.java       |  17 +-
 .../jdbc2/JdbcDynamicIndexAbstractSelfTest.java    |  17 +-
 ...cDynamicIndexAtomicPartitionedNearSelfTest.java |  17 +-
 .../JdbcDynamicIndexAtomicPartitionedSelfTest.java |  17 +-
 .../JdbcDynamicIndexAtomicReplicatedSelfTest.java  |  17 +-
 ...cIndexTransactionalPartitionedNearSelfTest.java |  17 +-
 ...namicIndexTransactionalPartitionedSelfTest.java |  17 +-
 ...ynamicIndexTransactionalReplicatedSelfTest.java |  17 +-
 .../internal/jdbc2/JdbcEmptyCacheSelfTest.java     |  17 +-
 .../ignite/internal/jdbc2/JdbcErrorsSelfTest.java  |  17 +-
 .../jdbc2/JdbcInsertStatementSelfTest.java         |  17 +-
 .../internal/jdbc2/JdbcLocalCachesSelfTest.java    |  17 +-
 .../internal/jdbc2/JdbcMergeStatementSelfTest.java |  17 +-
 .../internal/jdbc2/JdbcMetadataSelfTest.java       |  17 +-
 .../jdbc2/JdbcNoCacheStreamingSelfTest.java        |  17 +-
 .../internal/jdbc2/JdbcNoDefaultCacheTest.java     |  17 +-
 .../jdbc2/JdbcPreparedStatementSelfTest.java       |  17 +-
 .../internal/jdbc2/JdbcResultSetSelfTest.java      |  17 +-
 .../internal/jdbc2/JdbcSchemaCaseSelfTest.java     |  17 +-
 .../ignite/internal/jdbc2/JdbcSpringSelfTest.java  |  17 +-
 .../jdbc2/JdbcStatementBatchingSelfTest.java       |  17 +-
 .../internal/jdbc2/JdbcStatementSelfTest.java      |  17 +-
 .../internal/jdbc2/JdbcStreamingSelfTest.java      |  17 +-
 .../jdbc2/JdbcStreamingToPublicCacheTest.java      |  17 +-
 .../jdbc2/JdbcUpdateStatementSelfTest.java         |  17 +-
 .../rest/AbstractRestProcessorSelfTest.java        |  17 +-
 .../rest/ChangeStateCommandHandlerTest.java        |  17 +-
 .../rest/ClientMemcachedProtocolSelfTest.java      |  17 +-
 .../rest/JettyRestProcessorAbstractSelfTest.java   |  17 +-
 ...ttyRestProcessorAuthenticationAbstractTest.java |  17 +-
 ...stProcessorAuthenticationWithCredsSelfTest.java |  17 +-
 ...stProcessorAuthenticationWithTokenSelfTest.java |  17 +-
 .../rest/JettyRestProcessorBaselineSelfTest.java   |  17 +-
 .../rest/JettyRestProcessorCommonSelfTest.java     |  17 +-
 .../rest/JettyRestProcessorGetAllAsArrayTest.java  |  17 +-
 .../rest/JettyRestProcessorSignedSelfTest.java     |  17 +-
 .../rest/JettyRestProcessorUnsignedSelfTest.java   |  17 +-
 .../rest/RestBinaryProtocolSelfTest.java           |  17 +-
 .../rest/RestMemcacheProtocolSelfTest.java         |  17 +-
 .../rest/RestProcessorMultiStartSelfTest.java      |  17 +-
 .../rest/RestProcessorStartSelfTest.java           |  17 +-
 .../internal/processors/rest/SimplePerson.java     |  17 +-
 .../rest/TaskCommandHandlerSelfTest.java           |  17 +-
 .../rest/TcpRestUnmarshalVulnerabilityTest.java    |  17 +-
 .../internal/processors/rest/TestBinaryClient.java |  17 +-
 .../processors/rest/TestMemcacheClient.java        |  17 +-
 .../ignite/internal/processors/rest/TestTask1.java |  17 +-
 .../ignite/internal/processors/rest/TestTask2.java |  17 +-
 .../rest/protocols/tcp/MockNioSession.java         |  17 +-
 .../rest/protocols/tcp/TcpRestParserSelfTest.java  |  17 +-
 .../tcp/redis/RedisCommonAbstractTest.java         |  17 +-
 .../tcp/redis/RedisProtocolConnectSelfTest.java    |  17 +-
 .../tcp/redis/RedisProtocolGetAllAsArrayTest.java  |  17 +-
 .../tcp/redis/RedisProtocolServerSelfTest.java     |  17 +-
 ...ProtocolStringAtomicDatastructuresSelfTest.java |  17 +-
 .../tcp/redis/RedisProtocolStringSelfTest.java     |  17 +-
 .../ignite/jdbc/AbstractJdbcPojoQuerySelfTest.java |  17 +-
 .../ignite/jdbc/JdbcComplexQuerySelfTest.java      |  17 +-
 .../apache/ignite/jdbc/JdbcConnectionSelfTest.java |  17 +-
 .../ignite/jdbc/JdbcDefaultNoOpCacheTest.java      |  17 +-
 .../apache/ignite/jdbc/JdbcEmptyCacheSelfTest.java |  17 +-
 .../ignite/jdbc/JdbcErrorsAbstractSelfTest.java    |  17 +-
 .../ignite/jdbc/JdbcLocalCachesSelfTest.java       |  17 +-
 .../apache/ignite/jdbc/JdbcMetadataSelfTest.java   |  17 +-
 .../apache/ignite/jdbc/JdbcNoDefaultCacheTest.java |  17 +-
 .../ignite/jdbc/JdbcPojoLegacyQuerySelfTest.java   |  17 +-
 .../apache/ignite/jdbc/JdbcPojoQuerySelfTest.java  |  17 +-
 .../ignite/jdbc/JdbcPreparedStatementSelfTest.java |  17 +-
 .../apache/ignite/jdbc/JdbcResultSetSelfTest.java  |  17 +-
 .../apache/ignite/jdbc/JdbcStatementSelfTest.java  |  17 +-
 .../ignite/jdbc/JdbcThinMetadataSqlMatchTest.java  |  17 +-
 .../ignite/jdbc/JdbcVersionMismatchSelfTest.java   |  17 +-
 .../jdbc/suite/IgniteJdbcDriverMvccTestSuite.java  |  17 +-
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java      |  17 +-
 ...teJdbcThinDriverAffinityAwarenessTestSuite.java |  17 +-
 .../thin/JdbcThinAbstractDmlStatementSelfTest.java |  17 +-
 .../ignite/jdbc/thin/JdbcThinAbstractSelfTest.java |  17 +-
 .../JdbcThinAbstractUpdateStatementSelfTest.java   |  17 +-
 .../thin/JdbcThinAffinityAwarenessSelfTest.java    |  17 +-
 ...cThinAffinityAwarenessTransactionsSelfTest.java |  17 +-
 .../JdbcThinAuthenticateConnectionSelfTest.java    |  17 +-
 .../thin/JdbcThinAutoCloseServerCursorTest.java    |  17 +-
 .../ignite/jdbc/thin/JdbcThinBatchSelfTest.java    |  17 +-
 .../thin/JdbcThinBulkLoadAbstractSelfTest.java     |  17 +-
 ...cThinBulkLoadAtomicPartitionedNearSelfTest.java |  17 +-
 .../JdbcThinBulkLoadAtomicPartitionedSelfTest.java |  17 +-
 .../JdbcThinBulkLoadAtomicReplicatedSelfTest.java  |  17 +-
 ...lkLoadTransactionalPartitionedNearSelfTest.java |  17 +-
 ...inBulkLoadTransactionalPartitionedSelfTest.java |  17 +-
 ...hinBulkLoadTransactionalReplicatedSelfTest.java |  17 +-
 .../JdbcThinComplexDmlDdlCustomSchemaSelfTest.java |  17 +-
 .../jdbc/thin/JdbcThinComplexDmlDdlSelfTest.java   |  17 +-
 ...inComplexDmlDdlSkipReducerOnUpdateSelfTest.java |  17 +-
 .../jdbc/thin/JdbcThinComplexQuerySelfTest.java    |  17 +-
 .../JdbcThinConnectionMultipleAddressesTest.java   |  17 +-
 .../JdbcThinConnectionMvccEnabledSelfTest.java     |  17 +-
 .../jdbc/thin/JdbcThinConnectionSSLTest.java       |  17 +-
 .../jdbc/thin/JdbcThinConnectionSelfTest.java      |  17 +-
 .../thin/JdbcThinConnectionTimeoutSelfTest.java    |  17 +-
 .../thin/JdbcThinDataPageScanPropertySelfTest.java |  17 +-
 .../jdbc/thin/JdbcThinDataSourceSelfTest.java      |  17 +-
 .../jdbc/thin/JdbcThinDeleteStatementSelfTest.java |  17 +-
 .../thin/JdbcThinDynamicIndexAbstractSelfTest.java |  17 +-
 ...nDynamicIndexAtomicPartitionedNearSelfTest.java |  17 +-
 ...cThinDynamicIndexAtomicPartitionedSelfTest.java |  17 +-
 ...bcThinDynamicIndexAtomicReplicatedSelfTest.java |  17 +-
 ...cIndexTransactionalPartitionedNearSelfTest.java |  17 +-
 ...namicIndexTransactionalPartitionedSelfTest.java |  17 +-
 ...ynamicIndexTransactionalReplicatedSelfTest.java |  17 +-
 .../jdbc/thin/JdbcThinEmptyCacheSelfTest.java      |  17 +-
 .../ignite/jdbc/thin/JdbcThinErrorsSelfTest.java   |  17 +-
 .../jdbc/thin/JdbcThinInsertStatementSelfTest.java |  17 +-
 ...InsertStatementSkipReducerOnUpdateSelfTest.java |  17 +-
 .../jdbc/thin/JdbcThinLocalQueriesSelfTest.java    |  17 +-
 .../jdbc/thin/JdbcThinMergeStatementSelfTest.java  |  17 +-
 ...nMergeStatementSkipReducerOnUpdateSelfTest.java |  17 +-
 .../thin/JdbcThinMetadataPrimaryKeysSelfTest.java  |  17 +-
 .../ignite/jdbc/thin/JdbcThinMetadataSelfTest.java |  17 +-
 .../thin/JdbcThinMissingLongArrayResultsTest.java  |  17 +-
 .../jdbc/thin/JdbcThinMultiStatementSelfTest.java  |  17 +-
 .../jdbc/thin/JdbcThinNoDefaultSchemaTest.java     |  17 +-
 .../thin/JdbcThinPreparedStatementLeakTest.java    |  17 +-
 .../thin/JdbcThinPreparedStatementSelfTest.java    |  17 +-
 .../jdbc/thin/JdbcThinResultSetSelfTest.java       |  17 +-
 .../jdbc/thin/JdbcThinSchemaCaseSelfTest.java      |  17 +-
 .../jdbc/thin/JdbcThinSelectAfterAlterTable.java   |  17 +-
 .../jdbc/thin/JdbcThinStatementCancelSelfTest.java |  17 +-
 .../jdbc/thin/JdbcThinStatementSelfTest.java       |  17 +-
 .../thin/JdbcThinStatementTimeoutSelfTest.java     |  17 +-
 .../thin/JdbcThinStreamingAbstractSelfTest.java    |  17 +-
 .../thin/JdbcThinStreamingNotOrderedSelfTest.java  |  17 +-
 .../thin/JdbcThinStreamingOrderedSelfTest.java     |  17 +-
 .../thin/JdbcThinStreamingResetStreamTest.java     |  17 +-
 .../apache/ignite/jdbc/thin/JdbcThinTcpIoTest.java |  17 +-
 ...dbcThinTransactionsAbstractComplexSelfTest.java |  17 +-
 ...ransactionsClientAutoCommitComplexSelfTest.java |  17 +-
 ...nsactionsClientNoAutoCommitComplexSelfTest.java |  17 +-
 .../thin/JdbcThinTransactionsLeaksMvccTest.java    |  17 +-
 .../jdbc/thin/JdbcThinTransactionsSelfTest.java    |  17 +-
 ...ransactionsServerAutoCommitComplexSelfTest.java |  17 +-
 ...nsactionsServerNoAutoCommitComplexSelfTest.java |  17 +-
 ...dbcThinTransactionsWithMvccEnabledSelfTest.java |  17 +-
 .../jdbc/thin/JdbcThinUpdateStatementSelfTest.java |  17 +-
 ...UpdateStatementSkipReducerOnUpdateSelfTest.java |  17 +-
 .../jdbc/thin/JdbcThinWalModeChangeSelfTest.java   |  17 +-
 ...nsactionFinishOnDeactivatedClusterSelfTest.java |  17 +-
 .../loadtests/client/ClientCacheBenchmark.java     |  17 +-
 .../client/ClientMarshallerBenchmarkTest.java      |  17 +-
 .../loadtests/client/ClientTcpSslLoadTest.java     |  17 +-
 modules/clients/src/test/keystore/ca/oneca.cnf     |  22 ++-
 modules/clients/src/test/keystore/ca/twoca.cnf     |  22 ++-
 modules/clients/src/test/keystore/generate.sh      |  21 +--
 .../src/test/resources/jetty/rest-jetty-ssl.xml    |  27 ++-
 .../src/test/resources/jetty/rest-jetty.xml        |  27 ++-
 .../src/test/resources/jetty/router-jetty-ssl.xml  |  27 ++-
 .../src/test/resources/jetty/router-jetty.xml      |  27 ++-
 modules/clients/src/test/resources/log4j.xml       |  27 ++-
 .../clients/src/test/resources/spring-cache.xml    |  27 ++-
 .../src/test/resources/spring-router-ssl.xml       |  27 ++-
 .../clients/src/test/resources/spring-router.xml   |  27 ++-
 .../src/test/resources/spring-server-node.xml      |  27 ++-
 .../src/test/resources/spring-server-ssl-node.xml  |  27 ++-
 modules/cloud/licenses/apache-2.0.txt              | 202 ---------------------
 modules/cloud/licenses/gg-community.txt            |  13 ++
 modules/cloud/pom.xml                              |  37 ++--
 .../ipfinder/cloud/TcpDiscoveryCloudIpFinder.java  |  17 +-
 .../discovery/tcp/ipfinder/cloud/package-info.java |  17 +-
 .../cloud/TcpDiscoveryCloudIpFinderSelfTest.java   |  17 +-
 .../discovery/tcp/ipfinder/cloud/package-info.java |  17 +-
 .../ignite/testsuites/IgniteCloudTestSuite.java    |  17 +-
 modules/codegen/pom.xml                            |  37 ++--
 .../ignite/codegen/MessageCodeGenerator.java       |  17 +-
 modules/compatibility/licenses/apache-2.0.txt      | 202 ---------------------
 modules/compatibility/licenses/gg-community.txt    |  13 ++
 modules/compatibility/pom.xml                      |  39 ++--
 .../compatibility/PdsWithTtlCompatibilityTest.java |  17 +-
 .../apache/ignite/compatibility/package-info.java  |  17 +-
 .../persistence/FoldersReuseCompatibilityTest.java |  17 +-
 .../IgnitePKIndexesMigrationToUnwrapPkTest.java    |  18 +-
 ...IgnitePersistenceCompatibilityAbstractTest.java |  17 +-
 ...gratingToWalV2SerializerWithCompactionTest.java |  17 +-
 .../PersistenceBasicCompatibilityTest.java         |  17 +-
 .../compatibility/persistence/package-info.java    |  17 +-
 .../junits/CompatibilityTestsFacade.java           |  17 +-
 .../testframework/junits/Dependency.java           |  17 +-
 .../junits/IgniteCompatibilityAbstractTest.java    |  17 +-
 .../junits/IgniteCompatibilityNodeRunner.java      |  17 +-
 .../junits/logger/ListenedGridTestLog4jLogger.java |  17 +-
 .../testframework/junits/logger/package-info.java  |  17 +-
 .../testframework/junits/package-info.java         |  17 +-
 .../compatibility/testframework/package-info.java  |  17 +-
 .../plugins/DisabledValidationProcessor.java       |  17 +-
 .../plugins/TestCompatibilityPluginProvider.java   |  17 +-
 .../testframework/plugins/package-info.java        |  17 +-
 .../util/CompatibilityTestsUtils.java              |  17 +-
 .../testframework/util/MavenUtils.java             |  17 +-
 .../testframework/util/package-info.java           |  17 +-
 .../IgniteCompatibilityBasicTestSuite.java         |  17 +-
 .../compatibility/testsuites/package-info.java     |  17 +-
 modules/compress/pom.xml                           |  37 ++--
 .../compress/CompressionProcessorImpl.java         |  17 +-
 .../processors/compress/NativeFileSystemLinux.java |  17 +-
 .../processors/compress/NativeFileSystemPosix.java |  17 +-
 .../compress/CompressionConfigurationTest.java     |  17 +-
 .../compress/CompressionProcessorTest.java         |  17 +-
 .../DiskPageCompressionIntegrationAsyncTest.java   |  17 +-
 .../DiskPageCompressionIntegrationTest.java        |  17 +-
 .../processors/compress/FileSystemUtilsTest.java   |  17 +-
 .../testsuites/IgnitePdsCompressionTestSuite.java  |  17 +-
 .../testsuites/IgnitePdsCompressionTestSuite2.java |  17 +-
 modules/core/licenses/apache-2.0.txt               | 202 ---------------------
 modules/core/licenses/gg-community.txt             |  13 ++
 modules/core/pom.xml                               |  55 +++---
 .../java/org/apache/ignite/DataRegionMetrics.java  |  17 +-
 .../apache/ignite/DataRegionMetricsAdapter.java    |  29 ++-
 .../apache/ignite/DataRegionMetricsProvider.java   |  17 +-
 .../java/org/apache/ignite/DataStorageMetrics.java |  17 +-
 .../apache/ignite/DataStorageMetricsAdapter.java   |  29 ++-
 .../src/main/java/org/apache/ignite/Ignite.java    |  17 +-
 .../java/org/apache/ignite/IgniteAtomicLong.java   |  17 +-
 .../org/apache/ignite/IgniteAtomicReference.java   |  17 +-
 .../org/apache/ignite/IgniteAtomicSequence.java    |  17 +-
 .../org/apache/ignite/IgniteAtomicStamped.java     |  17 +-
 .../ignite/IgniteAuthenticationException.java      |  17 +-
 .../main/java/org/apache/ignite/IgniteBinary.java  |  17 +-
 .../main/java/org/apache/ignite/IgniteCache.java   |  17 +-
 .../ignite/IgniteCacheRestartingException.java     |  18 +-
 .../org/apache/ignite/IgniteCheckedException.java  |  17 +-
 .../ignite/IgniteClientDisconnectedException.java  |  17 +-
 .../main/java/org/apache/ignite/IgniteCluster.java |  17 +-
 .../main/java/org/apache/ignite/IgniteCompute.java |  17 +-
 .../java/org/apache/ignite/IgniteCondition.java    |  17 +-
 .../org/apache/ignite/IgniteCountDownLatch.java    |  17 +-
 .../java/org/apache/ignite/IgniteDataStreamer.java |  17 +-
 .../ignite/IgniteDataStreamerTimeoutException.java |  17 +-
 .../apache/ignite/IgniteDeploymentException.java   |  17 +-
 .../main/java/org/apache/ignite/IgniteEvents.java  |  17 +-
 .../java/org/apache/ignite/IgniteException.java    |  17 +-
 .../java/org/apache/ignite/IgniteFileSystem.java   |  17 +-
 .../apache/ignite/IgniteIllegalStateException.java |  17 +-
 .../apache/ignite/IgniteInterruptedException.java  |  17 +-
 .../java/org/apache/ignite/IgniteJdbcDriver.java   |  17 +-
 .../apache/ignite/IgniteJdbcThinDataSource.java    |  17 +-
 .../org/apache/ignite/IgniteJdbcThinDriver.java    |  17 +-
 .../main/java/org/apache/ignite/IgniteLock.java    |  17 +-
 .../main/java/org/apache/ignite/IgniteLogger.java  |  17 +-
 .../java/org/apache/ignite/IgniteMessaging.java    |  17 +-
 .../main/java/org/apache/ignite/IgniteQueue.java   |  17 +-
 .../java/org/apache/ignite/IgniteScheduler.java    |  17 +-
 .../java/org/apache/ignite/IgniteSemaphore.java    |  17 +-
 .../java/org/apache/ignite/IgniteServices.java     |  17 +-
 .../src/main/java/org/apache/ignite/IgniteSet.java |  17 +-
 .../main/java/org/apache/ignite/IgniteState.java   |  17 +-
 .../org/apache/ignite/IgniteSystemProperties.java  |  17 +-
 .../java/org/apache/ignite/IgniteTransactions.java |  17 +-
 .../src/main/java/org/apache/ignite/Ignition.java  |  17 +-
 .../java/org/apache/ignite/IgnitionListener.java   |  17 +-
 .../main/java/org/apache/ignite/MemoryMetrics.java |  17 +-
 .../java/org/apache/ignite/PersistenceMetrics.java |  17 +-
 .../apache/ignite/binary/BinaryBasicIdMapper.java  |  17 +-
 .../ignite/binary/BinaryBasicNameMapper.java       |  17 +-
 .../ignite/binary/BinaryCollectionFactory.java     |  17 +-
 .../java/org/apache/ignite/binary/BinaryField.java |  17 +-
 .../org/apache/ignite/binary/BinaryIdMapper.java   |  17 +-
 .../ignite/binary/BinaryInvalidTypeException.java  |  17 +-
 .../org/apache/ignite/binary/BinaryMapFactory.java |  17 +-
 .../org/apache/ignite/binary/BinaryNameMapper.java |  17 +-
 .../org/apache/ignite/binary/BinaryObject.java     |  17 +-
 .../apache/ignite/binary/BinaryObjectBuilder.java  |  17 +-
 .../ignite/binary/BinaryObjectException.java       |  17 +-
 .../org/apache/ignite/binary/BinaryRawReader.java  |  17 +-
 .../org/apache/ignite/binary/BinaryRawWriter.java  |  17 +-
 .../org/apache/ignite/binary/BinaryReader.java     |  17 +-
 .../ignite/binary/BinaryReflectiveSerializer.java  |  17 +-
 .../org/apache/ignite/binary/BinarySerializer.java |  17 +-
 .../java/org/apache/ignite/binary/BinaryType.java  |  17 +-
 .../ignite/binary/BinaryTypeConfiguration.java     |  17 +-
 .../org/apache/ignite/binary/BinaryWriter.java     |  17 +-
 .../org/apache/ignite/binary/Binarylizable.java    |  17 +-
 .../org/apache/ignite/binary/package-info.java     |  17 +-
 .../apache/ignite/cache/CacheAtomicityMode.java    |  17 +-
 .../java/org/apache/ignite/cache/CacheEntry.java   |  17 +-
 .../cache/CacheEntryEventSerializableFilter.java   |  17 +-
 .../apache/ignite/cache/CacheEntryProcessor.java   |  17 +-
 .../apache/ignite/cache/CacheExistsException.java  |  17 +-
 .../org/apache/ignite/cache/CacheInterceptor.java  |  17 +-
 .../ignite/cache/CacheInterceptorAdapter.java      |  17 +-
 .../apache/ignite/cache/CacheInterceptorEntry.java |  17 +-
 .../apache/ignite/cache/CacheKeyConfiguration.java |  17 +-
 .../java/org/apache/ignite/cache/CacheManager.java |  17 +-
 .../java/org/apache/ignite/cache/CacheMetrics.java |  17 +-
 .../java/org/apache/ignite/cache/CacheMode.java    |  17 +-
 .../ignite/cache/CachePartialUpdateException.java  |  17 +-
 .../org/apache/ignite/cache/CachePeekMode.java     |  17 +-
 .../apache/ignite/cache/CacheRebalanceMode.java    |  17 +-
 .../ignite/cache/CacheServerNotFoundException.java |  17 +-
 .../cache/CacheWriteSynchronizationMode.java       |  17 +-
 .../org/apache/ignite/cache/CachingProvider.java   |  17 +-
 .../apache/ignite/cache/PartitionLossPolicy.java   |  17 +-
 .../java/org/apache/ignite/cache/QueryEntity.java  |  17 +-
 .../org/apache/ignite/cache/QueryEntityPatch.java  |  17 +-
 .../java/org/apache/ignite/cache/QueryIndex.java   |  17 +-
 .../org/apache/ignite/cache/QueryIndexType.java    |  17 +-
 .../org/apache/ignite/cache/affinity/Affinity.java |  17 +-
 .../affinity/AffinityCentralizedFunction.java      |  17 +-
 .../ignite/cache/affinity/AffinityFunction.java    |  17 +-
 .../cache/affinity/AffinityFunctionContext.java    |  17 +-
 .../apache/ignite/cache/affinity/AffinityKey.java  |  17 +-
 .../ignite/cache/affinity/AffinityKeyMapped.java   |  17 +-
 .../ignite/cache/affinity/AffinityKeyMapper.java   |  17 +-
 .../apache/ignite/cache/affinity/AffinityUuid.java |  17 +-
 .../apache/ignite/cache/affinity/package-info.java |  17 +-
 .../ClusterNodeAttributeAffinityBackupFilter.java  |  17 +-
 .../rendezvous/RendezvousAffinityFunction.java     |  17 +-
 .../cache/affinity/rendezvous/package-info.java    |  17 +-
 .../cache/eviction/AbstractEvictionPolicy.java     |  17 +-
 .../eviction/AbstractEvictionPolicyFactory.java    |  17 +-
 .../ignite/cache/eviction/EvictableEntry.java      |  17 +-
 .../ignite/cache/eviction/EvictionFilter.java      |  17 +-
 .../ignite/cache/eviction/EvictionPolicy.java      |  17 +-
 .../cache/eviction/fifo/FifoEvictionPolicy.java    |  17 +-
 .../eviction/fifo/FifoEvictionPolicyFactory.java   |  17 +-
 .../eviction/fifo/FifoEvictionPolicyMBean.java     |  17 +-
 .../ignite/cache/eviction/fifo/package-info.java   |  17 +-
 .../cache/eviction/igfs/IgfsEvictionFilter.java    |  17 +-
 .../igfs/IgfsPerBlockLruEvictionPolicy.java        |  17 +-
 .../igfs/IgfsPerBlockLruEvictionPolicyMXBean.java  |  17 +-
 .../ignite/cache/eviction/igfs/package-info.java   |  17 +-
 .../cache/eviction/lru/LruEvictionPolicy.java      |  17 +-
 .../eviction/lru/LruEvictionPolicyFactory.java     |  17 +-
 .../cache/eviction/lru/LruEvictionPolicyMBean.java |  17 +-
 .../ignite/cache/eviction/lru/package-info.java    |  17 +-
 .../apache/ignite/cache/eviction/package-info.java |  17 +-
 .../ignite/cache/eviction/random/package-info.java |  17 +-
 .../eviction/sorted/SortedEvictionPolicy.java      |  17 +-
 .../sorted/SortedEvictionPolicyFactory.java        |  17 +-
 .../eviction/sorted/SortedEvictionPolicyMBean.java |  17 +-
 .../ignite/cache/eviction/sorted/package-info.java |  17 +-
 .../java/org/apache/ignite/cache/package-info.java |  17 +-
 .../cache/query/AbstractContinuousQuery.java       |  17 +-
 .../ignite/cache/query/BulkLoadContextCursor.java  |  17 +-
 .../ignite/cache/query/CacheQueryEntryEvent.java   |  17 +-
 .../apache/ignite/cache/query/ContinuousQuery.java |  17 +-
 .../query/ContinuousQueryWithTransformer.java      |  17 +-
 .../ignite/cache/query/FieldsQueryCursor.java      |  17 +-
 .../java/org/apache/ignite/cache/query/Query.java  |  17 +-
 .../cache/query/QueryCancelledException.java       |  17 +-
 .../org/apache/ignite/cache/query/QueryCursor.java |  17 +-
 .../ignite/cache/query/QueryDetailMetrics.java     |  17 +-
 .../apache/ignite/cache/query/QueryMetrics.java    |  17 +-
 .../ignite/cache/query/QueryRetryException.java    |  17 +-
 .../org/apache/ignite/cache/query/ScanQuery.java   |  17 +-
 .../org/apache/ignite/cache/query/SpiQuery.java    |  17 +-
 .../apache/ignite/cache/query/SqlFieldsQuery.java  |  17 +-
 .../org/apache/ignite/cache/query/SqlQuery.java    |  17 +-
 .../org/apache/ignite/cache/query/TextQuery.java   |  17 +-
 .../cache/query/annotations/QueryGroupIndex.java   |  17 +-
 .../cache/query/annotations/QuerySqlField.java     |  17 +-
 .../cache/query/annotations/QuerySqlFunction.java  |  17 +-
 .../cache/query/annotations/QueryTextField.java    |  17 +-
 .../cache/query/annotations/package-info.java      |  17 +-
 .../apache/ignite/cache/query/package-info.java    |  17 +-
 .../cache/store/CacheLoadOnlyStoreAdapter.java     |  17 +-
 .../org/apache/ignite/cache/store/CacheStore.java  |  17 +-
 .../ignite/cache/store/CacheStoreAdapter.java      |  17 +-
 .../ignite/cache/store/CacheStoreSession.java      |  17 +-
 .../cache/store/CacheStoreSessionListener.java     |  17 +-
 .../cache/store/jdbc/CacheAbstractJdbcStore.java   |  17 +-
 .../cache/store/jdbc/CacheJdbcBlobStore.java       |  17 +-
 .../store/jdbc/CacheJdbcBlobStoreFactory.java      |  17 +-
 .../cache/store/jdbc/CacheJdbcPojoStore.java       |  17 +-
 .../store/jdbc/CacheJdbcPojoStoreFactory.java      |  17 +-
 .../store/jdbc/CacheJdbcStoreSessionListener.java  |  17 +-
 .../apache/ignite/cache/store/jdbc/JdbcType.java   |  17 +-
 .../cache/store/jdbc/JdbcTypeDefaultHasher.java    |  17 +-
 .../ignite/cache/store/jdbc/JdbcTypeField.java     |  17 +-
 .../ignite/cache/store/jdbc/JdbcTypeHasher.java    |  17 +-
 .../store/jdbc/JdbcTypesDefaultTransformer.java    |  17 +-
 .../cache/store/jdbc/JdbcTypesTransformer.java     |  17 +-
 .../cache/store/jdbc/dialect/BasicJdbcDialect.java |  17 +-
 .../cache/store/jdbc/dialect/DB2Dialect.java       |  17 +-
 .../ignite/cache/store/jdbc/dialect/H2Dialect.java |  17 +-
 .../cache/store/jdbc/dialect/JdbcDialect.java      |  17 +-
 .../cache/store/jdbc/dialect/MySQLDialect.java     |  17 +-
 .../cache/store/jdbc/dialect/OracleDialect.java    |  17 +-
 .../cache/store/jdbc/dialect/SQLServerDialect.java |  17 +-
 .../cache/store/jdbc/dialect/package-info.java     |  17 +-
 .../ignite/cache/store/jdbc/package-info.java      |  17 +-
 .../apache/ignite/cache/store/package-info.java    |  17 +-
 .../client/ClientAuthenticationException.java      |  17 +-
 .../client/ClientAuthorizationException.java       |  17 +-
 .../java/org/apache/ignite/client/ClientCache.java |  17 +-
 .../ignite/client/ClientCacheConfiguration.java    |  17 +-
 .../ignite/client/ClientConnectionException.java   |  17 +-
 .../org/apache/ignite/client/ClientException.java  |  17 +-
 .../org/apache/ignite/client/IgniteClient.java     |  17 +-
 .../java/org/apache/ignite/client/SslMode.java     |  17 +-
 .../java/org/apache/ignite/client/SslProtocol.java |  17 +-
 .../org/apache/ignite/cluster/BaselineNode.java    |  17 +-
 .../org/apache/ignite/cluster/ClusterGroup.java    |  17 +-
 .../ignite/cluster/ClusterGroupEmptyException.java |  17 +-
 .../org/apache/ignite/cluster/ClusterMetrics.java  |  17 +-
 .../org/apache/ignite/cluster/ClusterNode.java     |  17 +-
 .../ignite/cluster/ClusterStartNodeResult.java     |  17 +-
 .../ignite/cluster/ClusterTopologyException.java   |  17 +-
 .../org/apache/ignite/cluster/package-info.java    |  17 +-
 .../compute/ComputeExecutionRejectedException.java |  17 +-
 .../java/org/apache/ignite/compute/ComputeJob.java |  17 +-
 .../apache/ignite/compute/ComputeJobAdapter.java   |  17 +-
 .../apache/ignite/compute/ComputeJobAfterSend.java |  17 +-
 .../ignite/compute/ComputeJobBeforeFailover.java   |  17 +-
 .../apache/ignite/compute/ComputeJobContext.java   |  17 +-
 .../ignite/compute/ComputeJobContinuation.java     |  17 +-
 .../compute/ComputeJobContinuationAdapter.java     |  17 +-
 .../compute/ComputeJobFailoverException.java       |  17 +-
 .../ignite/compute/ComputeJobMasterLeaveAware.java |  17 +-
 .../apache/ignite/compute/ComputeJobResult.java    |  17 +-
 .../ignite/compute/ComputeJobResultPolicy.java     |  17 +-
 .../apache/ignite/compute/ComputeJobSibling.java   |  17 +-
 .../apache/ignite/compute/ComputeLoadBalancer.java |  17 +-
 .../org/apache/ignite/compute/ComputeTask.java     |  17 +-
 .../apache/ignite/compute/ComputeTaskAdapter.java  |  17 +-
 .../compute/ComputeTaskCancelledException.java     |  17 +-
 .../compute/ComputeTaskContinuousMapper.java       |  17 +-
 .../apache/ignite/compute/ComputeTaskFuture.java   |  17 +-
 .../apache/ignite/compute/ComputeTaskMapAsync.java |  17 +-
 .../org/apache/ignite/compute/ComputeTaskName.java |  17 +-
 .../ignite/compute/ComputeTaskNoResultCache.java   |  17 +-
 .../apache/ignite/compute/ComputeTaskSession.java  |  17 +-
 .../ComputeTaskSessionAttributeListener.java       |  17 +-
 .../compute/ComputeTaskSessionFullSupport.java     |  17 +-
 .../ignite/compute/ComputeTaskSessionScope.java    |  17 +-
 .../org/apache/ignite/compute/ComputeTaskSpis.java |  17 +-
 .../ignite/compute/ComputeTaskSplitAdapter.java    |  17 +-
 .../compute/ComputeTaskTimeoutException.java       |  17 +-
 .../compute/ComputeUserUndeclaredException.java    |  17 +-
 .../org/apache/ignite/compute/gridify/Gridify.java |  17 +-
 .../ignite/compute/gridify/GridifyArgument.java    |  17 +-
 .../ignite/compute/gridify/GridifyInput.java       |  17 +-
 .../ignite/compute/gridify/GridifyInterceptor.java |  17 +-
 .../ignite/compute/gridify/GridifyNodeFilter.java  |  17 +-
 .../compute/gridify/GridifyRuntimeException.java   |  17 +-
 .../ignite/compute/gridify/GridifySetToSet.java    |  17 +-
 .../ignite/compute/gridify/GridifySetToValue.java  |  17 +-
 .../ignite/compute/gridify/GridifyTaskAdapter.java |  17 +-
 .../compute/gridify/GridifyTaskSplitAdapter.java   |  17 +-
 .../gridify/aop/GridifyArgumentAdapter.java        |  17 +-
 .../gridify/aop/GridifyDefaultRangeTask.java       |  17 +-
 .../compute/gridify/aop/GridifyDefaultTask.java    |  17 +-
 .../gridify/aop/GridifySetToSetAbstractAspect.java |  17 +-
 .../aop/GridifySetToValueAbstractAspect.java       |  17 +-
 .../ignite/compute/gridify/aop/package-info.java   |  17 +-
 .../ignite/compute/gridify/package-info.java       |  17 +-
 .../org/apache/ignite/compute/package-info.java    |  17 +-
 .../ignite/configuration/AddressResolver.java      |  17 +-
 .../ignite/configuration/AtomicConfiguration.java  |  17 +-
 .../ignite/configuration/BasicAddressResolver.java |  17 +-
 .../ignite/configuration/BinaryConfiguration.java  |  17 +-
 .../ignite/configuration/CacheConfiguration.java   |  17 +-
 .../ignite/configuration/CheckpointWriteOrder.java |  29 ++-
 .../ignite/configuration/ClientConfiguration.java  |  17 +-
 .../ClientConnectorConfiguration.java              |  17 +-
 .../configuration/CollectionConfiguration.java     |  17 +-
 .../configuration/CommunicationFailureContext.java |  17 +-
 .../CommunicationFailureResolver.java              |  17 +-
 .../configuration/ConnectorConfiguration.java      |  17 +-
 .../configuration/ConnectorMessageInterceptor.java |  17 +-
 .../ignite/configuration/DataPageEvictionMode.java |  29 ++-
 .../configuration/DataRegionConfiguration.java     |  17 +-
 .../configuration/DataStorageConfiguration.java    |  17 +-
 .../DefaultCommunicationFailureResolver.java       |  17 +-
 .../ignite/configuration/DeploymentMode.java       |  17 +-
 .../ignite/configuration/DiskPageCompression.java  |  17 +-
 .../configuration/ExecutorConfiguration.java       |  17 +-
 .../configuration/FileSystemConfiguration.java     |  17 +-
 .../ignite/configuration/HadoopConfiguration.java  |  17 +-
 .../ignite/configuration/IgniteConfiguration.java  |  17 +-
 .../configuration/IgniteReflectionFactory.java     |  17 +-
 .../ignite/configuration/MemoryConfiguration.java  |  17 +-
 .../configuration/MemoryPolicyConfiguration.java   |  17 +-
 .../configuration/NearCacheConfiguration.java      |  17 +-
 .../ignite/configuration/OdbcConfiguration.java    |  17 +-
 .../PersistentStoreConfiguration.java              |  17 +-
 .../configuration/PlatformConfiguration.java       |  17 +-
 .../ignite/configuration/SerializeSeparately.java  |  17 +-
 .../configuration/SqlConnectorConfiguration.java   |  17 +-
 .../ignite/configuration/TopologyValidator.java    |  17 +-
 .../configuration/TransactionConfiguration.java    |  17 +-
 .../org/apache/ignite/configuration/WALMode.java   |  17 +-
 .../apache/ignite/configuration/package-info.java  |  17 +-
 .../java/org/apache/ignite/events/CacheEvent.java  |  17 +-
 .../ignite/events/CacheQueryExecutedEvent.java     |  17 +-
 .../apache/ignite/events/CacheQueryReadEvent.java  |  17 +-
 .../ignite/events/CacheRebalancingEvent.java       |  17 +-
 .../org/apache/ignite/events/CheckpointEvent.java  |  17 +-
 .../ignite/events/ClusterActivationEvent.java      |  17 +-
 .../org/apache/ignite/events/DeploymentEvent.java  |  17 +-
 .../org/apache/ignite/events/DiscoveryEvent.java   |  17 +-
 .../main/java/org/apache/ignite/events/Event.java  |  17 +-
 .../org/apache/ignite/events/EventAdapter.java     |  17 +-
 .../org/apache/ignite/events/EventLocalOrder.java  |  17 +-
 .../java/org/apache/ignite/events/EventType.java   |  17 +-
 .../java/org/apache/ignite/events/IgfsEvent.java   |  17 +-
 .../java/org/apache/ignite/events/JobEvent.java    |  17 +-
 .../java/org/apache/ignite/events/TaskEvent.java   |  17 +-
 .../events/TransactionStateChangedEvent.java       |  17 +-
 .../ignite/events/WalSegmentArchivedEvent.java     |  17 +-
 .../ignite/events/WalSegmentCompactedEvent.java    |  17 +-
 .../org/apache/ignite/events/package-info.java     |  17 +-
 .../ignite/failure/AbstractFailureHandler.java     |  17 +-
 .../org/apache/ignite/failure/FailureContext.java  |  17 +-
 .../org/apache/ignite/failure/FailureHandler.java  |  17 +-
 .../org/apache/ignite/failure/FailureType.java     |  17 +-
 .../apache/ignite/failure/NoOpFailureHandler.java  |  17 +-
 .../failure/RestartProcessFailureHandler.java      |  17 +-
 .../ignite/failure/StopNodeFailureHandler.java     |  17 +-
 .../failure/StopNodeOrHaltFailureHandler.java      |  17 +-
 .../org/apache/ignite/failure/package-info.java    |  17 +-
 .../org/apache/ignite/hadoop/HadoopInputSplit.java |  17 +-
 .../java/org/apache/ignite/hadoop/HadoopJob.java   |  17 +-
 .../apache/ignite/hadoop/HadoopMapReducePlan.java  |  17 +-
 .../ignite/hadoop/HadoopMapReducePlanner.java      |  17 +-
 .../org/apache/ignite/hadoop/package-info.java     |  17 +-
 .../org/apache/ignite/igfs/IgfsBlockLocation.java  |  17 +-
 .../igfs/IgfsConcurrentModificationException.java  |  17 +-
 .../ignite/igfs/IgfsCorruptedFileException.java    |  17 +-
 .../igfs/IgfsDirectoryNotEmptyException.java       |  17 +-
 .../java/org/apache/ignite/igfs/IgfsException.java |  17 +-
 .../main/java/org/apache/ignite/igfs/IgfsFile.java |  17 +-
 .../ignite/igfs/IgfsGroupDataBlocksKeyMapper.java  |  17 +-
 .../org/apache/ignite/igfs/IgfsInputStream.java    |  17 +-
 .../igfs/IgfsInvalidHdfsVersionException.java      |  17 +-
 .../ignite/igfs/IgfsInvalidPathException.java      |  17 +-
 .../ignite/igfs/IgfsIpcEndpointConfiguration.java  |  17 +-
 .../apache/ignite/igfs/IgfsIpcEndpointType.java    |  17 +-
 .../java/org/apache/ignite/igfs/IgfsMetrics.java   |  17 +-
 .../main/java/org/apache/ignite/igfs/IgfsMode.java |  17 +-
 .../ignite/igfs/IgfsOutOfSpaceException.java       |  17 +-
 .../org/apache/ignite/igfs/IgfsOutputStream.java   |  17 +-
 .../igfs/IgfsParentNotDirectoryException.java      |  17 +-
 .../main/java/org/apache/ignite/igfs/IgfsPath.java |  17 +-
 .../igfs/IgfsPathAlreadyExistsException.java       |  17 +-
 .../ignite/igfs/IgfsPathIsDirectoryException.java  |  17 +-
 .../igfs/IgfsPathIsNotDirectoryException.java      |  17 +-
 .../ignite/igfs/IgfsPathNotFoundException.java     |  17 +-
 .../org/apache/ignite/igfs/IgfsPathSummary.java    |  17 +-
 .../org/apache/ignite/igfs/IgfsUserContext.java    |  17 +-
 .../ignite/igfs/mapreduce/IgfsFileRange.java       |  17 +-
 .../igfs/mapreduce/IgfsInputStreamJobAdapter.java  |  17 +-
 .../org/apache/ignite/igfs/mapreduce/IgfsJob.java  |  17 +-
 .../ignite/igfs/mapreduce/IgfsJobAdapter.java      |  17 +-
 .../igfs/mapreduce/IgfsRangeInputStream.java       |  17 +-
 .../ignite/igfs/mapreduce/IgfsRecordResolver.java  |  17 +-
 .../org/apache/ignite/igfs/mapreduce/IgfsTask.java |  17 +-
 .../apache/ignite/igfs/mapreduce/IgfsTaskArgs.java |  17 +-
 .../igfs/mapreduce/IgfsTaskNoReduceAdapter.java    |  17 +-
 .../apache/ignite/igfs/mapreduce/package-info.java |  17 +-
 .../records/IgfsByteDelimiterRecordResolver.java   |  17 +-
 .../records/IgfsFixedLengthRecordResolver.java     |  17 +-
 .../records/IgfsNewLineRecordResolver.java         |  17 +-
 .../records/IgfsStringDelimiterRecordResolver.java |  17 +-
 .../igfs/mapreduce/records/package-info.java       |  17 +-
 .../java/org/apache/ignite/igfs/package-info.java  |  17 +-
 .../igfs/secondary/IgfsSecondaryFileSystem.java    |  17 +-
 .../IgfsSecondaryFileSystemPositionedReadable.java |  17 +-
 .../local/LocalIgfsSecondaryFileSystem.java        |  17 +-
 .../ignite/igfs/secondary/local/package-info.java  |  17 +-
 .../apache/ignite/igfs/secondary/package-info.java |  17 +-
 .../ignite/internal/AsyncSupportAdapter.java       |  17 +-
 .../java/org/apache/ignite/internal/ClassSet.java  |  17 +-
 .../ClusterLocalNodeMetricsMXBeanImpl.java         |  17 +-
 .../ignite/internal/ClusterMetricsMXBeanImpl.java  |  17 +-
 .../ignite/internal/ClusterMetricsSnapshot.java    |  17 +-
 .../ignite/internal/ComputeTaskInternalFuture.java |  17 +-
 .../ignite/internal/DuplicateTypeIdException.java  |  17 +-
 .../ignite/internal/ExecutorAwareMessage.java      |  17 +-
 .../ignite/internal/GridCachePluginContext.java    |  17 +-
 .../ignite/internal/GridClosureCallMode.java       |  17 +-
 .../ignite/internal/GridCodegenConverter.java      |  17 +-
 .../org/apache/ignite/internal/GridComponent.java  |  17 +-
 .../org/apache/ignite/internal/GridDiagnostic.java |  17 +-
 .../ignite/internal/GridDirectCollection.java      |  17 +-
 .../org/apache/ignite/internal/GridDirectMap.java  |  17 +-
 .../ignite/internal/GridDirectTransient.java       |  17 +-
 .../ignite/internal/GridEventConsumeHandler.java   |  17 +-
 .../ignite/internal/GridInternalException.java     |  17 +-
 .../ignite/internal/GridInternalWrapper.java       |  17 +-
 .../ignite/internal/GridJobCancelRequest.java      |  17 +-
 .../apache/ignite/internal/GridJobContextImpl.java |  17 +-
 .../ignite/internal/GridJobExecuteRequest.java     |  17 +-
 .../ignite/internal/GridJobExecuteResponse.java    |  17 +-
 .../apache/ignite/internal/GridJobResultImpl.java  |  17 +-
 .../apache/ignite/internal/GridJobSessionImpl.java |  17 +-
 .../apache/ignite/internal/GridJobSiblingImpl.java |  17 +-
 .../ignite/internal/GridJobSiblingsRequest.java    |  17 +-
 .../ignite/internal/GridJobSiblingsResponse.java   |  17 +-
 .../apache/ignite/internal/GridKernalContext.java  |  17 +-
 .../ignite/internal/GridKernalContextImpl.java     |  17 +-
 .../apache/ignite/internal/GridKernalGateway.java  |  17 +-
 .../ignite/internal/GridKernalGatewayImpl.java     |  17 +-
 .../apache/ignite/internal/GridKernalState.java    |  17 +-
 .../apache/ignite/internal/GridLoggerProxy.java    |  17 +-
 .../ignite/internal/GridMessageListenHandler.java  |  17 +-
 .../ignite/internal/GridPluginComponent.java       |  17 +-
 .../apache/ignite/internal/GridPluginContext.java  |  17 +-
 .../apache/ignite/internal/GridProxyListener.java  |  17 +-
 .../ignite/internal/GridTaskCancelRequest.java     |  17 +-
 .../ignite/internal/GridTaskNameHashKey.java       |  17 +-
 .../ignite/internal/GridTaskSessionImpl.java       |  17 +-
 .../ignite/internal/GridTaskSessionInternal.java   |  17 +-
 .../ignite/internal/GridTaskSessionRequest.java    |  17 +-
 .../java/org/apache/ignite/internal/GridTopic.java |  17 +-
 .../IgniteClientDisconnectedCheckedException.java  |  17 +-
 .../ignite/internal/IgniteCodeGeneratingFail.java  |  17 +-
 .../ignite/internal/IgniteComponentType.java       |  17 +-
 .../apache/ignite/internal/IgniteComputeImpl.java  |  17 +-
 .../internal/IgniteDeploymentCheckedException.java |  17 +-
 .../ignite/internal/IgniteDiagnosticAware.java     |  17 +-
 .../ignite/internal/IgniteDiagnosticInfo.java      |  17 +-
 .../ignite/internal/IgniteDiagnosticMessage.java   |  17 +-
 .../internal/IgniteDiagnosticPrepareContext.java   |  17 +-
 .../apache/ignite/internal/IgniteEventsImpl.java   |  17 +-
 .../java/org/apache/ignite/internal/IgniteEx.java  |  17 +-
 .../org/apache/ignite/internal/IgniteFeatures.java |  17 +-
 .../IgniteFutureCancelledCheckedException.java     |  17 +-
 .../IgniteFutureTimeoutCheckedException.java       |  17 +-
 .../ignite/internal/IgniteInternalFuture.java      |  17 +-
 .../IgniteInterruptedCheckedException.java         |  17 +-
 .../org/apache/ignite/internal/IgniteKernal.java   |  17 +-
 .../ignite/internal/IgniteMessagingImpl.java       |  17 +-
 .../internal/IgniteNeedReconnectException.java     |  17 +-
 .../ignite/internal/IgniteNodeAttributes.java      |  17 +-
 .../apache/ignite/internal/IgniteProperties.java   |  17 +-
 .../ignite/internal/IgniteSchedulerImpl.java       |  17 +-
 .../apache/ignite/internal/IgniteServicesImpl.java |  17 +-
 .../ignite/internal/IgniteTransactionsEx.java      |  17 +-
 .../apache/ignite/internal/IgniteVersionUtils.java |  17 +-
 .../org/apache/ignite/internal/IgnitionEx.java     |  17 +-
 .../ignite/internal/IgnitionMXBeanAdapter.java     |  17 +-
 .../internal/InvalidEnvironmentException.java      |  17 +-
 .../ignite/internal/LongJVMPauseDetector.java      |  17 +-
 .../apache/ignite/internal/MappingStoreTask.java   |  17 +-
 .../ignite/internal/MarshallerContextImpl.java     |  17 +-
 .../internal/MarshallerMappingFileStore.java       |  17 +-
 .../ignite/internal/MarshallerPlatformIds.java     |  17 +-
 .../ignite/internal/NodeStoppingException.java     |  17 +-
 .../SecurityCredentialsAttrFilterPredicate.java    |  17 +-
 .../org/apache/ignite/internal/SkipDaemon.java     |  17 +-
 .../internal/StripedExecutorMXBeanAdapter.java     |  17 +-
 .../ignite/internal/ThreadPoolMXBeanAdapter.java   |  17 +-
 .../internal/TransactionMetricsMxBeanImpl.java     |  17 +-
 .../ignite/internal/TransactionsMXBeanImpl.java    |  17 +-
 .../internal/UnregisteredBinaryTypeException.java  |  17 +-
 .../internal/UnregisteredClassException.java       |  17 +-
 .../binary/BinaryAbstractIdentityResolver.java     |  17 +-
 .../binary/BinaryArrayIdentityResolver.java        |  17 +-
 .../binary/BinaryCachingMetadataHandler.java       |  17 +-
 .../internal/binary/BinaryClassDescriptor.java     |  17 +-
 .../ignite/internal/binary/BinaryContext.java      |  17 +-
 .../internal/binary/BinaryContextHolder.java       |  17 +-
 .../ignite/internal/binary/BinaryEnumCache.java    |  17 +-
 .../internal/binary/BinaryEnumObjectImpl.java      |  17 +-
 .../internal/binary/BinaryFieldAccessor.java       |  17 +-
 .../ignite/internal/binary/BinaryFieldEx.java      |  17 +-
 .../ignite/internal/binary/BinaryFieldImpl.java    |  17 +-
 .../internal/binary/BinaryFieldMetadata.java       |  17 +-
 .../internal/binary/BinaryIdentityResolver.java    |  17 +-
 .../internal/binary/BinaryInternalMapper.java      |  17 +-
 .../ignite/internal/binary/BinaryMarshaller.java   |  17 +-
 .../ignite/internal/binary/BinaryMetadata.java     |  17 +-
 .../internal/binary/BinaryMetadataCollector.java   |  17 +-
 .../internal/binary/BinaryMetadataHandler.java     |  17 +-
 .../internal/binary/BinaryMethodWriteReplacer.java |  17 +-
 .../internal/binary/BinaryNoopMetadataHandler.java |  17 +-
 .../ignite/internal/binary/BinaryObjectEx.java     |  17 +-
 .../ignite/internal/binary/BinaryObjectExImpl.java |  17 +-
 .../ignite/internal/binary/BinaryObjectImpl.java   |  17 +-
 .../internal/binary/BinaryObjectOffheapImpl.java   |  17 +-
 .../internal/binary/BinaryPositionReadable.java    |  17 +-
 .../ignite/internal/binary/BinaryPrimitives.java   |  17 +-
 .../ignite/internal/binary/BinaryRawReaderEx.java  |  17 +-
 .../ignite/internal/binary/BinaryRawWriterEx.java  |  17 +-
 .../ignite/internal/binary/BinaryReaderExImpl.java |  17 +-
 .../internal/binary/BinaryReaderHandles.java       |  17 +-
 .../internal/binary/BinaryReaderHandlesHolder.java |  17 +-
 .../binary/BinaryReaderHandlesHolderImpl.java      |  17 +-
 .../ignite/internal/binary/BinarySchema.java       |  17 +-
 .../internal/binary/BinarySchemaRegistry.java      |  17 +-
 .../binary/BinarySerializedFieldComparator.java    |  17 +-
 .../internal/binary/BinaryThreadLocalContext.java  |  17 +-
 .../ignite/internal/binary/BinaryTreeMap.java      |  17 +-
 .../binary/BinaryTreeMapWriteReplacer.java         |  17 +-
 .../ignite/internal/binary/BinaryTreeSet.java      |  17 +-
 .../binary/BinaryTreeSetWriteReplacer.java         |  17 +-
 .../ignite/internal/binary/BinaryTypeImpl.java     |  17 +-
 .../ignite/internal/binary/BinaryTypeProxy.java    |  17 +-
 .../apache/ignite/internal/binary/BinaryUtils.java |  17 +-
 .../ignite/internal/binary/BinaryWriteMode.java    |  17 +-
 .../internal/binary/BinaryWriteReplacer.java       |  17 +-
 .../ignite/internal/binary/BinaryWriterExImpl.java |  17 +-
 .../internal/binary/BinaryWriterHandles.java       |  17 +-
 .../internal/binary/BinaryWriterSchemaHolder.java  |  17 +-
 .../internal/binary/GridBinaryMarshaller.java      |  17 +-
 .../binary/builder/BinaryAbstractLazyValue.java    |  17 +-
 .../internal/binary/builder/BinaryBuilderEnum.java |  17 +-
 .../binary/builder/BinaryBuilderReader.java        |  17 +-
 .../builder/BinaryBuilderSerializationAware.java   |  17 +-
 .../binary/builder/BinaryBuilderSerializer.java    |  17 +-
 .../binary/builder/BinaryEnumArrayLazyValue.java   |  17 +-
 .../binary/builder/BinaryLazyArrayList.java        |  17 +-
 .../binary/builder/BinaryLazyLinkedList.java       |  17 +-
 .../internal/binary/builder/BinaryLazyMap.java     |  17 +-
 .../internal/binary/builder/BinaryLazySet.java     |  17 +-
 .../internal/binary/builder/BinaryLazyValue.java   |  17 +-
 .../binary/builder/BinaryModifiableLazyValue.java  |  17 +-
 .../binary/builder/BinaryObjectArrayLazyValue.java |  17 +-
 .../binary/builder/BinaryObjectBuilderImpl.java    |  17 +-
 .../binary/builder/BinaryPlainBinaryObject.java    |  17 +-
 .../binary/builder/BinaryPlainLazyValue.java       |  17 +-
 .../binary/builder/BinaryValueWithType.java        |  17 +-
 .../internal/binary/builder/package-info.java      |  17 +-
 .../ignite/internal/binary/package-info.java       |  17 +-
 .../binary/streams/BinaryAbstractInputStream.java  |  17 +-
 .../binary/streams/BinaryAbstractOutputStream.java |  17 +-
 .../binary/streams/BinaryAbstractStream.java       |  17 +-
 .../streams/BinaryByteBufferInputStream.java       |  17 +-
 .../binary/streams/BinaryHeapInputStream.java      |  17 +-
 .../binary/streams/BinaryHeapOutputStream.java     |  17 +-
 .../internal/binary/streams/BinaryInputStream.java |  17 +-
 .../binary/streams/BinaryMemoryAllocator.java      |  17 +-
 .../binary/streams/BinaryMemoryAllocatorChunk.java |  17 +-
 .../binary/streams/BinaryOffheapInputStream.java   |  17 +-
 .../binary/streams/BinaryOffheapOutputStream.java  |  17 +-
 .../binary/streams/BinaryOutputStream.java         |  17 +-
 .../internal/binary/streams/BinaryStream.java      |  17 +-
 .../internal/binary/streams/package-info.java      |  17 +-
 .../apache/ignite/internal/client/GridClient.java  |  17 +-
 .../client/GridClientAuthenticationException.java  |  17 +-
 .../internal/client/GridClientCacheFlag.java       |  17 +-
 .../internal/client/GridClientCacheMode.java       |  17 +-
 .../internal/client/GridClientClosedException.java |  17 +-
 .../internal/client/GridClientClusterState.java    |  17 +-
 .../ignite/internal/client/GridClientCompute.java  |  17 +-
 .../internal/client/GridClientConfiguration.java   |  17 +-
 .../ignite/internal/client/GridClientData.java     |  17 +-
 .../internal/client/GridClientDataAffinity.java    |  17 +-
 .../client/GridClientDataConfiguration.java        |  17 +-
 .../internal/client/GridClientDataMetrics.java     |  17 +-
 .../client/GridClientDisconnectedException.java    |  17 +-
 .../internal/client/GridClientException.java       |  17 +-
 .../ignite/internal/client/GridClientFactory.java  |  17 +-
 .../ignite/internal/client/GridClientFuture.java   |  17 +-
 .../internal/client/GridClientFutureListener.java  |  17 +-
 .../client/GridClientFutureTimeoutException.java   |  17 +-
 .../client/GridClientHandshakeException.java       |  17 +-
 .../ignite/internal/client/GridClientNode.java     |  17 +-
 .../internal/client/GridClientNodeMetrics.java     |  17 +-
 .../client/GridClientPartitionAffinity.java        |  17 +-
 .../internal/client/GridClientPredicate.java       |  17 +-
 .../ignite/internal/client/GridClientProtocol.java |  17 +-
 .../client/GridClientTopologyListener.java         |  17 +-
 .../client/GridServerUnreachableException.java     |  17 +-
 .../client/balancer/GridClientBalancerAdapter.java |  17 +-
 .../client/balancer/GridClientLoadBalancer.java    |  17 +-
 .../client/balancer/GridClientRandomBalancer.java  |  17 +-
 .../balancer/GridClientRoundRobinBalancer.java     |  17 +-
 .../client/impl/GridClientAbstractProjection.java  |  17 +-
 .../client/impl/GridClientAndPredicate.java        |  17 +-
 .../client/impl/GridClientClusterStateImpl.java    |  17 +-
 .../client/impl/GridClientComputeImpl.java         |  17 +-
 .../internal/client/impl/GridClientDataImpl.java   |  17 +-
 .../client/impl/GridClientDataMetricsAdapter.java  |  17 +-
 .../client/impl/GridClientFutureAdapter.java       |  17 +-
 .../client/impl/GridClientFutureCallback.java      |  17 +-
 .../internal/client/impl/GridClientImpl.java       |  17 +-
 .../internal/client/impl/GridClientNodeImpl.java   |  17 +-
 .../client/impl/GridClientNodeMetricsAdapter.java  |  17 +-
 .../client/impl/GridClientThreadFactory.java       |  17 +-
 .../impl/connection/GridClientConnection.java      |  17 +-
 .../GridClientConnectionCloseReason.java           |  17 +-
 .../connection/GridClientConnectionManager.java    |  17 +-
 .../GridClientConnectionManagerAdapter.java        |  17 +-
 .../GridClientConnectionManagerOsImpl.java         |  17 +-
 .../GridClientConnectionResetException.java        |  17 +-
 .../connection/GridClientNioTcpConnection.java     |  17 +-
 .../client/impl/connection/GridClientTopology.java |  17 +-
 .../GridConnectionIdleClosedException.java         |  17 +-
 .../client/marshaller/GridClientMarshaller.java    |  17 +-
 .../marshaller/jdk/GridClientJdkMarshaller.java    |  17 +-
 .../optimized/GridClientOptimizedMarshaller.java   |  17 +-
 .../GridClientZipOptimizedMarshaller.java          |  17 +-
 .../internal/client/router/GridRouterFactory.java  |  17 +-
 .../internal/client/router/GridTcpRouter.java      |  17 +-
 .../client/router/GridTcpRouterConfiguration.java  |  17 +-
 .../internal/client/router/GridTcpRouterMBean.java |  17 +-
 .../client/router/impl/GridRouterClientImpl.java   |  17 +-
 .../router/impl/GridRouterCommandLineStartup.java  |  17 +-
 .../client/router/impl/GridTcpRouterImpl.java      |  17 +-
 .../impl/GridTcpRouterNioListenerAdapter.java      |  17 +-
 .../impl/GridTcpRouterNioListenerOsImpl.java       |  17 +-
 .../client/router/impl/GridTcpRouterNioParser.java |  17 +-
 .../client/ssl/GridSslBasicContextFactory.java     |  17 +-
 .../internal/client/ssl/GridSslContextFactory.java |  17 +-
 .../ignite/internal/client/thin/ClientBinary.java  |  17 +-
 .../client/thin/ClientBinaryMarshaller.java        |  17 +-
 .../internal/client/thin/ClientCacheEntry.java     |  17 +-
 .../ignite/internal/client/thin/ClientChannel.java |  17 +-
 .../client/thin/ClientChannelConfiguration.java    |  17 +-
 .../ignite/internal/client/thin/ClientError.java   |  17 +-
 .../client/thin/ClientFieldsQueryCursor.java       |  17 +-
 .../client/thin/ClientFieldsQueryPager.java        |  17 +-
 .../internal/client/thin/ClientOperation.java      |  17 +-
 .../internal/client/thin/ClientProtocolError.java  |  17 +-
 .../internal/client/thin/ClientQueryCursor.java    |  17 +-
 .../internal/client/thin/ClientQueryPager.java     |  17 +-
 .../internal/client/thin/ClientServerError.java    |  17 +-
 .../ignite/internal/client/thin/ClientUtils.java   |  17 +-
 .../internal/client/thin/FieldsQueryPager.java     |  17 +-
 .../internal/client/thin/GenericQueryPager.java    |  17 +-
 .../internal/client/thin/ProtocolVersion.java      |  17 +-
 .../ignite/internal/client/thin/QueryPager.java    |  17 +-
 .../internal/client/thin/ReliableChannel.java      |  17 +-
 .../apache/ignite/internal/client/thin/Result.java |  17 +-
 .../internal/client/thin/TcpClientCache.java       |  17 +-
 .../internal/client/thin/TcpClientChannel.java     |  17 +-
 .../internal/client/thin/TcpIgniteClient.java      |  17 +-
 .../client/util/GridClientConsistentHash.java      |  17 +-
 .../client/util/GridClientStripedLock.java         |  17 +-
 .../internal/client/util/GridClientUtils.java      |  17 +-
 .../client/util/GridConcurrentHashSet.java         |  17 +-
 .../internal/cluster/ClusterGroupAdapter.java      |  17 +-
 .../cluster/ClusterGroupEmptyCheckedException.java |  17 +-
 .../ignite/internal/cluster/ClusterGroupEx.java    |  17 +-
 .../internal/cluster/ClusterNodeLocalMapImpl.java  |  17 +-
 .../cluster/ClusterStartNodeResultImpl.java        |  17 +-
 .../cluster/ClusterTopologyCheckedException.java   |  17 +-
 .../ClusterTopologyServerNotFoundException.java    |  17 +-
 .../internal/cluster/DetachedClusterNode.java      |  18 +-
 .../cluster/DistributedBaselineConfiguration.java  |  17 +-
 .../internal/cluster/IgniteClusterAsyncImpl.java   |  17 +-
 .../ignite/internal/cluster/IgniteClusterEx.java   |  17 +-
 .../ignite/internal/cluster/IgniteClusterImpl.java |  17 +-
 .../ignite/internal/cluster/IgniteKillTask.java    |  17 +-
 .../internal/cluster/NodeOrderComparator.java      |  18 +-
 .../cluster/NodeOrderLegacyComparator.java         |  18 +-
 .../internal/cluster/graph/BitSetIterator.java     |  17 +-
 .../internal/cluster/graph/ClusterGraph.java       |  17 +-
 .../graph/FullyConnectedComponentSearcher.java     |  17 +-
 .../ignite/internal/commandline/Arguments.java     |  17 +-
 .../ignite/internal/commandline/Command.java       |  17 +-
 .../internal/commandline/CommandHandler.java       |  17 +-
 .../ignite/internal/commandline/GridConsole.java   |  17 +-
 .../internal/commandline/GridConsoleAdapter.java   |  17 +-
 .../ignite/internal/commandline/NoopConsole.java   |  17 +-
 .../ignite/internal/commandline/OutputFormat.java  |  17 +-
 .../internal/commandline/argument/CommandArg.java  |  27 ++-
 .../commandline/argument/CommandArgUtils.java      |  27 ++-
 .../commandline/baseline/AutoAdjustCommandArg.java |  17 +-
 .../commandline/baseline/BaselineArguments.java    |  17 +-
 .../commandline/baseline/BaselineCommand.java      |  17 +-
 .../internal/commandline/cache/CacheArguments.java |  29 ++-
 .../internal/commandline/cache/CacheCommand.java   |  29 ++-
 .../cache/argument/DistributionCommandArg.java     |  27 ++-
 .../cache/argument/IdleVerifyCommandArg.java       |  27 ++-
 .../commandline/cache/argument/ListCommandArg.java |  27 ++-
 .../cache/argument/ValidateIndexesCommandArg.java  |  27 ++-
 .../cache/distribution/CacheDistributionGroup.java |  17 +-
 .../cache/distribution/CacheDistributionNode.java  |  17 +-
 .../distribution/CacheDistributionPartition.java   |  17 +-
 .../cache/distribution/CacheDistributionTask.java  |  17 +-
 .../distribution/CacheDistributionTaskArg.java     |  17 +-
 .../distribution/CacheDistributionTaskResult.java  |  17 +-
 .../CacheResetLostPartitionsTask.java              |  17 +-
 .../CacheResetLostPartitionsTaskArg.java           |  17 +-
 .../CacheResetLostPartitionsTaskResult.java        |  17 +-
 .../ComputeTaskCancelledCheckedException.java      |  17 +-
 .../ComputeTaskTimeoutCheckedException.java        |  17 +-
 .../internal/direct/DirectMessageReader.java       |  17 +-
 .../internal/direct/DirectMessageWriter.java       |  17 +-
 .../internal/direct/state/DirectMessageState.java  |  17 +-
 .../direct/state/DirectMessageStateItem.java       |  17 +-
 .../direct/stream/DirectByteBufferStream.java      |  17 +-
 .../stream/v1/DirectByteBufferStreamImplV1.java    |  17 +-
 .../stream/v2/DirectByteBufferStreamImplV2.java    |  17 +-
 .../stream/v3/DirectByteBufferStreamImplV3.java    |  17 +-
 .../internal/dto/IgniteDataTransferObject.java     |  17 +-
 .../dto/IgniteDataTransferObjectInput.java         |  17 +-
 .../dto/IgniteDataTransferObjectOutput.java        |  17 +-
 .../internal/events/DiscoveryCustomEvent.java      |  17 +-
 .../internal/executor/GridExecutorService.java     |  17 +-
 .../ignite/internal/executor/package-info.java     |  17 +-
 .../internal/igfs/common/IgfsControlResponse.java  |  17 +-
 .../internal/igfs/common/IgfsDataInputStream.java  |  17 +-
 .../internal/igfs/common/IgfsDataOutputStream.java |  17 +-
 .../internal/igfs/common/IgfsHandshakeRequest.java |  17 +-
 .../internal/igfs/common/IgfsIpcCommand.java       |  17 +-
 .../ignite/internal/igfs/common/IgfsLogger.java    |  17 +-
 .../internal/igfs/common/IgfsMarshaller.java       |  17 +-
 .../ignite/internal/igfs/common/IgfsMessage.java   |  17 +-
 .../igfs/common/IgfsModeResolverRequest.java       |  17 +-
 .../igfs/common/IgfsPathControlRequest.java        |  17 +-
 .../internal/igfs/common/IgfsStatusRequest.java    |  17 +-
 .../igfs/common/IgfsStreamControlRequest.java      |  17 +-
 .../ignite/internal/igfs/common/package-info.java  |  17 +-
 .../ignite/internal/jdbc/JdbcConnection.java       |  17 +-
 .../ignite/internal/jdbc/JdbcDatabaseMetadata.java |  17 +-
 .../internal/jdbc/JdbcDriverPropertyInfo.java      |  17 +-
 .../internal/jdbc/JdbcPreparedStatement.java       |  17 +-
 .../apache/ignite/internal/jdbc/JdbcResultSet.java |  17 +-
 .../internal/jdbc/JdbcResultSetMetadata.java       |  17 +-
 .../apache/ignite/internal/jdbc/JdbcStatement.java |  17 +-
 .../org/apache/ignite/internal/jdbc/JdbcUtils.java |  17 +-
 .../ignite/internal/jdbc/thin/AffinityCache.java   |  17 +-
 .../internal/jdbc/thin/ConnectionProperties.java   |  17 +-
 .../jdbc/thin/ConnectionPropertiesImpl.java        |  17 +-
 .../ignite/internal/jdbc/thin/HandshakeResult.java |  17 +-
 .../JdbcThinAffinityAwarenessMappingGroup.java     |  17 +-
 .../internal/jdbc/thin/JdbcThinConnection.java     |  17 +-
 .../jdbc/thin/JdbcThinDatabaseMetadata.java        |  17 +-
 .../jdbc/thin/JdbcThinParameterMetadata.java       |  17 +-
 .../thin/JdbcThinPartitionResultDescriptor.java    |  17 +-
 .../jdbc/thin/JdbcThinPreparedStatement.java       |  17 +-
 .../internal/jdbc/thin/JdbcThinResultSet.java      |  17 +-
 .../jdbc/thin/JdbcThinResultSetMetadata.java       |  17 +-
 .../ignite/internal/jdbc/thin/JdbcThinSSLUtil.java |  17 +-
 .../internal/jdbc/thin/JdbcThinStatement.java      |  17 +-
 .../ignite/internal/jdbc/thin/JdbcThinTcpIo.java   |  17 +-
 .../ignite/internal/jdbc/thin/JdbcThinUtils.java   |  17 +-
 .../internal/jdbc/thin/QualifiedSQLQuery.java      |  17 +-
 .../ignite/internal/jdbc2/JdbcBatchUpdateTask.java |  17 +-
 .../org/apache/ignite/internal/jdbc2/JdbcBlob.java |  17 +-
 .../ignite/internal/jdbc2/JdbcConnection.java      |  17 +-
 .../internal/jdbc2/JdbcDatabaseMetadata.java       |  17 +-
 .../internal/jdbc2/JdbcPreparedStatement.java      |  17 +-
 .../jdbc2/JdbcQueryMultipleStatementsTask.java     |  17 +-
 .../ignite/internal/jdbc2/JdbcQueryTask.java       |  17 +-
 .../ignite/internal/jdbc2/JdbcQueryTaskResult.java |  17 +-
 .../ignite/internal/jdbc2/JdbcQueryTaskV2.java     |  17 +-
 .../ignite/internal/jdbc2/JdbcQueryTaskV3.java     |  17 +-
 .../ignite/internal/jdbc2/JdbcResultSet.java       |  17 +-
 .../internal/jdbc2/JdbcResultSetMetadata.java      |  17 +-
 .../ignite/internal/jdbc2/JdbcStatement.java       |  17 +-
 .../internal/jdbc2/JdbcStatementResultInfo.java    |  17 +-
 .../jdbc2/JdbcStreamedPreparedStatement.java       |  17 +-
 .../apache/ignite/internal/jdbc2/JdbcUtils.java    |  17 +-
 .../internal/logger/platform/PlatformLogger.java   |  17 +-
 .../ignite/internal/managers/GridManager.java      |  17 +-
 .../internal/managers/GridManagerAdapter.java      |  17 +-
 .../internal/managers/IgniteMBeansManager.java     |  17 +-
 .../managers/checkpoint/GridCheckpointManager.java |  17 +-
 .../managers/checkpoint/GridCheckpointRequest.java |  17 +-
 .../internal/managers/checkpoint/package-info.java |  17 +-
 .../collision/GridCollisionJobContextAdapter.java  |  17 +-
 .../managers/collision/GridCollisionManager.java   |  17 +-
 .../internal/managers/collision/package-info.java  |  17 +-
 .../communication/GridDisconnectListener.java      |  17 +-
 .../managers/communication/GridIoManager.java      |  17 +-
 .../managers/communication/GridIoMessage.java      |  17 +-
 .../communication/GridIoMessageFactory.java        |  17 +-
 .../managers/communication/GridIoPolicy.java       |  17 +-
 .../managers/communication/GridIoUserMessage.java  |  17 +-
 .../communication/GridMessageListener.java         |  17 +-
 .../communication/IgniteIoTestMessage.java         |  17 +-
 .../managers/communication/package-info.java       |  17 +-
 .../managers/deployment/GridDeployment.java        |  17 +-
 .../deployment/GridDeploymentClassLoader.java      |  17 +-
 .../deployment/GridDeploymentCommunication.java    |  17 +-
 .../managers/deployment/GridDeploymentInfo.java    |  17 +-
 .../deployment/GridDeploymentInfoBean.java         |  17 +-
 .../deployment/GridDeploymentLocalStore.java       |  17 +-
 .../managers/deployment/GridDeploymentManager.java |  17 +-
 .../deployment/GridDeploymentMetadata.java         |  17 +-
 .../deployment/GridDeploymentPerLoaderStore.java   |  17 +-
 .../deployment/GridDeploymentPerVersionStore.java  |  17 +-
 .../managers/deployment/GridDeploymentRequest.java |  17 +-
 .../deployment/GridDeploymentResponse.java         |  17 +-
 .../managers/deployment/GridDeploymentStore.java   |  17 +-
 .../deployment/GridDeploymentStoreAdapter.java     |  17 +-
 .../internal/managers/deployment/package-info.java |  17 +-
 .../protocol/gg/GridProtocolHandler.java           |  17 +-
 .../deployment/protocol/gg/GridUrlConnection.java  |  17 +-
 .../deployment/protocol/gg/package-info.java       |  17 +-
 .../managers/discovery/ClusterMetricsImpl.java     |  17 +-
 .../managers/discovery/ConsistentIdMapper.java     |  17 +-
 .../managers/discovery/CustomEventListener.java    |  17 +-
 .../managers/discovery/CustomMessageWrapper.java   |  17 +-
 .../internal/managers/discovery/DiscoCache.java    |  17 +-
 .../managers/discovery/DiscoveryCustomMessage.java |  17 +-
 .../managers/discovery/DiscoveryLocalJoinData.java |  17 +-
 .../DiscoveryMessageResultsCollector.java          |  17 +-
 .../DiscoveryServerOnlyCustomMessage.java          |  17 +-
 .../managers/discovery/GridDiscoveryManager.java   |  17 +-
 .../discovery/GridDiscoveryTopologySnapshot.java   |  17 +-
 .../managers/discovery/GridLocalMetrics.java       |  17 +-
 .../managers/discovery/IgniteClusterNode.java      |  17 +-
 .../managers/discovery/IgniteDiscoverySpi.java     |  17 +-
 .../IgniteDiscoverySpiInternalListener.java        |  17 +-
 .../internal/managers/discovery/package-info.java  |  17 +-
 .../encryption/GenerateEncryptionKeyRequest.java   |  17 +-
 .../encryption/GenerateEncryptionKeyResponse.java  |  17 +-
 .../managers/encryption/GridEncryptionManager.java |  17 +-
 .../eventstorage/DiscoveryEventListener.java       |  17 +-
 .../eventstorage/GridEventStorageManager.java      |  17 +-
 .../eventstorage/GridEventStorageMessage.java      |  17 +-
 .../eventstorage/GridLocalEventListener.java       |  17 +-
 .../eventstorage/HighPriorityListener.java         |  17 +-
 .../managers/eventstorage/package-info.java        |  17 +-
 .../managers/failover/GridFailoverContextImpl.java |  17 +-
 .../managers/failover/GridFailoverManager.java     |  17 +-
 .../internal/managers/failover/package-info.java   |  17 +-
 .../managers/indexing/GridIndexingManager.java     |  17 +-
 .../internal/managers/indexing/package-info.java   |  17 +-
 .../loadbalancer/GridLoadBalancerAdapter.java      |  17 +-
 .../loadbalancer/GridLoadBalancerManager.java      |  17 +-
 .../managers/loadbalancer/package-info.java        |  17 +-
 .../ignite/internal/managers/package-info.java     |  17 +-
 .../optimized/OptimizedClassDescriptor.java        |  17 +-
 .../marshaller/optimized/OptimizedFieldType.java   |  17 +-
 .../marshaller/optimized/OptimizedMarshaller.java  |  17 +-
 .../optimized/OptimizedMarshallerIdMapper.java     |  17 +-
 .../optimized/OptimizedMarshallerUtils.java        |  17 +-
 .../optimized/OptimizedObjectInputStream.java      |  17 +-
 .../optimized/OptimizedObjectOutputStream.java     |  17 +-
 .../optimized/OptimizedObjectStreamRegistry.java   |  17 +-
 .../marshaller/optimized/package-info.java         |  17 +-
 .../ignite/internal/mem/DirectMemoryProvider.java  |  17 +-
 .../ignite/internal/mem/DirectMemoryRegion.java    |  17 +-
 .../internal/mem/IgniteOutOfMemoryException.java   |  17 +-
 .../apache/ignite/internal/mem/UnsafeChunk.java    |  17 +-
 .../ignite/internal/mem/file/MappedFile.java       |  17 +-
 .../mem/file/MappedFileMemoryProvider.java         |  17 +-
 .../internal/mem/unsafe/UnsafeMemoryProvider.java  |  17 +-
 .../internal/mxbean/IgniteStandardMXBean.java      |  17 +-
 .../ignite/internal/mxbean/package-info.java       |  17 +-
 .../org/apache/ignite/internal/package-info.java   |  17 +-
 .../apache/ignite/internal/pagemem/FullPageId.java |  17 +-
 .../ignite/internal/pagemem/PageIdAllocator.java   |  17 +-
 .../ignite/internal/pagemem/PageIdUtils.java       |  17 +-
 .../apache/ignite/internal/pagemem/PageMemory.java |  17 +-
 .../ignite/internal/pagemem/PageSupport.java       |  17 +-
 .../apache/ignite/internal/pagemem/PageUtils.java  |  17 +-
 .../pagemem/impl/PageMemoryNoStoreImpl.java        |  17 +-
 .../pagemem/store/IgnitePageStoreManager.java      |  17 +-
 .../ignite/internal/pagemem/store/PageStore.java   |  17 +-
 .../pagemem/wal/IgniteWriteAheadLogManager.java    |  17 +-
 .../ignite/internal/pagemem/wal/WALIterator.java   |  17 +-
 .../ignite/internal/pagemem/wal/WALPointer.java    |  17 +-
 .../internal/pagemem/wal/record/CacheState.java    |  17 +-
 .../pagemem/wal/record/CheckpointRecord.java       |  17 +-
 .../internal/pagemem/wal/record/DataEntry.java     |  17 +-
 .../internal/pagemem/wal/record/DataRecord.java    |  17 +-
 .../pagemem/wal/record/EncryptedRecord.java        |  17 +-
 .../pagemem/wal/record/ExchangeRecord.java         |  17 +-
 .../pagemem/wal/record/FilteredRecord.java         |  29 ++-
 .../internal/pagemem/wal/record/LazyDataEntry.java |  17 +-
 .../pagemem/wal/record/LazyMvccDataEntry.java      |  17 +-
 .../pagemem/wal/record/MarshalledDataEntry.java    |  17 +-
 .../pagemem/wal/record/MarshalledRecord.java       |  29 ++-
 .../pagemem/wal/record/MemoryRecoveryRecord.java   |  17 +-
 .../pagemem/wal/record/MetastoreDataRecord.java    |  18 +-
 .../internal/pagemem/wal/record/MvccDataEntry.java |  17 +-
 .../pagemem/wal/record/MvccDataRecord.java         |  17 +-
 .../internal/pagemem/wal/record/MvccTxRecord.java  |  17 +-
 .../internal/pagemem/wal/record/PageSnapshot.java  |  17 +-
 .../internal/pagemem/wal/record/RolloverType.java  |  17 +-
 .../pagemem/wal/record/SnapshotRecord.java         |  17 +-
 .../pagemem/wal/record/SwitchSegmentRecord.java    |  17 +-
 .../pagemem/wal/record/TimeStampRecord.java        |  17 +-
 .../internal/pagemem/wal/record/TxRecord.java      |  17 +-
 .../pagemem/wal/record/UnwrapDataEntry.java        |  17 +-
 .../pagemem/wal/record/UnwrapMvccDataEntry.java    |  17 +-
 .../pagemem/wal/record/UnwrappedDataEntry.java     |  17 +-
 .../internal/pagemem/wal/record/WALRecord.java     |  17 +-
 .../wal/record/WalRecordCacheGroupAware.java       |  17 +-
 .../record/delta/DataPageInsertFragmentRecord.java |  17 +-
 .../wal/record/delta/DataPageInsertRecord.java     |  17 +-
 .../delta/DataPageMvccMarkUpdatedRecord.java       |  17 +-
 .../DataPageMvccUpdateNewTxStateHintRecord.java    |  17 +-
 .../delta/DataPageMvccUpdateTxStateHintRecord.java |  17 +-
 .../wal/record/delta/DataPageRemoveRecord.java     |  17 +-
 .../delta/DataPageSetFreeListPageRecord.java       |  17 +-
 .../wal/record/delta/DataPageUpdateRecord.java     |  17 +-
 .../record/delta/DeltaApplicationException.java    |  17 +-
 .../pagemem/wal/record/delta/FixCountRecord.java   |  17 +-
 .../wal/record/delta/FixLeftmostChildRecord.java   |  17 +-
 .../pagemem/wal/record/delta/FixRemoveId.java      |  17 +-
 .../wal/record/delta/InitNewPageRecord.java        |  17 +-
 .../wal/record/delta/InnerReplaceRecord.java       |  17 +-
 .../pagemem/wal/record/delta/InsertRecord.java     |  17 +-
 .../pagemem/wal/record/delta/MergeRecord.java      |  17 +-
 .../wal/record/delta/MetaPageAddRootRecord.java    |  17 +-
 .../wal/record/delta/MetaPageCutRootRecord.java    |  17 +-
 .../wal/record/delta/MetaPageInitRecord.java       |  17 +-
 .../record/delta/MetaPageInitRootInlineRecord.java |  17 +-
 .../wal/record/delta/MetaPageInitRootRecord.java   |  17 +-
 .../delta/MetaPageUpdateLastAllocatedIndex.java    |  17 +-
 ...MetaPageUpdateLastSuccessfulFullSnapshotId.java |  17 +-
 .../MetaPageUpdateLastSuccessfulSnapshotId.java    |  17 +-
 .../record/delta/MetaPageUpdateNextSnapshotId.java |  17 +-
 .../delta/MetaPageUpdatePartitionDataRecord.java   |  17 +-
 .../wal/record/delta/NewRootInitRecord.java        |  17 +-
 .../pagemem/wal/record/delta/PageDeltaRecord.java  |  17 +-
 .../record/delta/PageListMetaResetCountRecord.java |  17 +-
 .../wal/record/delta/PagesListAddPageRecord.java   |  17 +-
 .../record/delta/PagesListInitNewPageRecord.java   |  17 +-
 .../record/delta/PagesListRemovePageRecord.java    |  17 +-
 .../wal/record/delta/PagesListSetNextRecord.java   |  17 +-
 .../record/delta/PagesListSetPreviousRecord.java   |  17 +-
 .../wal/record/delta/PartitionDestroyRecord.java   |  17 +-
 .../wal/record/delta/PartitionMetaStateRecord.java |  17 +-
 .../pagemem/wal/record/delta/RecycleRecord.java    |  17 +-
 .../pagemem/wal/record/delta/RemoveRecord.java     |  17 +-
 .../pagemem/wal/record/delta/ReplaceRecord.java    |  17 +-
 .../wal/record/delta/RotatedIdPartRecord.java      |  17 +-
 .../wal/record/delta/SplitExistingPageRecord.java  |  17 +-
 .../wal/record/delta/SplitForwardPageRecord.java   |  17 +-
 .../wal/record/delta/TrackingPageDeltaRecord.java  |  17 +-
 .../ignite/internal/processors/GridProcessor.java  |  17 +-
 .../internal/processors/GridProcessorAdapter.java  |  17 +-
 .../processors/affinity/AffinityAssignment.java    |  17 +-
 .../affinity/AffinityTopologyVersion.java          |  13 +-
 .../affinity/GridAffinityAssignment.java           |  17 +-
 .../affinity/GridAffinityAssignmentCache.java      |  17 +-
 .../affinity/GridAffinityAssignmentV2.java         |  17 +-
 .../affinity/GridAffinityFunctionContextImpl.java  |  17 +-
 .../processors/affinity/GridAffinityMessage.java   |  17 +-
 .../processors/affinity/GridAffinityProcessor.java |  17 +-
 .../processors/affinity/GridAffinityUtils.java     |  17 +-
 .../affinity/HistoryAffinityAssignment.java        |  29 ++-
 .../affinity/HistoryAffinityAssignmentImpl.java    |  17 +-
 .../HistoryAffinityAssignmentShallowCopy.java      |  29 ++-
 .../affinity/IdealAffinityAssignment.java          |  17 +-
 .../internal/processors/affinity/package-info.java |  17 +-
 .../authentication/AuthorizationContext.java       |  17 +-
 .../IgniteAccessControlException.java              |  17 +-
 .../IgniteAuthenticationProcessor.java             |  17 +-
 .../internal/processors/authentication/User.java   |  17 +-
 .../authentication/UserAcceptedMessage.java        |  17 +-
 .../UserAuthenticateRequestMessage.java            |  17 +-
 .../UserAuthenticateResponseMessage.java           |  17 +-
 .../authentication/UserManagementException.java    |  17 +-
 .../authentication/UserManagementOperation.java    |  17 +-
 .../UserManagementOperationFinishedMessage.java    |  17 +-
 .../authentication/UserProposedMessage.java        |  17 +-
 .../bulkload/BulkLoadAckClientParameters.java      |  17 +-
 .../processors/bulkload/BulkLoadCacheWriter.java   |  17 +-
 .../processors/bulkload/BulkLoadCsvFormat.java     |  17 +-
 .../processors/bulkload/BulkLoadCsvParser.java     |  17 +-
 .../processors/bulkload/BulkLoadFormat.java        |  17 +-
 .../processors/bulkload/BulkLoadParser.java        |  17 +-
 .../processors/bulkload/BulkLoadProcessor.java     |  17 +-
 .../bulkload/BulkLoadStreamerWriter.java           |  17 +-
 .../bulkload/pipeline/CharsetDecoderBlock.java     |  17 +-
 .../bulkload/pipeline/CsvLineProcessorBlock.java   |  17 +-
 .../bulkload/pipeline/LineSplitterBlock.java       |  17 +-
 .../bulkload/pipeline/PipelineBlock.java           |  17 +-
 .../bulkload/pipeline/StrListAppenderBlock.java    |  17 +-
 .../cache/AutoClosableCursorIterator.java          |  18 +-
 .../cache/CacheAffinityChangeMessage.java          |  17 +-
 .../cache/CacheAffinitySharedManager.java          |  17 +-
 .../processors/cache/CacheClassLoaderMarker.java   |  17 +-
 .../cache/CacheClientReconnectDiscoveryData.java   |  17 +-
 .../cache/CacheClusterMetricsMXBeanImpl.java       |  17 +-
 .../processors/cache/CacheCompressionManager.java  |  17 +-
 .../cache/CacheConfigurationEnricher.java          |  17 +-
 .../cache/CacheConfigurationEnrichment.java        |  17 +-
 .../cache/CacheConfigurationOverride.java          |  17 +-
 .../cache/CacheConfigurationSplitter.java          |  17 +-
 .../cache/CacheConfigurationSplitterImpl.java      |  17 +-
 .../cache/CacheConfigurationSplitterOldFormat.java |  17 +-
 .../cache/CacheConflictResolutionManager.java      |  17 +-
 .../internal/processors/cache/CacheData.java       |  17 +-
 .../cache/CacheDefaultBinaryAffinityKeyMapper.java |  17 +-
 .../internal/processors/cache/CacheEntryImpl.java  |  17 +-
 .../internal/processors/cache/CacheEntryImpl0.java |  17 +-
 .../processors/cache/CacheEntryImplEx.java         |  17 +-
 .../processors/cache/CacheEntryInfoCollection.java |  17 +-
 .../processors/cache/CacheEntryPredicate.java      |  17 +-
 .../cache/CacheEntryPredicateAdapter.java          |  17 +-
 .../cache/CacheEntryPredicateContainsValue.java    |  17 +-
 .../cache/CacheEntryPredicateHasValue.java         |  17 +-
 .../cache/CacheEntryPredicateNoValue.java          |  17 +-
 .../cache/CacheEntrySerializablePredicate.java     |  17 +-
 .../processors/cache/CacheEvictableEntryImpl.java  |  17 +-
 .../processors/cache/CacheEvictionEntry.java       |  17 +-
 .../processors/cache/CacheEvictionManager.java     |  17 +-
 .../processors/cache/CacheGroupContext.java        |  17 +-
 .../internal/processors/cache/CacheGroupData.java  |  17 +-
 .../processors/cache/CacheGroupDescriptor.java     |  17 +-
 .../cache/CacheGroupMetricsMXBeanImpl.java         |  17 +-
 .../cache/CacheInvalidStateException.java          |  18 +-
 .../processors/cache/CacheInvokeDirectResult.java  |  17 +-
 .../processors/cache/CacheInvokeEntry.java         |  17 +-
 .../processors/cache/CacheInvokeResult.java        |  17 +-
 .../processors/cache/CacheIteratorConverter.java   |  17 +-
 .../cache/CacheJoinNodeDiscoveryData.java          |  17 +-
 .../internal/processors/cache/CacheLazyEntry.java  |  17 +-
 .../cache/CacheLocalMetricsMXBeanImpl.java         |  17 +-
 .../processors/cache/CacheLockCandidates.java      |  17 +-
 .../processors/cache/CacheLockCandidatesList.java  |  17 +-
 .../internal/processors/cache/CacheLockImpl.java   |  17 +-
 .../processors/cache/CacheMetricsImpl.java         |  17 +-
 .../processors/cache/CacheMetricsSnapshot.java     |  17 +-
 .../processors/cache/CacheMetricsSnapshotV2.java   |  17 +-
 .../cache/CacheNodeCommonDiscoveryData.java        |  17 +-
 .../internal/processors/cache/CacheObject.java     |  17 +-
 .../processors/cache/CacheObjectAdapter.java       |  17 +-
 .../processors/cache/CacheObjectByteArrayImpl.java |  17 +-
 .../processors/cache/CacheObjectContext.java       |  17 +-
 .../internal/processors/cache/CacheObjectImpl.java |  17 +-
 .../processors/cache/CacheObjectUtils.java         |  17 +-
 .../processors/cache/CacheObjectValueContext.java  |  17 +-
 .../cache/CacheObjectsReleaseFuture.java           |  17 +-
 .../cache/CacheOffheapEvictionManager.java         |  17 +-
 .../processors/cache/CacheOperationContext.java    |  17 +-
 .../processors/cache/CacheOperationFilter.java     |  17 +-
 .../cache/CacheOsConflictResolutionManager.java    |  17 +-
 .../cache/CachePartialUpdateCheckedException.java  |  17 +-
 .../cache/CachePartitionExchangeWorkerTask.java    |  17 +-
 .../internal/processors/cache/CachePeekModes.java  |  17 +-
 .../cache/CacheStatisticsClearMessage.java         |  17 +-
 .../cache/CacheStatisticsModeChangeMessage.java    |  17 +-
 .../cache/CacheStatisticsModeChangeTask.java       |  17 +-
 .../processors/cache/CacheStoppedException.java    |  17 +-
 .../cache/CacheStoreBalancingWrapper.java          |  17 +-
 .../cache/CacheStorePartialUpdateException.java    |  17 +-
 .../internal/processors/cache/CacheType.java       |  17 +-
 .../cache/CacheWeakQueryIteratorsHolder.java       |  17 +-
 .../internal/processors/cache/CachesRegistry.java  |  17 +-
 .../cache/ClientCacheChangeDiscoveryMessage.java   |  17 +-
 .../ClientCacheChangeDummyDiscoveryMessage.java    |  17 +-
 .../processors/cache/ClientCacheUpdateTimeout.java |  17 +-
 .../processors/cache/ClusterCachesInfo.java        |  17 +-
 .../cache/ClusterCachesReconnectResult.java        |  17 +-
 .../processors/cache/DynamicCacheChangeBatch.java  |  17 +-
 .../cache/DynamicCacheChangeFailureMessage.java    |  17 +-
 .../cache/DynamicCacheChangeRequest.java           |  17 +-
 .../processors/cache/DynamicCacheDescriptor.java   |  17 +-
 .../internal/processors/cache/EntryGetResult.java  |  17 +-
 .../processors/cache/EntryGetWithTtlResult.java    |  17 +-
 .../cache/EntryProcessorResourceInjectorProxy.java |  17 +-
 .../internal/processors/cache/ExchangeActions.java |  17 +-
 .../internal/processors/cache/ExchangeContext.java |  17 +-
 .../processors/cache/ExchangeDiscoveryEvents.java  |  17 +-
 .../cache/FetchActiveTxOwnerTraceClosure.java      |  17 +-
 .../cache/GatewayProtectedCacheProxy.java          |  17 +-
 .../processors/cache/GridCacheAdapter.java         |  17 +-
 .../processors/cache/GridCacheAffinityManager.java |  17 +-
 .../processors/cache/GridCacheAtomicFuture.java    |  17 +-
 .../cache/GridCacheAtomicVersionComparator.java    |  17 +-
 .../processors/cache/GridCacheAttributes.java      |  17 +-
 .../cache/GridCacheClearAllRunnable.java           |  17 +-
 .../processors/cache/GridCacheCompoundFuture.java  |  17 +-
 .../cache/GridCacheCompoundIdentityFuture.java     |  17 +-
 .../processors/cache/GridCacheConcurrentMap.java   |  17 +-
 .../cache/GridCacheConcurrentMapImpl.java          |  18 +-
 .../processors/cache/GridCacheContext.java         |  17 +-
 .../processors/cache/GridCacheContextInfo.java     |  17 +-
 .../cache/GridCacheDefaultAffinityKeyMapper.java   |  17 +-
 .../processors/cache/GridCacheDeployable.java      |  17 +-
 .../cache/GridCacheDeploymentManager.java          |  17 +-
 .../processors/cache/GridCacheEntryEx.java         |  17 +-
 .../processors/cache/GridCacheEntryInfo.java       |  17 +-
 .../cache/GridCacheEntryRedeployException.java     |  17 +-
 .../cache/GridCacheEntryRemovedException.java      |  17 +-
 .../processors/cache/GridCacheEventManager.java    |  17 +-
 .../processors/cache/GridCacheEvictionManager.java |  17 +-
 .../cache/GridCacheExplicitLockSpan.java           |  17 +-
 .../cache/GridCacheFilterFailedException.java      |  17 +-
 .../internal/processors/cache/GridCacheFuture.java |  17 +-
 .../processors/cache/GridCacheFutureAdapter.java   |  17 +-
 .../processors/cache/GridCacheGateway.java         |  17 +-
 .../processors/cache/GridCacheGroupIdMessage.java  |  17 +-
 .../processors/cache/GridCacheIdMessage.java       |  17 +-
 .../cache/GridCacheIndexUpdateException.java       |  17 +-
 .../processors/cache/GridCacheInternal.java        |  17 +-
 .../processors/cache/GridCacheIoManager.java       |  17 +-
 .../processors/cache/GridCacheIterator.java        |  17 +-
 .../cache/GridCacheLoaderWriterStore.java          |  17 +-
 .../cache/GridCacheLoaderWriterStoreFactory.java   |  17 +-
 .../cache/GridCacheLocalConcurrentMap.java         |  18 +-
 .../processors/cache/GridCacheLockCallback.java    |  17 +-
 .../cache/GridCacheLockTimeoutException.java       |  17 +-
 .../internal/processors/cache/GridCacheLogger.java |  17 +-
 .../processors/cache/GridCacheManager.java         |  17 +-
 .../processors/cache/GridCacheManagerAdapter.java  |  17 +-
 .../processors/cache/GridCacheMapEntry.java        |  17 +-
 .../processors/cache/GridCacheMapEntryFactory.java |  17 +-
 .../processors/cache/GridCacheMessage.java         |  17 +-
 .../processors/cache/GridCacheMultiTxFuture.java   |  17 +-
 .../internal/processors/cache/GridCacheMvcc.java   |  17 +-
 .../processors/cache/GridCacheMvccCandidate.java   |  17 +-
 .../processors/cache/GridCacheMvccEntryInfo.java   |  17 +-
 .../processors/cache/GridCacheMvccManager.java     |  17 +-
 .../processors/cache/GridCacheOperation.java       |  17 +-
 .../cache/GridCachePartitionExchangeManager.java   |  17 +-
 .../processors/cache/GridCachePreloader.java       |  17 +-
 .../cache/GridCachePreloaderAdapter.java           |  17 +-
 .../processors/cache/GridCacheProcessor.java       |  17 +-
 .../processors/cache/GridCacheProxyImpl.java       |  17 +-
 .../internal/processors/cache/GridCacheReturn.java |  17 +-
 .../cache/GridCacheReturnCompletableWrapper.java   |  17 +-
 .../processors/cache/GridCacheSharedContext.java   |  17 +-
 .../processors/cache/GridCacheSharedManager.java   |  17 +-
 .../cache/GridCacheSharedManagerAdapter.java       |  17 +-
 .../cache/GridCacheSharedTtlCleanupManager.java    |  17 +-
 .../processors/cache/GridCacheTtlManager.java      |  17 +-
 .../cache/GridCacheUpdateAtomicResult.java         |  17 +-
 .../processors/cache/GridCacheUpdateTxResult.java  |  17 +-
 .../processors/cache/GridCacheUtilityKey.java      |  17 +-
 .../internal/processors/cache/GridCacheUtils.java  |  17 +-
 .../processors/cache/GridCacheValueCollection.java |  17 +-
 .../processors/cache/GridCacheVersionedFuture.java |  17 +-
 .../GridChangeGlobalStateMessageResponse.java      |  17 +-
 .../cache/GridDeferredAckMessageSender.java        |  17 +-
 .../processors/cache/GridNoStorageCacheMap.java    |  18 +-
 .../processors/cache/IgniteCacheExpiryPolicy.java  |  17 +-
 .../processors/cache/IgniteCacheFutureImpl.java    |  17 +-
 .../cache/IgniteCacheOffheapManager.java           |  17 +-
 .../cache/IgniteCacheOffheapManagerImpl.java       |  17 +-
 .../processors/cache/IgniteCacheProxy.java         |  17 +-
 .../processors/cache/IgniteCacheProxyImpl.java     |  17 +-
 .../cache/IgniteFinishedCacheFutureImpl.java       |  17 +-
 .../processors/cache/IgniteInternalCache.java      |  17 +-
 .../processors/cache/IgniteRebalanceIterator.java  |  17 +-
 .../processors/cache/IncompleteCacheObject.java    |  17 +-
 .../processors/cache/IncompleteObject.java         |  17 +-
 .../internal/processors/cache/KeyCacheObject.java  |  17 +-
 .../processors/cache/KeyCacheObjectImpl.java       |  17 +-
 .../processors/cache/LocalJoinCachesContext.java   |  17 +-
 .../processors/cache/PartitionUpdateCounter.java   |  17 +-
 .../processors/cache/PendingDiscoveryEvent.java    |  17 +-
 .../internal/processors/cache/QueryCursorImpl.java |  17 +-
 .../internal/processors/cache/ReaderArguments.java |  17 +-
 .../internal/processors/cache/StartCacheInfo.java  |  17 +-
 .../processors/cache/StateChangeRequest.java       |  17 +-
 .../internal/processors/cache/StoredCacheData.java |  17 +-
 .../TxOwnerDumpRequestAllowedSettingClosure.java   |  17 +-
 ...TimeoutOnPartitionMapExchangeChangeMessage.java |  17 +-
 .../TxTimeoutOnPartitionMapExchangeChangeTask.java |  17 +-
 .../processors/cache/WalStateAbstractMessage.java  |  17 +-
 .../processors/cache/WalStateAckMessage.java       |  17 +-
 .../cache/WalStateDistributedProcess.java          |  17 +-
 .../processors/cache/WalStateFinishMessage.java    |  17 +-
 .../internal/processors/cache/WalStateManager.java |  17 +-
 .../cache/WalStateNodeLeaveExchangeTask.java       |  17 +-
 .../processors/cache/WalStateProposeMessage.java   |  17 +-
 .../internal/processors/cache/WalStateResult.java  |  17 +-
 .../cache/affinity/GridCacheAffinityImpl.java      |  17 +-
 .../cache/affinity/GridCacheAffinityProxy.java     |  17 +-
 .../cache/binary/BinaryMetadataFileStore.java      |  17 +-
 .../cache/binary/BinaryMetadataHolder.java         |  17 +-
 .../processors/cache/binary/BinaryMetadataKey.java |  17 +-
 .../cache/binary/BinaryMetadataTransport.java      |  17 +-
 .../binary/BinaryMetadataUpdatedListener.java      |  17 +-
 .../binary/CacheObjectBinaryProcessorImpl.java     |  17 +-
 .../cache/binary/ClientMetadataRequestFuture.java  |  17 +-
 .../processors/cache/binary/IgniteBinaryImpl.java  |  17 +-
 .../cache/binary/MetadataRequestMessage.java       |  17 +-
 .../cache/binary/MetadataResponseMessage.java      |  17 +-
 .../binary/MetadataUpdateAcceptedMessage.java      |  17 +-
 .../binary/MetadataUpdateProposedMessage.java      |  17 +-
 .../cache/binary/MetadataUpdateResult.java         |  17 +-
 .../processors/cache/binary/package-info.java      |  17 +-
 .../datastructures/CacheDataStructuresManager.java |  17 +-
 .../cache/distributed/GridCacheMappedVersion.java  |  17 +-
 .../distributed/GridCacheTtlUpdateRequest.java     |  17 +-
 .../cache/distributed/GridCacheTxFinishSync.java   |  17 +-
 .../distributed/GridCacheTxRecoveryFuture.java     |  17 +-
 .../distributed/GridCacheTxRecoveryRequest.java    |  17 +-
 .../distributed/GridCacheTxRecoveryResponse.java   |  17 +-
 .../distributed/GridDistributedBaseMessage.java    |  17 +-
 .../distributed/GridDistributedCacheAdapter.java   |  17 +-
 .../distributed/GridDistributedCacheEntry.java     |  17 +-
 .../GridDistributedLockCancelledException.java     |  17 +-
 .../distributed/GridDistributedLockRequest.java    |  17 +-
 .../distributed/GridDistributedLockResponse.java   |  17 +-
 .../GridDistributedTxFinishRequest.java            |  17 +-
 .../GridDistributedTxFinishResponse.java           |  17 +-
 .../distributed/GridDistributedTxMapping.java      |  17 +-
 .../GridDistributedTxPrepareRequest.java           |  17 +-
 .../GridDistributedTxPrepareResponse.java          |  17 +-
 .../GridDistributedTxRemoteAdapter.java            |  17 +-
 .../distributed/GridDistributedUnlockRequest.java  |  17 +-
 .../IgniteExternalizableExpiryPolicy.java          |  17 +-
 .../dht/CacheDistributedGetFutureAdapter.java      |  17 +-
 .../cache/distributed/dht/CacheGetFuture.java      |  17 +-
 .../dht/ClientCacheDhtTopologyFuture.java          |  17 +-
 .../cache/distributed/dht/DhtLockFuture.java       |  17 +-
 .../cache/distributed/dht/ExceptionAware.java      |  17 +-
 .../dht/GridCachePartitionedConcurrentMap.java     |  18 +-
 .../dht/GridDhtAffinityAssignmentRequest.java      |  17 +-
 .../dht/GridDhtAffinityAssignmentResponse.java     |  17 +-
 .../dht/GridDhtAssignmentFetchFuture.java          |  17 +-
 .../cache/distributed/dht/GridDhtCache.java        |  17 +-
 .../cache/distributed/dht/GridDhtCacheAdapter.java |  17 +-
 .../cache/distributed/dht/GridDhtCacheEntry.java   |  17 +-
 .../distributed/dht/GridDhtEmbeddedFuture.java     |  17 +-
 .../distributed/dht/GridDhtFinishedFuture.java     |  17 +-
 .../cache/distributed/dht/GridDhtFuture.java       |  17 +-
 .../cache/distributed/dht/GridDhtGetFuture.java    |  17 +-
 .../distributed/dht/GridDhtGetSingleFuture.java    |  17 +-
 .../cache/distributed/dht/GridDhtLockFuture.java   |  17 +-
 .../cache/distributed/dht/GridDhtLockRequest.java  |  17 +-
 .../cache/distributed/dht/GridDhtLockResponse.java |  17 +-
 .../distributed/dht/GridDhtTopologyFuture.java     |  17 +-
 .../dht/GridDhtTopologyFutureAdapter.java          |  17 +-
 .../dht/GridDhtTransactionalCacheAdapter.java      |  17 +-
 .../dht/GridDhtTxAbstractEnlistFuture.java         |  17 +-
 .../distributed/dht/GridDhtTxEnlistFuture.java     |  17 +-
 .../distributed/dht/GridDhtTxFinishFuture.java     |  17 +-
 .../distributed/dht/GridDhtTxFinishRequest.java    |  17 +-
 .../distributed/dht/GridDhtTxFinishResponse.java   |  17 +-
 .../cache/distributed/dht/GridDhtTxLocal.java      |  17 +-
 .../distributed/dht/GridDhtTxLocalAdapter.java     |  17 +-
 .../cache/distributed/dht/GridDhtTxMapping.java    |  17 +-
 .../dht/GridDhtTxOnePhaseCommitAckRequest.java     |  17 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java    |  17 +-
 .../distributed/dht/GridDhtTxPrepareRequest.java   |  17 +-
 .../distributed/dht/GridDhtTxPrepareResponse.java  |  17 +-
 .../dht/GridDhtTxQueryAbstractEnlistFuture.java    |  17 +-
 .../dht/GridDhtTxQueryEnlistFuture.java            |  17 +-
 .../dht/GridDhtTxQueryEnlistRequest.java           |  17 +-
 .../dht/GridDhtTxQueryEnlistResponse.java          |  17 +-
 .../dht/GridDhtTxQueryFirstEnlistRequest.java      |  17 +-
 .../dht/GridDhtTxQueryResultsEnlistFuture.java     |  17 +-
 .../cache/distributed/dht/GridDhtTxRemote.java     |  17 +-
 .../distributed/dht/GridDhtUnlockRequest.java      |  17 +-
 .../dht/GridDhtUnreservedPartitionException.java   |  17 +-
 .../cache/distributed/dht/GridInvokeValue.java     |  17 +-
 .../distributed/dht/GridPartitionedGetFuture.java  |  17 +-
 .../dht/GridPartitionedSingleGetFuture.java        |  17 +-
 .../cache/distributed/dht/GridReservable.java      |  17 +-
 .../dht/NearTxQueryEnlistResultHandler.java        |  17 +-
 .../cache/distributed/dht/NearTxResultHandler.java |  17 +-
 .../dht/PartitionUpdateCountersMessage.java        |  17 +-
 .../dht/atomic/DhtAtomicUpdateResult.java          |  17 +-
 .../atomic/GridDhtAtomicAbstractUpdateFuture.java  |  17 +-
 .../atomic/GridDhtAtomicAbstractUpdateRequest.java |  17 +-
 .../distributed/dht/atomic/GridDhtAtomicCache.java |  17 +-
 .../GridDhtAtomicDeferredUpdateResponse.java       |  17 +-
 .../dht/atomic/GridDhtAtomicNearResponse.java      |  17 +-
 .../atomic/GridDhtAtomicSingleUpdateFuture.java    |  17 +-
 .../atomic/GridDhtAtomicSingleUpdateRequest.java   |  17 +-
 .../dht/atomic/GridDhtAtomicUpdateFuture.java      |  17 +-
 .../dht/atomic/GridDhtAtomicUpdateRequest.java     |  17 +-
 .../dht/atomic/GridDhtAtomicUpdateResponse.java    |  17 +-
 .../GridNearAtomicAbstractSingleUpdateRequest.java |  17 +-
 .../atomic/GridNearAtomicAbstractUpdateFuture.java |  17 +-
 .../GridNearAtomicAbstractUpdateRequest.java       |  17 +-
 .../atomic/GridNearAtomicCheckUpdateRequest.java   |  17 +-
 .../atomic/GridNearAtomicFullUpdateRequest.java    |  17 +-
 .../GridNearAtomicSingleUpdateFilterRequest.java   |  17 +-
 .../atomic/GridNearAtomicSingleUpdateFuture.java   |  17 +-
 .../GridNearAtomicSingleUpdateInvokeRequest.java   |  17 +-
 .../atomic/GridNearAtomicSingleUpdateRequest.java  |  17 +-
 .../dht/atomic/GridNearAtomicUpdateFuture.java     |  17 +-
 .../dht/atomic/GridNearAtomicUpdateResponse.java   |  17 +-
 .../distributed/dht/atomic/NearCacheUpdates.java   |  17 +-
 .../cache/distributed/dht/atomic/UpdateErrors.java |  17 +-
 .../dht/colocated/GridDhtColocatedCache.java       |  17 +-
 .../dht/colocated/GridDhtColocatedLockFuture.java  |  17 +-
 .../dht/colocated/GridDhtDetachedCacheEntry.java   |  17 +-
 .../dht/preloader/CacheGroupAffinityMessage.java   |  17 +-
 .../preloader/CachePartitionFullCountersMap.java   |  17 +-
 .../CachePartitionPartialCountersMap.java          |  17 +-
 .../dht/preloader/ForceRebalanceExchangeTask.java  |  17 +-
 .../dht/preloader/GridDhtForceKeysFuture.java      |  17 +-
 .../dht/preloader/GridDhtForceKeysRequest.java     |  17 +-
 .../dht/preloader/GridDhtForceKeysResponse.java    |  17 +-
 .../GridDhtPartitionDemandLegacyMessage.java       |  17 +-
 .../preloader/GridDhtPartitionDemandMessage.java   |  17 +-
 .../dht/preloader/GridDhtPartitionDemander.java    |  17 +-
 .../dht/preloader/GridDhtPartitionExchangeId.java  |  17 +-
 .../dht/preloader/GridDhtPartitionFullMap.java     |  17 +-
 .../dht/preloader/GridDhtPartitionMap.java         |  17 +-
 .../dht/preloader/GridDhtPartitionSupplier.java    |  17 +-
 .../preloader/GridDhtPartitionSupplyMessage.java   |  17 +-
 .../preloader/GridDhtPartitionSupplyMessageV2.java |  17 +-
 .../GridDhtPartitionsAbstractMessage.java          |  17 +-
 .../preloader/GridDhtPartitionsExchangeFuture.java |  17 +-
 .../preloader/GridDhtPartitionsFullMessage.java    |  17 +-
 .../preloader/GridDhtPartitionsSingleMessage.java  |  17 +-
 .../preloader/GridDhtPartitionsSingleRequest.java  |  17 +-
 .../dht/preloader/GridDhtPreloader.java            |  17 +-
 .../dht/preloader/GridDhtPreloaderAssignments.java |  17 +-
 .../preloader/IgniteDhtDemandedPartitionsMap.java  |  18 +-
 .../preloader/IgniteDhtPartitionCountersMap.java   |  18 +-
 .../preloader/IgniteDhtPartitionCountersMap2.java  |  18 +-
 .../IgniteDhtPartitionHistorySuppliersMap.java     |  18 +-
 .../preloader/IgniteDhtPartitionsToReloadMap.java  |  18 +-
 .../dht/preloader/IgniteHistoricalIterator.java    |  18 +-
 .../dht/preloader/IgniteRebalanceIteratorImpl.java |  18 +-
 .../dht/preloader/InitNewCoordinatorFuture.java    |  17 +-
 .../preloader/RebalanceReassignExchangeTask.java   |  17 +-
 .../StopCachesOnClientReconnectExchangeTask.java   |  17 +-
 .../dht/preloader/latch/ExchangeLatchManager.java  |  17 +-
 .../distributed/dht/preloader/latch/Latch.java     |  17 +-
 .../dht/preloader/latch/LatchAckMessage.java       |  17 +-
 .../distributed/dht/topology/EvictionContext.java  |  17 +-
 .../dht/topology/GridClientPartitionTopology.java  |  17 +-
 .../topology/GridDhtInvalidPartitionException.java |  17 +-
 .../dht/topology/GridDhtLocalPartition.java        |  17 +-
 .../dht/topology/GridDhtPartitionState.java        |  17 +-
 .../dht/topology/GridDhtPartitionTopology.java     |  17 +-
 .../dht/topology/GridDhtPartitionTopologyImpl.java |  17 +-
 .../dht/topology/GridDhtPartitionsReservation.java |  17 +-
 .../topology/GridDhtPartitionsStateValidator.java  |  17 +-
 .../dht/topology/PartitionsEvictManager.java       |  17 +-
 .../distributed/near/CacheVersionedValue.java      |  17 +-
 .../distributed/near/GridNearAtomicCache.java      |  17 +-
 .../distributed/near/GridNearCacheAdapter.java     |  17 +-
 .../near/GridNearCacheClearAllRunnable.java        |  17 +-
 .../cache/distributed/near/GridNearCacheEntry.java |  17 +-
 .../cache/distributed/near/GridNearGetFuture.java  |  17 +-
 .../cache/distributed/near/GridNearGetRequest.java |  17 +-
 .../distributed/near/GridNearGetResponse.java      |  17 +-
 .../cache/distributed/near/GridNearLockFuture.java |  17 +-
 .../distributed/near/GridNearLockMapping.java      |  17 +-
 .../distributed/near/GridNearLockRequest.java      |  17 +-
 .../distributed/near/GridNearLockResponse.java     |  17 +-
 ...dNearOptimisticSerializableTxPrepareFuture.java |  17 +-
 .../near/GridNearOptimisticTxPrepareFuture.java    |  17 +-
 .../GridNearOptimisticTxPrepareFutureAdapter.java  |  17 +-
 .../near/GridNearPessimisticTxPrepareFuture.java   |  17 +-
 .../distributed/near/GridNearSingleGetRequest.java |  17 +-
 .../near/GridNearSingleGetResponse.java            |  17 +-
 .../near/GridNearTransactionalCache.java           |  17 +-
 .../near/GridNearTxAbstractEnlistFuture.java       |  17 +-
 .../distributed/near/GridNearTxEnlistFuture.java   |  17 +-
 .../distributed/near/GridNearTxEnlistRequest.java  |  17 +-
 .../distributed/near/GridNearTxEnlistResponse.java |  17 +-
 .../near/GridNearTxFastFinishFuture.java           |  17 +-
 .../near/GridNearTxFinishAndAckFuture.java         |  17 +-
 .../distributed/near/GridNearTxFinishFuture.java   |  17 +-
 .../distributed/near/GridNearTxFinishRequest.java  |  17 +-
 .../distributed/near/GridNearTxFinishResponse.java |  17 +-
 .../cache/distributed/near/GridNearTxLocal.java    |  17 +-
 .../near/GridNearTxPrepareFutureAdapter.java       |  17 +-
 .../distributed/near/GridNearTxPrepareRequest.java |  17 +-
 .../near/GridNearTxPrepareResponse.java            |  17 +-
 .../near/GridNearTxQueryAbstractEnlistFuture.java  |  17 +-
 .../near/GridNearTxQueryEnlistFuture.java          |  17 +-
 .../near/GridNearTxQueryEnlistRequest.java         |  17 +-
 .../near/GridNearTxQueryEnlistResponse.java        |  17 +-
 .../near/GridNearTxQueryResultsEnlistFuture.java   |  17 +-
 .../near/GridNearTxQueryResultsEnlistRequest.java  |  17 +-
 .../near/GridNearTxQueryResultsEnlistResponse.java |  17 +-
 .../cache/distributed/near/GridNearTxRemote.java   |  17 +-
 .../distributed/near/GridNearUnlockRequest.java    |  17 +-
 .../cache/distributed/near/IgniteTxMappings.java   |  17 +-
 .../distributed/near/IgniteTxMappingsImpl.java     |  17 +-
 .../near/IgniteTxMappingsSingleImpl.java           |  17 +-
 .../cache/distributed/near/NearTxFinishFuture.java |  17 +-
 .../cache/dr/GridCacheDrExpirationInfo.java        |  17 +-
 .../processors/cache/dr/GridCacheDrInfo.java       |  17 +-
 .../processors/cache/dr/GridCacheDrManager.java    |  17 +-
 .../processors/cache/dr/GridOsCacheDrManager.java  |  17 +-
 .../extras/GridCacheAttributesEntryExtras.java     |  17 +-
 .../extras/GridCacheAttributesMvccEntryExtras.java |  17 +-
 ...GridCacheAttributesMvccObsoleteEntryExtras.java |  17 +-
 ...dCacheAttributesMvccObsoleteTtlEntryExtras.java |  17 +-
 .../GridCacheAttributesMvccTtlEntryExtras.java     |  17 +-
 .../GridCacheAttributesObsoleteEntryExtras.java    |  17 +-
 .../GridCacheAttributesObsoleteTtlEntryExtras.java |  17 +-
 .../extras/GridCacheAttributesTtlEntryExtras.java  |  17 +-
 .../cache/extras/GridCacheEntryExtras.java         |  17 +-
 .../cache/extras/GridCacheEntryExtrasAdapter.java  |  17 +-
 .../cache/extras/GridCacheMvccEntryExtras.java     |  17 +-
 .../extras/GridCacheMvccObsoleteEntryExtras.java   |  17 +-
 .../GridCacheMvccObsoleteTtlEntryExtras.java       |  17 +-
 .../cache/extras/GridCacheMvccTtlEntryExtras.java  |  17 +-
 .../cache/extras/GridCacheObsoleteEntryExtras.java |  17 +-
 .../extras/GridCacheObsoleteTtlEntryExtras.java    |  17 +-
 .../cache/extras/GridCacheTtlEntryExtras.java      |  17 +-
 .../cache/jta/CacheJtaManagerAdapter.java          |  17 +-
 .../processors/cache/jta/CacheNoopJtaManager.java  |  17 +-
 .../processors/cache/local/GridLocalCache.java     |  17 +-
 .../cache/local/GridLocalCacheEntry.java           |  17 +-
 .../cache/local/GridLocalLockCallback.java         |  17 +-
 .../cache/local/GridLocalLockFuture.java           |  17 +-
 .../cache/local/atomic/GridLocalAtomicCache.java   |  17 +-
 .../cache/mvcc/DeadlockDetectionManager.java       |  17 +-
 .../processors/cache/mvcc/DeadlockProbe.java       |  17 +-
 .../processors/cache/mvcc/MvccCachingManager.java  |  17 +-
 .../processors/cache/mvcc/MvccCoordinator.java     |  17 +-
 .../cache/mvcc/MvccCoordinatorChangeAware.java     |  17 +-
 .../processors/cache/mvcc/MvccEmptyLongList.java   |  17 +-
 .../internal/processors/cache/mvcc/MvccFuture.java |  17 +-
 .../processors/cache/mvcc/MvccLongList.java        |  17 +-
 .../processors/cache/mvcc/MvccProcessor.java       |  17 +-
 .../processors/cache/mvcc/MvccProcessorImpl.java   |  17 +-
 .../processors/cache/mvcc/MvccQueryTracker.java    |  17 +-
 .../cache/mvcc/MvccQueryTrackerImpl.java           |  17 +-
 .../processors/cache/mvcc/MvccSnapshot.java        |  17 +-
 .../processors/cache/mvcc/MvccSnapshotFuture.java  |  17 +-
 .../cache/mvcc/MvccSnapshotResponseListener.java   |  17 +-
 .../cache/mvcc/MvccSnapshotWithoutTxs.java         |  17 +-
 .../processors/cache/mvcc/MvccTxEntry.java         |  17 +-
 .../cache/mvcc/MvccUpdateVersionAware.java         |  17 +-
 .../internal/processors/cache/mvcc/MvccUtils.java  |  17 +-
 .../processors/cache/mvcc/MvccVersion.java         |  17 +-
 .../processors/cache/mvcc/MvccVersionAware.java    |  17 +-
 .../processors/cache/mvcc/MvccVersionImpl.java     |  17 +-
 .../processors/cache/mvcc/PreviousQueries.java     |  17 +-
 .../internal/processors/cache/mvcc/ProbedTx.java   |  17 +-
 .../cache/mvcc/StaticMvccQueryTracker.java         |  17 +-
 .../processors/cache/mvcc/VacuumMetrics.java       |  17 +-
 .../cache/mvcc/VacuumMetricsReducer.java           |  17 +-
 .../internal/processors/cache/mvcc/VacuumTask.java |  17 +-
 .../cache/mvcc/msg/MvccAckRequestQueryCntr.java    |  17 +-
 .../cache/mvcc/msg/MvccAckRequestQueryId.java      |  17 +-
 .../cache/mvcc/msg/MvccAckRequestTx.java           |  17 +-
 .../mvcc/msg/MvccAckRequestTxAndQueryCntr.java     |  17 +-
 .../cache/mvcc/msg/MvccAckRequestTxAndQueryId.java |  17 +-
 .../cache/mvcc/msg/MvccActiveQueriesMessage.java   |  17 +-
 .../cache/mvcc/msg/MvccFutureResponse.java         |  17 +-
 .../processors/cache/mvcc/msg/MvccMessage.java     |  17 +-
 .../cache/mvcc/msg/MvccQuerySnapshotRequest.java   |  17 +-
 .../mvcc/msg/MvccRecoveryFinishedMessage.java      |  17 +-
 .../cache/mvcc/msg/MvccSnapshotResponse.java       |  17 +-
 .../cache/mvcc/msg/MvccTxSnapshotRequest.java      |  17 +-
 .../msg/PartitionCountersNeighborcastRequest.java  |  17 +-
 .../msg/PartitionCountersNeighborcastResponse.java |  17 +-
 .../processors/cache/mvcc/txlog/TxKey.java         |  17 +-
 .../processors/cache/mvcc/txlog/TxLog.java         |  17 +-
 .../processors/cache/mvcc/txlog/TxLogIO.java       |  17 +-
 .../processors/cache/mvcc/txlog/TxLogInnerIO.java  |  17 +-
 .../processors/cache/mvcc/txlog/TxLogLeafIO.java   |  17 +-
 .../processors/cache/mvcc/txlog/TxLogTree.java     |  17 +-
 .../processors/cache/mvcc/txlog/TxRow.java         |  17 +-
 .../processors/cache/mvcc/txlog/TxState.java       |  17 +-
 .../internal/processors/cache/package-info.java    |  17 +-
 .../cache/persistence/AllocatedPageTracker.java    |  17 +-
 .../processors/cache/persistence/CacheDataRow.java |  17 +-
 .../cache/persistence/CacheDataRowAdapter.java     |  17 +-
 .../cache/persistence/CacheSearchRow.java          |  17 +-
 .../cache/persistence/CheckpointFuture.java        |  17 +-
 .../persistence/CheckpointLockStateChecker.java    |  17 +-
 .../CheckpointWriteProgressSupplier.java           |  17 +-
 .../persistence/CorruptedPersistenceException.java |  17 +-
 .../processors/cache/persistence/DataRegion.java   |  17 +-
 .../cache/persistence/DataRegionMetricsImpl.java   |  17 +-
 .../persistence/DataRegionMetricsMXBeanImpl.java   |  17 +-
 .../persistence/DataRegionMetricsSnapshot.java     |  17 +-
 .../cache/persistence/DataStorageMXBeanImpl.java   |  17 +-
 .../cache/persistence/DataStorageMetricsImpl.java  |  17 +-
 .../persistence/DataStorageMetricsSnapshot.java    |  17 +-
 .../cache/persistence/DataStructure.java           |  17 +-
 .../persistence/DatabaseLifecycleListener.java     |  17 +-
 .../cache/persistence/DbCheckpointListener.java    |  17 +-
 .../GridCacheDatabaseSharedManager.java            |  17 +-
 .../cache/persistence/GridCacheOffheapManager.java |  17 +-
 .../IgniteCacheDatabaseSharedManager.java          |  17 +-
 .../processors/cache/persistence/IndexStorage.java |  17 +-
 .../cache/persistence/IndexStorageImpl.java        |  17 +-
 .../cache/persistence/RecoveryDebug.java           |  17 +-
 .../processors/cache/persistence/RootPage.java     |  17 +-
 .../processors/cache/persistence/RowStore.java     |  17 +-
 .../processors/cache/persistence/Storable.java     |  17 +-
 .../cache/persistence/StorageException.java        |  17 +-
 .../persistence/checkpoint/CheckpointEntry.java    |  17 +-
 .../checkpoint/CheckpointEntryType.java            |  17 +-
 .../persistence/checkpoint/CheckpointHistory.java  |  17 +-
 .../evict/FairFifoPageEvictionTracker.java         |  29 ++-
 .../persistence/evict/NoOpPageEvictionTracker.java |  29 ++-
 .../evict/PageAbstractEvictionTracker.java         |  29 ++-
 .../persistence/evict/PageEvictionTracker.java     |  29 ++-
 .../evict/Random2LruPageEvictionTracker.java       |  29 ++-
 .../evict/RandomLruPageEvictionTracker.java        |  29 ++-
 .../cache/persistence/file/AbstractFileIO.java     |  17 +-
 .../cache/persistence/file/AsyncFileIO.java        |  17 +-
 .../cache/persistence/file/AsyncFileIOFactory.java |  17 +-
 .../cache/persistence/file/EncryptedFileIO.java    |  17 +-
 .../persistence/file/EncryptedFileIOFactory.java   |  17 +-
 .../cache/persistence/file/FileDownloader.java     |  29 ++-
 .../processors/cache/persistence/file/FileIO.java  |  17 +-
 .../cache/persistence/file/FileIODecorator.java    |  17 +-
 .../cache/persistence/file/FileIOFactory.java      |  17 +-
 .../cache/persistence/file/FilePageStore.java      |  17 +-
 .../persistence/file/FilePageStoreFactory.java     |  29 ++-
 .../persistence/file/FilePageStoreManager.java     |  17 +-
 .../cache/persistence/file/FilePageStoreV2.java    |  29 ++-
 .../cache/persistence/file/FileUploader.java       |  29 ++-
 .../file/FileVersionCheckingFactory.java           |  29 ++-
 .../cache/persistence/file/RandomAccessFileIO.java |  17 +-
 .../file/RandomAccessFileIOFactory.java            |  17 +-
 .../cache/persistence/file/UnzipFileIO.java        |  29 ++-
 .../filename/PdsConsistentIdProcessor.java         |  17 +-
 .../persistence/filename/PdsFolderSettings.java    |  17 +-
 .../persistence/filename/PdsFoldersResolver.java   |  17 +-
 .../persistence/freelist/AbstractFreeList.java     |  17 +-
 .../persistence/freelist/CacheFreeListImpl.java    |  17 +-
 .../freelist/CorruptedFreeListException.java       |  17 +-
 .../cache/persistence/freelist/FreeList.java       |  17 +-
 .../cache/persistence/freelist/PagesList.java      |  17 +-
 .../persistence/freelist/io/PagesListMetaIO.java   |  17 +-
 .../persistence/freelist/io/PagesListNodeIO.java   |  17 +-
 .../cache/persistence/metastorage/MetaStorage.java |  17 +-
 .../metastorage/MetastorageDataRow.java            |  17 +-
 .../metastorage/MetastorageLifecycleListener.java  |  17 +-
 .../metastorage/MetastorageRowStore.java           |  17 +-
 .../metastorage/MetastorageSearchRow.java          |  17 +-
 .../persistence/metastorage/MetastorageTree.java   |  17 +-
 .../metastorage/MetsatorageSearchRowImpl.java      |  17 +-
 .../metastorage/ReadOnlyMetastorage.java           |  17 +-
 .../metastorage/ReadWriteMetastorage.java          |  17 +-
 .../UpgradePendingTreeToPerPartitionTask.java      |  17 +-
 .../processors/cache/persistence/package-info.java |  17 +-
 .../pagemem/CheckpointMetricsTracker.java          |  17 +-
 .../persistence/pagemem/DelayedDirtyPageWrite.java |  17 +-
 .../pagemem/DelayedPageReplacementTracker.java     |  17 +-
 .../cache/persistence/pagemem/FullPageIdTable.java |  17 +-
 .../pagemem/IntervalBasedMeasurement.java          |  17 +-
 .../cache/persistence/pagemem/LoadedPagesMap.java  |  17 +-
 .../cache/persistence/pagemem/PageMemoryEx.java    |  17 +-
 .../cache/persistence/pagemem/PageMemoryImpl.java  |  17 +-
 .../pagemem/PagesWriteSpeedBasedThrottle.java      |  29 ++-
 .../persistence/pagemem/PagesWriteThrottle.java    |  29 ++-
 .../pagemem/PagesWriteThrottlePolicy.java          |  17 +-
 .../persistence/pagemem/ReplaceCandidate.java      |  17 +-
 .../persistence/pagemem/ReplacedPageWriter.java    |  17 +-
 .../pagemem/RobinHoodBackwardShiftHashMap.java     |  17 +-
 .../cache/persistence/pagemem/package-info.java    |  17 +-
 .../persistence/partstate/GroupPartitionId.java    |  17 +-
 .../partstate/PagesAllocationRange.java            |  17 +-
 .../partstate/PartitionAllocationMap.java          |  17 +-
 .../partstate/PartitionRecoverState.java           |  17 +-
 .../snapshot/IgniteCacheSnapshotManager.java       |  17 +-
 .../snapshot/SnapshotDiscoveryMessage.java         |  18 +-
 .../persistence/snapshot/SnapshotOperation.java    |  18 +-
 .../snapshot/TrackingPageIsCorruptedException.java |  17 +-
 .../cache/persistence/tree/BPlusTree.java          |  17 +-
 .../persistence/tree/CorruptedTreeException.java   |  17 +-
 .../persistence/tree/io/AbstractDataPageIO.java    |  17 +-
 .../cache/persistence/tree/io/BPlusIO.java         |  17 +-
 .../cache/persistence/tree/io/BPlusInnerIO.java    |  17 +-
 .../cache/persistence/tree/io/BPlusLeafIO.java     |  17 +-
 .../cache/persistence/tree/io/BPlusMetaIO.java     |  17 +-
 .../cache/persistence/tree/io/CacheVersionIO.java  |  17 +-
 .../persistence/tree/io/CompactablePageIO.java     |  17 +-
 .../cache/persistence/tree/io/DataPageIO.java      |  17 +-
 .../cache/persistence/tree/io/DataPagePayload.java |  17 +-
 .../cache/persistence/tree/io/IOVersions.java      |  17 +-
 .../cache/persistence/tree/io/PageIO.java          |  17 +-
 .../cache/persistence/tree/io/PageMetaIO.java      |  17 +-
 .../tree/io/PagePartitionCountersIO.java           |  18 +-
 .../persistence/tree/io/PagePartitionMetaIO.java   |  18 +-
 .../persistence/tree/io/PagePartitionMetaIOV2.java |  18 +-
 .../persistence/tree/io/SimpleDataPageIO.java      |  17 +-
 .../cache/persistence/tree/io/TrackingPageIO.java  |  17 +-
 .../persistence/tree/reuse/LongListReuseBag.java   |  17 +-
 .../cache/persistence/tree/reuse/ReuseBag.java     |  17 +-
 .../cache/persistence/tree/reuse/ReuseList.java    |  17 +-
 .../persistence/tree/reuse/ReuseListImpl.java      |  17 +-
 .../cache/persistence/tree/util/PageHandler.java   |  17 +-
 .../persistence/tree/util/PageHandlerWrapper.java  |  17 +-
 .../persistence/tree/util/PageLockListener.java    |  17 +-
 .../wal/AbstractWalRecordsIterator.java            |  17 +-
 .../persistence/wal/ByteBufferBackedDataInput.java |  17 +-
 .../wal/ByteBufferBackedDataInputImpl.java         |  17 +-
 .../cache/persistence/wal/ByteBufferExpander.java  |  17 +-
 .../cache/persistence/wal/FileDescriptor.java      |  17 +-
 .../cache/persistence/wal/FileWALPointer.java      |  17 +-
 .../persistence/wal/FileWriteAheadLogManager.java  |  17 +-
 .../persistence/wal/SegmentArchiveResult.java      |  17 +-
 .../cache/persistence/wal/SegmentEofException.java |  17 +-
 .../cache/persistence/wal/SegmentRouter.java       |  17 +-
 .../persistence/wal/SegmentedRingByteBuffer.java   |  17 +-
 .../wal/SingleSegmentLogicalRecordsIterator.java   |  29 ++-
 .../wal/WalSegmentTailReachedException.java        |  17 +-
 .../wal/aware/SegmentArchivedStorage.java          |  17 +-
 .../cache/persistence/wal/aware/SegmentAware.java  |  17 +-
 .../wal/aware/SegmentCompressStorage.java          |  17 +-
 .../wal/aware/SegmentCurrentStateStorage.java      |  17 +-
 .../persistence/wal/aware/SegmentLockStorage.java  |  17 +-
 .../persistence/wal/aware/SegmentObservable.java   |  17 +-
 .../wal/aware/SegmentReservationStorage.java       |  17 +-
 .../cache/persistence/wal/crc/FastCrc.java         |  17 +-
 .../crc/IgniteDataIntegrityViolationException.java |  17 +-
 .../cache/persistence/wal/crc/PureJavaCrc32.java   |  17 +-
 .../wal/filehandle/AbstractFileHandle.java         |  17 +-
 .../wal/filehandle/FileHandleManager.java          |  17 +-
 .../wal/filehandle/FileHandleManagerFactory.java   |  17 +-
 .../wal/filehandle/FileHandleManagerImpl.java      |  17 +-
 .../wal/filehandle/FileWriteHandle.java            |  17 +-
 .../wal/filehandle/FileWriteHandleImpl.java        |  17 +-
 .../wal/filehandle/FsyncFileHandleManagerImpl.java |  17 +-
 .../wal/filehandle/FsyncFileWriteHandle.java       |  17 +-
 .../cache/persistence/wal/io/FileInput.java        |  17 +-
 .../persistence/wal/io/LockedReadFileInput.java    |  17 +-
 .../wal/io/LockedSegmentFileInputFactory.java      |  17 +-
 .../wal/io/SegmentFileInputFactory.java            |  17 +-
 .../cache/persistence/wal/io/SegmentIO.java        |  17 +-
 .../cache/persistence/wal/io/SimpleFileInput.java  |  17 +-
 .../wal/io/SimpleSegmentFileInputFactory.java      |  17 +-
 .../wal/reader/IgniteWalIteratorFactory.java       |  17 +-
 .../wal/reader/StandaloneGridKernalContext.java    |  17 +-
 ...StandaloneIgniteCacheDatabaseSharedManager.java |  17 +-
 .../reader/StandaloneIgnitePluginProcessor.java    |  17 +-
 .../wal/reader/StandaloneNoopCommunicationSpi.java |  17 +-
 .../wal/reader/StandaloneNoopDiscoverySpi.java     |  17 +-
 .../wal/reader/StandaloneWalRecordsIterator.java   |  17 +-
 .../wal/reader/StrictBoundsCheckException.java     |  17 +-
 .../cache/persistence/wal/record/HeaderRecord.java |  17 +-
 .../cache/persistence/wal/record/RecordTypes.java  |  17 +-
 .../wal/serializer/RecordDataSerializer.java       |  17 +-
 .../wal/serializer/RecordDataV1Serializer.java     |  17 +-
 .../wal/serializer/RecordDataV2Serializer.java     |  17 +-
 .../wal/serializer/RecordSerializer.java           |  17 +-
 .../wal/serializer/RecordSerializerFactory.java    |  17 +-
 .../serializer/RecordSerializerFactoryImpl.java    |  29 ++-
 .../wal/serializer/RecordV1Serializer.java         |  17 +-
 .../wal/serializer/RecordV2Serializer.java         |  17 +-
 .../persistence/wal/serializer/SegmentHeader.java  |  17 +-
 .../wal/serializer/TxRecordSerializer.java         |  17 +-
 .../persistence/wal/serializer/io/RecordIO.java    |  17 +-
 .../processors/cache/query/CacheQuery.java         |  17 +-
 .../processors/cache/query/CacheQueryEntry.java    |  17 +-
 .../processors/cache/query/CacheQueryFuture.java   |  17 +-
 .../processors/cache/query/CacheQueryType.java     |  17 +-
 .../GridCacheDistributedFieldsQueryFuture.java     |  17 +-
 .../query/GridCacheDistributedQueryFuture.java     |  17 +-
 .../query/GridCacheDistributedQueryManager.java    |  17 +-
 .../query/GridCacheLocalFieldsQueryFuture.java     |  17 +-
 .../cache/query/GridCacheLocalQueryFuture.java     |  17 +-
 .../cache/query/GridCacheLocalQueryManager.java    |  17 +-
 .../cache/query/GridCacheQueryAdapter.java         |  17 +-
 .../processors/cache/query/GridCacheQueryBean.java |  17 +-
 .../query/GridCacheQueryDetailMetricsAdapter.java  |  17 +-
 .../query/GridCacheQueryDetailMetricsKey.java      |  17 +-
 .../cache/query/GridCacheQueryErrorFuture.java     |  17 +-
 .../cache/query/GridCacheQueryFutureAdapter.java   |  17 +-
 .../processors/cache/query/GridCacheQueryInfo.java |  17 +-
 .../cache/query/GridCacheQueryManager.java         |  17 +-
 .../cache/query/GridCacheQueryMarshallable.java    |  17 +-
 .../cache/query/GridCacheQueryMetadataAware.java   |  17 +-
 .../cache/query/GridCacheQueryMetricsAdapter.java  |  17 +-
 .../cache/query/GridCacheQueryMetricsKey.java      |  17 +-
 .../cache/query/GridCacheQueryRequest.java         |  17 +-
 .../cache/query/GridCacheQueryResponse.java        |  17 +-
 .../cache/query/GridCacheQueryResponseEntry.java   |  17 +-
 .../query/GridCacheQuerySqlMetadataJobV2.java      |  17 +-
 .../cache/query/GridCacheQuerySqlMetadataV2.java   |  17 +-
 .../processors/cache/query/GridCacheQueryType.java |  17 +-
 .../cache/query/GridCacheSqlIndexMetadata.java     |  17 +-
 .../cache/query/GridCacheSqlMetadata.java          |  17 +-
 .../processors/cache/query/GridCacheSqlQuery.java  |  17 +-
 .../cache/query/IgniteQueryErrorCode.java          |  17 +-
 .../processors/cache/query/QueryCursorEx.java      |  17 +-
 .../cache/query/QueryEntityClassProperty.java      |  17 +-
 .../cache/query/QueryEntityIndexDescriptor.java    |  17 +-
 .../cache/query/QueryEntityTypeDescriptor.java     |  17 +-
 .../processors/cache/query/SqlFieldsQueryEx.java   |  17 +-
 .../CacheContinuousQueryAcknowledgeBuffer.java     |  17 +-
 .../continuous/CacheContinuousQueryBatchAck.java   |  17 +-
 .../CacheContinuousQueryDeployableObject.java      |  17 +-
 .../continuous/CacheContinuousQueryEntry.java      |  17 +-
 .../continuous/CacheContinuousQueryEvent.java      |  17 +-
 .../CacheContinuousQueryEventBuffer.java           |  17 +-
 .../continuous/CacheContinuousQueryHandler.java    |  17 +-
 .../continuous/CacheContinuousQueryHandlerV2.java  |  17 +-
 .../continuous/CacheContinuousQueryHandlerV3.java  |  17 +-
 .../continuous/CacheContinuousQueryListener.java   |  17 +-
 .../continuous/CacheContinuousQueryManager.java    |  17 +-
 .../CacheContinuousQueryPartitionRecovery.java     |  17 +-
 .../cache/query/continuous/CounterSkipContext.java |  17 +-
 .../query/jdbc/GridCacheQueryJdbcMetadataTask.java |  17 +-
 .../cache/query/jdbc/GridCacheQueryJdbcTask.java   |  17 +-
 .../jdbc/GridCacheQueryJdbcValidationTask.java     |  17 +-
 .../cache/ratemetrics/HitRateMetrics.java          |  29 ++-
 .../cache/ratemetrics/HitRateMetricsSandbox.java   |  29 ++-
 .../processors/cache/store/CacheLocalStore.java    |  17 +-
 .../cache/store/CacheOsStoreManager.java           |  17 +-
 .../processors/cache/store/CacheStoreManager.java  |  17 +-
 .../cache/store/GridCacheStoreManagerAdapter.java  |  17 +-
 .../cache/store/GridCacheWriteBehindStore.java     |  17 +-
 .../cache/transactions/IgniteInternalTx.java       |  17 +-
 .../cache/transactions/IgniteTransactionsImpl.java |  17 +-
 .../cache/transactions/IgniteTxAdapter.java        |  17 +-
 .../cache/transactions/IgniteTxEntry.java          |  17 +-
 .../cache/transactions/IgniteTxHandler.java        |  17 +-
 .../IgniteTxImplicitSingleStateImpl.java           |  17 +-
 .../processors/cache/transactions/IgniteTxKey.java |  17 +-
 .../cache/transactions/IgniteTxLocalAdapter.java   |  17 +-
 .../cache/transactions/IgniteTxLocalEx.java        |  17 +-
 .../cache/transactions/IgniteTxLocalState.java     |  17 +-
 .../transactions/IgniteTxLocalStateAdapter.java    |  17 +-
 .../cache/transactions/IgniteTxManager.java        |  17 +-
 .../processors/cache/transactions/IgniteTxMap.java |  17 +-
 .../cache/transactions/IgniteTxRemoteEx.java       |  17 +-
 .../IgniteTxRemoteSingleStateImpl.java             |  17 +-
 .../cache/transactions/IgniteTxRemoteState.java    |  17 +-
 .../transactions/IgniteTxRemoteStateAdapter.java   |  17 +-
 .../transactions/IgniteTxRemoteStateImpl.java      |  17 +-
 .../cache/transactions/IgniteTxState.java          |  17 +-
 .../cache/transactions/IgniteTxStateAware.java     |  18 +-
 .../cache/transactions/IgniteTxStateImpl.java      |  17 +-
 .../PartitionCountersNeighborcastFuture.java       |  17 +-
 .../transactions/TransactionEventProxyImpl.java    |  17 +-
 .../transactions/TransactionMetricsAdapter.java    |  17 +-
 .../cache/transactions/TransactionProxy.java       |  17 +-
 .../cache/transactions/TransactionProxyImpl.java   |  17 +-
 .../TransactionProxyRollbackOnlyImpl.java          |  17 +-
 .../processors/cache/transactions/TxCounters.java  |  17 +-
 .../processors/cache/transactions/TxDeadlock.java  |  17 +-
 .../cache/transactions/TxDeadlockDetection.java    |  17 +-
 .../cache/transactions/TxEntryValueHolder.java     |  17 +-
 .../processors/cache/transactions/TxLock.java      |  17 +-
 .../processors/cache/transactions/TxLockList.java  |  17 +-
 .../cache/transactions/TxLocksRequest.java         |  17 +-
 .../cache/transactions/TxLocksResponse.java        |  17 +-
 .../processors/cache/tree/AbstractDataInnerIO.java |  17 +-
 .../processors/cache/tree/AbstractDataLeafIO.java  |  17 +-
 .../cache/tree/AbstractPendingEntryInnerIO.java    |  17 +-
 .../cache/tree/AbstractPendingEntryLeafIO.java     |  17 +-
 .../processors/cache/tree/CacheDataRowStore.java   |  17 +-
 .../processors/cache/tree/CacheDataTree.java       |  17 +-
 .../cache/tree/CacheIdAwareDataInnerIO.java        |  17 +-
 .../cache/tree/CacheIdAwareDataLeafIO.java         |  17 +-
 .../tree/CacheIdAwarePendingEntryInnerIO.java      |  17 +-
 .../cache/tree/CacheIdAwarePendingEntryLeafIO.java |  17 +-
 .../processors/cache/tree/DataInnerIO.java         |  17 +-
 .../internal/processors/cache/tree/DataLeafIO.java |  17 +-
 .../internal/processors/cache/tree/DataRow.java    |  17 +-
 .../processors/cache/tree/PendingEntriesTree.java  |  17 +-
 .../processors/cache/tree/PendingEntryInnerIO.java |  17 +-
 .../processors/cache/tree/PendingEntryLeafIO.java  |  17 +-
 .../internal/processors/cache/tree/PendingRow.java |  17 +-
 .../processors/cache/tree/PendingRowIO.java        |  17 +-
 .../internal/processors/cache/tree/RowLinkIO.java  |  17 +-
 .../internal/processors/cache/tree/SearchRow.java  |  17 +-
 .../mvcc/data/MvccCacheIdAwareDataInnerIO.java     |  17 +-
 .../tree/mvcc/data/MvccCacheIdAwareDataLeafIO.java |  17 +-
 .../cache/tree/mvcc/data/MvccDataInnerIO.java      |  17 +-
 .../cache/tree/mvcc/data/MvccDataLeafIO.java       |  17 +-
 .../cache/tree/mvcc/data/MvccDataRow.java          |  17 +-
 .../cache/tree/mvcc/data/MvccUpdateDataRow.java    |  17 +-
 .../cache/tree/mvcc/data/MvccUpdateResult.java     |  17 +-
 .../cache/tree/mvcc/data/ResultType.java           |  17 +-
 .../tree/mvcc/search/MvccDataPageClosure.java      |  17 +-
 .../tree/mvcc/search/MvccFirstRowTreeClosure.java  |  17 +-
 .../tree/mvcc/search/MvccLinkAwareSearchRow.java   |  17 +-
 .../cache/tree/mvcc/search/MvccMaxSearchRow.java   |  17 +-
 .../cache/tree/mvcc/search/MvccMinSearchRow.java   |  17 +-
 .../cache/tree/mvcc/search/MvccSearchRow.java      |  17 +-
 .../tree/mvcc/search/MvccSnapshotSearchRow.java    |  19 +-
 .../cache/tree/mvcc/search/MvccTreeClosure.java    |  17 +-
 .../processors/cache/verify/CacheInfo.java         |  17 +-
 .../verify/CollectConflictPartitionKeysTask.java   |  29 ++-
 .../processors/cache/verify/ContentionClosure.java |  17 +-
 .../processors/cache/verify/ContentionInfo.java    |  17 +-
 .../cache/verify/GridNotIdleException.java         |  27 ++-
 .../cache/verify/IdleVerifyDumpResult.java         |  29 ++-
 .../cache/verify/IdleVerifyException.java          |  27 ++-
 .../cache/verify/IdleVerifyResultV2.java           |  17 +-
 .../processors/cache/verify/IdleVerifyUtility.java |  27 ++-
 .../cache/verify/NoMatchingCachesException.java    |  17 +-
 .../cache/verify/PartitionEntryHashRecord.java     |  29 ++-
 .../cache/verify/PartitionHashRecord.java          |  29 ++-
 .../cache/verify/PartitionHashRecordV2.java        |  29 ++-
 .../processors/cache/verify/PartitionKey.java      |  29 ++-
 .../processors/cache/verify/PartitionKeyV2.java    |  29 ++-
 .../RetrieveConflictPartitionValuesTask.java       |  29 ++-
 .../verify/VerifyBackupPartitionsDumpTask.java     |  17 +-
 .../cache/verify/VerifyBackupPartitionsTask.java   |  29 ++-
 .../cache/verify/VerifyBackupPartitionsTaskV2.java |  29 ++-
 .../processors/cache/verify/ViewCacheClosure.java  |  17 +-
 .../version/CacheVersionConflictResolver.java      |  17 +-
 .../version/GridCacheLazyPlainVersionedEntry.java  |  17 +-
 .../version/GridCachePlainVersionedEntry.java      |  17 +-
 .../cache/version/GridCacheRawVersionedEntry.java  |  17 +-
 .../processors/cache/version/GridCacheVersion.java |  17 +-
 .../cache/version/GridCacheVersionAware.java       |  17 +-
 .../version/GridCacheVersionConflictContext.java   |  17 +-
 .../cache/version/GridCacheVersionEx.java          |  17 +-
 .../cache/version/GridCacheVersionManager.java     |  17 +-
 .../cache/version/GridCacheVersionable.java        |  17 +-
 .../cache/version/GridCacheVersionedEntry.java     |  17 +-
 .../cache/version/GridCacheVersionedEntryEx.java   |  17 +-
 .../cacheobject/IgniteCacheObjectProcessor.java    |  17 +-
 .../processors/cacheobject/NoOpBinary.java         |  17 +-
 .../cacheobject/UserCacheObjectByteArrayImpl.java  |  17 +-
 .../cacheobject/UserCacheObjectImpl.java           |  17 +-
 .../cacheobject/UserKeyCacheObjectImpl.java        |  17 +-
 .../processors/cacheobject/package-info.java       |  17 +-
 .../internal/processors/closure/AffinityTask.java  |  17 +-
 .../processors/closure/GridClosureProcessor.java   |  17 +-
 .../closure/GridPeerDeployAwareTaskAdapter.java    |  17 +-
 .../internal/processors/closure/package-info.java  |  17 +-
 .../cluster/BaselineAdjustForbiddenException.java  |  17 +-
 .../cluster/BaselineAutoAdjustMXBeanImpl.java      |  17 +-
 .../processors/cluster/BaselineTopology.java       |  18 +-
 .../cluster/BaselineTopologyHistory.java           |  17 +-
 .../cluster/BaselineTopologyHistoryItem.java       |  17 +-
 .../processors/cluster/BranchingPointType.java     |  17 +-
 .../cluster/ChangeGlobalStateFinishMessage.java    |  17 +-
 .../cluster/ChangeGlobalStateMessage.java          |  17 +-
 .../cluster/ClusterMetricsUpdateMessage.java       |  17 +-
 .../processors/cluster/ClusterNodeMetrics.java     |  17 +-
 .../processors/cluster/ClusterProcessor.java       |  17 +-
 .../cluster/DiscoveryDataClusterState.java         |  17 +-
 .../cluster/GridClusterStateProcessor.java         |  17 +-
 .../processors/cluster/GridUpdateNotifier.java     |  17 +-
 .../cluster/HttpIgniteUpdatesChecker.java          |  17 +-
 .../cluster/IGridClusterStateProcessor.java        |  18 +-
 .../cluster/IgniteChangeGlobalStateSupport.java    |  17 +-
 .../autoadjust/BaselineAutoAdjustData.java         |  17 +-
 .../autoadjust/BaselineAutoAdjustExecutor.java     |  17 +-
 .../autoadjust/BaselineAutoAdjustScheduler.java    |  17 +-
 .../autoadjust/BaselineAutoAdjustStatus.java       |  17 +-
 .../baseline/autoadjust/ChangeTopologyWatcher.java |  17 +-
 .../processors/compress/CompressionProcessor.java  |  17 +-
 .../processors/compress/FileSystemUtils.java       |  17 +-
 .../processors/compress/NativeFileSystem.java      |  17 +-
 .../distributed/DetachedPropertyException.java     |  17 +-
 .../distributed/DistributePropertyListener.java    |  17 +-
 .../distributed/DistributedBooleanProperty.java    |  17 +-
 .../distributed/DistributedComparableProperty.java |  17 +-
 .../DistributedConfigurationLifecycleListener.java |  17 +-
 .../DistributedConfigurationProcessor.java         |  17 +-
 .../distributed/DistributedLongProperty.java       |  17 +-
 .../distributed/DistributedProperty.java           |  17 +-
 .../distributed/DistributedPropertyDispatcher.java |  17 +-
 .../distributed/NotWritablePropertyException.java  |  17 +-
 .../distributed/PropertyUpdateClosure.java         |  17 +-
 .../continuous/AbstractContinuousMessage.java      |  17 +-
 .../continuous/ContinuousRoutineInfo.java          |  17 +-
 .../ContinuousRoutineStartResultMessage.java       |  17 +-
 .../ContinuousRoutinesCommonDiscoveryData.java     |  17 +-
 .../continuous/ContinuousRoutinesInfo.java         |  17 +-
 ...ContinuousRoutinesJoiningNodeDiscoveryData.java |  17 +-
 .../processors/continuous/GridContinuousBatch.java |  17 +-
 .../continuous/GridContinuousBatchAdapter.java     |  17 +-
 .../continuous/GridContinuousHandler.java          |  17 +-
 .../continuous/GridContinuousMessage.java          |  17 +-
 .../continuous/GridContinuousMessageType.java      |  17 +-
 .../continuous/GridContinuousProcessor.java        |  17 +-
 .../continuous/GridContinuousQueryBatch.java       |  17 +-
 .../processors/continuous/StartRequestData.java    |  13 +-
 .../processors/continuous/StartRequestDataV2.java  |  17 +-
 .../StartRoutineAckDiscoveryMessage.java           |  17 +-
 .../continuous/StartRoutineDiscoveryMessage.java   |  17 +-
 .../continuous/StartRoutineDiscoveryMessageV2.java |  17 +-
 .../continuous/StopRoutineAckDiscoveryMessage.java |  17 +-
 .../continuous/StopRoutineDiscoveryMessage.java    |  17 +-
 .../datastreamer/DataStreamProcessor.java          |  17 +-
 .../datastreamer/DataStreamerCacheUpdaters.java    |  17 +-
 .../processors/datastreamer/DataStreamerEntry.java |  17 +-
 .../datastreamer/DataStreamerFuture.java           |  17 +-
 .../processors/datastreamer/DataStreamerImpl.java  |  17 +-
 .../datastreamer/DataStreamerRequest.java          |  17 +-
 .../datastreamer/DataStreamerResponse.java         |  17 +-
 .../datastreamer/DataStreamerUpdateJob.java        |  17 +-
 .../processors/datastreamer/package-info.java      |  17 +-
 .../datastructures/AtomicDataStructureProxy.java   |  18 +-
 .../datastructures/AtomicDataStructureValue.java   |  18 +-
 .../datastructures/CollocatedQueueItemKey.java     |  17 +-
 .../datastructures/CollocatedSetItemKey.java       |  17 +-
 .../datastructures/DataStructureInfoKey.java       |  17 +-
 .../datastructures/DataStructureType.java          |  18 +-
 .../datastructures/DataStructuresCacheKey.java     |  17 +-
 .../datastructures/DataStructuresProcessor.java    |  17 +-
 .../DistributedCollectionMetadata.java             |  17 +-
 .../datastructures/GridAtomicCacheQueueImpl.java   |  17 +-
 .../datastructures/GridCacheAnnotationHelper.java  |  17 +-
 .../datastructures/GridCacheAtomicLongEx.java      |  17 +-
 .../datastructures/GridCacheAtomicLongImpl.java    |  17 +-
 .../datastructures/GridCacheAtomicLongValue.java   |  17 +-
 .../datastructures/GridCacheAtomicReferenceEx.java |  17 +-
 .../GridCacheAtomicReferenceImpl.java              |  17 +-
 .../GridCacheAtomicReferenceValue.java             |  17 +-
 .../datastructures/GridCacheAtomicSequenceEx.java  |  17 +-
 .../GridCacheAtomicSequenceImpl.java               |  17 +-
 .../GridCacheAtomicSequenceValue.java              |  17 +-
 .../datastructures/GridCacheAtomicStampedEx.java   |  17 +-
 .../datastructures/GridCacheAtomicStampedImpl.java |  17 +-
 .../GridCacheAtomicStampedValue.java               |  17 +-
 .../datastructures/GridCacheCountDownLatchEx.java  |  17 +-
 .../GridCacheCountDownLatchImpl.java               |  17 +-
 .../GridCacheCountDownLatchValue.java              |  17 +-
 .../datastructures/GridCacheInternalKey.java       |  17 +-
 .../datastructures/GridCacheInternalKeyImpl.java   |  17 +-
 .../processors/datastructures/GridCacheLockEx.java |  17 +-
 .../datastructures/GridCacheLockImpl.java          |  17 +-
 .../datastructures/GridCacheLockState.java         |  17 +-
 .../datastructures/GridCacheQueueAdapter.java      |  17 +-
 .../datastructures/GridCacheQueueHeader.java       |  17 +-
 .../datastructures/GridCacheQueueHeaderKey.java    |  17 +-
 .../datastructures/GridCacheQueueItemKey.java      |  17 +-
 .../datastructures/GridCacheQueueProxy.java        |  17 +-
 .../datastructures/GridCacheRemovable.java         |  17 +-
 .../datastructures/GridCacheSemaphoreEx.java       |  17 +-
 .../datastructures/GridCacheSemaphoreImpl.java     |  17 +-
 .../datastructures/GridCacheSemaphoreState.java    |  17 +-
 .../datastructures/GridCacheSetHeader.java         |  17 +-
 .../datastructures/GridCacheSetHeaderKey.java      |  17 +-
 .../datastructures/GridCacheSetImpl.java           |  17 +-
 .../datastructures/GridCacheSetItemKey.java        |  17 +-
 .../datastructures/GridCacheSetProxy.java          |  17 +-
 .../datastructures/GridSetQueryPredicate.java      |  17 +-
 .../GridTransactionalCacheQueueImpl.java           |  17 +-
 .../processors/datastructures/QueueItemKey.java    |  17 +-
 .../processors/datastructures/SetItemKey.java      |  17 +-
 .../VolatileAtomicDataStructureValue.java          |  18 +-
 .../ignite/internal/processors/dr/GridDrType.java  |  17 +-
 .../dr/IgniteDrDataStreamerCacheUpdater.java       |  17 +-
 .../internal/processors/dr/package-info.java       |  17 +-
 .../processors/failure/FailureProcessor.java       |  17 +-
 .../internal/processors/failure/package-info.java  |  17 +-
 .../ignite/internal/processors/hadoop/Hadoop.java  |  17 +-
 .../processors/hadoop/HadoopClassLoader.java       |  17 +-
 .../processors/hadoop/HadoopClasspathUtils.java    |  17 +-
 .../processors/hadoop/HadoopDefaultJobInfo.java    |  17 +-
 .../processors/hadoop/HadoopFileBlock.java         |  17 +-
 .../internal/processors/hadoop/HadoopHelper.java   |  17 +-
 .../internal/processors/hadoop/HadoopJobEx.java    |  17 +-
 .../internal/processors/hadoop/HadoopJobId.java    |  17 +-
 .../internal/processors/hadoop/HadoopJobInfo.java  |  17 +-
 .../internal/processors/hadoop/HadoopJobPhase.java |  17 +-
 .../processors/hadoop/HadoopJobProperty.java       |  17 +-
 .../processors/hadoop/HadoopJobStatus.java         |  17 +-
 .../processors/hadoop/HadoopLocations.java         |  17 +-
 .../hadoop/HadoopMapperAwareTaskOutput.java        |  17 +-
 .../processors/hadoop/HadoopNoopHelper.java        |  17 +-
 .../processors/hadoop/HadoopNoopProcessor.java     |  17 +-
 .../processors/hadoop/HadoopPartitioner.java       |  17 +-
 .../processors/hadoop/HadoopProcessorAdapter.java  |  17 +-
 .../processors/hadoop/HadoopSerialization.java     |  17 +-
 .../internal/processors/hadoop/HadoopTask.java     |  17 +-
 .../processors/hadoop/HadoopTaskContext.java       |  17 +-
 .../internal/processors/hadoop/HadoopTaskInfo.java |  17 +-
 .../processors/hadoop/HadoopTaskInput.java         |  17 +-
 .../processors/hadoop/HadoopTaskOutput.java        |  17 +-
 .../internal/processors/hadoop/HadoopTaskType.java |  17 +-
 .../processors/hadoop/counter/HadoopCounter.java   |  17 +-
 .../hadoop/counter/HadoopCounterWriter.java        |  17 +-
 .../processors/hadoop/counter/HadoopCounters.java  |  17 +-
 .../hadoop/io/PartiallyOffheapRawComparatorEx.java |  17 +-
 .../processors/hadoop/message/HadoopMessage.java   |  17 +-
 .../internal/processors/hadoop/package-info.java   |  17 +-
 .../hadoop/shuffle/HadoopDirectShuffleMessage.java |  17 +-
 .../hadoop/shuffle/HadoopShuffleAck.java           |  17 +-
 .../hadoop/shuffle/HadoopShuffleFinishRequest.java |  17 +-
 .../shuffle/HadoopShuffleFinishResponse.java       |  17 +-
 .../hadoop/shuffle/HadoopShuffleMessage.java       |  17 +-
 .../processors/igfs/IgfsAbstractOutputStream.java  |  17 +-
 .../internal/processors/igfs/IgfsAckMessage.java   |  17 +-
 .../internal/processors/igfs/IgfsAsyncImpl.java    |  17 +-
 .../internal/processors/igfs/IgfsAttributes.java   |  17 +-
 .../internal/processors/igfs/IgfsBaseBlockKey.java |  17 +-
 .../internal/processors/igfs/IgfsBlockKey.java     |  17 +-
 .../processors/igfs/IgfsBlockLocationImpl.java     |  17 +-
 .../processors/igfs/IgfsBlocksMessage.java         |  17 +-
 .../processors/igfs/IgfsClientSession.java         |  17 +-
 .../IgfsColocatedMetadataAffinityKeyMapper.java    |  17 +-
 .../processors/igfs/IgfsCommunicationMessage.java  |  17 +-
 .../internal/processors/igfs/IgfsContext.java      |  17 +-
 .../internal/processors/igfs/IgfsCreateResult.java |  17 +-
 .../internal/processors/igfs/IgfsDataManager.java  |  17 +-
 .../processors/igfs/IgfsDeleteMessage.java         |  17 +-
 .../internal/processors/igfs/IgfsDeleteResult.java |  17 +-
 .../internal/processors/igfs/IgfsDeleteWorker.java |  17 +-
 .../processors/igfs/IgfsDirectoryInfo.java         |  17 +-
 .../internal/processors/igfs/IgfsEntryInfo.java    |  17 +-
 .../ignite/internal/processors/igfs/IgfsEx.java    |  17 +-
 .../processors/igfs/IgfsFileAffinityRange.java     |  17 +-
 .../internal/processors/igfs/IgfsFileImpl.java     |  17 +-
 .../internal/processors/igfs/IgfsFileInfo.java     |  17 +-
 .../internal/processors/igfs/IgfsFileMap.java      |  17 +-
 .../processors/igfs/IgfsFileWorkerBatch.java       |  17 +-
 .../IgfsFileWorkerBatchCancelledException.java     |  17 +-
 .../processors/igfs/IgfsFragmentizerManager.java   |  17 +-
 .../processors/igfs/IgfsFragmentizerRequest.java   |  17 +-
 .../processors/igfs/IgfsFragmentizerResponse.java  |  17 +-
 .../processors/igfs/IgfsHandshakeResponse.java     |  17 +-
 .../internal/processors/igfs/IgfsHelper.java       |  17 +-
 .../internal/processors/igfs/IgfsHelperImpl.java   |  17 +-
 .../ignite/internal/processors/igfs/IgfsImpl.java  |  17 +-
 .../processors/igfs/IgfsInputStreamDescriptor.java |  17 +-
 .../processors/igfs/IgfsInputStreamImpl.java       |  17 +-
 .../processors/igfs/IgfsInvalidRangeException.java |  17 +-
 .../internal/processors/igfs/IgfsIpcHandler.java   |  17 +-
 .../internal/processors/igfs/IgfsJobImpl.java      |  17 +-
 ...sLazySecondaryFileSystemPositionedReadable.java |  17 +-
 .../internal/processors/igfs/IgfsListingEntry.java |  17 +-
 .../internal/processors/igfs/IgfsLocalMetrics.java |  17 +-
 .../internal/processors/igfs/IgfsManager.java      |  17 +-
 .../internal/processors/igfs/IgfsMetaManager.java  |  17 +-
 .../processors/igfs/IgfsMetricsAdapter.java        |  17 +-
 .../internal/processors/igfs/IgfsModeResolver.java |  17 +-
 .../processors/igfs/IgfsNodePredicate.java         |  17 +-
 .../internal/processors/igfs/IgfsNoopHelper.java   |  17 +-
 .../processors/igfs/IgfsNoopProcessor.java         |  17 +-
 .../processors/igfs/IgfsOutputStreamImpl.java      |  17 +-
 .../processors/igfs/IgfsOutputStreamProxyImpl.java |  17 +-
 .../internal/processors/igfs/IgfsPathIds.java      |  17 +-
 .../processors/igfs/IgfsPathsCreateResult.java     |  17 +-
 .../internal/processors/igfs/IgfsProcessor.java    |  17 +-
 .../processors/igfs/IgfsProcessorAdapter.java      |  17 +-
 .../internal/processors/igfs/IgfsSamplingKey.java  |  17 +-
 .../igfs/IgfsSecondaryFileSystemCreateContext.java |  17 +-
 .../igfs/IgfsSecondaryFileSystemImpl.java          |  17 +-
 .../igfs/IgfsSecondaryInputStreamDescriptor.java   |  17 +-
 .../internal/processors/igfs/IgfsServer.java       |  17 +-
 .../processors/igfs/IgfsServerHandler.java         |  17 +-
 .../processors/igfs/IgfsServerManager.java         |  17 +-
 .../internal/processors/igfs/IgfsStatus.java       |  17 +-
 .../internal/processors/igfs/IgfsSyncMessage.java  |  17 +-
 .../internal/processors/igfs/IgfsTaskArgsImpl.java |  17 +-
 .../internal/processors/igfs/IgfsThread.java       |  17 +-
 .../processors/igfs/IgfsThreadFactory.java         |  17 +-
 .../ignite/internal/processors/igfs/IgfsUtils.java |  17 +-
 .../igfs/client/IgfsClientAbstractCallable.java    |  17 +-
 .../igfs/client/IgfsClientAffinityCallable.java    |  17 +-
 .../igfs/client/IgfsClientDeleteCallable.java      |  17 +-
 .../igfs/client/IgfsClientExistsCallable.java      |  17 +-
 .../igfs/client/IgfsClientInfoCallable.java        |  17 +-
 .../igfs/client/IgfsClientListFilesCallable.java   |  17 +-
 .../igfs/client/IgfsClientListPathsCallable.java   |  17 +-
 .../igfs/client/IgfsClientMkdirsCallable.java      |  17 +-
 .../igfs/client/IgfsClientRenameCallable.java      |  17 +-
 .../igfs/client/IgfsClientSetTimesCallable.java    |  17 +-
 .../igfs/client/IgfsClientSizeCallable.java        |  17 +-
 .../igfs/client/IgfsClientSummaryCallable.java     |  17 +-
 .../igfs/client/IgfsClientUpdateCallable.java      |  17 +-
 .../meta/IgfsClientMetaIdsForPathCallable.java     |  17 +-
 .../meta/IgfsClientMetaInfoForPathCallable.java    |  17 +-
 .../client/meta/IgfsClientMetaUnlockCallable.java  |  17 +-
 .../processors/igfs/data/IgfsDataPutProcessor.java |  17 +-
 .../meta/IgfsMetaDirectoryCreateProcessor.java     |  17 +-
 .../meta/IgfsMetaDirectoryListingAddProcessor.java |  17 +-
 .../IgfsMetaDirectoryListingRemoveProcessor.java   |  17 +-
 .../IgfsMetaDirectoryListingRenameProcessor.java   |  17 +-
 .../IgfsMetaDirectoryListingReplaceProcessor.java  |  17 +-
 .../igfs/meta/IgfsMetaFileCreateProcessor.java     |  17 +-
 .../igfs/meta/IgfsMetaFileLockProcessor.java       |  17 +-
 .../meta/IgfsMetaFileRangeDeleteProcessor.java     |  17 +-
 .../meta/IgfsMetaFileRangeUpdateProcessor.java     |  17 +-
 .../meta/IgfsMetaFileReserveSpaceProcessor.java    |  17 +-
 .../igfs/meta/IgfsMetaFileUnlockProcessor.java     |  17 +-
 .../meta/IgfsMetaUpdatePropertiesProcessor.java    |  17 +-
 .../igfs/meta/IgfsMetaUpdateTimesProcessor.java    |  17 +-
 .../internal/processors/igfs/package-info.java     |  17 +-
 .../secondary/local/LocalFileSystemBlockKey.java   |  17 +-
 .../secondary/local/LocalFileSystemIgfsFile.java   |  17 +-
 .../local/LocalFileSystemPositionedReadable.java   |  17 +-
 .../local/LocalFileSystemSizeVisitor.java          |  17 +-
 .../igfs/secondary/local/LocalFileSystemUtils.java |  17 +-
 .../processors/job/GridJobEventListener.java       |  17 +-
 .../processors/job/GridJobHoldListener.java        |  17 +-
 .../internal/processors/job/GridJobProcessor.java  |  17 +-
 .../internal/processors/job/GridJobWorker.java     |  17 +-
 .../internal/processors/job/package-info.java      |  17 +-
 .../processors/jobmetrics/GridJobMetrics.java      |  17 +-
 .../jobmetrics/GridJobMetricsProcessor.java        |  17 +-
 .../jobmetrics/GridJobMetricsSnapshot.java         |  17 +-
 .../processors/jobmetrics/package-info.java        |  17 +-
 .../processors/marshaller/ClientRequestFuture.java |  17 +-
 .../marshaller/GridMarshallerMappingProcessor.java |  17 +-
 .../internal/processors/marshaller/MappedName.java |  17 +-
 .../marshaller/MappingAcceptedMessage.java         |  17 +-
 .../marshaller/MappingExchangeResult.java          |  17 +-
 .../marshaller/MappingProposedMessage.java         |  17 +-
 .../marshaller/MappingUpdatedListener.java         |  17 +-
 .../marshaller/MarshallerMappingItem.java          |  17 +-
 .../marshaller/MarshallerMappingTransport.java     |  17 +-
 .../marshaller/MissingMappingRequestMessage.java   |  17 +-
 .../marshaller/MissingMappingResponseMessage.java  |  17 +-
 .../metastorage/DistributedMetaStorage.java        |  17 +-
 .../DistributedMetaStorageListener.java            |  17 +-
 .../DistributedMetastorageLifecycleListener.java   |  17 +-
 .../ReadableDistributedMetaStorage.java            |  17 +-
 .../persistence/DistributedMetaStorageBridge.java  |  17 +-
 .../DistributedMetaStorageCasAckMessage.java       |  17 +-
 .../DistributedMetaStorageCasMessage.java          |  17 +-
 .../DistributedMetaStorageClusterNodeData.java     |  17 +-
 .../DistributedMetaStorageHistoryCache.java        |  17 +-
 .../DistributedMetaStorageHistoryItem.java         |  17 +-
 .../persistence/DistributedMetaStorageImpl.java    |  17 +-
 .../DistributedMetaStorageJoiningNodeData.java     |  17 +-
 .../DistributedMetaStorageKeyValuePair.java        |  17 +-
 .../DistributedMetaStorageUpdateAckMessage.java    |  17 +-
 .../DistributedMetaStorageUpdateMessage.java       |  17 +-
 .../persistence/DistributedMetaStorageUtil.java    |  17 +-
 .../persistence/DistributedMetaStorageVersion.java |  17 +-
 .../EmptyDistributedMetaStorageBridge.java         |  17 +-
 ...InMemoryCachedDistributedMetaStorageBridge.java |  17 +-
 .../NotAvailableDistributedMetaStorageBridge.java  |  17 +-
 .../ReadOnlyDistributedMetaStorageBridge.java      |  17 +-
 .../metastorage/persistence/StartupExtras.java     |  17 +-
 .../WritableDistributedMetaStorageBridge.java      |  17 +-
 .../DiscoveryNodeValidationProcessor.java          |  17 +-
 .../OsDiscoveryNodeValidationProcessor.java        |  17 +-
 .../odbc/ClientConnectorConfigurationEx.java       |  17 +-
 .../ClientListenerAbstractConnectionContext.java   |  17 +-
 .../odbc/ClientListenerBufferedParser.java         |  17 +-
 .../odbc/ClientListenerConnectionContext.java      |  17 +-
 .../odbc/ClientListenerMessageParser.java          |  17 +-
 .../processors/odbc/ClientListenerNioListener.java |  17 +-
 .../odbc/ClientListenerNioServerBuffer.java        |  17 +-
 .../processors/odbc/ClientListenerProcessor.java   |  17 +-
 .../odbc/ClientListenerProtocolVersion.java        |  17 +-
 .../processors/odbc/ClientListenerRequest.java     |  17 +-
 .../odbc/ClientListenerRequestHandler.java         |  17 +-
 .../processors/odbc/ClientListenerRequestNoId.java |  17 +-
 .../processors/odbc/ClientListenerResponse.java    |  17 +-
 .../odbc/ClientListenerResponseSender.java         |  17 +-
 .../processors/odbc/SqlListenerDataTypes.java      |  17 +-
 .../internal/processors/odbc/SqlListenerUtils.java |  17 +-
 .../internal/processors/odbc/SqlStateCode.java     |  17 +-
 .../odbc/jdbc/JdbcBatchExecuteRequest.java         |  17 +-
 .../odbc/jdbc/JdbcBatchExecuteResult.java          |  17 +-
 .../odbc/jdbc/JdbcBulkLoadAckResult.java           |  17 +-
 .../odbc/jdbc/JdbcBulkLoadBatchRequest.java        |  17 +-
 .../odbc/jdbc/JdbcBulkLoadProcessor.java           |  17 +-
 .../odbc/jdbc/JdbcCachePartitionsRequest.java      |  17 +-
 .../odbc/jdbc/JdbcCachePartitionsResult.java       |  17 +-
 .../processors/odbc/jdbc/JdbcColumnMeta.java       |  17 +-
 .../processors/odbc/jdbc/JdbcColumnMetaV2.java     |  17 +-
 .../processors/odbc/jdbc/JdbcColumnMetaV3.java     |  17 +-
 .../processors/odbc/jdbc/JdbcColumnMetaV4.java     |  17 +-
 .../odbc/jdbc/JdbcConnectionContext.java           |  17 +-
 .../internal/processors/odbc/jdbc/JdbcCursor.java  |  17 +-
 .../processors/odbc/jdbc/JdbcIndexMeta.java        |  17 +-
 .../processors/odbc/jdbc/JdbcMessageParser.java    |  17 +-
 .../odbc/jdbc/JdbcMetaColumnsRequest.java          |  17 +-
 .../odbc/jdbc/JdbcMetaColumnsResult.java           |  17 +-
 .../odbc/jdbc/JdbcMetaColumnsResultV2.java         |  17 +-
 .../odbc/jdbc/JdbcMetaColumnsResultV3.java         |  17 +-
 .../odbc/jdbc/JdbcMetaColumnsResultV4.java         |  17 +-
 .../odbc/jdbc/JdbcMetaIndexesRequest.java          |  17 +-
 .../odbc/jdbc/JdbcMetaIndexesResult.java           |  17 +-
 .../odbc/jdbc/JdbcMetaParamsRequest.java           |  17 +-
 .../processors/odbc/jdbc/JdbcMetaParamsResult.java |  17 +-
 .../odbc/jdbc/JdbcMetaPrimaryKeysRequest.java      |  17 +-
 .../odbc/jdbc/JdbcMetaPrimaryKeysResult.java       |  17 +-
 .../odbc/jdbc/JdbcMetaSchemasRequest.java          |  17 +-
 .../odbc/jdbc/JdbcMetaSchemasResult.java           |  17 +-
 .../odbc/jdbc/JdbcMetaTablesRequest.java           |  17 +-
 .../processors/odbc/jdbc/JdbcMetaTablesResult.java |  17 +-
 .../processors/odbc/jdbc/JdbcMetadataInfo.java     |  17 +-
 .../odbc/jdbc/JdbcOrderedBatchExecuteRequest.java  |  17 +-
 .../odbc/jdbc/JdbcOrderedBatchExecuteResult.java   |  17 +-
 .../processors/odbc/jdbc/JdbcParameterMeta.java    |  17 +-
 .../processors/odbc/jdbc/JdbcPrimaryKeyMeta.java   |  17 +-
 .../internal/processors/odbc/jdbc/JdbcQuery.java   |  17 +-
 .../odbc/jdbc/JdbcQueryCancelRequest.java          |  17 +-
 .../odbc/jdbc/JdbcQueryCloseRequest.java           |  17 +-
 .../processors/odbc/jdbc/JdbcQueryCursor.java      |  17 +-
 .../processors/odbc/jdbc/JdbcQueryDescriptor.java  |  17 +-
 .../JdbcQueryExecuteMultipleStatementsResult.java  |  17 +-
 .../odbc/jdbc/JdbcQueryExecuteRequest.java         |  17 +-
 .../odbc/jdbc/JdbcQueryExecuteResult.java          |  17 +-
 .../odbc/jdbc/JdbcQueryFetchRequest.java           |  17 +-
 .../processors/odbc/jdbc/JdbcQueryFetchResult.java |  17 +-
 .../odbc/jdbc/JdbcQueryMetadataRequest.java        |  17 +-
 .../odbc/jdbc/JdbcQueryMetadataResult.java         |  17 +-
 .../processors/odbc/jdbc/JdbcRawBinarylizable.java |  17 +-
 .../internal/processors/odbc/jdbc/JdbcRequest.java |  17 +-
 .../processors/odbc/jdbc/JdbcRequestHandler.java   |  17 +-
 .../odbc/jdbc/JdbcRequestHandlerWorker.java        |  17 +-
 .../processors/odbc/jdbc/JdbcResponse.java         |  17 +-
 .../internal/processors/odbc/jdbc/JdbcResult.java  |  17 +-
 .../processors/odbc/jdbc/JdbcResultInfo.java       |  17 +-
 .../processors/odbc/jdbc/JdbcResultWithIo.java     |  17 +-
 .../processors/odbc/jdbc/JdbcStatementType.java    |  17 +-
 .../processors/odbc/jdbc/JdbcTableMeta.java        |  17 +-
 .../internal/processors/odbc/jdbc/JdbcUtils.java   |  17 +-
 .../processors/odbc/odbc/OdbcColumnMeta.java       |  17 +-
 .../odbc/odbc/OdbcConnectionContext.java           |  17 +-
 .../processors/odbc/odbc/OdbcMessageParser.java    |  17 +-
 .../internal/processors/odbc/odbc/OdbcQuery.java   |  17 +-
 .../odbc/odbc/OdbcQueryCloseRequest.java           |  17 +-
 .../processors/odbc/odbc/OdbcQueryCloseResult.java |  17 +-
 .../odbc/odbc/OdbcQueryExecuteBatchRequest.java    |  17 +-
 .../odbc/odbc/OdbcQueryExecuteBatchResult.java     |  17 +-
 .../odbc/odbc/OdbcQueryExecuteRequest.java         |  17 +-
 .../odbc/odbc/OdbcQueryExecuteResult.java          |  17 +-
 .../odbc/odbc/OdbcQueryFetchRequest.java           |  17 +-
 .../processors/odbc/odbc/OdbcQueryFetchResult.java |  17 +-
 .../odbc/odbc/OdbcQueryGetColumnsMetaRequest.java  |  17 +-
 .../odbc/odbc/OdbcQueryGetColumnsMetaResult.java   |  17 +-
 .../odbc/odbc/OdbcQueryGetParamsMetaRequest.java   |  17 +-
 .../odbc/odbc/OdbcQueryGetParamsMetaResult.java    |  17 +-
 .../odbc/odbc/OdbcQueryGetTablesMetaRequest.java   |  17 +-
 .../odbc/odbc/OdbcQueryGetTablesMetaResult.java    |  17 +-
 .../odbc/odbc/OdbcQueryMoreResultsRequest.java     |  17 +-
 .../odbc/odbc/OdbcQueryMoreResultsResult.java      |  17 +-
 .../processors/odbc/odbc/OdbcQueryResults.java     |  17 +-
 .../internal/processors/odbc/odbc/OdbcRequest.java |  17 +-
 .../processors/odbc/odbc/OdbcRequestHandler.java   |  17 +-
 .../odbc/odbc/OdbcRequestHandlerWorker.java        |  17 +-
 .../processors/odbc/odbc/OdbcResponse.java         |  17 +-
 .../processors/odbc/odbc/OdbcResultSet.java        |  17 +-
 .../odbc/odbc/OdbcStreamingBatchRequest.java       |  17 +-
 .../odbc/odbc/OdbcStreamingBatchResult.java        |  17 +-
 .../processors/odbc/odbc/OdbcTableMeta.java        |  17 +-
 .../internal/processors/odbc/odbc/OdbcTypes.java   |  17 +-
 .../internal/processors/odbc/odbc/OdbcUtils.java   |  17 +-
 .../odbc/odbc/escape/OdbcEscapeParseResult.java    |  17 +-
 .../odbc/odbc/escape/OdbcEscapeToken.java          |  17 +-
 .../odbc/odbc/escape/OdbcEscapeType.java           |  17 +-
 .../odbc/odbc/escape/OdbcEscapeUtils.java          |  17 +-
 .../processors/offheap/GridOffHeapProcessor.java   |  17 +-
 .../ignite/internal/processors/package-info.java   |  17 +-
 .../platform/PlatformAbstractBootstrap.java        |  17 +-
 .../PlatformAbstractConfigurationClosure.java      |  17 +-
 .../platform/PlatformAbstractPredicate.java        |  17 +-
 .../platform/PlatformAbstractTarget.java           |  17 +-
 .../processors/platform/PlatformAsyncResult.java   |  17 +-
 .../processors/platform/PlatformBootstrap.java     |  17 +-
 .../platform/PlatformBootstrapFactory.java         |  17 +-
 .../platform/PlatformConfigurationEx.java          |  17 +-
 .../processors/platform/PlatformContext.java       |  17 +-
 .../processors/platform/PlatformContextImpl.java   |  17 +-
 .../platform/PlatformDefaultJavaObjectFactory.java |  17 +-
 .../platform/PlatformEventFilterListener.java      |  17 +-
 .../processors/platform/PlatformException.java     |  17 +-
 .../platform/PlatformExtendedException.java        |  17 +-
 .../processors/platform/PlatformIgnition.java      |  17 +-
 .../platform/PlatformJavaObjectFactoryEx.java      |  17 +-
 .../platform/PlatformJavaObjectFactoryProxy.java   |  17 +-
 .../PlatformJavaObjectSingletonFactory.java        |  17 +-
 .../platform/PlatformNativeException.java          |  17 +-
 .../platform/PlatformNoCallbackException.java      |  17 +-
 .../processors/platform/PlatformNoopProcessor.java |  17 +-
 .../platform/PlatformPluginExtension.java          |  17 +-
 .../processors/platform/PlatformProcessor.java     |  17 +-
 .../processors/platform/PlatformProcessorImpl.java |  17 +-
 .../processors/platform/PlatformTarget.java        |  17 +-
 .../processors/platform/PlatformTargetProxy.java   |  17 +-
 .../platform/PlatformTargetProxyImpl.java          |  17 +-
 .../platform/binary/PlatformBinaryProcessor.java   |  17 +-
 .../processors/platform/cache/PlatformCache.java   |  17 +-
 .../platform/cache/PlatformCacheEntryFilter.java   |  17 +-
 .../cache/PlatformCacheEntryFilterImpl.java        |  17 +-
 .../cache/PlatformCacheEntryProcessor.java         |  17 +-
 .../cache/PlatformCacheEntryProcessorImpl.java     |  17 +-
 .../platform/cache/PlatformCacheExtension.java     |  17 +-
 .../platform/cache/PlatformCacheIterator.java      |  17 +-
 .../cache/PlatformCachePartialUpdateException.java |  17 +-
 .../platform/cache/affinity/PlatformAffinity.java  |  17 +-
 .../cache/affinity/PlatformAffinityFunction.java   |  17 +-
 .../affinity/PlatformAffinityFunctionTarget.java   |  17 +-
 .../cache/affinity/PlatformAffinityUtils.java      |  17 +-
 .../cache/expiry/PlatformExpiryPolicy.java         |  17 +-
 .../cache/expiry/PlatformExpiryPolicyFactory.java  |  17 +-
 .../cache/query/PlatformAbstractQueryCursor.java   |  17 +-
 .../cache/query/PlatformContinuousQuery.java       |  17 +-
 .../cache/query/PlatformContinuousQueryFilter.java |  17 +-
 .../cache/query/PlatformContinuousQueryImpl.java   |  17 +-
 .../cache/query/PlatformContinuousQueryProxy.java  |  17 +-
 .../query/PlatformContinuousQueryRemoteFilter.java |  17 +-
 .../cache/query/PlatformFieldsQueryCursor.java     |  17 +-
 .../platform/cache/query/PlatformQueryCursor.java  |  17 +-
 .../platform/cache/store/PlatformCacheStore.java   |  17 +-
 .../platform/callback/PlatformCallbackGateway.java |  17 +-
 .../platform/callback/PlatformCallbackOp.java      |  23 ++-
 .../platform/callback/PlatformCallbackUtils.java   |  17 +-
 .../client/ClientAffinityTopologyVersion.java      |  17 +-
 .../platform/client/ClientBooleanResponse.java     |  17 +-
 .../platform/client/ClientCloseableResource.java   |  17 +-
 .../client/ClientConnectableNodePartitions.java    |  17 +-
 .../platform/client/ClientConnectionContext.java   |  17 +-
 .../processors/platform/client/ClientFlag.java     |  17 +-
 .../platform/client/ClientIntResponse.java         |  17 +-
 .../platform/client/ClientLongResponse.java        |  17 +-
 .../platform/client/ClientMessageParser.java       |  17 +-
 .../platform/client/ClientObjectResponse.java      |  17 +-
 .../platform/client/ClientRawRequest.java          |  17 +-
 .../processors/platform/client/ClientRequest.java  |  17 +-
 .../platform/client/ClientRequestHandler.java      |  17 +-
 .../client/ClientResourceCloseRequest.java         |  17 +-
 .../platform/client/ClientResourceRegistry.java    |  17 +-
 .../processors/platform/client/ClientResponse.java |  17 +-
 .../processors/platform/client/ClientStatus.java   |  17 +-
 .../platform/client/ClientStringResponse.java      |  17 +-
 .../platform/client/IgniteClientException.java     |  17 +-
 .../client/binary/ClientBinaryTypeGetRequest.java  |  17 +-
 .../client/binary/ClientBinaryTypeGetResponse.java |  17 +-
 .../binary/ClientBinaryTypeNameGetRequest.java     |  17 +-
 .../binary/ClientBinaryTypeNamePutRequest.java     |  17 +-
 .../client/binary/ClientBinaryTypePutRequest.java  |  17 +-
 .../cache/ClientCacheAffinityAwarenessGroup.java   |  17 +-
 .../client/cache/ClientCacheClearKeyRequest.java   |  17 +-
 .../client/cache/ClientCacheClearKeysRequest.java  |  17 +-
 .../client/cache/ClientCacheClearRequest.java      |  17 +-
 .../cache/ClientCacheConfigurationSerializer.java  |  17 +-
 .../cache/ClientCacheContainsKeyRequest.java       |  17 +-
 .../cache/ClientCacheContainsKeysRequest.java      |  17 +-
 .../ClientCacheCreateWithConfigurationRequest.java |  17 +-
 .../cache/ClientCacheCreateWithNameRequest.java    |  17 +-
 .../client/cache/ClientCacheDestroyRequest.java    |  17 +-
 .../client/cache/ClientCacheEntryQueryCursor.java  |  17 +-
 .../client/cache/ClientCacheFieldsQueryCursor.java |  17 +-
 .../client/cache/ClientCacheGetAllRequest.java     |  17 +-
 .../client/cache/ClientCacheGetAllResponse.java    |  17 +-
 .../cache/ClientCacheGetAndPutIfAbsentRequest.java |  17 +-
 .../client/cache/ClientCacheGetAndPutRequest.java  |  17 +-
 .../cache/ClientCacheGetAndRemoveRequest.java      |  17 +-
 .../cache/ClientCacheGetAndReplaceRequest.java     |  17 +-
 .../cache/ClientCacheGetConfigurationRequest.java  |  17 +-
 .../cache/ClientCacheGetConfigurationResponse.java |  17 +-
 .../client/cache/ClientCacheGetNamesRequest.java   |  17 +-
 .../client/cache/ClientCacheGetNamesResponse.java  |  17 +-
 ...ntCacheGetOrCreateWithConfigurationRequest.java |  17 +-
 .../ClientCacheGetOrCreateWithNameRequest.java     |  17 +-
 .../client/cache/ClientCacheGetRequest.java        |  17 +-
 .../client/cache/ClientCacheGetSizeRequest.java    |  17 +-
 .../client/cache/ClientCacheKeyRequest.java        |  17 +-
 .../client/cache/ClientCacheKeyValueRequest.java   |  17 +-
 .../client/cache/ClientCacheKeysRequest.java       |  17 +-
 .../client/cache/ClientCacheLocalPeekRequest.java  |  17 +-
 .../cache/ClientCacheNodePartitionsRequest.java    |  17 +-
 .../cache/ClientCacheNodePartitionsResponse.java   |  17 +-
 .../client/cache/ClientCachePartitionMapping.java  |  17 +-
 .../client/cache/ClientCachePartitionsRequest.java |  17 +-
 .../cache/ClientCachePartitionsResponse.java       |  17 +-
 .../client/cache/ClientCachePutAllRequest.java     |  17 +-
 .../cache/ClientCachePutIfAbsentRequest.java       |  17 +-
 .../client/cache/ClientCachePutRequest.java        |  17 +-
 .../client/cache/ClientCacheQueryCursor.java       |  17 +-
 .../cache/ClientCacheQueryNextPageRequest.java     |  17 +-
 .../cache/ClientCacheQueryNextPageResponse.java    |  17 +-
 .../client/cache/ClientCacheQueryResponse.java     |  17 +-
 .../client/cache/ClientCacheRemoveAllRequest.java  |  17 +-
 .../cache/ClientCacheRemoveIfEqualsRequest.java    |  17 +-
 .../client/cache/ClientCacheRemoveKeyRequest.java  |  17 +-
 .../client/cache/ClientCacheRemoveKeysRequest.java |  17 +-
 .../cache/ClientCacheReplaceIfEqualsRequest.java   |  17 +-
 .../client/cache/ClientCacheReplaceRequest.java    |  17 +-
 .../platform/client/cache/ClientCacheRequest.java  |  17 +-
 .../client/cache/ClientCacheScanQueryRequest.java  |  17 +-
 .../cache/ClientCacheSqlFieldsQueryRequest.java    |  17 +-
 .../cache/ClientCacheSqlFieldsQueryResponse.java   |  17 +-
 .../client/cache/ClientCacheSqlQueryRequest.java   |  17 +-
 .../platform/cluster/PlatformClusterGroup.java     |  17 +-
 .../cluster/PlatformClusterNodeFilter.java         |  17 +-
 .../cluster/PlatformClusterNodeFilterImpl.java     |  17 +-
 .../platform/compute/PlatformAbstractJob.java      |  17 +-
 .../platform/compute/PlatformAbstractTask.java     |  17 +-
 .../compute/PlatformBalancingMultiClosureTask.java |  17 +-
 ...PlatformBalancingSingleClosureAffinityTask.java |  17 +-
 .../PlatformBalancingSingleClosureTask.java        |  17 +-
 .../PlatformBroadcastingMultiClosureTask.java      |  17 +-
 .../PlatformBroadcastingSingleClosureTask.java     |  17 +-
 .../platform/compute/PlatformClosureJob.java       |  17 +-
 .../platform/compute/PlatformCompute.java          |  17 +-
 .../platform/compute/PlatformFullJob.java          |  17 +-
 .../platform/compute/PlatformFullTask.java         |  17 +-
 .../processors/platform/compute/PlatformJob.java   |  17 +-
 .../platform/cpp/PlatformCppBootstrap.java         |  17 +-
 .../platform/cpp/PlatformCppBootstrapFactory.java  |  17 +-
 .../cpp/PlatformCppConfigurationClosure.java       |  17 +-
 .../platform/cpp/PlatformCppConfigurationEx.java   |  17 +-
 .../datastreamer/PlatformDataStreamer.java         |  17 +-
 .../datastreamer/PlatformStreamReceiver.java       |  17 +-
 .../datastreamer/PlatformStreamReceiverImpl.java   |  17 +-
 .../datastructures/PlatformAtomicLong.java         |  17 +-
 .../datastructures/PlatformAtomicReference.java    |  17 +-
 .../datastructures/PlatformAtomicSequence.java     |  17 +-
 .../platform/dotnet/PlatformDotNetBootstrap.java   |  17 +-
 .../dotnet/PlatformDotNetBootstrapFactory.java     |  17 +-
 .../platform/dotnet/PlatformDotNetCacheStore.java  |  17 +-
 .../dotnet/PlatformDotNetConfigurationClosure.java |  17 +-
 .../dotnet/PlatformDotNetConfigurationEx.java      |  17 +-
 .../dotnet/PlatformDotNetConsoleStream.java        |  17 +-
 .../platform/dotnet/PlatformDotNetService.java     |  17 +-
 .../platform/dotnet/PlatformDotNetServiceImpl.java |  17 +-
 .../PlatformDotNetEntityFrameworkCacheEntry.java   |  17 +-
 ...latformDotNetEntityFrameworkCacheExtension.java |  17 +-
 .../PlatformDotNetEntityFrameworkCacheKey.java     |  17 +-
 ...NetEntityFrameworkIncreaseVersionProcessor.java |  17 +-
 .../events/PlatformEventFilterListenerImpl.java    |  17 +-
 .../processors/platform/events/PlatformEvents.java |  17 +-
 .../events/PlatformLocalEventListener.java         |  17 +-
 .../platform/lifecycle/PlatformLifecycleBean.java  |  17 +-
 .../platform/memory/PlatformAbstractMemory.java    |  17 +-
 .../memory/PlatformBigEndianInputStreamImpl.java   |  17 +-
 .../memory/PlatformBigEndianOutputStreamImpl.java  |  17 +-
 .../platform/memory/PlatformExternalMemory.java    |  17 +-
 .../platform/memory/PlatformInputStream.java       |  17 +-
 .../platform/memory/PlatformInputStreamImpl.java   |  17 +-
 .../processors/platform/memory/PlatformMemory.java |  17 +-
 .../platform/memory/PlatformMemoryManager.java     |  17 +-
 .../platform/memory/PlatformMemoryManagerImpl.java |  17 +-
 .../platform/memory/PlatformMemoryPool.java        |  17 +-
 .../platform/memory/PlatformMemoryUtils.java       |  17 +-
 .../platform/memory/PlatformOutputStream.java      |  17 +-
 .../platform/memory/PlatformOutputStreamImpl.java  |  17 +-
 .../platform/memory/PlatformPooledMemory.java      |  17 +-
 .../platform/memory/PlatformUnpooledMemory.java    |  17 +-
 .../platform/message/PlatformMessageFilter.java    |  17 +-
 .../messaging/PlatformMessageFilterImpl.java       |  17 +-
 .../messaging/PlatformMessageLocalFilter.java      |  17 +-
 .../platform/messaging/PlatformMessaging.java      |  17 +-
 .../platform/plugin/PlatformPluginProcessor.java   |  17 +-
 .../cache/PlatformCachePluginConfiguration.java    |  17 +-
 .../platform/services/PlatformAbstractService.java |  17 +-
 .../platform/services/PlatformService.java         |  17 +-
 .../platform/services/PlatformServices.java        |  17 +-
 .../transactions/PlatformTransactions.java         |  17 +-
 .../platform/utils/PlatformConfigurationUtils.java |  17 +-
 .../platform/utils/PlatformFutureUtils.java        |  17 +-
 .../platform/utils/PlatformListenable.java         |  17 +-
 .../platform/utils/PlatformListenableTarget.java   |  17 +-
 .../platform/utils/PlatformReaderBiClosure.java    |  17 +-
 .../platform/utils/PlatformReaderClosure.java      |  17 +-
 .../processors/platform/utils/PlatformUtils.java   |  17 +-
 .../platform/utils/PlatformWriterBiClosure.java    |  17 +-
 .../platform/utils/PlatformWriterClosure.java      |  17 +-
 .../PlatformDotNetSessionCacheExtension.java       |  17 +-
 .../websession/PlatformDotNetSessionData.java      |  17 +-
 .../PlatformDotNetSessionLockProcessor.java        |  17 +-
 .../PlatformDotNetSessionLockResult.java           |  17 +-
 ...PlatformDotNetSessionSetAndUnlockProcessor.java |  17 +-
 .../processors/plugin/CachePluginManager.java      |  17 +-
 .../processors/plugin/IgnitePluginProcessor.java   |  17 +-
 .../internal/processors/pool/PoolProcessor.java    |  17 +-
 .../internal/processors/port/GridPortListener.java |  17 +-
 .../processors/port/GridPortProcessor.java         |  17 +-
 .../internal/processors/port/GridPortRecord.java   |  17 +-
 .../internal/processors/port/package-info.java     |  17 +-
 .../query/CacheQueryObjectValueContext.java        |  17 +-
 .../internal/processors/query/EnlistOperation.java |  17 +-
 .../query/GridQueryCacheObjectsIterator.java       |  17 +-
 .../internal/processors/query/GridQueryCancel.java |  17 +-
 .../processors/query/GridQueryFieldMetadata.java   |  17 +-
 .../processors/query/GridQueryFieldsResult.java    |  17 +-
 .../query/GridQueryFieldsResultAdapter.java        |  17 +-
 .../processors/query/GridQueryIndexDescriptor.java |  17 +-
 .../processors/query/GridQueryIndexing.java        |  17 +-
 .../processors/query/GridQueryProcessor.java       |  17 +-
 .../processors/query/GridQueryProperty.java        |  17 +-
 .../processors/query/GridQueryRowCacheCleaner.java |  17 +-
 .../processors/query/GridQueryTypeDescriptor.java  |  17 +-
 .../processors/query/GridRunningQueryInfo.java     |  17 +-
 .../processors/query/IgniteSQLException.java       |  17 +-
 .../internal/processors/query/NestedTxMode.java    |  17 +-
 .../processors/query/QueryCancellable.java         |  18 +-
 .../internal/processors/query/QueryEntityEx.java   |  17 +-
 .../internal/processors/query/QueryField.java      |  17 +-
 .../processors/query/QueryHistoryMetrics.java      |  18 +-
 .../processors/query/QueryHistoryMetricsKey.java   |  18 +-
 .../processors/query/QueryHistoryMetricsValue.java |  18 +-
 .../processors/query/QueryHistoryTracker.java      |  18 +-
 .../processors/query/QueryIndexDescriptorImpl.java |  17 +-
 .../internal/processors/query/QueryIndexKey.java   |  17 +-
 .../processors/query/QueryKeyValueIterable.java    |  17 +-
 .../processors/query/QueryKeyValueIterator.java    |  17 +-
 .../processors/query/QueryRunningFuture.java       |  18 +-
 .../internal/processors/query/QuerySchema.java     |  17 +-
 .../processors/query/QuerySchemaPatch.java         |  17 +-
 .../processors/query/QueryTypeCandidate.java       |  17 +-
 .../processors/query/QueryTypeDescriptorImpl.java  |  17 +-
 .../internal/processors/query/QueryTypeIdKey.java  |  17 +-
 .../processors/query/QueryTypeNameKey.java         |  17 +-
 .../internal/processors/query/QueryUtils.java      |  17 +-
 .../processors/query/RunningQueryManager.java      |  18 +-
 .../processors/query/SqlClientContext.java         |  17 +-
 .../processors/query/UpdateSourceIterator.java     |  17 +-
 .../twostep/messages/GridQueryCancelRequest.java   |  17 +-
 .../h2/twostep/messages/GridQueryFailResponse.java |  17 +-
 .../twostep/messages/GridQueryNextPageRequest.java |  17 +-
 .../messages/GridQueryNextPageResponse.java        |  17 +-
 .../query/messages/GridQueryKillRequest.java       |  18 +-
 .../query/messages/GridQueryKillResponse.java      |  18 +-
 .../query/property/QueryBinaryProperty.java        |  17 +-
 .../query/property/QueryClassProperty.java         |  17 +-
 .../query/property/QueryFieldAccessor.java         |  17 +-
 .../query/property/QueryMethodsAccessor.java       |  17 +-
 .../query/property/QueryPropertyAccessor.java      |  17 +-
 .../property/QueryReadOnlyMethodsAccessor.java     |  17 +-
 .../query/schema/SchemaExchangeWorkerTask.java     |  17 +-
 .../query/schema/SchemaIndexCacheFilter.java       |  17 +-
 .../query/schema/SchemaIndexCacheVisitor.java      |  17 +-
 .../schema/SchemaIndexCacheVisitorClosure.java     |  17 +-
 .../query/schema/SchemaIndexCacheVisitorImpl.java  |  17 +-
 .../SchemaIndexOperationCancellationToken.java     |  17 +-
 .../schema/SchemaNodeLeaveExchangeWorkerTask.java  |  17 +-
 .../query/schema/SchemaOperationClientFuture.java  |  17 +-
 .../query/schema/SchemaOperationException.java     |  17 +-
 .../query/schema/SchemaOperationManager.java       |  17 +-
 .../query/schema/SchemaOperationWorker.java        |  17 +-
 .../message/SchemaAbstractDiscoveryMessage.java    |  17 +-
 .../message/SchemaFinishDiscoveryMessage.java      |  17 +-
 .../message/SchemaOperationStatusMessage.java      |  17 +-
 .../message/SchemaProposeDiscoveryMessage.java     |  17 +-
 .../SchemaAbstractAlterTableOperation.java         |  17 +-
 .../schema/operation/SchemaAbstractOperation.java  |  17 +-
 .../SchemaAlterTableAddColumnOperation.java        |  17 +-
 .../SchemaAlterTableDropColumnOperation.java       |  17 +-
 .../operation/SchemaIndexAbstractOperation.java    |  17 +-
 .../operation/SchemaIndexCreateOperation.java      |  17 +-
 .../schema/operation/SchemaIndexDropOperation.java |  17 +-
 .../resource/GridNoImplicitInjection.java          |  17 +-
 .../resource/GridResourceBasicInjector.java        |  17 +-
 .../processors/resource/GridResourceField.java     |  17 +-
 .../processors/resource/GridResourceInjector.java  |  17 +-
 .../processors/resource/GridResourceIoc.java       |  17 +-
 .../resource/GridResourceJobContextInjector.java   |  17 +-
 .../resource/GridResourceLoggerInjector.java       |  17 +-
 .../processors/resource/GridResourceMethod.java    |  17 +-
 .../processors/resource/GridResourceProcessor.java |  17 +-
 .../resource/GridResourceServiceInjector.java      |  17 +-
 .../processors/resource/GridResourceUtils.java     |  17 +-
 .../resource/GridSpringResourceContext.java        |  17 +-
 .../internal/processors/resource/package-info.java |  17 +-
 .../internal/processors/rest/GridRestCommand.java  |  17 +-
 .../processors/rest/GridRestProcessor.java         |  17 +-
 .../internal/processors/rest/GridRestProtocol.java |  17 +-
 .../processors/rest/GridRestProtocolHandler.java   |  17 +-
 .../internal/processors/rest/GridRestResponse.java |  17 +-
 .../client/message/GridClientAbstractMessage.java  |  17 +-
 .../message/GridClientAuthenticationRequest.java   |  17 +-
 .../client/message/GridClientBinaryMetaData.java   |  17 +-
 .../rest/client/message/GridClientCacheBean.java   |  17 +-
 .../client/message/GridClientCacheRequest.java     |  17 +-
 .../client/message/GridClientHandshakeRequest.java |  17 +-
 .../message/GridClientHandshakeResponse.java       |  17 +-
 .../rest/client/message/GridClientMessage.java     |  17 +-
 .../rest/client/message/GridClientNodeBean.java    |  17 +-
 .../client/message/GridClientNodeMetricsBean.java  |  17 +-
 .../rest/client/message/GridClientPingPacket.java  |  17 +-
 .../rest/client/message/GridClientResponse.java    |  17 +-
 .../client/message/GridClientStateRequest.java     |  17 +-
 .../rest/client/message/GridClientTaskRequest.java |  17 +-
 .../client/message/GridClientTaskResultBean.java   |  17 +-
 .../client/message/GridClientTopologyRequest.java  |  17 +-
 .../rest/client/message/GridRouterRequest.java     |  17 +-
 .../rest/client/message/GridRouterResponse.java    |  17 +-
 .../rest/client/message/package-info.java          |  17 +-
 .../rest/handlers/GridRestCommandHandler.java      |  17 +-
 .../handlers/GridRestCommandHandlerAdapter.java    |  17 +-
 .../auth/AuthenticationCommandHandler.java         |  17 +-
 .../rest/handlers/auth/package-info.java           |  17 +-
 .../handlers/cache/GridCacheCommandHandler.java    |  17 +-
 .../rest/handlers/cache/GridCacheRestMetrics.java  |  17 +-
 .../rest/handlers/cache/GridCacheRestResponse.java |  17 +-
 .../rest/handlers/cache/package-info.java          |  17 +-
 .../cluster/GridBaselineCommandHandler.java        |  17 +-
 .../cluster/GridBaselineCommandResponse.java       |  17 +-
 .../cluster/GridChangeStateCommandHandler.java     |  17 +-
 .../DataStructuresCommandHandler.java              |  17 +-
 .../rest/handlers/log/GridLogCommandHandler.java   |  17 +-
 .../memory/MemoryMetricsCommandHandler.java        |  17 +-
 .../processors/rest/handlers/package-info.java     |  17 +-
 .../handlers/query/CacheQueryFieldsMetaResult.java |  17 +-
 .../rest/handlers/query/CacheQueryResult.java      |  17 +-
 .../rest/handlers/query/QueryCommandHandler.java   |  17 +-
 .../handlers/redis/GridRedisCommandHandler.java    |  17 +-
 .../redis/GridRedisConnectionCommandHandler.java   |  17 +-
 .../redis/GridRedisRestCommandHandler.java         |  17 +-
 .../redis/exception/GridRedisGenericException.java |  17 +-
 .../redis/exception/GridRedisTypeException.java    |  17 +-
 .../redis/key/GridRedisDelCommandHandler.java      |  17 +-
 .../redis/key/GridRedisExistsCommandHandler.java   |  17 +-
 .../redis/key/GridRedisExpireCommandHandler.java   |  17 +-
 .../rest/handlers/redis/package-info.java          |  17 +-
 .../server/GridRedisDbSizeCommandHandler.java      |  17 +-
 .../redis/server/GridRedisFlushCommandHandler.java |  17 +-
 .../string/GridRedisAppendCommandHandler.java      |  17 +-
 .../redis/string/GridRedisGetCommandHandler.java   |  17 +-
 .../string/GridRedisGetRangeCommandHandler.java    |  17 +-
 .../string/GridRedisGetSetCommandHandler.java      |  17 +-
 .../string/GridRedisIncrDecrCommandHandler.java    |  17 +-
 .../redis/string/GridRedisMGetCommandHandler.java  |  17 +-
 .../redis/string/GridRedisMSetCommandHandler.java  |  17 +-
 .../redis/string/GridRedisSetCommandHandler.java   |  17 +-
 .../string/GridRedisSetRangeCommandHandler.java    |  17 +-
 .../string/GridRedisStrlenCommandHandler.java      |  17 +-
 .../rest/handlers/task/GridTaskCommandHandler.java |  17 +-
 .../rest/handlers/task/GridTaskResultRequest.java  |  17 +-
 .../rest/handlers/task/GridTaskResultResponse.java |  17 +-
 .../handlers/top/GridTopologyCommandHandler.java   |  17 +-
 .../processors/rest/handlers/top/package-info.java |  17 +-
 .../handlers/user/UserActionCommandHandler.java    |  17 +-
 .../rest/handlers/user/package-info.java           |  17 +-
 .../version/GridVersionCommandHandler.java         |  17 +-
 .../rest/handlers/version/package-info.java        |  17 +-
 .../internal/processors/rest/package-info.java     |  17 +-
 .../rest/protocols/GridRestProtocolAdapter.java    |  17 +-
 .../processors/rest/protocols/package-info.java    |  17 +-
 .../rest/protocols/tcp/GridClientPacketType.java   |  17 +-
 .../rest/protocols/tcp/GridMemcachedMessage.java   |  17 +-
 .../protocols/tcp/GridTcpMemcachedNioListener.java |  17 +-
 .../rest/protocols/tcp/GridTcpRestNioListener.java |  17 +-
 .../rest/protocols/tcp/GridTcpRestParser.java      |  17 +-
 .../rest/protocols/tcp/GridTcpRestProtocol.java    |  17 +-
 .../rest/protocols/tcp/package-info.java           |  17 +-
 .../rest/protocols/tcp/redis/GridRedisCommand.java |  17 +-
 .../rest/protocols/tcp/redis/GridRedisMessage.java |  17 +-
 .../protocols/tcp/redis/GridRedisNioListener.java  |  17 +-
 .../tcp/redis/GridRedisProtocolParser.java         |  17 +-
 .../rest/request/DataStructuresRequest.java        |  17 +-
 .../rest/request/GridRestBaselineRequest.java      |  17 +-
 .../rest/request/GridRestCacheRequest.java         |  17 +-
 .../rest/request/GridRestChangeStateRequest.java   |  17 +-
 .../rest/request/GridRestLogRequest.java           |  17 +-
 .../processors/rest/request/GridRestRequest.java   |  17 +-
 .../rest/request/GridRestTaskRequest.java          |  17 +-
 .../rest/request/GridRestTopologyRequest.java      |  17 +-
 .../processors/rest/request/RestQueryRequest.java  |  17 +-
 .../rest/request/RestUserActionRequest.java        |  17 +-
 .../processors/rest/request/package-info.java      |  17 +-
 .../schedule/GridScheduleStatistics.java           |  17 +-
 .../schedule/IgniteNoopScheduleProcessor.java      |  17 +-
 .../schedule/IgniteScheduleProcessorAdapter.java   |  17 +-
 .../internal/processors/schedule/package-info.java |  17 +-
 .../processors/security/GridSecurityProcessor.java |  17 +-
 .../processors/security/SecurityContext.java       |  17 +-
 .../processors/security/SecurityContextHolder.java |  17 +-
 .../processors/security/SecurityUtils.java         |  17 +-
 .../security/os/GridOsSecurityProcessor.java       |  17 +-
 .../segmentation/GridSegmentationProcessor.java    |  17 +-
 .../os/GridOsSegmentationProcessor.java            |  17 +-
 .../processors/segmentation/package-info.java      |  17 +-
 .../processors/service/GridServiceAssignments.java |  17 +-
 .../service/GridServiceAssignmentsKey.java         |  17 +-
 .../processors/service/GridServiceDeployment.java  |  17 +-
 .../GridServiceDeploymentCompoundFuture.java       |  17 +-
 .../service/GridServiceDeploymentFuture.java       |  17 +-
 .../service/GridServiceDeploymentKey.java          |  17 +-
 .../GridServiceMethodNotFoundException.java        |  17 +-
 .../service/GridServiceMethodReflectKey.java       |  17 +-
 .../service/GridServiceNotFoundException.java      |  17 +-
 .../processors/service/GridServiceProcessor.java   |  17 +-
 .../processors/service/GridServiceProxy.java       |  17 +-
 .../processors/service/IgniteServiceProcessor.java |  17 +-
 .../service/LazyServiceConfiguration.java          |  17 +-
 .../processors/service/PreparedConfigurations.java |  17 +-
 .../service/ServiceChangeAbstractRequest.java      |  17 +-
 .../service/ServiceChangeBatchRequest.java         |  17 +-
 .../service/ServiceClusterDeploymentResult.java    |  17 +-
 .../ServiceClusterDeploymentResultBatch.java       |  17 +-
 .../processors/service/ServiceContextImpl.java     |  17 +-
 .../service/ServiceDeploymentActions.java          |  17 +-
 .../service/ServiceDeploymentManager.java          |  17 +-
 .../service/ServiceDeploymentProcessId.java        |  17 +-
 .../service/ServiceDeploymentRequest.java          |  17 +-
 .../processors/service/ServiceDeploymentTask.java  |  17 +-
 .../processors/service/ServiceDescriptorImpl.java  |  17 +-
 .../internal/processors/service/ServiceInfo.java   |  17 +-
 .../service/ServiceProcessorAdapter.java           |  17 +-
 .../ServiceProcessorCommonDiscoveryData.java       |  17 +-
 .../ServiceProcessorJoinNodeDiscoveryData.java     |  17 +-
 .../service/ServiceSingleNodeDeploymentResult.java |  17 +-
 .../ServiceSingleNodeDeploymentResultBatch.java    |  17 +-
 .../service/ServiceUndeploymentRequest.java        |  17 +-
 .../session/GridTaskSessionProcessor.java          |  17 +-
 .../internal/processors/session/package-info.java  |  17 +-
 .../GridInternalSubscriptionProcessor.java         |  17 +-
 .../internal/processors/task/GridInternal.java     |  17 +-
 .../processors/task/GridTaskEventListener.java     |  17 +-
 .../processors/task/GridTaskProcessor.java         |  17 +-
 .../processors/task/GridTaskThreadContextKey.java  |  17 +-
 .../internal/processors/task/GridTaskWorker.java   |  17 +-
 .../processors/task/GridVisorManagementTask.java   |  17 +-
 .../internal/processors/task/package-info.java     |  17 +-
 .../processors/timeout/GridSpiTimeoutObject.java   |  17 +-
 .../processors/timeout/GridTimeoutObject.java      |  17 +-
 .../timeout/GridTimeoutObjectAdapter.java          |  17 +-
 .../processors/timeout/GridTimeoutProcessor.java   |  17 +-
 .../internal/processors/timeout/package-info.java  |  17 +-
 .../org/apache/ignite/internal/sql/SqlKeyword.java |  17 +-
 .../org/apache/ignite/internal/sql/SqlLexer.java   |  17 +-
 .../internal/sql/SqlLexerLookAheadToken.java       |  17 +-
 .../apache/ignite/internal/sql/SqlLexerToken.java  |  17 +-
 .../ignite/internal/sql/SqlLexerTokenType.java     |  19 +-
 .../ignite/internal/sql/SqlParseException.java     |  17 +-
 .../org/apache/ignite/internal/sql/SqlParser.java  |  17 +-
 .../apache/ignite/internal/sql/SqlParserUtils.java |  17 +-
 .../internal/sql/SqlStrictParseException.java      |  17 +-
 .../internal/sql/command/SqlAlterTableCommand.java |  17 +-
 .../internal/sql/command/SqlAlterUserCommand.java  |  17 +-
 .../sql/command/SqlBeginTransactionCommand.java    |  17 +-
 .../internal/sql/command/SqlBulkLoadCommand.java   |  17 +-
 .../ignite/internal/sql/command/SqlCommand.java    |  17 +-
 .../sql/command/SqlCommitTransactionCommand.java   |  17 +-
 .../sql/command/SqlCreateIndexCommand.java         |  17 +-
 .../internal/sql/command/SqlCreateUserCommand.java |  17 +-
 .../internal/sql/command/SqlDropIndexCommand.java  |  17 +-
 .../internal/sql/command/SqlDropUserCommand.java   |  17 +-
 .../internal/sql/command/SqlIndexColumn.java       |  17 +-
 .../internal/sql/command/SqlKillQueryCommand.java  |  18 +-
 .../internal/sql/command/SqlQualifiedName.java     |  17 +-
 .../sql/command/SqlRollbackTransactionCommand.java |  17 +-
 .../sql/command/SqlSetStreamingCommand.java        |  17 +-
 .../affinity/PartitionAffinityFunctionType.java    |  17 +-
 .../sql/optimizer/affinity/PartitionAllNode.java   |  17 +-
 .../optimizer/affinity/PartitionClientContext.java |  17 +-
 .../optimizer/affinity/PartitionCompositeNode.java |  17 +-
 .../affinity/PartitionCompositeNodeOperator.java   |  17 +-
 .../optimizer/affinity/PartitionConstantNode.java  |  17 +-
 .../optimizer/affinity/PartitionDataTypeUtils.java |  17 +-
 .../sql/optimizer/affinity/PartitionGroupNode.java |  17 +-
 .../optimizer/affinity/PartitionJoinCondition.java |  17 +-
 .../sql/optimizer/affinity/PartitionJoinGroup.java |  17 +-
 .../sql/optimizer/affinity/PartitionNode.java      |  17 +-
 .../sql/optimizer/affinity/PartitionNoneNode.java  |  17 +-
 .../optimizer/affinity/PartitionParameterNode.java |  17 +-
 .../optimizer/affinity/PartitionParameterType.java |  17 +-
 .../sql/optimizer/affinity/PartitionResolver.java  |  17 +-
 .../sql/optimizer/affinity/PartitionResult.java    |  17 +-
 .../affinity/PartitionResultMarshaler.java         |  17 +-
 .../optimizer/affinity/PartitionSingleNode.java    |  17 +-
 .../sql/optimizer/affinity/PartitionTable.java     |  17 +-
 .../affinity/PartitionTableAffinityDescriptor.java |  17 +-
 .../optimizer/affinity/PartitionTableModel.java    |  17 +-
 .../apache/ignite/internal/stat/IndexPageType.java |  18 +-
 .../ignite/internal/stat/IoStatisticsHolder.java   |  18 +-
 .../internal/stat/IoStatisticsHolderCache.java     |  18 +-
 .../internal/stat/IoStatisticsHolderIndex.java     |  18 +-
 .../internal/stat/IoStatisticsHolderKey.java       |  18 +-
 .../internal/stat/IoStatisticsHolderNoOp.java      |  18 +-
 .../internal/stat/IoStatisticsHolderQuery.java     |  18 +-
 .../ignite/internal/stat/IoStatisticsManager.java  |  18 +-
 .../stat/IoStatisticsMetricsLocalMXBeanImpl.java   |  18 +-
 .../internal/stat/IoStatisticsQueryHelper.java     |  18 +-
 .../ignite/internal/stat/IoStatisticsType.java     |  18 +-
 .../suggestions/GridPerformanceSuggestions.java    |  17 +-
 .../suggestions/JvmConfigurationSuggestions.java   |  17 +-
 .../suggestions/OsConfigurationSuggestions.java    |  17 +-
 .../ignite/internal/suggestions/package-info.java  |  17 +-
 .../ignite/internal/tck/TCKMBeanServerBuilder.java |  17 +-
 .../IgniteTxAlreadyCompletedCheckedException.java  |  17 +-
 .../IgniteTxDuplicateKeyCheckedException.java      |  17 +-
 .../IgniteTxHeuristicCheckedException.java         |  17 +-
 .../IgniteTxOptimisticCheckedException.java        |  17 +-
 .../IgniteTxRollbackCheckedException.java          |  17 +-
 .../IgniteTxSerializationCheckedException.java     |  17 +-
 .../IgniteTxTimeoutCheckedException.java           |  17 +-
 .../IgniteTxUnexpectedStateCheckedException.java   |  17 +-
 .../transactions/TransactionCheckedException.java  |  17 +-
 .../apache/ignite/internal/util/BitSetIntSet.java  |  17 +-
 .../apache/ignite/internal/util/ClassCache.java    |  17 +-
 .../ignite/internal/util/DirectBufferCleaner.java  |  17 +-
 .../java/org/apache/ignite/internal/util/F0.java   |  17 +-
 .../ignite/internal/util/FeatureChecker.java       |  17 +-
 .../ignite/internal/util/GridAnnotationsCache.java |  17 +-
 .../ignite/internal/util/GridArgumentCheck.java    |  17 +-
 .../apache/ignite/internal/util/GridArrays.java    |  17 +-
 .../internal/util/GridAtomicInitializer.java       |  17 +-
 .../ignite/internal/util/GridAtomicInteger.java    |  17 +-
 .../ignite/internal/util/GridAtomicLong.java       |  17 +-
 .../util/GridBoundedConcurrentLinkedHashMap.java   |  17 +-
 .../util/GridBoundedConcurrentLinkedHashSet.java   |  17 +-
 .../util/GridBoundedConcurrentOrderedMap.java      |  17 +-
 .../util/GridBoundedConcurrentOrderedSet.java      |  17 +-
 .../internal/util/GridBoundedLinkedHashMap.java    |  17 +-
 .../internal/util/GridBoundedLinkedHashSet.java    |  17 +-
 .../internal/util/GridBoundedPriorityQueue.java    |  17 +-
 .../apache/ignite/internal/util/GridBusyLock.java  |  17 +-
 .../ignite/internal/util/GridByteArrayList.java    |  17 +-
 .../ignite/internal/util/GridCircularBuffer.java   |  17 +-
 .../ignite/internal/util/GridClassLoaderCache.java |  17 +-
 .../apache/ignite/internal/util/GridCleaner.java   |  17 +-
 .../ignite/internal/util/GridClientByteUtils.java  |  17 +-
 .../util/GridCloseableIteratorAdapter.java         |  17 +-
 .../util/GridCloseableIteratorAdapterEx.java       |  17 +-
 .../ignite/internal/util/GridCollections.java      |  17 +-
 .../internal/util/GridConcurrentFactory.java       |  17 +-
 .../internal/util/GridConcurrentHashSet.java       |  17 +-
 .../internal/util/GridConcurrentLinkedHashSet.java |  17 +-
 .../util/GridConcurrentPhantomHashSet.java         |  17 +-
 .../internal/util/GridConcurrentSkipListSet.java   |  17 +-
 .../internal/util/GridConcurrentWeakHashSet.java   |  17 +-
 .../internal/util/GridConfigurationFinder.java     |  17 +-
 .../ignite/internal/util/GridConsistentHash.java   |  17 +-
 .../internal/util/GridCursorIteratorWrapper.java   |  17 +-
 .../org/apache/ignite/internal/util/GridDebug.java |  17 +-
 .../internal/util/GridEmptyCloseableIterator.java  |  17 +-
 .../ignite/internal/util/GridEmptyIterator.java    |  17 +-
 .../internal/util/GridFixedSizeInputStream.java    |  17 +-
 .../ignite/internal/util/GridHandleTable.java      |  17 +-
 .../ignite/internal/util/GridIntIterator.java      |  17 +-
 .../apache/ignite/internal/util/GridIntList.java   |  17 +-
 .../ignite/internal/util/GridJavaProcess.java      |  17 +-
 .../apache/ignite/internal/util/GridKeyLock.java   |  17 +-
 .../ignite/internal/util/GridLeanIdentitySet.java  |  17 +-
 .../apache/ignite/internal/util/GridLeanMap.java   |  17 +-
 .../apache/ignite/internal/util/GridLeanSet.java   |  17 +-
 .../apache/ignite/internal/util/GridListSet.java   |  17 +-
 .../ignite/internal/util/GridLogThrottle.java      |  17 +-
 .../apache/ignite/internal/util/GridLongList.java  |  17 +-
 .../internal/util/GridMessageCollection.java       |  17 +-
 .../internal/util/GridMultiCollectionWrapper.java  |  17 +-
 .../org/apache/ignite/internal/util/GridMutex.java |  17 +-
 .../internal/util/GridPartitionStateMap.java       |  17 +-
 .../org/apache/ignite/internal/util/GridQueue.java |  17 +-
 .../apache/ignite/internal/util/GridRandom.java    |  17 +-
 .../internal/util/GridReadOnlyArrayView.java       |  29 ++-
 .../ignite/internal/util/GridReflectionCache.java  |  17 +-
 .../internal/util/GridSerializableCollection.java  |  17 +-
 .../internal/util/GridSerializableIterable.java    |  17 +-
 .../internal/util/GridSerializableIterator.java    |  17 +-
 .../ignite/internal/util/GridSerializableList.java |  17 +-
 .../ignite/internal/util/GridSerializableMap.java  |  17 +-
 .../ignite/internal/util/GridSerializableSet.java  |  17 +-
 .../ignite/internal/util/GridSetWrapper.java       |  17 +-
 .../ignite/internal/util/GridSnapshotLock.java     |  17 +-
 .../util/GridSpiCloseableIteratorWrapper.java      |  17 +-
 .../ignite/internal/util/GridSpinBusyLock.java     |  17 +-
 .../internal/util/GridSpinReadWriteLock.java       |  17 +-
 .../ignite/internal/util/GridStringBuilder.java    |  17 +-
 .../internal/util/GridStringBuilderFactory.java    |  17 +-
 .../ignite/internal/util/GridStripedLock.java      |  17 +-
 .../internal/util/GridStripedReadWriteLock.java    |  17 +-
 .../internal/util/GridStripedSpinBusyLock.java     |  17 +-
 .../ignite/internal/util/GridSynchronizedMap.java  |  17 +-
 .../org/apache/ignite/internal/util/GridTimer.java |  17 +-
 .../apache/ignite/internal/util/GridTimerTask.java |  17 +-
 .../apache/ignite/internal/util/GridUnsafe.java    |  17 +-
 .../ignite/internal/util/GridWeakIterator.java     |  17 +-
 .../ignite/internal/util/HostAndPortRange.java     |  17 +-
 .../internal/util/IgniteExceptionRegistry.java     |  17 +-
 .../ignite/internal/util/IgniteStopwatch.java      |  17 +-
 .../apache/ignite/internal/util/IgniteTicker.java  |  17 +-
 .../apache/ignite/internal/util/IgniteTree.java    |  17 +-
 .../apache/ignite/internal/util/IgniteUtils.java   |  17 +-
 .../ignite/internal/util/IgniteUuidCache.java      |  17 +-
 .../internal/util/InitializationProtector.java     |  17 +-
 .../ignite/internal/util/MutableSingletonList.java |  17 +-
 .../ignite/internal/util/OffheapReadWriteLock.java |  17 +-
 .../util/ReflectiveDirectBufferCleaner.java        |  17 +-
 .../internal/util/SerializableTransient.java       |  17 +-
 .../util/StripedCompositeReadWriteLock.java        |  17 +-
 .../ignite/internal/util/StripedExecutor.java      |  17 +-
 .../org/apache/ignite/internal/util/TimeBag.java   |  17 +-
 .../internal/util/TransientSerializable.java       |  17 +-
 .../internal/util/UUIDCollectionMessage.java       |  17 +-
 .../internal/util/UnsafeDirectBufferCleaner.java   |  17 +-
 .../internal/util/future/AsyncFutureListener.java  |  17 +-
 .../internal/util/future/CountDownFuture.java      |  17 +-
 .../internal/util/future/GridCompoundFuture.java   |  17 +-
 .../util/future/GridCompoundIdentityFuture.java    |  17 +-
 .../internal/util/future/GridEmbeddedFuture.java   |  17 +-
 .../internal/util/future/GridFinishedFuture.java   |  17 +-
 .../internal/util/future/GridFutureAdapter.java    |  17 +-
 .../util/future/GridFutureChainListener.java       |  17 +-
 .../util/future/IgniteFinishedFutureImpl.java      |  17 +-
 .../internal/util/future/IgniteFutureImpl.java     |  17 +-
 .../internal/util/future/IgniteRemoteMapTask.java  |  17 +-
 .../ignite/internal/util/future/package-info.java  |  17 +-
 .../util/gridify/GridifyArgumentBuilder.java       |  17 +-
 .../internal/util/gridify/GridifyJobAdapter.java   |  17 +-
 .../util/gridify/GridifyRangeArgument.java         |  17 +-
 .../ignite/internal/util/gridify/GridifyUtils.java |  17 +-
 .../ignite/internal/util/gridify/package-info.java |  17 +-
 .../internal/util/io/GridByteArrayInputStream.java |  17 +-
 .../util/io/GridByteArrayOutputStream.java         |  17 +-
 .../ignite/internal/util/io/GridDataInput.java     |  17 +-
 .../ignite/internal/util/io/GridDataOutput.java    |  17 +-
 .../ignite/internal/util/io/GridFileUtils.java     |  17 +-
 .../ignite/internal/util/io/GridFilenameUtils.java |  17 +-
 .../util/io/GridReversedLinesFileReader.java       |  17 +-
 .../internal/util/io/GridUnsafeDataInput.java      |  17 +-
 .../internal/util/io/GridUnsafeDataOutput.java     |  17 +-
 .../ignite/internal/util/ipc/IpcEndpoint.java      |  17 +-
 .../util/ipc/IpcEndpointBindException.java         |  17 +-
 .../internal/util/ipc/IpcEndpointFactory.java      |  17 +-
 .../ignite/internal/util/ipc/IpcEndpointType.java  |  17 +-
 .../internal/util/ipc/IpcServerEndpoint.java       |  17 +-
 .../ignite/internal/util/ipc/IpcToNioAdapter.java  |  17 +-
 .../util/ipc/loopback/IpcClientTcpEndpoint.java    |  17 +-
 .../util/ipc/loopback/IpcServerTcpEndpoint.java    |  17 +-
 .../internal/util/ipc/loopback/package-info.java   |  17 +-
 .../ignite/internal/util/ipc/package-info.java     |  17 +-
 .../shmem/IpcOutOfSystemResourcesException.java    |  17 +-
 .../ipc/shmem/IpcSharedMemoryClientEndpoint.java   |  17 +-
 .../util/ipc/shmem/IpcSharedMemoryInitRequest.java |  17 +-
 .../ipc/shmem/IpcSharedMemoryInitResponse.java     |  17 +-
 .../util/ipc/shmem/IpcSharedMemoryInputStream.java |  17 +-
 .../ipc/shmem/IpcSharedMemoryNativeLoader.java     |  17 +-
 .../IpcSharedMemoryOperationTimedoutException.java |  17 +-
 .../ipc/shmem/IpcSharedMemoryOutputStream.java     |  17 +-
 .../ipc/shmem/IpcSharedMemoryServerEndpoint.java   |  17 +-
 .../util/ipc/shmem/IpcSharedMemorySpace.java       |  17 +-
 .../util/ipc/shmem/IpcSharedMemoryUtils.java       |  17 +-
 .../internal/util/ipc/shmem/package-info.java      |  17 +-
 .../ignite/internal/util/lang/GridAbsClosure.java  |  17 +-
 .../ignite/internal/util/lang/GridAbsClosureX.java |  17 +-
 .../internal/util/lang/GridAbsPredicate.java       |  17 +-
 .../internal/util/lang/GridAbsPredicateX.java      |  17 +-
 .../internal/util/lang/GridCloseableIterator.java  |  17 +-
 .../ignite/internal/util/lang/GridClosure3.java    |  17 +-
 .../ignite/internal/util/lang/GridClosure3X.java   |  17 +-
 .../internal/util/lang/GridClosureException.java   |  17 +-
 .../ignite/internal/util/lang/GridCursor.java      |  17 +-
 .../util/lang/GridFilteredClosableIterator.java    |  17 +-
 .../internal/util/lang/GridFilteredIterator.java   |  17 +-
 .../apache/ignite/internal/util/lang/GridFunc.java |  17 +-
 .../ignite/internal/util/lang/GridInClosure3.java  |  17 +-
 .../ignite/internal/util/lang/GridInClosure3X.java |  17 +-
 .../ignite/internal/util/lang/GridIterable.java    |  17 +-
 .../internal/util/lang/GridIterableAdapter.java    |  17 +-
 .../ignite/internal/util/lang/GridIterator.java    |  17 +-
 .../internal/util/lang/GridIteratorAdapter.java    |  17 +-
 .../ignite/internal/util/lang/GridMapEntry.java    |  17 +-
 .../util/lang/GridMetadataAwareAdapter.java        |  17 +-
 .../internal/util/lang/GridNodePredicate.java      |  17 +-
 .../internal/util/lang/GridPeerDeployAware.java    |  17 +-
 .../util/lang/GridPeerDeployAwareAdapter.java      |  17 +-
 .../internal/util/lang/GridPlainAbsClosure.java    |  17 +-
 .../internal/util/lang/GridPlainCallable.java      |  17 +-
 .../internal/util/lang/GridPlainClosure.java       |  17 +-
 .../internal/util/lang/GridPlainClosure2.java      |  17 +-
 .../internal/util/lang/GridPlainInClosure.java     |  17 +-
 .../internal/util/lang/GridPlainOutClosure.java    |  17 +-
 .../internal/util/lang/GridPlainRunnable.java      |  17 +-
 .../ignite/internal/util/lang/GridPredicate3.java  |  17 +-
 .../ignite/internal/util/lang/GridPredicate3X.java |  17 +-
 .../ignite/internal/util/lang/GridTreePrinter.java |  17 +-
 .../ignite/internal/util/lang/GridTriple.java      |  17 +-
 .../ignite/internal/util/lang/GridTuple.java       |  17 +-
 .../ignite/internal/util/lang/GridTuple3.java      |  17 +-
 .../ignite/internal/util/lang/GridTuple4.java      |  17 +-
 .../ignite/internal/util/lang/GridTuple5.java      |  17 +-
 .../ignite/internal/util/lang/GridTuple6.java      |  17 +-
 .../ignite/internal/util/lang/IgniteClosure2X.java |  17 +-
 .../ignite/internal/util/lang/IgniteClosureX.java  |  17 +-
 .../internal/util/lang/IgniteInClosure2X.java      |  17 +-
 .../internal/util/lang/IgniteInClosureX.java       |  17 +-
 .../internal/util/lang/IgniteOutClosureX.java      |  17 +-
 .../ignite/internal/util/lang/IgnitePair.java      |  17 +-
 .../internal/util/lang/IgnitePredicate2X.java      |  17 +-
 .../internal/util/lang/IgnitePredicateX.java       |  17 +-
 .../ignite/internal/util/lang/IgniteReducer2.java  |  17 +-
 .../ignite/internal/util/lang/IgniteReducer2X.java |  17 +-
 .../ignite/internal/util/lang/IgniteReducer3.java  |  17 +-
 .../ignite/internal/util/lang/IgniteReducer3X.java |  17 +-
 .../ignite/internal/util/lang/IgniteReducerX.java  |  17 +-
 .../util/lang/IgniteSingletonIterator.java         |  17 +-
 .../util/lang/IgniteThrowableConsumer.java         |  17 +-
 .../util/lang/IgniteThrowableFunction.java         |  17 +-
 .../internal/util/lang/IgniteThrowableRunner.java  |  17 +-
 .../util/lang/gridfunc/AlwaysFalsePredicate.java   |  17 +-
 .../util/lang/gridfunc/AlwaysTruePredicate.java    |  17 +-
 .../util/lang/gridfunc/AlwaysTrueReducer.java      |  17 +-
 .../gridfunc/AtomicIntegerFactoryCallable.java     |  17 +-
 .../lang/gridfunc/CacheEntryGetValueClosure.java   |  17 +-
 .../lang/gridfunc/CacheEntryHasPeekPredicate.java  |  17 +-
 .../lang/gridfunc/ClusterNodeGetIdClosure.java     |  17 +-
 .../gridfunc/ConcurrentHashSetFactoryCallable.java |  17 +-
 .../gridfunc/ConcurrentMapFactoryCallable.java     |  17 +-
 .../lang/gridfunc/ContainsNodeIdsPredicate.java    |  17 +-
 .../util/lang/gridfunc/ContainsPredicate.java      |  17 +-
 .../gridfunc/EntryByKeyEvaluationPredicate.java    |  17 +-
 .../gridfunc/EqualsClusterNodeIdPredicate.java     |  17 +-
 .../util/lang/gridfunc/EqualsUuidPredicate.java    |  17 +-
 .../util/lang/gridfunc/FlatCollectionWrapper.java  |  17 +-
 .../internal/util/lang/gridfunc/FlatIterator.java  |  17 +-
 .../util/lang/gridfunc/HasEqualIdPredicate.java    |  17 +-
 .../util/lang/gridfunc/HasNotEqualIdPredicate.java |  17 +-
 .../util/lang/gridfunc/IdentityClosure.java        |  17 +-
 .../internal/util/lang/gridfunc/IntSumReducer.java |  17 +-
 .../util/lang/gridfunc/IsAllPredicate.java         |  17 +-
 .../util/lang/gridfunc/IsNotAllPredicate.java      |  17 +-
 .../util/lang/gridfunc/IsNotNullPredicate.java     |  17 +-
 .../util/lang/gridfunc/LongSumReducer.java         |  17 +-
 .../util/lang/gridfunc/MapFactoryCallable.java     |  17 +-
 .../util/lang/gridfunc/MultipleIterator.java       |  17 +-
 .../internal/util/lang/gridfunc/NoOpClosure.java   |  17 +-
 .../util/lang/gridfunc/NotContainsPredicate.java   |  17 +-
 .../util/lang/gridfunc/NotEqualPredicate.java      |  17 +-
 .../lang/gridfunc/PredicateCollectionView.java     |  17 +-
 .../util/lang/gridfunc/PredicateMapView.java       |  17 +-
 .../util/lang/gridfunc/PredicateSetView.java       |  17 +-
 .../util/lang/gridfunc/ReadOnlyCollectionView.java |  17 +-
 .../lang/gridfunc/ReadOnlyCollectionView2X.java    |  17 +-
 .../util/lang/gridfunc/RunnableWrapperClosure.java |  17 +-
 .../util/lang/gridfunc/SetFactoryCallable.java     |  17 +-
 .../util/lang/gridfunc/StringConcatReducer.java    |  17 +-
 .../util/lang/gridfunc/ToStringClosure.java        |  17 +-
 .../lang/gridfunc/TransformCollectionView.java     |  17 +-
 .../lang/gridfunc/TransformFilteringIterator.java  |  17 +-
 .../util/lang/gridfunc/TransformMapView.java       |  17 +-
 .../util/lang/gridfunc/TransformMapView2.java      |  17 +-
 .../internal/util/lang/gridfunc/package-info.java  |  17 +-
 .../util/nio/GridAbstractCommunicationClient.java  |  17 +-
 .../internal/util/nio/GridBufferedParser.java      |  17 +-
 .../internal/util/nio/GridCommunicationClient.java |  17 +-
 .../util/nio/GridConnectionBytesVerifyFilter.java  |  17 +-
 .../internal/util/nio/GridDelimitedParser.java     |  17 +-
 .../ignite/internal/util/nio/GridDirectParser.java |  17 +-
 .../util/nio/GridNioAsyncNotifyFilter.java         |  17 +-
 .../util/nio/GridNioBackPressureControl.java       |  17 +-
 .../internal/util/nio/GridNioCodecFilter.java      |  17 +-
 .../internal/util/nio/GridNioDelimitedBuffer.java  |  17 +-
 .../internal/util/nio/GridNioEmbeddedFuture.java   |  17 +-
 .../ignite/internal/util/nio/GridNioException.java |  17 +-
 .../ignite/internal/util/nio/GridNioFilter.java    |  17 +-
 .../internal/util/nio/GridNioFilterAdapter.java    |  17 +-
 .../internal/util/nio/GridNioFilterChain.java      |  17 +-
 .../internal/util/nio/GridNioFinishedFuture.java   |  17 +-
 .../ignite/internal/util/nio/GridNioFuture.java    |  17 +-
 .../internal/util/nio/GridNioFutureImpl.java       |  17 +-
 .../internal/util/nio/GridNioKeyAttachment.java    |  17 +-
 .../internal/util/nio/GridNioMessageReader.java    |  17 +-
 .../util/nio/GridNioMessageReaderFactory.java      |  17 +-
 .../internal/util/nio/GridNioMessageTracker.java   |  17 +-
 .../internal/util/nio/GridNioMessageWriter.java    |  17 +-
 .../util/nio/GridNioMessageWriterFactory.java      |  17 +-
 .../internal/util/nio/GridNioMetricsListener.java  |  17 +-
 .../ignite/internal/util/nio/GridNioParser.java    |  17 +-
 .../util/nio/GridNioRecoveryDescriptor.java        |  17 +-
 .../ignite/internal/util/nio/GridNioServer.java    |  17 +-
 .../internal/util/nio/GridNioServerBuffer.java     |  17 +-
 .../internal/util/nio/GridNioServerListener.java   |  17 +-
 .../util/nio/GridNioServerListenerAdapter.java     |  17 +-
 .../ignite/internal/util/nio/GridNioSession.java   |  17 +-
 .../internal/util/nio/GridNioSessionImpl.java      |  17 +-
 .../internal/util/nio/GridNioSessionMetaKey.java   |  17 +-
 .../ignite/internal/util/nio/GridNioWorker.java    |  17 +-
 .../util/nio/GridSelectorNioSessionImpl.java       |  17 +-
 .../util/nio/GridShmemCommunicationClient.java     |  17 +-
 .../util/nio/GridTcpNioCommunicationClient.java    |  17 +-
 .../internal/util/nio/SessionWriteRequest.java     |  17 +-
 .../ignite/internal/util/nio/package-info.java     |  17 +-
 .../internal/util/nio/ssl/BlockingSslHandler.java  |  17 +-
 .../internal/util/nio/ssl/GridNioSslFilter.java    |  17 +-
 .../internal/util/nio/ssl/GridNioSslHandler.java   |  17 +-
 .../ignite/internal/util/nio/ssl/GridSslMeta.java  |  17 +-
 .../ignite/internal/util/nio/ssl/package-info.java |  17 +-
 .../util/nodestart/IgniteNodeStartUtils.java       |  17 +-
 .../nodestart/IgniteRemoteStartSpecification.java  |  17 +-
 .../internal/util/nodestart/IgniteSshHelper.java   |  17 +-
 .../internal/util/nodestart/StartNodeCallable.java |  17 +-
 .../internal/util/offheap/GridOffHeapEvent.java    |  17 +-
 .../util/offheap/GridOffHeapEventListener.java     |  17 +-
 .../util/offheap/GridOffHeapEvictListener.java     |  17 +-
 .../internal/util/offheap/GridOffHeapMap.java      |  17 +-
 .../util/offheap/GridOffHeapMapFactory.java        |  17 +-
 .../offheap/GridOffHeapOutOfMemoryException.java   |  17 +-
 .../util/offheap/GridOffHeapPartitionedMap.java    |  17 +-
 .../util/offheap/unsafe/GridUnsafeLru.java         |  17 +-
 .../util/offheap/unsafe/GridUnsafeLruPoller.java   |  17 +-
 .../util/offheap/unsafe/GridUnsafeMap.java         |  17 +-
 .../util/offheap/unsafe/GridUnsafeMemory.java      |  17 +-
 .../offheap/unsafe/GridUnsafePartitionedMap.java   |  17 +-
 .../apache/ignite/internal/util/package-info.java  |  17 +-
 .../util/portscanner/GridJmxPortFinder.java        |  17 +-
 .../internal/util/portscanner/package-info.java    |  17 +-
 .../apache/ignite/internal/util/scala/impl.java    |  17 +-
 .../ignite/internal/util/scala/package-info.java   |  17 +-
 .../internal/util/spring/IgniteSpringHelper.java   |  17 +-
 .../internal/util/test/GridTestPrintStream.java    |  17 +-
 .../util/test/GridTestPrintStreamFactory.java      |  17 +-
 .../ignite/internal/util/test/package-info.java    |  17 +-
 .../util/tostring/CircularStringBuilder.java       |  17 +-
 .../util/tostring/GridToStringBuilder.java         |  17 +-
 .../util/tostring/GridToStringClassDescriptor.java |  17 +-
 .../util/tostring/GridToStringExclude.java         |  17 +-
 .../util/tostring/GridToStringFieldDescriptor.java |  17 +-
 .../util/tostring/GridToStringInclude.java         |  17 +-
 .../internal/util/tostring/GridToStringOrder.java  |  17 +-
 .../internal/util/tostring/SBLengthLimit.java      |  17 +-
 .../internal/util/tostring/SBLimitedLength.java    |  17 +-
 .../internal/util/tostring/package-info.java       |  17 +-
 .../apache/ignite/internal/util/typedef/C1.java    |  17 +-
 .../apache/ignite/internal/util/typedef/C2.java    |  17 +-
 .../apache/ignite/internal/util/typedef/C3.java    |  17 +-
 .../apache/ignite/internal/util/typedef/CA.java    |  17 +-
 .../apache/ignite/internal/util/typedef/CAX.java   |  17 +-
 .../apache/ignite/internal/util/typedef/CI1.java   |  17 +-
 .../apache/ignite/internal/util/typedef/CI2.java   |  17 +-
 .../apache/ignite/internal/util/typedef/CI3.java   |  17 +-
 .../apache/ignite/internal/util/typedef/CIX1.java  |  17 +-
 .../apache/ignite/internal/util/typedef/CIX2.java  |  17 +-
 .../apache/ignite/internal/util/typedef/CIX3.java  |  17 +-
 .../apache/ignite/internal/util/typedef/CO.java    |  17 +-
 .../apache/ignite/internal/util/typedef/COX.java   |  17 +-
 .../apache/ignite/internal/util/typedef/CX1.java   |  17 +-
 .../apache/ignite/internal/util/typedef/CX2.java   |  17 +-
 .../apache/ignite/internal/util/typedef/CX3.java   |  17 +-
 .../org/apache/ignite/internal/util/typedef/F.java |  17 +-
 .../org/apache/ignite/internal/util/typedef/G.java |  17 +-
 .../apache/ignite/internal/util/typedef/P1.java    |  17 +-
 .../apache/ignite/internal/util/typedef/P2.java    |  17 +-
 .../apache/ignite/internal/util/typedef/P3.java    |  17 +-
 .../apache/ignite/internal/util/typedef/PA.java    |  17 +-
 .../apache/ignite/internal/util/typedef/PAX.java   |  17 +-
 .../apache/ignite/internal/util/typedef/PCE.java   |  17 +-
 .../apache/ignite/internal/util/typedef/PE.java    |  17 +-
 .../apache/ignite/internal/util/typedef/PKV.java   |  17 +-
 .../apache/ignite/internal/util/typedef/PN.java    |  17 +-
 .../apache/ignite/internal/util/typedef/PX1.java   |  17 +-
 .../apache/ignite/internal/util/typedef/PX2.java   |  17 +-
 .../apache/ignite/internal/util/typedef/PX3.java   |  17 +-
 .../apache/ignite/internal/util/typedef/R1.java    |  17 +-
 .../apache/ignite/internal/util/typedef/R2.java    |  17 +-
 .../apache/ignite/internal/util/typedef/R3.java    |  17 +-
 .../apache/ignite/internal/util/typedef/RX1.java   |  17 +-
 .../apache/ignite/internal/util/typedef/RX2.java   |  17 +-
 .../apache/ignite/internal/util/typedef/RX3.java   |  17 +-
 .../apache/ignite/internal/util/typedef/T1.java    |  17 +-
 .../apache/ignite/internal/util/typedef/T2.java    |  17 +-
 .../apache/ignite/internal/util/typedef/T3.java    |  17 +-
 .../apache/ignite/internal/util/typedef/T4.java    |  17 +-
 .../apache/ignite/internal/util/typedef/T5.java    |  17 +-
 .../apache/ignite/internal/util/typedef/T6.java    |  17 +-
 .../org/apache/ignite/internal/util/typedef/X.java |  17 +-
 .../ignite/internal/util/typedef/internal/A.java   |  17 +-
 .../ignite/internal/util/typedef/internal/CU.java  |  17 +-
 .../ignite/internal/util/typedef/internal/D.java   |  17 +-
 .../ignite/internal/util/typedef/internal/GPC.java |  17 +-
 .../ignite/internal/util/typedef/internal/GPR.java |  17 +-
 .../ignite/internal/util/typedef/internal/LT.java  |  17 +-
 .../ignite/internal/util/typedef/internal/S.java   |  17 +-
 .../ignite/internal/util/typedef/internal/SB.java  |  17 +-
 .../ignite/internal/util/typedef/internal/U.java   |  17 +-
 .../util/typedef/internal/package-info.java        |  17 +-
 .../ignite/internal/util/typedef/package-info.java |  17 +-
 .../ignite/internal/util/worker/GridWorker.java    |  17 +-
 .../internal/util/worker/GridWorkerFuture.java     |  17 +-
 .../internal/util/worker/GridWorkerListener.java   |  17 +-
 .../util/worker/GridWorkerListenerAdapter.java     |  17 +-
 .../internal/util/worker/GridWorkerPool.java       |  17 +-
 .../ignite/internal/util/worker/package-info.java  |  17 +-
 .../internal/visor/VisorCoordinatorNodeTask.java   |  17 +-
 .../internal/visor/VisorDataTransferObject.java    |  17 +-
 .../visor/VisorDataTransferObjectInput.java        |  17 +-
 .../visor/VisorDataTransferObjectOutput.java       |  17 +-
 .../apache/ignite/internal/visor/VisorEither.java  |  17 +-
 .../org/apache/ignite/internal/visor/VisorJob.java |  17 +-
 .../ignite/internal/visor/VisorMultiNodeTask.java  |  17 +-
 .../ignite/internal/visor/VisorOneNodeTask.java    |  17 +-
 .../ignite/internal/visor/VisorTaskArgument.java   |  17 +-
 .../baseline/VisorBaselineAutoAdjustSettings.java  |  17 +-
 .../internal/visor/baseline/VisorBaselineNode.java |  17 +-
 .../visor/baseline/VisorBaselineOperation.java     |  17 +-
 .../internal/visor/baseline/VisorBaselineTask.java |  17 +-
 .../visor/baseline/VisorBaselineTaskArg.java       |  17 +-
 .../visor/baseline/VisorBaselineTaskResult.java    |  17 +-
 .../visor/baseline/VisorBaselineViewTask.java      |  17 +-
 .../internal/visor/binary/VisorBinaryMetadata.java |  17 +-
 .../binary/VisorBinaryMetadataCollectorTask.java   |  17 +-
 .../VisorBinaryMetadataCollectorTaskArg.java       |  17 +-
 .../VisorBinaryMetadataCollectorTaskResult.java    |  17 +-
 .../visor/binary/VisorBinaryMetadataField.java     |  17 +-
 .../ignite/internal/visor/cache/VisorCache.java    |  17 +-
 .../cache/VisorCacheAffinityConfiguration.java     |  17 +-
 .../visor/cache/VisorCacheAffinityNodeTask.java    |  17 +-
 .../visor/cache/VisorCacheAffinityNodeTaskArg.java |  17 +-
 .../visor/cache/VisorCacheAggregatedMetrics.java   |  17 +-
 .../internal/visor/cache/VisorCacheClearTask.java  |  17 +-
 .../visor/cache/VisorCacheClearTaskArg.java        |  17 +-
 .../visor/cache/VisorCacheClearTaskResult.java     |  17 +-
 .../visor/cache/VisorCacheConfiguration.java       |  17 +-
 .../cache/VisorCacheConfigurationCollectorJob.java |  17 +-
 .../VisorCacheConfigurationCollectorTask.java      |  17 +-
 .../VisorCacheConfigurationCollectorTaskArg.java   |  17 +-
 .../cache/VisorCacheEvictionConfiguration.java     |  17 +-
 .../internal/visor/cache/VisorCacheJdbcType.java   |  17 +-
 .../visor/cache/VisorCacheJdbcTypeField.java       |  17 +-
 .../internal/visor/cache/VisorCacheLoadTask.java   |  17 +-
 .../visor/cache/VisorCacheLoadTaskArg.java         |  17 +-
 .../visor/cache/VisorCacheLostPartitionsTask.java  |  17 +-
 .../cache/VisorCacheLostPartitionsTaskArg.java     |  17 +-
 .../cache/VisorCacheLostPartitionsTaskResult.java  |  17 +-
 .../visor/cache/VisorCacheMetadataTask.java        |  17 +-
 .../visor/cache/VisorCacheMetadataTaskArg.java     |  17 +-
 .../internal/visor/cache/VisorCacheMetrics.java    |  17 +-
 .../cache/VisorCacheMetricsCollectorTask.java      |  17 +-
 .../cache/VisorCacheMetricsCollectorTaskArg.java   |  17 +-
 .../internal/visor/cache/VisorCacheModifyTask.java |  17 +-
 .../visor/cache/VisorCacheModifyTaskArg.java       |  17 +-
 .../visor/cache/VisorCacheModifyTaskResult.java    |  17 +-
 .../visor/cache/VisorCacheNamesCollectorTask.java  |  17 +-
 .../cache/VisorCacheNamesCollectorTaskResult.java  |  17 +-
 .../visor/cache/VisorCacheNearConfiguration.java   |  17 +-
 .../internal/visor/cache/VisorCacheNodesTask.java  |  17 +-
 .../visor/cache/VisorCacheNodesTaskArg.java        |  17 +-
 .../internal/visor/cache/VisorCachePartitions.java |  17 +-
 .../visor/cache/VisorCachePartitionsTask.java      |  17 +-
 .../visor/cache/VisorCachePartitionsTaskArg.java   |  17 +-
 .../cache/VisorCacheRebalanceConfiguration.java    |  17 +-
 .../visor/cache/VisorCacheRebalanceTask.java       |  17 +-
 .../visor/cache/VisorCacheRebalanceTaskArg.java    |  17 +-
 .../cache/VisorCacheResetLostPartitionsTask.java   |  17 +-
 .../VisorCacheResetLostPartitionsTaskArg.java      |  17 +-
 .../visor/cache/VisorCacheResetMetricsTask.java    |  17 +-
 .../visor/cache/VisorCacheResetMetricsTaskArg.java |  17 +-
 .../visor/cache/VisorCacheSqlIndexMetadata.java    |  17 +-
 .../visor/cache/VisorCacheSqlMetadata.java         |  17 +-
 .../internal/visor/cache/VisorCacheStartTask.java  |  17 +-
 .../visor/cache/VisorCacheStartTaskArg.java        |  17 +-
 .../internal/visor/cache/VisorCacheStopTask.java   |  17 +-
 .../visor/cache/VisorCacheStopTaskArg.java         |  17 +-
 .../visor/cache/VisorCacheStoreConfiguration.java  |  17 +-
 .../cache/VisorCacheToggleStatisticsTask.java      |  17 +-
 .../cache/VisorCacheToggleStatisticsTaskArg.java   |  17 +-
 .../internal/visor/cache/VisorMemoryMetrics.java   |  17 +-
 .../internal/visor/cache/VisorModifyCacheMode.java |  17 +-
 .../internal/visor/cache/VisorPartitionMap.java    |  17 +-
 .../compute/VisorComputeCancelSessionsTask.java    |  17 +-
 .../compute/VisorComputeCancelSessionsTaskArg.java |  17 +-
 .../compute/VisorComputeMonitoringHolder.java      |  17 +-
 .../compute/VisorComputeResetMetricsTask.java      |  17 +-
 .../compute/VisorComputeToggleMonitoringTask.java  |  17 +-
 .../VisorComputeToggleMonitoringTaskArg.java       |  17 +-
 .../internal/visor/compute/VisorGatewayTask.java   |  17 +-
 .../internal/visor/debug/VisorThreadDumpTask.java  |  17 +-
 .../visor/debug/VisorThreadDumpTaskResult.java     |  17 +-
 .../internal/visor/debug/VisorThreadInfo.java      |  17 +-
 .../internal/visor/debug/VisorThreadLockInfo.java  |  17 +-
 .../visor/debug/VisorThreadMonitorInfo.java        |  17 +-
 .../visor/event/VisorGridDeploymentEvent.java      |  17 +-
 .../visor/event/VisorGridDiscoveryEvent.java       |  17 +-
 .../internal/visor/event/VisorGridEvent.java       |  17 +-
 .../internal/visor/event/VisorGridEventsLost.java  |  17 +-
 .../internal/visor/event/VisorGridJobEvent.java    |  17 +-
 .../internal/visor/event/VisorGridTaskEvent.java   |  17 +-
 .../ignite/internal/visor/file/VisorFileBlock.java |  17 +-
 .../internal/visor/file/VisorFileBlockTask.java    |  17 +-
 .../internal/visor/file/VisorFileBlockTaskArg.java |  17 +-
 .../visor/file/VisorFileBlockTaskResult.java       |  17 +-
 .../visor/file/VisorLatestTextFilesTask.java       |  17 +-
 .../visor/file/VisorLatestTextFilesTaskArg.java    |  17 +-
 .../ignite/internal/visor/igfs/VisorIgfs.java      |  17 +-
 .../internal/visor/igfs/VisorIgfsEndpoint.java     |  17 +-
 .../internal/visor/igfs/VisorIgfsFormatTask.java   |  17 +-
 .../visor/igfs/VisorIgfsFormatTaskArg.java         |  17 +-
 .../internal/visor/igfs/VisorIgfsMetrics.java      |  17 +-
 .../internal/visor/igfs/VisorIgfsProfiler.java     |  17 +-
 .../visor/igfs/VisorIgfsProfilerClearTask.java     |  17 +-
 .../visor/igfs/VisorIgfsProfilerClearTaskArg.java  |  17 +-
 .../igfs/VisorIgfsProfilerClearTaskResult.java     |  17 +-
 .../visor/igfs/VisorIgfsProfilerEntry.java         |  17 +-
 .../internal/visor/igfs/VisorIgfsProfilerTask.java |  17 +-
 .../visor/igfs/VisorIgfsProfilerTaskArg.java       |  17 +-
 .../igfs/VisorIgfsProfilerUniformityCounters.java  |  17 +-
 .../visor/igfs/VisorIgfsResetMetricsTask.java      |  17 +-
 .../visor/igfs/VisorIgfsResetMetricsTaskArg.java   |  17 +-
 .../visor/igfs/VisorIgfsSamplingStateTask.java     |  17 +-
 .../visor/igfs/VisorIgfsSamplingStateTaskArg.java  |  17 +-
 .../ignite/internal/visor/log/VisorLogFile.java    |  17 +-
 .../internal/visor/log/VisorLogSearchResult.java   |  17 +-
 .../internal/visor/log/VisorLogSearchTask.java     |  17 +-
 .../internal/visor/log/VisorLogSearchTaskArg.java  |  17 +-
 .../visor/log/VisorLogSearchTaskResult.java        |  17 +-
 .../ignite/internal/visor/misc/VisorAckTask.java   |  17 +-
 .../internal/visor/misc/VisorAckTaskArg.java       |  17 +-
 .../visor/misc/VisorChangeGridActiveStateTask.java |  17 +-
 .../misc/VisorChangeGridActiveStateTaskArg.java    |  17 +-
 .../internal/visor/misc/VisorClusterNode.java      |  17 +-
 .../visor/misc/VisorLatestVersionTask.java         |  17 +-
 .../ignite/internal/visor/misc/VisorNopTask.java   |  17 +-
 .../visor/misc/VisorResolveHostNameTask.java       |  17 +-
 .../ignite/internal/visor/misc/VisorWalTask.java   |  17 +-
 .../internal/visor/misc/VisorWalTaskArg.java       |  17 +-
 .../internal/visor/misc/VisorWalTaskOperation.java |  17 +-
 .../internal/visor/misc/VisorWalTaskResult.java    |  27 ++-
 .../visor/node/VisorAffinityTopologyVersion.java   |  17 +-
 .../visor/node/VisorAtomicConfiguration.java       |  17 +-
 .../visor/node/VisorBasicConfiguration.java        |  17 +-
 .../visor/node/VisorBinaryConfiguration.java       |  17 +-
 .../visor/node/VisorBinaryTypeConfiguration.java   |  17 +-
 .../visor/node/VisorCacheKeyConfiguration.java     |  17 +-
 .../VisorCacheRebalanceCollectorJobResult.java     |  17 +-
 .../node/VisorCacheRebalanceCollectorTask.java     |  17 +-
 .../node/VisorCacheRebalanceCollectorTaskArg.java  |  17 +-
 .../VisorCacheRebalanceCollectorTaskResult.java    |  17 +-
 .../node/VisorClientConnectorConfiguration.java    |  17 +-
 .../visor/node/VisorDataRegionConfiguration.java   |  17 +-
 .../visor/node/VisorDataStorageConfiguration.java  |  17 +-
 .../visor/node/VisorExecutorConfiguration.java     |  17 +-
 .../node/VisorExecutorServiceConfiguration.java    |  17 +-
 .../visor/node/VisorGridConfiguration.java         |  17 +-
 .../visor/node/VisorHadoopConfiguration.java       |  17 +-
 .../visor/node/VisorIgfsConfiguration.java         |  17 +-
 .../visor/node/VisorLifecycleConfiguration.java    |  17 +-
 .../visor/node/VisorMemoryConfiguration.java       |  17 +-
 .../visor/node/VisorMemoryPolicyConfiguration.java |  17 +-
 .../visor/node/VisorMetricsConfiguration.java      |  17 +-
 .../visor/node/VisorMvccConfiguration.java         |  17 +-
 .../visor/node/VisorNodeBaselineStatus.java        |  17 +-
 .../node/VisorNodeConfigurationCollectorJob.java   |  17 +-
 .../node/VisorNodeConfigurationCollectorTask.java  |  17 +-
 .../visor/node/VisorNodeDataCollectorJob.java      |  17 +-
 .../node/VisorNodeDataCollectorJobResult.java      |  17 +-
 .../visor/node/VisorNodeDataCollectorTask.java     |  17 +-
 .../visor/node/VisorNodeDataCollectorTaskArg.java  |  17 +-
 .../node/VisorNodeDataCollectorTaskResult.java     |  17 +-
 .../visor/node/VisorNodeEventsCollectorTask.java   |  17 +-
 .../node/VisorNodeEventsCollectorTaskArg.java      |  17 +-
 .../internal/visor/node/VisorNodeGcTask.java       |  17 +-
 .../internal/visor/node/VisorNodeGcTaskResult.java |  17 +-
 .../internal/visor/node/VisorNodePingTask.java     |  17 +-
 .../internal/visor/node/VisorNodePingTaskArg.java  |  17 +-
 .../visor/node/VisorNodePingTaskResult.java        |  17 +-
 .../internal/visor/node/VisorNodeRestartTask.java  |  17 +-
 .../internal/visor/node/VisorNodeStopTask.java     |  17 +-
 .../visor/node/VisorNodeSuppressedErrors.java      |  17 +-
 .../visor/node/VisorNodeSuppressedErrorsTask.java  |  17 +-
 .../node/VisorNodeSuppressedErrorsTaskArg.java     |  17 +-
 .../visor/node/VisorPeerToPeerConfiguration.java   |  17 +-
 .../visor/node/VisorPersistenceMetrics.java        |  17 +-
 .../node/VisorPersistentStoreConfiguration.java    |  17 +-
 .../visor/node/VisorRestConfiguration.java         |  17 +-
 .../visor/node/VisorSegmentationConfiguration.java |  17 +-
 .../visor/node/VisorServiceConfiguration.java      |  17 +-
 .../internal/visor/node/VisorSpiDescription.java   |  17 +-
 .../visor/node/VisorSpisConfiguration.java         |  17 +-
 .../visor/node/VisorSqlConnectorConfiguration.java |  17 +-
 .../internal/visor/node/VisorSuppressedError.java  |  17 +-
 .../visor/node/VisorTransactionConfiguration.java  |  17 +-
 .../internal/visor/query/VisorQueryCancelTask.java |  17 +-
 .../visor/query/VisorQueryCancelTaskArg.java       |  17 +-
 .../visor/query/VisorQueryCleanupTask.java         |  17 +-
 .../visor/query/VisorQueryCleanupTaskArg.java      |  17 +-
 .../visor/query/VisorQueryConfiguration.java       |  17 +-
 .../visor/query/VisorQueryDetailMetrics.java       |  17 +-
 .../VisorQueryDetailMetricsCollectorTask.java      |  17 +-
 .../VisorQueryDetailMetricsCollectorTaskArg.java   |  17 +-
 .../internal/visor/query/VisorQueryEntity.java     |  17 +-
 .../visor/query/VisorQueryFetchFirstPageTask.java  |  17 +-
 .../internal/visor/query/VisorQueryField.java      |  17 +-
 .../internal/visor/query/VisorQueryHolder.java     |  17 +-
 .../internal/visor/query/VisorQueryIndex.java      |  17 +-
 .../internal/visor/query/VisorQueryIndexField.java |  17 +-
 .../internal/visor/query/VisorQueryMetrics.java    |  17 +-
 .../visor/query/VisorQueryNextPageTask.java        |  17 +-
 .../visor/query/VisorQueryNextPageTaskArg.java     |  17 +-
 .../internal/visor/query/VisorQueryPingTask.java   |  17 +-
 .../visor/query/VisorQueryPingTaskResult.java      |  17 +-
 .../query/VisorQueryResetDetailMetricsTask.java    |  17 +-
 .../visor/query/VisorQueryResetMetricsTask.java    |  17 +-
 .../visor/query/VisorQueryResetMetricsTaskArg.java |  17 +-
 .../internal/visor/query/VisorQueryResult.java     |  17 +-
 .../visor/query/VisorQueryScanRegexFilter.java     |  17 +-
 .../internal/visor/query/VisorQueryTask.java       |  17 +-
 .../internal/visor/query/VisorQueryTaskArg.java    |  17 +-
 .../internal/visor/query/VisorQueryUtils.java      |  17 +-
 .../query/VisorRunningQueriesCollectorTask.java    |  17 +-
 .../query/VisorRunningQueriesCollectorTaskArg.java |  17 +-
 .../internal/visor/query/VisorRunningQuery.java    |  17 +-
 .../internal/visor/query/VisorScanQueryTask.java   |  17 +-
 .../visor/query/VisorScanQueryTaskArg.java         |  17 +-
 .../visor/service/VisorCancelServiceTask.java      |  17 +-
 .../visor/service/VisorCancelServiceTaskArg.java   |  17 +-
 .../visor/service/VisorServiceDescriptor.java      |  17 +-
 .../internal/visor/service/VisorServiceTask.java   |  17 +-
 .../internal/visor/tx/FetchNearXidVersionTask.java |  29 ++-
 .../ignite/internal/visor/tx/TxKeyLockType.java    |  29 ++-
 .../ignite/internal/visor/tx/TxMappingType.java    |  29 ++-
 .../ignite/internal/visor/tx/TxVerboseId.java      |  29 ++-
 .../ignite/internal/visor/tx/TxVerboseInfo.java    |  29 ++-
 .../ignite/internal/visor/tx/TxVerboseKey.java     |  29 ++-
 .../ignite/internal/visor/tx/VisorTxInfo.java      |  17 +-
 .../ignite/internal/visor/tx/VisorTxOperation.java |  17 +-
 .../internal/visor/tx/VisorTxProjection.java       |  17 +-
 .../ignite/internal/visor/tx/VisorTxSortOrder.java |  17 +-
 .../ignite/internal/visor/tx/VisorTxTask.java      |  17 +-
 .../ignite/internal/visor/tx/VisorTxTaskArg.java   |  17 +-
 .../internal/visor/tx/VisorTxTaskResult.java       |  17 +-
 .../util/VisorClusterGroupEmptyException.java      |  17 +-
 .../internal/visor/util/VisorEventMapper.java      |  17 +-
 .../internal/visor/util/VisorExceptionWrapper.java |  17 +-
 .../ignite/internal/visor/util/VisorMimeTypes.java |  17 +-
 .../ignite/internal/visor/util/VisorTaskUtils.java |  17 +-
 .../internal/visor/verify/CacheFilterEnum.java     |  17 +-
 .../visor/verify/IndexIntegrityCheckIssue.java     |  17 +-
 .../visor/verify/IndexValidationIssue.java         |  17 +-
 .../verify/ValidateIndexesPartitionResult.java     |  29 ++-
 .../visor/verify/VisorContentionJobResult.java     |  29 ++-
 .../internal/visor/verify/VisorContentionTask.java |  29 ++-
 .../visor/verify/VisorContentionTaskArg.java       |  29 ++-
 .../visor/verify/VisorContentionTaskResult.java    |  29 ++-
 .../visor/verify/VisorIdleAnalyzeTask.java         |  17 +-
 .../visor/verify/VisorIdleAnalyzeTaskArg.java      |  17 +-
 .../visor/verify/VisorIdleAnalyzeTaskResult.java   |  17 +-
 .../visor/verify/VisorIdleVerifyDumpTask.java      |  17 +-
 .../visor/verify/VisorIdleVerifyDumpTaskArg.java   |  17 +-
 .../internal/visor/verify/VisorIdleVerifyJob.java  |  17 +-
 .../internal/visor/verify/VisorIdleVerifyTask.java |  17 +-
 .../visor/verify/VisorIdleVerifyTaskArg.java       |  17 +-
 .../visor/verify/VisorIdleVerifyTaskResult.java    |  17 +-
 .../visor/verify/VisorIdleVerifyTaskV2.java        |  17 +-
 .../verify/VisorValidateIndexesJobResult.java      |  29 ++-
 .../visor/verify/VisorValidateIndexesTaskArg.java  |  17 +-
 .../verify/VisorValidateIndexesTaskResult.java     |  17 +-
 .../internal/visor/verify/VisorViewCacheCmd.java   |  29 ++-
 .../internal/visor/verify/VisorViewCacheTask.java  |  17 +-
 .../visor/verify/VisorViewCacheTaskArg.java        |  17 +-
 .../visor/verify/VisorViewCacheTaskResult.java     |  17 +-
 .../websession/WebSessionAttributeProcessor.java   |  17 +-
 .../internal/websession/WebSessionEntity.java      |  17 +-
 .../internal/worker/FailureHandlingMxBeanImpl.java |  17 +-
 .../internal/worker/WorkersControlMXBeanImpl.java  |  17 +-
 .../ignite/internal/worker/WorkersRegistry.java    |  17 +-
 .../ignite/internal/worker/package-info.java       |  17 +-
 .../apache/ignite/lang/IgniteAsyncCallback.java    |  17 +-
 .../org/apache/ignite/lang/IgniteAsyncSupport.java |  17 +-
 .../apache/ignite/lang/IgniteAsyncSupported.java   |  17 +-
 .../org/apache/ignite/lang/IgniteBiClosure.java    |  17 +-
 .../org/apache/ignite/lang/IgniteBiInClosure.java  |  17 +-
 .../org/apache/ignite/lang/IgniteBiPredicate.java  |  17 +-
 .../java/org/apache/ignite/lang/IgniteBiTuple.java |  17 +-
 .../org/apache/ignite/lang/IgniteCallable.java     |  17 +-
 .../java/org/apache/ignite/lang/IgniteClosure.java |  17 +-
 .../java/org/apache/ignite/lang/IgniteFuture.java  |  17 +-
 .../lang/IgniteFutureCancelledException.java       |  17 +-
 .../ignite/lang/IgniteFutureTimeoutException.java  |  17 +-
 .../org/apache/ignite/lang/IgniteInClosure.java    |  17 +-
 .../ignite/lang/IgniteNotPeerDeployable.java       |  17 +-
 .../org/apache/ignite/lang/IgniteOutClosure.java   |  17 +-
 .../org/apache/ignite/lang/IgnitePredicate.java    |  17 +-
 .../apache/ignite/lang/IgniteProductVersion.java   |  17 +-
 .../java/org/apache/ignite/lang/IgniteReducer.java |  17 +-
 .../org/apache/ignite/lang/IgniteRunnable.java     |  17 +-
 .../java/org/apache/ignite/lang/IgniteUuid.java    |  17 +-
 .../java/org/apache/ignite/lang/package-info.java  |  17 +-
 .../apache/ignite/lifecycle/LifecycleAware.java    |  17 +-
 .../org/apache/ignite/lifecycle/LifecycleBean.java |  17 +-
 .../ignite/lifecycle/LifecycleEventType.java       |  17 +-
 .../org/apache/ignite/lifecycle/package-info.java  |  17 +-
 .../apache/ignite/logger/LoggerNodeIdAware.java    |  17 +-
 .../java/org/apache/ignite/logger/NullLogger.java  |  17 +-
 .../org/apache/ignite/logger/java/JavaLogger.java  |  17 +-
 .../ignite/logger/java/JavaLoggerFileHandler.java  |  17 +-
 .../ignite/logger/java/JavaLoggerFormatter.java    |  17 +-
 .../apache/ignite/logger/java/package-info.java    |  17 +-
 .../org/apache/ignite/logger/package-info.java     |  17 +-
 .../ignite/marshaller/AbstractMarshaller.java      |  17 +-
 .../AbstractNodeNameAwareMarshaller.java           |  17 +-
 .../org/apache/ignite/marshaller/Marshaller.java   |  17 +-
 .../ignite/marshaller/MarshallerContext.java       |  17 +-
 .../ignite/marshaller/MarshallerExclusions.java    |  17 +-
 .../apache/ignite/marshaller/MarshallerUtils.java  |  17 +-
 .../ignite/marshaller/jdk/JdkMarshaller.java       |  17 +-
 .../jdk/JdkMarshallerDummySerializable.java        |  17 +-
 .../jdk/JdkMarshallerInputStreamWrapper.java       |  17 +-
 .../jdk/JdkMarshallerObjectInputStream.java        |  17 +-
 .../jdk/JdkMarshallerObjectOutputStream.java       |  17 +-
 .../jdk/JdkMarshallerOutputStreamWrapper.java      |  17 +-
 .../apache/ignite/marshaller/jdk/package-info.java |  17 +-
 .../org/apache/ignite/marshaller/package-info.java |  17 +-
 .../ignite/messaging/MessagingListenActor.java     |  17 +-
 .../org/apache/ignite/messaging/package-info.java  |  17 +-
 .../ignite/mxbean/BaselineAutoAdjustMXBean.java    |  17 +-
 .../ignite/mxbean/CacheGroupMetricsMXBean.java     |  17 +-
 .../apache/ignite/mxbean/CacheMetricsMXBean.java   |  17 +-
 .../ignite/mxbean/ClientProcessorMXBean.java       |  17 +-
 .../apache/ignite/mxbean/ClusterMetricsMXBean.java |  17 +-
 .../ignite/mxbean/DataRegionMetricsMXBean.java     |  17 +-
 .../apache/ignite/mxbean/DataStorageMXBean.java    |  17 +-
 .../ignite/mxbean/DataStorageMetricsMXBean.java    |  17 +-
 .../ignite/mxbean/FailureHandlingMxBean.java       |  17 +-
 .../org/apache/ignite/mxbean/IgniteMBeanAware.java |  17 +-
 .../org/apache/ignite/mxbean/IgniteMXBean.java     |  17 +-
 .../org/apache/ignite/mxbean/IgnitionMXBean.java   |  17 +-
 .../ignite/mxbean/IoStatisticsMetricsMXBean.java   |  18 +-
 .../apache/ignite/mxbean/MXBeanDescription.java    |  17 +-
 .../mxbean/MXBeanParametersDescriptions.java       |  17 +-
 .../ignite/mxbean/MXBeanParametersNames.java       |  17 +-
 .../apache/ignite/mxbean/MemoryMetricsMXBean.java  |  17 +-
 .../ignite/mxbean/PersistenceMetricsMXBean.java    |  17 +-
 .../ignite/mxbean/StripedExecutorMXBean.java       |  17 +-
 .../org/apache/ignite/mxbean/ThreadPoolMXBean.java |  17 +-
 .../ignite/mxbean/TransactionMetricsMxBean.java    |  17 +-
 .../apache/ignite/mxbean/TransactionsMXBean.java   |  17 +-
 .../apache/ignite/mxbean/WorkersControlMXBean.java |  17 +-
 .../org/apache/ignite/mxbean/package-info.java     |  17 +-
 .../main/java/org/apache/ignite/package-info.java  |  17 +-
 .../ignite/platform/PlatformJavaObjectFactory.java |  17 +-
 .../platform/cpp/PlatformCppConfiguration.java     |  17 +-
 .../apache/ignite/platform/cpp/package-info.java   |  17 +-
 .../dotnet/PlatformDotNetAffinityFunction.java     |  17 +-
 .../dotnet/PlatformDotNetBinaryConfiguration.java  |  17 +-
 .../PlatformDotNetBinaryTypeConfiguration.java     |  17 +-
 .../dotnet/PlatformDotNetCacheStoreFactory.java    |  17 +-
 .../PlatformDotNetCacheStoreFactoryNative.java     |  17 +-
 .../dotnet/PlatformDotNetConfiguration.java        |  17 +-
 .../dotnet/PlatformDotNetLifecycleBean.java        |  17 +-
 .../ignite/platform/dotnet/package-info.java       |  17 +-
 .../org/apache/ignite/platform/package-info.java   |  17 +-
 .../ignite/plugin/CachePluginConfiguration.java    |  17 +-
 .../apache/ignite/plugin/CachePluginContext.java   |  17 +-
 .../apache/ignite/plugin/CachePluginProvider.java  |  17 +-
 .../java/org/apache/ignite/plugin/Extension.java   |  17 +-
 .../apache/ignite/plugin/ExtensionRegistry.java    |  17 +-
 .../org/apache/ignite/plugin/IgnitePlugin.java     |  17 +-
 .../apache/ignite/plugin/PluginConfiguration.java  |  17 +-
 .../org/apache/ignite/plugin/PluginContext.java    |  17 +-
 .../ignite/plugin/PluginNotFoundException.java     |  17 +-
 .../org/apache/ignite/plugin/PluginProvider.java   |  17 +-
 .../ignite/plugin/PluginValidationException.java   |  17 +-
 .../plugin/extensions/communication/IoPool.java    |  17 +-
 .../plugin/extensions/communication/Message.java   |  17 +-
 .../communication/MessageCollectionItemType.java   |  17 +-
 .../extensions/communication/MessageFactory.java   |  17 +-
 .../extensions/communication/MessageFormatter.java |  17 +-
 .../extensions/communication/MessageReader.java    |  17 +-
 .../extensions/communication/MessageWriter.java    |  17 +-
 .../extensions/communication/package-info.java     |  17 +-
 .../org/apache/ignite/plugin/package-info.java     |  17 +-
 .../PlatformCachePluginConfigurationClosure.java   |  17 +-
 ...formCachePluginConfigurationClosureFactory.java |  17 +-
 .../PlatformPluginConfigurationClosure.java        |  17 +-
 .../PlatformPluginConfigurationClosureFactory.java |  17 +-
 .../ignite/plugin/platform/package-info.java       |  17 +-
 .../plugin/security/AuthenticationContext.java     |  17 +-
 .../security/SecurityBasicPermissionSet.java       |  17 +-
 .../plugin/security/SecurityCredentials.java       |  17 +-
 .../security/SecurityCredentialsBasicProvider.java |  17 +-
 .../security/SecurityCredentialsProvider.java      |  17 +-
 .../ignite/plugin/security/SecurityException.java  |  17 +-
 .../ignite/plugin/security/SecurityPermission.java |  17 +-
 .../plugin/security/SecurityPermissionSet.java     |  17 +-
 .../security/SecurityPermissionSetBuilder.java     |  17 +-
 .../ignite/plugin/security/SecuritySubject.java    |  17 +-
 .../plugin/security/SecuritySubjectType.java       |  17 +-
 .../ignite/plugin/security/package-info.java       |  17 +-
 .../plugin/segmentation/SegmentationPolicy.java    |  17 +-
 .../plugin/segmentation/SegmentationResolver.java  |  17 +-
 .../ignite/plugin/segmentation/package-info.java   |  17 +-
 .../apache/ignite/resources/CacheNameResource.java |  17 +-
 .../resources/CacheStoreSessionResource.java       |  17 +-
 .../ignite/resources/FileSystemResource.java       |  17 +-
 .../ignite/resources/IgniteInstanceResource.java   |  17 +-
 .../ignite/resources/JobContextResource.java       |  17 +-
 .../ignite/resources/LoadBalancerResource.java     |  17 +-
 .../apache/ignite/resources/LoggerResource.java    |  17 +-
 .../apache/ignite/resources/ServiceResource.java   |  17 +-
 .../SpringApplicationContextResource.java          |  17 +-
 .../apache/ignite/resources/SpringResource.java    |  17 +-
 .../resources/TaskContinuousMapperResource.java    |  17 +-
 .../ignite/resources/TaskSessionResource.java      |  17 +-
 .../org/apache/ignite/resources/package-info.java  |  17 +-
 .../apache/ignite/scheduler/SchedulerFuture.java   |  17 +-
 .../org/apache/ignite/scheduler/package-info.java  |  17 +-
 .../java/org/apache/ignite/services/Service.java   |  17 +-
 .../ignite/services/ServiceConfiguration.java      |  17 +-
 .../org/apache/ignite/services/ServiceContext.java |  17 +-
 .../services/ServiceDeploymentException.java       |  17 +-
 .../apache/ignite/services/ServiceDescriptor.java  |  17 +-
 .../org/apache/ignite/services/package-info.java   |  17 +-
 .../spi/ExponentialBackoffTimeoutStrategy.java     |  17 +-
 .../ignite/spi/IgniteNodeValidationResult.java     |  17 +-
 .../org/apache/ignite/spi/IgnitePortProtocol.java  |  17 +-
 .../main/java/org/apache/ignite/spi/IgniteSpi.java |  17 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java    |  17 +-
 .../ignite/spi/IgniteSpiCloseableIterator.java     |  17 +-
 .../apache/ignite/spi/IgniteSpiConfiguration.java  |  17 +-
 .../ignite/spi/IgniteSpiConsistencyChecked.java    |  17 +-
 .../org/apache/ignite/spi/IgniteSpiContext.java    |  17 +-
 .../org/apache/ignite/spi/IgniteSpiException.java  |  17 +-
 .../apache/ignite/spi/IgniteSpiMBeanAdapter.java   |  17 +-
 .../ignite/spi/IgniteSpiManagementMBean.java       |  17 +-
 .../apache/ignite/spi/IgniteSpiMultiException.java |  17 +-
 .../spi/IgniteSpiMultipleInstancesSupport.java     |  17 +-
 .../java/org/apache/ignite/spi/IgniteSpiNoop.java  |  17 +-
 .../spi/IgniteSpiOperationTimeoutException.java    |  17 +-
 .../spi/IgniteSpiOperationTimeoutHelper.java       |  17 +-
 .../org/apache/ignite/spi/IgniteSpiThread.java     |  17 +-
 .../apache/ignite/spi/IgniteSpiThreadFactory.java  |  17 +-
 .../apache/ignite/spi/IgniteSpiTimeoutObject.java  |  17 +-
 .../ignite/spi/IgniteSpiVersionCheckException.java |  17 +-
 .../org/apache/ignite/spi/TimeoutStrategy.java     |  17 +-
 .../ignite/spi/checkpoint/CheckpointListener.java  |  17 +-
 .../ignite/spi/checkpoint/CheckpointSpi.java       |  17 +-
 .../spi/checkpoint/cache/CacheCheckpointSpi.java   |  17 +-
 .../checkpoint/cache/CacheCheckpointSpiMBean.java  |  17 +-
 .../ignite/spi/checkpoint/cache/package-info.java  |  17 +-
 .../spi/checkpoint/jdbc/JdbcCheckpointSpi.java     |  17 +-
 .../checkpoint/jdbc/JdbcCheckpointSpiMBean.java    |  17 +-
 .../ignite/spi/checkpoint/jdbc/package-info.java   |  17 +-
 .../spi/checkpoint/noop/NoopCheckpointSpi.java     |  17 +-
 .../ignite/spi/checkpoint/noop/package-info.java   |  17 +-
 .../apache/ignite/spi/checkpoint/package-info.java |  17 +-
 .../sharedfs/SharedFsCheckpointData.java           |  17 +-
 .../checkpoint/sharedfs/SharedFsCheckpointSpi.java |  17 +-
 .../sharedfs/SharedFsCheckpointSpiMBean.java       |  17 +-
 .../spi/checkpoint/sharedfs/SharedFsTimeData.java  |  17 +-
 .../checkpoint/sharedfs/SharedFsTimeoutTask.java   |  17 +-
 .../spi/checkpoint/sharedfs/SharedFsUtils.java     |  17 +-
 .../spi/checkpoint/sharedfs/package-info.java      |  17 +-
 .../ignite/spi/collision/CollisionContext.java     |  17 +-
 .../spi/collision/CollisionExternalListener.java   |  17 +-
 .../ignite/spi/collision/CollisionJobContext.java  |  17 +-
 .../apache/ignite/spi/collision/CollisionSpi.java  |  17 +-
 .../collision/fifoqueue/FifoQueueCollisionSpi.java |  17 +-
 .../fifoqueue/FifoQueueCollisionSpiMBean.java      |  17 +-
 .../spi/collision/fifoqueue/package-info.java      |  17 +-
 .../jobstealing/JobStealingCollisionSpi.java       |  17 +-
 .../jobstealing/JobStealingCollisionSpiMBean.java  |  17 +-
 .../collision/jobstealing/JobStealingDisabled.java |  17 +-
 .../collision/jobstealing/JobStealingRequest.java  |  17 +-
 .../spi/collision/jobstealing/package-info.java    |  17 +-
 .../spi/collision/noop/NoopCollisionSpi.java       |  17 +-
 .../ignite/spi/collision/noop/package-info.java    |  17 +-
 .../apache/ignite/spi/collision/package-info.java  |  17 +-
 .../priorityqueue/PriorityQueueCollisionSpi.java   |  17 +-
 .../PriorityQueueCollisionSpiMBean.java            |  17 +-
 .../spi/collision/priorityqueue/package-info.java  |  17 +-
 .../spi/communication/CommunicationListener.java   |  17 +-
 .../ignite/spi/communication/CommunicationSpi.java |  17 +-
 .../ignite/spi/communication/package-info.java     |  17 +-
 .../tcp/TcpCommunicationMetricsListener.java       |  17 +-
 .../spi/communication/tcp/TcpCommunicationSpi.java |  17 +-
 .../tcp/TcpCommunicationSpiMBean.java              |  17 +-
 .../communication/tcp/internal/ConnectionKey.java  |  17 +-
 .../tcp/internal/HandshakeException.java           |  17 +-
 .../TcpCommunicationConnectionCheckFuture.java     |  17 +-
 .../TcpCommunicationNodeConnectionCheckFuture.java |  17 +-
 .../communication/tcp/internal/package-info.java   |  17 +-
 .../tcp/messages/HandshakeMessage.java             |  17 +-
 .../tcp/messages/HandshakeMessage2.java            |  17 +-
 .../tcp/messages/HandshakeWaitMessage.java         |  17 +-
 .../communication/tcp/messages/NodeIdMessage.java  |  17 +-
 .../tcp/messages/RecoveryLastReceivedMessage.java  |  17 +-
 .../communication/tcp/messages/package-info.java   |  17 +-
 .../ignite/spi/communication/tcp/package-info.java |  17 +-
 .../ignite/spi/deployment/DeploymentListener.java  |  17 +-
 .../ignite/spi/deployment/DeploymentResource.java  |  17 +-
 .../spi/deployment/DeploymentResourceAdapter.java  |  17 +-
 .../ignite/spi/deployment/DeploymentSpi.java       |  17 +-
 .../IgnoreIfPeerClassLoadingDisabled.java          |  17 +-
 .../spi/deployment/local/LocalDeploymentSpi.java   |  17 +-
 .../deployment/local/LocalDeploymentSpiMBean.java  |  17 +-
 .../ignite/spi/deployment/local/package-info.java  |  17 +-
 .../apache/ignite/spi/deployment/package-info.java |  17 +-
 .../ignite/spi/discovery/DiscoveryDataBag.java     |  17 +-
 .../spi/discovery/DiscoveryMetricsProvider.java    |  17 +-
 .../apache/ignite/spi/discovery/DiscoverySpi.java  |  17 +-
 .../spi/discovery/DiscoverySpiCustomMessage.java   |  17 +-
 .../spi/discovery/DiscoverySpiDataExchange.java    |  17 +-
 .../spi/discovery/DiscoverySpiHistorySupport.java  |  17 +-
 .../ignite/spi/discovery/DiscoverySpiListener.java |  17 +-
 .../ignite/spi/discovery/DiscoverySpiMBean.java    |  17 +-
 .../DiscoverySpiMutableCustomMessageSupport.java   |  17 +-
 .../discovery/DiscoverySpiNodeAuthenticator.java   |  17 +-
 .../spi/discovery/DiscoverySpiOrderSupport.java    |  17 +-
 .../spi/discovery/IgniteDiscoveryThread.java       |  17 +-
 .../apache/ignite/spi/discovery/package-info.java  |  17 +-
 .../ignite/spi/discovery/tcp/ClientImpl.java       |  17 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java       |  17 +-
 .../ignite/spi/discovery/tcp/TcpDiscoveryImpl.java |  17 +-
 .../ignite/spi/discovery/tcp/TcpDiscoverySpi.java  |  17 +-
 .../spi/discovery/tcp/TcpDiscoverySpiMBean.java    |  17 +-
 .../tcp/internal/DiscoveryDataPacket.java          |  17 +-
 .../spi/discovery/tcp/internal/FutureTask.java     |  17 +-
 .../discovery/tcp/internal/TcpDiscoveryNode.java   |  17 +-
 .../tcp/internal/TcpDiscoveryNodesRing.java        |  17 +-
 .../tcp/internal/TcpDiscoverySpiState.java         |  17 +-
 .../tcp/internal/TcpDiscoveryStatistics.java       |  17 +-
 .../spi/discovery/tcp/internal/package-info.java   |  17 +-
 .../tcp/ipfinder/TcpDiscoveryIpFinder.java         |  17 +-
 .../tcp/ipfinder/TcpDiscoveryIpFinderAdapter.java  |  17 +-
 .../ipfinder/jdbc/BasicJdbcIpFinderDialect.java    |  17 +-
 .../tcp/ipfinder/jdbc/JdbcIpFinderDialect.java     |  17 +-
 .../ipfinder/jdbc/OracleJdbcIpFinderDialect.java   |  17 +-
 .../ipfinder/jdbc/TcpDiscoveryJdbcIpFinder.java    |  17 +-
 .../discovery/tcp/ipfinder/jdbc/package-info.java  |  17 +-
 .../multicast/TcpDiscoveryMulticastIpFinder.java   |  17 +-
 .../tcp/ipfinder/multicast/package-info.java       |  17 +-
 .../spi/discovery/tcp/ipfinder/package-info.java   |  17 +-
 .../sharedfs/TcpDiscoverySharedFsIpFinder.java     |  17 +-
 .../tcp/ipfinder/sharedfs/package-info.java        |  17 +-
 .../tcp/ipfinder/vm/TcpDiscoveryVmIpFinder.java    |  17 +-
 .../discovery/tcp/ipfinder/vm/package-info.java    |  17 +-
 .../tcp/messages/TcpDiscoveryAbstractMessage.java  |  17 +-
 .../messages/TcpDiscoveryAuthFailedMessage.java    |  17 +-
 .../messages/TcpDiscoveryCheckFailedMessage.java   |  17 +-
 .../messages/TcpDiscoveryClientAckResponse.java    |  17 +-
 .../TcpDiscoveryClientMetricsUpdateMessage.java    |  17 +-
 .../messages/TcpDiscoveryClientPingRequest.java    |  17 +-
 .../messages/TcpDiscoveryClientPingResponse.java   |  17 +-
 .../TcpDiscoveryClientReconnectMessage.java        |  17 +-
 .../TcpDiscoveryConnectionCheckMessage.java        |  17 +-
 .../messages/TcpDiscoveryCustomEventMessage.java   |  17 +-
 .../tcp/messages/TcpDiscoveryDiscardMessage.java   |  17 +-
 .../messages/TcpDiscoveryDummyWakeupMessage.java   |  17 +-
 .../messages/TcpDiscoveryDuplicateIdMessage.java   |  17 +-
 .../tcp/messages/TcpDiscoveryEnsureDelivery.java   |  17 +-
 .../tcp/messages/TcpDiscoveryHandshakeRequest.java |  17 +-
 .../messages/TcpDiscoveryHandshakeResponse.java    |  17 +-
 .../messages/TcpDiscoveryJoinRequestMessage.java   |  17 +-
 .../TcpDiscoveryLoopbackProblemMessage.java        |  17 +-
 .../messages/TcpDiscoveryMetricsUpdateMessage.java |  17 +-
 .../TcpDiscoveryNodeAddFinishedMessage.java        |  17 +-
 .../tcp/messages/TcpDiscoveryNodeAddedMessage.java |  17 +-
 .../messages/TcpDiscoveryNodeFailedMessage.java    |  17 +-
 .../tcp/messages/TcpDiscoveryNodeLeftMessage.java  |  17 +-
 .../tcp/messages/TcpDiscoveryPingRequest.java      |  17 +-
 .../tcp/messages/TcpDiscoveryPingResponse.java     |  17 +-
 .../tcp/messages/TcpDiscoveryRedirectToClient.java |  17 +-
 .../TcpDiscoveryRingLatencyCheckMessage.java       |  17 +-
 .../TcpDiscoveryServerOnlyCustomEventMessage.java  |  17 +-
 .../messages/TcpDiscoveryStatusCheckMessage.java   |  17 +-
 .../spi/discovery/tcp/messages/package-info.java   |  17 +-
 .../ignite/spi/discovery/tcp/package-info.java     |  17 +-
 .../ignite/spi/encryption/EncryptionSpi.java       |  17 +-
 .../encryption/keystore/KeystoreEncryptionKey.java |  17 +-
 .../encryption/keystore/KeystoreEncryptionSpi.java |  17 +-
 .../spi/encryption/keystore/package-info.java      |  17 +-
 .../spi/encryption/noop/NoopEncryptionSpi.java     |  17 +-
 .../ignite/spi/encryption/noop/package-info.java   |  17 +-
 .../apache/ignite/spi/encryption/package-info.java |  17 +-
 .../ignite/spi/eventstorage/EventStorageSpi.java   |  17 +-
 .../spi/eventstorage/NoopEventStorageSpi.java      |  17 +-
 .../eventstorage/memory/MemoryEventStorageSpi.java |  17 +-
 .../memory/MemoryEventStorageSpiMBean.java         |  17 +-
 .../spi/eventstorage/memory/package-info.java      |  17 +-
 .../ignite/spi/eventstorage/package-info.java      |  17 +-
 .../ignite/spi/failover/FailoverContext.java       |  17 +-
 .../apache/ignite/spi/failover/FailoverSpi.java    |  17 +-
 .../spi/failover/always/AlwaysFailoverSpi.java     |  17 +-
 .../failover/always/AlwaysFailoverSpiMBean.java    |  17 +-
 .../ignite/spi/failover/always/package-info.java   |  17 +-
 .../jobstealing/JobStealingFailoverSpi.java        |  17 +-
 .../jobstealing/JobStealingFailoverSpiMBean.java   |  17 +-
 .../spi/failover/jobstealing/package-info.java     |  17 +-
 .../spi/failover/never/NeverFailoverSpi.java       |  17 +-
 .../spi/failover/never/NeverFailoverSpiMBean.java  |  17 +-
 .../ignite/spi/failover/never/package-info.java    |  17 +-
 .../apache/ignite/spi/failover/package-info.java   |  17 +-
 .../spi/indexing/IndexingQueryCacheFilter.java     |  17 +-
 .../ignite/spi/indexing/IndexingQueryFilter.java   |  17 +-
 .../spi/indexing/IndexingQueryFilterImpl.java      |  17 +-
 .../apache/ignite/spi/indexing/IndexingSpi.java    |  17 +-
 .../ignite/spi/indexing/noop/NoopIndexingSpi.java  |  17 +-
 .../ignite/spi/indexing/noop/package-info.java     |  17 +-
 .../apache/ignite/spi/indexing/package-info.java   |  17 +-
 .../ignite/spi/loadbalancing/LoadBalancingSpi.java |  17 +-
 .../adaptive/AdaptiveCpuLoadProbe.java             |  17 +-
 .../adaptive/AdaptiveJobCountLoadProbe.java        |  17 +-
 .../adaptive/AdaptiveLoadBalancingSpi.java         |  17 +-
 .../adaptive/AdaptiveLoadBalancingSpiMBean.java    |  17 +-
 .../loadbalancing/adaptive/AdaptiveLoadProbe.java  |  17 +-
 .../adaptive/AdaptiveProcessingTimeLoadProbe.java  |  17 +-
 .../spi/loadbalancing/adaptive/package-info.java   |  17 +-
 .../ignite/spi/loadbalancing/package-info.java     |  17 +-
 .../roundrobin/RoundRobinGlobalLoadBalancer.java   |  17 +-
 .../roundrobin/RoundRobinLoadBalancingSpi.java     |  17 +-
 .../RoundRobinLoadBalancingSpiMBean.java           |  17 +-
 .../roundrobin/RoundRobinPerTaskLoadBalancer.java  |  17 +-
 .../spi/loadbalancing/roundrobin/package-info.java |  17 +-
 .../WeightedRandomLoadBalancingSpi.java            |  17 +-
 .../WeightedRandomLoadBalancingSpiMBean.java       |  17 +-
 .../loadbalancing/weightedrandom/package-info.java |  17 +-
 .../java/org/apache/ignite/spi/package-info.java   |  17 +-
 .../apache/ignite/ssl/DelegatingSSLContextSpi.java |  17 +-
 .../org/apache/ignite/ssl/SSLContextWrapper.java   |  17 +-
 .../ignite/ssl/SSLServerSocketFactoryWrapper.java  |  17 +-
 .../apache/ignite/ssl/SSLSocketFactoryWrapper.java |  17 +-
 .../org/apache/ignite/ssl/SslContextFactory.java   |  17 +-
 .../java/org/apache/ignite/ssl/package-info.java   |  17 +-
 .../apache/ignite/startup/BasicWarmupClosure.java  |  17 +-
 .../apache/ignite/startup/cmdline/AboutDialog.java |  17 +-
 .../cmdline/CommandLineRandomNumberGenerator.java  |  17 +-
 .../ignite/startup/cmdline/CommandLineStartup.java |  17 +-
 .../startup/cmdline/CommandLineTransformer.java    |  17 +-
 .../ignite/startup/cmdline/package-info.java       |  17 +-
 .../org/apache/ignite/startup/package-info.java    |  17 +-
 .../org/apache/ignite/stream/StreamAdapter.java    |  17 +-
 .../stream/StreamMultipleTupleExtractor.java       |  17 +-
 .../org/apache/ignite/stream/StreamReceiver.java   |  17 +-
 .../ignite/stream/StreamSingleTupleExtractor.java  |  17 +-
 .../apache/ignite/stream/StreamTransformer.java    |  17 +-
 .../apache/ignite/stream/StreamTupleExtractor.java |  17 +-
 .../org/apache/ignite/stream/StreamVisitor.java    |  17 +-
 .../org/apache/ignite/stream/package-info.java     |  17 +-
 .../stream/socket/SocketMessageConverter.java      |  17 +-
 .../ignite/stream/socket/SocketStreamer.java       |  17 +-
 .../apache/ignite/stream/socket/package-info.java  |  17 +-
 .../thread/IgniteStripedThreadPoolExecutor.java    |  17 +-
 .../org/apache/ignite/thread/IgniteThread.java     |  17 +-
 .../apache/ignite/thread/IgniteThreadFactory.java  |  17 +-
 .../ignite/thread/IgniteThreadPoolExecutor.java    |  17 +-
 .../apache/ignite/thread/OomExceptionHandler.java  |  17 +-
 .../org/apache/ignite/thread/package-info.java     |  17 +-
 .../apache/ignite/transactions/Transaction.java    |  17 +-
 .../TransactionAlreadyCompletedException.java      |  17 +-
 .../transactions/TransactionConcurrency.java       |  17 +-
 .../transactions/TransactionDeadlockException.java |  17 +-
 .../TransactionDuplicateKeyException.java          |  17 +-
 .../ignite/transactions/TransactionException.java  |  17 +-
 .../TransactionHeuristicException.java             |  17 +-
 .../ignite/transactions/TransactionIsolation.java  |  17 +-
 .../ignite/transactions/TransactionMetrics.java    |  17 +-
 .../TransactionMixedModeException.java             |  17 +-
 .../TransactionOptimisticException.java            |  17 +-
 .../transactions/TransactionRollbackException.java |  17 +-
 .../TransactionSerializationException.java         |  17 +-
 .../ignite/transactions/TransactionState.java      |  17 +-
 .../transactions/TransactionTimeoutException.java  |  17 +-
 ...TransactionUnsupportedConcurrencyException.java |  17 +-
 .../apache/ignite/transactions/package-info.java   |  17 +-
 .../apache/ignite/util/AttributeNodeFilter.java    |  17 +-
 .../apache/ignite/util/deque/FastSizeDeque.java    |  17 +-
 .../resources/META-INF/classnames-jdk.properties   |  18 +-
 .../main/resources/META-INF/classnames.properties  |  18 +-
 modules/core/src/main/resources/ignite.properties  |  18 +-
 modules/core/src/test/bin/start-nodes-custom.bat   |  18 +-
 modules/core/src/test/bin/start-nodes-custom.sh    |  17 +-
 .../benchmark/spring-cache-client-benchmark-1.xml  |  27 ++-
 .../benchmark/spring-cache-client-benchmark-2.xml  |  27 ++-
 .../benchmark/spring-cache-client-benchmark-3.xml  |  27 ++-
 modules/core/src/test/config/cache-load.properties |  18 +-
 .../test/config/class_list_exploit_excluded.txt    |  18 +-
 .../test/config/class_list_exploit_included.txt    |  18 +-
 .../src/test/config/default-spring-url-testing.xml |  27 ++-
 modules/core/src/test/config/discovery-stress.xml  |  27 ++-
 modules/core/src/test/config/example-cache.xml     |  27 ++-
 modules/core/src/test/config/examples.properties   |  18 +-
 .../config/hadoop/core-site-loopback-secondary.xml |  27 ++-
 .../src/test/config/hadoop/core-site-loopback.xml  |  27 ++-
 .../src/test/config/hadoop/core-site-secondary.xml |  27 ++-
 modules/core/src/test/config/hadoop/core-site.xml  |  27 ++-
 modules/core/src/test/config/igfs-loopback.xml     |  27 ++-
 modules/core/src/test/config/igfs-shmem.xml        |  27 ++-
 .../core/src/test/config/io-manager-benchmark.xml  |  27 ++-
 .../core/src/test/config/job-loadtest/client.xml   |  27 ++-
 .../config/job-loadtest/job-loadtest.properties    |  18 +-
 .../core/src/test/config/job-loadtest/server.xml   |  27 ++-
 modules/core/src/test/config/jobs-load-base.xml    |  27 ++-
 modules/core/src/test/config/jobs-load-client.xml  |  27 ++-
 modules/core/src/test/config/jobs-load-server.xml  |  27 ++-
 .../core/src/test/config/load/cache-benchmark.xml  |  27 ++-
 .../test/config/load/cache-client-benchmark.xml    |  27 ++-
 .../test/config/load/dsi-49-server-production.xml  |  27 ++-
 .../core/src/test/config/load/dsi-load-base.xml    |  27 ++-
 .../core/src/test/config/load/dsi-load-client.xml  |  27 ++-
 .../core/src/test/config/load/dsi-load-server.xml  |  27 ++-
 .../core/src/test/config/load/merge-sort-base.xml  |  27 ++-
 .../src/test/config/loaders/grid-cfg-2-grids.xml   |  27 ++-
 modules/core/src/test/config/loaders/grid-cfg.xml  |  27 ++-
 modules/core/src/test/config/log4j-tc-test.xml     |  29 ++-
 modules/core/src/test/config/log4j-test.xml        |  27 ++-
 modules/core/src/test/config/log4j2-test.xml       |  27 ++-
 .../core/src/test/config/log4j2-verbose-test.xml   |  27 ++-
 .../core/src/test/config/spark/spark-config.xml    |  27 ++-
 modules/core/src/test/config/spring-cache-load.xml |  27 ++-
 .../test/config/spring-cache-put-remove-load.xml   |  27 ++-
 modules/core/src/test/config/spring-cache-swap.xml |  27 ++-
 .../src/test/config/spring-cache-teststore.xml     |  27 ++-
 modules/core/src/test/config/spring-multicache.xml |  27 ++-
 .../src/test/config/spring-start-nodes-attr.xml    |  27 ++-
 .../core/src/test/config/spring-start-nodes.xml    |  27 ++-
 modules/core/src/test/config/start-nodes.ini       |  26 +--
 .../test/config/store/jdbc/ignite-jdbc-type.xml    |  27 ++-
 .../average/spring-streamer-average-base.xml       |  27 ++-
 .../average/spring-streamer-average-local.xml      |  27 ++-
 .../average/spring-streamer-average-random.xml     |  27 ++-
 .../test/config/streamer/spring-streamer-base.xml  |  27 ++-
 modules/core/src/test/config/tests.properties      |  18 +-
 .../test/config/websession/example-cache-base.xml  |  29 ++-
 .../config/websession/example-cache-client.xml     |  27 ++-
 .../src/test/config/websession/example-cache.xml   |  27 ++-
 .../src/test/config/websession/example-cache2.xml  |  27 ++-
 .../src/test/config/websession/spring-cache-1.xml  |  27 ++-
 .../src/test/config/websession/spring-cache-2.xml  |  27 ++-
 .../src/test/config/websession/spring-cache-3.xml  |  27 ++-
 modules/core/src/test/java/ExcludeList             |  19 +-
 .../ignite/GridCacheAffinityBackupsSelfTest.java   |  17 +-
 .../ignite/GridSuppressedExceptionSelfTest.java    |  17 +-
 .../java/org/apache/ignite/GridTestIoUtils.java    |  17 +-
 .../test/java/org/apache/ignite/GridTestJob.java   |  17 +-
 .../java/org/apache/ignite/GridTestJobContext.java |  17 +-
 .../java/org/apache/ignite/GridTestJobResult.java  |  17 +-
 .../org/apache/ignite/GridTestNodeStartup.java     |  17 +-
 .../apache/ignite/GridTestStoreNodeStartup.java    |  17 +-
 .../test/java/org/apache/ignite/GridTestTask.java  |  17 +-
 .../org/apache/ignite/GridTestTaskSession.java     |  17 +-
 .../apache/ignite/IgniteCacheAffinitySelfTest.java |  17 +-
 .../ignite/IgniteExternalizableAbstractTest.java   |  17 +-
 ...gniteCacheEntryProcessorSequentialCallTest.java |  17 +-
 .../ignite/cache/IgniteWarmupClosureSelfTest.java  |  17 +-
 .../apache/ignite/cache/LargeEntryUpdateTest.java  |  17 +-
 .../ignite/cache/NodeWithFilterRestartTest.java    |  17 +-
 .../ignite/cache/ResetLostPartitionTest.java       |  17 +-
 .../affinity/AbstractAffinityFunctionSelfTest.java |  17 +-
 .../cache/affinity/AffinityClientNodeSelfTest.java |  17 +-
 .../affinity/AffinityDistributionLoggingTest.java  |  17 +-
 ...finityFunctionBackupFilterAbstractSelfTest.java |  17 +-
 ...tyFunctionExcludeNeighborsAbstractSelfTest.java |  17 +-
 .../cache/affinity/AffinityHistoryCleanupTest.java |  17 +-
 .../affinity/local/LocalAffinityFunctionTest.java  |  17 +-
 ...rNodeAttributeAffinityBackupFilterSelfTest.java |  17 +-
 ...ezvousAffinityFunctionBackupFilterSelfTest.java |  17 +-
 ...usAffinityFunctionExcludeNeighborsSelfTest.java |  17 +-
 ...AffinityFunctionFastPowerOfTwoHashSelfTest.java |  17 +-
 .../RendezvousAffinityFunctionSelfTest.java        |  17 +-
 .../RendezvousAffinityFunctionSimpleBenchmark.java |  17 +-
 ...ezvousAffinityFunctionStandardHashSelfTest.java |  17 +-
 ...reListenerRWThroughDisabledAtomicCacheTest.java |  17 +-
 ...nerRWThroughDisabledTransactionalCacheTest.java |  17 +-
 .../cache/store/CacheStoreReadFromBackupTest.java  |  17 +-
 .../CacheStoreSessionListenerAbstractSelfTest.java |  17 +-
 ...CacheStoreSessionListenerLifecycleSelfTest.java |  17 +-
 ...stenerReadWriteThroughDisabledAbstractTest.java |  17 +-
 ...StoreSessionListenerWriteBehindEnabledTest.java |  17 +-
 .../cache/store/CacheStoreWriteErrorTest.java      |  17 +-
 .../CacheTransactionalStoreReadFromBackupTest.java |  17 +-
 .../store/GridCacheBalancingStoreSelfTest.java     |  17 +-
 .../GridCacheLoadOnlyStoreAdapterSelfTest.java     |  17 +-
 .../cache/store/GridGeneratingTestStore.java       |  17 +-
 .../ignite/cache/store/GridStoreLoadCacheTest.java |  17 +-
 .../store/IgniteCacheExpiryStoreLoadSelfTest.java  |  17 +-
 .../store/StoreResourceInjectionSelfTest.java      |  17 +-
 .../jdbc/CacheJdbcPojoStoreAbstractSelfTest.java   |  17 +-
 ...CacheJdbcPojoStoreBinaryMarshallerSelfTest.java |  17 +-
 ...oreBinaryMarshallerStoreKeepBinarySelfTest.java |  17 +-
 ...hallerStoreKeepBinaryWithSqlEscapeSelfTest.java |  17 +-
 ...StoreBinaryMarshallerWithSqlEscapeSelfTest.java |  17 +-
 .../CacheJdbcPojoStoreMultitreadedSelfTest.java    |  17 +-
 .../cache/store/jdbc/CacheJdbcPojoStoreTest.java   |  17 +-
 ...JdbcPojoWriteBehindStoreWithCoalescingTest.java |  17 +-
 ...acheJdbcStoreAbstractMultithreadedSelfTest.java |  17 +-
 .../CacheJdbcStoreSessionListenerSelfTest.java     |  17 +-
 ...ridCacheJdbcBlobStoreMultithreadedSelfTest.java |  17 +-
 .../store/jdbc/GridCacheJdbcBlobStoreSelfTest.java |  17 +-
 .../cache/store/jdbc/H2DataSourceFactory.java      |  17 +-
 .../jdbc/JdbcTypesDefaultTransformerTest.java      |  17 +-
 .../ignite/cache/store/jdbc/model/BinaryTest.java  |  17 +-
 .../cache/store/jdbc/model/BinaryTestKey.java      |  17 +-
 .../ignite/cache/store/jdbc/model/Gender.java      |  17 +-
 .../cache/store/jdbc/model/Organization.java       |  17 +-
 .../cache/store/jdbc/model/OrganizationKey.java    |  17 +-
 .../ignite/cache/store/jdbc/model/Person.java      |  17 +-
 .../cache/store/jdbc/model/PersonComplexKey.java   |  17 +-
 .../ignite/cache/store/jdbc/model/PersonKey.java   |  17 +-
 .../store/jdbc/model/TestJdbcPojoDataSource.java   |  17 +-
 .../jdbc/model/TestJdbcPojoDataSourceFactory.java  |  17 +-
 .../TestJdbcPojoStoreFactoryWithHangWriteAll.java  |  17 +-
 .../ignite/cache/store/jdbc/model/TestPojo.java    |  17 +-
 .../cache/store/jdbc/model/package-info.java       |  17 +-
 .../ignite/cache/store/jdbc/package-info.java      |  17 +-
 .../apache/ignite/cache/store/package-info.java    |  17 +-
 .../client/ClientCacheConfigurationTest.java       |  17 +-
 .../ignite/client/ClientConfigurationTest.java     |  17 +-
 .../java/org/apache/ignite/client/Comparers.java   |  17 +-
 .../test/java/org/apache/ignite/client/Config.java |  17 +-
 .../org/apache/ignite/client/ConnectionTest.java   |  17 +-
 .../org/apache/ignite/client/FunctionalTest.java   |  17 +-
 .../org/apache/ignite/client/IgniteBinaryTest.java |  17 +-
 .../java/org/apache/ignite/client/LoadTest.java    |  17 +-
 .../apache/ignite/client/LocalIgniteCluster.java   |  17 +-
 .../test/java/org/apache/ignite/client/Person.java |  17 +-
 .../org/apache/ignite/client/ReliabilityTest.java  |  17 +-
 .../apache/ignite/client/SslParametersTest.java    |  17 +-
 .../ignite/custom/DummyEventFilterFactory.java     |  17 +-
 .../ignite/failure/AbstractFailureHandlerTest.java |  17 +-
 .../failure/FailureHandlerTriggeredTest.java       |  17 +-
 .../failure/FailureHandlingConfigurationTest.java  |  17 +-
 .../ignite/failure/IoomFailureHandlerTest.java     |  17 +-
 .../ignite/failure/OomFailureHandlerTest.java      |  17 +-
 .../ignite/failure/StopNodeFailureHandlerTest.java |  17 +-
 .../failure/StopNodeOrHaltFailureHandlerTest.java  |  17 +-
 .../ignite/failure/SystemWorkersBlockingTest.java  |  17 +-
 .../failure/SystemWorkersTerminationTest.java      |  17 +-
 .../apache/ignite/failure/TestFailureHandler.java  |  17 +-
 .../ignite/igfs/IgfsEventsAbstractSelfTest.java    |  17 +-
 .../igfs/IgfsFragmentizerAbstractSelfTest.java     |  17 +-
 .../ignite/igfs/IgfsFragmentizerSelfTest.java      |  17 +-
 .../igfs/IgfsFragmentizerTopologySelfTest.java     |  17 +-
 .../org/apache/ignite/igfs/IgfsPathSelfTest.java   |  17 +-
 .../apache/ignite/igfs/IgfsTestInputGenerator.java |  17 +-
 .../org/apache/ignite/internal/ClassSetTest.java   |  17 +-
 .../ClusterBaselineNodesMetricsSelfTest.java       |  17 +-
 .../ignite/internal/ClusterGroupAbstractTest.java  |  17 +-
 .../ignite/internal/ClusterGroupHostsSelfTest.java |  17 +-
 .../ignite/internal/ClusterGroupSelfTest.java      |  17 +-
 .../ignite/internal/ClusterMetricsSelfTest.java    |  17 +-
 .../internal/ClusterNodeMetricsSelfTest.java       |  17 +-
 .../internal/ClusterNodeMetricsUpdateTest.java     |  17 +-
 .../ComputeJobCancelWithServiceSelfTest.java       |  17 +-
 .../ConsistentIdImplicitlyExplicitlyTest.java      |  17 +-
 .../ignite/internal/DiscoverySpiTestListener.java  |  17 +-
 .../ignite/internal/GridAffinityMappedTest.java    |  17 +-
 .../internal/GridAffinityNoCacheSelfTest.java      |  17 +-
 .../ignite/internal/GridAffinityP2PSelfTest.java   |  17 +-
 .../ignite/internal/GridAffinitySelfTest.java      |  17 +-
 .../GridAlwaysFailoverSpiFailSelfTest.java         |  17 +-
 ...dCachePartitionExchangeManagerHistSizeTest.java |  17 +-
 ...dCachePartitionExchangeManagerWarningsTest.java |  17 +-
 .../internal/GridCancelOnGridStopSelfTest.java     |  17 +-
 .../internal/GridCancelUnusedJobSelfTest.java      |  17 +-
 .../internal/GridCancelledJobsMetricsSelfTest.java |  17 +-
 .../internal/GridCollisionJobsContextSelfTest.java |  17 +-
 .../ignite/internal/GridCommunicationSelfTest.java |  17 +-
 ...idComputationBinarylizableClosuresSelfTest.java |  18 +-
 .../GridContinuousJobAnnotationSelfTest.java       |  17 +-
 .../GridContinuousJobSiblingsSelfTest.java         |  17 +-
 .../internal/GridContinuousTaskSelfTest.java       |  17 +-
 .../GridDeploymentMultiThreadedSelfTest.java       |  17 +-
 .../ignite/internal/GridDeploymentSelfTest.java    |  17 +-
 .../internal/GridDiscoveryEventSelfTest.java       |  17 +-
 .../ignite/internal/GridDiscoverySelfTest.java     |  17 +-
 .../GridEventStorageCheckAllEventsSelfTest.java    |  17 +-
 .../GridEventStorageDefaultExceptionTest.java      |  17 +-
 ...idEventStorageRuntimeConfigurationSelfTest.java |  17 +-
 .../ignite/internal/GridEventStorageSelfTest.java  |  17 +-
 .../ignite/internal/GridFactoryVmShutdownTest.java |  17 +-
 .../GridFailFastNodeFailureDetectionSelfTest.java  |  17 +-
 .../GridFailedInputParametersSelfTest.java         |  17 +-
 .../GridFailoverCustomTopologySelfTest.java        |  17 +-
 .../ignite/internal/GridFailoverSelfTest.java      |  17 +-
 .../GridFailoverTaskWithPredicateSelfTest.java     |  17 +-
 .../internal/GridFailoverTopologySelfTest.java     |  17 +-
 .../ignite/internal/GridGetOrStartSelfTest.java    |  17 +-
 .../ignite/internal/GridHomePathSelfTest.java      |  17 +-
 .../internal/GridJobCheckpointCleanupSelfTest.java |  17 +-
 .../internal/GridJobCollisionCancelSelfTest.java   |  17 +-
 .../ignite/internal/GridJobContextSelfTest.java    |  17 +-
 .../internal/GridJobMasterLeaveAwareSelfTest.java  |  17 +-
 .../internal/GridJobServicesAddNodeTest.java       |  17 +-
 .../ignite/internal/GridJobStealingSelfTest.java   |  17 +-
 .../GridJobStealingZeroActiveJobsSelfTest.java     |  17 +-
 .../ignite/internal/GridJobSubjectIdSelfTest.java  |  17 +-
 .../GridKernalConcurrentAccessStopSelfTest.java    |  17 +-
 .../ignite/internal/GridKernalTestUtils.java       |  17 +-
 .../internal/GridLifecycleAwareSelfTest.java       |  17 +-
 .../ignite/internal/GridLifecycleBeanSelfTest.java |  17 +-
 .../ignite/internal/GridListenActorSelfTest.java   |  17 +-
 .../internal/GridLocalEventListenerSelfTest.java   |  17 +-
 .../org/apache/ignite/internal/GridMBeansTest.java |  17 +-
 .../ignite/internal/GridMultipleJobsSelfTest.java  |  17 +-
 .../ignite/internal/GridMultipleSpisSelfTest.java  |  17 +-
 .../GridMultipleVersionsDeploymentSelfTest.java    |  17 +-
 .../GridMultithreadedJobStealingSelfTest.java      |  17 +-
 .../ignite/internal/GridNodeFilterSelfTest.java    |  17 +-
 .../ignite/internal/GridNodeLocalSelfTest.java     |  17 +-
 .../internal/GridNodeMetricsLogPdsSelfTest.java    |  17 +-
 .../internal/GridNodeMetricsLogSelfTest.java       |  17 +-
 .../internal/GridNodeVisorAttributesSelfTest.java  |  17 +-
 .../internal/GridNonHistoryMetricsSelfTest.java    |  17 +-
 .../internal/GridProjectionForCachesSelfTest.java  |  17 +-
 ...rojectionLocalJobMultipleArgumentsSelfTest.java |  17 +-
 .../apache/ignite/internal/GridReduceSelfTest.java |  17 +-
 .../ignite/internal/GridReleaseTypeSelfTest.java   |  17 +-
 .../internal/GridRuntimeExceptionSelfTest.java     |  17 +-
 .../ignite/internal/GridSameVmStartupSelfTest.java |  17 +-
 .../org/apache/ignite/internal/GridSelfTest.java   |  17 +-
 .../ignite/internal/GridSpiExceptionSelfTest.java  |  17 +-
 .../ignite/internal/GridStartStopSelfTest.java     |  17 +-
 .../internal/GridStopWithCancelSelfTest.java       |  17 +-
 .../ignite/internal/GridStopWithWaitSelfTest.java  |  17 +-
 .../internal/GridTaskCancelSingleNodeSelfTest.java |  17 +-
 .../internal/GridTaskContinuousMapperSelfTest.java |  17 +-
 .../internal/GridTaskExecutionContextSelfTest.java |  17 +-
 .../ignite/internal/GridTaskExecutionSelfTest.java |  17 +-
 ...skExecutionWithoutPeerClassLoadingSelfTest.java |  17 +-
 .../internal/GridTaskFailoverAffinityRunTest.java  |  17 +-
 .../ignite/internal/GridTaskFailoverSelfTest.java  |  17 +-
 .../GridTaskFutureImplStopGridSelfTest.java        |  17 +-
 .../GridTaskInstanceExecutionSelfTest.java         |  17 +-
 .../internal/GridTaskInstantiationSelfTest.java    |  17 +-
 .../ignite/internal/GridTaskJobRejectSelfTest.java |  17 +-
 .../ignite/internal/GridTaskListenerSelfTest.java  |  17 +-
 .../ignite/internal/GridTaskMapAsyncSelfTest.java  |  17 +-
 .../internal/GridTaskNameAnnotationSelfTest.java   |  17 +-
 .../internal/GridTaskResultCacheSelfTest.java      |  17 +-
 .../ignite/internal/GridTaskTimeoutSelfTest.java   |  17 +-
 .../internal/GridTopicExternalizableSelfTest.java  |  17 +-
 .../ignite/internal/GridVersionSelfTest.java       |  17 +-
 ...ClientConnectAfterCommunicationFailureTest.java |  17 +-
 .../IgniteClientReconnectAbstractTest.java         |  17 +-
 .../IgniteClientReconnectApiExceptionTest.java     |  17 +-
 .../internal/IgniteClientReconnectAtomicsTest.java |  17 +-
 ...ientReconnectAtomicsWithLostPartitionsTest.java |  29 ++-
 .../IgniteClientReconnectBinaryContexTest.java     |  17 +-
 .../internal/IgniteClientReconnectCacheTest.java   |  17 +-
 .../IgniteClientReconnectCollectionsTest.java      |  17 +-
 .../internal/IgniteClientReconnectComputeTest.java |  17 +-
 ...niteClientReconnectContinuousProcessorTest.java |  17 +-
 .../IgniteClientReconnectDelayedSpiTest.java       |  17 +-
 .../IgniteClientReconnectDiscoveryStateTest.java   |  17 +-
 .../IgniteClientReconnectFailoverAbstractTest.java |  17 +-
 .../IgniteClientReconnectFailoverTest.java         |  17 +-
 .../IgniteClientReconnectServicesTest.java         |  17 +-
 .../internal/IgniteClientReconnectStopTest.java    |  17 +-
 .../IgniteClientReconnectStreamerTest.java         |  17 +-
 .../ignite/internal/IgniteClientRejoinTest.java    |  17 +-
 .../IgniteComputeEmptyClusterGroupTest.java        |  17 +-
 .../internal/IgniteComputeJobOneThreadTest.java    |  17 +-
 .../internal/IgniteComputeResultExceptionTest.java |  17 +-
 .../IgniteComputeTopologyExceptionTest.java        |  17 +-
 ...niteConcurrentEntryProcessorAccessStopTest.java |  17 +-
 ...teConnectionConcurrentReserveAndRemoveTest.java |  17 +-
 .../IgniteDiscoveryMassiveNodeFailTest.java        |  17 +-
 .../ignite/internal/IgniteExecutorServiceTest.java |  17 +-
 .../IgniteExplicitImplicitDeploymentSelfTest.java  |  17 +-
 .../internal/IgniteInternalCacheRemoveTest.java    |  17 +-
 .../IgniteLocalNodeMapBeforeStartTest.java         |  17 +-
 .../internal/IgniteReflectionFactorySelfTest.java  |  17 +-
 ...iteRoundRobinErrorAfterClientReconnectTest.java |  17 +-
 .../IgniteSlowClientDetectionSelfTest.java         |  17 +-
 ...iteUpdateNotifierPerClusterSettingSelfTest.java |  17 +-
 .../internal/IgniteVersionUtilsSelfTest.java       |  17 +-
 .../ignite/internal/LongJVMPauseDetectorTest.java  |  17 +-
 .../internal/MarshallerContextLockingSelfTest.java |  17 +-
 .../internal/MemoryLeaksOnRestartNodeTest.java     |  17 +-
 .../internal/SensitiveInfoTestLoggerProxy.java     |  17 +-
 .../SensitiveInfoTestLoggerProxy_Exclude.txt       |  17 +-
 .../SensitiveInfoTestLoggerProxy_Include.txt       |  17 +-
 .../ignite/internal/TaskNodeRestartTest.java       |  17 +-
 .../internal/TestDelayingCommunicationSpi.java     |  17 +-
 .../internal/TestManagementVisorMultiNodeTask.java |  17 +-
 .../internal/TestManagementVisorOneNodeTask.java   |  17 +-
 .../TestNotManagementVisorMultiNodeTask.java       |  17 +-
 .../TestNotManagementVisorOneNodeTask.java         |  17 +-
 .../internal/TestRecordingCommunicationSpi.java    |  17 +-
 .../internal/TransactionMetricsMxBeanImplTest.java |  17 +-
 .../internal/TransactionsMXBeanImplTest.java       |  17 +-
 .../internal/VisorManagementEventSelfTest.java     |  17 +-
 .../apache/ignite/internal/binary/AffinityKey.java |  17 +-
 .../BinaryArrayIdentityResolverSelfTest.java       |  17 +-
 .../binary/BinaryBasicIdMapperSelfTest.java        |  17 +-
 .../binary/BinaryBasicNameMapperSelfTest.java      |  17 +-
 .../BinaryConfigurationConsistencySelfTest.java    |  17 +-
 ...inaryConfigurationCustomSerializerSelfTest.java |  17 +-
 .../internal/binary/BinaryEnumsSelfTest.java       |  17 +-
 .../binary/BinaryFieldExtractionSelfTest.java      |  17 +-
 .../binary/BinaryFieldsAbstractSelfTest.java       |  17 +-
 .../internal/binary/BinaryFieldsHeapSelfTest.java  |  17 +-
 .../binary/BinaryFieldsOffheapSelfTest.java        |  17 +-
 .../BinaryFooterOffsetsAbstractSelfTest.java       |  17 +-
 .../binary/BinaryFooterOffsetsHeapSelfTest.java    |  17 +-
 .../binary/BinaryFooterOffsetsOffheapSelfTest.java |  17 +-
 .../internal/binary/BinaryMarshallerSelfTest.java  |  17 +-
 .../BinaryObjectBuilderAdditionalSelfTest.java     |  17 +-
 .../BinaryObjectBuilderDefaultMappersSelfTest.java |  17 +-
 ...tBuilderSimpleNameLowerCaseMappersSelfTest.java |  17 +-
 .../binary/BinaryObjectExceptionSelfTest.java      |  17 +-
 .../binary/BinaryObjectToStringSelfTest.java       |  17 +-
 .../binary/BinaryObjectTypeCompatibilityTest.java  |  17 +-
 .../BinarySerialiedFieldComparatorSelfTest.java    |  17 +-
 .../BinarySimpleNameTestPropertySelfTest.java      |  17 +-
 .../ignite/internal/binary/BinaryTreeSelfTest.java |  17 +-
 .../binary/GridBinaryAffinityKeySelfTest.java      |  17 +-
 .../GridBinaryMarshallerCtxDisabledSelfTest.java   |  17 +-
 .../binary/GridBinaryWildcardsSelfTest.java        |  17 +-
 ...DefaultBinaryMappersBinaryMetaDataSelfTest.java |  17 +-
 ...werCaseBinaryMappersBinaryMetaDataSelfTest.java |  17 +-
 .../binary/TestCachingMetadataHandler.java         |  17 +-
 .../ignite/internal/binary/TestMappedObject.java   |  17 +-
 .../GridBinaryMarshalerAwareTestClass.java         |  17 +-
 .../binary/mutabletest/GridBinaryTestClasses.java  |  17 +-
 .../internal/binary/mutabletest/package-info.java  |  17 +-
 .../BinaryFieldsHeapNonCompactSelfTest.java        |  17 +-
 .../BinaryFieldsOffheapNonCompactSelfTest.java     |  17 +-
 .../BinaryFooterOffsetsHeapNonCompactSelfTest.java |  17 +-
 ...naryFooterOffsetsOffheapNonCompactSelfTest.java |  17 +-
 .../BinaryMarshallerNonCompactSelfTest.java        |  17 +-
 ...yObjectBuilderAdditionalNonCompactSelfTest.java |  17 +-
 ...ectBuilderNonCompactDefaultMappersSelfTest.java |  17 +-
 ...nCompactSimpleNameLowerCaseMappersSelfTest.java |  17 +-
 .../ignite/internal/binary/package-info.java       |  17 +-
 .../AbstractBinaryStreamByteOrderSelfTest.java     |  17 +-
 .../streams/BinaryAbstractOutputStreamTest.java    |  17 +-
 .../streams/BinaryHeapStreamByteOrderSelfTest.java |  17 +-
 .../BinaryOffheapStreamByteOrderSelfTest.java      |  17 +-
 .../internal/binary/test/GridBinaryTestClass1.java |  17 +-
 .../internal/binary/test/GridBinaryTestClass2.java |  17 +-
 .../ignite/internal/binary/test/package-info.java  |  17 +-
 .../test/subpackage/GridBinaryTestClass3.java      |  17 +-
 .../binary/test/subpackage/package-info.java       |  17 +-
 .../FullyConnectedComponentSearcherTest.java       |  17 +-
 .../internal/commandline/CommandArgFactory.java    |  27 ++-
 .../commandline/CommandHandlerParsingTest.java     |  17 +-
 ...ectByteBufferStreamImplV2ByteOrderSelfTest.java |  17 +-
 .../encryption/AbstractEncryptionTest.java         |  17 +-
 .../encryption/EncryptedCacheBigEntryTest.java     |  17 +-
 .../encryption/EncryptedCacheCreateTest.java       |  17 +-
 .../encryption/EncryptedCacheDestroyTest.java      |  17 +-
 .../encryption/EncryptedCacheGroupCreateTest.java  |  17 +-
 .../encryption/EncryptedCacheNodeJoinTest.java     |  17 +-
 .../EncryptedCachePreconfiguredRestartTest.java    |  17 +-
 .../encryption/EncryptedCacheRestartTest.java      |  17 +-
 .../GridManagerLocalMessageListenerSelfTest.java   |  17 +-
 ...GridManagerMxBeanIllegalArgumentHandleTest.java |  17 +-
 .../internal/managers/GridManagerStopSelfTest.java |  17 +-
 .../internal/managers/GridNoopManagerSelfTest.java |  17 +-
 ...eDiagnosticMessagesMultipleConnectionsTest.java |  17 +-
 .../managers/IgniteDiagnosticMessagesTest.java     |  17 +-
 .../GridCheckpointManagerAbstractSelfTest.java     |  17 +-
 .../checkpoint/GridCheckpointManagerSelfTest.java  |  17 +-
 .../checkpoint/GridCheckpointTaskSelfTest.java     |  17 +-
 .../internal/managers/checkpoint/package-info.java |  17 +-
 .../GridCommunicationManagerListenersSelfTest.java |  17 +-
 .../GridCommunicationSendMessageSelfTest.java      |  17 +-
 .../communication/GridIoManagerSelfTest.java       |  17 +-
 ...ommunicationBalanceMultipleConnectionsTest.java |  17 +-
 ...eCommunicationBalancePairedConnectionsTest.java |  17 +-
 .../IgniteCommunicationBalanceTest.java            |  17 +-
 .../IgniteCommunicationSslBalanceTest.java         |  17 +-
 .../communication/IgniteIoTestMessagesTest.java    |  17 +-
 .../IgniteVariousConnectionNumberTest.java         |  17 +-
 .../managers/communication/package-info.java       |  17 +-
 ...loymentRequestOfUnknownClassProcessingTest.java |  17 +-
 .../GridDeploymentManagerStopSelfTest.java         |  17 +-
 .../GridDeploymentMessageCountSelfTest.java        |  17 +-
 .../managers/deployment/GridTestDeployment.java    |  17 +-
 .../internal/managers/deployment/package-info.java |  17 +-
 .../GridDiscoveryManagerAliveCacheSelfTest.java    |  17 +-
 .../GridDiscoveryManagerAttributesSelfTest.java    |  17 +-
 .../IgniteTopologyPrintFormatSelfTest.java         |  17 +-
 .../events/GridEventStorageManagerSelfTest.java    |  17 +-
 .../ignite/internal/managers/package-info.java     |  17 +-
 .../optimized/OptimizedMarshallerEnumSelfTest.java |  17 +-
 .../OptimizedMarshallerNodeFailoverTest.java       |  17 +-
 .../OptimizedMarshallerPooledSelfTest.java         |  17 +-
 .../optimized/OptimizedMarshallerSelfTest.java     |  17 +-
 ...edMarshallerSerialPersistentFieldsSelfTest.java |  17 +-
 .../optimized/OptimizedMarshallerTest.java         |  17 +-
 .../optimized/OptimizedObjectStreamSelfTest.java   |  17 +-
 .../optimized/TestTcpDiscoveryIpFinderAdapter.java |  17 +-
 .../marshaller/optimized/package-info.java         |  17 +-
 .../org/apache/ignite/internal/package-info.java   |  17 +-
 .../internal/pagemem/impl/PageIdUtilsSelfTest.java |  17 +-
 .../pagemem/impl/PageMemoryNoLoadSelfTest.java     |  17 +-
 .../processors/DeadLockOnNodeLeftExchangeTest.java |  17 +-
 .../GridCacheTxLoadFromStoreOnLockSelfTest.java    |  17 +-
 .../affinity/GridAffinityAssignmentV2Test.java     |  17 +-
 ...ridAffinityAssignmentV2TestNoOptimizations.java |  17 +-
 .../GridAffinityProcessorAbstractSelfTest.java     |  17 +-
 .../GridAffinityProcessorMemoryLeakTest.java       |  17 +-
 .../GridAffinityProcessorRendezvousSelfTest.java   |  17 +-
 .../GridHistoryAffinityAssignmentTest.java         |  17 +-
 ...istoryAffinityAssignmentTestNoOptimization.java |  17 +-
 .../affinity/SerializableMetricsProvider.java      |  17 +-
 .../Authentication1kUsersNodeRestartTest.java      |  17 +-
 .../AuthenticationConfigurationClusterTest.java    |  17 +-
 .../AuthenticationOnNotActiveClusterTest.java      |  17 +-
 .../AuthenticationProcessorNPEOnStartTest.java     |  17 +-
 .../AuthenticationProcessorNodeRestartTest.java    |  17 +-
 .../AuthenticationProcessorSelfTest.java           |  17 +-
 .../AtomicCacheAffinityConfigurationTest.java      |  17 +-
 ...tadataRegistrationInsideEntryProcessorTest.java |  17 +-
 .../cache/CacheAffinityCallSelfTest.java           |  17 +-
 .../CacheAtomicSingleMessageCountSelfTest.java     |  17 +-
 .../processors/cache/CacheClientStoreSelfTest.java |  17 +-
 .../processors/cache/CacheComparatorTest.java      |  17 +-
 .../cache/CacheConcurrentReadThroughTest.java      |  17 +-
 .../cache/CacheConfigurationLeakTest.java          |  17 +-
 ...eConfigurationSerializationOnDiscoveryTest.java |  17 +-
 ...heConfigurationSerializationOnExchangeTest.java |  17 +-
 .../cache/CacheConnectionLeakStoreTxTest.java      |  17 +-
 .../cache/CacheDataRegionConfigurationTest.java    |  17 +-
 .../cache/CacheDeferredDeleteQueueTest.java        |  17 +-
 .../cache/CacheDeferredDeleteSanitySelfTest.java   |  17 +-
 .../CacheDhtLocalPartitionAfterRemoveSelfTest.java |  17 +-
 .../cache/CacheEntryProcessorCopySelfTest.java     |  17 +-
 .../cache/CacheEnumOperationsAbstractTest.java     |  17 +-
 .../cache/CacheEnumOperationsSingleNodeTest.java   |  17 +-
 .../processors/cache/CacheEnumOperationsTest.java  |  17 +-
 .../cache/CacheEventWithTxLabelTest.java           |  17 +-
 .../CacheExchangeMessageDuplicatedStateTest.java   |  17 +-
 .../cache/CacheFutureExceptionSelfTest.java        |  17 +-
 .../cache/CacheGetEntryAbstractTest.java           |  17 +-
 ...cheGetEntryOptimisticReadCommittedSelfTest.java |  17 +-
 ...heGetEntryOptimisticRepeatableReadSelfTest.java |  17 +-
 ...acheGetEntryOptimisticSerializableSelfTest.java |  17 +-
 ...heGetEntryPessimisticReadCommittedSelfTest.java |  17 +-
 ...eGetEntryPessimisticRepeatableReadSelfTest.java |  17 +-
 ...cheGetEntryPessimisticSerializableSelfTest.java |  17 +-
 .../processors/cache/CacheGetFromJobTest.java      |  17 +-
 .../cache/CacheGetRemoveSkipStoreTest.java         |  17 +-
 .../cache/CacheGetsDistributionAbstractTest.java   |  17 +-
 .../CacheGroupLocalConfigurationSelfTest.java      |  17 +-
 .../cache/CacheGroupMetricsMBeanTest.java          |  17 +-
 .../cache/CacheGroupsMetricsRebalanceTest.java     |  17 +-
 ...InterceptorPartitionCounterLocalSanityTest.java |  17 +-
 ...ceptorPartitionCounterRandomOperationsTest.java |  17 +-
 .../cache/CacheKeepBinaryTransactionTest.java      |  17 +-
 .../cache/CacheLocalGetSerializationTest.java      |  17 +-
 .../cache/CacheMetricsCacheSizeTest.java           |  17 +-
 .../cache/CacheMetricsEntitiesCountTest.java       |  17 +-
 .../cache/CacheMetricsForClusterGroupSelfTest.java |  17 +-
 .../processors/cache/CacheMetricsManageTest.java   |  17 +-
 .../cache/CacheMvccTxFastFinishTest.java           |  17 +-
 .../cache/CacheNearReaderUpdateTest.java           |  17 +-
 .../CacheNearUpdateTopologyChangeAbstractTest.java |  17 +-
 .../cache/CacheNoAffinityExchangeTest.java         |  17 +-
 .../cache/CacheOffheapMapEntrySelfTest.java        |  17 +-
 ...sticTransactionsWithFilterSingleServerTest.java |  17 +-
 .../CacheOptimisticTransactionsWithFilterTest.java |  17 +-
 .../cache/CachePutEventListenerErrorSelfTest.java  |  17 +-
 .../processors/cache/CachePutIfAbsentTest.java     |  17 +-
 .../CacheReadThroughAtomicRestartSelfTest.java     |  17 +-
 ...CacheReadThroughLocalAtomicRestartSelfTest.java |  17 +-
 .../CacheReadThroughLocalRestartSelfTest.java      |  17 +-
 ...ReadThroughReplicatedAtomicRestartSelfTest.java |  17 +-
 .../CacheReadThroughReplicatedRestartSelfTest.java |  17 +-
 .../cache/CacheReadThroughRestartSelfTest.java     |  17 +-
 .../processors/cache/CacheRebalancingSelfTest.java |  18 +-
 .../processors/cache/CacheRemoveAllSelfTest.java   |  17 +-
 .../cache/CacheSerializableTransactionsTest.java   |  17 +-
 .../cache/CacheStartupInDeploymentModesTest.java   |  17 +-
 .../cache/CacheStopAndDestroySelfTest.java         |  27 ++-
 .../cache/CacheStoreTxPutAllMultiNodeTest.java     |  27 ++-
 .../CacheStoreUsageMultinodeAbstractTest.java      |  17 +-
 ...toreUsageMultinodeDynamicStartAbstractTest.java |  17 +-
 ...eStoreUsageMultinodeDynamicStartAtomicTest.java |  17 +-
 ...CacheStoreUsageMultinodeDynamicStartTxTest.java |  17 +-
 ...StoreUsageMultinodeStaticStartAbstractTest.java |  17 +-
 ...heStoreUsageMultinodeStaticStartAtomicTest.java |  17 +-
 .../CacheStoreUsageMultinodeStaticStartTxTest.java |  17 +-
 .../processors/cache/CacheTxFastFinishTest.java    |  17 +-
 .../cache/CacheTxNotAllowReadFromBackupTest.java   |  17 +-
 .../cache/CacheValidatorMetricsTest.java           |  17 +-
 .../ClientFastReplyCoordinatorFailureTest.java     |  17 +-
 .../cache/ClusterReadOnlyModeAbstractTest.java     |  17 +-
 .../processors/cache/ClusterReadOnlyModeTest.java  |  17 +-
 .../processors/cache/ClusterStateAbstractTest.java |  18 +-
 .../cache/ClusterStatePartitionedSelfTest.java     |  18 +-
 .../cache/ClusterStateReplicatedSelfTest.java      |  18 +-
 .../processors/cache/ConcurrentCacheStartTest.java |  18 +-
 .../processors/cache/CrossCacheLockTest.java       |  17 +-
 ...rossCacheTxNearEnabledRandomOperationsTest.java |  17 +-
 .../cache/CrossCacheTxRandomOperationsTest.java    |  17 +-
 .../DataStorageConfigurationValidationTest.java    |  17 +-
 .../EntryVersionConsistencyReadThroughTest.java    |  17 +-
 .../GridAbstractCacheInterceptorRebalanceTest.java |  17 +-
 .../GridCacheAbstractByteArrayValuesSelfTest.java  |  17 +-
 .../cache/GridCacheAbstractFailoverSelfTest.java   |  17 +-
 .../cache/GridCacheAbstractFailoverTxSelfTest.java |  17 +-
 ...dCacheAbstractFullApiMultithreadedSelfTest.java |  17 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java    |  17 +-
 .../cache/GridCacheAbstractIteratorsSelfTest.java  |  17 +-
 .../cache/GridCacheAbstractLocalStoreSelfTest.java |  17 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java    |  17 +-
 .../cache/GridCacheAbstractRemoveFailureTest.java  |  17 +-
 .../cache/GridCacheAbstractSelfTest.java           |  17 +-
 .../cache/GridCacheAbstractTxReadTest.java         |  17 +-
 ...idCacheAbstractUsersAffinityMapperSelfTest.java |  17 +-
 .../cache/GridCacheAffinityApiSelfTest.java        |  17 +-
 .../cache/GridCacheAffinityMapperSelfTest.java     |  17 +-
 .../cache/GridCacheAffinityRoutingSelfTest.java    |  17 +-
 .../cache/GridCacheAlwaysEvictionPolicy.java       |  17 +-
 .../GridCacheAsyncOperationsLimitSelfTest.java     |  17 +-
 ...acheAtomicEntryProcessorDeploymentSelfTest.java |  17 +-
 .../cache/GridCacheAtomicMessageCountSelfTest.java |  17 +-
 ...GridCacheAtomicUsersAffinityMapperSelfTest.java |  17 +-
 .../cache/GridCacheBasicApiAbstractTest.java       |  17 +-
 .../cache/GridCacheBasicStoreAbstractTest.java     |  17 +-
 ...idCacheBasicStoreMultithreadedAbstractTest.java |  17 +-
 .../cache/GridCacheClearAllSelfTest.java           |  17 +-
 .../cache/GridCacheClearLocallySelfTest.java       |  17 +-
 .../processors/cache/GridCacheClearSelfTest.java   |  17 +-
 ...GridCacheColocatedTxStoreExceptionSelfTest.java |  17 +-
 .../GridCacheConcurrentGetCacheOnClientTest.java   |  17 +-
 .../cache/GridCacheConcurrentMapSelfTest.java      |  17 +-
 .../GridCacheConcurrentTxMultiNodeLoadTest.java    |  17 +-
 .../GridCacheConditionalDeploymentSelfTest.java    |  17 +-
 .../GridCacheConfigurationConsistencySelfTest.java |  17 +-
 .../GridCacheConfigurationValidationSelfTest.java  |  17 +-
 .../cache/GridCacheDaemonNodeAbstractSelfTest.java |  17 +-
 .../cache/GridCacheEntryMemorySizeSelfTest.java    |  17 +-
 .../cache/GridCacheEntryVersionSelfTest.java       |  17 +-
 .../cache/GridCacheEvictionEventAbstractTest.java  |  17 +-
 .../cache/GridCacheFinishPartitionsSelfTest.java   |  17 +-
 ...ridCacheFullTextQueryMultithreadedSelfTest.java |  17 +-
 .../cache/GridCacheGenericTestStore.java           |  17 +-
 .../GridCacheGetAndTransformStoreAbstractTest.java |  17 +-
 .../cache/GridCacheIncrementTransformTest.java     |  17 +-
 .../GridCacheInterceptorAbstractSelfTest.java      |  17 +-
 ...dCacheInterceptorAtomicNearEnabledSelfTest.java |  17 +-
 .../GridCacheInterceptorAtomicRebalanceTest.java   |  17 +-
 ...idCacheInterceptorAtomicReplicatedSelfTest.java |  17 +-
 .../cache/GridCacheInterceptorAtomicSelfTest.java  |  17 +-
 ...terceptorAtomicWithStoreReplicatedSelfTest.java |  17 +-
 ...ridCacheInterceptorAtomicWithStoreSelfTest.java |  17 +-
 .../GridCacheInterceptorLocalAtomicSelfTest.java   |  17 +-
 ...cheInterceptorLocalAtomicWithStoreSelfTest.java |  17 +-
 .../cache/GridCacheInterceptorLocalSelfTest.java   |  17 +-
 ...GridCacheInterceptorLocalWithStoreSelfTest.java |  17 +-
 .../GridCacheInterceptorNearEnabledSelfTest.java   |  17 +-
 .../GridCacheInterceptorReplicatedSelfTest.java    |  17 +-
 ...acheInterceptorReplicatedWithStoreSelfTest.java |  17 +-
 .../cache/GridCacheInterceptorSelfTest.java        |  17 +-
 ...CacheInterceptorTransactionalRebalanceTest.java |  17 +-
 .../GridCacheInterceptorWithStoreSelfTest.java     |  17 +-
 .../cache/GridCacheIteratorPerformanceTest.java    |  17 +-
 .../GridCacheKeyCheckNearEnabledSelfTest.java      |  17 +-
 .../cache/GridCacheKeyCheckSelfTest.java           |  17 +-
 .../processors/cache/GridCacheLeakTest.java        |  17 +-
 .../cache/GridCacheLifecycleAwareSelfTest.java     |  17 +-
 .../GridCacheLocalTxStoreExceptionSelfTest.java    |  17 +-
 ...CacheLongRunningTransactionDiagnosticsTest.java |  17 +-
 .../cache/GridCacheMarshallerTxAbstractTest.java   |  17 +-
 .../GridCacheMarshallingNodeJoinSelfTest.java      |  17 +-
 .../GridCacheMissingCommitVersionSelfTest.java     |  17 +-
 .../GridCacheMixedPartitionExchangeSelfTest.java   |  17 +-
 .../cache/GridCacheMultiUpdateLockSelfTest.java    |  17 +-
 .../GridCacheMultinodeUpdateAbstractSelfTest.java  |  17 +-
 ...heMultinodeUpdateAtomicNearEnabledSelfTest.java |  17 +-
 .../GridCacheMultinodeUpdateAtomicSelfTest.java    |  17 +-
 ...ultinodeUpdateNearEnabledNoBackupsSelfTest.java |  17 +-
 ...ridCacheMultinodeUpdateNearEnabledSelfTest.java |  17 +-
 .../cache/GridCacheMultinodeUpdateSelfTest.java    |  17 +-
 .../processors/cache/GridCacheMvccFlagsTest.java   |  17 +-
 .../cache/GridCacheMvccManagerSelfTest.java        |  17 +-
 .../GridCacheMvccMultiThreadedUpdateSelfTest.java  |  17 +-
 .../cache/GridCacheMvccPartitionedSelfTest.java    |  17 +-
 .../processors/cache/GridCacheMvccSelfTest.java    |  17 +-
 .../GridCacheNearTxStoreExceptionSelfTest.java     |  17 +-
 .../cache/GridCacheNestedTxAbstractTest.java       |  17 +-
 .../cache/GridCacheObjectToStringSelfTest.java     |  17 +-
 ...heOffHeapAtomicMultiThreadedUpdateSelfTest.java |  17 +-
 ...OffHeapMultiThreadedUpdateAbstractSelfTest.java |  17 +-
 ...ridCacheOffHeapMultiThreadedUpdateSelfTest.java |  17 +-
 .../cache/GridCacheOffheapUpdateSelfTest.java      |  17 +-
 .../cache/GridCacheOnCopyFlagAbstractSelfTest.java |  17 +-
 .../cache/GridCacheOnCopyFlagAtomicSelfTest.java   |  17 +-
 .../cache/GridCacheOnCopyFlagLocalSelfTest.java    |  17 +-
 .../GridCacheOnCopyFlagReplicatedSelfTest.java     |  17 +-
 .../GridCacheOnCopyFlagTxPartitionedSelfTest.java  |  17 +-
 .../cache/GridCacheOrderedPreloadingSelfTest.java  |  17 +-
 .../cache/GridCacheP2PUndeploySelfTest.java        |  17 +-
 .../cache/GridCachePartitionedGetSelfTest.java     |  17 +-
 .../GridCachePartitionedLocalStoreSelfTest.java    |  17 +-
 ...CachePartitionedProjectionAffinitySelfTest.java |  17 +-
 .../cache/GridCachePartitionedWritesTest.java      |  17 +-
 .../GridCachePreloadingEvictionsSelfTest.java      |  17 +-
 .../cache/GridCachePutAllFailoverSelfTest.java     |  17 +-
 .../processors/cache/GridCachePutAllTask.java      |  17 +-
 .../cache/GridCacheQueryEmbeddedValue.java         |  17 +-
 .../GridCacheQueryIndexingDisabledSelfTest.java    |  17 +-
 .../cache/GridCacheQueryInternalKeysSelfTest.java  |  17 +-
 .../GridCacheQuerySqlFieldInlineSizeSelfTest.java  |  17 +-
 .../cache/GridCacheReferenceCleanupSelfTest.java   |  17 +-
 .../processors/cache/GridCacheReloadSelfTest.java  |  17 +-
 .../GridCacheReplicatedLocalStoreSelfTest.java     |  17 +-
 .../GridCacheReplicatedSynchronousCommitTest.java  |  17 +-
 ...ridCacheReplicatedTxStoreExceptionSelfTest.java |  17 +-
 ...CacheReplicatedUsersAffinityMapperSelfTest.java |  17 +-
 .../GridCacheReturnValueTransferSelfTest.java      |  17 +-
 .../processors/cache/GridCacheSlowTxWarnTest.java  |  17 +-
 .../processors/cache/GridCacheStopSelfTest.java    |  17 +-
 .../GridCacheStoreManagerDeserializationTest.java  |  17 +-
 .../cache/GridCacheStoreValueBytesSelfTest.java    |  17 +-
 ...idCacheTcpClientDiscoveryMultiThreadedTest.java |  17 +-
 .../processors/cache/GridCacheTestEntryEx.java     |  17 +-
 .../processors/cache/GridCacheTestKey.java         |  17 +-
 .../processors/cache/GridCacheTestStore.java       |  17 +-
 .../processors/cache/GridCacheTestValue.java       |  17 +-
 .../processors/cache/GridCacheTestValue2.java      |  17 +-
 ...dCacheTransactionalAbstractMetricsSelfTest.java |  17 +-
 ...nsactionalEntryProcessorDeploymentSelfTest.java |  17 +-
 .../cache/GridCacheTtlManagerEvictionSelfTest.java |  17 +-
 .../cache/GridCacheTtlManagerLoadTest.java         |  17 +-
 .../cache/GridCacheTtlManagerNotificationTest.java |  17 +-
 .../cache/GridCacheTtlManagerSelfTest.java         |  17 +-
 .../GridCacheTxPartitionedLocalStoreSelfTest.java  |  17 +-
 .../GridCacheTxUsersAffinityMapperSelfTest.java    |  17 +-
 .../processors/cache/GridCacheUtilsSelfTest.java   |  17 +-
 .../GridCacheValueBytesPreloadingSelfTest.java     |  17 +-
 .../GridCacheValueConsistencyAbstractSelfTest.java |  17 +-
 ...onsistencyTransactionalNearEnabledSelfTest.java |  17 +-
 ...CacheValueConsistencyTransactionalSelfTest.java |  17 +-
 .../cache/GridCacheVariableTopologySelfTest.java   |  17 +-
 .../cache/GridCacheVersionMultinodeTest.java       |  17 +-
 .../processors/cache/GridCacheVersionSelfTest.java |  17 +-
 .../cache/GridCacheVersionTopologyChangeTest.java  |  17 +-
 ...ataStorageConfigurationConsistencySelfTest.java |  29 ++-
 .../cache/GridEvictionPolicyMBeansTest.java        |  19 +-
 ...dLocalCacheStoreManagerDeserializationTest.java |  17 +-
 .../cache/GridLocalIgniteSerializationTest.java    |  17 +-
 ...ridProjectionForCachesOnDaemonNodeSelfTest.java |  17 +-
 .../processors/cache/H2CacheStoreStrategy.java     |  17 +-
 .../IgniteAbstractDynamicCacheStartFailTest.java   |  17 +-
 ...gniteAtomicCacheEntryProcessorNodeJoinTest.java |  17 +-
 .../cache/IgniteCacheAbstractStopBusySelfTest.java |  17 +-
 .../processors/cache/IgniteCacheAbstractTest.java  |  17 +-
 .../IgniteCacheAtomicCopyOnReadDisabledTest.java   |  17 +-
 .../cache/IgniteCacheAtomicInvokeTest.java         |  17 +-
 .../cache/IgniteCacheAtomicLocalInvokeTest.java    |  17 +-
 .../cache/IgniteCacheAtomicLocalPeekModesTest.java |  17 +-
 .../IgniteCacheAtomicLocalStoreValueTest.java      |  17 +-
 .../IgniteCacheAtomicLocalWithStoreInvokeTest.java |  17 +-
 .../IgniteCacheAtomicNearEnabledInvokeTest.java    |  17 +-
 ...IgniteCacheAtomicNearEnabledStoreValueTest.java |  17 +-
 .../cache/IgniteCacheAtomicNearPeekModesTest.java  |  17 +-
 .../cache/IgniteCacheAtomicPeekModesTest.java      |  17 +-
 .../IgniteCacheAtomicPutAllFailoverSelfTest.java   |  17 +-
 .../IgniteCacheAtomicReplicatedPeekModesTest.java  |  17 +-
 .../cache/IgniteCacheAtomicStopBusySelfTest.java   |  17 +-
 .../cache/IgniteCacheAtomicStoreValueTest.java     |  17 +-
 .../IgniteCacheAtomicWithStoreInvokeTest.java      |  17 +-
 .../IgniteCacheBinaryEntryProcessorSelfTest.java   |  17 +-
 .../IgniteCacheBinaryObjectsScanSelfTest.java      |  17 +-
 ...teCacheBinaryObjectsScanWithEventsSelfTest.java |  17 +-
 .../IgniteCacheConfigVariationsFullApiTest.java    |  17 +-
 ...gniteCacheConfigurationDefaultTemplateTest.java |  17 +-
 .../IgniteCacheConfigurationTemplateTest.java      |  17 +-
 .../IgniteCacheContainsKeyAbstractSelfTest.java    |  17 +-
 .../cache/IgniteCacheContainsKeyAtomicTest.java    |  17 +-
 .../IgniteCacheCopyOnReadDisabledAbstractTest.java |  17 +-
 .../cache/IgniteCacheCreateRestartSelfTest.java    |  17 +-
 .../cache/IgniteCacheDynamicStopSelfTest.java      |  17 +-
 .../IgniteCacheEntryListenerAbstractTest.java      |  17 +-
 .../IgniteCacheEntryListenerAtomicLocalTest.java   |  17 +-
 ...niteCacheEntryListenerAtomicReplicatedTest.java |  17 +-
 .../cache/IgniteCacheEntryListenerAtomicTest.java  |  17 +-
 ...niteCacheEntryListenerEagerTtlDisabledTest.java |  17 +-
 .../IgniteCacheEntryListenerExpiredEventsTest.java |  17 +-
 .../cache/IgniteCacheEntryListenerTxLocalTest.java |  17 +-
 .../IgniteCacheEntryListenerTxReplicatedTest.java  |  17 +-
 .../cache/IgniteCacheEntryListenerTxTest.java      |  17 +-
 .../cache/IgniteCacheEntryProcessorCallTest.java   |  17 +-
 .../IgniteCacheEntryProcessorNodeJoinTest.java     |  17 +-
 .../IgniteCacheExpireAndUpdateConsistencyTest.java |  17 +-
 .../IgniteCacheGetCustomCollectionsSelfTest.java   |  17 +-
 .../processors/cache/IgniteCacheGroupsTest.java    |  17 +-
 .../cache/IgniteCacheIncrementTxTest.java          |  17 +-
 .../cache/IgniteCacheInterceptorSelfTestSuite.java |  17 +-
 .../cache/IgniteCacheInvokeAbstractTest.java       |  17 +-
 .../IgniteCacheInvokeReadThroughAbstractTest.java  |  17 +-
 ...IgniteCacheInvokeReadThroughSingleNodeTest.java |  17 +-
 .../cache/IgniteCacheInvokeReadThroughTest.java    |  17 +-
 .../IgniteCacheLoadRebalanceEvictionSelfTest.java  |  17 +-
 .../cache/IgniteCacheManyAsyncOperationsTest.java  |  17 +-
 .../cache/IgniteCacheMvccTxInvokeTest.java         |  17 +-
 .../IgniteCacheMvccTxNearEnabledInvokeTest.java    |  17 +-
 .../cache/IgniteCacheNearLockValueSelfTest.java    |  17 +-
 .../cache/IgniteCacheNoSyncForGetTest.java         |  17 +-
 .../cache/IgniteCacheObjectPutSelfTest.java        |  17 +-
 .../IgniteCacheP2pUnmarshallingErrorTest.java      |  27 ++-
 .../IgniteCacheP2pUnmarshallingNearErrorTest.java  |  27 ++-
 ...iteCacheP2pUnmarshallingRebalanceErrorTest.java |  27 ++-
 .../IgniteCacheP2pUnmarshallingTxErrorTest.java    |  27 ++-
 .../cache/IgniteCachePartitionMapUpdateTest.java   |  17 +-
 .../cache/IgniteCachePeekModesAbstractTest.java    |  17 +-
 .../cache/IgniteCachePutAllRestartTest.java        |  17 +-
 .../cache/IgniteCachePutStackOverflowSelfTest.java |  17 +-
 .../IgniteCacheReadThroughEvictionSelfTest.java    |  17 +-
 ...teCacheReadThroughEvictionsVariationsSuite.java |  17 +-
 .../cache/IgniteCacheReadThroughStoreCallTest.java |  17 +-
 ...IgniteCacheScanPredicateDeploymentSelfTest.java |  17 +-
 .../cache/IgniteCacheSerializationSelfTest.java    |  17 +-
 .../cache/IgniteCacheStartStopLoadTest.java        |  17 +-
 .../processors/cache/IgniteCacheStartTest.java     |  17 +-
 .../cache/IgniteCacheStoreCollectionTest.java      |  17 +-
 .../cache/IgniteCacheStoreValueAbstractTest.java   |  17 +-
 .../IgniteCacheTransactionalStopBusySelfTest.java  |  17 +-
 .../cache/IgniteCacheTxCopyOnReadDisabledTest.java |  17 +-
 .../processors/cache/IgniteCacheTxInvokeTest.java  |  17 +-
 .../cache/IgniteCacheTxLocalInvokeTest.java        |  17 +-
 .../cache/IgniteCacheTxLocalPeekModesTest.java     |  17 +-
 .../cache/IgniteCacheTxLocalStoreValueTest.java    |  17 +-
 .../cache/IgniteCacheTxNearEnabledInvokeTest.java  |  17 +-
 .../IgniteCacheTxNearEnabledStoreValueTest.java    |  17 +-
 .../cache/IgniteCacheTxNearPeekModesTest.java      |  17 +-
 .../cache/IgniteCacheTxPeekModesTest.java          |  17 +-
 .../cache/IgniteCacheTxPreloadNoWriteTest.java     |  17 +-
 .../IgniteCacheTxReplicatedPeekModesTest.java      |  17 +-
 .../cache/IgniteCacheTxStoreValueTest.java         |  17 +-
 .../cache/IgniteCachingProviderSelfTest.java       |  17 +-
 .../IgniteClientAffinityAssignmentSelfTest.java    |  17 +-
 .../IgniteClientCacheInitializationFailTest.java   |  17 +-
 .../cache/IgniteClientCacheStartFailoverTest.java  |  17 +-
 .../cache/IgniteClusterActivateDeactivateTest.java |  17 +-
 ...usterActivateDeactivateTestWithPersistence.java |  17 +-
 ...eactivateTestWithPersistenceAndMemoryReuse.java |  17 +-
 .../cache/IgniteDaemonNodeMarshallerCacheTest.java |  17 +-
 .../IgniteDiscoDataHandlingInNewClusterTest.java   |  17 +-
 .../cache/IgniteDynamicCacheAndNodeStop.java       |  17 +-
 .../cache/IgniteDynamicCacheFilterTest.java        |  17 +-
 .../cache/IgniteDynamicCacheMultinodeTest.java     |  17 +-
 ...teDynamicCacheStartCoordinatorFailoverTest.java |  17 +-
 .../cache/IgniteDynamicCacheStartFailTest.java     |  17 +-
 ...teDynamicCacheStartFailWithPersistenceTest.java |  17 +-
 ...niteDynamicCacheStartNoExchangeTimeoutTest.java |  17 +-
 .../cache/IgniteDynamicCacheStartSelfTest.java     |  17 +-
 .../IgniteDynamicCacheStartStopConcurrentTest.java |  17 +-
 .../IgniteDynamicCacheWithConfigStartSelfTest.java |  17 +-
 .../IgniteDynamicClientCacheStartSelfTest.java     |  17 +-
 .../cache/IgniteExchangeFutureHistoryTest.java     |  27 ++-
 .../IgniteGetNonPlainKeyReadThroughSelfTest.java   |  17 +-
 .../cache/IgniteIncompleteCacheObjectSelfTest.java |  17 +-
 .../cache/IgniteInternalCacheTypesTest.java        |  17 +-
 ...IgniteMarshallerCacheClassNameConflictTest.java |  17 +-
 ...hallerCacheClientRequestsMappingOnMissTest.java |  17 +-
 ...niteMarshallerCacheConcurrentReadWriteTest.java |  17 +-
 .../cache/IgniteMarshallerCacheFSRestoreTest.java  |  17 +-
 .../IgniteMvccTxMultiThreadedAbstractTest.java     |  17 +-
 .../IgniteMvccTxSingleThreadedAbstractTest.java    |  17 +-
 .../cache/IgniteNearClientCacheCloseTest.java      |  17 +-
 .../cache/IgniteOnePhaseCommitInvokeTest.java      |  17 +-
 .../cache/IgniteOnePhaseCommitNearReadersTest.java |  17 +-
 .../cache/IgniteOnePhaseCommitNearSelfTest.java    |  17 +-
 .../cache/IgniteOutOfMemoryPropagationTest.java    |  17 +-
 .../cache/IgnitePdsDataRegionMetricsTxTest.java    |  17 +-
 .../cache/IgnitePutAllLargeBatchSelfTest.java      |  17 +-
 ...ePutAllUpdateNonPreloadedPartitionSelfTest.java |  17 +-
 ...gniteStartCacheInTransactionAtomicSelfTest.java |  17 +-
 .../IgniteStartCacheInTransactionSelfTest.java     |  17 +-
 .../cache/IgniteStaticCacheStartSelfTest.java      |  17 +-
 .../cache/IgniteSystemCacheOnClientTest.java       |  17 +-
 .../IgniteTopologyValidatorAbstractCacheTest.java  |  17 +-
 ...TopologyValidatorAbstractTxCacheGroupsTest.java |  27 ++-
 ...IgniteTopologyValidatorAbstractTxCacheTest.java |  27 ++-
 ...teTopologyValidatorCacheGroupsAbstractTest.java |  17 +-
 .../IgniteTopologyValidatorGridSplitCacheTest.java |  17 +-
 ...idatorNearPartitionedAtomicCacheGroupsTest.java |  27 ++-
 ...ogyValidatorNearPartitionedAtomicCacheTest.java |  27 ++-
 ...yValidatorNearPartitionedTxCacheGroupsTest.java |  27 ++-
 ...opologyValidatorNearPartitionedTxCacheTest.java |  27 ++-
 ...yValidatorPartitionedAtomicCacheGroupsTest.java |  27 ++-
 ...opologyValidatorPartitionedAtomicCacheTest.java |  27 ++-
 ...ologyValidatorPartitionedTxCacheGroupsTest.java |  27 ++-
 ...iteTopologyValidatorPartitionedTxCacheTest.java |  27 ++-
 ...gyValidatorReplicatedAtomicCacheGroupsTest.java |  27 ++-
 ...TopologyValidatorReplicatedAtomicCacheTest.java |  27 ++-
 ...pologyValidatorReplicatedTxCacheGroupsTest.java |  27 ++-
 ...niteTopologyValidatorReplicatedTxCacheTest.java |  27 ++-
 .../processors/cache/IgniteTxAbstractTest.java     |  17 +-
 .../cache/IgniteTxConcurrentGetAbstractTest.java   |  17 +-
 .../cache/IgniteTxConfigCacheSelfTest.java         |  17 +-
 .../cache/IgniteTxExceptionAbstractSelfTest.java   |  17 +-
 .../cache/IgniteTxMultiNodeAbstractTest.java       |  17 +-
 .../cache/IgniteTxMultiThreadedAbstractTest.java   |  17 +-
 .../cache/IgniteTxReentryAbstractSelfTest.java     |  17 +-
 .../cache/IgniteTxSingleThreadedAbstractTest.java  |  17 +-
 .../IgniteTxStoreExceptionAbstractSelfTest.java    |  17 +-
 ...nterceptorCacheConfigVariationsFullApiTest.java |  17 +-
 .../InterceptorWithKeepBinaryCacheFullApiTest.java |  17 +-
 .../processors/cache/MapCacheStoreStrategy.java    |  17 +-
 .../MarshallerCacheJobRunNodeRestartTest.java      |  17 +-
 .../cache/MemoryPolicyConfigValidationTest.java    |  17 +-
 .../cache/MvccCacheGroupMetricsMBeanTest.java      |  17 +-
 ...NonAffinityCoordinatorDynamicStartStopTest.java |  29 ++-
 ...OffheapCacheMetricsForClusterGroupSelfTest.java |  17 +-
 ...PartitionedAtomicCacheGetsDistributionTest.java |  17 +-
 ...MvccTxPessimisticCacheGetsDistributionTest.java |  17 +-
 ...ctionalOptimisticCacheGetsDistributionTest.java |  17 +-
 ...tionalPessimisticCacheGetsDistributionTest.java |  17 +-
 .../PartitionsExchangeCoordinatorFailoverTest.java |  17 +-
 ...ionsExchangeOnDiscoveryHistoryOverflowTest.java |  17 +-
 .../RebalanceWithDifferentThreadPoolSizeTest.java  |  17 +-
 .../ReplicatedAtomicCacheGetsDistributionTest.java |  17 +-
 ...MvccTxPessimisticCacheGetsDistributionTest.java |  17 +-
 ...ctionalOptimisticCacheGetsDistributionTest.java |  17 +-
 ...tionalPessimisticCacheGetsDistributionTest.java |  17 +-
 .../SetTxTimeoutOnPartitionMapExchangeTest.java    |  17 +-
 .../processors/cache/TestCacheStoreStrategy.java   |  17 +-
 .../cache/WalModeChangeAbstractSelfTest.java       |  27 ++-
 .../cache/WalModeChangeAdvancedSelfTest.java       |  27 ++-
 .../cache/WalModeChangeCommonAbstractSelfTest.java |  27 ++-
 ...deChangeCoordinatorNotAffinityNodeSelfTest.java |  27 ++-
 .../processors/cache/WalModeChangeSelfTest.java    |  27 ++-
 .../cache/WithKeepBinaryCacheFullApiTest.java      |  17 +-
 .../BinaryAtomicCacheLocalEntriesSelfTest.java     |  17 +-
 .../binary/BinaryMetadataUpdatesFlowTest.java      |  17 +-
 .../binary/BinaryTxCacheLocalEntriesSelfTest.java  |  17 +-
 .../binary/CacheKeepBinaryWithInterceptorTest.java |  17 +-
 .../GridBinaryCacheEntryMemorySizeSelfTest.java    |  17 +-
 ...naryAtomicEntryProcessorDeploymentSelfTest.java |  27 ++-
 ...eBinaryObjectMetadataExchangeMultinodeTest.java |  17 +-
 ...idCacheBinaryObjectUserClassloaderSelfTest.java |  17 +-
 ...eBinaryObjectsAbstractDataStreamerSelfTest.java |  17 +-
 ...BinaryObjectsAbstractMultiThreadedSelfTest.java |  17 +-
 .../GridCacheBinaryObjectsAbstractSelfTest.java    |  17 +-
 .../GridCacheBinaryStoreAbstractSelfTest.java      |  17 +-
 ...eBinaryStoreBinariesDefaultMappersSelfTest.java |  17 +-
 ...naryStoreBinariesSimpleNameMappersSelfTest.java |  17 +-
 .../GridCacheBinaryStoreObjectsSelfTest.java       |  17 +-
 ...nsactionalEntryProcessorDeploymentSelfTest.java |  27 ++-
 ...lientNodeBinaryObjectMetadataMultinodeTest.java |  17 +-
 ...ridCacheClientNodeBinaryObjectMetadataTest.java |  17 +-
 .../DataStreamProcessorBinarySelfTest.java         |  17 +-
 ...taStreamProcessorPersistenceBinarySelfTest.java |  17 +-
 .../GridDataStreamerImplSelfTest.java              |  17 +-
 .../GridCacheAffinityRoutingBinarySelfTest.java    |  17 +-
 ...nedOnlyBinaryDataStreamerMultiNodeSelfTest.java |  17 +-
 ...nlyBinaryDataStreamerMultithreadedSelfTest.java |  17 +-
 ...omicPartitionedOnlyBinaryMultiNodeSelfTest.java |  17 +-
 ...PartitionedOnlyBinaryMultithreadedSelfTest.java |  17 +-
 ...riesNearPartitionedByteArrayValuesSelfTest.java |  17 +-
 ...riesPartitionedOnlyByteArrayValuesSelfTest.java |  17 +-
 ...aryObjectsAtomicNearDisabledOnheapSelfTest.java |  17 +-
 ...cheBinaryObjectsAtomicNearDisabledSelfTest.java |  17 +-
 ...GridCacheBinaryObjectsAtomicOnheapSelfTest.java |  17 +-
 .../dht/GridCacheBinaryObjectsAtomicSelfTest.java  |  17 +-
 ...jectsPartitionedNearDisabledOnheapSelfTest.java |  17 +-
 ...naryObjectsPartitionedNearDisabledSelfTest.java |  17 +-
 ...acheBinaryObjectsPartitionedOnheapSelfTest.java |  17 +-
 .../GridCacheBinaryObjectsPartitionedSelfTest.java |  17 +-
 .../GridCacheBinaryObjectsReplicatedSelfTest.java  |  17 +-
 .../GridCacheBinaryObjectsAtomicLocalSelfTest.java |  17 +-
 .../GridCacheBinaryObjectsLocalOnheapSelfTest.java |  18 +-
 .../local/GridCacheBinaryObjectsLocalSelfTest.java |  17 +-
 .../IgniteCacheAbstractExecutionContextTest.java   |  17 +-
 .../IgniteCacheAtomicExecutionContextTest.java     |  17 +-
 .../IgniteCacheContinuousExecutionContextTest.java |  17 +-
 .../IgniteCacheIsolatedExecutionContextTest.java   |  17 +-
 .../IgniteCacheP2PDisableExecutionContextTest.java |  17 +-
 .../IgniteCachePrivateExecutionContextTest.java    |  17 +-
 .../IgniteCacheReplicatedExecutionContextTest.java |  17 +-
 .../IgniteCacheSharedExecutionContextTest.java     |  17 +-
 .../context/IgniteCacheTxExecutionContextTest.java |  17 +-
 ...acheAbstractDataStructuresFailoverSelfTest.java |  17 +-
 ...stractQueueFailoverDataConsistencySelfTest.java |  17 +-
 ...ridCacheAtomicReferenceApiSelfAbstractTest.java |  17 +-
 ...dCacheAtomicReferenceMultiNodeAbstractTest.java |  17 +-
 .../GridCacheAtomicStampedApiSelfAbstractTest.java |  17 +-
 .../GridCacheMultiNodeDataStructureTest.java       |  17 +-
 .../GridCacheQueueApiSelfAbstractTest.java         |  17 +-
 .../GridCacheQueueCleanupSelfTest.java             |  17 +-
 .../GridCacheQueueClientDisconnectTest.java        |  17 +-
 .../GridCacheQueueJoinedNodeSelfAbstractTest.java  |  17 +-
 .../GridCacheQueueMultiNodeAbstractSelfTest.java   |  17 +-
 ...GridCacheQueueMultiNodeConsistencySelfTest.java |  17 +-
 ...ridCacheQueueRotativeMultiNodeAbstractTest.java |  17 +-
 .../GridCacheSequenceApiSelfAbstractTest.java      |  17 +-
 ...GridCacheSequenceMultiNodeAbstractSelfTest.java |  17 +-
 .../GridCacheSetAbstractSelfTest.java              |  17 +-
 .../GridCacheSetFailoverAbstractSelfTest.java      |  17 +-
 .../IgniteAtomicLongApiAbstractSelfTest.java       |  17 +-
 .../datastructures/IgniteAtomicsAbstractTest.java  |  17 +-
 .../IgniteClientDataStructuresAbstractTest.java    |  17 +-
 .../IgniteClientDataStructuresTest.java            |  17 +-
 .../IgniteClientDiscoveryDataStructuresTest.java   |  17 +-
 .../IgniteCollectionAbstractTest.java              |  17 +-
 .../IgniteCountDownLatchAbstractSelfTest.java      |  17 +-
 .../IgniteDataStructureUniqueNameTest.java         |  17 +-
 .../IgniteDataStructureWithJobTest.java            |  17 +-
 .../IgniteDataStructuresNoClassOnServerTest.java   |  17 +-
 ...iteExchangeLatchManagerCoordinatorFailTest.java |  17 +-
 .../datastructures/IgniteLockAbstractSelfTest.java |  17 +-
 .../IgniteSemaphoreAbstractSelfTest.java           |  17 +-
 .../IgniteSequenceInternalCleanupTest.java         |  17 +-
 .../SemaphoreFailoverNoWaitingAcquirerTest.java    |  17 +-
 .../SemaphoreFailoverSafeReleasePermitsTest.java   |  17 +-
 .../GridCacheLocalAtomicQueueApiSelfTest.java      |  17 +-
 .../local/GridCacheLocalAtomicSetSelfTest.java     |  17 +-
 .../local/GridCacheLocalQueueApiSelfTest.java      |  17 +-
 .../local/GridCacheLocalSequenceApiSelfTest.java   |  17 +-
 .../local/GridCacheLocalSetSelfTest.java           |  17 +-
 .../local/IgniteLocalAtomicLongApiSelfTest.java    |  17 +-
 .../local/IgniteLocalCountDownLatchSelfTest.java   |  17 +-
 .../local/IgniteLocalLockSelfTest.java             |  17 +-
 .../local/IgniteLocalSemaphoreSelfTest.java        |  17 +-
 ...GridCachePartitionedAtomicQueueApiSelfTest.java |  17 +-
 ...titionedAtomicQueueCreateMultiNodeSelfTest.java |  17 +-
 ...AtomicQueueFailoverDataConsistencySelfTest.java |  17 +-
 ...chePartitionedAtomicQueueMultiNodeSelfTest.java |  17 +-
 ...artitionedAtomicQueueRotativeMultiNodeTest.java |  17 +-
 ...CachePartitionedAtomicReferenceApiSelfTest.java |  17 +-
 ...chePartitionedAtomicReferenceMultiNodeTest.java |  17 +-
 ...PartitionedAtomicSequenceMultiThreadedTest.java |  17 +-
 ...idCachePartitionedAtomicSequenceTxSelfTest.java |  17 +-
 ...dCachePartitionedAtomicSetFailoverSelfTest.java |  17 +-
 .../GridCachePartitionedAtomicSetSelfTest.java     |  17 +-
 ...idCachePartitionedAtomicStampedApiSelfTest.java |  17 +-
 ...ePartitionedDataStructuresFailoverSelfTest.java |  17 +-
 .../GridCachePartitionedNodeRestartTxSelfTest.java |  17 +-
 .../GridCachePartitionedQueueApiSelfTest.java      |  17 +-
 ...chePartitionedQueueCreateMultiNodeSelfTest.java |  17 +-
 ...GridCachePartitionedQueueEntryMoveSelfTest.java |  17 +-
 ...tionedQueueFailoverDataConsistencySelfTest.java |  17 +-
 ...ridCachePartitionedQueueJoinedNodeSelfTest.java |  17 +-
 ...GridCachePartitionedQueueMultiNodeSelfTest.java |  17 +-
 ...CachePartitionedQueueRotativeMultiNodeTest.java |  17 +-
 .../GridCachePartitionedSequenceApiSelfTest.java   |  17 +-
 ...dCachePartitionedSequenceMultiNodeSelfTest.java |  17 +-
 .../GridCachePartitionedSetFailoverSelfTest.java   |  17 +-
 .../GridCachePartitionedSetSelfTest.java           |  17 +-
 .../GridCachePartitionedSetWithClientSelfTest.java |  17 +-
 ...dCachePartitionedSetWithNodeFilterSelfTest.java |  17 +-
 .../IgnitePartitionedAtomicLongApiSelfTest.java    |  17 +-
 .../IgnitePartitionedCountDownLatchSelfTest.java   |  17 +-
 .../partitioned/IgnitePartitionedLockSelfTest.java |  17 +-
 .../IgnitePartitionedQueueNoBackupsTest.java       |  17 +-
 .../IgnitePartitionedSemaphoreSelfTest.java        |  17 +-
 .../IgnitePartitionedSetNoBackupsSelfTest.java     |  17 +-
 ...dCacheReplicatedAtomicReferenceApiSelfTest.java |  17 +-
 ...acheReplicatedAtomicReferenceMultiNodeTest.java |  17 +-
 ...ridCacheReplicatedAtomicStampedApiSelfTest.java |  17 +-
 ...heReplicatedDataStructuresFailoverSelfTest.java |  17 +-
 .../GridCacheReplicatedQueueApiSelfTest.java       |  17 +-
 .../GridCacheReplicatedQueueMultiNodeSelfTest.java |  17 +-
 ...dCacheReplicatedQueueRotativeMultiNodeTest.java |  17 +-
 .../GridCacheReplicatedSequenceApiSelfTest.java    |  17 +-
 ...idCacheReplicatedSequenceMultiNodeSelfTest.java |  17 +-
 .../replicated/GridCacheReplicatedSetSelfTest.java |  17 +-
 .../GridCacheReplicatedSetWithClientSelfTest.java  |  17 +-
 ...idCacheReplicatedSetWithNodeFilterSelfTest.java |  17 +-
 .../IgniteReplicatedAtomicLongApiSelfTest.java     |  17 +-
 .../IgniteReplicatedCountDownLatchSelfTest.java    |  17 +-
 .../replicated/IgniteReplicatedLockSelfTest.java   |  17 +-
 .../IgniteReplicatedSemaphoreSelfTest.java         |  17 +-
 .../cache/distributed/Cache64kPartitionsTest.java  |  17 +-
 .../distributed/CacheAbstractRestartSelfTest.java  |  29 ++-
 .../cache/distributed/CacheAffinityEarlyTest.java  |  17 +-
 .../CacheAsyncOperationsFailoverAbstractTest.java  |  17 +-
 .../CacheAsyncOperationsFailoverAtomicTest.java    |  17 +-
 .../CacheAsyncOperationsFailoverTxTest.java        |  17 +-
 .../distributed/CacheAsyncOperationsTest.java      |  17 +-
 .../CacheAtomicNearUpdateTopologyChangeTest.java   |  17 +-
 .../CacheAtomicPrimarySyncBackPressureTest.java    |  17 +-
 .../distributed/CacheBaselineTopologyTest.java     |  18 +-
 .../cache/distributed/CacheBlockOnGetAllTest.java  |  17 +-
 .../distributed/CacheBlockOnReadAbstractTest.java  |  17 +-
 .../cache/distributed/CacheBlockOnScanTest.java    |  17 +-
 .../distributed/CacheBlockOnSingleGetTest.java     |  17 +-
 .../CacheClientsConcurrentStartTest.java           |  17 +-
 .../CacheDataLossOnPartitionMoveTest.java          |  17 +-
 .../CacheDiscoveryDataConcurrentJoinTest.java      |  17 +-
 .../cache/distributed/CacheExchangeMergeTest.java  |  17 +-
 .../distributed/CacheGetFutureHangsSelfTest.java   |  17 +-
 .../CacheGetInsideLockChangingTopologyTest.java    |  17 +-
 .../cache/distributed/CacheGroupsPreloadTest.java  |  17 +-
 ...teAffinityAssignmentNodeJoinValidationTest.java |  17 +-
 .../CacheLateAffinityAssignmentTest.java           |  17 +-
 .../CacheLoadingConcurrentGridStartSelfTest.java   |  17 +-
 ...gConcurrentGridStartSelfTestAllowOverwrite.java |  17 +-
 .../distributed/CacheLockChangingTopologyTest.java |  17 +-
 .../distributed/CacheLockReleaseNodeLeaveTest.java |  17 +-
 ...cheNearDisabledAtomicInvokeRestartSelfTest.java |  17 +-
 ...DisabledTransactionalInvokeRestartSelfTest.java |  17 +-
 ...abledTransactionalWriteReadRestartSelfTest.java |  17 +-
 .../CacheNoValueClassOnServerNodeTest.java         |  17 +-
 .../distributed/CacheOperationsInterruptTest.java  |  17 +-
 .../distributed/CachePageWriteLockUnlockTest.java  |  17 +-
 .../cache/distributed/CacheParallelStartTest.java  |  17 +-
 .../cache/distributed/CachePartitionStateTest.java |  17 +-
 .../CachePutAllFailoverAbstractTest.java           |  17 +-
 .../distributed/CachePutAllFailoverAtomicTest.java |  17 +-
 .../distributed/CachePutAllFailoverTxTest.java     |  17 +-
 .../distributed/CacheRentingStateRepairTest.java   |  17 +-
 .../CacheResultIsNotNullOnPartitionLossTest.java   |  17 +-
 .../cache/distributed/CacheStartOnJoinTest.java    |  17 +-
 .../distributed/CacheTryLockMultithreadedTest.java |  17 +-
 ...gConcurrentGridStartSelfTestAllowOverwrite.java |  17 +-
 .../CacheTxNearUpdateTopologyChangeTest.java       |  17 +-
 .../ExchangeMergeStaleServerNodesTest.java         |  17 +-
 ...AbstractDistributedByteArrayValuesSelfTest.java |  17 +-
 .../GridCacheAbstractJobExecutionTest.java         |  17 +-
 .../GridCacheAbstractNodeRestartSelfTest.java      |  17 +-
 ...AbstractPartitionedByteArrayValuesSelfTest.java |  17 +-
 .../GridCacheAbstractPrimarySyncSelfTest.java      |  17 +-
 .../distributed/GridCacheBasicOpAbstractTest.java  |  17 +-
 .../GridCacheClientModesAbstractSelfTest.java      |  17 +-
 ...eClientModesTcpClientDiscoveryAbstractTest.java |  17 +-
 .../GridCacheEntrySetAbstractSelfTest.java         |  17 +-
 ...idCacheEntrySetIterationPreloadingSelfTest.java |  17 +-
 .../distributed/GridCacheEventAbstractTest.java    |  17 +-
 .../distributed/GridCacheLockAbstractTest.java     |  17 +-
 .../distributed/GridCacheMixedModeSelfTest.java    |  17 +-
 .../GridCacheModuloAffinityFunction.java           |  17 +-
 .../GridCacheMultiNodeAbstractTest.java            |  17 +-
 .../GridCacheMultiNodeLockAbstractTest.java        |  17 +-
 ...GridCacheMultithreadedFailoverAbstractTest.java |  17 +-
 .../GridCacheNodeFailureAbstractTest.java          |  17 +-
 ...PartitionEvictionDuringReadThroughSelfTest.java |  17 +-
 .../GridCachePartitionNotLoadedEventSelfTest.java  |  17 +-
 ...nedNearDisabledMvccTxMultiThreadedSelfTest.java |  17 +-
 ...itionedNearDisabledTxMultiThreadedSelfTest.java |  17 +-
 ...dCachePartitionedReloadAllAbstractSelfTest.java |  17 +-
 .../GridCachePreloadEventsAbstractSelfTest.java    |  17 +-
 .../GridCachePreloadLifecycleAbstractTest.java     |  17 +-
 .../GridCachePreloadRestartAbstractSelfTest.java   |  17 +-
 .../GridCacheTransformEventSelfTest.java           |  17 +-
 ...naryMetadataUpdateChangingTopologySelfTest.java |  17 +-
 .../IgniteBinaryMetadataUpdateNodeRestartTest.java |  17 +-
 .../distributed/IgniteCache150ClientsTest.java     |  17 +-
 ...acheAtomicMessageRecovery10ConnectionsTest.java |  17 +-
 ...AtomicMessageRecoveryPairedConnectionsTest.java |  17 +-
 .../IgniteCacheAtomicMessageRecoveryTest.java      |  17 +-
 .../distributed/IgniteCacheAtomicNodeJoinTest.java |  17 +-
 .../IgniteCacheAtomicNodeRestartTest.java          |  17 +-
 ...CacheClientMultiNodeUpdateTopologyLockTest.java |  17 +-
 .../IgniteCacheClientNodeChangingTopologyTest.java |  17 +-
 .../IgniteCacheClientNodeConcurrentStart.java      |  17 +-
 ...gniteCacheClientNodePartitionsExchangeTest.java |  17 +-
 .../IgniteCacheClientReconnectTest.java            |  17 +-
 ...teCacheConnectionRecovery10ConnectionsTest.java |  17 +-
 .../IgniteCacheConnectionRecoveryTest.java         |  17 +-
 .../IgniteCacheCreatePutMultiNodeSelfTest.java     |  17 +-
 .../distributed/IgniteCacheCreatePutTest.java      |  17 +-
 .../IgniteCacheFailedUpdateResponseTest.java       |  17 +-
 .../distributed/IgniteCacheGetRestartTest.java     |  17 +-
 ...niteCacheGroupsPartitionLossPolicySelfTest.java |  17 +-
 .../distributed/IgniteCacheManyClientsTest.java    |  17 +-
 .../IgniteCacheMessageRecoveryAbstractTest.java    |  17 +-
 ...niteCacheMessageRecoveryIdleConnectionTest.java |  17 +-
 .../IgniteCacheMessageWriteTimeoutTest.java        |  17 +-
 .../IgniteCacheNearRestartRollbackSelfTest.java    |  17 +-
 .../IgniteCacheNodeJoinAbstractTest.java           |  17 +-
 .../IgniteCachePartitionLossPolicySelfTest.java    |  17 +-
 .../distributed/IgniteCachePrimarySyncTest.java    |  17 +-
 .../IgniteCachePutGetRestartAbstractTest.java      |  17 +-
 .../distributed/IgniteCacheReadFromBackupTest.java |  17 +-
 .../IgniteCacheServerNodeConcurrentStart.java      |  17 +-
 .../IgniteCacheSingleGetMessageTest.java           |  17 +-
 .../distributed/IgniteCacheSizeFailoverTest.java   |  17 +-
 .../IgniteCacheSystemTransactionsSelfTest.java     |  17 +-
 .../distributed/IgniteCacheThreadLocalTxTest.java  |  17 +-
 .../distributed/IgniteCacheTxIteratorSelfTest.java |  17 +-
 .../IgniteCacheTxMessageRecoveryTest.java          |  17 +-
 ...IgniteCacheTxNearDisabledPutGetRestartTest.java |  17 +-
 .../distributed/IgniteCacheTxNodeJoinTest.java     |  17 +-
 .../IgniteCrossCacheTxStoreSelfTest.java           |  17 +-
 .../IgniteMvccTxTimeoutAbstractTest.java           |  17 +-
 .../IgniteNoClassOnServerAbstractTest.java         |  17 +-
 .../IgniteOptimisticTxSuspendResumeTest.java       |  17 +-
 .../IgnitePessimisticTxSuspendResumeTest.java      |  17 +-
 .../IgniteRejectConnectOnNodeStopTest.java         |  17 +-
 .../distributed/IgniteTxCachePrimarySyncTest.java  |  17 +-
 ...WriteSynchronizationModesMultithreadedTest.java |  17 +-
 .../IgniteTxConcurrentRemoveObjectsTest.java       |  17 +-
 ...IgniteTxConsistencyRestartAbstractSelfTest.java |  17 +-
 .../distributed/IgniteTxGetAfterStopTest.java      |  17 +-
 ...teTxOriginatingNodeFailureAbstractSelfTest.java |  17 +-
 ...sticOriginatingNodeFailureAbstractSelfTest.java |  17 +-
 .../distributed/IgniteTxPreloadAbstractTest.java   |  17 +-
 .../IgniteTxRemoveTimeoutObjectsNearTest.java      |  17 +-
 .../IgniteTxRemoveTimeoutObjectsTest.java          |  17 +-
 .../distributed/IgniteTxTimeoutAbstractTest.java   |  17 +-
 .../distributed/TestCacheNodeExcludingFilter.java  |  17 +-
 .../dht/CacheGetReadFromBackupFailoverTest.java    |  17 +-
 .../CachePartitionPartialCountersMapSelfTest.java  |  17 +-
 ...ractPartitionedOnlyByteArrayValuesSelfTest.java |  17 +-
 ...CacheAbstractTransformWriteThroughSelfTest.java |  17 +-
 .../dht/GridCacheAtomicFullApiSelfTest.java        |  17 +-
 .../dht/GridCacheAtomicNearCacheSelfTest.java      |  17 +-
 .../GridCacheAtomicNearEnabledFullApiSelfTest.java |  17 +-
 .../dht/GridCacheAtomicReloadAllSelfTest.java      |  17 +-
 .../dht/GridCacheClientOnlySelfTest.java           |  17 +-
 .../dht/GridCacheColocatedDebugTest.java           |  17 +-
 .../dht/GridCacheColocatedFailoverSelfTest.java    |  17 +-
 ...CacheColocatedMvccTxSingleThreadedSelfTest.java |  17 +-
 ...acheColocatedOptimisticTransactionSelfTest.java |  17 +-
 .../GridCacheColocatedPreloadRestartSelfTest.java  |  17 +-
 .../dht/GridCacheColocatedPrimarySyncSelfTest.java |  17 +-
 .../dht/GridCacheColocatedReloadAllSelfTest.java   |  17 +-
 .../dht/GridCacheColocatedTxExceptionSelfTest.java |  17 +-
 ...xPessimisticOriginatingNodeFailureSelfTest.java |  17 +-
 ...GridCacheColocatedTxSingleThreadedSelfTest.java |  17 +-
 .../GridCacheDaemonNodePartitionedSelfTest.java    |  17 +-
 ...dCacheDhtAtomicEvictionNearReadersSelfTest.java |  17 +-
 .../dht/GridCacheDhtAtomicRemoveFailureTest.java   |  17 +-
 .../dht/GridCacheDhtClientRemoveFailureTest.java   |  17 +-
 .../distributed/dht/GridCacheDhtEntrySelfTest.java |  17 +-
 .../dht/GridCacheDhtEntrySetSelfTest.java          |  17 +-
 .../GridCacheDhtEvictionNearReadersSelfTest.java   |  17 +-
 .../dht/GridCacheDhtEvictionsDisabledSelfTest.java |  17 +-
 .../dht/GridCacheDhtMappingSelfTest.java           |  17 +-
 .../dht/GridCacheDhtMultiBackupTest.java           |  17 +-
 .../dht/GridCacheDhtPreloadBigDataSelfTest.java    |  17 +-
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java    |  17 +-
 .../dht/GridCacheDhtPreloadDisabledSelfTest.java   |  17 +-
 .../dht/GridCacheDhtPreloadMessageCountTest.java   |  17 +-
 .../GridCacheDhtPreloadMultiThreadedSelfTest.java  |  17 +-
 .../dht/GridCacheDhtPreloadOnheapSelfTest.java     |  18 +-
 .../dht/GridCacheDhtPreloadPerformanceTest.java    |  17 +-
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java     |  17 +-
 .../dht/GridCacheDhtPreloadSelfTest.java           |  17 +-
 .../dht/GridCacheDhtPreloadStartStopSelfTest.java  |  17 +-
 .../dht/GridCacheDhtPreloadUnloadSelfTest.java     |  17 +-
 .../dht/GridCacheDhtRemoveFailureTest.java         |  17 +-
 .../dht/GridCacheDhtTxPreloadSelfTest.java         |  17 +-
 .../distributed/dht/GridCacheGlobalLoadTest.java   |  17 +-
 ...nedNearDisabledAtomicOnheapFullApiSelfTest.java |  18 +-
 ...sabledAtomicOnheapMultiNodeFullApiSelfTest.java |  18 +-
 ...achePartitionedNearDisabledFullApiSelfTest.java |  17 +-
 ...idCachePartitionedNearDisabledLockSelfTest.java |  17 +-
 ...achePartitionedNearDisabledMetricsSelfTest.java |  17 +-
 ...tionedNearDisabledMultiNodeFullApiSelfTest.java |  17 +-
 ...isabledMultiNodeP2PDisabledFullApiSelfTest.java |  17 +-
 ...rDisabledMultiNodeWithGroupFullApiSelfTest.java |  17 +-
 ...rtitionedNearDisabledOnheapFullApiSelfTest.java |  18 +-
 ...NearDisabledOnheapMultiNodeFullApiSelfTest.java |  18 +-
 ...nedNearDisabledOptimisticTxNodeRestartTest.java |  17 +-
 ...arDisabledTxOriginatingNodeFailureSelfTest.java |  17 +-
 ...onedOnlyP2PDisabledByteArrayValuesSelfTest.java |  17 +-
 ...ionedOnlyP2PEnabledByteArrayValuesSelfTest.java |  17 +-
 .../GridCachePartitionedSupplyEventsSelfTest.java  |  17 +-
 ...GridCachePartitionedTopologyChangeSelfTest.java |  17 +-
 ...edTransformWriteThroughBatchUpdateSelfTest.java |  17 +-
 ...artitionedTxOriginatingNodeFailureSelfTest.java |  17 +-
 .../GridCachePartitionedUnloadEventsSelfTest.java  |  17 +-
 .../GridCachePartitionsStateValidationTest.java    |  17 +-
 .../GridCachePartitionsStateValidatorSelfTest.java |  17 +-
 .../dht/GridCacheTxNodeFailureSelfTest.java        |  17 +-
 .../IgniteAtomicLongChangingTopologySelfTest.java  |  17 +-
 .../dht/IgniteCacheClearDuringRebalanceTest.java   |  17 +-
 .../dht/IgniteCacheCommitDelayTxRecoveryTest.java  |  17 +-
 .../dht/IgniteCacheConcurrentPutGetRemove.java     |  17 +-
 .../IgniteCacheContainsKeyColocatedSelfTest.java   |  17 +-
 .../dht/IgniteCacheCrossCacheTxFailoverTest.java   |  17 +-
 .../dht/IgniteCacheLockFailoverSelfTest.java       |  17 +-
 .../dht/IgniteCacheMultiTxLockSelfTest.java        |  17 +-
 ...hePartitionedBackupNodeFailureRecoveryTest.java |  29 ++-
 ...NearDisabledPrimaryNodeFailureRecoveryTest.java |  17 +-
 ...ePartitionedPrimaryNodeFailureRecoveryTest.java |  17 +-
 ...edTwoBackupsPrimaryNodeFailureRecoveryTest.java |  17 +-
 ...achePrimaryNodeFailureRecoveryAbstractTest.java |  17 +-
 .../dht/IgniteCachePutRetryAbstractSelfTest.java   |  17 +-
 .../dht/IgniteCachePutRetryAtomicSelfTest.java     |  17 +-
 .../IgniteCachePutRetryTransactionalSelfTest.java  |  17 +-
 .../dht/IgniteCacheStartWithLoadTest.java          |  17 +-
 .../dht/IgniteCacheTopologySplitAbstractTest.java  |  17 +-
 .../dht/IgniteCacheTxRecoveryRollbackTest.java     |  17 +-
 .../dht/IgniteCrossCacheMvccTxSelfTest.java        |  17 +-
 .../dht/IgniteCrossCacheTxAbstractSelfTest.java    |  17 +-
 .../dht/IgniteCrossCacheTxNearEnabledSelfTest.java |  17 +-
 .../dht/IgniteCrossCacheTxSelfTest.java            |  17 +-
 ...gniteTxConsistencyColocatedRestartSelfTest.java |  17 +-
 .../dht/IgniteTxReentryColocatedSelfTest.java      |  17 +-
 .../dht/NotMappedPartitionInTxTest.java            |  17 +-
 .../dht/TxRecoveryStoreEnabledTest.java            |  17 +-
 .../atomic/AtomicPutAllChangingTopologyTest.java   |  17 +-
 ...omicClientInvalidPartitionHandlingSelfTest.java |  17 +-
 .../GridCacheAtomicClientRemoveFailureTest.java    |  17 +-
 .../atomic/GridCacheAtomicFailoverSelfTest.java    |  17 +-
 ...acheAtomicInvalidPartitionHandlingSelfTest.java |  17 +-
 .../dht/atomic/GridCacheAtomicPreloadSelfTest.java |  17 +-
 .../atomic/GridCacheAtomicRemoveFailureTest.java   |  17 +-
 .../GridCacheAtomicReplicatedFailoverSelfTest.java |  17 +-
 ...eValueConsistencyAtomicNearEnabledSelfTest.java |  17 +-
 .../GridCacheValueConsistencyAtomicSelfTest.java   |  17 +-
 .../dht/atomic/IgniteCacheAtomicProtocolTest.java  |  17 +-
 ...iteCacheContainsKeyColocatedAtomicSelfTest.java |  17 +-
 .../IgniteCacheContainsKeyNearAtomicSelfTest.java  |  17 +-
 ...titionedMultiNodeLongTxTimeout2FullApiTest.java |  17 +-
 ...rtitionedMultiNodeLongTxTimeoutFullApiTest.java |  17 +-
 ...arEnabledMultiNodeLongTxTimeoutFullApiTest.java |  17 +-
 ...ractNearPartitionedByteArrayValuesSelfTest.java |  17 +-
 ...heAtomicClientOnlyMultiNodeFullApiSelfTest.java |  17 +-
 ...entOnlyMultiNodeP2PDisabledFullApiSelfTest.java |  17 +-
 ...CopyOnReadDisabledMultiNodeFullApiSelfTest.java |  17 +-
 .../GridCacheAtomicMultiNodeFullApiSelfTest.java   |  17 +-
 ...eAtomicMultiNodeP2PDisabledFullApiSelfTest.java |  17 +-
 ...cheAtomicMultiNodeWithGroupFullApiSelfTest.java |  17 +-
 ...eAtomicNearEnabledMultiNodeFullApiSelfTest.java |  17 +-
 ...arEnabledMultiNodeWithGroupFullApiSelfTest.java |  17 +-
 .../GridCacheAtomicNearEvictionEventSelfTest.java  |  17 +-
 .../near/GridCacheAtomicNearEvictionSelfTest.java  |  17 +-
 .../near/GridCacheAtomicNearMultiNodeSelfTest.java |  17 +-
 ...acheAtomicNearOnlyMultiNodeFullApiSelfTest.java |  17 +-
 ...earOnlyMultiNodeP2PDisabledFullApiSelfTest.java |  17 +-
 .../near/GridCacheAtomicNearReadersSelfTest.java   |  17 +-
 .../near/GridCacheAtomicNearRemoveFailureTest.java |  17 +-
 .../near/GridCacheAtomicOnheapFullApiSelfTest.java |  18 +-
 ...dCacheAtomicOnheapMultiNodeFullApiSelfTest.java |  18 +-
 .../GridCacheAtomicPartitionedMetricsSelfTest.java |  17 +-
 ...cheAtomicPartitionedTckMetricsSelfTestImpl.java |  17 +-
 .../near/GridCacheGetStoreErrorSelfTest.java       |  17 +-
 .../near/GridCacheMvccNearEvictionSelfTest.java    |  17 +-
 .../near/GridCacheNearAtomicMetricsSelfTest.java   |  17 +-
 .../near/GridCacheNearClientHitTest.java           |  17 +-
 .../near/GridCacheNearEvictionEventSelfTest.java   |  17 +-
 .../near/GridCacheNearEvictionSelfTest.java        |  17 +-
 .../near/GridCacheNearJobExecutionSelfTest.java    |  17 +-
 .../near/GridCacheNearMetricsSelfTest.java         |  17 +-
 .../near/GridCacheNearMultiGetSelfTest.java        |  17 +-
 .../near/GridCacheNearMultiNodeSelfTest.java       |  17 +-
 .../near/GridCacheNearOneNodeSelfTest.java         |  17 +-
 .../GridCacheNearOnlyMultiNodeFullApiSelfTest.java |  17 +-
 ...earOnlyMultiNodeP2PDisabledFullApiSelfTest.java |  17 +-
 .../near/GridCacheNearOnlySelfTest.java            |  17 +-
 .../near/GridCacheNearOnlyTopologySelfTest.java    |  17 +-
 .../GridCacheNearPartitionedClearSelfTest.java     |  17 +-
 ...titionedP2PDisabledByteArrayValuesSelfTest.java |  17 +-
 ...rtitionedP2PEnabledByteArrayValuesSelfTest.java |  17 +-
 .../near/GridCacheNearPreloadRestartSelfTest.java  |  17 +-
 .../near/GridCacheNearPrimarySyncSelfTest.java     |  17 +-
 .../near/GridCacheNearReaderPreloadSelfTest.java   |  17 +-
 .../near/GridCacheNearReadersSelfTest.java         |  17 +-
 .../near/GridCacheNearReloadAllSelfTest.java       |  17 +-
 .../near/GridCacheNearRemoveFailureTest.java       |  17 +-
 .../near/GridCacheNearTxExceptionSelfTest.java     |  17 +-
 .../near/GridCacheNearTxForceKeyTest.java          |  17 +-
 .../near/GridCacheNearTxMultiNodeSelfTest.java     |  17 +-
 ...xPessimisticOriginatingNodeFailureSelfTest.java |  17 +-
 .../near/GridCacheNearTxPreloadSelfTest.java       |  17 +-
 ...nedAffinityExcludeNeighborsPerformanceTest.java |  17 +-
 .../near/GridCachePartitionedAffinitySelfTest.java |  17 +-
 ...titionedAtomicGetAndTransformStoreSelfTest.java |  17 +-
 ...achePartitionedAtomicOnheapFullApiSelfTest.java |  18 +-
 ...tionedAtomicOnheapMultiNodeFullApiSelfTest.java |  18 +-
 .../near/GridCachePartitionedBasicApiTest.java     |  17 +-
 .../near/GridCachePartitionedBasicOpSelfTest.java  |  17 +-
 ...achePartitionedBasicStoreMultiNodeSelfTest.java |  17 +-
 .../GridCachePartitionedBasicStoreSelfTest.java    |  17 +-
 ...titionedClientOnlyNoPrimaryFullApiSelfTest.java |  17 +-
 ...CopyOnReadDisabledMultiNodeFullApiSelfTest.java |  17 +-
 .../GridCachePartitionedEntryLockSelfTest.java     |  17 +-
 .../near/GridCachePartitionedEventSelfTest.java    |  17 +-
 .../near/GridCachePartitionedEvictionSelfTest.java |  17 +-
 ...PartitionedExplicitLockNodeFailureSelfTest.java |  17 +-
 .../near/GridCachePartitionedFailoverSelfTest.java |  17 +-
 .../GridCachePartitionedFilteredPutSelfTest.java   |  17 +-
 ...chePartitionedFullApiMultithreadedSelfTest.java |  17 +-
 .../near/GridCachePartitionedFullApiSelfTest.java  |  17 +-
 ...chePartitionedGetAndTransformStoreSelfTest.java |  17 +-
 .../GridCachePartitionedHitsAndMissesSelfTest.java |  17 +-
 .../GridCachePartitionedIteratorsSelfTest.java     |  17 +-
 .../GridCachePartitionedLoadCacheSelfTest.java     |  17 +-
 .../near/GridCachePartitionedLockSelfTest.java     |  17 +-
 .../near/GridCachePartitionedMetricsSelfTest.java  |  17 +-
 ...idCachePartitionedMultiNodeCounterSelfTest.java |  17 +-
 ...idCachePartitionedMultiNodeFullApiSelfTest.java |  17 +-
 .../GridCachePartitionedMultiNodeLockSelfTest.java |  17 +-
 ...itionedMultiNodeP2PDisabledFullApiSelfTest.java |  17 +-
 .../GridCachePartitionedMultiNodeSelfTest.java     |  17 +-
 ...rtitionedMultiNodeWithGroupFullApiSelfTest.java |  17 +-
 ...achePartitionedMultiThreadedPutGetSelfTest.java |  17 +-
 ...achePartitionedMvccTxMultiThreadedSelfTest.java |  17 +-
 ...chePartitionedMvccTxSingleThreadedSelfTest.java |  17 +-
 .../GridCachePartitionedMvccTxTimeoutSelfTest.java |  17 +-
 ...nedNearDisabledBasicStoreMultiNodeSelfTest.java |  17 +-
 ...artitionedNearOnlyNoPrimaryFullApiSelfTest.java |  17 +-
 .../near/GridCachePartitionedNestedTxTest.java     |  17 +-
 .../GridCachePartitionedNodeFailureSelfTest.java   |  17 +-
 .../near/GridCachePartitionedNodeRestartTest.java  |  17 +-
 .../GridCachePartitionedOnheapFullApiSelfTest.java |  18 +-
 ...ePartitionedOnheapMultiNodeFullApiSelfTest.java |  18 +-
 ...achePartitionedOptimisticTxNodeRestartTest.java |  17 +-
 ...idCachePartitionedPreloadLifecycleSelfTest.java |  17 +-
 .../near/GridCachePartitionedStorePutSelfTest.java |  17 +-
 .../GridCachePartitionedTxConcurrentGetTest.java   |  17 +-
 .../GridCachePartitionedTxMultiNodeSelfTest.java   |  17 +-
 ...ridCachePartitionedTxMultiThreadedSelfTest.java |  17 +-
 .../near/GridCachePartitionedTxReadTest.java       |  17 +-
 .../GridCachePartitionedTxSalvageSelfTest.java     |  17 +-
 ...idCachePartitionedTxSingleThreadedSelfTest.java |  17 +-
 .../GridCachePartitionedTxTimeoutSelfTest.java     |  17 +-
 .../near/GridCachePutArrayValueSelfTest.java       |  17 +-
 .../GridCacheRendezvousAffinityClientSelfTest.java |  17 +-
 .../near/GridNearCacheStoreUpdateTest.java         |  17 +-
 .../near/GridPartitionedBackupLoadSelfTest.java    |  17 +-
 .../near/IgniteCacheContainsKeyNearSelfTest.java   |  17 +-
 .../near/IgniteCacheNearOnlyTxTest.java            |  17 +-
 .../near/IgniteCacheNearReadCommittedTest.java     |  17 +-
 .../near/IgniteCacheNearTxRollbackTest.java        |  17 +-
 .../near/IgniteTxReentryNearSelfTest.java          |  17 +-
 .../near/NearCacheMultithreadedUpdateTest.java     |  17 +-
 .../near/NearCachePutAllMultinodeTest.java         |  17 +-
 .../distributed/near/NearCacheSyncUpdateTest.java  |  17 +-
 .../near/NoneRebalanceModeSelfTest.java            |  17 +-
 .../rebalancing/CacheManualRebalancingTest.java    |  17 +-
 .../rebalancing/CacheNodeSafeAssertion.java        |  17 +-
 ...lancingDelayedPartitionMapExchangeSelfTest.java |  27 ++-
 .../GridCacheRebalancingAsyncSelfTest.java         |  27 ++-
 .../GridCacheRebalancingCancelTest.java            |  27 ++-
 .../GridCacheRebalancingOrderingTest.java          |  27 ++-
 ...dCacheRebalancingPartitionCountersMvccTest.java |  17 +-
 .../GridCacheRebalancingPartitionCountersTest.java |  17 +-
 ...dCacheRebalancingPartitionDistributionTest.java |  17 +-
 .../GridCacheRebalancingSyncCheckDataTest.java     |  17 +-
 .../GridCacheRebalancingSyncSelfTest.java          |  27 ++-
 ...acheRebalancingUnmarshallingFailedSelfTest.java |  27 ++-
 ...dCacheRebalancingWithAsyncClearingMvccTest.java |  17 +-
 .../GridCacheRebalancingWithAsyncClearingTest.java |  27 ++-
 ...eRebalanceOnCachesStoppingOrDestroyingTest.java |  17 +-
 ...tyExcludeNeighborsMultiNodeFullApiSelfTest.java |  17 +-
 ...RendezvousAffinityMultiNodeFullApiSelfTest.java |  17 +-
 ...eAbstractReplicatedByteArrayValuesSelfTest.java |  17 +-
 .../GridCacheAtomicReplicatedMetricsSelfTest.java  |  17 +-
 .../GridCacheDaemonNodeReplicatedSelfTest.java     |  17 +-
 .../GridCacheReplicatedAtomicFullApiSelfTest.java  |  17 +-
 ...plicatedAtomicGetAndTransformStoreSelfTest.java |  17 +-
 ...heReplicatedAtomicMultiNodeFullApiSelfTest.java |  17 +-
 .../GridCacheReplicatedBasicApiTest.java           |  17 +-
 .../GridCacheReplicatedBasicOpSelfTest.java        |  17 +-
 .../GridCacheReplicatedBasicStoreSelfTest.java     |  17 +-
 .../GridCacheReplicatedEntrySetSelfTest.java       |  17 +-
 .../GridCacheReplicatedEventDisabledSelfTest.java  |  17 +-
 .../GridCacheReplicatedEventSelfTest.java          |  17 +-
 .../GridCacheReplicatedEvictionEventSelfTest.java  |  17 +-
 .../GridCacheReplicatedFailoverSelfTest.java       |  17 +-
 ...acheReplicatedFullApiMultithreadedSelfTest.java |  17 +-
 .../GridCacheReplicatedFullApiSelfTest.java        |  17 +-
 ...acheReplicatedGetAndTransformStoreSelfTest.java |  17 +-
 .../GridCacheReplicatedIteratorsSelfTest.java      |  17 +-
 .../GridCacheReplicatedJobExecutionTest.java       |  17 +-
 .../GridCacheReplicatedLockSelfTest.java           |  17 +-
 .../GridCacheReplicatedMarshallerTxTest.java       |  17 +-
 .../GridCacheReplicatedMetricsSelfTest.java        |  17 +-
 ...ridCacheReplicatedMultiNodeFullApiSelfTest.java |  17 +-
 .../GridCacheReplicatedMultiNodeLockSelfTest.java  |  17 +-
 ...licatedMultiNodeP2PDisabledFullApiSelfTest.java |  17 +-
 .../GridCacheReplicatedMultiNodeSelfTest.java      |  17 +-
 ...CacheReplicatedMvccTxMultiThreadedSelfTest.java |  17 +-
 ...acheReplicatedMvccTxSingleThreadedSelfTest.java |  17 +-
 .../GridCacheReplicatedMvccTxTimeoutSelfTest.java  |  17 +-
 ...ReplicatedNearOnlyMultiNodeFullApiSelfTest.java |  17 +-
 .../GridCacheReplicatedNodeFailureSelfTest.java    |  17 +-
 .../GridCacheReplicatedNodeRestartSelfTest.java    |  17 +-
 .../GridCacheReplicatedOnheapFullApiSelfTest.java  |  18 +-
 ...heReplicatedOnheapMultiNodeFullApiSelfTest.java |  18 +-
 ...plicatedP2PDisabledByteArrayValuesSelfTest.java |  17 +-
 ...eplicatedP2PEnabledByteArrayValuesSelfTest.java |  17 +-
 .../GridCacheReplicatedPreloadEventsSelfTest.java  |  17 +-
 .../GridCacheReplicatedTxConcurrentGetTest.java    |  17 +-
 .../GridCacheReplicatedTxExceptionSelfTest.java    |  17 +-
 .../GridCacheReplicatedTxMultiNodeBasicTest.java   |  17 +-
 ...GridCacheReplicatedTxMultiThreadedSelfTest.java |  17 +-
 ...ReplicatedTxOriginatingNodeFailureSelfTest.java |  17 +-
 ...xPessimisticOriginatingNodeFailureSelfTest.java |  17 +-
 .../replicated/GridCacheReplicatedTxReadTest.java  |  17 +-
 ...ridCacheReplicatedTxSingleThreadedSelfTest.java |  17 +-
 .../GridCacheReplicatedTxTimeoutSelfTest.java      |  17 +-
 .../GridCacheSyncReplicatedPreloadSelfTest.java    |  17 +-
 .../replicated/GridReplicatedTxPreloadTest.java    |  17 +-
 ...teCacheAtomicReplicatedNodeRestartSelfTest.java |  17 +-
 .../IgniteCacheSyncRebalanceModeSelfTest.java      |  17 +-
 ...ridCacheReplicatedPreloadLifecycleSelfTest.java |  17 +-
 .../GridCacheReplicatedPreloadSelfTest.java        |  17 +-
 ...heReplicatedPreloadStartStopEventsSelfTest.java |  17 +-
 .../GridCacheReplicatedPreloadUndeploysTest.java   |  17 +-
 .../cache/eviction/DhtAndNearEvictionTest.java     |  17 +-
 .../cache/eviction/EvictionAbstractTest.java       |  17 +-
 .../EvictionPolicyFactoryAbstractTest.java         |  17 +-
 ...CacheConcurrentEvictionConsistencySelfTest.java |  17 +-
 .../GridCacheConcurrentEvictionsSelfTest.java      |  17 +-
 .../GridCacheEmptyEntriesAbstractSelfTest.java     |  17 +-
 .../GridCacheEmptyEntriesLocalSelfTest.java        |  17 +-
 .../GridCacheEmptyEntriesPartitionedSelfTest.java  |  17 +-
 .../GridCacheEvictableEntryEqualsSelfTest.java     |  17 +-
 .../eviction/GridCacheEvictionFilterSelfTest.java  |  17 +-
 .../GridCacheEvictionLockUnlockSelfTest.java       |  17 +-
 .../eviction/GridCacheEvictionTouchSelfTest.java   |  17 +-
 .../cache/eviction/GridCacheMockEntry.java         |  17 +-
 .../fifo/FifoEvictionPolicyFactorySelfTest.java    |  17 +-
 .../eviction/fifo/FifoEvictionPolicySelfTest.java  |  17 +-
 .../lru/LruEvictionPolicyFactorySelfTest.java      |  17 +-
 .../eviction/lru/LruEvictionPolicySelfTest.java    |  17 +-
 .../lru/LruNearEvictionPolicySelfTest.java         |  17 +-
 .../lru/LruNearOnlyNearEvictionPolicySelfTest.java |  17 +-
 .../eviction/paged/PageEvictionAbstractTest.java   |  29 ++-
 .../paged/PageEvictionDataStreamerTest.java        |  29 ++-
 .../eviction/paged/PageEvictionMetricTest.java     |  29 ++-
 .../paged/PageEvictionMultinodeAbstractTest.java   |  29 ++-
 .../PageEvictionMultinodeMixedRegionsTest.java     |  17 +-
 .../PageEvictionPagesRecyclingAndReusingTest.java  |  17 +-
 .../paged/PageEvictionReadThroughTest.java         |  29 ++-
 .../eviction/paged/PageEvictionTouchOrderTest.java |  29 ++-
 .../PageEvictionWithRebalanceAbstractTest.java     |  29 ++-
 ...om2LruNearEnabledPageEvictionMultinodeTest.java |  17 +-
 .../paged/Random2LruPageEvictionMultinodeTest.java |  29 ++-
 .../Random2LruPageEvictionWithRebalanceTest.java   |  29 ++-
 ...domLruNearEnabledPageEvictionMultinodeTest.java |  17 +-
 .../paged/RandomLruPageEvictionMultinodeTest.java  |  29 ++-
 .../RandomLruPageEvictionWithRebalanceTest.java    |  29 ++-
 .../cache/eviction/paged/TestObject.java           |  29 ++-
 .../SortedEvictionPolicyFactorySelfTest.java       |  17 +-
 .../SortedEvictionPolicyPerformanceTest.java       |  17 +-
 .../sorted/SortedEvictionPolicySelfTest.java       |  17 +-
 .../expiry/IgniteCacheAtomicExpiryPolicyTest.java  |  17 +-
 ...IgniteCacheAtomicExpiryPolicyWithStoreTest.java |  17 +-
 .../IgniteCacheAtomicLocalExpiryPolicyTest.java    |  17 +-
 ...niteCacheAtomicLocalOnheapExpiryPolicyTest.java |  18 +-
 .../IgniteCacheAtomicOnheapExpiryPolicyTest.java   |  18 +-
 ...gniteCacheAtomicReplicatedExpiryPolicyTest.java |  17 +-
 ...IgniteCacheAtomicWithStoreExpiryPolicyTest.java |  17 +-
 .../IgniteCacheClientNearCacheExpiryTest.java      |  17 +-
 .../IgniteCacheExpireWhileRebalanceTest.java       |  17 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java       |  17 +-
 .../expiry/IgniteCacheExpiryPolicyTestSuite.java   |  17 +-
 ...niteCacheExpiryPolicyWithStoreAbstractTest.java |  17 +-
 .../expiry/IgniteCacheLargeValueExpireTest.java    |  17 +-
 ...niteCacheOnlyOneTtlCleanupThreadExistsTest.java |  17 +-
 .../expiry/IgniteCacheTxExpiryPolicyTest.java      |  17 +-
 .../IgniteCacheTxExpiryPolicyWithStoreTest.java    |  17 +-
 .../expiry/IgniteCacheTxLocalExpiryPolicyTest.java |  17 +-
 .../IgniteCacheTxReplicatedExpiryPolicyTest.java   |  17 +-
 .../IgniteCacheTxWithStoreExpiryPolicyTest.java    |  17 +-
 .../integration/IgniteCacheAtomicLoadAllTest.java  |  17 +-
 .../IgniteCacheAtomicLoaderWriterTest.java         |  17 +-
 .../IgniteCacheAtomicLocalLoadAllTest.java         |  17 +-
 ...iteCacheAtomicLocalNoLoadPreviousValueTest.java |  17 +-
 .../IgniteCacheAtomicLocalNoReadThroughTest.java   |  17 +-
 .../IgniteCacheAtomicLocalNoWriteThroughTest.java  |  17 +-
 ...heAtomicNearEnabledNoLoadPreviousValueTest.java |  17 +-
 ...iteCacheAtomicNearEnabledNoReadThroughTest.java |  17 +-
 ...teCacheAtomicNearEnabledNoWriteThroughTest.java |  17 +-
 .../IgniteCacheAtomicNoLoadPreviousValueTest.java  |  17 +-
 .../IgniteCacheAtomicNoReadThroughTest.java        |  17 +-
 .../IgniteCacheAtomicNoWriteThroughTest.java       |  17 +-
 .../IgniteCacheAtomicStoreSessionTest.java         |  17 +-
 ...niteCacheAtomicStoreSessionWriteBehindTest.java |  17 +-
 .../IgniteCacheJdbcBlobStoreNodeRestartTest.java   |  17 +-
 .../IgniteCacheLoadAllAbstractTest.java            |  17 +-
 .../IgniteCacheLoaderWriterAbstractTest.java       |  17 +-
 ...IgniteCacheNoLoadPreviousValueAbstractTest.java |  17 +-
 .../IgniteCacheNoReadThroughAbstractTest.java      |  17 +-
 .../IgniteCacheNoWriteThroughAbstractTest.java     |  17 +-
 .../IgniteCacheStoreNodeRestartAbstractTest.java   |  17 +-
 .../IgniteCacheStoreSessionAbstractTest.java       |  17 +-
 ...teCacheStoreSessionWriteBehindAbstractTest.java |  17 +-
 .../integration/IgniteCacheTxLoadAllTest.java      |  17 +-
 .../integration/IgniteCacheTxLoaderWriterTest.java |  17 +-
 .../integration/IgniteCacheTxLocalLoadAllTest.java |  17 +-
 .../IgniteCacheTxLocalNoLoadPreviousValueTest.java |  17 +-
 .../IgniteCacheTxLocalNoReadThroughTest.java       |  17 +-
 .../IgniteCacheTxLocalNoWriteThroughTest.java      |  17 +-
 ...eCacheTxNearEnabledNoLoadPreviousValueTest.java |  17 +-
 .../IgniteCacheTxNearEnabledNoReadThroughTest.java |  17 +-
 ...IgniteCacheTxNearEnabledNoWriteThroughTest.java |  17 +-
 .../IgniteCacheTxNoLoadPreviousValueTest.java      |  17 +-
 .../IgniteCacheTxNoReadThroughTest.java            |  17 +-
 .../IgniteCacheTxNoWriteThroughTest.java           |  17 +-
 .../integration/IgniteCacheTxStoreSessionTest.java |  17 +-
 ...cheTxStoreSessionWriteBehindCoalescingTest.java |  17 +-
 .../IgniteCacheTxStoreSessionWriteBehindTest.java  |  17 +-
 ...GridCacheAtomicLocalMetricsNoStoreSelfTest.java |  17 +-
 .../local/GridCacheAtomicLocalMetricsSelfTest.java |  17 +-
 ...GridCacheAtomicLocalTckMetricsSelfTestImpl.java |  17 +-
 .../local/GridCacheDaemonNodeLocalSelfTest.java    |  17 +-
 .../GridCacheLocalAtomicBasicStoreSelfTest.java    |  17 +-
 .../local/GridCacheLocalAtomicFullApiSelfTest.java |  17 +-
 ...cheLocalAtomicGetAndTransformStoreSelfTest.java |  17 +-
 ...cheLocalAtomicMetricsNoReadThroughSelfTest.java |  17 +-
 ...idCacheLocalAtomicWithGroupFullApiSelfTest.java |  17 +-
 .../local/GridCacheLocalBasicApiSelfTest.java      |  17 +-
 ...dCacheLocalBasicStoreMultithreadedSelfTest.java |  17 +-
 .../local/GridCacheLocalBasicStoreSelfTest.java    |  17 +-
 .../GridCacheLocalByteArrayValuesSelfTest.java     |  17 +-
 .../cache/local/GridCacheLocalEventSelfTest.java   |  17 +-
 .../local/GridCacheLocalEvictionEventSelfTest.java |  17 +-
 ...GridCacheLocalFullApiMultithreadedSelfTest.java |  17 +-
 .../cache/local/GridCacheLocalFullApiSelfTest.java |  17 +-
 ...GridCacheLocalGetAndTransformStoreSelfTest.java |  17 +-
 .../local/GridCacheLocalIsolatedNodesSelfTest.java |  17 +-
 .../local/GridCacheLocalIteratorsSelfTest.java     |  17 +-
 .../cache/local/GridCacheLocalLoadAllSelfTest.java |  17 +-
 .../cache/local/GridCacheLocalLockSelfTest.java    |  17 +-
 .../cache/local/GridCacheLocalMetricsSelfTest.java |  17 +-
 .../local/GridCacheLocalMultithreadedSelfTest.java |  17 +-
 .../local/GridCacheLocalTxExceptionSelfTest.java   |  17 +-
 .../GridCacheLocalTxMultiThreadedSelfTest.java     |  17 +-
 .../cache/local/GridCacheLocalTxReadTest.java      |  17 +-
 .../GridCacheLocalTxSingleThreadedSelfTest.java    |  17 +-
 .../local/GridCacheLocalTxTimeoutSelfTest.java     |  17 +-
 .../GridCacheLocalWithGroupFullApiSelfTest.java    |  17 +-
 ...cheAtomicClientOnlyMultiJvmFullApiSelfTest.java |  17 +-
 ...ientOnlyMultiJvmP2PDisabledFullApiSelfTest.java |  17 +-
 ...cCopyOnReadDisabledMultiJvmFullApiSelfTest.java |  17 +-
 .../GridCacheAtomicMultiJvmFullApiSelfTest.java    |  17 +-
 ...heAtomicMultiJvmP2PDisabledFullApiSelfTest.java |  17 +-
 ...heAtomicNearEnabledMultiJvmFullApiSelfTest.java |  17 +-
 ...CacheAtomicNearOnlyMultiJvmFullApiSelfTest.java |  17 +-
 ...NearOnlyMultiJvmP2PDisabledFullApiSelfTest.java |  17 +-
 ...idCacheAtomicOnheapMultiJvmFullApiSelfTest.java |  18 +-
 .../GridCacheNearOnlyMultiJvmFullApiSelfTest.java  |  17 +-
 ...NearOnlyMultiJvmP2PDisabledFullApiSelfTest.java |  17 +-
 ...dCopyOnReadDisabledMultiJvmFullApiSelfTest.java |  17 +-
 ...ridCachePartitionedMultiJvmFullApiSelfTest.java |  17 +-
 ...titionedMultiJvmP2PDisabledFullApiSelfTest.java |  17 +-
 ...isabledAtomicOnheapMultiJvmFullApiSelfTest.java |  18 +-
 ...itionedNearDisabledMultiJvmFullApiSelfTest.java |  17 +-
 ...DisabledMultiJvmP2PDisabledFullApiSelfTest.java |  17 +-
 ...dNearDisabledOnheapMultiJvmFullApiSelfTest.java |  18 +-
 ...hePartitionedOnheapMultiJvmFullApiSelfTest.java |  18 +-
 ...cheReplicatedAtomicMultiJvmFullApiSelfTest.java |  17 +-
 ...GridCacheReplicatedMultiJvmFullApiSelfTest.java |  17 +-
 ...plicatedMultiJvmP2PDisabledFullApiSelfTest.java |  17 +-
 ...eReplicatedNearOnlyMultiJvmFullApiSelfTest.java |  17 +-
 ...cheReplicatedOnheapMultiJvmFullApiSelfTest.java |  18 +-
 ...heMvccAbstractBasicCoordinatorFailoverTest.java |  17 +-
 .../CacheMvccAbstractCoordinatorFailoverTest.java  |  17 +-
 .../cache/mvcc/CacheMvccAbstractFeatureTest.java   |  17 +-
 .../cache/mvcc/CacheMvccAbstractTest.java          |  17 +-
 .../cache/mvcc/CacheMvccClientReconnectTest.java   |  17 +-
 .../cache/mvcc/CacheMvccClusterRestartTest.java    |  17 +-
 .../mvcc/CacheMvccConfigurationValidationTest.java |  17 +-
 ...eMvccIteratorWithConcurrentTransactionTest.java |  17 +-
 ...cLocalEntriesWithConcurrentTransactionTest.java |  17 +-
 .../cache/mvcc/CacheMvccOperationChecksTest.java   |  17 +-
 ...acheMvccPartitionedCoordinatorFailoverTest.java |  17 +-
 .../mvcc/CacheMvccProcessorLazyStartTest.java      |  17 +-
 .../cache/mvcc/CacheMvccProcessorTest.java         |  17 +-
 .../mvcc/CacheMvccRemoteTxOnNearNodeStartTest.java |  17 +-
 ...CacheMvccReplicatedCoordinatorFailoverTest.java |  17 +-
 ...MvccScanQueryWithConcurrentTransactionTest.java |  17 +-
 ...CacheMvccSizeWithConcurrentTransactionTest.java |  17 +-
 .../cache/mvcc/CacheMvccTransactionsTest.java      |  17 +-
 .../cache/mvcc/CacheMvccTxFailoverTest.java        |  17 +-
 .../processors/cache/mvcc/CacheMvccVacuumTest.java |  17 +-
 .../processors/cache/mvcc/MvccCachePeekTest.java   |  17 +-
 .../cache/mvcc/MvccUnsupportedTxModesTest.java     |  17 +-
 .../persistence/CheckpointReadLockFailureTest.java |  17 +-
 .../persistence/CleanupRestoredCachesSlowTest.java |  17 +-
 .../CommonPoolStarvationCheckpointTest.java        |  29 ++-
 .../processors/cache/persistence/DummyPageIO.java  |  17 +-
 ...niteBaselineAffinityTopologyActivationTest.java |  17 +-
 .../IgniteDataStorageMetricsSelfTest.java          |  17 +-
 ...itePdsAtomicCacheHistoricalRebalancingTest.java |  17 +-
 .../IgnitePdsAtomicCacheRebalancingTest.java       |  17 +-
 ...gnitePdsBinaryMetadataOnClusterRestartTest.java |  17 +-
 .../IgnitePdsBinarySortObjectFieldsTest.java       |  17 +-
 .../IgnitePdsCacheAssignmentNodeRestartsTest.java  |  17 +-
 ...CacheConfigurationFileConsistencyCheckTest.java |  17 +-
 ...sCacheObjectBinaryProcessorOnDiscoveryTest.java |  17 +-
 .../IgnitePdsCacheRebalancingAbstractTest.java     |  17 +-
 ...itePdsCacheStartStopWithFreqCheckpointTest.java |  17 +-
 .../IgnitePdsClientNearCachePutGetTest.java        |  17 +-
 .../IgnitePdsContinuousRestartTest.java            |  17 +-
 ...tePdsContinuousRestartTestWithExpiryPolicy.java |  17 +-
 ...inuousRestartTestWithSharedGroupAndIndexes.java |  17 +-
 .../persistence/IgnitePdsCorruptedIndexTest.java   |  17 +-
 .../persistence/IgnitePdsCorruptedStoreTest.java   |  17 +-
 .../IgnitePdsDestroyCacheAbstractTest.java         |  17 +-
 .../persistence/IgnitePdsDestroyCacheTest.java     |  17 +-
 ...gnitePdsDestroyCacheWithoutCheckpointsTest.java |  17 +-
 ...IgnitePdsDiscoDataHandlingInNewClusterTest.java |  17 +-
 .../persistence/IgnitePdsDynamicCacheTest.java     |  17 +-
 .../IgnitePdsExchangeDuringCheckpointTest.java     |  17 +-
 ...PdsMarshallerMappingRestoreOnNodeStartTest.java |  17 +-
 .../IgnitePdsNoSpaceLeftOnDeviceTest.java          |  17 +-
 .../IgnitePdsNodeJoinWithCachesStopping.java       |  17 +-
 .../cache/persistence/IgnitePdsPageSizesTest.java  |  17 +-
 .../IgnitePdsPartitionFilesDestroyTest.java        |  17 +-
 .../IgnitePdsPartitionsStateRecoveryTest.java      |  17 +-
 .../IgnitePdsRecoveryAfterFileCorruptionTest.java  |  17 +-
 .../IgnitePdsRemoveDuringRebalancingTest.java      |  17 +-
 .../IgnitePdsSingleNodePutGetPersistenceTest.java  |  17 +-
 .../IgnitePdsSporadicDataRecordsOnBackupTest.java  |  17 +-
 .../persistence/IgnitePdsTaskCancelingTest.java    |  17 +-
 .../IgnitePdsTxCacheRebalancingTest.java           |  17 +-
 .../IgnitePdsTxHistoricalRebalancingTest.java      |  17 +-
 .../IgnitePersistenceSequentialCheckpointTest.java |  29 ++-
 .../IgnitePersistentStoreCacheGroupsTest.java      |  17 +-
 .../IgnitePersistentStoreDataStructuresTest.java   |  17 +-
 ...gniteRebalanceScheduleResendPartitionsTest.java |  17 +-
 ...ocalWalModeChangeDuringRebalancingSelfTest.java |  17 +-
 ...NoChangeDuringRebalanceOnNonNodeAssignTest.java |  17 +-
 .../MemoryPolicyInitializationTest.java            |  17 +-
 .../PersistenceDirectoryWarningLoggingTest.java    |  17 +-
 .../persistence/SingleNodePersistenceSslTest.java  |  17 +-
 .../ClientAffinityAssignmentWithBaselineTest.java  |  29 ++-
 .../baseline/ClusterActivationEventTest.java       |  17 +-
 .../IgniteAbsentEvictionNodeOutOfBaselineTest.java |  17 +-
 ...gniteAllBaselineNodesOnlineFullApiSelfTest.java |  17 +-
 .../IgniteBaselineAbstractFullApiSelfTest.java     |  17 +-
 ...hangingBaselineDownCachePutAllFailoverTest.java |  17 +-
 ...hangingBaselineDownCacheRemoveFailoverTest.java |  17 +-
 ...eChangingBaselineUpCachePutAllFailoverTest.java |  17 +-
 ...eChangingBaselineUpCacheRemoveFailoverTest.java |  17 +-
 .../IgniteOfflineBaselineNodeFullApiSelfTest.java  |  17 +-
 ...niteOnlineNodeOutOfBaselineFullApiSelfTest.java |  17 +-
 ...gniteStableBaselineCachePutAllFailoverTest.java |  17 +-
 ...gniteStableBaselineCacheRemoveFailoverTest.java |  17 +-
 .../db/CheckpointBufferDeadlockTest.java           |  29 ++-
 .../persistence/db/CheckpointFailingIoFactory.java |  17 +-
 .../persistence/db/IgniteLogicalRecoveryTest.java  |  17 +-
 .../persistence/db/IgnitePdsCacheRestoreTest.java  |  17 +-
 ...IgnitePdsCacheWalDisabledOnRebalancingTest.java |  17 +-
 .../db/IgnitePdsDataRegionMetricsTest.java         |  17 +-
 .../db/IgnitePdsMultiNodePutGetRestartTest.java    |  17 +-
 ...itePdsPageEvictionDuringPartitionClearTest.java |  17 +-
 .../persistence/db/IgnitePdsPageEvictionTest.java  |  17 +-
 .../db/IgnitePdsPartitionPreloadTest.java          |  17 +-
 ...gnitePdsRebalancingOnNotStableTopologyTest.java |  17 +-
 .../db/IgnitePdsReserveWalSegmentsTest.java        |  17 +-
 ...itePdsReserveWalSegmentsWithCompactionTest.java |  17 +-
 .../db/IgnitePdsStartWIthEmptyArchive.java         |  17 +-
 .../db/IgnitePdsTransactionsHangTest.java          |  17 +-
 .../db/IgnitePdsWholeClusterRestartTest.java       |  17 +-
 .../cache/persistence/db/IgnitePdsWithTtlTest.java |  17 +-
 .../persistence/db/IgnitePdsWithTtlTest2.java      |  17 +-
 .../db/IgniteSequentialNodeCrashRecoveryTest.java  |  17 +-
 .../IgniteShutdownOnSupplyMessageFailureTest.java  |  17 +-
 .../SlowHistoricalRebalanceSmallHistoryTest.java   |  29 ++-
 .../db/checkpoint/CheckpointFreeListTest.java      |  17 +-
 .../IgniteCheckpointDirtyPagesForLowLoadTest.java  |  17 +-
 .../db/checkpoint/IgniteMassLoadSandboxTest.java   |  17 +-
 .../db/checkpoint/ProgressWatchdog.java            |  17 +-
 .../DefaultPageSizeBackwardsCompatibilityTest.java |  29 ++-
 .../IgnitePdsCacheDestroyDuringCheckpointTest.java |  17 +-
 .../db/file/IgnitePdsCacheIntegrationTest.java     |  17 +-
 .../db/file/IgnitePdsCheckpointSimpleTest.java     |  17 +-
 ...CheckpointSimulationWithRealCpDisabledTest.java |  17 +-
 .../db/file/IgnitePdsDiskErrorsRecoveringTest.java |  17 +-
 .../db/file/IgnitePdsNoActualWalHistoryTest.java   |  17 +-
 .../db/file/IgnitePdsPageReplacementTest.java      |  17 +-
 .../db/file/IgnitePdsThreadInterruptionTest.java   |  17 +-
 .../IgniteUidAsConsistentIdMigrationTest.java      |  17 +-
 .../db/wal/FsyncWalRolloverDoesNotBlockTest.java   |  17 +-
 .../wal/IgniteNodeStoppedDuringDisableWALTest.java |  17 +-
 ...ailIsReachedDuringIterationOverArchiveTest.java |  17 +-
 .../db/wal/IgniteWalFlushBackgroundSelfTest.java   |  17 +-
 ...teWalFlushBackgroundWithMmapBufferSelfTest.java |  17 +-
 .../db/wal/IgniteWalFlushFailoverTest.java         |  17 +-
 .../db/wal/IgniteWalFlushFsyncSelfTest.java        |  17 +-
 ...teWalFlushFsyncWithDedicatedWorkerSelfTest.java |  17 +-
 .../IgniteWalFlushFsyncWithMmapBufferSelfTest.java |  17 +-
 .../db/wal/IgniteWalFlushLogOnlySelfTest.java      |  17 +-
 ...gniteWalFlushLogOnlyWithMmapBufferSelfTest.java |  17 +-
 ...eWalFlushMultiNodeFailoverAbstractSelfTest.java |  17 +-
 .../db/wal/IgniteWalFormatFileFailoverTest.java    |  17 +-
 .../db/wal/IgniteWalHistoryReservationsTest.java   |  17 +-
 .../IgniteWalIteratorExceptionDuringReadTest.java  |  17 +-
 .../db/wal/IgniteWalIteratorSwitchSegmentTest.java |  17 +-
 .../persistence/db/wal/IgniteWalRebalanceTest.java |  17 +-
 .../db/wal/IgniteWalRecoveryPPCTest.java           |  17 +-
 .../wal/IgniteWalRecoverySeveralRestartsTest.java  |  17 +-
 .../db/wal/IgniteWalSerializerVersionTest.java     |  17 +-
 .../db/wal/WalCompactionAfterRestartTest.java      |  29 ++-
 .../db/wal/WalCompactionSwitchOnTest.java          |  17 +-
 .../persistence/db/wal/WalCompactionTest.java      |  17 +-
 .../db/wal/WalDeletionArchiveAbstractTest.java     |  17 +-
 .../db/wal/WalDeletionArchiveFsyncTest.java        |  17 +-
 .../db/wal/WalDeletionArchiveLogOnlyTest.java      |  17 +-
 .../cache/persistence/db/wal/WalPathsTest.java     |  17 +-
 .../db/wal/WalRecoveryTxLogicalRecordsTest.java    |  17 +-
 .../db/wal/WalRolloverRecordLoggingFsyncTest.java  |  17 +-
 .../wal/WalRolloverRecordLoggingLogOnlyTest.java   |  17 +-
 .../db/wal/WalRolloverRecordLoggingTest.java       |  17 +-
 .../persistence/db/wal/WalRolloverTypesTest.java   |  29 ++-
 .../IgniteAbstractWalIteratorInvalidCrcTest.java   |  17 +-
 .../db/wal/crc/IgniteDataIntegrityTests.java       |  17 +-
 ...IgniteFsyncReplayWalIteratorInvalidCrcTest.java |  17 +-
 .../db/wal/crc/IgnitePureJavaCrcCompatibility.java |  17 +-
 .../crc/IgniteReplayWalIteratorInvalidCrcTest.java |  17 +-
 .../IgniteStandaloneWalIteratorInvalidCrcTest.java |  17 +-
 ...teWithoutArchiverWalIteratorInvalidCrcTest.java |  17 +-
 .../cache/persistence/db/wal/crc/WalTestUtils.java |  17 +-
 .../db/wal/reader/IgniteWalReaderTest.java         |  17 +-
 .../persistence/db/wal/reader/IndexedObject.java   |  17 +-
 .../db/wal/reader/MockWalIteratorFactory.java      |  17 +-
 .../cache/persistence/file/FileDownloaderTest.java |  17 +-
 .../metastorage/IgniteMetaStorageBasicTest.java    |  17 +-
 .../pagemem/BPlusTreePageMemoryImplTest.java       |  17 +-
 .../BPlusTreeReuseListPageMemoryImplTest.java      |  17 +-
 .../persistence/pagemem/FillFactorMetricTest.java  |  17 +-
 .../persistence/pagemem/FullPageIdTableTest.java   |  17 +-
 .../IgnitePageMemReplaceDelayedWriteUnitTest.java  |  17 +-
 .../pagemem/IgniteThrottlingUnitTest.java          |  17 +-
 .../pagemem/IndexStoragePageMemoryImplTest.java    |  17 +-
 .../persistence/pagemem/NoOpPageStoreManager.java  |  17 +-
 .../cache/persistence/pagemem/NoOpWALManager.java  |  17 +-
 .../pagemem/PageIdDistributionTest.java            |  17 +-
 .../pagemem/PageMemoryImplNoLoadTest.java          |  17 +-
 .../persistence/pagemem/PageMemoryImplTest.java    |  17 +-
 .../pagemem/PageMemoryLazyAllocationTest.java      |  17 +-
 .../PageMemoryLazyAllocationWithPDSTest.java       |  17 +-
 .../pagemem/PageMemoryNoStoreLeakTest.java         |  17 +-
 .../pagemem/PagesWriteThrottleSandboxTest.java     |  17 +-
 .../pagemem/PagesWriteThrottleSmokeTest.java       |  29 ++-
 .../pagemem/RobinHoodBackwardShiftHashMapTest.java |  17 +-
 .../pagemem/UsedPagesMetricAbstractTest.java       |  17 +-
 .../persistence/pagemem/UsedPagesMetricTest.java   |  17 +-
 .../pagemem/UsedPagesMetricTestPersistence.java    |  17 +-
 .../standbycluster/AbstractNodeJoinTemplate.java   |  17 +-
 .../IgniteChangeGlobalStateAbstractTest.java       |  17 +-
 .../IgniteChangeGlobalStateCacheTest.java          |  17 +-
 .../IgniteChangeGlobalStateDataStreamerTest.java   |  17 +-
 .../IgniteChangeGlobalStateDataStructureTest.java  |  17 +-
 .../IgniteChangeGlobalStateFailOverTest.java       |  17 +-
 .../IgniteChangeGlobalStateServiceTest.java        |  17 +-
 .../IgniteChangeGlobalStateTest.java               |  17 +-
 .../IgniteNoParrallelClusterIsAllowedTest.java     |  17 +-
 .../standbycluster/IgniteStandByClusterTest.java   |  17 +-
 .../extended/GridActivateExtensionTest.java        |  17 +-
 .../join/JoinActiveNodeToActiveCluster.java        |  17 +-
 .../join/JoinActiveNodeToInActiveCluster.java      |  17 +-
 .../join/JoinInActiveNodeToActiveCluster.java      |  17 +-
 .../join/JoinInActiveNodeToInActiveCluster.java    |  17 +-
 ...inActiveNodeToActiveClusterWithPersistence.java |  17 +-
 ...ActiveNodeToInActiveClusterWithPersistence.java |  17 +-
 ...InActiveNodeToActiveClusterWithPersistence.java |  17 +-
 ...ActiveNodeToInActiveClusterWithPersistence.java |  17 +-
 .../IgniteAbstractStandByClientReconnectTest.java  |  17 +-
 .../IgniteStandByClientReconnectTest.java          |  17 +-
 ...niteStandByClientReconnectToNewClusterTest.java |  17 +-
 .../persistence/tree/io/TrackingPageIOTest.java    |  17 +-
 .../wal/AbstractWalDeltaConsistencyTest.java       |  17 +-
 .../wal/CpTriggeredWalDeltaConsistencyTest.java    |  17 +-
 .../wal/ExplicitWalDeltaConsistencyTest.java       |  17 +-
 .../wal/SegmentedRingByteBufferTest.java           |  17 +-
 .../wal/SysPropWalDeltaConsistencyTest.java        |  17 +-
 .../persistence/wal/aware/SegmentAwareTest.java    |  17 +-
 .../wal/memtracker/PageMemoryTracker.java          |  17 +-
 .../memtracker/PageMemoryTrackerConfiguration.java |  17 +-
 .../PageMemoryTrackerPluginProvider.java           |  17 +-
 .../reader/StandaloneWalRecordsIteratorTest.java   |  17 +-
 .../cache/query/CacheDataPageScanQueryTest.java    |  17 +-
 .../cache/query/CacheScanQueryFailoverTest.java    |  17 +-
 .../query/GridCacheQueryTransformerSelfTest.java   |  17 +-
 .../cache/query/GridCircularQueueTest.java         |  17 +-
 .../IgniteCacheQueryCacheDestroySelfTest.java      |  17 +-
 .../cache/query/IndexingSpiQuerySelfTest.java      |  17 +-
 .../cache/query/IndexingSpiQueryTxSelfTest.java    |  17 +-
 .../IndexingSpiQueryWithH2IndexingSelfTest.java    |  17 +-
 .../ScanQueryOffheapExpiryPolicySelfTest.java      |  17 +-
 .../continuous/CacheContinuousBatchAckTest.java    |  17 +-
 ...CacheContinuousBatchForceServerModeAckTest.java |  17 +-
 ...ContinuousQueryAsyncFailoverAtomicSelfTest.java |  17 +-
 ...ContinuousQueryAsyncFailoverMvccTxSelfTest.java |  17 +-
 ...uousQueryAsyncFailoverTxReplicatedSelfTest.java |  17 +-
 ...acheContinuousQueryAsyncFailoverTxSelfTest.java |  17 +-
 ...acheContinuousQueryAsyncFilterListenerTest.java |  17 +-
 ...ntinuousQueryConcurrentPartitionUpdateTest.java |  17 +-
 .../CacheContinuousQueryCounterAbstractTest.java   |  17 +-
 ...ontinuousQueryCounterPartitionedAtomicTest.java |  17 +-
 ...cheContinuousQueryCounterPartitionedTxTest.java |  17 +-
 ...ContinuousQueryCounterReplicatedAtomicTest.java |  17 +-
 ...acheContinuousQueryCounterReplicatedTxTest.java |  17 +-
 .../CacheContinuousQueryEventBufferTest.java       |  17 +-
 .../CacheContinuousQueryExecuteInPrimaryTest.java  |  17 +-
 ...QueryFactoryAsyncFilterRandomOperationTest.java |  17 +-
 ...nuousQueryFactoryFilterRandomOperationTest.java |  17 +-
 ...cheContinuousQueryFailoverAbstractSelfTest.java |  17 +-
 ...QueryFailoverAtomicNearEnabledSelfSelfTest.java |  17 +-
 ...nuousQueryFailoverAtomicReplicatedSelfTest.java |  17 +-
 ...CacheContinuousQueryFailoverAtomicSelfTest.java |  17 +-
 ...nuousQueryFailoverMvccTxReplicatedSelfTest.java |  17 +-
 ...CacheContinuousQueryFailoverMvccTxSelfTest.java |  17 +-
 ...ontinuousQueryFailoverTxReplicatedSelfTest.java |  17 +-
 .../CacheContinuousQueryFailoverTxSelfTest.java    |  17 +-
 .../CacheContinuousQueryLostPartitionTest.java     |  17 +-
 ...heContinuousQueryOperationFromCallbackTest.java |  17 +-
 .../CacheContinuousQueryOperationP2PTest.java      |  17 +-
 .../CacheContinuousQueryOrderingEventTest.java     |  17 +-
 .../CacheContinuousQueryRandomOperationsTest.java  |  17 +-
 ...ontinuousQueryRandomOperationsTwoNodesTest.java |  17 +-
 .../CacheContinuousQueryVariationsTest.java        |  17 +-
 ...cheContinuousWithTransformerClientSelfTest.java |  17 +-
 ...CacheContinuousWithTransformerFailoverTest.java |  17 +-
 ...acheContinuousWithTransformerLocalSelfTest.java |  17 +-
 ...ntinuousWithTransformerPartitionedSelfTest.java |  17 +-
 ...tinuousWithTransformerRandomOperationsTest.java |  17 +-
 ...ontinuousWithTransformerReplicatedSelfTest.java |  17 +-
 ...acheEntryProcessorExternalizableFailedTest.java |  17 +-
 .../CacheEntryProcessorNonSerializableTest.java    |  17 +-
 .../CacheKeepBinaryIterationNearEnabledTest.java   |  17 +-
 .../CacheKeepBinaryIterationStoreEnabledTest.java  |  17 +-
 .../continuous/CacheKeepBinaryIterationTest.java   |  17 +-
 .../ClientReconnectContinuousQueryTest.java        |  17 +-
 .../continuous/ContinuousQueryMarshallerTest.java  |  17 +-
 .../ContinuousQueryPeerClassLoadingTest.java       |  17 +-
 .../ContinuousQueryReassignmentTest.java           |  17 +-
 ...ueryRemoteFilterMissingInClassPathSelfTest.java |  17 +-
 .../GridCacheContinuousQueryAbstractSelfTest.java  |  17 +-
 ...heContinuousQueryAtomicNearEnabledSelfTest.java |  17 +-
 ...heContinuousQueryAtomicP2PDisabledSelfTest.java |  17 +-
 .../GridCacheContinuousQueryAtomicSelfTest.java    |  17 +-
 .../GridCacheContinuousQueryConcurrentTest.java    |  17 +-
 ...ridCacheContinuousQueryLocalAtomicSelfTest.java |  17 +-
 .../GridCacheContinuousQueryLocalSelfTest.java     |  17 +-
 ...acheContinuousQueryMultiNodesFilteringTest.java |  17 +-
 ...GridCacheContinuousQueryNodesFilteringTest.java |  17 +-
 ...eContinuousQueryPartitionAtomicOneNodeTest.java |  17 +-
 ...CacheContinuousQueryPartitionTxOneNodeTest.java |  17 +-
 ...acheContinuousQueryPartitionedOnlySelfTest.java |  17 +-
 ...tinuousQueryPartitionedP2PDisabledSelfTest.java |  17 +-
 ...ridCacheContinuousQueryPartitionedSelfTest.java |  17 +-
 ...ContinuousQueryReplicatedAtomicOneNodeTest.java |  17 +-
 ...cheContinuousQueryReplicatedAtomicSelfTest.java |  17 +-
 ...ntinuousQueryReplicatedP2PDisabledSelfTest.java |  17 +-
 ...GridCacheContinuousQueryReplicatedSelfTest.java |  17 +-
 ...acheContinuousQueryReplicatedTxOneNodeTest.java |  17 +-
 .../GridCacheContinuousQueryTxSelfTest.java        |  17 +-
 .../IgniteCacheContinuousQueryBackupQueueTest.java |  17 +-
 ...iteCacheContinuousQueryClientReconnectTest.java |  17 +-
 .../IgniteCacheContinuousQueryClientTest.java      |  17 +-
 ...eCacheContinuousQueryClientTxReconnectTest.java |  17 +-
 ...niteCacheContinuousQueryImmutableEntryTest.java |  17 +-
 ...gniteCacheContinuousQueryNoUnsubscribeTest.java |  17 +-
 .../IgniteCacheContinuousQueryReconnectTest.java   |  17 +-
 .../GridCacheWriteBehindStoreAbstractSelfTest.java |  17 +-
 .../GridCacheWriteBehindStoreAbstractTest.java     |  17 +-
 .../store/GridCacheWriteBehindStoreLocalTest.java  |  17 +-
 ...CacheWriteBehindStoreMultithreadedSelfTest.java |  17 +-
 ...iteBehindStorePartitionedMultiNodeSelfTest.java |  17 +-
 .../GridCacheWriteBehindStorePartitionedTest.java  |  17 +-
 .../GridCacheWriteBehindStoreReplicatedTest.java   |  17 +-
 .../store/GridCacheWriteBehindStoreSelfTest.java   |  17 +-
 .../IgniteCacheWriteBehindNoUpdateSelfTest.java    |  17 +-
 ...nteCacheClientWriteBehindStoreAbstractTest.java |  17 +-
 ...IgnteCacheClientWriteBehindStoreAtomicTest.java |  17 +-
 ...cheClientWriteBehindStoreNonCoalescingTest.java |  17 +-
 .../IgnteCacheClientWriteBehindStoreTxTest.java    |  17 +-
 .../AbstractDeadlockDetectionTest.java             |  17 +-
 .../AbstractTransactionIntergrityTest.java         |  17 +-
 .../transactions/AtomicOperationsInTxTest.java     |  17 +-
 .../cache/transactions/DepthFirstSearchTest.java   |  17 +-
 ...ionIntegrityWithPrimaryIndexCorruptionTest.java |  17 +-
 ...nsactionIntegrityWithSystemWorkerDeathTest.java |  17 +-
 .../TxDataConsistencyOnCommitFailureTest.java      |  17 +-
 .../cache/transactions/TxDeadlockCauseTest.java    |  17 +-
 .../TxDeadlockDetectionMessageMarshallingTest.java |  17 +-
 .../TxDeadlockDetectionNoHangsTest.java            |  17 +-
 .../transactions/TxDeadlockDetectionTest.java      |  17 +-
 .../TxDeadlockDetectionUnmasrhalErrorsTest.java    |  17 +-
 .../processors/cache/transactions/TxLabelTest.java |  17 +-
 .../transactions/TxMultiCacheAsyncOpsTest.java     |  17 +-
 .../cache/transactions/TxOnCachesStartTest.java    |  17 +-
 ...xOptimisticDeadlockDetectionCrossCacheTest.java |  17 +-
 .../TxOptimisticDeadlockDetectionTest.java         |  17 +-
 .../TxOptimisticOnPartitionExchangeTest.java       |  17 +-
 .../TxOptimisticPrepareOnUnstableTopologyTest.java |  17 +-
 ...PessimisticDeadlockDetectionCrossCacheTest.java |  17 +-
 .../TxPessimisticDeadlockDetectionTest.java        |  17 +-
 .../transactions/TxRollbackAsyncNearCacheTest.java |  17 +-
 .../cache/transactions/TxRollbackAsyncTest.java    |  17 +-
 .../TxRollbackAsyncWithPersistenceTest.java        |  17 +-
 .../TxRollbackOnIncorrectParamsTest.java           |  17 +-
 .../TxRollbackOnTimeoutNearCacheTest.java          |  17 +-
 ...TxRollbackOnTimeoutNoDeadlockDetectionTest.java |  17 +-
 .../TxRollbackOnTimeoutOnePhaseCommitTest.java     |  17 +-
 .../transactions/TxRollbackOnTimeoutTest.java      |  17 +-
 .../TxRollbackOnTopologyChangeTest.java            |  17 +-
 .../cache/transactions/TxStateChangeEventTest.java |  17 +-
 .../TxWithSmallTimeoutAndContentionOneKeyTest.java |  17 +-
 .../version/CacheVersionedEntryAbstractTest.java   |  17 +-
 ...sionedEntryLocalAtomicSwapDisabledSelfTest.java |  17 +-
 ...heVersionedEntryLocalTransactionalSelfTest.java |  17 +-
 ...cheVersionedEntryPartitionedAtomicSelfTest.java |  17 +-
 ...ionedEntryPartitionedTransactionalSelfTest.java |  17 +-
 ...acheVersionedEntryReplicatedAtomicSelfTest.java |  17 +-
 ...sionedEntryReplicatedTransactionalSelfTest.java |  17 +-
 .../closure/GridClosureProcessorRemoteTest.java    |  17 +-
 .../closure/GridClosureProcessorSelfTest.java      |  17 +-
 .../closure/GridClosureSerializationTest.java      |  17 +-
 .../internal/processors/closure/package-info.java  |  17 +-
 .../cluster/BaselineAutoAdjustInMemoryTest.java    |  17 +-
 .../cluster/BaselineAutoAdjustMXBeanTest.java      |  17 +-
 .../processors/cluster/BaselineAutoAdjustTest.java |  17 +-
 .../cluster/GridAddressResolverSelfTest.java       |  17 +-
 .../cluster/GridUpdateNotifierSelfTest.java        |  17 +-
 ...ridComputeJobExecutionErrorToLogManualTest.java |  17 +-
 .../IgniteComputeConfigVariationsFullApiTest.java  |  17 +-
 ...ComputeCustomExecutorConfigurationSelfTest.java |  17 +-
 .../IgniteComputeCustomExecutorSelfTest.java       |  17 +-
 .../compute/PublicThreadpoolStarvationTest.java    |  17 +-
 .../DistributedConfigurationAbstractTest.java      |  17 +-
 .../DistributedConfigurationInMemoryTest.java      |  17 +-
 .../DistributedConfigurationPersistentTest.java    |  17 +-
 .../TestDistibutedConfigurationPlugin.java         |  17 +-
 .../continuous/GridEventConsumeSelfTest.java       |  17 +-
 .../continuous/GridMessageListenSelfTest.java      |  17 +-
 .../IgniteContinuousQueryMetadataUpdateTest.java   |  17 +-
 .../IgniteNoCustomEventsOnNodeStart.java           |  17 +-
 .../database/BPlusTreeFakeReuseSelfTest.java       |  17 +-
 .../database/BPlusTreeReuseSelfTest.java           |  17 +-
 .../processors/database/BPlusTreeSelfTest.java     |  17 +-
 .../database/CacheFreeListImplSelfTest.java        |  17 +-
 .../database/DataRegionMetricsSelfTest.java        |  17 +-
 .../processors/database/IgniteDbAbstractTest.java  |  17 +-
 .../database/IgniteDbDynamicCacheSelfTest.java     |  18 +-
 .../database/IgniteDbMemoryLeakAbstractTest.java   |  17 +-
 .../IgniteDbMemoryLeakLargeObjectsTest.java        |  17 +-
 .../database/IgniteDbMemoryLeakLargePagesTest.java |  17 +-
 .../IgniteDbMemoryLeakNonTransactionalTest.java    |  17 +-
 .../database/IgniteDbMemoryLeakTest.java           |  17 +-
 .../IgniteDbMemoryLeakWithExpirationTest.java      |  17 +-
 .../database/IgniteDbMultiNodePutGetTest.java      |  17 +-
 .../database/IgniteDbPutGetAbstractTest.java       |  17 +-
 .../database/IgniteDbPutGetWithCacheStoreTest.java |  17 +-
 .../database/IgniteDbSingleNodePutGetTest.java     |  17 +-
 .../database/IgniteDbSingleNodeTinyPutGetTest.java |  17 +-
 .../processors/database/IndexStorageSelfTest.java  |  17 +-
 .../database/SwapPathConstructionSelfTest.java     |  17 +-
 ...DataStreamProcessorMvccPersistenceSelfTest.java |  17 +-
 .../DataStreamProcessorMvccSelfTest.java           |  17 +-
 .../DataStreamProcessorPersistenceSelfTest.java    |  17 +-
 .../datastreamer/DataStreamProcessorSelfTest.java  |  17 +-
 ...amerClientReconnectAfterClusterRestartTest.java |  17 +-
 .../datastreamer/DataStreamerImplSelfTest.java     |  17 +-
 .../DataStreamerMultiThreadedSelfTest.java         |  17 +-
 .../DataStreamerMultinodeCreateCacheTest.java      |  17 +-
 .../datastreamer/DataStreamerTimeoutTest.java      |  17 +-
 .../DataStreamerUpdateAfterLoadTest.java           |  17 +-
 .../IgniteDataStreamerPerformanceTest.java         |  17 +-
 .../DefaultIgfsSecondaryFileSystemTestAdapter.java |  17 +-
 .../processors/igfs/IgfsAbstractBaseSelfTest.java  |  17 +-
 .../processors/igfs/IgfsAbstractSelfTest.java      |  17 +-
 .../igfs/IgfsAtomicPrimaryMultiNodeSelfTest.java   |  17 +-
 .../processors/igfs/IgfsAtomicPrimarySelfTest.java |  17 +-
 .../processors/igfs/IgfsAttributesSelfTest.java    |  17 +-
 .../igfs/IgfsBackupFailoverSelfTest.java           |  17 +-
 .../igfs/IgfsBackupsDualAsyncSelfTest.java         |  17 +-
 .../igfs/IgfsBackupsDualSyncSelfTest.java          |  17 +-
 .../igfs/IgfsBackupsPrimarySelfTest.java           |  17 +-
 ...fsBlockMessageSystemPoolStarvationSelfTest.java |  17 +-
 ...IgfsCachePerBlockLruEvictionPolicySelfTest.java |  17 +-
 .../processors/igfs/IgfsCacheSelfTest.java         |  17 +-
 .../processors/igfs/IgfsCommonAbstractTest.java    |  17 +-
 .../processors/igfs/IgfsDataManagerSelfTest.java   |  17 +-
 .../processors/igfs/IgfsDualAbstractSelfTest.java  |  17 +-
 .../igfs/IgfsDualAsyncClientSelfTest.java          |  17 +-
 .../processors/igfs/IgfsDualAsyncSelfTest.java     |  17 +-
 .../igfs/IgfsDualSyncClientSelfTest.java           |  17 +-
 .../processors/igfs/IgfsDualSyncSelfTest.java      |  17 +-
 .../processors/igfs/IgfsFileInfoSelfTest.java      |  17 +-
 .../processors/igfs/IgfsFileMapSelfTest.java       |  17 +-
 .../IgfsGroupDataBlockKeyMapperHashSelfTest.java   |  17 +-
 .../internal/processors/igfs/IgfsIgniteMock.java   |  17 +-
 ...calSecondaryFileSystemDualAbstractSelfTest.java |  17 +-
 ...SecondaryFileSystemDualAsyncClientSelfTest.java |  17 +-
 ...sLocalSecondaryFileSystemDualAsyncSelfTest.java |  17 +-
 ...lSecondaryFileSystemDualSyncClientSelfTest.java |  17 +-
 ...fsLocalSecondaryFileSystemDualSyncSelfTest.java |  17 +-
 ...ocalSecondaryFileSystemProxyClientSelfTest.java |  17 +-
 .../IgfsLocalSecondaryFileSystemProxySelfTest.java |  17 +-
 .../IgfsLocalSecondaryFileSystemTestAdapter.java   |  17 +-
 .../processors/igfs/IgfsMetaManagerSelfTest.java   |  17 +-
 .../processors/igfs/IgfsMetricsSelfTest.java       |  17 +-
 .../ignite/internal/processors/igfs/IgfsMock.java  |  17 +-
 .../processors/igfs/IgfsModeResolverSelfTest.java  |  17 +-
 .../processors/igfs/IgfsModesSelfTest.java         |  17 +-
 .../processors/igfs/IgfsOneClientNodeTest.java     |  17 +-
 .../processors/igfs/IgfsPrimaryClientSelfTest.java |  17 +-
 .../igfs/IgfsPrimaryMultiNodeSelfTest.java         |  17 +-
 ...gfsPrimaryRelaxedConsistencyClientSelfTest.java |  17 +-
 ...PrimaryRelaxedConsistencyMultiNodeSelfTest.java |  17 +-
 .../IgfsPrimaryRelaxedConsistencySelfTest.java     |  17 +-
 .../processors/igfs/IgfsPrimarySelfTest.java       |  17 +-
 .../processors/igfs/IgfsProcessorSelfTest.java     |  17 +-
 .../igfs/IgfsProcessorValidationSelfTest.java      |  17 +-
 .../processors/igfs/IgfsProxySelfTest.java         |  17 +-
 .../IgfsSecondaryFileSystemInjectionSelfTest.java  |  17 +-
 .../igfs/IgfsSecondaryFileSystemTestAdapter.java   |  17 +-
 ...gerIpcEndpointRegistrationAbstractSelfTest.java |  17 +-
 ...cEndpointRegistrationOnLinuxAndMacSelfTest.java |  17 +-
 ...erIpcEndpointRegistrationOnWindowsSelfTest.java |  17 +-
 .../internal/processors/igfs/IgfsSizeSelfTest.java |  17 +-
 .../processors/igfs/IgfsStartCacheTest.java        |  17 +-
 .../processors/igfs/IgfsStreamsSelfTest.java       |  17 +-
 .../internal/processors/igfs/IgfsTaskSelfTest.java |  17 +-
 .../processors/igfs/IgfsTestInputStream.java       |  17 +-
 .../processors/igfs/benchmark/IgfsBenchmark.java   |  17 +-
 .../internal/processors/igfs/package-info.java     |  17 +-
 .../split/IgfsAbstractRecordResolverSelfTest.java  |  17 +-
 .../IgfsByteDelimiterRecordResolverSelfTest.java   |  17 +-
 .../IgfsFixedLengthRecordResolverSelfTest.java     |  17 +-
 ...IgfsNewLineDelimiterRecordResolverSelfTest.java |  17 +-
 .../IgfsStringDelimiterRecordResolverSelfTest.java |  17 +-
 .../GridJobMetricsProcessorLoadTest.java           |  17 +-
 .../IgniteMessagingConfigVariationFullApiTest.java |  17 +-
 .../DistributedMetaStoragePersistentTest.java      |  17 +-
 .../metastorage/DistributedMetaStorageTest.java    |  17 +-
 .../DistributedMetaStorageHistoryCacheTest.java    |  17 +-
 .../odbc/OdbcConfigurationValidationSelfTest.java  |  17 +-
 .../odbc/OdbcEscapeSequenceSelfTest.java           |  17 +-
 .../processors/port/GridPortProcessorSelfTest.java |  17 +-
 .../processors/rest/RestProtocolStartTest.java     |  17 +-
 .../GridCacheAtomicCommandHandlerSelfTest.java     |  17 +-
 .../cache/GridCacheCommandHandlerSelfTest.java     |  17 +-
 .../handlers/log/GridLogCommandHandlerTest.java    |  17 +-
 .../query/GridQueryCommandHandlerTest.java         |  17 +-
 .../top/CacheTopologyCommandHandlerTest.java       |  17 +-
 .../service/ClosureServiceClientsNodesTest.java    |  17 +-
 .../internal/processors/service/DummyService.java  |  17 +-
 .../service/GridServiceClientNodeTest.java         |  17 +-
 .../GridServiceContinuousQueryRedeployTest.java    |  17 +-
 ...ridServiceDeploymentCompoundFutureSelfTest.java |  17 +-
 ...dServiceDeploymentExceptionPropagationTest.java |  17 +-
 .../service/GridServicePackagePrivateSelfTest.java |  17 +-
 .../GridServiceProcessorAbstractSelfTest.java      |  17 +-
 .../GridServiceProcessorBatchDeploySelfTest.java   |  17 +-
 ...ridServiceProcessorMultiNodeConfigSelfTest.java |  17 +-
 .../GridServiceProcessorMultiNodeSelfTest.java     |  17 +-
 .../service/GridServiceProcessorProxySelfTest.java |  17 +-
 .../GridServiceProcessorSingleNodeSelfTest.java    |  17 +-
 .../service/GridServiceProcessorStopSelfTest.java  |  17 +-
 .../GridServiceProxyClientReconnectSelfTest.java   |  17 +-
 .../service/GridServiceProxyNodeStopSelfTest.java  |  17 +-
 .../service/GridServiceReassignmentSelfTest.java   |  17 +-
 .../service/GridServiceSerializationSelfTest.java  |  17 +-
 .../IgniteServiceConfigVariationsFullApiTest.java  |  17 +-
 ...ployment2ClassLoadersDefaultMarshallerTest.java |  17 +-
 ...ceDeployment2ClassLoadersJdkMarshallerTest.java |  17 +-
 ...oyment2ClassLoadersOptimizedMarshallerTest.java |  17 +-
 ...eploymentClassLoadingDefaultMarshallerTest.java |  17 +-
 ...iceDeploymentClassLoadingJdkMarshallerTest.java |  17 +-
 ...loymentClassLoadingOptimizedMarshallerTest.java |  17 +-
 .../IgniteServiceDynamicCachesSelfTest.java        |  17 +-
 .../IgniteServiceProxyTimeoutInitializedTest.java  |  17 +-
 .../service/IgniteServiceReassignmentTest.java     |  17 +-
 ...mentDiscoveryListenerNotificationOrderTest.java |  29 ++-
 ...mentNonSerializableStaticConfigurationTest.java |  17 +-
 .../service/ServiceDeploymentOnActivationTest.java |  17 +-
 .../ServiceDeploymentOnClientDisconnectTest.java   |  17 +-
 .../ServiceDeploymentOutsideBaselineTest.java      |  17 +-
 .../ServiceDeploymentProcessAbstractTest.java      |  17 +-
 .../ServiceDeploymentProcessIdSelfTest.java        |  17 +-
 ...eDeploymentProcessingOnCoordinatorFailTest.java |  17 +-
 ...eDeploymentProcessingOnCoordinatorLeftTest.java |  17 +-
 ...ServiceDeploymentProcessingOnNodesFailTest.java |  17 +-
 ...ServiceDeploymentProcessingOnNodesLeftTest.java |  17 +-
 ...ServiceHotRedeploymentViaDeploymentSpiTest.java |  17 +-
 .../processors/service/ServiceInfoSelfTest.java    |  17 +-
 .../service/ServicePredicateAccessCacheTest.java   |  17 +-
 .../ServiceReassignmentFunctionSelfTest.java       |  17 +-
 .../service/SystemCacheNotConfiguredTest.java      |  17 +-
 .../service/inner/LongInitializedTestService.java  |  17 +-
 .../processors/service/inner/MyService.java        |  17 +-
 .../processors/service/inner/MyServiceFactory.java |  17 +-
 .../processors/service/inner/MyServiceImpl.java    |  17 +-
 .../timeout/GridTimeoutProcessorSelfTest.java      |  17 +-
 .../product/GridProductVersionSelfTest.java        |  17 +-
 .../internal/sql/SqlParserAbstractSelfTest.java    |  17 +-
 .../internal/sql/SqlParserBulkLoadSelfTest.java    |  17 +-
 .../internal/sql/SqlParserCreateIndexSelfTest.java |  17 +-
 .../internal/sql/SqlParserDropIndexSelfTest.java   |  17 +-
 .../internal/sql/SqlParserKillQuerySelfTest.java   |  18 +-
 .../sql/SqlParserMultiStatementSelfTest.java       |  17 +-
 .../sql/SqlParserSetStreamingSelfTest.java         |  17 +-
 .../SqlParserTransactionalKeywordsSelfTest.java    |  17 +-
 .../ignite/internal/sql/SqlParserUserSelfTest.java |  17 +-
 .../stat/IoStatisticsCachePersistenceSelfTest.java |  18 +-
 .../internal/stat/IoStatisticsCacheSelfTest.java   |  18 +-
 .../internal/stat/IoStatisticsManagerSelfTest.java |  18 +-
 ...IoStatisticsMetricsLocalMXBeanImplSelfTest.java |  18 +-
 .../org/apache/ignite/internal/updatestatus.html   |  27 ++-
 .../ignite/internal/util/BitSetIntSetTest.java     |  17 +-
 .../ignite/internal/util/GridArraysSelfTest.java   |  17 +-
 .../ignite/internal/util/GridCleanerTest.java      |  17 +-
 .../internal/util/GridHandleTableSelfTest.java     |  17 +-
 ...GridStartupWithUndefinedIgniteHomeSelfTest.java |  17 +-
 .../ignite/internal/util/GridTestClockTimer.java   |  17 +-
 .../ignite/internal/util/IgniteDevOnlyLogTest.java |  17 +-
 .../util/IgniteExceptionRegistrySelfTest.java      |  17 +-
 .../ignite/internal/util/IgniteUtilsSelfTest.java  |  17 +-
 .../ignite/internal/util/StripedExecutorTest.java  |  17 +-
 .../util/future/GridCompoundFutureSelfTest.java    |  17 +-
 .../util/future/GridEmbeddedFutureSelfTest.java    |  17 +-
 .../util/future/GridFutureAdapterSelfTest.java     |  17 +-
 .../internal/util/future/GridFutureQueueTest.java  |  17 +-
 .../util/future/IgniteCacheFutureImplTest.java     |  17 +-
 .../internal/util/future/IgniteFutureImplTest.java |  17 +-
 .../future/nio/GridNioEmbeddedFutureSelfTest.java  |  17 +-
 .../util/future/nio/GridNioFutureSelfTest.java     |  17 +-
 ...GridUnsafeDataInputOutputByteOrderSelfTest.java |  17 +-
 .../GridUnsafeDataOutputArraySizingSelfTest.java   |  17 +-
 .../util/ipc/shmem/IgfsSharedMemoryTestClient.java |  17 +-
 .../util/ipc/shmem/IgfsSharedMemoryTestServer.java |  17 +-
 .../IpcSharedMemoryCrashDetectionSelfTest.java     |  17 +-
 .../util/ipc/shmem/IpcSharedMemoryFakeClient.java  |  17 +-
 .../shmem/IpcSharedMemoryNativeLoaderSelfTest.java |  17 +-
 .../util/ipc/shmem/IpcSharedMemoryNodeStartup.java |  17 +-
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java    |  17 +-
 .../ipc/shmem/IpcSharedMemoryUtilsSelfTest.java    |  17 +-
 .../shmem/LoadWithCorruptedLibFileTestRunner.java  |  17 +-
 .../benchmark/IpcSharedMemoryBenchmarkParty.java   |  17 +-
 .../benchmark/IpcSharedMemoryBenchmarkReader.java  |  17 +-
 .../benchmark/IpcSharedMemoryBenchmarkWriter.java  |  17 +-
 .../util/nio/GridNioDelimitedBufferSelfTest.java   |  17 +-
 .../ignite/internal/util/nio/GridNioSelfTest.java  |  17 +-
 .../util/nio/GridNioSessionMetaKeySelfTest.java    |  17 +-
 .../internal/util/nio/GridNioSslSelfTest.java      |  17 +-
 .../internal/util/nio/GridRoundTripTest.java       |  17 +-
 .../nio/IgniteExceptionInNioWorkerSelfTest.java    |  17 +-
 .../util/nio/impl/GridNioFilterChainSelfTest.java  |  17 +-
 .../ignite/internal/util/nio/package-info.java     |  17 +-
 .../util/offheap/GridByteArrayWrapper.java         |  17 +-
 .../offheap/GridOffHeapMapAbstractSelfTest.java    |  17 +-
 .../GridOffHeapMapPerformanceAbstractTest.java     |  17 +-
 .../GridOffHeapPartitionedMapAbstractSelfTest.java |  17 +-
 ...fHeapPartitionedMapPerformanceAbstractTest.java |  17 +-
 .../unsafe/GridUnsafeMapPerformanceTest.java       |  17 +-
 .../util/offheap/unsafe/GridUnsafeMapSelfTest.java |  17 +-
 .../offheap/unsafe/GridUnsafeMemorySelfTest.java   |  17 +-
 .../GridUnsafePartitionedMapPerformanceTest.java   |  17 +-
 .../unsafe/GridUnsafePartitionedMapSelfTest.java   |  17 +-
 .../unsafe/GridUnsafeStripedLruSefTest.java        |  17 +-
 .../tostring/CircularStringBuilderSelfTest.java    |  17 +-
 .../util/tostring/GridToStringBuilderSelfTest.java |  17 +-
 .../tostring/IncludeSensitiveAbstractTest.java     |  17 +-
 .../util/tostring/IncludeSensitiveAtomicTest.java  |  17 +-
 .../IncludeSensitiveTransactionalTest.java         |  17 +-
 .../internal/util/tostring/package-info.java       |  17 +-
 .../apache/ignite/jvmtest/BlockingQueueTest.java   |  17 +-
 .../java/org/apache/ignite/jvmtest/FileIOTest.java |  17 +-
 .../org/apache/ignite/jvmtest/FileLocksTest.java   |  17 +-
 .../apache/ignite/jvmtest/LinkedHashMapTest.java   |  17 +-
 .../apache/ignite/jvmtest/MultipleFileIOTest.java  |  17 +-
 .../apache/ignite/jvmtest/NetworkFailureTest.java  |  17 +-
 .../jvmtest/QueueSizeCounterMultiThreadedTest.java |  17 +-
 .../jvmtest/ReadWriteLockMultiThreadedTest.java    |  17 +-
 .../java/org/apache/ignite/jvmtest/RegExpTest.java |  17 +-
 .../jvmtest/ServerSocketMultiThreadedTest.java     |  17 +-
 .../ignite/lang/GridBasicPerformanceTest.java      |  17 +-
 .../ignite/lang/GridByteArrayListSelfTest.java     |  17 +-
 .../ignite/lang/GridFuncPerformanceTest.java       |  17 +-
 .../lang/GridFutureListenPerformanceTest.java      |  17 +-
 .../lang/GridMetadataAwareAdapterLoadTest.java     |  27 ++-
 .../lang/GridMetadataAwareAdapterSelfTest.java     |  17 +-
 .../apache/ignite/lang/GridSetWrapperSelfTest.java |  17 +-
 .../lang/GridSystemCurrentTimeMillisTest.java      |  17 +-
 .../apache/ignite/lang/GridThreadPriorityTest.java |  17 +-
 .../org/apache/ignite/lang/GridTupleSelfTest.java  |  17 +-
 .../java/org/apache/ignite/lang/GridXSelfTest.java |  17 +-
 .../org/apache/ignite/lang/IgniteUuidSelfTest.java |  17 +-
 .../java/org/apache/ignite/lang/package-info.java  |  17 +-
 ...GridBoundedConcurrentLinkedHashMapSelfTest.java |  17 +-
 .../GridBoundedConcurrentOrderedMapSelfTest.java   |  17 +-
 .../utils/GridBoundedPriorityQueueSelfTest.java    |  17 +-
 .../utils/GridCircularBufferPerformanceTest.java   |  17 +-
 .../lang/utils/GridCircularBufferSelfTest.java     |  17 +-
 .../utils/GridConcurrentLinkedHashMapSelfTest.java |  17 +-
 .../utils/GridConcurrentWeakHashSetSelfTest.java   |  17 +-
 .../lang/utils/GridConsistentHashSelfTest.java     |  17 +-
 .../lang/utils/GridLeanIdentitySetSelfTest.java    |  17 +-
 .../lang/utils/GridLeanMapPerformanceTest.java     |  17 +-
 .../ignite/lang/utils/GridLeanMapSelfTest.java     |  17 +-
 .../ignite/lang/utils/GridListSetSelfTest.java     |  17 +-
 .../ignite/lang/utils/GridStripedLockSelfTest.java |  17 +-
 .../utils/IgniteOffheapReadWriteLockSelfTest.java  |  17 +-
 .../org/apache/ignite/lang/utils/package-info.java |  17 +-
 .../loadtests/GridCacheLoadPopulationTask.java     |  17 +-
 .../loadtests/GridCacheMultiNodeLoadTest.java      |  17 +-
 .../ignite/loadtests/GridLoadTestStatistics.java   |  17 +-
 .../ignite/loadtests/GridSingleExecutionTest.java  |  17 +-
 .../loadtests/cache/GridCacheAbstractLoadTest.java |  17 +-
 .../ignite/loadtests/cache/GridCacheBenchmark.java |  17 +-
 .../cache/GridCacheDataStructuresLoadTest.java     |  17 +-
 .../ignite/loadtests/cache/GridCacheLoadTest.java  |  17 +-
 .../cache/GridCacheWriteBehindStoreLoadTest.java   |  17 +-
 .../loadtests/capacity/GridCapacityLoadTest.java   |  17 +-
 .../loadtests/capacity/spring-capacity-cache.xml   |  27 ++-
 .../loadtests/colocation/GridTestCacheStore.java   |  17 +-
 .../loadtests/colocation/GridTestConstants.java    |  17 +-
 .../ignite/loadtests/colocation/GridTestKey.java   |  17 +-
 .../colocation/GridTestLifecycleBean.java          |  17 +-
 .../ignite/loadtests/colocation/GridTestMain.java  |  17 +-
 .../loadtests/colocation/spring-colocation.xml     |  27 ++-
 .../communication/GridIoManagerBenchmark.java      |  17 +-
 .../communication/GridIoManagerBenchmark0.java     |  17 +-
 .../GridTcpCommunicationBenchmark.java             |  17 +-
 .../loadtests/communication/GridTestMessage.java   |  17 +-
 .../GridContinuousOperationsLoadTest.java          |  17 +-
 .../GridCachePartitionedAtomicLongLoadTest.java    |  17 +-
 .../direct/multisplit/GridLoadTestJob.java         |  17 +-
 .../direct/multisplit/GridLoadTestJobTarget.java   |  17 +-
 .../direct/multisplit/GridLoadTestTask.java        |  17 +-
 .../direct/multisplit/GridMultiSplitsLoadTest.java |  17 +-
 .../GridMultiSplitsRedeployLoadTest.java           |  17 +-
 .../loadtests/direct/multisplit/package-info.java  |  17 +-
 .../GridSingleSplitNewNodesTestJobTarget.java      |  17 +-
 .../newnodes/GridSingleSplitNewNodesTestTask.java  |  17 +-
 .../GridSingleSplitsNewNodesAbstractLoadTest.java  |  17 +-
 .../GridSingleSplitsNewNodesMulticastLoadTest.java |  17 +-
 .../loadtests/direct/newnodes/package-info.java    |  17 +-
 .../redeploy/GridSingleSplitsRedeployLoadTest.java |  17 +-
 .../loadtests/direct/redeploy/package-info.java    |  17 +-
 .../direct/session/GridSessionLoadTest.java        |  17 +-
 .../direct/session/GridSessionLoadTestJob.java     |  17 +-
 .../direct/session/GridSessionLoadTestTask.java    |  17 +-
 .../loadtests/direct/session/package-info.java     |  17 +-
 .../direct/stealing/GridStealingLoadTest.java      |  17 +-
 .../direct/stealing/GridStealingLoadTestJob.java   |  17 +-
 .../direct/stealing/GridStealingLoadTestTask.java  |  17 +-
 .../loadtests/direct/stealing/package-info.java    |  17 +-
 .../loadtests/discovery/GridGcTimeoutTest.java     |  17 +-
 .../apache/ignite/loadtests/dsi/GridDsiClient.java |  17 +-
 .../ignite/loadtests/dsi/GridDsiLifecycleBean.java |  17 +-
 .../ignite/loadtests/dsi/GridDsiMessage.java       |  17 +-
 .../ignite/loadtests/dsi/GridDsiPerfJob.java       |  17 +-
 .../ignite/loadtests/dsi/GridDsiRequest.java       |  17 +-
 .../ignite/loadtests/dsi/GridDsiRequestTask.java   |  17 +-
 .../ignite/loadtests/dsi/GridDsiResponse.java      |  17 +-
 .../ignite/loadtests/dsi/GridDsiResponseTask.java  |  17 +-
 .../ignite/loadtests/dsi/GridDsiSession.java       |  17 +-
 .../cacheget/GridBenchmarkCacheGetLoadTest.java    |  17 +-
 .../apache/ignite/loadtests/dsi/package-info.java  |  17 +-
 ...GridBoundedConcurrentLinkedHashSetLoadTest.java |  17 +-
 .../loadtests/hashmap/GridCacheTestContext.java    |  17 +-
 .../loadtests/hashmap/GridHashMapLoadTest.java     |  17 +-
 .../job/GridJobExecutionLoadTestClient.java        |  17 +-
 .../GridJobExecutionLoadTestClientSemaphore.java   |  17 +-
 .../loadtests/job/GridJobExecutionLoadTestJob.java |  17 +-
 .../job/GridJobExecutionLoadTestServer.java        |  17 +-
 .../job/GridJobExecutionLoadTestTask.java          |  17 +-
 .../job/GridJobExecutionSingleNodeLoadTest.java    |  17 +-
 ...ridJobExecutionSingleNodeSemaphoreLoadTest.java |  17 +-
 .../ignite/loadtests/job/GridJobLoadTest.java      |  17 +-
 .../ignite/loadtests/job/GridJobLoadTestJob.java   |  17 +-
 .../loadtests/job/GridJobLoadTestParams.java       |  17 +-
 .../loadtests/job/GridJobLoadTestSubmitter.java    |  17 +-
 .../ignite/loadtests/job/GridJobLoadTestTask.java  |  17 +-
 .../apache/ignite/loadtests/job/package-info.java  |  17 +-
 .../lang/GridConcurrentLinkedHashMapBenchmark.java |  17 +-
 .../ignite/loadtests/mapper/GridNodeStartup.java   |  17 +-
 .../loadtests/mergesort/GridMergeSortLoadTask.java |  17 +-
 .../loadtests/mergesort/GridMergeSortLoadTest.java |  17 +-
 .../loadtests/nio/GridNioBenchmarkClient.java      |  17 +-
 .../ignite/loadtests/nio/GridNioBenchmarkTest.java |  17 +-
 .../loadtests/util/GridCumulativeAverage.java      |  17 +-
 .../ignite/loadtests/util/GridLoadTestArgs.java    |  17 +-
 .../apache/ignite/logger/java/JavaLoggerTest.java  |  17 +-
 .../apache/ignite/logger/java/package-info.java    |  17 +-
 .../DynamicProxySerializationMultiJvmSelfTest.java |  17 +-
 .../marshaller/GridMarshallerAbstractTest.java     |  17 +-
 .../GridMarshallerExternalizableBean.java          |  17 +-
 .../GridMarshallerMappingConsistencyTest.java      |  17 +-
 .../marshaller/GridMarshallerPerformanceTest.java  |  17 +-
 .../marshaller/GridMarshallerResourceBean.java     |  17 +-
 .../marshaller/GridMarshallerTestAbstractBean.java |  17 +-
 .../ignite/marshaller/GridMarshallerTestBean.java  |  17 +-
 .../GridMarshallerTestInheritedBean.java           |  17 +-
 .../marshaller/MarshallerContextSelfTest.java      |  17 +-
 .../marshaller/MarshallerContextTestImpl.java      |  17 +-
 .../MarshallerEnumDeadlockMultiJvmTest.java        |  17 +-
 .../marshaller/jdk/GridJdkMarshallerSelfTest.java  |  17 +-
 .../apache/ignite/marshaller/jdk/package-info.java |  17 +-
 .../org/apache/ignite/marshaller/package-info.java |  17 +-
 .../GridMessagingNoPeerClassLoadingSelfTest.java   |  17 +-
 .../ignite/messaging/GridMessagingSelfTest.java    |  17 +-
 .../messaging/IgniteMessagingSendAsyncTest.java    |  17 +-
 .../messaging/IgniteMessagingWithClientTest.java   |  17 +-
 .../p2p/DeploymentClassLoaderCallableTest.java     |  17 +-
 .../p2p/GridAbstractMultinodeRedeployTest.java     |  17 +-
 ...ridMultinodeRedeployContinuousModeSelfTest.java |  17 +-
 .../GridMultinodeRedeployIsolatedModeSelfTest.java |  17 +-
 .../GridMultinodeRedeployPrivateModeSelfTest.java  |  17 +-
 .../GridMultinodeRedeploySharedModeSelfTest.java   |  17 +-
 .../ignite/p2p/GridP2PClassLoadingSelfTest.java    |  17 +-
 ...GridP2PComputeWithNestedEntryProcessorTest.java |  17 +-
 .../p2p/GridP2PContinuousDeploymentSelfTest.java   |  17 +-
 .../p2p/GridP2PDifferentClassLoaderSelfTest.java   |  17 +-
 .../p2p/GridP2PDoubleDeploymentSelfTest.java       |  17 +-
 .../ignite/p2p/GridP2PHotRedeploymentSelfTest.java |  17 +-
 .../ignite/p2p/GridP2PJobClassLoaderSelfTest.java  |  17 +-
 .../ignite/p2p/GridP2PLocalDeploymentSelfTest.java |  17 +-
 .../GridP2PMissedResourceCacheSizeSelfTest.java    |  17 +-
 .../apache/ignite/p2p/GridP2PNodeLeftSelfTest.java |  17 +-
 .../ignite/p2p/GridP2PRecursionTaskSelfTest.java   |  17 +-
 .../p2p/GridP2PRemoteClassLoadersSelfTest.java     |  17 +-
 .../ignite/p2p/GridP2PSameClassLoaderSelfTest.java |  17 +-
 .../java/org/apache/ignite/p2p/GridP2PTestJob.java |  17 +-
 .../org/apache/ignite/p2p/GridP2PTestTask.java     |  17 +-
 .../ignite/p2p/GridP2PTestTaskExecutionTest.java   |  17 +-
 .../apache/ignite/p2p/GridP2PTimeoutSelfTest.java  |  17 +-
 .../apache/ignite/p2p/GridP2PUndeploySelfTest.java |  17 +-
 .../apache/ignite/p2p/GridSwapSpaceCustomKey.java  |  17 +-
 .../ignite/p2p/GridSwapSpaceCustomValue.java       |  17 +-
 .../ignite/p2p/P2PScanQueryUndeployTest.java       |  17 +-
 .../ignite/p2p/P2PStreamingClassLoaderTest.java    |  17 +-
 .../apache/ignite/p2p/SharedDeploymentTest.java    |  17 +-
 .../java/org/apache/ignite/p2p/package-info.java   |  17 +-
 .../test/java/org/apache/ignite/package-info.java  |  17 +-
 .../platform/PlatformAttributeNodeFilter.java      |  17 +-
 .../platform/PlatformCacheEntryEventFilter.java    |  17 +-
 .../PlatformCacheEntryEventFilterFactory.java      |  17 +-
 .../platform/PlatformCacheWriteMetricsTask.java    |  17 +-
 .../platform/PlatformComputeBinarizable.java       |  17 +-
 .../PlatformComputeBinarizableArgTask.java         |  17 +-
 .../platform/PlatformComputeBroadcastTask.java     |  17 +-
 .../platform/PlatformComputeDecimalTask.java       |  17 +-
 .../ignite/platform/PlatformComputeEchoTask.java   |  17 +-
 .../ignite/platform/PlatformComputeEnum.java       |  17 +-
 .../platform/PlatformComputeJavaBinarizable.java   |  17 +-
 .../PlatformDefaultJavaObjectFactorySelfTest.java  |  17 +-
 .../ignite/platform/PlatformDeployServiceTask.java |  17 +-
 .../platform/PlatformEventsWriteEventTask.java     |  17 +-
 .../ignite/platform/PlatformExceptionTask.java     |  17 +-
 .../PlatformJavaObjectFactoryProxySelfTest.java    |  17 +-
 .../ignite/platform/PlatformMaxMemoryTask.java     |  17 +-
 .../ignite/platform/PlatformMinMemoryTask.java     |  17 +-
 .../ignite/platform/PlatformSqlQueryTask.java      |  17 +-
 .../ignite/platform/PlatformStartIgniteTask.java   |  17 +-
 .../ignite/platform/PlatformStopIgniteTask.java    |  17 +-
 .../ignite/platform/PlatformStringTestTask.java    |  17 +-
 .../ignite/platform/javaobject/TestJavaObject.java |  17 +-
 .../javaobject/TestJavaObjectNoDefaultCtor.java    |  17 +-
 .../TestJavaObjectNoDefaultCtorFactory.java        |  17 +-
 .../lifecycle/PlatformJavaLifecycleBean.java       |  17 +-
 .../lifecycle/PlatformJavaLifecycleTask.java       |  17 +-
 .../plugin/NodeValidationPluginProvider.java       |  17 +-
 .../ignite/plugin/PluginNodeValidationTest.java    |  17 +-
 .../security/SecurityPermissionSetBuilderTest.java |  17 +-
 .../ignite/services/ServiceThreadPoolSelfTest.java |  17 +-
 ...ridSessionCancelSiblingsFromFutureSelfTest.java |  17 +-
 .../GridSessionCancelSiblingsFromJobSelfTest.java  |  17 +-
 .../GridSessionCancelSiblingsFromTaskSelfTest.java |  17 +-
 .../GridSessionCheckpointAbstractSelfTest.java     |  17 +-
 .../session/GridSessionCheckpointSelfTest.java     |  17 +-
 .../session/GridSessionCollisionSpiSelfTest.java   |  17 +-
 .../GridSessionFutureWaitJobAttributeSelfTest.java |  17 +-
 ...GridSessionFutureWaitTaskAttributeSelfTest.java |  17 +-
 .../session/GridSessionJobFailoverSelfTest.java    |  17 +-
 .../GridSessionJobWaitTaskAttributeSelfTest.java   |  17 +-
 .../ignite/session/GridSessionLoadSelfTest.java    |  17 +-
 .../GridSessionSetFutureAttributeSelfTest.java     |  17 +-
 ...sionSetFutureAttributeWaitListenerSelfTest.java |  17 +-
 .../GridSessionSetJobAttribute2SelfTest.java       |  17 +-
 .../GridSessionSetJobAttributeOrderSelfTest.java   |  17 +-
 .../GridSessionSetJobAttributeSelfTest.java        |  17 +-
 ...SessionSetJobAttributeWaitListenerSelfTest.java |  17 +-
 .../GridSessionSetTaskAttributeSelfTest.java       |  17 +-
 .../GridSessionTaskWaitJobAttributeSelfTest.java   |  17 +-
 .../session/GridSessionWaitAttributeSelfTest.java  |  17 +-
 .../ignite/session/GridThreadSerialNumber.java     |  17 +-
 .../org/apache/ignite/session/package-info.java    |  17 +-
 .../spi/ExponentialBackoffTimeoutStrategyTest.java |  17 +-
 .../ignite/spi/GridSpiLocalHostInjectionTest.java  |  17 +-
 .../ignite/spi/GridSpiStartStopAbstractTest.java   |  17 +-
 .../org/apache/ignite/spi/GridTcpForwarder.java    |  17 +-
 .../ignite/spi/GridTcpSpiForwardingSelfTest.java   |  17 +-
 .../checkpoint/GridCheckpointSpiAbstractTest.java  |  17 +-
 .../spi/checkpoint/GridCheckpointTestState.java    |  17 +-
 .../cache/CacheCheckpointSpiConfigSelfTest.java    |  17 +-
 .../CacheCheckpointSpiSecondCacheSelfTest.java     |  17 +-
 .../cache/CacheCheckpointSpiSelfTest.java          |  17 +-
 .../cache/CacheCheckpointSpiStartStopSelfTest.java |  17 +-
 .../ignite/spi/checkpoint/cache/package-info.java  |  17 +-
 .../jdbc/JdbcCheckpointSpiConfigSelfTest.java      |  17 +-
 .../JdbcCheckpointSpiCustomConfigSelfTest.java     |  17 +-
 .../JdbcCheckpointSpiDefaultConfigSelfTest.java    |  17 +-
 .../jdbc/JdbcCheckpointSpiStartStopSelfTest.java   |  17 +-
 .../ignite/spi/checkpoint/jdbc/package-info.java   |  17 +-
 .../apache/ignite/spi/checkpoint/package-info.java |  17 +-
 .../GridSharedFsCheckpointSpiConfigSelfTest.java   |  17 +-
 ...SharedFsCheckpointSpiMultiThreadedSelfTest.java |  17 +-
 ...FsCheckpointSpiMultipleDirectoriesSelfTest.java |  17 +-
 .../GridSharedFsCheckpointSpiSelfTest.java         |  17 +-
 ...GridSharedFsCheckpointSpiStartStopSelfTest.java |  17 +-
 .../spi/checkpoint/sharedfs/package-info.java      |  17 +-
 .../spi/collision/GridCollisionTestContext.java    |  17 +-
 .../spi/collision/GridTestCollisionJobContext.java |  17 +-
 .../collision/GridTestCollisionTaskSession.java    |  17 +-
 .../GridFifoQueueCollisionSpiConfigSelfTest.java   |  17 +-
 .../GridFifoQueueCollisionSpiSelfTest.java         |  17 +-
 ...GridFifoQueueCollisionSpiStartStopSelfTest.java |  17 +-
 .../spi/collision/fifoqueue/package-info.java      |  17 +-
 ...dJobStealingCollisionSpiAttributesSelfTest.java |  17 +-
 .../GridJobStealingCollisionSpiConfigSelfTest.java |  17 +-
 ...StealingCollisionSpiCustomTopologySelfTest.java |  17 +-
 .../GridJobStealingCollisionSpiSelfTest.java       |  17 +-
 ...idJobStealingCollisionSpiStartStopSelfTest.java |  17 +-
 .../spi/collision/jobstealing/package-info.java    |  17 +-
 .../apache/ignite/spi/collision/package-info.java  |  17 +-
 ...ridPriorityQueueCollisionSpiConfigSelfTest.java |  17 +-
 .../GridPriorityQueueCollisionSpiSelfTest.java     |  17 +-
 ...PriorityQueueCollisionSpiStartStopSelfTest.java |  17 +-
 .../spi/collision/priorityqueue/package-info.java  |  17 +-
 .../GridAbstractCommunicationSelfTest.java         |  17 +-
 .../communication/GridCacheMessageSelfTest.java    |  17 +-
 .../ignite/spi/communication/GridTestMessage.java  |  17 +-
 .../ignite/spi/communication/package-info.java     |  17 +-
 .../tcp/GridCacheDhtLockBackupSelfTest.java        |  17 +-
 .../tcp/GridTcpCommunicationSpiAbstractTest.java   |  17 +-
 ...pCommunicationSpiConcurrentConnectSelfTest.java |  17 +-
 ...mmunicationSpiConcurrentConnectSslSelfTest.java |  17 +-
 .../tcp/GridTcpCommunicationSpiConfigSelfTest.java |  17 +-
 .../tcp/GridTcpCommunicationSpiLanLoadTest.java    |  17 +-
 ...idTcpCommunicationSpiMultithreadedSelfTest.java |  17 +-
 ...dTcpCommunicationSpiMultithreadedShmemTest.java |  17 +-
 ...GridTcpCommunicationSpiRecoveryAckSelfTest.java |  17 +-
 ...icationSpiRecoveryFailureDetectionSelfTest.java |  17 +-
 ...nicationSpiRecoveryNoPairedConnectionsTest.java |  17 +-
 .../GridTcpCommunicationSpiRecoverySelfTest.java   |  17 +-
 ...GridTcpCommunicationSpiRecoverySslSelfTest.java |  17 +-
 .../tcp/GridTcpCommunicationSpiShmemSelfTest.java  |  17 +-
 .../tcp/GridTcpCommunicationSpiSslSelfTest.java    |  17 +-
 ...TcpCommunicationSpiSslSmallBuffersSelfTest.java |  17 +-
 .../GridTcpCommunicationSpiStartStopSelfTest.java  |  17 +-
 ...ommunicationSpiTcpFailureDetectionSelfTest.java |  17 +-
 ...idTcpCommunicationSpiTcpNoDelayOffSelfTest.java |  17 +-
 .../tcp/GridTcpCommunicationSpiTcpSelfTest.java    |  17 +-
 .../tcp/IgniteCacheSslStartStopSelfTest.java       |  17 +-
 .../IgniteTcpCommunicationConnectOnInitTest.java   |  17 +-
 ...IgniteTcpCommunicationHandshakeWaitSslTest.java |  17 +-
 .../IgniteTcpCommunicationHandshakeWaitTest.java   |  17 +-
 ...TcpCommunicationRecoveryAckClosureSelfTest.java |  17 +-
 .../tcp/TcpCommunicationSpiDropNodesTest.java      |  17 +-
 .../TcpCommunicationSpiFaultyClientSslTest.java    |  17 +-
 .../tcp/TcpCommunicationSpiFaultyClientTest.java   |  17 +-
 .../tcp/TcpCommunicationSpiFreezingClientTest.java |  17 +-
 ...cpCommunicationSpiHalfOpenedConnectionTest.java |  17 +-
 .../TcpCommunicationSpiSkipMessageSendTest.java    |  17 +-
 .../tcp/TcpCommunicationStatisticsTest.java        |  17 +-
 .../ignite/spi/communication/tcp/package-info.java |  17 +-
 .../local/GridLocalDeploymentSpiSelfTest.java      |  17 +-
 .../GridLocalDeploymentSpiStartStopSelfTest.java   |  17 +-
 .../ignite/spi/deployment/local/package-info.java  |  17 +-
 .../AbstractDiscoveryRandomStartStopTest.java      |  17 +-
 .../spi/discovery/AbstractDiscoverySelfTest.java   |  17 +-
 .../spi/discovery/AbstractDiscoveryTest.java       |  17 +-
 .../spi/discovery/AuthenticationRestartTest.java   |  17 +-
 ...rMetricsSnapshotSerializeCompatibilityTest.java |  17 +-
 .../ClusterMetricsSnapshotSerializeSelfTest.java   |  17 +-
 .../FilterDataForClientNodeDiscoveryTest.java      |  17 +-
 .../IgniteDiscoveryCacheReuseSelfTest.java         |  17 +-
 .../discovery/LongClientConnectToClusterTest.java  |  17 +-
 .../apache/ignite/spi/discovery/package-info.java  |  17 +-
 .../tcp/DiscoveryUnmarshalVulnerabilityTest.java   |  17 +-
 .../discovery/tcp/IgniteClientConnectSslTest.java  |  17 +-
 .../spi/discovery/tcp/IgniteClientConnectTest.java |  17 +-
 ...gniteClientReconnectMassiveShutdownSslTest.java |  17 +-
 .../IgniteClientReconnectMassiveShutdownTest.java  |  17 +-
 .../TcpClientDiscoveryMarshallerCheckSelfTest.java |  17 +-
 ...TcpClientDiscoverySpiCoordinatorChangeTest.java |  17 +-
 ...cpClientDiscoverySpiFailureTimeoutSelfTest.java |  17 +-
 .../tcp/TcpClientDiscoverySpiMulticastTest.java    |  17 +-
 .../tcp/TcpClientDiscoverySpiSelfTest.java         |  17 +-
 .../tcp/TcpClientDiscoveryUnresolvedHostTest.java  |  17 +-
 .../tcp/TcpDiscoveryClientSuspensionSelfTest.java  |  17 +-
 .../tcp/TcpDiscoveryConcurrentStartTest.java       |  17 +-
 .../tcp/TcpDiscoveryCoordinatorFailureTest.java    |  17 +-
 .../discovery/tcp/TcpDiscoveryFailedJoinTest.java  |  17 +-
 .../tcp/TcpDiscoveryIpFinderCleanerTest.java       |  17 +-
 .../tcp/TcpDiscoveryMarshallerCheckSelfTest.java   |  17 +-
 .../tcp/TcpDiscoveryMultiThreadedTest.java         |  17 +-
 .../tcp/TcpDiscoveryNetworkIssuesTest.java         |  17 +-
 ...scoveryNodeAttributesUpdateOnReconnectTest.java |  17 +-
 ...TcpDiscoveryNodeConfigConsistentIdSelfTest.java |  17 +-
 .../tcp/TcpDiscoveryNodeConsistentIdSelfTest.java  |  17 +-
 .../tcp/TcpDiscoveryNodeJoinAndFailureTest.java    |  17 +-
 .../TcpDiscoveryPendingMessageDeliveryTest.java    |  17 +-
 .../TcpDiscoveryReconnectUnstableTopologyTest.java |  17 +-
 .../spi/discovery/tcp/TcpDiscoveryRestartTest.java |  17 +-
 .../tcp/TcpDiscoverySegmentationPolicyTest.java    |  17 +-
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java    |  17 +-
 .../tcp/TcpDiscoverySnapshotHistoryTest.java       |  17 +-
 .../tcp/TcpDiscoverySpiConfigSelfTest.java         |  17 +-
 .../tcp/TcpDiscoverySpiFailureTimeoutSelfTest.java |  17 +-
 .../discovery/tcp/TcpDiscoverySpiMBeanTest.java    |  17 +-
 .../tcp/TcpDiscoverySpiRandomStartStopTest.java    |  17 +-
 .../tcp/TcpDiscoverySpiReconnectDelayTest.java     |  17 +-
 .../spi/discovery/tcp/TcpDiscoverySpiSelfTest.java |  17 +-
 .../discovery/tcp/TcpDiscoverySpiSslSelfTest.java  |  17 +-
 .../tcp/TcpDiscoverySpiStartStopSelfTest.java      |  17 +-
 .../tcp/TcpDiscoverySpiWildcardSelfTest.java       |  17 +-
 .../tcp/TcpDiscoverySslParametersTest.java         |  17 +-
 .../tcp/TcpDiscoverySslSecuredUnsecuredTest.java   |  17 +-
 .../spi/discovery/tcp/TcpDiscoverySslSelfTest.java |  17 +-
 .../tcp/TcpDiscoverySslTrustedSelfTest.java        |  17 +-
 .../tcp/TcpDiscoverySslTrustedUntrustedTest.java   |  17 +-
 .../tcp/TcpDiscoveryWithWrongServerTest.java       |  17 +-
 .../discovery/tcp/TestReconnectPluginProvider.java |  17 +-
 .../spi/discovery/tcp/TestReconnectProcessor.java  |  17 +-
 .../spi/discovery/tcp/TestTcpDiscoverySpi.java     |  27 ++-
 .../TcpDiscoveryIpFinderAbstractSelfTest.java      |  17 +-
 .../jdbc/TcpDiscoveryJdbcIpFinderSelfTest.java     |  17 +-
 .../discovery/tcp/ipfinder/jdbc/package-info.java  |  17 +-
 .../TcpDiscoveryMulticastIpFinderSelfTest.java     |  17 +-
 .../spi/discovery/tcp/ipfinder/package-info.java   |  17 +-
 .../TcpDiscoverySharedFsIpFinderSelfTest.java      |  17 +-
 .../tcp/ipfinder/sharedfs/package-info.java        |  17 +-
 .../vm/TcpDiscoveryVmIpFinderSelfTest.java         |  17 +-
 .../discovery/tcp/ipfinder/vm/package-info.java    |  17 +-
 .../ignite/spi/discovery/tcp/package-info.java     |  17 +-
 .../encryption/KeystoreEncryptionSpiSelfTest.java  |  17 +-
 ...ridMemoryEventStorageMultiThreadedSelfTest.java |  17 +-
 .../GridMemoryEventStorageSpiConfigSelfTest.java   |  17 +-
 .../memory/GridMemoryEventStorageSpiSelfTest.java  |  17 +-
 ...GridMemoryEventStorageSpiStartStopSelfTest.java |  17 +-
 .../spi/eventstorage/memory/package-info.java      |  17 +-
 .../spi/failover/GridFailoverTestContext.java      |  17 +-
 .../GridAlwaysFailoverSpiConfigSelfTest.java       |  17 +-
 .../always/GridAlwaysFailoverSpiSelfTest.java      |  17 +-
 .../GridAlwaysFailoverSpiStartStopSelfTest.java    |  17 +-
 .../ignite/spi/failover/always/package-info.java   |  17 +-
 .../GridJobStealingFailoverSpiConfigSelfTest.java  |  17 +-
 .../GridJobStealingFailoverSpiOneNodeSelfTest.java |  17 +-
 .../GridJobStealingFailoverSpiSelfTest.java        |  17 +-
 ...ridJobStealingFailoverSpiStartStopSelfTest.java |  17 +-
 .../spi/failover/jobstealing/package-info.java     |  17 +-
 .../never/GridNeverFailoverSpiSelfTest.java        |  17 +-
 .../GridNeverFailoverSpiStartStopSelfTest.java     |  17 +-
 .../ignite/spi/failover/never/package-info.java    |  17 +-
 .../apache/ignite/spi/failover/package-info.java   |  17 +-
 ...GridAdaptiveLoadBalancingSpiConfigSelfTest.java |  17 +-
 ...aptiveLoadBalancingSpiMultipleNodeSelfTest.java |  17 +-
 .../GridAdaptiveLoadBalancingSpiSelfTest.java      |  17 +-
 ...dAdaptiveLoadBalancingSpiStartStopSelfTest.java |  17 +-
 .../spi/loadbalancing/adaptive/package-info.java   |  17 +-
 .../GridInternalTasksLoadBalancingSelfTest.java    |  17 +-
 .../ignite/spi/loadbalancing/package-info.java     |  17 +-
 ...adBalancingNotPerTaskMultithreadedSelfTest.java |  17 +-
 ...oundRobinLoadBalancingSpiLocalNodeSelfTest.java |  17 +-
 ...RobinLoadBalancingSpiMultipleNodesSelfTest.java |  17 +-
 ...undRobinLoadBalancingSpiNotPerTaskSelfTest.java |  17 +-
 ...oundRobinLoadBalancingSpiStartStopSelfTest.java |  17 +-
 ...obinLoadBalancingSpiTopologyChangeSelfTest.java |  17 +-
 .../roundrobin/GridRoundRobinTestUtils.java        |  17 +-
 .../spi/loadbalancing/roundrobin/package-info.java |  17 +-
 ...ightedRandomLoadBalancingSpiConfigSelfTest.java |  17 +-
 ...GridWeightedRandomLoadBalancingSpiSelfTest.java |  17 +-
 ...tedRandomLoadBalancingSpiStartStopSelfTest.java |  17 +-
 ...htedRandomLoadBalancingSpiWeightedSelfTest.java |  17 +-
 .../loadbalancing/weightedrandom/package-info.java |  17 +-
 .../java/org/apache/ignite/spi/package-info.java   |  17 +-
 .../startup/GridRandomCommandLineLoader.java       |  17 +-
 .../apache/ignite/startup/GridVmNodesStarter.java  |  17 +-
 .../startup/cmdline/GridCommandLineLoaderTest.java |  17 +-
 .../GridCommandLineTransformerSelfTest.java        |  17 +-
 .../ignite/startup/cmdline/package-info.java       |  17 +-
 .../org/apache/ignite/startup/package-info.java    |  17 +-
 .../properties/NotStringSystemPropertyTest.java    |  17 +-
 .../startup/servlet/GridServletLoaderTest.java     |  17 +-
 .../ignite/startup/servlet/package-info.java       |  17 +-
 .../stream/socket/SocketStreamerSelfTest.java      |  17 +-
 .../SocketStreamerUnmarshalVulnerabilityTest.java  |  17 +-
 .../apache/ignite/stream/socket/package-info.java  |  17 +-
 .../apache/ignite/testframework/GridFileLock.java  |  17 +-
 .../ignite/testframework/GridJarClassLoader.java   |  17 +-
 .../ignite/testframework/GridLoadTestUtils.java    |  17 +-
 .../ignite/testframework/GridSpiTestContext.java   |  17 +-
 .../ignite/testframework/GridStringLogger.java     |  17 +-
 .../ignite/testframework/GridTestClassLoader.java  |  17 +-
 .../testframework/GridTestExternalClassLoader.java |  17 +-
 .../apache/ignite/testframework/GridTestNode.java  |  17 +-
 .../testframework/GridTestSafeThreadFactory.java   |  17 +-
 .../ignite/testframework/GridTestThread.java       |  17 +-
 .../apache/ignite/testframework/GridTestUtils.java |  17 +-
 .../ignite/testframework/ListeningTestLogger.java  |  17 +-
 .../apache/ignite/testframework/LogListener.java   |  17 +-
 .../ignite/testframework/MvccFeatureChecker.java   |  17 +-
 .../testframework/assertions/AlwaysAssertion.java  |  17 +-
 .../ignite/testframework/assertions/Assertion.java |  17 +-
 .../testframework/assertions/package-info.java     |  17 +-
 .../testframework/config/GridTestProperties.java   |  17 +-
 .../ignite/testframework/config/package-info.java  |  17 +-
 .../configvariations/CacheStartMode.java           |  17 +-
 .../configvariations/ConfigFactory.java            |  17 +-
 .../configvariations/ConfigParameter.java          |  17 +-
 .../configvariations/ConfigVariations.java         |  17 +-
 .../configvariations/ConfigVariationsFactory.java  |  17 +-
 .../ConfigVariationsTestSuiteBuilder.java          |  17 +-
 .../testframework/configvariations/Parameters.java |  17 +-
 .../configvariations/VariationsIterator.java       |  17 +-
 .../configvariations/VariationsTestsConfig.java    |  17 +-
 .../testframework/http/GridEmbeddedHttpServer.java |  17 +-
 .../ignite/testframework/http/package-info.java    |  17 +-
 .../ignite/testframework/junits/DynamicSuite.java  |  17 +-
 .../testframework/junits/GridAbstractTest.java     |  17 +-
 .../junits/GridTestKernalContext.java              |  17 +-
 .../IgniteCacheConfigVariationsAbstractTest.java   |  17 +-
 .../junits/IgniteConfigVariationsAbstractTest.java |  17 +-
 .../ignite/testframework/junits/IgniteMock.java    |  17 +-
 .../testframework/junits/IgniteTestResources.java  |  17 +-
 .../junits/JUnit3TestLegacySupport.java            |  17 +-
 .../testframework/junits/JUnitAssertAware.java     |  17 +-
 .../testframework/junits/SystemPropertiesList.java |  17 +-
 .../testframework/junits/WithSystemProperty.java   |  17 +-
 .../cache/GridAbstractCacheStoreSelfTest.java      |  17 +-
 .../junits/cache/TestCacheSession.java             |  17 +-
 .../junits/cache/TestThreadLocalCacheSession.java  |  17 +-
 .../junits/common/GridAbstractExamplesTest.java    |  17 +-
 .../common/GridAbstractLifecycleAwareSelfTest.java |  17 +-
 .../junits/common/GridCommonAbstractTest.java      |  17 +-
 .../junits/common/GridCommonTest.java              |  17 +-
 .../common/GridRollingRestartAbstractTest.java     |  17 +-
 .../testframework/junits/common/package-info.java  |  17 +-
 .../logger/GridLog4jRollingFileAppender.java       |  17 +-
 .../junits/logger/GridTestLog4jLogger.java         |  17 +-
 .../junits/multijvm/AffinityProcessProxy.java      |  17 +-
 .../junits/multijvm/IgniteCacheProcessProxy.java   |  17 +-
 .../junits/multijvm/IgniteClusterProcessProxy.java |  17 +-
 .../junits/multijvm/IgniteEventsProcessProxy.java  |  17 +-
 .../junits/multijvm/IgniteNodeRunner.java          |  17 +-
 .../junits/multijvm/IgniteProcessProxy.java        |  17 +-
 .../ignite/testframework/junits/package-info.java  |  17 +-
 .../junits/spi/GridSpiAbstractConfigTest.java      |  17 +-
 .../junits/spi/GridSpiAbstractTest.java            |  17 +-
 .../testframework/junits/spi/GridSpiTest.java      |  17 +-
 .../junits/spi/GridSpiTestConfig.java              |  17 +-
 .../testframework/junits/spi/package-info.java     |  17 +-
 .../apache/ignite/testframework/package-info.java  |  17 +-
 .../test/ConfigVariationsTestSuiteBuilderTest.java |  17 +-
 .../test/ListeningTestLoggerTest.java              |  17 +-
 .../ignite/testframework/test/ParametersTest.java  |  17 +-
 .../testframework/test/VariationsIteratorTest.java |  17 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java    |  17 +-
 .../IgniteBasicWithPersistenceTestSuite.java       |  17 +-
 .../testsuites/IgniteBinaryCacheTestSuite.java     |  17 +-
 .../IgniteBinaryObjectsCacheTestSuite3.java        |  17 +-
 .../IgniteBinaryObjectsComputeGridTestSuite.java   |  17 +-
 ...bjectsSimpleNameMapperComputeGridTestSuite.java |  17 +-
 .../testsuites/IgniteBinaryObjectsTestSuite.java   |  17 +-
 ...IgniteBinarySimpleNameMapperBasicTestSuite.java |  17 +-
 ...inarySimpleNameMapperCacheFullApiTestSuite.java |  17 +-
 ...CacheBasicConfigVariationsFullApiTestSuite.java |  17 +-
 ...acheBlockExchangeOnReadOperationsTestSuite.java |  17 +-
 ...niteCacheDataStructuresBinarySelfTestSuite.java |  17 +-
 .../IgniteCacheDataStructuresSelfTestSuite.java    |  17 +-
 .../IgniteCacheEvictionSelfTestSuite.java          |  17 +-
 .../testsuites/IgniteCacheFailoverTestSuite.java   |  17 +-
 .../testsuites/IgniteCacheFailoverTestSuite2.java  |  17 +-
 .../testsuites/IgniteCacheFailoverTestSuite3.java  |  17 +-
 .../IgniteCacheFailoverTestSuiteSsl.java           |  27 ++-
 .../IgniteCacheFullApiMultiJvmSelfTestSuite.java   |  17 +-
 .../IgniteCacheFullApiSelfTestSuite.java           |  17 +-
 .../IgniteCacheIteratorsSelfTestSuite.java         |  17 +-
 .../IgniteCacheLoadConsistencyTestSuite.java       |  17 +-
 .../IgniteCacheMetricsSelfTestSuite.java           |  17 +-
 .../testsuites/IgniteCacheMvccTestSuite.java       |  17 +-
 .../testsuites/IgniteCacheMvccTestSuite1.java      |  17 +-
 .../testsuites/IgniteCacheMvccTestSuite2.java      |  17 +-
 .../testsuites/IgniteCacheMvccTestSuite3.java      |  17 +-
 .../testsuites/IgniteCacheMvccTestSuite4.java      |  17 +-
 .../testsuites/IgniteCacheMvccTestSuite5.java      |  17 +-
 .../testsuites/IgniteCacheMvccTestSuite6.java      |  17 +-
 .../testsuites/IgniteCacheMvccTestSuite7.java      |  17 +-
 .../testsuites/IgniteCacheMvccTestSuite8.java      |  17 +-
 .../testsuites/IgniteCacheMvccTestSuite9.java      |  17 +-
 .../IgniteCacheNearOnlySelfTestSuite.java          |  17 +-
 .../IgniteCacheP2pUnmarshallingErrorTestSuite.java |  17 +-
 .../testsuites/IgniteCacheRestartTestSuite.java    |  17 +-
 .../testsuites/IgniteCacheRestartTestSuite2.java   |  17 +-
 .../IgniteCacheTcpClientDiscoveryTestSuite.java    |  17 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java    |  17 +-
 .../ignite/testsuites/IgniteCacheTestSuite2.java   |  17 +-
 .../ignite/testsuites/IgniteCacheTestSuite3.java   |  17 +-
 .../ignite/testsuites/IgniteCacheTestSuite4.java   |  17 +-
 .../ignite/testsuites/IgniteCacheTestSuite5.java   |  17 +-
 .../ignite/testsuites/IgniteCacheTestSuite6.java   |  17 +-
 .../ignite/testsuites/IgniteCacheTestSuite7.java   |  17 +-
 .../ignite/testsuites/IgniteCacheTestSuite8.java   |  17 +-
 .../ignite/testsuites/IgniteCacheTestSuite9.java   |  17 +-
 .../IgniteCacheTxRecoverySelfTestSuite.java        |  17 +-
 .../IgniteCacheWriteBehindTestSuite.java           |  17 +-
 .../testsuites/IgniteClientNodesTestSuite.java     |  17 +-
 .../testsuites/IgniteClientReconnectTestSuite.java |  17 +-
 ...mputeBasicConfigVariationsFullApiTestSuite.java |  17 +-
 .../testsuites/IgniteComputeGridTestSuite.java     |  17 +-
 ...IgniteContinuousQueryConfigVariationsSuite.java |  17 +-
 .../IgniteContinuousTaskSelfTestSuite.java         |  17 +-
 .../ignite/testsuites/IgniteDatabaseTestSuite.java |  17 +-
 .../testsuites/IgniteDbMemoryLeakTestSuite.java    |  17 +-
 .../IgniteExternalizableSelfTestSuite.java         |  17 +-
 .../ignite/testsuites/IgniteIgfsTestSuite.java     |  17 +-
 .../IgniteIpcSharedMemorySelfTestSuite.java        |  17 +-
 .../ignite/testsuites/IgniteIpcTestSuite.java      |  29 ++-
 .../testsuites/IgniteJobMetricsSelfTestSuite.java  |  17 +-
 .../testsuites/IgniteKernalSelfTestSuite.java      |  17 +-
 .../ignite/testsuites/IgniteLangSelfTestSuite.java |  17 +-
 .../testsuites/IgniteLoggingSelfTestSuite.java     |  17 +-
 .../testsuites/IgniteLostAndFoundTestSuite.java    |  17 +-
 .../testsuites/IgniteMarshallerSelfTestSuite.java  |  17 +-
 ...teMessagingConfigVariationFullApiTestSuite.java |  17 +-
 .../ignite/testsuites/IgniteP2PSelfTestSuite.java  |  17 +-
 .../ignite/testsuites/IgnitePdsMvccTestSuite.java  |  17 +-
 .../ignite/testsuites/IgnitePdsMvccTestSuite2.java |  17 +-
 .../ignite/testsuites/IgnitePdsMvccTestSuite3.java |  17 +-
 .../ignite/testsuites/IgnitePdsMvccTestSuite4.java |  17 +-
 .../ignite/testsuites/IgnitePdsTestSuite.java      |  17 +-
 .../ignite/testsuites/IgnitePdsTestSuite2.java     |  17 +-
 .../ignite/testsuites/IgnitePdsTestSuite3.java     |  17 +-
 .../ignite/testsuites/IgnitePdsTestSuite4.java     |  17 +-
 .../ignite/testsuites/IgnitePdsUnitTestSuite.java  |  17 +-
 .../testsuites/IgnitePerformanceTestSuite.java     |  17 +-
 .../testsuites/IgnitePlatformsTestSuite.java       |  17 +-
 .../ignite/testsuites/IgniteReproducingSuite.java  |  17 +-
 .../testsuites/IgniteRestHandlerTestSuite.java     |  17 +-
 ...iteServiceConfigVariationsFullApiTestSuite.java |  17 +-
 .../testsuites/IgniteServiceGridTestSuite.java     |  17 +-
 .../IgniteSpiCheckpointSelfTestSuite.java          |  17 +-
 .../IgniteSpiCollisionSelfTestSuite.java           |  17 +-
 .../IgniteSpiCommunicationSelfTestSuite.java       |  17 +-
 .../IgniteSpiDeploymentSelfTestSuite.java          |  17 +-
 .../IgniteSpiDiscoverySelfTestSuite.java           |  17 +-
 .../IgniteSpiEventStorageSelfTestSuite.java        |  17 +-
 .../testsuites/IgniteSpiFailoverSelfTestSuite.java |  17 +-
 .../IgniteSpiLoadBalancingSelfTestSuite.java       |  17 +-
 .../ignite/testsuites/IgniteSpiTestSuite.java      |  17 +-
 .../testsuites/IgniteStandByClusterSuite.java      |  17 +-
 .../ignite/testsuites/IgniteStartUpTestSuite.java  |  17 +-
 .../testsuites/IgniteStreamSelfTestSuite.java      |  17 +-
 .../testsuites/IgniteTaskSessionSelfTestSuite.java |  17 +-
 .../IgniteTimeoutProcessorSelfTestSuite.java       |  17 +-
 .../IgniteTopologyValidatorTestSuite.java          |  27 ++-
 .../ignite/testsuites/IgniteUtilSelfTestSuite.java |  17 +-
 ...eptorCacheConfigVariationsFullApiTestSuite.java |  17 +-
 .../testsuites/TxDeadlockDetectionTestSuite.java   |  17 +-
 ...inaryCacheConfigVariationsFullApiTestSuite.java |  17 +-
 .../org/apache/ignite/testsuites/package-info.java |  17 +-
 .../GridThreadPoolExecutorServiceSelfTest.java     |  17 +-
 .../org/apache/ignite/thread/GridThreadTest.java   |  17 +-
 .../ignite/thread/IgniteThreadPoolSizeTest.java    |  17 +-
 .../ignite/util/AttributeNodeFilterSelfTest.java   |  17 +-
 .../ignite/util/GridCommandHandlerSslTest.java     |  17 +-
 .../apache/ignite/util/GridCommandHandlerTest.java |  17 +-
 ...GridConcurrentLinkedDequeMultiThreadedTest.java |  17 +-
 .../util/GridConcurrentLinkedDequeSelfTest.java    |  17 +-
 ...ncurrentLinkedHashMapMultiThreadedSelfTest.java |  17 +-
 .../apache/ignite/util/GridIntListSelfTest.java    |  17 +-
 .../GridInternalTaskUnusedWalSegmentsTest.java     |  17 +-
 .../apache/ignite/util/GridLogThrottleTest.java    |  17 +-
 .../apache/ignite/util/GridLongListSelfTest.java   |  17 +-
 .../ignite/util/GridMessageCollectionTest.java     |  17 +-
 .../ignite/util/GridPartitionMapSelfTest.java      |  17 +-
 .../org/apache/ignite/util/GridQueueSelfTest.java  |  17 +-
 .../org/apache/ignite/util/GridRandomSelfTest.java |  17 +-
 .../ignite/util/GridSnapshotLockSelfTest.java      |  17 +-
 .../ignite/util/GridSpinReadWriteLockSelfTest.java |  17 +-
 .../util/GridStringBuilderFactorySelfTest.java     |  17 +-
 .../ignite/util/GridTopologyHeapSizeSelfTest.java  |  17 +-
 .../org/apache/ignite/util/GridTransientTest.java  |  17 +-
 .../ignite/util/TestTcpCommunicationSpi.java       |  13 +-
 .../ignite/util/mbeans/GridMBeanBaselineTest.java  |  17 +-
 .../util/mbeans/GridMBeanDisableSelfTest.java      |  17 +-
 .../util/mbeans/GridMBeanExoticNamesSelfTest.java  |  17 +-
 .../ignite/util/mbeans/GridMBeanSelfTest.java      |  17 +-
 .../util/mbeans/WorkersControlMXBeanTest.java      |  17 +-
 .../java/org/apache/ignite/util/package-info.java  |  17 +-
 .../test/webapp/META-INF/ignite-webapp-config.xml  |  27 ++-
 modules/core/src/test/webapp/WEB-INF/web.xml       |  27 ++-
 modules/dev-utils/ignite-modules-test/build.gradle |  17 +-
 .../src/test/java/module-info.java                 |  17 +-
 .../modulestest/IgniteLaunchInModularEnvTest.java  |  17 +-
 modules/dev-utils/licenses/apache-2.0.txt          | 202 ---------------------
 modules/dev-utils/licenses/gg-community.txt        |  13 ++
 modules/dev-utils/pom.xml                          |  37 ++--
 .../development/utils/IgniteWalConverter.java      |  17 +-
 .../development/utils/RecordSizeCountStat.java     |  17 +-
 .../apache/ignite/development/utils/TxWalStat.java |  17 +-
 .../apache/ignite/development/utils/WalStat.java   |  17 +-
 .../ignite/development/utils/package-info.java     |  17 +-
 modules/direct-io/licenses/apache-2.0.txt          | 202 ---------------------
 modules/direct-io/licenses/gg-community.txt        |  13 ++
 modules/direct-io/pom.xml                          |  43 +++--
 .../cache/persistence/file/AlignedBuffers.java     |  17 +-
 .../file/AlignedBuffersDirectFileIO.java           |  17 +-
 .../file/AlignedBuffersDirectFileIOFactory.java    |  17 +-
 .../cache/persistence/file/IgniteNativeIoLib.java  |  17 +-
 .../persistence/file/LinuxNativeIoPlugin.java      |  17 +-
 .../file/LinuxNativeIoPluginProvider.java          |  17 +-
 ...DiskPageCompressionIntegrationDirectIOTest.java |  17 +-
 ...ocalWalModeChangeDuringRebalancingSelfTest.java |  17 +-
 ...NativeIoPdsRecoveryAfterFileCorruptionTest.java |  17 +-
 .../wal/IgniteNativeIoWalFlushFsyncSelfTest.java   |  17 +-
 .../cache/persistence/file/IgniteFileIOTest.java   |  17 +-
 .../file/IgniteNativeIoWithNoPersistenceTest.java  |  17 +-
 .../testsuites/IgnitePdsNativeIoTestSuite.java     |  17 +-
 .../testsuites/IgnitePdsNativeIoTestSuite2.java    |  17 +-
 .../IgnitePdsReplacementNativeIoTest.java          |  17 +-
 modules/extdata/p2p/META-INF/ignite.xml            |  27 ++-
 modules/extdata/p2p/pom.xml                        |  37 ++--
 .../ignite/tests/p2p/AlwaysTruePredicate.java      |  17 +-
 ...heDeploymenComputeWithNestedEntryProcessor.java |  17 +-
 .../p2p/CacheDeploymentAffinityKeyMapper.java      |  17 +-
 .../p2p/CacheDeploymentAlwaysTruePredicate.java    |  17 +-
 .../p2p/CacheDeploymentAlwaysTruePredicate2.java   |  17 +-
 .../p2p/CacheDeploymentBinaryEntryProcessor.java   |  17 +-
 .../CacheDeploymentBinaryObjectEntryProcessor.java |  27 ++-
 ...eploymentCacheEntryEventSerializableFilter.java |  17 +-
 .../p2p/CacheDeploymentCacheEntryListener.java     |  17 +-
 .../CacheDeploymentCachePluginConfiguration.java   |  17 +-
 .../tests/p2p/CacheDeploymentEntryEventFilter.java |  27 ++-
 .../CacheDeploymentEntryEventFilterFactory.java    |  27 ++-
 .../tests/p2p/CacheDeploymentEntryProcessor.java   |  17 +-
 .../CacheDeploymentExternalizableTestValue.java    |  17 +-
 ...CacheDeploymentStoreSessionListenerFactory.java |  17 +-
 .../tests/p2p/CacheDeploymentTestEnumValue.java    |  17 +-
 .../ignite/tests/p2p/CacheDeploymentTestKey.java   |  17 +-
 .../tests/p2p/CacheDeploymentTestStoreFactory.java |  17 +-
 .../ignite/tests/p2p/CacheDeploymentTestTask1.java |  17 +-
 .../ignite/tests/p2p/CacheDeploymentTestTask2.java |  17 +-
 .../ignite/tests/p2p/CacheDeploymentTestTask3.java |  17 +-
 .../ignite/tests/p2p/CacheDeploymentTestValue.java |  17 +-
 .../tests/p2p/CacheDeploymentTestValue2.java       |  17 +-
 .../tests/p2p/CacheDeploymentTestValue3.java       |  27 ++-
 .../apache/ignite/tests/p2p/ExcludeNodeFilter.java |  17 +-
 .../tests/p2p/GridCacheDeploymentTestValue3.java   |  17 +-
 .../ignite/tests/p2p/GridEventConsumeFilter.java   |  17 +-
 .../p2p/GridEventConsumeProjectionPredicate.java   |  17 +-
 .../tests/p2p/GridExternalAffinityFunction.java    |  17 +-
 .../tests/p2p/GridExternalAffinityKeyMapper.java   |  17 +-
 .../tests/p2p/GridP2PAwareTestUserResource.java    |  17 +-
 .../p2p/GridP2PContinuousDeploymentTask1.java      |  17 +-
 .../p2p/GridP2PContinuousDeploymentTask2.java      |  17 +-
 .../tests/p2p/GridP2PEventFilterExternalPath1.java |  17 +-
 .../tests/p2p/GridP2PEventFilterExternalPath2.java |  17 +-
 .../tests/p2p/GridSingleSplitTestJobTarget.java    |  17 +-
 .../ignite/tests/p2p/GridTestMessageListener.java  |  17 +-
 .../ignite/tests/p2p/GridTestMessageTopic.java     |  17 +-
 .../apache/ignite/tests/p2p/JobStealingTask.java   |  17 +-
 .../p2p/NoValueClassOnServerAbstractClient.java    |  17 +-
 .../org/apache/ignite/tests/p2p/NodeFilter.java    |  17 +-
 .../ignite/tests/p2p/NoopCacheEntryProcessor.java  |  17 +-
 .../org/apache/ignite/tests/p2p/NoopService.java   |  17 +-
 .../org/apache/ignite/tests/p2p/NoopService2.java  |  17 +-
 .../ignite/tests/p2p/P2PTestTaskExternalPath1.java |  17 +-
 .../ignite/tests/p2p/P2PTestTaskExternalPath2.java |  17 +-
 .../ignite/tests/p2p/SingleSplitTestTask.java      |  17 +-
 .../apache/ignite/tests/p2p/TestUserResource.java  |  17 +-
 .../cache/CacheNoValueClassOnServerTestClient.java |  17 +-
 .../org/apache/ignite/tests/p2p/cache/Person.java  |  17 +-
 .../apache/ignite/tests/p2p/cache/PersonKey.java   |  17 +-
 .../ignite/tests/p2p/cache/PersonWrapper.java      |  27 ++-
 .../ignite/tests/p2p/compute/ExternalCallable.java |  17 +-
 .../tests/p2p/compute/ExternalCallable1.java       |  17 +-
 .../tests/p2p/compute/ExternalCallable2.java       |  17 +-
 .../DataStructuresNoClassOnServerTestClient.java   |  17 +-
 .../org/apache/ignite/tests/p2p/package-info.java  |  17 +-
 .../tests/p2p/pedicates/BinaryPredicate.java       |  17 +-
 .../tests/p2p/pedicates/CompositePredicate.java    |  17 +-
 .../p2p/pedicates/FirstConsideredPredicate.java    |  17 +-
 .../p2p/pedicates/SecondConsideredPredicate.java   |  17 +-
 .../tests/p2p/startcache/CacheAllNodesFilter.java  |  17 +-
 .../CacheConfigurationP2PTestClient.java           |  17 +-
 .../ignite/tests/p2p/startcache/Organization1.java |  17 +-
 .../ignite/tests/p2p/startcache/Organization2.java |  17 +-
 modules/extdata/platform/licenses/apache-2.0.txt   | 202 ---------------------
 modules/extdata/platform/licenses/gg-community.txt |  13 ++
 modules/extdata/platform/pom.xml                   |  33 ++--
 .../ignite/platform/plugin/PlatformTestPlugin.java |  17 +-
 .../plugin/PlatformTestPluginConfiguration.java    |  17 +-
 ...tformTestPluginConfigurationClosureFactory.java |  17 +-
 .../plugin/PlatformTestPluginException.java        |  17 +-
 .../plugin/PlatformTestPluginExtension.java        |  17 +-
 .../plugin/PlatformTestPluginProvider.java         |  17 +-
 .../platform/plugin/PlatformTestPluginTarget.java  |  17 +-
 .../plugin/cache/PlatformGetCachePluginsTask.java  |  17 +-
 .../PlatformTestCachePluginConfiguration.java      |  17 +-
 ...latformTestCachePluginConfigurationClosure.java |  17 +-
 ...TestCachePluginConfigurationClosureFactory.java |  17 +-
 .../cache/PlatformTestCachePluginProvider.java     |  17 +-
 .../ignite/platform/plugin/cache/package-info.java |  17 +-
 .../ignite/platform/plugin/package-info.java       |  17 +-
 .../extdata/uri/META-INF/bad-classes-ignite.xml    |  27 ++-
 .../uri/META-INF/bad-signed-deployfile-ignite.xml  |  27 ++-
 .../extdata/uri/META-INF/deploydepend-ignite.xml   |  27 ++-
 modules/extdata/uri/META-INF/deploydir-ignite.xml  |  27 ++-
 modules/extdata/uri/META-INF/deployfile-ignite.xml |  27 ++-
 modules/extdata/uri/META-INF/ignite.xml            |  27 ++-
 .../uri/META-INF/well-signed-deployfile-ignite.xml |  27 ++-
 modules/extdata/uri/modules/uri-dependency/pom.xml |  35 ++--
 .../deployment/uri/tasks/GarHelloWorldBean.java    |  27 ++-
 .../src/main/resources/gar-example.properties      |  28 ++-
 modules/extdata/uri/pom.xml                        |  39 ++--
 .../deployment/uri/tasks/GarHelloWorldTask.java    |  27 ++-
 .../tasks/GridUriDeploymentAbstractTestTask.java   |  17 +-
 .../uri/tasks/GridUriDeploymentDependency1.java    |  17 +-
 .../uri/tasks/GridUriDeploymentDependency2.java    |  17 +-
 .../uri/tasks/GridUriDeploymentDependency9.java    |  17 +-
 .../uri/tasks/GridUriDeploymentInnerTestTask.java  |  17 +-
 .../tasks/GridUriDeploymentInterfaceTestTask.java  |  17 +-
 .../tasks/GridUriDeploymentNonePublicTestTask.java |  17 +-
 .../uri/tasks/GridUriDeploymentTestTask0.java      |  17 +-
 .../uri/tasks/GridUriDeploymentTestTask1.java      |  17 +-
 .../uri/tasks/GridUriDeploymentTestTask10.java     |  17 +-
 .../uri/tasks/GridUriDeploymentTestTask11.java     |  17 +-
 .../uri/tasks/GridUriDeploymentTestTask2.java      |  17 +-
 .../uri/tasks/GridUriDeploymentTestTask3.java      |  17 +-
 .../uri/tasks/GridUriDeploymentTestTask4.java      |  17 +-
 .../uri/tasks/GridUriDeploymentTestTask5.java      |  17 +-
 .../uri/tasks/GridUriDeploymentTestTask6.java      |  17 +-
 .../uri/tasks/GridUriDeploymentTestTask8.java      |  17 +-
 .../uri/tasks/GridUriDeploymentTestTask9.java      |  17 +-
 .../tasks/GridUriDeploymentTestWithNameTask0.java  |  17 +-
 .../tasks/GridUriDeploymentTestWithNameTask10.java |  17 +-
 .../tasks/GridUriDeploymentTestWithNameTask11.java |  17 +-
 .../tasks/GridUriDeploymentTestWithNameTask3.java  |  17 +-
 .../tasks/GridUriDeploymentTestWithNameTask4.java  |  17 +-
 .../tasks/GridUriDeploymentTestWithNameTask5.java  |  17 +-
 .../tasks/GridUriDeploymentTestWithNameTask6.java  |  17 +-
 .../tasks/GridUriDeploymentTestWithNameTask7.java  |  17 +-
 .../tasks/GridUriDeploymentTestWithNameTask8.java  |  17 +-
 .../spi/deployment/uri/tasks/gar-spring-bean.xml   |  27 ++-
 .../spi/deployment/uri/tasks/package-info.java     |  17 +-
 .../ignite/spi/deployment/uri/tasks/spring1.xml    |  27 ++-
 .../ignite/spi/deployment/uri/tasks/spring2.xml    |  27 ++-
 .../ignite/spi/deployment/uri/tasks/spring9.xml    |  27 ++-
 .../spi/deployment/uri/tasks/test1.properties      |  18 +-
 .../spi/deployment/uri/tasks/test2.properties      |  18 +-
 .../spi/deployment/uri/tasks/test9.properties      |  18 +-
 .../java/org/apache/ignite/test/test.properties    |  18 +-
 .../ignite/tests/p2p/compute/ExternalCallable.java |  17 +-
 .../tests/p2p/compute/ExternalCallable1.java       |  17 +-
 .../tests/p2p/compute/ExternalCallable2.java       |  17 +-
 modules/flink/licenses/apache-2.0.txt              | 202 ---------------------
 modules/flink/licenses/gg-community.txt            |  13 ++
 modules/flink/pom.xml                              |  41 ++---
 .../org/apache/ignite/sink/flink/IgniteSink.java   |  17 +-
 .../org/apache/ignite/sink/flink/package-info.java |  17 +-
 .../apache/ignite/source/flink/IgniteSource.java   |  17 +-
 .../ignite/source/flink/TaskRemoteFilter.java      |  17 +-
 .../apache/ignite/source/flink/package-info.java   |  17 +-
 .../ignite/sink/flink/FlinkIgniteSinkSelfTest.java |  17 +-
 .../sink/flink/FlinkIgniteSinkSelfTestSuite.java   |  17 +-
 .../source/flink/FlinkIgniteSourceSelfTest.java    |  17 +-
 .../flink/FlinkIgniteSourceSelfTestSuite.java      |  17 +-
 .../flink/src/test/resources/example-ignite.xml    |  27 ++-
 modules/flume/licenses/apache-2.0.txt              | 202 ---------------------
 modules/flume/licenses/gg-community.txt            |  13 ++
 modules/flume/pom.xml                              |  41 ++---
 .../ignite/stream/flume/EventTransformer.java      |  17 +-
 .../org/apache/ignite/stream/flume/IgniteSink.java |  17 +-
 .../ignite/stream/flume/IgniteSinkConstants.java   |  17 +-
 .../apache/ignite/stream/flume/package-info.java   |  27 ++-
 .../apache/ignite/stream/flume/IgniteSinkTest.java |  17 +-
 .../ignite/stream/flume/IgniteSinkTestSuite.java   |  17 +-
 .../ignite/stream/flume/TestEventTransformer.java  |  17 +-
 .../apache/ignite/stream/flume/package-info.java   |  27 ++-
 .../flume/src/test/resources/example-ignite.xml    |  27 ++-
 modules/gce/licenses/apache-2.0.txt                | 202 ---------------------
 modules/gce/licenses/gg-community.txt              |  13 ++
 modules/gce/pom.xml                                |  37 ++--
 .../gce/TcpDiscoveryGoogleStorageIpFinder.java     |  17 +-
 .../discovery/tcp/ipfinder/gce/package-info.java   |  17 +-
 .../TcpDiscoveryGoogleStorageIpFinderSelfTest.java |  17 +-
 .../discovery/tcp/ipfinder/gce/package-info.java   |  17 +-
 .../ignite/testsuites/IgniteGCETestSuite.java      |  17 +-
 modules/geospatial/licenses/apache-2.0.txt         | 202 ---------------------
 modules/geospatial/licenses/gg-community.txt       |  13 ++
 modules/geospatial/pom.xml                         |  37 ++--
 .../query/h2/opt/GridH2SpatialIndex.java           |  17 +-
 .../query/h2/H2IndexesSystemViewTest.java          |  18 +-
 .../query/h2/H2IndexingAbstractGeoSelfTest.java    |  17 +-
 .../processors/query/h2/H2IndexingGeoSelfTest.java |  17 +-
 .../query/h2/H2IndexingSegmentedGeoSelfTest.java   |  17 +-
 .../testsuites/GeoSpatialIndexingTestSuite.java    |  17 +-
 modules/hadoop/config/core-site.ignite.xml         |  27 ++-
 modules/hadoop/config/hive-site.ignite.xml         |  27 ++-
 modules/hadoop/config/mapred-site.ignite.xml       |  27 ++-
 modules/hadoop/licenses/apache-2.0.txt             | 202 ---------------------
 modules/hadoop/licenses/gg-community.txt           |  13 ++
 modules/hadoop/pom.xml                             |  63 +++----
 .../hadoop/fs/BasicHadoopFileSystemFactory.java    |  17 +-
 .../hadoop/fs/CachingHadoopFileSystemFactory.java  |  17 +-
 .../ignite/hadoop/fs/HadoopFileSystemFactory.java  |  17 +-
 .../fs/IgniteHadoopFileSystemCounterWriter.java    |  17 +-
 .../fs/IgniteHadoopIgfsSecondaryFileSystem.java    |  17 +-
 .../hadoop/fs/KerberosHadoopFileSystemFactory.java |  17 +-
 .../org/apache/ignite/hadoop/fs/package-info.java  |  17 +-
 .../hadoop/fs/v1/IgniteHadoopFileSystem.java       |  17 +-
 .../apache/ignite/hadoop/fs/v1/package-info.java   |  17 +-
 .../hadoop/fs/v2/IgniteHadoopFileSystem.java       |  17 +-
 .../apache/ignite/hadoop/fs/v2/package-info.java   |  17 +-
 .../io/BytesWritablePartiallyRawComparator.java    |  17 +-
 .../ignite/hadoop/io/PartiallyRawComparator.java   |  17 +-
 .../org/apache/ignite/hadoop/io/RawMemory.java     |  17 +-
 .../hadoop/io/TextPartiallyRawComparator.java      |  17 +-
 .../org/apache/ignite/hadoop/io/package-info.java  |  17 +-
 .../IgniteHadoopClientProtocolProvider.java        |  17 +-
 .../IgniteHadoopWeightedMapReducePlanner.java      |  17 +-
 .../ignite/hadoop/mapreduce/package-info.java      |  17 +-
 .../planner/HadoopAbstractMapReducePlanner.java    |  17 +-
 .../planner/HadoopTestRoundRobinMrPlanner.java     |  17 +-
 .../apache/ignite/hadoop/planner/package-info.java |  17 +-
 .../ignite/hadoop/util/BasicUserNameMapper.java    |  17 +-
 .../ignite/hadoop/util/ChainedUserNameMapper.java  |  17 +-
 .../ignite/hadoop/util/KerberosUserNameMapper.java |  17 +-
 .../apache/ignite/hadoop/util/UserNameMapper.java  |  17 +-
 .../apache/ignite/hadoop/util/package-info.java    |  17 +-
 .../processors/hadoop/HadoopAttributes.java        |  17 +-
 .../processors/hadoop/HadoopCommonUtils.java       |  17 +-
 .../processors/hadoop/HadoopComponent.java         |  17 +-
 .../internal/processors/hadoop/HadoopContext.java  |  17 +-
 .../processors/hadoop/HadoopExternalSplit.java     |  17 +-
 .../processors/hadoop/HadoopHelperImpl.java        |  17 +-
 .../internal/processors/hadoop/HadoopImpl.java     |  17 +-
 .../processors/hadoop/HadoopMapperUtils.java       |  17 +-
 .../processors/hadoop/HadoopProcessor.java         |  17 +-
 .../internal/processors/hadoop/HadoopSetup.java    |  17 +-
 .../processors/hadoop/HadoopSplitWrapper.java      |  17 +-
 .../hadoop/HadoopTaskCancelledException.java       |  17 +-
 .../hadoop/counter/HadoopCounterAdapter.java       |  17 +-
 .../hadoop/counter/HadoopCountersImpl.java         |  17 +-
 .../hadoop/counter/HadoopLongCounter.java          |  17 +-
 .../hadoop/counter/HadoopPerformanceCounter.java   |  17 +-
 .../hadoop/delegate/HadoopDelegateUtils.java       |  17 +-
 .../HadoopFileSystemCounterWriterDelegate.java     |  17 +-
 .../delegate/HadoopFileSystemFactoryDelegate.java  |  17 +-
 .../HadoopIgfsSecondaryFileSystemDelegate.java     |  17 +-
 .../processors/hadoop/igfs/HadoopIgfsEndpoint.java |  17 +-
 .../hadoop/impl/HadoopMapReduceCounterGroup.java   |  17 +-
 .../hadoop/impl/HadoopMapReduceCounters.java       |  17 +-
 .../processors/hadoop/impl/HadoopUtils.java        |  17 +-
 .../HadoopBasicFileSystemFactoryDelegate.java      |  17 +-
 .../HadoopCachingFileSystemFactoryDelegate.java    |  17 +-
 .../HadoopDefaultFileSystemFactoryDelegate.java    |  17 +-
 .../HadoopFileSystemCounterWriterDelegateImpl.java |  17 +-
 .../HadoopIgfsSecondaryFileSystemDelegateImpl.java |  17 +-
 .../HadoopKerberosFileSystemFactoryDelegate.java   |  17 +-
 .../hadoop/impl/fs/HadoopFileSystemCacheUtils.java |  17 +-
 .../hadoop/impl/fs/HadoopFileSystemsUtils.java     |  17 +-
 .../hadoop/impl/fs/HadoopLazyConcurrentMap.java    |  17 +-
 .../hadoop/impl/fs/HadoopLocalFileSystemV1.java    |  17 +-
 .../hadoop/impl/fs/HadoopLocalFileSystemV2.java    |  17 +-
 .../hadoop/impl/fs/HadoopParameters.java           |  17 +-
 .../hadoop/impl/fs/HadoopRawLocalFileSystem.java   |  17 +-
 .../processors/hadoop/impl/igfs/HadoopIgfs.java    |  17 +-
 .../igfs/HadoopIgfsCommunicationException.java     |  17 +-
 .../processors/hadoop/impl/igfs/HadoopIgfsEx.java  |  17 +-
 .../hadoop/impl/igfs/HadoopIgfsFuture.java         |  17 +-
 .../hadoop/impl/igfs/HadoopIgfsInProc.java         |  17 +-
 .../hadoop/impl/igfs/HadoopIgfsInputStream.java    |  17 +-
 .../processors/hadoop/impl/igfs/HadoopIgfsIo.java  |  17 +-
 .../hadoop/impl/igfs/HadoopIgfsIpcIo.java          |  17 +-
 .../hadoop/impl/igfs/HadoopIgfsIpcIoListener.java  |  17 +-
 .../hadoop/impl/igfs/HadoopIgfsJclLogger.java      |  17 +-
 .../hadoop/impl/igfs/HadoopIgfsOutProc.java        |  17 +-
 .../hadoop/impl/igfs/HadoopIgfsOutputStream.java   |  17 +-
 .../hadoop/impl/igfs/HadoopIgfsProperties.java     |  17 +-
 .../impl/igfs/HadoopIgfsProxyInputStream.java      |  17 +-
 .../impl/igfs/HadoopIgfsProxyOutputStream.java     |  17 +-
 ...pIgfsSecondaryFileSystemPositionedReadable.java |  17 +-
 .../hadoop/impl/igfs/HadoopIgfsStreamDelegate.java |  17 +-
 .../impl/igfs/HadoopIgfsStreamEventListener.java   |  17 +-
 .../hadoop/impl/igfs/HadoopIgfsUtils.java          |  17 +-
 .../hadoop/impl/igfs/HadoopIgfsWrapper.java        |  17 +-
 .../hadoop/impl/proto/HadoopClientProtocol.java    |  17 +-
 .../hadoop/impl/v1/HadoopV1CleanupTask.java        |  17 +-
 .../processors/hadoop/impl/v1/HadoopV1Counter.java |  17 +-
 .../processors/hadoop/impl/v1/HadoopV1MapTask.java |  17 +-
 .../hadoop/impl/v1/HadoopV1OutputCollector.java    |  17 +-
 .../hadoop/impl/v1/HadoopV1Partitioner.java        |  17 +-
 .../hadoop/impl/v1/HadoopV1ReduceTask.java         |  17 +-
 .../hadoop/impl/v1/HadoopV1Reporter.java           |  17 +-
 .../hadoop/impl/v1/HadoopV1SetupTask.java          |  17 +-
 .../hadoop/impl/v1/HadoopV1Splitter.java           |  17 +-
 .../processors/hadoop/impl/v1/HadoopV1Task.java    |  17 +-
 .../processors/hadoop/impl/v2/HadoopDaemon.java    |  17 +-
 .../hadoop/impl/v2/HadoopSerializationWrapper.java |  17 +-
 .../hadoop/impl/v2/HadoopShutdownHookManager.java  |  17 +-
 .../hadoop/impl/v2/HadoopV2CleanupTask.java        |  17 +-
 .../processors/hadoop/impl/v2/HadoopV2Context.java |  17 +-
 .../processors/hadoop/impl/v2/HadoopV2Counter.java |  17 +-
 ...pV2DelegatingPartiallyOffheapRawComparator.java |  17 +-
 .../processors/hadoop/impl/v2/HadoopV2Job.java     |  17 +-
 .../hadoop/impl/v2/HadoopV2JobResourceManager.java |  17 +-
 .../processors/hadoop/impl/v2/HadoopV2MapTask.java |  17 +-
 .../hadoop/impl/v2/HadoopV2Partitioner.java        |  17 +-
 .../hadoop/impl/v2/HadoopV2ReduceTask.java         |  17 +-
 .../hadoop/impl/v2/HadoopV2SetupTask.java          |  17 +-
 .../hadoop/impl/v2/HadoopV2Splitter.java           |  17 +-
 .../processors/hadoop/impl/v2/HadoopV2Task.java    |  17 +-
 .../hadoop/impl/v2/HadoopV2TaskContext.java        |  17 +-
 .../impl/v2/HadoopWritableSerialization.java       |  17 +-
 .../processors/hadoop/io/OffheapRawMemory.java     |  17 +-
 .../hadoop/jobtracker/HadoopJobMetadata.java       |  17 +-
 .../hadoop/jobtracker/HadoopJobTracker.java        |  17 +-
 .../hadoop/mapreduce/MapReduceClient.java          |  17 +-
 .../hadoop/planner/HadoopDefaultMapReducePlan.java |  17 +-
 .../hadoop/planner/HadoopMapReducePlanGroup.java   |  17 +-
 .../planner/HadoopMapReducePlanTopology.java       |  17 +-
 .../proto/HadoopProtocolJobCountersTask.java       |  17 +-
 .../hadoop/proto/HadoopProtocolJobStatusTask.java  |  17 +-
 .../hadoop/proto/HadoopProtocolKillJobTask.java    |  17 +-
 .../hadoop/proto/HadoopProtocolNextTaskIdTask.java |  17 +-
 .../hadoop/proto/HadoopProtocolSubmitJobTask.java  |  17 +-
 .../hadoop/proto/HadoopProtocolTaskAdapter.java    |  17 +-
 .../hadoop/proto/HadoopProtocolTaskArguments.java  |  17 +-
 .../processors/hadoop/shuffle/HadoopShuffle.java   |  17 +-
 .../hadoop/shuffle/HadoopShuffleJob.java           |  17 +-
 .../hadoop/shuffle/HadoopShuffleLocalState.java    |  17 +-
 .../hadoop/shuffle/HadoopShuffleRemoteState.java   |  17 +-
 .../collections/HadoopConcurrentHashMultimap.java  |  17 +-
 .../shuffle/collections/HadoopHashMultimap.java    |  17 +-
 .../collections/HadoopHashMultimapBase.java        |  17 +-
 .../hadoop/shuffle/collections/HadoopMultimap.java |  17 +-
 .../shuffle/collections/HadoopMultimapBase.java    |  17 +-
 .../hadoop/shuffle/collections/HadoopSkipList.java |  17 +-
 .../shuffle/direct/HadoopDirectDataInput.java      |  17 +-
 .../shuffle/direct/HadoopDirectDataOutput.java     |  17 +-
 .../direct/HadoopDirectDataOutputContext.java      |  17 +-
 .../direct/HadoopDirectDataOutputState.java        |  17 +-
 .../hadoop/shuffle/streams/HadoopDataInStream.java |  17 +-
 .../shuffle/streams/HadoopDataOutStream.java       |  17 +-
 .../shuffle/streams/HadoopOffheapBuffer.java       |  17 +-
 .../taskexecutor/HadoopEmbeddedTaskExecutor.java   |  17 +-
 .../hadoop/taskexecutor/HadoopExecutorService.java |  17 +-
 .../hadoop/taskexecutor/HadoopRunnableTask.java    |  17 +-
 .../taskexecutor/HadoopTaskExecutorAdapter.java    |  17 +-
 .../hadoop/taskexecutor/HadoopTaskState.java       |  17 +-
 .../hadoop/taskexecutor/HadoopTaskStatus.java      |  17 +-
 .../external/HadoopExternalTaskExecutor.java       |  17 +-
 .../external/HadoopExternalTaskMetadata.java       |  17 +-
 .../external/HadoopJobInfoUpdateRequest.java       |  17 +-
 .../external/HadoopPrepareForJobRequest.java       |  17 +-
 .../external/HadoopProcessDescriptor.java          |  17 +-
 .../external/HadoopProcessStartedAck.java          |  17 +-
 .../external/HadoopTaskExecutionRequest.java       |  17 +-
 .../external/HadoopTaskFinishedMessage.java        |  17 +-
 .../external/child/HadoopChildProcessRunner.java   |  17 +-
 .../child/HadoopExternalProcessStarter.java        |  17 +-
 .../HadoopAbstractCommunicationClient.java         |  17 +-
 .../communication/HadoopCommunicationClient.java   |  17 +-
 .../communication/HadoopExternalCommunication.java |  17 +-
 .../HadoopHandshakeTimeoutException.java           |  17 +-
 .../communication/HadoopIpcToNioAdapter.java       |  17 +-
 .../communication/HadoopMarshallerFilter.java      |  17 +-
 .../communication/HadoopMessageListener.java       |  17 +-
 .../HadoopTcpNioCommunicationClient.java           |  17 +-
 .../main/resources/META-INF/classnames.properties  |  18 +-
 .../src/test/config/hadoop-fs-open-test/grid-0.xml |  27 ++-
 .../src/test/config/hadoop-fs-open-test/grid-1.xml |  27 ++-
 .../src/test/config/hadoop-fs-open-test/grid-2.xml |  27 ++-
 .../src/test/config/igfs-cli-config-dual-async.xml |  27 ++-
 .../src/test/config/igfs-cli-config-dual-sync.xml  |  27 ++-
 .../src/test/config/igfs-cli-config-primary.xml    |  27 ++-
 .../src/test/config/igfs-cli-config-proxy.xml      |  27 ++-
 .../processors/hadoop/HadoopSharedMap.java         |  17 +-
 .../processors/hadoop/HadoopTestClassLoader.java   |  17 +-
 .../hadoop/impl/HadoopAbstractMapReduceTest.java   |  17 +-
 .../hadoop/impl/HadoopAbstractSelfTest.java        |  17 +-
 .../hadoop/impl/HadoopAbstractWordCountTest.java   |  17 +-
 .../hadoop/impl/HadoopCommandLineTest.java         |  17 +-
 .../hadoop/impl/HadoopErrorSimulator.java          |  17 +-
 .../hadoop/impl/HadoopFileSystemsTest.java         |  17 +-
 .../processors/hadoop/impl/HadoopGroupingTest.java |  17 +-
 .../hadoop/impl/HadoopJobTrackerSelfTest.java      |  17 +-
 .../impl/HadoopMapReduceEmbeddedSelfTest.java      |  17 +-
 .../impl/HadoopMapReduceErrorResilienceTest.java   |  17 +-
 .../hadoop/impl/HadoopMapReduceTest.java           |  17 +-
 .../hadoop/impl/HadoopNoHadoopMapReduceTest.java   |  17 +-
 .../hadoop/impl/HadoopPlannerMockJob.java          |  17 +-
 .../impl/HadoopSerializationWrapperSelfTest.java   |  17 +-
 .../hadoop/impl/HadoopSnappyFullMapReduceTest.java |  17 +-
 .../processors/hadoop/impl/HadoopSnappyTest.java   |  17 +-
 .../hadoop/impl/HadoopSortingExternalTest.java     |  17 +-
 .../processors/hadoop/impl/HadoopSortingTest.java  |  17 +-
 .../hadoop/impl/HadoopSplitWrapperSelfTest.java    |  17 +-
 .../processors/hadoop/impl/HadoopStartup.java      |  17 +-
 .../hadoop/impl/HadoopTaskExecutionSelfTest.java   |  17 +-
 .../processors/hadoop/impl/HadoopTasksV1Test.java  |  17 +-
 .../processors/hadoop/impl/HadoopTasksV2Test.java  |  17 +-
 .../impl/HadoopTasksVersionsAbstractTest.java      |  17 +-
 .../processors/hadoop/impl/HadoopTeraSortTest.java |  17 +-
 .../hadoop/impl/HadoopTestTaskContext.java         |  17 +-
 .../processors/hadoop/impl/HadoopTestUtils.java    |  17 +-
 .../hadoop/impl/HadoopTxConfigCacheTest.java       |  17 +-
 .../hadoop/impl/HadoopUserLibsSelfTest.java        |  17 +-
 .../hadoop/impl/HadoopV2JobSelfTest.java           |  17 +-
 .../hadoop/impl/HadoopValidationSelfTest.java      |  17 +-
 .../impl/HadoopWeightedMapReducePlannerTest.java   |  17 +-
 .../impl/HadoopWeightedPlannerMapReduceTest.java   |  17 +-
 .../HadoopClientProtocolEmbeddedSelfTest.java      |  17 +-
 ...adoopClientProtocolMultipleServersSelfTest.java |  17 +-
 .../impl/client/HadoopClientProtocolSelfTest.java  |  17 +-
 .../hadoop/impl/examples/HadoopPopularWords.java   |  17 +-
 .../hadoop/impl/examples/HadoopWordCount1.java     |  17 +-
 .../hadoop/impl/examples/HadoopWordCount1Map.java  |  17 +-
 .../impl/examples/HadoopWordCount1Reduce.java      |  17 +-
 .../hadoop/impl/examples/HadoopWordCount2.java     |  17 +-
 .../impl/examples/HadoopWordCount2Combiner.java    |  17 +-
 .../impl/examples/HadoopWordCount2Mapper.java      |  17 +-
 .../impl/examples/HadoopWordCount2Reducer.java     |  17 +-
 .../KerberosHadoopFileSystemFactorySelfTest.java   |  17 +-
 .../hadoop/impl/igfs/Hadoop1DualAbstractTest.java  |  17 +-
 .../impl/igfs/Hadoop1OverIgfsDualAsyncTest.java    |  17 +-
 .../impl/igfs/Hadoop1OverIgfsDualSyncTest.java     |  17 +-
 .../hadoop/impl/igfs/Hadoop1OverIgfsProxyTest.java |  17 +-
 .../impl/igfs/HadoopFIleSystemFactorySelfTest.java |  17 +-
 .../HadoopIgfs20FileSystemAbstractSelfTest.java    |  17 +-
 ...oopIgfs20FileSystemLoopbackPrimarySelfTest.java |  17 +-
 ...HadoopIgfs20FileSystemShmemPrimarySelfTest.java |  17 +-
 .../impl/igfs/HadoopIgfsDualAbstractSelfTest.java  |  17 +-
 .../impl/igfs/HadoopIgfsDualAsyncSelfTest.java     |  17 +-
 .../impl/igfs/HadoopIgfsDualSyncSelfTest.java      |  17 +-
 .../HadoopIgfsSecondaryFileSystemTestAdapter.java  |  17 +-
 ...HadoopSecondaryFileSystemConfigurationTest.java |  17 +-
 .../hadoop/impl/igfs/IgfsEventsTestSuite.java      |  17 +-
 .../impl/igfs/IgfsNearOnlyMultiNodeSelfTest.java   |  17 +-
 .../IgniteHadoopFileSystemAbstractSelfTest.java    |  17 +-
 ...adoopFileSystemClientBasedAbstractSelfTest.java |  17 +-
 ...doopFileSystemClientBasedDualAsyncSelfTest.java |  17 +-
 ...adoopFileSystemClientBasedDualSyncSelfTest.java |  17 +-
 .../IgniteHadoopFileSystemClientBasedOpenTest.java |  17 +-
 ...HadoopFileSystemClientBasedPrimarySelfTest.java |  17 +-
 ...teHadoopFileSystemClientBasedProxySelfTest.java |  17 +-
 .../igfs/IgniteHadoopFileSystemClientSelfTest.java |  17 +-
 .../IgniteHadoopFileSystemHandshakeSelfTest.java   |  17 +-
 .../IgniteHadoopFileSystemIpcCacheSelfTest.java    |  17 +-
 .../igfs/IgniteHadoopFileSystemLoggerSelfTest.java |  17 +-
 .../IgniteHadoopFileSystemLoggerStateSelfTest.java |  17 +-
 ...teHadoopFileSystemLoopbackAbstractSelfTest.java |  17 +-
 ...ileSystemLoopbackEmbeddedDualAsyncSelfTest.java |  17 +-
 ...FileSystemLoopbackEmbeddedDualSyncSelfTest.java |  17 +-
 ...pFileSystemLoopbackEmbeddedPrimarySelfTest.java |  17 +-
 ...ileSystemLoopbackEmbeddedSecondarySelfTest.java |  17 +-
 ...ileSystemLoopbackExternalDualAsyncSelfTest.java |  17 +-
 ...FileSystemLoopbackExternalDualSyncSelfTest.java |  17 +-
 ...pFileSystemLoopbackExternalPrimarySelfTest.java |  17 +-
 ...ileSystemLoopbackExternalSecondarySelfTest.java |  17 +-
 ...emLoopbackExternalToClientAbstractSelfTest.java |  17 +-
 ...mLoopbackExternalToClientDualAsyncSelfTest.java |  17 +-
 ...emLoopbackExternalToClientDualSyncSelfTest.java |  17 +-
 ...temLoopbackExternalToClientPrimarySelfTest.java |  17 +-
 ...ystemLoopbackExternalToClientProxySelfTest.java |  17 +-
 ...gniteHadoopFileSystemShmemAbstractSelfTest.java |  17 +-
 ...opFileSystemShmemExternalDualAsyncSelfTest.java |  17 +-
 ...oopFileSystemShmemExternalDualSyncSelfTest.java |  17 +-
 ...doopFileSystemShmemExternalPrimarySelfTest.java |  17 +-
 ...opFileSystemShmemExternalSecondarySelfTest.java |  17 +-
 ...ystemShmemExternalToClientAbstractSelfTest.java |  17 +-
 ...stemShmemExternalToClientDualAsyncSelfTest.java |  17 +-
 ...ystemShmemExternalToClientDualSyncSelfTest.java |  17 +-
 ...SystemShmemExternalToClientPrimarySelfTest.java |  17 +-
 ...leSystemShmemExternalToClientProxySelfTest.java |  17 +-
 .../shuffle/collections/HadoopAbstractMapTest.java |  17 +-
 .../HadoopConcurrentHashMultimapSelftest.java      |  17 +-
 .../shuffle/collections/HadoopHashMapSelfTest.java |  17 +-
 .../collections/HadoopSkipListSelfTest.java        |  17 +-
 .../shuffle/streams/HadoopDataStreamSelfTest.java  |  17 +-
 .../taskexecutor/HadoopExecutorServiceTest.java    |  17 +-
 .../HadoopExternalTaskExecutionSelfTest.java       |  17 +-
 .../HadoopExternalCommunicationSelfTest.java       |  17 +-
 .../impl/util/BasicUserNameMapperSelfTest.java     |  17 +-
 .../impl/util/ChainedUserNameMapperSelfTest.java   |  17 +-
 .../impl/util/KerberosUserNameMapperSelfTest.java  |  17 +-
 .../hadoop/state/HadoopGroupingTestState.java      |  17 +-
 .../state/HadoopJobTrackerSelfTestState.java       |  17 +-
 .../HadoopMapReduceEmbeddedSelfTestState.java      |  17 +-
 .../state/HadoopTaskExecutionSelfTestValues.java   |  17 +-
 .../ignite/testsuites/IgniteHadoopTestSuite.java   |  17 +-
 .../IgniteIgfsLinuxAndMacOSTestSuite.java          |  17 +-
 modules/hibernate-4.2/licenses/apache-2.0.txt      | 202 ---------------------
 modules/hibernate-4.2/licenses/gg-community.txt    |  13 ++
 modules/hibernate-4.2/pom.xml                      |  45 +++--
 .../HibernateAbstractRegionAccessStrategy.java     |  17 +-
 .../cache/hibernate/HibernateCollectionRegion.java |  17 +-
 .../cache/hibernate/HibernateEntityRegion.java     |  17 +-
 .../hibernate/HibernateGeneralDataRegion.java      |  17 +-
 .../cache/hibernate/HibernateKeyWrapper.java       |  17 +-
 .../cache/hibernate/HibernateNaturalIdRegion.java  |  17 +-
 .../hibernate/HibernateQueryResultsRegion.java     |  17 +-
 .../ignite/cache/hibernate/HibernateRegion.java    |  17 +-
 .../cache/hibernate/HibernateRegionFactory.java    |  17 +-
 .../cache/hibernate/HibernateTimestampsRegion.java |  17 +-
 .../HibernateTransactionalDataRegion.java          |  17 +-
 .../ignite/cache/hibernate/package-info.java       |  17 +-
 .../store/hibernate/CacheHibernateBlobStore.java   |  17 +-
 .../hibernate/CacheHibernateBlobStoreEntry.hbm.xml |  27 ++-
 .../hibernate/CacheHibernateBlobStoreEntry.java    |  17 +-
 .../hibernate/CacheHibernateBlobStoreFactory.java  |  17 +-
 .../CacheHibernateStoreSessionListener.java        |  17 +-
 .../ignite/cache/store/hibernate/package-info.java |  17 +-
 .../src/test/config/factory-cache.xml              |  27 ++-
 .../src/test/config/factory-cache1.xml             |  27 ++-
 .../test/config/factory-incorrect-store-cache.xml  |  27 ++-
 .../HibernateL2CacheConfigurationSelfTest.java     |  17 +-
 .../hibernate/HibernateL2CacheMultiJvmTest.java    |  17 +-
 .../cache/hibernate/HibernateL2CacheSelfTest.java  |  17 +-
 .../HibernateL2CacheStrategySelfTest.java          |  17 +-
 .../HibernateL2CacheTransactionalSelfTest.java     |  17 +-
 ...bernateL2CacheTransactionalUseSyncSelfTest.java |  17 +-
 .../CacheHibernateBlobStoreNodeRestartTest.java    |  17 +-
 .../hibernate/CacheHibernateBlobStoreSelfTest.java |  17 +-
 .../CacheHibernateStoreFactorySelfTest.java        |  17 +-
 ...CacheHibernateStoreSessionListenerSelfTest.java |  17 +-
 .../ignite/cache/store/hibernate/hibernate.cfg.xml |  27 ++-
 .../ignite/cache/store/hibernate/package-info.java |  17 +-
 .../testsuites/IgniteHibernateTestSuite.java       |  17 +-
 modules/hibernate-5.1/licenses/apache-2.0.txt      | 202 ---------------------
 modules/hibernate-5.1/licenses/gg-community.txt    |  13 ++
 modules/hibernate-5.1/pom.xml                      |  45 +++--
 .../HibernateAbstractRegionAccessStrategy.java     |  17 +-
 .../cache/hibernate/HibernateCollectionRegion.java |  17 +-
 .../cache/hibernate/HibernateEntityRegion.java     |  17 +-
 .../hibernate/HibernateGeneralDataRegion.java      |  17 +-
 .../cache/hibernate/HibernateKeyWrapper.java       |  17 +-
 .../cache/hibernate/HibernateNaturalIdRegion.java  |  17 +-
 .../hibernate/HibernateQueryResultsRegion.java     |  17 +-
 .../ignite/cache/hibernate/HibernateRegion.java    |  17 +-
 .../cache/hibernate/HibernateRegionFactory.java    |  17 +-
 .../cache/hibernate/HibernateTimestampsRegion.java |  17 +-
 .../HibernateTransactionalDataRegion.java          |  17 +-
 .../ignite/cache/hibernate/package-info.java       |  17 +-
 .../store/hibernate/CacheHibernateBlobStore.java   |  17 +-
 .../hibernate/CacheHibernateBlobStoreEntry.hbm.xml |  27 ++-
 .../hibernate/CacheHibernateBlobStoreEntry.java    |  17 +-
 .../hibernate/CacheHibernateBlobStoreFactory.java  |  17 +-
 .../CacheHibernateStoreSessionListener.java        |  17 +-
 .../ignite/cache/store/hibernate/package-info.java |  17 +-
 .../src/test/config/factory-cache.xml              |  27 ++-
 .../src/test/config/factory-cache1.xml             |  27 ++-
 .../test/config/factory-incorrect-store-cache.xml  |  27 ++-
 .../HibernateL2CacheConfigurationSelfTest.java     |  17 +-
 .../hibernate/HibernateL2CacheMultiJvmTest.java    |  17 +-
 .../cache/hibernate/HibernateL2CacheSelfTest.java  |  17 +-
 .../HibernateL2CacheStrategySelfTest.java          |  17 +-
 .../HibernateL2CacheTransactionalSelfTest.java     |  17 +-
 ...bernateL2CacheTransactionalUseSyncSelfTest.java |  17 +-
 .../CacheHibernateBlobStoreNodeRestartTest.java    |  17 +-
 .../hibernate/CacheHibernateBlobStoreSelfTest.java |  17 +-
 .../CacheHibernateStoreFactorySelfTest.java        |  17 +-
 ...CacheHibernateStoreSessionListenerSelfTest.java |  17 +-
 .../ignite/cache/store/hibernate/hibernate.cfg.xml |  27 ++-
 .../ignite/cache/store/hibernate/package-info.java |  17 +-
 .../testsuites/IgniteHibernate5TestSuite.java      |  17 +-
 modules/hibernate-5.3/licenses/apache-2.0.txt      | 202 ---------------------
 modules/hibernate-5.3/licenses/gg-community.txt    |  13 ++
 modules/hibernate-5.3/pom.xml                      |  45 +++--
 .../cache/hibernate/HibernateKeyWrapper.java       |  17 +-
 .../ignite/cache/hibernate/HibernateRegion.java    |  17 +-
 .../cache/hibernate/HibernateRegionFactory.java    |  17 +-
 .../hibernate/IgniteCachedDomainDataAccess.java    |  17 +-
 .../hibernate/IgniteCollectionDataAccess.java      |  17 +-
 .../cache/hibernate/IgniteDomainDataRegion.java    |  17 +-
 .../cache/hibernate/IgniteEntityDataAccess.java    |  17 +-
 .../cache/hibernate/IgniteGeneralDataRegion.java   |  17 +-
 .../cache/hibernate/IgniteNaturalIdDataAccess.java |  17 +-
 .../cache/hibernate/IgniteQueryResultsRegion.java  |  17 +-
 .../cache/hibernate/IgniteTimestampsRegion.java    |  17 +-
 .../ignite/cache/hibernate/package-info.java       |  17 +-
 .../store/hibernate/CacheHibernateBlobStore.java   |  17 +-
 .../hibernate/CacheHibernateBlobStoreEntry.java    |  17 +-
 .../hibernate/CacheHibernateBlobStoreFactory.java  |  17 +-
 .../CacheHibernateStoreSessionListener.java        |  17 +-
 .../ignite/cache/store/hibernate/package-info.java |  17 +-
 .../hibernate/CacheHibernateBlobStoreEntry.hbm.xml |  27 ++-
 .../src/test/config/factory-cache.xml              |  27 ++-
 .../src/test/config/factory-cache1.xml             |  27 ++-
 .../test/config/factory-incorrect-store-cache.xml  |  27 ++-
 .../HibernateL2CacheConfigurationSelfTest.java     |  17 +-
 .../hibernate/HibernateL2CacheMultiJvmTest.java    |  17 +-
 .../cache/hibernate/HibernateL2CacheSelfTest.java  |  17 +-
 .../HibernateL2CacheStrategySelfTest.java          |  17 +-
 .../HibernateL2CacheTransactionalSelfTest.java     |  17 +-
 ...bernateL2CacheTransactionalUseSyncSelfTest.java |  17 +-
 .../CacheHibernateBlobStoreNodeRestartTest.java    |  17 +-
 .../hibernate/CacheHibernateBlobStoreSelfTest.java |  17 +-
 .../CacheHibernateStoreFactorySelfTest.java        |  17 +-
 ...CacheHibernateStoreSessionListenerSelfTest.java |  17 +-
 .../ignite/cache/store/hibernate/hibernate.cfg.xml |  26 +--
 .../ignite/cache/store/hibernate/package-info.java |  17 +-
 .../testsuites/IgniteHibernate53TestSuite.java     |  17 +-
 .../ignite/cache/store/hibernate/hibernate.cfg.xml |  26 +--
 modules/hibernate-core/pom.xml                     |  37 ++--
 .../hibernate/HibernateAccessStrategyAdapter.java  |  17 +-
 .../hibernate/HibernateAccessStrategyFactory.java  |  17 +-
 .../cache/hibernate/HibernateCacheProxy.java       |  17 +-
 .../hibernate/HibernateExceptionConverter.java     |  17 +-
 .../cache/hibernate/HibernateKeyTransformer.java   |  17 +-
 .../HibernateNonStrictAccessStrategy.java          |  17 +-
 .../hibernate/HibernateReadOnlyAccessStrategy.java |  17 +-
 .../HibernateReadWriteAccessStrategy.java          |  17 +-
 .../HibernateTransactionalAccessStrategy.java      |  17 +-
 .../ignite/cache/hibernate/package-info.java       |  17 +-
 modules/ignored-tests/pom.xml                      |  69 ++++---
 .../testsuites/IgniteIgnoredBinaryTestSuite.java   |  17 +-
 .../ignite/testsuites/IgniteIgnoredTestSuite.java  |  17 +-
 .../org/apache/ignite/testsuites/package-info.java |  17 +-
 modules/indexing/licenses/apache-2.0.txt           | 202 ---------------------
 modules/indexing/licenses/gg-community.txt         |  13 ++
 modules/indexing/pom.xml                           |  37 ++--
 .../ignite/internal/mxbean/SqlQueryMXBean.java     |  17 +-
 .../ignite/internal/mxbean/SqlQueryMXBeanImpl.java |  17 +-
 .../cache/query/GridCacheTwoStepQuery.java         |  17 +-
 .../processors/cache/query/QueryTable.java         |  17 +-
 .../cache/query/RegisteredQueryCursor.java         |  18 +-
 .../processors/query/h2/CommandProcessor.java      |  17 +-
 .../processors/query/h2/CommandResult.java         |  17 +-
 .../processors/query/h2/ConnectionManager.java     |  17 +-
 .../query/h2/DmlStatementsProcessor.java           |  17 +-
 .../processors/query/h2/H2CachedStatementKey.java  |  17 +-
 .../processors/query/h2/H2ConnectionWrapper.java   |  17 +-
 .../internal/processors/query/h2/H2Cursor.java     |  17 +-
 .../processors/query/h2/H2DatabaseType.java        |  17 +-
 .../processors/query/h2/H2FieldsIterator.java      |  17 +-
 .../processors/query/h2/H2KeyValueIterator.java    |  17 +-
 .../internal/processors/query/h2/H2QueryInfo.java  |  17 +-
 .../processors/query/h2/H2ResultSetIterator.java   |  17 +-
 .../internal/processors/query/h2/H2RowCache.java   |  17 +-
 .../processors/query/h2/H2RowCacheRegistry.java    |  17 +-
 .../internal/processors/query/h2/H2Schema.java     |  17 +-
 .../processors/query/h2/H2SqlFieldMetadata.java    |  17 +-
 .../processors/query/h2/H2StatementCache.java      |  17 +-
 .../processors/query/h2/H2TableDescriptor.java     |  17 +-
 .../processors/query/h2/H2TableEngine.java         |  17 +-
 .../internal/processors/query/h2/H2TypeKey.java    |  17 +-
 .../internal/processors/query/h2/H2Utils.java      |  17 +-
 .../processors/query/h2/IgniteH2Indexing.java      |  17 +-
 .../processors/query/h2/IndexBuildClosure.java     |  17 +-
 .../query/h2/IndexRebuildFullClosure.java          |  17 +-
 .../query/h2/IndexRebuildPartialClosure.java       |  17 +-
 .../internal/processors/query/h2/KillQueryRun.java |  18 +-
 .../query/h2/LongRunningQueryManager.java          |  17 +-
 .../processors/query/h2/MapH2QueryInfo.java        |  17 +-
 .../processors/query/h2/QueryDescriptor.java       |  17 +-
 .../processors/query/h2/QueryParameters.java       |  18 +-
 .../internal/processors/query/h2/QueryParser.java  |  17 +-
 .../processors/query/h2/QueryParserCacheEntry.java |  17 +-
 .../processors/query/h2/QueryParserResult.java     |  17 +-
 .../query/h2/QueryParserResultCommand.java         |  17 +-
 .../processors/query/h2/QueryParserResultDml.java  |  17 +-
 .../query/h2/QueryParserResultSelect.java          |  17 +-
 .../processors/query/h2/ReduceH2QueryInfo.java     |  17 +-
 .../processors/query/h2/SchemaManager.java         |  17 +-
 .../processors/query/h2/ThreadLocalObjectPool.java |  17 +-
 .../internal/processors/query/h2/UpdateResult.java |  17 +-
 .../query/h2/affinity/H2PartitionResolver.java     |  17 +-
 .../query/h2/affinity/PartitionExtractor.java      |  17 +-
 .../processors/query/h2/database/H2IndexType.java  |  18 +-
 .../query/h2/database/H2PkHashIndex.java           |  18 +-
 .../processors/query/h2/database/H2Tree.java       |  17 +-
 .../query/h2/database/H2TreeClientIndex.java       |  17 +-
 .../query/h2/database/H2TreeFilterClosure.java     |  17 +-
 .../processors/query/h2/database/H2TreeIndex.java  |  17 +-
 .../query/h2/database/H2TreeIndexBase.java         |  18 +-
 .../query/h2/database/IndexInformation.java        |  18 +-
 .../query/h2/database/InlineIndexHelper.java       |  17 +-
 .../h2/database/io/AbstractH2ExtrasInnerIO.java    |  17 +-
 .../h2/database/io/AbstractH2ExtrasLeafIO.java     |  17 +-
 .../query/h2/database/io/AbstractH2InnerIO.java    |  17 +-
 .../query/h2/database/io/AbstractH2LeafIO.java     |  17 +-
 .../query/h2/database/io/H2ExtrasInnerIO.java      |  17 +-
 .../query/h2/database/io/H2ExtrasLeafIO.java       |  17 +-
 .../processors/query/h2/database/io/H2IOUtils.java |  17 +-
 .../processors/query/h2/database/io/H2InnerIO.java |  17 +-
 .../processors/query/h2/database/io/H2LeafIO.java  |  17 +-
 .../query/h2/database/io/H2MvccExtrasInnerIO.java  |  17 +-
 .../query/h2/database/io/H2MvccExtrasLeafIO.java   |  17 +-
 .../query/h2/database/io/H2MvccInnerIO.java        |  17 +-
 .../query/h2/database/io/H2MvccLeafIO.java         |  17 +-
 .../query/h2/database/io/H2RowLinkIO.java          |  17 +-
 .../processors/query/h2/dml/DmlArgument.java       |  17 +-
 .../processors/query/h2/dml/DmlArguments.java      |  17 +-
 .../processors/query/h2/dml/DmlAstUtils.java       |  17 +-
 .../processors/query/h2/dml/DmlBatchSender.java    |  17 +-
 .../query/h2/dml/DmlBulkLoadDataConverter.java     |  17 +-
 .../query/h2/dml/DmlDistributedPlanInfo.java       |  17 +-
 .../query/h2/dml/DmlDistributedUpdateRun.java      |  17 +-
 .../query/h2/dml/DmlPageProcessingErrorResult.java |  17 +-
 .../query/h2/dml/DmlPageProcessingResult.java      |  17 +-
 .../query/h2/dml/DmlUpdateResultsIterator.java     |  17 +-
 .../query/h2/dml/DmlUpdateSingleEntryIterator.java |  17 +-
 .../internal/processors/query/h2/dml/DmlUtils.java |  17 +-
 .../processors/query/h2/dml/FastUpdate.java        |  17 +-
 .../processors/query/h2/dml/KeyValueSupplier.java  |  17 +-
 .../processors/query/h2/dml/UpdateMode.java        |  17 +-
 .../processors/query/h2/dml/UpdatePlan.java        |  17 +-
 .../processors/query/h2/dml/UpdatePlanBuilder.java |  17 +-
 .../processors/query/h2/dml/package-info.java      |  17 +-
 .../processors/query/h2/opt/GridH2Cursor.java      |  17 +-
 .../query/h2/opt/GridH2DefaultTableEngine.java     |  17 +-
 .../processors/query/h2/opt/GridH2IndexBase.java   |  17 +-
 .../processors/query/h2/opt/GridH2MetaTable.java   |  17 +-
 .../processors/query/h2/opt/GridH2ProxyIndex.java  |  17 +-
 .../query/h2/opt/GridH2ProxySpatialIndex.java      |  17 +-
 .../query/h2/opt/GridH2RetryException.java         |  17 +-
 .../query/h2/opt/GridH2RowDescriptor.java          |  17 +-
 .../processors/query/h2/opt/GridH2Table.java       |  17 +-
 .../query/h2/opt/GridH2ValueCacheObject.java       |  17 +-
 .../query/h2/opt/GridLuceneDirectory.java          |  17 +-
 .../processors/query/h2/opt/GridLuceneFile.java    |  17 +-
 .../processors/query/h2/opt/GridLuceneIndex.java   |  17 +-
 .../query/h2/opt/GridLuceneInputStream.java        |  17 +-
 .../query/h2/opt/GridLuceneLockFactory.java        |  17 +-
 .../query/h2/opt/GridLuceneOutputStream.java       |  17 +-
 .../processors/query/h2/opt/H2CacheRow.java        |  17 +-
 .../processors/query/h2/opt/H2PlainRow.java        |  17 +-
 .../processors/query/h2/opt/H2PlainRowFactory.java |  17 +-
 .../processors/query/h2/opt/H2PlainRowPair.java    |  17 +-
 .../processors/query/h2/opt/H2PlainRowSingle.java  |  17 +-
 .../internal/processors/query/h2/opt/H2Row.java    |  17 +-
 .../processors/query/h2/opt/H2ScanIndex.java       |  17 +-
 .../processors/query/h2/opt/H2TableScanIndex.java  |  17 +-
 .../processors/query/h2/opt/QueryContext.java      |  17 +-
 .../processors/query/h2/opt/QueryContextKey.java   |  17 +-
 .../query/h2/opt/QueryContextRegistry.java         |  17 +-
 .../query/h2/opt/join/BroadcastCursor.java         |  17 +-
 .../query/h2/opt/join/CollocationModel.java        |  17 +-
 .../h2/opt/join/CollocationModelAffinity.java      |  17 +-
 .../h2/opt/join/CollocationModelMultiplier.java    |  17 +-
 .../query/h2/opt/join/CollocationModelType.java    |  17 +-
 .../query/h2/opt/join/CursorIteratorWrapper.java   |  17 +-
 .../query/h2/opt/join/DistributedJoinContext.java  |  17 +-
 .../query/h2/opt/join/DistributedLookupBatch.java  |  17 +-
 .../h2/opt/join/ProxyDistributedLookupBatch.java   |  17 +-
 .../processors/query/h2/opt/join/RangeSource.java  |  17 +-
 .../processors/query/h2/opt/join/RangeStream.java  |  17 +-
 .../processors/query/h2/opt/join/SegmentKey.java   |  17 +-
 .../processors/query/h2/opt/join/SourceKey.java    |  17 +-
 .../query/h2/opt/join/UnicastCursor.java           |  17 +-
 .../internal/processors/query/h2/package-info.java |  17 +-
 .../query/h2/sql/GridSqlAggregateFunction.java     |  17 +-
 .../processors/query/h2/sql/GridSqlAlias.java      |  17 +-
 .../query/h2/sql/GridSqlAlterTableAddColumn.java   |  17 +-
 .../query/h2/sql/GridSqlAlterTableDropColumn.java  |  17 +-
 .../processors/query/h2/sql/GridSqlArray.java      |  17 +-
 .../processors/query/h2/sql/GridSqlAst.java        |  17 +-
 .../processors/query/h2/sql/GridSqlColumn.java     |  17 +-
 .../processors/query/h2/sql/GridSqlConst.java      |  17 +-
 .../query/h2/sql/GridSqlCreateIndex.java           |  17 +-
 .../query/h2/sql/GridSqlCreateTable.java           |  17 +-
 .../processors/query/h2/sql/GridSqlDelete.java     |  17 +-
 .../processors/query/h2/sql/GridSqlDropIndex.java  |  17 +-
 .../processors/query/h2/sql/GridSqlDropTable.java  |  17 +-
 .../processors/query/h2/sql/GridSqlElement.java    |  17 +-
 .../processors/query/h2/sql/GridSqlFunction.java   |  17 +-
 .../query/h2/sql/GridSqlFunctionType.java          |  17 +-
 .../processors/query/h2/sql/GridSqlInsert.java     |  17 +-
 .../processors/query/h2/sql/GridSqlJoin.java       |  17 +-
 .../processors/query/h2/sql/GridSqlKeyword.java    |  17 +-
 .../processors/query/h2/sql/GridSqlMerge.java      |  17 +-
 .../processors/query/h2/sql/GridSqlOperation.java  |  17 +-
 .../query/h2/sql/GridSqlOperationType.java         |  17 +-
 .../processors/query/h2/sql/GridSqlParameter.java  |  17 +-
 .../query/h2/sql/GridSqlPlaceholder.java           |  17 +-
 .../processors/query/h2/sql/GridSqlQuery.java      |  17 +-
 .../query/h2/sql/GridSqlQueryParser.java           |  17 +-
 .../query/h2/sql/GridSqlQuerySplitter.java         |  17 +-
 .../processors/query/h2/sql/GridSqlSelect.java     |  17 +-
 .../processors/query/h2/sql/GridSqlSortColumn.java |  17 +-
 .../processors/query/h2/sql/GridSqlStatement.java  |  17 +-
 .../processors/query/h2/sql/GridSqlSubquery.java   |  17 +-
 .../processors/query/h2/sql/GridSqlTable.java      |  17 +-
 .../processors/query/h2/sql/GridSqlType.java       |  17 +-
 .../processors/query/h2/sql/GridSqlUnion.java      |  17 +-
 .../processors/query/h2/sql/GridSqlUpdate.java     |  17 +-
 .../query/h2/sql/SplitterAndCondition.java         |  17 +-
 .../processors/query/h2/sql/SplitterContext.java   |  17 +-
 .../query/h2/sql/SplitterQueryModel.java           |  17 +-
 .../query/h2/sql/SplitterQueryModelType.java       |  17 +-
 .../processors/query/h2/sql/SplitterUtils.java     |  17 +-
 .../processors/query/h2/sys/SqlSystemIndex.java    |  17 +-
 .../processors/query/h2/sys/SqlSystemTable.java    |  17 +-
 .../query/h2/sys/SqlSystemTableEngine.java         |  17 +-
 .../h2/sys/view/SqlAbstractLocalSystemView.java    |  17 +-
 .../query/h2/sys/view/SqlAbstractSystemView.java   |  17 +-
 .../query/h2/sys/view/SqlSystemView.java           |  17 +-
 .../h2/sys/view/SqlSystemViewBaselineNodes.java    |  17 +-
 .../h2/sys/view/SqlSystemViewCacheGroups.java      |  17 +-
 .../view/SqlSystemViewCacheGroupsIOStatistics.java |  18 +-
 .../query/h2/sys/view/SqlSystemViewCaches.java     |  17 +-
 .../h2/sys/view/SqlSystemViewColumnCondition.java  |  17 +-
 .../query/h2/sys/view/SqlSystemViewIndexes.java    |  18 +-
 .../h2/sys/view/SqlSystemViewNodeAttributes.java   |  17 +-
 .../h2/sys/view/SqlSystemViewNodeMetrics.java      |  17 +-
 .../query/h2/sys/view/SqlSystemViewNodes.java      |  17 +-
 .../sys/view/SqlSystemViewQueryHistoryMetrics.java |  18 +-
 .../h2/sys/view/SqlSystemViewRunningQueries.java   |  18 +-
 .../query/h2/sys/view/SqlSystemViewSchemas.java    |  18 +-
 .../query/h2/sys/view/SqlSystemViewTables.java     |  17 +-
 .../query/h2/twostep/GridMapQueryExecutor.java     |  17 +-
 .../query/h2/twostep/GridReduceQueryExecutor.java  |  17 +-
 .../query/h2/twostep/MapNodeResults.java           |  17 +-
 .../query/h2/twostep/MapQueryResult.java           |  17 +-
 .../query/h2/twostep/MapQueryResults.java          |  17 +-
 .../processors/query/h2/twostep/MapRequestKey.java |  17 +-
 .../query/h2/twostep/PartitionReservation.java     |  17 +-
 .../query/h2/twostep/PartitionReservationKey.java  |  17 +-
 .../h2/twostep/PartitionReservationManager.java    |  17 +-
 .../query/h2/twostep/ReduceBlockList.java          |  17 +-
 .../processors/query/h2/twostep/ReduceIndex.java   |  17 +-
 .../query/h2/twostep/ReduceIndexIterator.java      |  17 +-
 .../query/h2/twostep/ReduceIndexSorted.java        |  17 +-
 .../query/h2/twostep/ReduceIndexUnsorted.java      |  17 +-
 .../query/h2/twostep/ReducePartitionMapResult.java |  17 +-
 .../query/h2/twostep/ReducePartitionMapper.java    |  17 +-
 .../h2/twostep/ReducePartitionsSpecializer.java    |  17 +-
 .../query/h2/twostep/ReduceQueryRun.java           |  17 +-
 .../query/h2/twostep/ReduceResultPage.java         |  17 +-
 .../query/h2/twostep/ReduceSourceKey.java          |  17 +-
 .../processors/query/h2/twostep/ReduceTable.java   |  17 +-
 .../query/h2/twostep/ReduceTableEngine.java        |  17 +-
 .../query/h2/twostep/ReduceTableWrapper.java       |  17 +-
 .../query/h2/twostep/msg/GridH2Array.java          |  17 +-
 .../query/h2/twostep/msg/GridH2Boolean.java        |  17 +-
 .../query/h2/twostep/msg/GridH2Byte.java           |  17 +-
 .../query/h2/twostep/msg/GridH2Bytes.java          |  17 +-
 .../query/h2/twostep/msg/GridH2CacheObject.java    |  17 +-
 .../query/h2/twostep/msg/GridH2Date.java           |  17 +-
 .../query/h2/twostep/msg/GridH2Decimal.java        |  17 +-
 .../query/h2/twostep/msg/GridH2DmlRequest.java     |  17 +-
 .../query/h2/twostep/msg/GridH2DmlResponse.java    |  17 +-
 .../query/h2/twostep/msg/GridH2Double.java         |  17 +-
 .../query/h2/twostep/msg/GridH2Float.java          |  17 +-
 .../query/h2/twostep/msg/GridH2Geometry.java       |  17 +-
 .../h2/twostep/msg/GridH2IndexRangeRequest.java    |  17 +-
 .../h2/twostep/msg/GridH2IndexRangeResponse.java   |  17 +-
 .../query/h2/twostep/msg/GridH2Integer.java        |  17 +-
 .../query/h2/twostep/msg/GridH2JavaObject.java     |  17 +-
 .../query/h2/twostep/msg/GridH2Long.java           |  17 +-
 .../query/h2/twostep/msg/GridH2Null.java           |  17 +-
 .../query/h2/twostep/msg/GridH2QueryRequest.java   |  17 +-
 .../query/h2/twostep/msg/GridH2RowMessage.java     |  17 +-
 .../query/h2/twostep/msg/GridH2RowRange.java       |  17 +-
 .../query/h2/twostep/msg/GridH2RowRangeBounds.java |  17 +-
 .../msg/GridH2SelectForUpdateTxDetails.java        |  17 +-
 .../query/h2/twostep/msg/GridH2Short.java          |  17 +-
 .../query/h2/twostep/msg/GridH2String.java         |  17 +-
 .../query/h2/twostep/msg/GridH2Time.java           |  17 +-
 .../query/h2/twostep/msg/GridH2Timestamp.java      |  17 +-
 .../query/h2/twostep/msg/GridH2Uuid.java           |  17 +-
 .../query/h2/twostep/msg/GridH2ValueMessage.java   |  17 +-
 .../h2/twostep/msg/GridH2ValueMessageFactory.java  |  17 +-
 .../visor/verify/ValidateIndexesClosure.java       |  29 ++-
 .../visor/verify/VisorValidateIndexesTask.java     |  29 ++-
 .../org/apache/ignite/client/ClientTestSuite.java  |  17 +-
 .../apache/ignite/client/FunctionalQueryTest.java  |  17 +-
 .../ignite/client/IgniteBinaryQueryTest.java       |  17 +-
 .../org/apache/ignite/client/SecurityTest.java     |  17 +-
 ...finityKeyNameAndValueFieldNameConflictTest.java |  17 +-
 .../processors/cache/BigEntryQueryTest.java        |  17 +-
 ...aryMetadataConcurrentUpdateWithIndexesTest.java |  17 +-
 .../cache/BinarySerializationQuerySelfTest.java    |  17 +-
 ...ationQueryWithReflectiveSerializerSelfTest.java |  17 +-
 .../cache/BinaryTypeMismatchLoggingTest.java       |  17 +-
 .../cache/BinaryTypeRegistrationTest.java          |  17 +-
 .../CacheAbstractQueryDetailMetricsSelfTest.java   |  17 +-
 .../cache/CacheAbstractQueryMetricsSelfTest.java   |  17 +-
 .../cache/CacheBinaryKeyConcurrentQueryTest.java   |  17 +-
 .../cache/CacheConfigurationP2PTest.java           |  17 +-
 .../cache/CacheConfigurationP2PTestServer.java     |  17 +-
 .../processors/cache/CacheIndexStreamerTest.java   |  17 +-
 .../cache/CacheIteratorScanQueryTest.java          |  17 +-
 .../CacheLocalQueryDetailMetricsSelfTest.java      |  17 +-
 .../cache/CacheLocalQueryMetricsSelfTest.java      |  17 +-
 .../cache/CacheOffheapBatchIndexingBaseTest.java   |  17 +-
 .../CacheOffheapBatchIndexingMultiTypeTest.java    |  17 +-
 .../CacheOffheapBatchIndexingSingleTypeTest.java   |  17 +-
 .../cache/CacheOperationsWithExpirationTest.java   |  17 +-
 ...ionedQueryDetailMetricsDistributedSelfTest.java |  17 +-
 ...PartitionedQueryDetailMetricsLocalSelfTest.java |  17 +-
 ...PartitionedQueryMetricsDistributedSelfTest.java |  17 +-
 .../CachePartitionedQueryMetricsLocalSelfTest.java |  17 +-
 ...acheQueryAfterDynamicCacheStartFailureTest.java |  29 ++-
 .../processors/cache/CacheQueryBuildValueTest.java |  17 +-
 .../cache/CacheQueryEvictDataLostTest.java         |  17 +-
 .../cache/CacheQueryFilterExpiredTest.java         |  17 +-
 .../cache/CacheQueryNewClientSelfTest.java         |  17 +-
 .../CacheRandomOperationsMultithreadedTest.java    |  17 +-
 ...catedQueryDetailMetricsDistributedSelfTest.java |  17 +-
 ...eReplicatedQueryDetailMetricsLocalSelfTest.java |  17 +-
 ...eReplicatedQueryMetricsDistributedSelfTest.java |  17 +-
 .../CacheReplicatedQueryMetricsLocalSelfTest.java  |  17 +-
 .../CacheScanPartitionQueryFallbackSelfTest.java   |  17 +-
 .../cache/CacheSqlQueryValueCopySelfTest.java      |  17 +-
 .../ClientReconnectAfterClusterRestartTest.java    |  17 +-
 .../cache/ClusterReadOnlyModeSqlTest.java          |  17 +-
 .../processors/cache/DdlTransactionSelfTest.java   |  17 +-
 .../cache/GridCacheCrossCacheQuerySelfTest.java    |  17 +-
 ...GridCacheDynamicLoadOnClientPersistentTest.java |  18 +-
 .../cache/GridCacheDynamicLoadOnClientTest.java    |  17 +-
 .../cache/GridCacheFullTextQuerySelfTest.java      |  17 +-
 .../GridCacheLazyQueryPartitionsReleaseTest.java   |  17 +-
 .../processors/cache/GridCacheOffHeapSelfTest.java |  17 +-
 .../cache/GridCacheOffheapIndexEntryEvictTest.java |  17 +-
 .../cache/GridCacheOffheapIndexGetSelfTest.java    |  17 +-
 .../cache/GridCacheQueryIndexDisabledSelfTest.java |  17 +-
 .../cache/GridCacheQuerySerializationSelfTest.java |  17 +-
 .../cache/GridCacheQuerySimpleBenchmark.java       |  17 +-
 .../processors/cache/GridCacheQueryTestValue.java  |  17 +-
 .../cache/GridIndexingWithNoopSwapSelfTest.java    |  17 +-
 .../IgniteBinaryObjectFieldsQuerySelfTest.java     |  17 +-
 .../IgniteBinaryObjectLocalQueryArgumentsTest.java |  17 +-
 .../IgniteBinaryObjectQueryArgumentsTest.java      |  17 +-
 ...niteBinaryWrappedObjectFieldsQuerySelfTest.java |  27 ++-
 .../IgniteCacheAbstractFieldsQuerySelfTest.java    |  17 +-
 .../IgniteCacheAbstractInsertSqlQuerySelfTest.java |  17 +-
 .../cache/IgniteCacheAbstractQuerySelfTest.java    |  17 +-
 .../IgniteCacheAbstractSqlDmlQuerySelfTest.java    |  17 +-
 .../cache/IgniteCacheCollocatedQuerySelfTest.java  |  17 +-
 .../IgniteCacheConfigVariationsQueryTest.java      |  17 +-
 ...teCacheConfigurationPrimitiveTypesSelfTest.java |  17 +-
 .../cache/IgniteCacheCrossCacheJoinRandomTest.java |  17 +-
 .../cache/IgniteCacheDeleteSqlQuerySelfTest.java   |  17 +-
 ...teCacheDistributedJoinCollocatedAndNotTest.java |  17 +-
 ...teCacheDistributedJoinCustomAffinityMapper.java |  17 +-
 .../IgniteCacheDistributedJoinNoIndexTest.java     |  17 +-
 ...istributedJoinPartitionedAndReplicatedTest.java |  17 +-
 ...iteCacheDistributedJoinQueryConditionsTest.java |  17 +-
 .../cache/IgniteCacheDistributedJoinTest.java      |  17 +-
 ...eCacheDuplicateEntityConfigurationSelfTest.java |  17 +-
 .../IgniteCacheFieldsQueryNoDataSelfTest.java      |  17 +-
 ...gniteCacheFullTextQueryNodeJoiningSelfTest.java |  17 +-
 .../processors/cache/IgniteCacheGroupsSqlTest.java |  17 +-
 .../cache/IgniteCacheInsertSqlQuerySelfTest.java   |  17 +-
 ...oinPartitionedAndReplicatedCollocationTest.java |  17 +-
 ...gniteCacheJoinPartitionedAndReplicatedTest.java |  17 +-
 .../IgniteCacheJoinQueryWithAffinityKeyTest.java   |  17 +-
 .../cache/IgniteCacheLargeResultSelfTest.java      |  17 +-
 ...acheLockPartitionOnAffinityRunAbstractTest.java |  17 +-
 ...ockPartitionOnAffinityRunAtomicCacheOpTest.java |  17 +-
 .../IgniteCacheLockPartitionOnAffinityRunTest.java |  17 +-
 ...cheLockPartitionOnAffinityRunTxCacheOpTest.java |  17 +-
 ...PartitionOnAffinityRunWithCollisionSpiTest.java |  17 +-
 .../cache/IgniteCacheMergeSqlQuerySelfTest.java    |  17 +-
 .../cache/IgniteCacheMultipleIndexedTypesTest.java |  17 +-
 .../cache/IgniteCacheNoClassQuerySelfTest.java     |  17 +-
 .../IgniteCacheObjectKeyIndexingSelfTest.java      |  17 +-
 .../cache/IgniteCacheOffheapEvictQueryTest.java    |  17 +-
 .../cache/IgniteCacheOffheapIndexScanTest.java     |  17 +-
 .../IgniteCacheP2pUnmarshallingQueryErrorTest.java |  27 ++-
 ...CachePartitionedQueryMultiThreadedSelfTest.java |  17 +-
 .../IgniteCachePrimitiveFieldsQuerySelfTest.java   |  17 +-
 .../cache/IgniteCacheQueriesLoadTest1.java         |  17 +-
 ...gniteCacheQueryEvictsMultiThreadedSelfTest.java |  17 +-
 .../cache/IgniteCacheQueryH2IndexingLeakTest.java  |  17 +-
 .../cache/IgniteCacheQueryIndexSelfTest.java       |  17 +-
 .../cache/IgniteCacheQueryLoadSelfTest.java        |  17 +-
 .../IgniteCacheQueryMultiThreadedSelfTest.java     |  17 +-
 .../cache/IgniteCacheSqlDmlErrorSelfTest.java      |  17 +-
 .../IgniteCacheSqlInsertValidationSelfTest.java    |  17 +-
 .../cache/IgniteCacheSqlQueryErrorSelfTest.java    |  17 +-
 .../IgniteCacheSqlQueryMultiThreadedSelfTest.java  |  17 +-
 .../IgniteCacheStarvationOnRebalanceTest.java      |  17 +-
 .../cache/IgniteCacheUnionDuplicatesTest.java      |  17 +-
 .../cache/IgniteCacheUpdateSqlQuerySelfTest.java   |  17 +-
 ...iteCheckClusterStateBeforeExecuteQueryTest.java |  17 +-
 ...iteClientReconnectCacheQueriesFailoverTest.java |  17 +-
 .../cache/IgniteClientReconnectQueriesTest.java    |  17 +-
 .../cache/IgniteCrossCachesJoinsQueryTest.java     |  17 +-
 .../cache/IgniteDynamicSqlRestoreTest.java         |  17 +-
 .../cache/IgniteErrorOnRebalanceTest.java          |  17 +-
 ...hIndexingAndGroupPutGetPersistenceSelfTest.java |  17 +-
 ...ingleNodeWithIndexingPutGetPersistenceTest.java |  17 +-
 .../processors/cache/IncorrectQueryEntityTest.java |  17 +-
 .../IndexingCachePartitionLossPolicySelfTest.java  |  17 +-
 .../cache/QueryEntityCaseMismatchTest.java         |  17 +-
 .../QueryJoinWithDifferentNodeFiltersTest.java     |  17 +-
 .../processors/cache/SqlFieldsQuerySelfTest.java   |  17 +-
 .../cache/StartCachesInParallelTest.java           |  17 +-
 .../authentication/SqlUserCommandSelfTest.java     |  17 +-
 .../CacheBlockOnCreateDestoryIndexTest.java        |  17 +-
 .../distributed/CacheBlockOnSqlQueryTest.java      |  17 +-
 .../near/IgniteCacheAtomicFieldsQuerySelfTest.java |  17 +-
 ...eCacheAtomicNearEnabledFieldsQuerySelfTest.java |  17 +-
 .../IgniteCacheAtomicNearEnabledQuerySelfTest.java |  17 +-
 .../near/IgniteCacheAtomicQuerySelfTest.java       |  17 +-
 ...heClientQueryReplicatedNodeRestartSelfTest.java |  17 +-
 ...eDistributedPartitionQueryAbstractSelfTest.java |  17 +-
 ...ributedPartitionQueryConfigurationSelfTest.java |  17 +-
 ...tributedPartitionQueryNodeRestartsSelfTest.java |  17 +-
 ...niteCacheDistributedPartitionQuerySelfTest.java |  17 +-
 .../IgniteCacheDistributedQueryCancelSelfTest.java |  17 +-
 ...tributedQueryStopOnCancelOrTimeoutSelfTest.java |  17 +-
 ...hePartitionedFieldsQueryP2PEnabledSelfTest.java |  17 +-
 .../IgniteCachePartitionedFieldsQuerySelfTest.java |  17 +-
 ...eCachePartitionedQueryEvtsDisabledSelfTest.java |  17 +-
 ...teCachePartitionedQueryP2PDisabledSelfTest.java |  17 +-
 .../near/IgniteCachePartitionedQuerySelfTest.java  |  17 +-
 ...chePartitionedSnapshotEnabledQuerySelfTest.java |  17 +-
 ...eCacheQueryAbstractDistributedJoinSelfTest.java |  17 +-
 .../near/IgniteCacheQueryNoRebalanceSelfTest.java  |  17 +-
 .../near/IgniteCacheQueryNodeFailTest.java         |  17 +-
 ...cheQueryNodeRestartDistributedJoinSelfTest.java |  17 +-
 .../near/IgniteCacheQueryNodeRestartSelfTest.java  |  17 +-
 .../near/IgniteCacheQueryNodeRestartSelfTest2.java |  17 +-
 .../IgniteCacheQueryNodeRestartTxSelfTest.java     |  17 +-
 ...opOnCancelOrTimeoutDistributedJoinSelfTest.java |  17 +-
 .../near/IgniteSqlQueryWithBaselineTest.java       |  17 +-
 ...FieldsQueryJoinNoPrimaryPartitionsSelfTest.java |  17 +-
 ...cheReplicatedFieldsQueryP2PEnabledSelfTest.java |  17 +-
 ...IgniteCacheReplicatedFieldsQueryROSelfTest.java |  17 +-
 .../IgniteCacheReplicatedFieldsQuerySelfTest.java  |  17 +-
 ...teCacheReplicatedQueryEvtsDisabledSelfTest.java |  17 +-
 ...iteCacheReplicatedQueryP2PDisabledSelfTest.java |  17 +-
 .../IgniteCacheReplicatedQuerySelfTest.java        |  17 +-
 .../cache/encryption/EncryptedSqlTableTest.java    |  17 +-
 .../cache/index/AbstractIndexingCommonTest.java    |  17 +-
 .../cache/index/AbstractSchemaSelfTest.java        |  17 +-
 .../cache/index/BasicIndexMultinodeTest.java       |  17 +-
 .../processors/cache/index/BasicIndexTest.java     |  17 +-
 .../index/ComplexPrimaryKeyUnwrapSelfTest.java     |  17 +-
 .../index/ComplexSecondaryKeyUnwrapSelfTest.java   |  18 +-
 .../index/DuplicateKeyValueClassesSelfTest.java    |  17 +-
 .../DynamicColumnsAbstractConcurrentSelfTest.java  |  17 +-
 .../cache/index/DynamicColumnsAbstractTest.java    |  17 +-
 ...ColumnsConcurrentAtomicPartitionedSelfTest.java |  17 +-
 ...cColumnsConcurrentAtomicReplicatedSelfTest.java |  17 +-
 ...ConcurrentTransactionalPartitionedSelfTest.java |  17 +-
 ...sConcurrentTransactionalReplicatedSelfTest.java |  17 +-
 .../index/DynamicIndexAbstractBasicSelfTest.java   |  17 +-
 .../DynamicIndexAbstractConcurrentSelfTest.java    |  17 +-
 .../cache/index/DynamicIndexAbstractSelfTest.java  |  17 +-
 .../index/DynamicIndexClientBasicSelfTest.java     |  17 +-
 ...icIndexPartitionedAtomicConcurrentSelfTest.java |  17 +-
 ...PartitionedTransactionalConcurrentSelfTest.java |  17 +-
 ...micIndexReplicatedAtomicConcurrentSelfTest.java |  17 +-
 ...xReplicatedTransactionalConcurrentSelfTest.java |  17 +-
 .../index/DynamicIndexServerBasicSelfTest.java     |  17 +-
 ...DynamicIndexServerCoordinatorBasicSelfTest.java |  17 +-
 .../DynamicIndexServerNodeFIlterBasicSelfTest.java |  17 +-
 ...exServerNodeFilterCoordinatorBasicSelfTest.java |  17 +-
 .../cache/index/H2ConnectionLeaksSelfTest.java     |  17 +-
 .../H2DynamicColumnsAbstractBasicSelfTest.java     |  17 +-
 .../index/H2DynamicColumnsClientBasicSelfTest.java |  17 +-
 .../index/H2DynamicColumnsServerBasicSelfTest.java |  17 +-
 ...namicColumnsServerCoordinatorBasicSelfTest.java |  17 +-
 .../index/H2DynamicIndexAbstractSelfTest.java      |  17 +-
 ...2DynamicIndexAtomicPartitionedNearSelfTest.java |  17 +-
 .../H2DynamicIndexAtomicPartitionedSelfTest.java   |  17 +-
 .../H2DynamicIndexAtomicReplicatedSelfTest.java    |  17 +-
 ...cIndexTransactionalPartitionedNearSelfTest.java |  17 +-
 ...namicIndexTransactionalPartitionedSelfTest.java |  17 +-
 ...ynamicIndexTransactionalReplicatedSelfTest.java |  17 +-
 .../H2DynamicIndexingComplexAbstractTest.java      |  17 +-
 ...omplexClientAtomicPartitionedNoBackupsTest.java |  17 +-
 ...IndexingComplexClientAtomicPartitionedTest.java |  17 +-
 ...cIndexingComplexClientAtomicReplicatedTest.java |  17 +-
 ...lientTransactionalPartitionedNoBackupsTest.java |  17 +-
 ...gComplexClientTransactionalPartitionedTest.java |  17 +-
 ...ngComplexClientTransactionalReplicatedTest.java |  17 +-
 ...omplexServerAtomicPartitionedNoBackupsTest.java |  17 +-
 ...IndexingComplexServerAtomicPartitionedTest.java |  17 +-
 ...cIndexingComplexServerAtomicReplicatedTest.java |  17 +-
 ...erverTransactionalPartitionedNoBackupsTest.java |  17 +-
 ...gComplexServerTransactionalPartitionedTest.java |  17 +-
 ...ngComplexServerTransactionalReplicatedTest.java |  17 +-
 .../cache/index/H2DynamicTableSelfTest.java        |  17 +-
 .../cache/index/H2RowCachePageEvictionTest.java    |  17 +-
 .../processors/cache/index/H2RowCacheSelfTest.java |  17 +-
 .../cache/index/H2RowExpireTimeIndexSelfTest.java  |  17 +-
 .../cache/index/IgniteDecimalSelfTest.java         |  17 +-
 .../index/IoStatisticsBasicIndexSelfTest.java      |  18 +-
 .../processors/cache/index/LongIndexNameTest.java  |  17 +-
 .../cache/index/MvccEmptyTransactionSelfTest.java  |  17 +-
 .../index/OptimizedMarshallerIndexNameTest.java    |  17 +-
 .../cache/index/QueryEntityValidationSelfTest.java |  17 +-
 .../cache/index/SchemaExchangeSelfTest.java        |  17 +-
 ...ransactionCommandsWithMvccDisabledSelfTest.java |  17 +-
 ...ransactionsCommandsWithMvccEnabledSelfTest.java |  17 +-
 .../cache/index/SqlTransactionsSelfTest.java       |  17 +-
 .../StaticCacheDdlKeepStaticConfigurationTest.java |  17 +-
 .../processors/cache/index/StaticCacheDdlTest.java |  17 +-
 .../local/IgniteCacheLocalAtomicQuerySelfTest.java |  17 +-
 .../local/IgniteCacheLocalFieldsQuerySelfTest.java |  17 +-
 ...niteCacheLocalQueryCancelOrTimeoutSelfTest.java |  17 +-
 .../cache/local/IgniteCacheLocalQuerySelfTest.java |  17 +-
 .../CacheMvccAbstractContinuousQuerySelfTest.java  |  17 +-
 ...acheMvccAbstractSqlContinuousQuerySelfTest.java |  17 +-
 ...acheMvccAbstractSqlCoordinatorFailoverTest.java |  17 +-
 .../cache/mvcc/CacheMvccBackupsAbstractTest.java   |  17 +-
 .../mvcc/CacheMvccBasicContinuousQueryTest.java    |  17 +-
 .../cache/mvcc/CacheMvccBulkLoadTest.java          |  17 +-
 ...acheMvccClientReconnectContinuousQueryTest.java |  17 +-
 .../CacheMvccContinuousQueryBackupQueueTest.java   |  17 +-
 ...acheMvccContinuousQueryClientReconnectTest.java |  17 +-
 .../mvcc/CacheMvccContinuousQueryClientTest.java   |  17 +-
 ...CacheMvccContinuousQueryImmutableEntryTest.java |  17 +-
 ...MvccContinuousQueryMultiNodesFilteringTest.java |  17 +-
 ...acheMvccContinuousQueryPartitionedSelfTest.java |  17 +-
 ...vccContinuousQueryPartitionedTxOneNodeTest.java |  17 +-
 ...CacheMvccContinuousQueryReplicatedSelfTest.java |  17 +-
 ...MvccContinuousQueryReplicatedTxOneNodeTest.java |  17 +-
 ...vccContinuousWithTransformerClientSelfTest.java |  17 +-
 ...ntinuousWithTransformerPartitionedSelfTest.java |  17 +-
 ...ontinuousWithTransformerReplicatedSelfTest.java |  17 +-
 .../cache/mvcc/CacheMvccDmlSimpleTest.java         |  17 +-
 ...cIteratorWithConcurrentJdbcTransactionTest.java |  17 +-
 ...alEntriesWithConcurrentJdbcTransactionTest.java |  17 +-
 .../mvcc/CacheMvccPartitionedBackupsTest.java      |  17 +-
 ...eMvccPartitionedSqlCoordinatorFailoverTest.java |  17 +-
 .../mvcc/CacheMvccPartitionedSqlQueriesTest.java   |  17 +-
 .../mvcc/CacheMvccPartitionedSqlTxQueriesTest.java |  17 +-
 ...MvccPartitionedSqlTxQueriesWithReducerTest.java |  17 +-
 .../cache/mvcc/CacheMvccReplicatedBackupsTest.java |  17 +-
 ...heMvccReplicatedSqlCoordinatorFailoverTest.java |  17 +-
 .../mvcc/CacheMvccReplicatedSqlQueriesTest.java    |  17 +-
 .../mvcc/CacheMvccReplicatedSqlTxQueriesTest.java  |  17 +-
 ...eMvccReplicatedSqlTxQueriesWithReducerTest.java |  17 +-
 ...ScanQueryWithConcurrentJdbcTransactionTest.java |  17 +-
 .../CacheMvccSelectForUpdateQueryBasicTest.java    |  17 +-
 .../mvcc/CacheMvccSelectForUpdateQueryTest.java    |  17 +-
 .../processors/cache/mvcc/CacheMvccSizeTest.java   |  17 +-
 ...eMvccSizeWithConcurrentJdbcTransactionTest.java |  17 +-
 .../CacheMvccSqlConfigurationValidationTest.java   |  17 +-
 ...eMvccSqlContinuousQueryPartitionedSelfTest.java |  17 +-
 ...heMvccSqlContinuousQueryReplicatedSelfTest.java |  17 +-
 .../cache/mvcc/CacheMvccSqlLockTimeoutTest.java    |  17 +-
 .../mvcc/CacheMvccSqlQueriesAbstractTest.java      |  17 +-
 .../cache/mvcc/CacheMvccSqlTxModesTest.java        |  17 +-
 .../mvcc/CacheMvccSqlTxQueriesAbstractTest.java    |  17 +-
 ...cheMvccSqlTxQueriesWithReducerAbstractTest.java |  17 +-
 .../cache/mvcc/CacheMvccSqlUpdateCountersTest.java |  17 +-
 .../cache/mvcc/CacheMvccStreamingInsertTest.java   |  17 +-
 .../cache/mvcc/CacheMvccTxNodeMappingTest.java     |  17 +-
 .../cache/mvcc/CacheMvccTxRecoveryTest.java        |  17 +-
 .../mvcc/MvccDeadlockDetectionConfigTest.java      |  17 +-
 .../cache/mvcc/MvccDeadlockDetectionTest.java      |  17 +-
 .../cache/mvcc/MvccRepeatableReadBulkOpsTest.java  |  17 +-
 .../mvcc/MvccRepeatableReadOperationsTest.java     |  17 +-
 .../persistence/db/IgniteTcBotInitNewPageTest.java |  29 ++-
 ...xingMultithreadedLoadContinuousRestartTest.java |  29 ++-
 .../persistence/db/wal/IgniteWalRecoveryTest.java  |  17 +-
 .../wal/IgniteWalRecoveryWithCompactionTest.java   |  29 ++-
 .../transaction/DmlInsideTransactionTest.java      |  17 +-
 .../cache/ttl/CacheTtlAbstractSelfTest.java        |  17 +-
 .../cache/ttl/CacheTtlAtomicAbstractSelfTest.java  |  17 +-
 .../cache/ttl/CacheTtlAtomicLocalSelfTest.java     |  17 +-
 .../ttl/CacheTtlAtomicPartitionedSelfTest.java     |  17 +-
 .../ttl/CacheTtlTransactionalAbstractSelfTest.java |  17 +-
 .../ttl/CacheTtlTransactionalLocalSelfTest.java    |  17 +-
 .../CacheTtlTransactionalPartitionedSelfTest.java  |  17 +-
 ...ntConnectorConfigurationValidationSelfTest.java |  17 +-
 .../processors/client/IgniteDataStreamerTest.java  |  17 +-
 .../database/IgniteDbMemoryLeakIndexedTest.java    |  17 +-
 .../database/IgniteDbMemoryLeakSqlQueryTest.java   |  17 +-
 .../IgniteDbMultiNodeWithIndexingPutGetTest.java   |  17 +-
 .../IgniteDbSingleNodeWithIndexingPutGetTest.java  |  17 +-
 ...niteDbSingleNodeWithIndexingWalRestoreTest.java |  17 +-
 ...tStoreQueryWithMultipleClassesPerCacheTest.java |  17 +-
 .../IgnitePersistentStoreSchemaLoadTest.java       |  17 +-
 .../database/IgniteTwoRegionsRebuildIndexTest.java |  17 +-
 ...eLockPartitionOnAffinityRunAtomicCacheTest.java |  17 +-
 ...elineLockPartitionOnAffinityRunTxCacheTest.java |  17 +-
 ...ngingBaselineCacheQueryNodeRestartSelfTest.java |  17 +-
 ...iteStableBaselineBinObjFieldsQuerySelfTest.java |  17 +-
 ...ableBaselineCacheQueryNodeRestartsSelfTest.java |  17 +-
 ...actQueryTableLockAndConnectionPoolSelfTest.java |  17 +-
 .../query/IgniteCacheGroupsCompareQueryTest.java   |  17 +-
 ...gniteCacheGroupsSqlDistributedJoinSelfTest.java |  17 +-
 ...heGroupsSqlSegmentedIndexMultiNodeSelfTest.java |  17 +-
 ...IgniteCacheGroupsSqlSegmentedIndexSelfTest.java |  17 +-
 .../query/IgniteCachelessQueriesSelfTest.java      |  17 +-
 .../query/IgniteQueryDedicatedPoolTest.java        |  17 +-
 ...yTableLockAndConnectionPoolLazyModeOffTest.java |  17 +-
 ...ryTableLockAndConnectionPoolLazyModeOnTest.java |  17 +-
 .../query/IgniteSqlCreateTableTemplateTest.java    |  17 +-
 .../query/IgniteSqlDefaultValueTest.java           |  17 +-
 .../query/IgniteSqlDistributedJoinSelfTest.java    |  17 +-
 .../query/IgniteSqlEntryCacheModeAgnosticTest.java |  17 +-
 .../query/IgniteSqlGroupConcatCollocatedTest.java  |  17 +-
 .../IgniteSqlGroupConcatNotCollocatedTest.java     |  17 +-
 .../query/IgniteSqlKeyValueFieldsTest.java         |  17 +-
 .../query/IgniteSqlNotNullConstraintTest.java      |  17 +-
 .../query/IgniteSqlParameterizedQueryTest.java     |  17 +-
 .../query/IgniteSqlQueryParallelismTest.java       |  17 +-
 .../processors/query/IgniteSqlRoutingTest.java     |  17 +-
 .../query/IgniteSqlSchemaIndexingTest.java         |  17 +-
 .../IgniteSqlSegmentedIndexMultiNodeSelfTest.java  |  17 +-
 .../query/IgniteSqlSegmentedIndexSelfTest.java     |  17 +-
 ...gniteSqlSkipReducerOnUpdateDmlFlagSelfTest.java |  17 +-
 .../IgniteSqlSkipReducerOnUpdateDmlSelfTest.java   |  17 +-
 .../query/IgniteSqlSplitterSelfTest.java           |  17 +-
 .../processors/query/KillQueryFromClientTest.java  |  18 +-
 .../query/KillQueryFromNeighbourTest.java          |  18 +-
 .../query/KillQueryOnClientDisconnectTest.java     |  18 +-
 .../internal/processors/query/KillQueryTest.java   |  18 +-
 .../processors/query/LocalQueryLazyTest.java       |  17 +-
 .../processors/query/LongRunningQueryTest.java     |  17 +-
 .../query/MultipleStatementsSqlQuerySelfTest.java  |  17 +-
 .../processors/query/RunningQueriesTest.java       |  17 +-
 .../processors/query/SqlIllegalSchemaSelfTest.java |  17 +-
 .../SqlIncompatibleDataTypeExceptionTest.java      |  17 +-
 .../SqlLocalQueryConnectionAndStatementTest.java   |  17 +-
 .../processors/query/SqlNestedQuerySelfTest.java   |  17 +-
 .../processors/query/SqlPushDownFunctionTest.java  |  17 +-
 .../query/SqlQueryHistoryFromClientSelfTest.java   |  18 +-
 .../processors/query/SqlQueryHistorySelfTest.java  |  18 +-
 .../processors/query/SqlSchemaSelfTest.java        |  17 +-
 .../processors/query/SqlSystemViewsSelfTest.java   |  17 +-
 .../CacheQueryEntityWithDateTimeApiFieldsTest.java |  17 +-
 .../query/h2/DmlStatementsProcessorTest.java       |  17 +-
 .../query/h2/GridIndexFullRebuildTest.java         |  17 +-
 .../query/h2/GridIndexRebuildSelfTest.java         |  17 +-
 .../GridIndexRebuildWithMvccEnabledSelfTest.java   |  17 +-
 .../H2ResultSetIteratorNullifyOnEndSelfTest.java   |  17 +-
 .../query/h2/IgniteSqlBigIntegerKeyTest.java       |  17 +-
 .../query/h2/IgniteSqlQueryMinMaxTest.java         |  17 +-
 .../processors/query/h2/QueryDataPageScanTest.java |  17 +-
 .../query/h2/ThreadLocalObjectPoolSelfTest.java    |  17 +-
 .../query/h2/database/InlineIndexHelperTest.java   |  17 +-
 .../query/h2/sql/AbstractH2CompareQueryTest.java   |  17 +-
 .../query/h2/sql/BaseH2CompareQueryTest.java       |  17 +-
 .../processors/query/h2/sql/ExplainSelfTest.java   |  17 +-
 .../query/h2/sql/GridQueryParsingTest.java         |  17 +-
 .../sql/H2CompareBigQueryDistributedJoinsTest.java |  17 +-
 .../query/h2/sql/H2CompareBigQueryTest.java        |  17 +-
 .../query/h2/sql/ParameterTypeInferenceTest.java   |  17 +-
 .../query/h2/sql/SqlUnsupportedSelfTest.java       |  17 +-
 .../twostep/AbstractPartitionPruningBaseTest.java  |  17 +-
 .../AndOperationExtractPartitionSelfTest.java      |  17 +-
 .../BetweenOperationExtractPartitionSelfTest.java  |  17 +-
 .../query/h2/twostep/CacheQueryMemoryLeakTest.java |  17 +-
 .../h2/twostep/CreateTableWithDateKeySelfTest.java |  17 +-
 .../DisappearedCacheCauseRetryMessageSelfTest.java |  17 +-
 ...DisappearedCacheWasNotFoundMessageSelfTest.java |  17 +-
 .../twostep/DmlSelectPartitionPruningSelfTest.java |  17 +-
 .../InOperationExtractPartitionSelfTest.java       |  17 +-
 .../h2/twostep/JoinPartitionPruningSelfTest.java   |  17 +-
 .../query/h2/twostep/JoinSqlTestHelper.java        |  17 +-
 .../twostep/MvccDmlPartitionPruningSelfTest.java   |  17 +-
 .../twostep/NonCollocatedRetryMessageSelfTest.java |  17 +-
 ...neOrSinglePartitionsQueryOptimizationsTest.java |  17 +-
 .../h2/twostep/RetryCauseMessageSelfTest.java      |  17 +-
 .../h2/twostep/SqlDataTypeConversionTest.java      |  17 +-
 .../h2/twostep/TableViewSubquerySelfTest.java      |  17 +-
 .../processors/query/oom/AbstractQueryOOMTest.java |  17 +-
 .../query/oom/IgniteQueryOOMTestSuite.java         |  17 +-
 .../oom/QueryOOMWithQueryParallelismTest.java      |  17 +-
 .../oom/QueryOOMWithoutQueryParallelismTest.java   |  17 +-
 ...achePartitionedAtomicColumnConstraintsTest.java |  17 +-
 ...titionedTransactionalColumnConstraintsTest.java |  17 +-
 ...dTransactionalSnapshotColumnConstraintTest.java |  17 +-
 ...CacheReplicatedAtomicColumnConstraintsTest.java |  17 +-
 ...plicatedTransactionalColumnConstraintsTest.java |  17 +-
 ...dTransactionalSnapshotColumnConstraintTest.java |  17 +-
 .../sql/IgniteSQLColumnConstraintsTest.java        |  17 +-
 .../IgniteTransactionSQLColumnConstraintTest.java  |  17 +-
 ...qlConnectorConfigurationValidationSelfTest.java |  17 +-
 .../h2indexing/FetchingQueryCursorStressTest.java  |  17 +-
 .../tcp/GridOrderedMessageCancelSelfTest.java      |  17 +-
 .../org/apache/ignite/sqltests/BaseSqlTest.java    |  17 +-
 .../apache/ignite/sqltests/PartitionedSqlTest.java |  17 +-
 .../apache/ignite/sqltests/ReplicatedSqlTest.java  |  17 +-
 .../IgniteBinaryCacheQueryTestSuite.java           |  17 +-
 .../IgniteBinaryCacheQueryTestSuite2.java          |  17 +-
 ...eBinarySimpleNameMapperCacheQueryTestSuite.java |  17 +-
 .../IgniteCacheAffinityRunTestSuite.java           |  17 +-
 ...eBlockExchangeOnSqlReadOperationsTestSuite.java |  17 +-
 .../IgniteCacheConfigVariationQueryTestSuite.java  |  17 +-
 .../testsuites/IgniteCacheMvccSqlTestSuite.java    |  17 +-
 .../testsuites/IgniteCacheQuerySelfTestSuite3.java |  17 +-
 .../testsuites/IgniteCacheQuerySelfTestSuite4.java |  17 +-
 .../testsuites/IgniteCacheQuerySelfTestSuite5.java |  17 +-
 .../testsuites/IgniteCacheQuerySelfTestSuite6.java |  17 +-
 ...teCacheWithIndexingAndPersistenceTestSuite.java |  17 +-
 .../IgniteCacheWithIndexingTestSuite.java          |  17 +-
 .../IgniteDbMemoryLeakWithIndexingTestSuite.java   |  17 +-
 .../IgnitePdsWithIndexingCoreTestSuite.java        |  29 ++-
 .../testsuites/IgnitePdsWithIndexingTestSuite.java |  17 +-
 .../IgniteBinaryCacheQueryLazyTestSuite.java       |  17 +-
 .../IgniteBinaryCacheQueryLazyTestSuite2.java      |  17 +-
 .../util/GridCommandHandlerIndexingTest.java       |  29 ++-
 .../internal/processors/query/h2/sql/bigQuery.sql  |  18 +-
 modules/jcl/licenses/apache-2.0.txt                | 202 ---------------------
 modules/jcl/licenses/gg-community.txt              |  13 ++
 modules/jcl/pom.xml                                |  37 ++--
 .../org/apache/ignite/logger/jcl/JclLogger.java    |  17 +-
 .../org/apache/ignite/logger/jcl/package-info.java |  17 +-
 .../apache/ignite/logger/jcl/JclLoggerTest.java    |  17 +-
 .../org/apache/ignite/logger/jcl/package-info.java |  17 +-
 .../ignite/testsuites/IgniteJclTestSuite.java      |  17 +-
 modules/jms11/licenses/apache-2.0.txt              | 202 ---------------------
 modules/jms11/licenses/gg-community.txt            |  13 ++
 modules/jms11/pom.xml                              |  41 ++---
 .../apache/ignite/stream/jms11/JmsStreamer.java    |  17 +-
 .../ignite/stream/jms11/MessageTransformer.java    |  17 +-
 .../apache/ignite/stream/jms11/package-info.java   |  27 ++-
 .../ignite/stream/jms11/IgniteJmsStreamerTest.java |  17 +-
 .../stream/jms11/IgniteJmsStreamerTestSuite.java   |  17 +-
 .../ignite/stream/jms11/TestTransformers.java      |  17 +-
 .../apache/ignite/stream/jms11/package-info.java   |  27 ++-
 modules/jta/licenses/apache-2.0.txt                | 202 ---------------------
 modules/jta/licenses/gg-community.txt              |  13 ++
 modules/jta/pom.xml                                |  37 ++--
 .../org/apache/ignite/cache/jta/CacheTmLookup.java |  17 +-
 .../ignite/cache/jta/jndi/CacheJndiTmFactory.java  |  17 +-
 .../ignite/cache/jta/jndi/CacheJndiTmLookup.java   |  17 +-
 .../apache/ignite/cache/jta/jndi/package-info.java |  17 +-
 .../org/apache/ignite/cache/jta/package-info.java  |  17 +-
 .../cache/jta/reflect/CacheReflectionTmLookup.java |  17 +-
 .../ignite/cache/jta/reflect/package-info.java     |  17 +-
 .../jta/websphere/WebSphereLibertyTmFactory.java   |  17 +-
 .../cache/jta/websphere/WebSphereTmFactory.java    |  17 +-
 .../ignite/cache/jta/websphere/package-info.java   |  17 +-
 .../processors/cache/jta/CacheJtaManager.java      |  17 +-
 .../processors/cache/jta/CacheJtaResource.java     |  17 +-
 .../cache/CacheJndiTmFactorySelfTest.java          |  17 +-
 ...ridCacheJtaConfigurationValidationSelfTest.java |  17 +-
 ...ridCacheJtaFactoryConfigValidationSelfTest.java |  17 +-
 .../cache/GridJtaLifecycleAwareSelfTest.java       |  17 +-
 .../cache/GridJtaTransactionManagerSelfTest.java   |  17 +-
 .../cache/jta/AbstractCacheJtaSelfTest.java        |  17 +-
 .../GridPartitionedCacheJtaFactorySelfTest.java    |  17 +-
 ...dPartitionedCacheJtaFactoryUseSyncSelfTest.java |  17 +-
 ...PartitionedCacheJtaLookupClassNameSelfTest.java |  17 +-
 .../jta/GridReplicatedCacheJtaFactorySelfTest.java |  17 +-
 ...idReplicatedCacheJtaFactoryUseSyncSelfTest.java |  17 +-
 ...dReplicatedCacheJtaLookupClassNameSelfTest.java |  17 +-
 .../processors/cache/jta/package-info.java         |  17 +-
 .../ignite/testsuites/IgniteJtaTestSuite.java      |  17 +-
 modules/kafka/licenses/apache-2.0.txt              | 202 ---------------------
 modules/kafka/licenses/gg-community.txt            |  13 ++
 modules/kafka/pom.xml                              |  41 ++---
 .../apache/ignite/stream/kafka/KafkaStreamer.java  |  17 +-
 .../stream/kafka/connect/IgniteSinkConnector.java  |  17 +-
 .../stream/kafka/connect/IgniteSinkConstants.java  |  17 +-
 .../stream/kafka/connect/IgniteSinkTask.java       |  17 +-
 .../kafka/connect/IgniteSourceConnector.java       |  17 +-
 .../kafka/connect/IgniteSourceConstants.java       |  17 +-
 .../stream/kafka/connect/IgniteSourceTask.java     |  17 +-
 .../ignite/stream/kafka/connect/package-info.java  |  17 +-
 .../connect/serialization/CacheEventConverter.java |  17 +-
 .../serialization/CacheEventDeserializer.java      |  17 +-
 .../serialization/CacheEventSerializer.java        |  17 +-
 .../kafka/connect/serialization/package-info.java  |  17 +-
 .../apache/ignite/stream/kafka/package-info.java   |  27 ++-
 .../kafka/IgniteKafkaStreamerSelfTestSuite.java    |  17 +-
 .../stream/kafka/KafkaIgniteStreamerSelfTest.java  |  17 +-
 .../ignite/stream/kafka/TestKafkaBroker.java       |  17 +-
 .../kafka/connect/IgniteSinkConnectorMock.java     |  17 +-
 .../kafka/connect/IgniteSinkConnectorTest.java     |  17 +-
 .../stream/kafka/connect/IgniteSinkTaskMock.java   |  17 +-
 .../kafka/connect/IgniteSourceConnectorMock.java   |  17 +-
 .../kafka/connect/IgniteSourceConnectorTest.java   |  17 +-
 .../stream/kafka/connect/IgniteSourceTaskMock.java |  17 +-
 .../stream/kafka/connect/TestCacheEventFilter.java |  17 +-
 .../apache/ignite/stream/kafka/package-info.java   |  27 ++-
 .../kafka/src/test/resources/example-ignite.xml    |  27 ++-
 modules/kubernetes/config/Dockerfile               |  18 +-
 .../kubernetes/config/az/ignite-account-role.yaml  |  18 +-
 .../kubernetes/config/az/ignite-deployment.yaml    |  18 +-
 modules/kubernetes/config/az/ignite-namespace.yaml |  18 +-
 .../az/ignite-persistence-storage-class.yaml       |  18 +-
 .../kubernetes/config/az/ignite-role-binding.yaml  |  18 +-
 .../config/az/ignite-service-account.yaml          |  18 +-
 modules/kubernetes/config/az/ignite-service.yaml   |  18 +-
 .../kubernetes/config/az/ignite-stateful-set.yaml  |  18 +-
 .../config/az/ignite-wal-storage-class.yaml        |  18 +-
 .../kubernetes/config/eks/ignite-account-role.yaml |  18 +-
 .../kubernetes/config/eks/ignite-namespace.yaml    |  18 +-
 .../eks/ignite-persistence-storage-class.yaml      |  18 +-
 .../kubernetes/config/eks/ignite-role-binding.yaml |  18 +-
 .../config/eks/ignite-service-account.yaml         |  18 +-
 modules/kubernetes/config/eks/ignite-service.yaml  |  18 +-
 .../kubernetes/config/eks/ignite-stateful-set.yaml |  18 +-
 .../config/eks/ignite-wal-storage-class.yaml       |  18 +-
 .../config/example-kube-persistence-and-wal.xml    |  27 ++-
 .../kubernetes/config/example-kube-persistence.xml |  27 ++-
 modules/kubernetes/config/example-kube-rbac.xml    |  27 ++-
 modules/kubernetes/config/example-kube.xml         |  27 ++-
 .../kubernetes/config/gce/ignite-account-role.yaml |  18 +-
 .../kubernetes/config/gce/ignite-deployment.yaml   |  18 +-
 .../kubernetes/config/gce/ignite-namespace.yaml    |  18 +-
 .../gce/ignite-persistence-storage-class.yaml      |  18 +-
 .../kubernetes/config/gce/ignite-role-binding.yaml |  18 +-
 .../config/gce/ignite-service-account.yaml         |  18 +-
 modules/kubernetes/config/gce/ignite-service.yaml  |  18 +-
 .../kubernetes/config/gce/ignite-stateful-set.yaml |  18 +-
 .../config/gce/ignite-wal-storage-class.yaml       |  18 +-
 modules/kubernetes/config/ignite-deployment.yaml   |  18 +-
 modules/kubernetes/config/ignite-service.yaml      |  18 +-
 modules/kubernetes/config/run.sh                   |  17 +-
 modules/kubernetes/licenses/apache-2.0.txt         | 202 ---------------------
 modules/kubernetes/licenses/gg-community.txt       |  13 ++
 modules/kubernetes/pom.xml                         |  37 ++--
 .../kubernetes/TcpDiscoveryKubernetesIpFinder.java |  17 +-
 .../tcp/ipfinder/kubernetes/package-info.java      |  17 +-
 .../TcpDiscoveryKubernetesIpFinderSelfTest.java    |  17 +-
 .../tcp/ipfinder/kubernetes/package-info.java      |  17 +-
 .../testsuites/IgniteKubernetesTestSuite.java      |  17 +-
 modules/log4j/licenses/apache-2.0.txt              | 202 ---------------------
 modules/log4j/licenses/gg-community.txt            |  13 ++
 modules/log4j/pom.xml                              |  37 ++--
 .../log4j/Log4JDailyRollingFileAppender.java       |  17 +-
 .../log4j/Log4JExternallyRolledFileAppender.java   |  17 +-
 .../ignite/logger/log4j/Log4JFileAppender.java     |  17 +-
 .../apache/ignite/logger/log4j/Log4JLogger.java    |  17 +-
 .../apache/ignite/logger/log4j/Log4jFileAware.java |  17 +-
 .../ignite/logger/log4j/Log4jNodeIdFilePath.java   |  17 +-
 .../logger/log4j/Log4jRollingFileAppender.java     |  17 +-
 .../apache/ignite/logger/log4j/package-info.java   |  17 +-
 modules/log4j/src/test/config/log4j-debug.xml      |  27 ++-
 modules/log4j/src/test/config/log4j-info.xml       |  27 ++-
 .../logger/log4j/GridLog4jConfigUpdateTest.java    |  17 +-
 .../logger/log4j/GridLog4jCorrectFileNameTest.java |  17 +-
 .../logger/log4j/GridLog4jInitializedTest.java     |  17 +-
 .../logger/log4j/GridLog4jLoggingFileTest.java     |  17 +-
 .../logger/log4j/GridLog4jLoggingPathTest.java     |  17 +-
 .../logger/log4j/GridLog4jLoggingUrlTest.java      |  17 +-
 .../logger/log4j/GridLog4jNotInitializedTest.java  |  17 +-
 .../logger/log4j/GridLog4jWatchDelayTest.java      |  17 +-
 .../apache/ignite/logger/log4j/package-info.java   |  17 +-
 .../ignite/testsuites/IgniteLog4jTestSuite.java    |  17 +-
 modules/log4j2/licenses/apache-2.0.txt             | 202 ---------------------
 modules/log4j2/licenses/gg-community.txt           |  13 ++
 modules/log4j2/pom.xml                             |  37 ++--
 .../apache/ignite/logger/log4j2/Log4J2Logger.java  |  17 +-
 .../apache/ignite/logger/log4j2/package-info.java  |  17 +-
 modules/log4j2/src/test/config/log4j2-debug.xml    |  27 ++-
 modules/log4j2/src/test/config/log4j2-info.xml     |  27 ++-
 modules/log4j2/src/test/config/log4j2-markers.xml  |  27 ++-
 .../logger/log4j2/Log4j2ConfigUpdateTest.java      |  17 +-
 .../logger/log4j2/Log4j2LoggerMarkerTest.java      |  17 +-
 .../ignite/logger/log4j2/Log4j2LoggerSelfTest.java |  17 +-
 .../log4j2/Log4j2LoggerVerboseModeSelfTest.java    |  17 +-
 .../apache/ignite/logger/log4j2/package-info.java  |  17 +-
 .../ignite/testsuites/IgniteLog4j2TestSuite.java   |  17 +-
 modules/mesos/licenses/apache-2.0.txt              | 202 ---------------------
 modules/mesos/licenses/gg-community.txt            |  13 ++
 modules/mesos/pom.xml                              |  33 ++--
 .../org/apache/ignite/mesos/ClusterProperties.java |  17 +-
 .../org/apache/ignite/mesos/IgniteFramework.java   |  17 +-
 .../org/apache/ignite/mesos/IgniteScheduler.java   |  17 +-
 .../java/org/apache/ignite/mesos/IgniteTask.java   |  17 +-
 .../java/org/apache/ignite/mesos/package-info.java |  17 +-
 .../ignite/mesos/resource/IgniteProvider.java      |  17 +-
 .../apache/ignite/mesos/resource/JettyServer.java  |  17 +-
 .../ignite/mesos/resource/ResourceHandler.java     |  17 +-
 .../ignite/mesos/resource/ResourceProvider.java    |  17 +-
 .../apache/ignite/mesos/resource/package-info.java |  17 +-
 .../src/main/resources/ignite-default-config.xml   |  27 ++-
 .../org/apache/ignite/IgniteMesosTestSuite.java    |  17 +-
 .../ignite/mesos/IgniteSchedulerSelfTest.java      |  17 +-
 modules/ml/licenses/apache-2.0.txt                 | 202 ---------------------
 modules/ml/licenses/gg-community.txt               |  13 ++
 modules/ml/mleap-model-parser/pom.xml              |  35 ++--
 .../org/apache/ignite/ml/mleap/MLeapModel.java     |  17 +-
 .../apache/ignite/ml/mleap/MLeapModelParser.java   |  17 +-
 .../org/apache/ignite/ml/mleap/package-info.java   |  17 +-
 .../ignite/ml/mleap/IgniteMLeapTestSuite.java      |  17 +-
 .../ignite/ml/mleap/MLeapModelParserTest.java      |  17 +-
 modules/ml/pom.xml                                 |  37 ++--
 modules/ml/spark-model-parser/pom.xml              |  35 ++--
 .../ml/sparkmodelparser/SparkModelParser.java      |  17 +-
 .../ml/sparkmodelparser/SupportedSparkModels.java  |  17 +-
 .../UnsupportedSparkModelException.java            |  17 +-
 .../ignite/ml/sparkmodelparser/package-info.java   |  17 +-
 .../IgniteMLSparkModelParserTestSuite.java         |  17 +-
 .../ml/sparkmodelparser/SparkModelParserTest.java  |  17 +-
 .../main/java/org/apache/ignite/ml/Exportable.java |  17 +-
 .../main/java/org/apache/ignite/ml/Exporter.java   |  17 +-
 .../java/org/apache/ignite/ml/FileExporter.java    |  17 +-
 .../java/org/apache/ignite/ml/IgniteModel.java     |  17 +-
 .../gmm/CovarianceMatricesAggregator.java          |  17 +-
 .../apache/ignite/ml/clustering/gmm/GmmModel.java  |  17 +-
 .../ignite/ml/clustering/gmm/GmmPartitionData.java |  17 +-
 .../ignite/ml/clustering/gmm/GmmTrainer.java       |  17 +-
 .../gmm/MeanWithClusterProbAggregator.java         |  17 +-
 .../gmm/NewComponentStatisticsAggregator.java      |  17 +-
 .../ignite/ml/clustering/gmm/package-info.java     |  17 +-
 .../ignite/ml/clustering/kmeans/Clusterer.java     |  17 +-
 .../ml/clustering/kmeans/ClusterizationModel.java  |  17 +-
 .../ignite/ml/clustering/kmeans/KMeansModel.java   |  17 +-
 .../ml/clustering/kmeans/KMeansModelFormat.java    |  17 +-
 .../ignite/ml/clustering/kmeans/KMeansTrainer.java |  17 +-
 .../ignite/ml/clustering/kmeans/package-info.java  |  17 +-
 .../apache/ignite/ml/clustering/package-info.java  |  17 +-
 .../ignite/ml/composition/CompositionUtils.java    |  17 +-
 .../ignite/ml/composition/DatasetMapping.java      |  17 +-
 .../ml/composition/ModelOnFeaturesSubspace.java    |  17 +-
 .../ignite/ml/composition/ModelsComposition.java   |  17 +-
 .../ml/composition/ModelsCompositionFormat.java    |  17 +-
 .../ignite/ml/composition/bagging/BaggedModel.java |  17 +-
 .../ml/composition/bagging/BaggedTrainer.java      |  17 +-
 .../boosting/GDBBinaryClassifierTrainer.java       |  17 +-
 .../composition/boosting/GDBLearningStrategy.java  |  17 +-
 .../composition/boosting/GDBRegressionTrainer.java |  17 +-
 .../ignite/ml/composition/boosting/GDBTrainer.java |  17 +-
 .../boosting/convergence/ConvergenceChecker.java   |  17 +-
 .../convergence/ConvergenceCheckerFactory.java     |  17 +-
 .../mean/MeanAbsValueConvergenceChecker.java       |  17 +-
 .../MeanAbsValueConvergenceCheckerFactory.java     |  17 +-
 .../boosting/convergence/mean/package-info.java    |  17 +-
 .../median/MedianOfMedianConvergenceChecker.java   |  17 +-
 .../MedianOfMedianConvergenceCheckerFactory.java   |  17 +-
 .../boosting/convergence/median/package-info.java  |  17 +-
 .../boosting/convergence/package-info.java         |  17 +-
 .../convergence/simple/ConvergenceCheckerStub.java |  17 +-
 .../simple/ConvergenceCheckerStubFactory.java      |  17 +-
 .../boosting/convergence/simple/package-info.java  |  17 +-
 .../ml/composition/boosting/loss/LogLoss.java      |  17 +-
 .../ignite/ml/composition/boosting/loss/Loss.java  |  17 +-
 .../ml/composition/boosting/loss/SquaredError.java |  17 +-
 .../ml/composition/boosting/loss/package-info.java |  17 +-
 .../ml/composition/boosting/package-info.java      |  17 +-
 .../ml/composition/combinators/package-info.java   |  17 +-
 .../parallel/ModelsParallelComposition.java        |  17 +-
 .../parallel/TrainersParallelComposition.java      |  17 +-
 .../combinators/parallel/package-info.java         |  17 +-
 .../sequential/ModelsSequentialComposition.java    |  17 +-
 .../sequential/TrainersSequentialComposition.java  |  17 +-
 .../combinators/sequential/package-info.java       |  17 +-
 .../apache/ignite/ml/composition/package-info.java |  17 +-
 .../MeanValuePredictionsAggregator.java            |  17 +-
 .../OnMajorityPredictionsAggregator.java           |  17 +-
 .../PredictionsAggregator.java                     |  17 +-
 .../WeightedPredictionsAggregator.java             |  17 +-
 .../predictionsaggregator/package-info.java        |  17 +-
 .../stacking/SimpleStackedDatasetTrainer.java      |  17 +-
 .../stacking/StackedDatasetTrainer.java            |  17 +-
 .../ml/composition/stacking/StackedModel.java      |  17 +-
 .../stacking/StackedVectorDatasetTrainer.java      |  17 +-
 .../ml/composition/stacking/package-info.java      |  17 +-
 .../java/org/apache/ignite/ml/dataset/Dataset.java |  17 +-
 .../apache/ignite/ml/dataset/DatasetBuilder.java   |  17 +-
 .../apache/ignite/ml/dataset/DatasetFactory.java   |  17 +-
 .../ignite/ml/dataset/PartitionContextBuilder.java |  17 +-
 .../ignite/ml/dataset/PartitionDataBuilder.java    |  17 +-
 .../apache/ignite/ml/dataset/UpstreamEntry.java    |  17 +-
 .../ignite/ml/dataset/UpstreamTransformer.java     |  17 +-
 .../ml/dataset/UpstreamTransformerBuilder.java     |  17 +-
 .../ignite/ml/dataset/feature/BucketMeta.java      |  17 +-
 .../ml/dataset/feature/DistributionComputer.java   |  17 +-
 .../ignite/ml/dataset/feature/FeatureMeta.java     |  17 +-
 .../ignite/ml/dataset/feature/Histogram.java       |  17 +-
 .../ignite/ml/dataset/feature/ObjectHistogram.java |  17 +-
 .../dataset/feature/extractor/ExtractionUtils.java |  17 +-
 .../ml/dataset/feature/extractor/Vectorizer.java   |  17 +-
 .../extractor/impl/BinaryObjectVectorizer.java     |  17 +-
 .../extractor/impl/DoubleArrayVectorizer.java      |  17 +-
 .../feature/extractor/impl/DummyVectorizer.java    |  17 +-
 .../extractor/impl/LabeledDummyVectorizer.java     |  17 +-
 .../feature/extractor/impl/package-info.java       |  18 +-
 .../ml/dataset/feature/extractor/package-info.java |  18 +-
 .../ignite/ml/dataset/feature/package-info.java    |  18 +-
 .../bootstrapping/BootstrappedDatasetBuilder.java  |  17 +-
 .../BootstrappedDatasetPartition.java              |  17 +-
 .../impl/bootstrapping/BootstrappedVector.java     |  17 +-
 .../dataset/impl/bootstrapping/package-info.java   |  18 +-
 .../ml/dataset/impl/cache/CacheBasedDataset.java   |  17 +-
 .../impl/cache/CacheBasedDatasetBuilder.java       |  17 +-
 .../ignite/ml/dataset/impl/cache/package-info.java |  17 +-
 .../ml/dataset/impl/cache/util/ComputeUtils.java   |  17 +-
 .../cache/util/DatasetAffinityFunctionWrapper.java |  17 +-
 .../IteratorWithConcurrentModificationChecker.java |  17 +-
 .../impl/cache/util/PartitionDataStorage.java      |  17 +-
 .../ml/dataset/impl/cache/util/package-info.java   |  17 +-
 .../ignite/ml/dataset/impl/local/LocalDataset.java |  17 +-
 .../ml/dataset/impl/local/LocalDatasetBuilder.java |  17 +-
 .../ignite/ml/dataset/impl/local/package-info.java |  17 +-
 .../ignite/ml/dataset/impl/package-info.java       |  17 +-
 .../org/apache/ignite/ml/dataset/package-info.java |  17 +-
 .../ml/dataset/primitive/DatasetWrapper.java       |  17 +-
 .../FeatureMatrixWithLabelsOnHeapData.java         |  17 +-
 .../FeatureMatrixWithLabelsOnHeapDataBuilder.java  |  17 +-
 .../ignite/ml/dataset/primitive/SimpleDataset.java |  17 +-
 .../ml/dataset/primitive/SimpleLabeledDataset.java |  17 +-
 .../builder/context/EmptyContextBuilder.java       |  17 +-
 .../primitive/builder/context/package-info.java    |  17 +-
 .../builder/data/SimpleDatasetDataBuilder.java     |  17 +-
 .../data/SimpleLabeledDatasetDataBuilder.java      |  17 +-
 .../primitive/builder/data/package-info.java       |  17 +-
 .../ml/dataset/primitive/builder/package-info.java |  17 +-
 .../ml/dataset/primitive/context/EmptyContext.java |  17 +-
 .../ml/dataset/primitive/context/package-info.java |  17 +-
 .../dataset/primitive/data/SimpleDatasetData.java  |  17 +-
 .../primitive/data/SimpleLabeledDatasetData.java   |  17 +-
 .../ml/dataset/primitive/data/package-info.java    |  17 +-
 .../ignite/ml/dataset/primitive/package-info.java  |  17 +-
 .../DefaultLearningEnvironmentBuilder.java         |  17 +-
 .../ignite/ml/environment/LearningEnvironment.java |  17 +-
 .../ml/environment/LearningEnvironmentBuilder.java |  17 +-
 .../ml/environment/logging/ConsoleLogger.java      |  17 +-
 .../ml/environment/logging/CustomMLLogger.java     |  17 +-
 .../ignite/ml/environment/logging/MLLogger.java    |  17 +-
 .../ignite/ml/environment/logging/NoOpLogger.java  |  17 +-
 .../ml/environment/logging/package-info.java       |  17 +-
 .../apache/ignite/ml/environment/package-info.java |  17 +-
 .../parallelism/DefaultParallelismStrategy.java    |  17 +-
 .../parallelism/NoParallelismStrategy.java         |  17 +-
 .../parallelism/ParallelismStrategy.java           |  17 +-
 .../ignite/ml/environment/parallelism/Promise.java |  17 +-
 .../ml/environment/parallelism/package-info.java   |  17 +-
 .../org/apache/ignite/ml/genetic/Chromosome.java   |  17 +-
 .../org/apache/ignite/ml/genetic/CrossOverJob.java |  17 +-
 .../apache/ignite/ml/genetic/CrossOverTask.java    |  17 +-
 .../org/apache/ignite/ml/genetic/FitnessJob.java   |  17 +-
 .../org/apache/ignite/ml/genetic/FitnessTask.java  |  17 +-
 .../java/org/apache/ignite/ml/genetic/GAGrid.java  |  17 +-
 .../java/org/apache/ignite/ml/genetic/Gene.java    |  17 +-
 .../apache/ignite/ml/genetic/IFitnessFunction.java |  17 +-
 .../org/apache/ignite/ml/genetic/MutateJob.java    |  17 +-
 .../org/apache/ignite/ml/genetic/MutateTask.java   |  17 +-
 .../ml/genetic/RouletteWheelSelectionJob.java      |  17 +-
 .../ml/genetic/RouletteWheelSelectionTask.java     |  17 +-
 .../ignite/ml/genetic/TruncateSelectionJob.java    |  17 +-
 .../ignite/ml/genetic/TruncateSelectionTask.java   |  17 +-
 .../ignite/ml/genetic/cache/GeneCacheConfig.java   |  17 +-
 .../ml/genetic/cache/PopulationCacheConfig.java    |  17 +-
 .../ignite/ml/genetic/cache/package-info.java      |  17 +-
 .../ml/genetic/functions/GAGridFunction.java       |  17 +-
 .../ignite/ml/genetic/functions/package-info.java  |  17 +-
 .../org/apache/ignite/ml/genetic/package-info.java |  17 +-
 .../ml/genetic/parameter/ChromosomeCriteria.java   |  17 +-
 .../ml/genetic/parameter/GAConfiguration.java      |  17 +-
 .../ml/genetic/parameter/GAGridConstants.java      |  17 +-
 .../ml/genetic/parameter/ITerminateCriteria.java   |  17 +-
 .../ignite/ml/genetic/parameter/package-info.java  |  17 +-
 .../ignite/ml/genetic/utils/GAGridUtils.java       |  17 +-
 .../ignite/ml/genetic/utils/package-info.java      |  17 +-
 .../ml/inference/IgniteModelStorageUtil.java       |  17 +-
 .../java/org/apache/ignite/ml/inference/Model.java |  17 +-
 .../ignite/ml/inference/ModelDescriptor.java       |  17 +-
 .../apache/ignite/ml/inference/ModelSignature.java |  17 +-
 .../ml/inference/builder/AsyncModelBuilder.java    |  17 +-
 .../builder/IgniteDistributedModelBuilder.java     |  17 +-
 .../ml/inference/builder/SingleModelBuilder.java   |  17 +-
 .../ml/inference/builder/SyncModelBuilder.java     |  17 +-
 .../ml/inference/builder/ThreadedModelBuilder.java |  17 +-
 .../ignite/ml/inference/builder/package-info.java  |  17 +-
 .../apache/ignite/ml/inference/package-info.java   |  17 +-
 .../ml/inference/parser/IgniteModelParser.java     |  17 +-
 .../ignite/ml/inference/parser/ModelParser.java    |  17 +-
 .../ignite/ml/inference/parser/package-info.java   |  17 +-
 .../ml/inference/reader/FileSystemModelReader.java |  17 +-
 .../ml/inference/reader/InMemoryModelReader.java   |  17 +-
 .../ignite/ml/inference/reader/ModelReader.java    |  17 +-
 .../inference/reader/ModelStorageModelReader.java  |  17 +-
 .../ignite/ml/inference/reader/package-info.java   |  17 +-
 .../descriptor/IgniteModelDescriptorStorage.java   |  17 +-
 .../descriptor/LocalModelDescriptorStorage.java    |  17 +-
 .../storage/descriptor/ModelDescriptorStorage.java |  17 +-
 .../descriptor/ModelDescriptorStorageFactory.java  |  17 +-
 .../inference/storage/descriptor/package-info.java |  17 +-
 .../storage/model/DefaultModelStorage.java         |  17 +-
 .../ml/inference/storage/model/Directory.java      |  17 +-
 .../ignite/ml/inference/storage/model/File.java    |  17 +-
 .../inference/storage/model/FileOrDirectory.java   |  17 +-
 .../storage/model/IgniteModelStorageProvider.java  |  17 +-
 .../storage/model/LocalModelStorageProvider.java   |  17 +-
 .../ml/inference/storage/model/ModelStorage.java   |  17 +-
 .../storage/model/ModelStorageFactory.java         |  17 +-
 .../storage/model/ModelStorageProvider.java        |  17 +-
 .../ml/inference/storage/model/package-info.java   |  17 +-
 .../ignite/ml/inference/storage/package-info.java  |  17 +-
 .../ml/inference/util/DirectorySerializer.java     |  17 +-
 .../ignite/ml/inference/util/package-info.java     |  17 +-
 .../java/org/apache/ignite/ml/knn/KNNUtils.java    |  17 +-
 .../ignite/ml/knn/NNClassificationModel.java       |  17 +-
 .../ignite/ml/knn/ann/ANNClassificationModel.java  |  17 +-
 .../ml/knn/ann/ANNClassificationTrainer.java       |  17 +-
 .../apache/ignite/ml/knn/ann/ANNModelFormat.java   |  17 +-
 .../apache/ignite/ml/knn/ann/ProbableLabel.java    |  17 +-
 .../org/apache/ignite/ml/knn/ann/package-info.java |  17 +-
 .../knn/classification/KNNClassificationModel.java |  17 +-
 .../classification/KNNClassificationTrainer.java   |  17 +-
 .../ml/knn/classification/KNNModelFormat.java      |  17 +-
 .../ignite/ml/knn/classification/NNStrategy.java   |  17 +-
 .../ignite/ml/knn/classification/package-info.java |  17 +-
 .../org/apache/ignite/ml/knn/package-info.java     |  17 +-
 .../ml/knn/regression/KNNRegressionModel.java      |  17 +-
 .../ml/knn/regression/KNNRegressionTrainer.java    |  17 +-
 .../ignite/ml/knn/regression/package-info.java     |  17 +-
 .../main/java/org/apache/ignite/ml/math/Blas.java  |  17 +-
 .../org/apache/ignite/ml/math/Destroyable.java     |  17 +-
 .../org/apache/ignite/ml/math/MetaAttributes.java  |  17 +-
 .../apache/ignite/ml/math/StorageConstants.java    |  17 +-
 .../apache/ignite/ml/math/StorageOpsMetrics.java   |  17 +-
 .../java/org/apache/ignite/ml/math/Tracer.java     |  17 +-
 .../ignite/ml/math/distances/DistanceMeasure.java  |  17 +-
 .../ml/math/distances/EuclideanDistance.java       |  17 +-
 .../ignite/ml/math/distances/HammingDistance.java  |  17 +-
 .../ml/math/distances/ManhattanDistance.java       |  17 +-
 .../ignite/ml/math/distances/package-info.java     |  17 +-
 .../ml/math/exceptions/CardinalityException.java   |  17 +-
 .../ml/math/exceptions/ColumnIndexException.java   |  17 +-
 .../ignite/ml/math/exceptions/IndexException.java  |  17 +-
 .../exceptions/MathIllegalArgumentException.java   |  17 +-
 .../ml/math/exceptions/MathRuntimeException.java   |  17 +-
 .../ignite/ml/math/exceptions/NoDataException.java |  17 +-
 .../math/exceptions/NonSquareMatrixException.java  |  17 +-
 .../ml/math/exceptions/RowIndexException.java      |  17 +-
 .../math/exceptions/SingularMatrixException.java   |  17 +-
 .../exceptions/UnsupportedOperationException.java  |  17 +-
 .../ml/math/exceptions/knn/EmptyFileException.java |  17 +-
 .../math/exceptions/knn/FileParsingException.java  |  17 +-
 .../exceptions/knn/NoLabelVectorException.java     |  17 +-
 .../ml/math/exceptions/knn/package-info.java       |  17 +-
 .../ignite/ml/math/exceptions/package-info.java    |  17 +-
 .../UnknownCategorialFeatureValue.java             |  17 +-
 .../exceptions/preprocessing/package-info.java     |  17 +-
 .../apache/ignite/ml/math/functions/Functions.java |  17 +-
 .../ignite/ml/math/functions/IgniteBiConsumer.java |  17 +-
 .../ignite/ml/math/functions/IgniteBiFunction.java |  17 +-
 .../ml/math/functions/IgniteBinaryOperator.java    |  17 +-
 .../ignite/ml/math/functions/IgniteConsumer.java   |  17 +-
 .../ml/math/functions/IgniteCurriedBiFunction.java |  17 +-
 .../math/functions/IgniteCurriedTriFunction.java   |  17 +-
 ...IgniteDifferentiableDoubleToDoubleFunction.java |  17 +-
 ...IgniteDifferentiableVectorToDoubleFunction.java |  17 +-
 .../ml/math/functions/IgniteDoubleFunction.java    |  17 +-
 .../ignite/ml/math/functions/IgniteFunction.java   |  17 +-
 .../IgniteIntDoubleToDoubleBiFunction.java         |  17 +-
 .../functions/IgniteIntIntToIntBiFunction.java     |  17 +-
 .../ignite/ml/math/functions/IgniteSupplier.java   |  17 +-
 .../ml/math/functions/IgniteToDoubleFunction.java  |  17 +-
 .../ml/math/functions/IgniteTriConsumer.java       |  17 +-
 .../ml/math/functions/IgniteTriFunction.java       |  17 +-
 .../ml/math/functions/IntDoubleToVoidFunction.java |  17 +-
 .../math/functions/IntIntDoubleToVoidFunction.java |  17 +-
 .../ml/math/functions/IntIntToDoubleFunction.java  |  17 +-
 .../ignite/ml/math/functions/package-info.java     |  17 +-
 .../ml/math/isolve/IterativeSolverResult.java      |  17 +-
 .../ignite/ml/math/isolve/lsqr/AbstractLSQR.java   |  17 +-
 .../ignite/ml/math/isolve/lsqr/LSQROnHeap.java     |  17 +-
 .../ml/math/isolve/lsqr/LSQRPartitionContext.java  |  17 +-
 .../ignite/ml/math/isolve/lsqr/LSQRResult.java     |  17 +-
 .../ignite/ml/math/isolve/lsqr/package-info.java   |  17 +-
 .../apache/ignite/ml/math/isolve/package-info.java |  17 +-
 .../org/apache/ignite/ml/math/package-info.java    |  17 +-
 .../ml/math/primitives/matrix/AbstractMatrix.java  |  17 +-
 .../ml/math/primitives/matrix/LUDecomposition.java |  17 +-
 .../ignite/ml/math/primitives/matrix/Matrix.java   |  17 +-
 .../ml/math/primitives/matrix/MatrixStorage.java   |  17 +-
 .../ml/math/primitives/matrix/OrderedMatrix.java   |  17 +-
 .../math/primitives/matrix/impl/DenseMatrix.java   |  17 +-
 .../math/primitives/matrix/impl/SparseMatrix.java  |  17 +-
 .../ml/math/primitives/matrix/impl/ViewMatrix.java |  17 +-
 .../math/primitives/matrix/impl/package-info.java  |  17 +-
 .../ml/math/primitives/matrix/package-info.java    |  17 +-
 .../matrix/storage/DenseMatrixStorage.java         |  17 +-
 .../matrix/storage/SparseMatrixStorage.java        |  17 +-
 .../matrix/storage/ViewMatrixStorage.java          |  17 +-
 .../primitives/matrix/storage/package-info.java    |  17 +-
 .../ignite/ml/math/primitives/package-info.java    |  17 +-
 .../ml/math/primitives/vector/AbstractVector.java  |  17 +-
 .../ml/math/primitives/vector/NamedVector.java     |  17 +-
 .../ignite/ml/math/primitives/vector/Vector.java   |  17 +-
 .../ml/math/primitives/vector/VectorStorage.java   |  17 +-
 .../ml/math/primitives/vector/VectorUtils.java     |  17 +-
 .../vector/impl/DelegatingNamedVector.java         |  17 +-
 .../primitives/vector/impl/DelegatingVector.java   |  17 +-
 .../math/primitives/vector/impl/DenseVector.java   |  17 +-
 .../math/primitives/vector/impl/SparseVector.java  |  17 +-
 .../ml/math/primitives/vector/impl/VectorView.java |  17 +-
 .../vector/impl/VectorizedViewMatrix.java          |  17 +-
 .../math/primitives/vector/impl/package-info.java  |  17 +-
 .../ml/math/primitives/vector/package-info.java    |  17 +-
 .../vector/storage/DenseVectorStorage.java         |  17 +-
 .../vector/storage/SparseVectorStorage.java        |  17 +-
 .../vector/storage/VectorViewStorage.java          |  17 +-
 .../storage/VectorizedViewMatrixStorage.java       |  17 +-
 .../primitives/vector/storage/package-info.java    |  17 +-
 .../apache/ignite/ml/math/stat/Distribution.java   |  17 +-
 .../ignite/ml/math/stat/DistributionMixture.java   |  17 +-
 .../stat/MultivariateGaussianDistribution.java     |  17 +-
 .../apache/ignite/ml/math/stat/package-info.java   |  17 +-
 .../org/apache/ignite/ml/math/util/MapUtil.java    |  17 +-
 .../org/apache/ignite/ml/math/util/MatrixUtil.java |  17 +-
 .../apache/ignite/ml/math/util/package-info.java   |  17 +-
 .../ignite/ml/multiclass/MultiClassModel.java      |  17 +-
 .../ignite/ml/multiclass/OneVsRestTrainer.java     |  17 +-
 .../apache/ignite/ml/multiclass/package-info.java  |  17 +-
 .../discrete/DiscreteNaiveBayesModel.java          |  17 +-
 .../discrete/DiscreteNaiveBayesSumsHolder.java     |  17 +-
 .../discrete/DiscreteNaiveBayesTrainer.java        |  17 +-
 .../ml/naivebayes/discrete/package-info.java       |  17 +-
 .../gaussian/GaussianNaiveBayesModel.java          |  17 +-
 .../gaussian/GaussianNaiveBayesSumsHolder.java     |  17 +-
 .../gaussian/GaussianNaiveBayesTrainer.java        |  17 +-
 .../ml/naivebayes/gaussian/package-info.java       |  17 +-
 .../apache/ignite/ml/naivebayes/package-info.java  |  17 +-
 .../java/org/apache/ignite/ml/nn/Activators.java   |  17 +-
 .../java/org/apache/ignite/ml/nn/MLPLayer.java     |  17 +-
 .../java/org/apache/ignite/ml/nn/MLPState.java     |  17 +-
 .../java/org/apache/ignite/ml/nn/MLPTrainer.java   |  17 +-
 .../apache/ignite/ml/nn/MultilayerPerceptron.java  |  17 +-
 .../ignite/ml/nn/ReplicatedVectorMatrix.java       |  17 +-
 .../org/apache/ignite/ml/nn/UpdatesStrategy.java   |  17 +-
 .../ml/nn/architecture/LayerArchitecture.java      |  17 +-
 .../ignite/ml/nn/architecture/MLPArchitecture.java |  17 +-
 .../TransformationLayerArchitecture.java           |  17 +-
 .../ignite/ml/nn/architecture/package-info.java    |  17 +-
 .../ignite/ml/nn/initializers/MLPInitializer.java  |  17 +-
 .../ml/nn/initializers/RandomInitializer.java      |  17 +-
 .../ignite/ml/nn/initializers/package-info.java    |  17 +-
 .../java/org/apache/ignite/ml/nn/package-info.java |  17 +-
 .../ignite/ml/optimization/BaseParametrized.java   |  17 +-
 .../ignite/ml/optimization/LossFunctions.java      |  17 +-
 .../ignite/ml/optimization/Parametrized.java       |  17 +-
 .../ignite/ml/optimization/SmoothParametrized.java |  17 +-
 .../ignite/ml/optimization/package-info.java       |  17 +-
 .../updatecalculators/NesterovParameterUpdate.java |  17 +-
 .../NesterovUpdateCalculator.java                  |  17 +-
 .../ParameterUpdateCalculator.java                 |  17 +-
 .../updatecalculators/RPropParameterUpdate.java    |  17 +-
 .../updatecalculators/RPropUpdateCalculator.java   |  17 +-
 .../updatecalculators/SimpleGDParameterUpdate.java |  17 +-
 .../SimpleGDUpdateCalculator.java                  |  17 +-
 .../updatecalculators/package-info.java            |  17 +-
 .../java/org/apache/ignite/ml/package-info.java    |  17 +-
 .../org/apache/ignite/ml/pipeline/Pipeline.java    |  17 +-
 .../org/apache/ignite/ml/pipeline/PipelineMdl.java |  17 +-
 .../apache/ignite/ml/pipeline/package-info.java    |  17 +-
 .../ml/preprocessing/PreprocessingTrainer.java     |  17 +-
 .../ignite/ml/preprocessing/Preprocessor.java      |  17 +-
 .../binarization/BinarizationPreprocessor.java     |  17 +-
 .../binarization/BinarizationTrainer.java          |  17 +-
 .../preprocessing/binarization/package-info.java   |  17 +-
 .../developer/MappedPreprocessor.java              |  17 +-
 .../developer/PatchedPreprocessor.java             |  17 +-
 .../ml/preprocessing/developer/package-info.java   |  17 +-
 .../encoding/EncoderPartitionData.java             |  17 +-
 .../encoding/EncoderPreprocessor.java              |  17 +-
 .../encoding/EncoderSortingStrategy.java           |  17 +-
 .../ml/preprocessing/encoding/EncoderTrainer.java  |  17 +-
 .../ml/preprocessing/encoding/EncoderType.java     |  17 +-
 .../onehotencoder/OneHotEncoderPreprocessor.java   |  17 +-
 .../encoding/onehotencoder/package-info.java       |  17 +-
 .../ml/preprocessing/encoding/package-info.java    |  17 +-
 .../stringencoder/StringEncoderPreprocessor.java   |  17 +-
 .../encoding/stringencoder/package-info.java       |  17 +-
 .../imputing/ImputerPartitionData.java             |  17 +-
 .../imputing/ImputerPreprocessor.java              |  17 +-
 .../ml/preprocessing/imputing/ImputerTrainer.java  |  17 +-
 .../preprocessing/imputing/ImputingStrategy.java   |  17 +-
 .../ml/preprocessing/imputing/package-info.java    |  17 +-
 .../maxabsscaling/MaxAbsScalerPartitionData.java   |  17 +-
 .../maxabsscaling/MaxAbsScalerPreprocessor.java    |  17 +-
 .../maxabsscaling/MaxAbsScalerTrainer.java         |  17 +-
 .../preprocessing/maxabsscaling/package-info.java  |  17 +-
 .../minmaxscaling/MinMaxScalerPartitionData.java   |  17 +-
 .../minmaxscaling/MinMaxScalerPreprocessor.java    |  17 +-
 .../minmaxscaling/MinMaxScalerTrainer.java         |  17 +-
 .../preprocessing/minmaxscaling/package-info.java  |  17 +-
 .../normalization/NormalizationPreprocessor.java   |  17 +-
 .../normalization/NormalizationTrainer.java        |  17 +-
 .../preprocessing/normalization/package-info.java  |  17 +-
 .../ignite/ml/preprocessing/package-info.java      |  17 +-
 .../standardscaling/StandardScalerData.java        |  17 +-
 .../StandardScalerPreprocessor.java                |  17 +-
 .../standardscaling/StandardScalerTrainer.java     |  17 +-
 .../standardscaling/package-info.java              |  17 +-
 .../linear/LinearRegressionLSQRTrainer.java        |  17 +-
 .../regressions/linear/LinearRegressionModel.java  |  17 +-
 .../linear/LinearRegressionSGDTrainer.java         |  17 +-
 .../ignite/ml/regressions/linear/package-info.java |  17 +-
 .../logistic/LogisticRegressionModel.java          |  17 +-
 .../logistic/LogisticRegressionSGDTrainer.java     |  17 +-
 .../ml/regressions/logistic/package-info.java      |  17 +-
 .../apache/ignite/ml/regressions/package-info.java |  17 +-
 .../ignite/ml/selection/cv/CrossValidation.java    |  17 +-
 .../ml/selection/cv/CrossValidationResult.java     |  17 +-
 .../ignite/ml/selection/cv/package-info.java       |  17 +-
 .../apache/ignite/ml/selection/package-info.java   |  17 +-
 .../ignite/ml/selection/paramgrid/ParamGrid.java   |  17 +-
 .../selection/paramgrid/ParameterSetGenerator.java |  17 +-
 .../ml/selection/paramgrid/package-info.java       |  17 +-
 .../ignite/ml/selection/scoring/LabelPair.java     |  17 +-
 .../scoring/cursor/CacheBasedLabelPairCursor.java  |  17 +-
 .../selection/scoring/cursor/LabelPairCursor.java  |  17 +-
 .../scoring/cursor/LocalLabelPairCursor.java       |  17 +-
 .../ml/selection/scoring/cursor/package-info.java  |  17 +-
 .../ml/selection/scoring/evaluator/Evaluator.java  |  17 +-
 .../selection/scoring/evaluator/package-info.java  |  17 +-
 .../selection/scoring/metric/AbstractMetrics.java  |  17 +-
 .../ignite/ml/selection/scoring/metric/Metric.java |  17 +-
 .../ml/selection/scoring/metric/MetricValues.java  |  17 +-
 .../scoring/metric/classification/Accuracy.java    |  17 +-
 .../BinaryClassificationMetricValues.java          |  17 +-
 .../BinaryClassificationMetrics.java               |  17 +-
 .../scoring/metric/classification/ClassMetric.java |  17 +-
 .../scoring/metric/classification/Fmeasure.java    |  17 +-
 .../scoring/metric/classification/Precision.java   |  17 +-
 .../scoring/metric/classification/ROCAUC.java      |  17 +-
 .../scoring/metric/classification/Recall.java      |  17 +-
 .../metric/classification/package-info.java        |  17 +-
 .../exceptions/UnknownClassLabelException.java     |  17 +-
 .../scoring/metric/exceptions/package-info.java    |  17 +-
 .../ml/selection/scoring/metric/package-info.java  |  17 +-
 .../metric/regression/RegressionMetricValues.java  |  17 +-
 .../metric/regression/RegressionMetrics.java       |  17 +-
 .../scoring/metric/regression/package-info.java    |  17 +-
 .../ignite/ml/selection/scoring/package-info.java  |  17 +-
 .../selection/split/TrainTestDatasetSplitter.java  |  17 +-
 .../ignite/ml/selection/split/TrainTestSplit.java  |  17 +-
 .../split/mapper/SHA256UniformMapper.java          |  17 +-
 .../ml/selection/split/mapper/UniformMapper.java   |  17 +-
 .../ml/selection/split/mapper/package-info.java    |  17 +-
 .../ignite/ml/selection/split/package-info.java    |  17 +-
 .../org/apache/ignite/ml/sql/SQLFunctions.java     |  17 +-
 .../apache/ignite/ml/sql/SqlDatasetBuilder.java    |  17 +-
 .../org/apache/ignite/ml/sql/package-info.java     |  17 +-
 .../org/apache/ignite/ml/structures/Dataset.java   |  17 +-
 .../apache/ignite/ml/structures/DatasetRow.java    |  17 +-
 .../ignite/ml/structures/FeatureMetadata.java      |  17 +-
 .../apache/ignite/ml/structures/LabeledVector.java |  17 +-
 .../ignite/ml/structures/LabeledVectorSet.java     |  17 +-
 .../structures/LabeledVectorSetTestTrainPair.java  |  17 +-
 .../apache/ignite/ml/structures/package-info.java  |  17 +-
 .../partition/LabelPartitionDataBuilderOnHeap.java |  17 +-
 .../partition/LabelPartitionDataOnHeap.java        |  17 +-
 .../LabeledDatasetPartitionDataBuilderOnHeap.java  |  17 +-
 .../ml/structures/partition/package-info.java      |  17 +-
 .../preprocessing/LabeledDatasetLoader.java        |  17 +-
 .../ml/structures/preprocessing/package-info.java  |  17 +-
 .../ml/svm/SVMLinearClassificationModel.java       |  17 +-
 .../ml/svm/SVMLinearClassificationTrainer.java     |  17 +-
 .../org/apache/ignite/ml/svm/package-info.java     |  17 +-
 .../ignite/ml/trainers/AdaptableDatasetModel.java  |  17 +-
 .../ml/trainers/AdaptableDatasetTrainer.java       |  17 +-
 .../apache/ignite/ml/trainers/DatasetTrainer.java  |  17 +-
 .../ignite/ml/trainers/FeatureLabelExtractor.java  |  17 +-
 .../ml/trainers/MultiLabelDatasetTrainer.java      |  17 +-
 .../ml/trainers/SingleLabelDatasetTrainer.java     |  17 +-
 .../ignite/ml/trainers/TrainerTransformers.java    |  17 +-
 .../apache/ignite/ml/trainers/package-info.java    |  17 +-
 .../transformers/BaggingUpstreamTransformer.java   |  17 +-
 .../ml/trainers/transformers/package-info.java     |  17 +-
 .../org/apache/ignite/ml/tree/DecisionTree.java    |  17 +-
 .../ml/tree/DecisionTreeClassificationTrainer.java |  17 +-
 .../ml/tree/DecisionTreeConditionalNode.java       |  17 +-
 .../ignite/ml/tree/DecisionTreeLeafNode.java       |  17 +-
 .../apache/ignite/ml/tree/DecisionTreeNode.java    |  17 +-
 .../ml/tree/DecisionTreeRegressionTrainer.java     |  17 +-
 .../java/org/apache/ignite/ml/tree/TreeFilter.java |  17 +-
 .../GDBBinaryClassifierOnTreesTrainer.java         |  17 +-
 .../tree/boosting/GDBOnTreesLearningStrategy.java  |  17 +-
 .../tree/boosting/GDBRegressionOnTreesTrainer.java |  17 +-
 .../ignite/ml/tree/boosting/package-info.java      |  17 +-
 .../ignite/ml/tree/data/DecisionTreeData.java      |  17 +-
 .../ml/tree/data/DecisionTreeDataBuilder.java      |  17 +-
 .../apache/ignite/ml/tree/data/TreeDataIndex.java  |  17 +-
 .../apache/ignite/ml/tree/data/package-info.java   |  17 +-
 .../ignite/ml/tree/impurity/ImpurityMeasure.java   |  17 +-
 .../tree/impurity/ImpurityMeasureCalculator.java   |  17 +-
 .../ml/tree/impurity/gini/GiniImpurityMeasure.java |  17 +-
 .../gini/GiniImpurityMeasureCalculator.java        |  17 +-
 .../ignite/ml/tree/impurity/gini/package-info.java |  17 +-
 .../ml/tree/impurity/mse/MSEImpurityMeasure.java   |  17 +-
 .../impurity/mse/MSEImpurityMeasureCalculator.java |  17 +-
 .../ignite/ml/tree/impurity/mse/package-info.java  |  17 +-
 .../ignite/ml/tree/impurity/package-info.java      |  17 +-
 .../util/SimpleStepFunctionCompressor.java         |  17 +-
 .../ignite/ml/tree/impurity/util/StepFunction.java |  17 +-
 .../tree/impurity/util/StepFunctionCompressor.java |  17 +-
 .../ignite/ml/tree/impurity/util/package-info.java |  17 +-
 .../ml/tree/leaf/DecisionTreeLeafBuilder.java      |  17 +-
 .../ml/tree/leaf/MeanDecisionTreeLeafBuilder.java  |  17 +-
 .../leaf/MostCommonDecisionTreeLeafBuilder.java    |  17 +-
 .../apache/ignite/ml/tree/leaf/package-info.java   |  17 +-
 .../org/apache/ignite/ml/tree/package-info.java    |  17 +-
 .../RandomForestClassifierTrainer.java             |  17 +-
 .../RandomForestRegressionTrainer.java             |  17 +-
 .../ml/tree/randomforest/RandomForestTrainer.java  |  17 +-
 .../data/FeaturesCountSelectionStrategies.java     |  17 +-
 .../ignite/ml/tree/randomforest/data/NodeId.java   |  17 +-
 .../ml/tree/randomforest/data/NodeSplit.java       |  17 +-
 .../ignite/ml/tree/randomforest/data/TreeNode.java |  17 +-
 .../ignite/ml/tree/randomforest/data/TreeRoot.java |  17 +-
 .../randomforest/data/impurity/GiniHistogram.java  |  17 +-
 .../data/impurity/GiniHistogramsComputer.java      |  17 +-
 .../data/impurity/ImpurityComputer.java            |  17 +-
 .../data/impurity/ImpurityHistogram.java           |  17 +-
 .../data/impurity/ImpurityHistogramsComputer.java  |  17 +-
 .../randomforest/data/impurity/MSEHistogram.java   |  17 +-
 .../data/impurity/MSEHistogramComputer.java        |  17 +-
 .../basic/BootstrappedVectorsHistogram.java        |  17 +-
 .../data/impurity/basic/CountersHistogram.java     |  17 +-
 .../data/impurity/basic/package-info.java          |  17 +-
 .../randomforest/data/impurity/package-info.java   |  17 +-
 .../ml/tree/randomforest/data/package-info.java    |  17 +-
 .../statistics/ClassifierLeafValuesComputer.java   |  17 +-
 .../data/statistics/LeafValuesComputer.java        |  17 +-
 .../data/statistics/MeanValueStatistic.java        |  17 +-
 .../statistics/NormalDistributionStatistics.java   |  17 +-
 .../NormalDistributionStatisticsComputer.java      |  17 +-
 .../statistics/RegressionLeafValuesComputer.java   |  17 +-
 .../randomforest/data/statistics/package-info.java |  17 +-
 .../ignite/ml/tree/randomforest/package-info.java  |  17 +-
 .../java/org/apache/ignite/ml/util/LRUCache.java   |  17 +-
 .../ignite/ml/util/LRUCacheExpirationListener.java |  17 +-
 .../apache/ignite/ml/util/MLSandboxDatasets.java   |  17 +-
 .../java/org/apache/ignite/ml/util/MnistUtils.java |  17 +-
 .../java/org/apache/ignite/ml/util/ModelTrace.java |  17 +-
 .../org/apache/ignite/ml/util/SandboxMLCache.java  |  17 +-
 .../main/java/org/apache/ignite/ml/util/Utils.java |  17 +-
 .../ml/util/generators/DataStreamGenerator.java    |  17 +-
 .../ml/util/generators/DatasetBuilderAdapter.java  |  17 +-
 .../ignite/ml/util/generators/package-info.java    |  17 +-
 .../util/generators/primitives/package-info.java   |  17 +-
 .../primitives/scalar/DiscreteRandomProducer.java  |  17 +-
 .../primitives/scalar/GaussRandomProducer.java     |  17 +-
 .../primitives/scalar/RandomProducer.java          |  17 +-
 .../scalar/RandomProducerWithGenerator.java        |  17 +-
 .../primitives/scalar/UniformRandomProducer.java   |  17 +-
 .../generators/primitives/scalar/package-info.java |  17 +-
 .../vector/ParametricVectorGenerator.java          |  17 +-
 .../primitives/vector/VectorGenerator.java         |  17 +-
 .../vector/VectorGeneratorPrimitives.java          |  17 +-
 .../primitives/vector/VectorGeneratorsFamily.java  |  17 +-
 .../generators/primitives/vector/package-info.java |  17 +-
 .../standard/GaussianMixtureDataStream.java        |  17 +-
 .../generators/standard/RegressionDataStream.java  |  17 +-
 .../util/generators/standard/RingsDataStream.java  |  17 +-
 .../standard/TwoSeparableClassesDataStream.java    |  17 +-
 .../ml/util/generators/standard/package-info.java  |  17 +-
 .../org/apache/ignite/ml/util/package-info.java    |  17 +-
 .../org/apache/ignite/ml/util/plugin/MLPlugin.java |  17 +-
 .../ml/util/plugin/MLPluginConfiguration.java      |  17 +-
 .../ignite/ml/util/plugin/MLPluginProvider.java    |  17 +-
 .../apache/ignite/ml/math/d3-dataset-template.html |  17 +-
 .../apache/ignite/ml/math/d3-matrix-template.html  |  17 +-
 .../apache/ignite/ml/math/d3-vector-template.html  |  17 +-
 .../org/apache/ignite/ml/IgniteMLTestSuite.java    |  17 +-
 .../test/java/org/apache/ignite/ml/TestUtils.java  |  17 +-
 .../ignite/ml/clustering/ClusteringTestSuite.java  |  17 +-
 .../ignite/ml/clustering/KMeansModelTest.java      |  17 +-
 .../ignite/ml/clustering/KMeansTrainerTest.java    |  17 +-
 .../gmm/CovarianceMatricesAggregatorTest.java      |  17 +-
 .../ignite/ml/clustering/gmm/GmmModelTest.java     |  17 +-
 .../ml/clustering/gmm/GmmPartitionDataTest.java    |  17 +-
 .../clustering/gmm/GmmTrainerIntegrationTest.java  |  17 +-
 .../ignite/ml/clustering/gmm/GmmTrainerTest.java   |  17 +-
 .../gmm/MeanWithClusterProbAggregatorTest.java     |  17 +-
 .../gmm/NewComponentStatisticsAggregatorTest.java  |  17 +-
 .../apache/ignite/ml/common/CollectionsTest.java   |  17 +-
 .../apache/ignite/ml/common/CommonTestSuite.java   |  17 +-
 .../apache/ignite/ml/common/ExternalizeTest.java   |  17 +-
 .../apache/ignite/ml/common/KeepBinaryTest.java    |  17 +-
 .../apache/ignite/ml/common/LocalModelsTest.java   |  17 +-
 .../org/apache/ignite/ml/common/ModelTest.java     |  17 +-
 .../org/apache/ignite/ml/common/TrainerTest.java   |  17 +-
 .../ml/composition/CompositionTestSuite.java       |  17 +-
 .../apache/ignite/ml/composition/StackingTest.java |  17 +-
 .../ignite/ml/composition/bagging/BaggingTest.java |  17 +-
 .../ml/composition/boosting/GDBTrainerTest.java    |  17 +-
 .../convergence/ConvergenceCheckerTest.java        |  17 +-
 .../mean/MeanAbsValueConvergenceCheckerTest.java   |  17 +-
 .../MedianOfMedianConvergenceCheckerTest.java      |  17 +-
 .../MeanValuePredictionsAggregatorTest.java        |  17 +-
 .../OnMajorityPredictionsAggregatorTest.java       |  17 +-
 .../WeightedPredictionsAggregatorTest.java         |  17 +-
 .../apache/ignite/ml/dataset/DatasetTestSuite.java |  17 +-
 .../ml/dataset/feature/ObjectHistogramTest.java    |  17 +-
 .../dataset/feature/extractor/VectorizerTest.java  |  17 +-
 .../impl/cache/CacheBasedDatasetBuilderTest.java   |  17 +-
 .../dataset/impl/cache/CacheBasedDatasetTest.java  |  17 +-
 .../dataset/impl/cache/util/ComputeUtilsTest.java  |  17 +-
 .../util/DatasetAffinityFunctionWrapperTest.java   |  17 +-
 ...ratorWithConcurrentModificationCheckerTest.java |  17 +-
 .../impl/cache/util/PartitionDataStorageTest.java  |  17 +-
 .../impl/local/LocalDatasetBuilderTest.java        |  17 +-
 .../ml/dataset/primitive/DatasetWrapperTest.java   |  17 +-
 .../ml/dataset/primitive/SimpleDatasetTest.java    |  17 +-
 .../primitive/SimpleLabeledDatasetTest.java        |  17 +-
 .../ml/environment/EnvironmentTestSuite.java       |  17 +-
 .../LearningEnvironmentBuilderTest.java            |  17 +-
 .../ml/environment/LearningEnvironmentTest.java    |  17 +-
 .../apache/ignite/ml/environment/PromiseTest.java  |  17 +-
 .../ml/genetic/GAGridCalculateFitnessTest.java     |  17 +-
 .../ml/genetic/GAGridInitializePopulationTest.java |  17 +-
 .../apache/ignite/ml/genetic/GAGridTestSuite.java  |  17 +-
 .../ignite/ml/genetic/PasswordFitnessFunction.java |  17 +-
 .../ml/inference/IgniteModelStorageUtilTest.java   |  17 +-
 .../ignite/ml/inference/InferenceTestSuite.java    |  17 +-
 .../builder/IgniteDistributedModelBuilderTest.java |  17 +-
 .../ml/inference/builder/ModelBuilderTestUtil.java |  17 +-
 .../inference/builder/SingleModelBuilderTest.java  |  17 +-
 .../builder/ThreadedModelBuilderTest.java          |  17 +-
 .../storage/model/AbstractModelStorageTest.java    |  17 +-
 .../storage/model/DefaultModelStorageTest.java     |  17 +-
 .../ml/inference/util/DirectorySerializerTest.java |  17 +-
 .../ignite/ml/knn/ANNClassificationTest.java       |  17 +-
 .../ignite/ml/knn/KNNClassificationTest.java       |  17 +-
 .../apache/ignite/ml/knn/KNNRegressionTest.java    |  17 +-
 .../org/apache/ignite/ml/knn/KNNTestSuite.java     |  17 +-
 .../apache/ignite/ml/knn/LabeledDatasetHelper.java |  17 +-
 .../apache/ignite/ml/knn/LabeledVectorSetTest.java |  17 +-
 .../java/org/apache/ignite/ml/math/BlasTest.java   |  17 +-
 .../apache/ignite/ml/math/ExternalizableTest.java  |  17 +-
 .../org/apache/ignite/ml/math/ExternalizeTest.java |  17 +-
 .../ignite/ml/math/MathImplLocalTestSuite.java     |  17 +-
 .../ignite/ml/math/MathImplMainTestSuite.java      |  17 +-
 .../java/org/apache/ignite/ml/math/TracerTest.java |  17 +-
 .../org/apache/ignite/ml/math/VectorUtilsTest.java |  17 +-
 .../ignite/ml/math/distances/DistanceTest.java     |  17 +-
 .../ignite/ml/math/isolve/lsqr/LSQROnHeapTest.java |  17 +-
 .../ml/math/primitives/MathTestConstants.java      |  17 +-
 .../matrix/DenseMatrixConstructorTest.java         |  17 +-
 .../primitives/matrix/LUDecompositionTest.java     |  17 +-
 .../primitives/matrix/MatrixArrayStorageTest.java  |  17 +-
 .../primitives/matrix/MatrixAttributeTest.java     |  17 +-
 .../primitives/matrix/MatrixBaseStorageTest.java   |  17 +-
 .../primitives/matrix/MatrixStorageFixtures.java   |  17 +-
 .../matrix/MatrixStorageImplementationTest.java    |  17 +-
 .../matrix/MatrixViewConstructorTest.java          |  17 +-
 .../matrix/SparseMatrixConstructorTest.java        |  17 +-
 .../math/primitives/vector/AbstractVectorTest.java |  17 +-
 .../vector/DelegatingVectorConstructorTest.java    |  17 +-
 .../vector/DenseVectorConstructorTest.java         |  17 +-
 .../primitives/vector/MatrixVectorViewTest.java    |  17 +-
 .../vector/SparseVectorConstructorTest.java        |  17 +-
 .../primitives/vector/VectorArrayStorageTest.java  |  17 +-
 .../primitives/vector/VectorAttributesTest.java    |  17 +-
 .../primitives/vector/VectorBaseStorageTest.java   |  17 +-
 .../math/primitives/vector/VectorFoldMapTest.java  |  17 +-
 .../vector/VectorImplementationsFixtures.java      |  17 +-
 .../vector/VectorImplementationsTest.java          |  17 +-
 .../ml/math/primitives/vector/VectorNormTest.java  |  17 +-
 .../math/primitives/vector/VectorToMatrixTest.java |  17 +-
 .../ml/math/primitives/vector/VectorViewTest.java  |  17 +-
 .../vector/storage/AbstractStorageTest.java        |  17 +-
 .../vector/storage/DenseVectorStorageTest.java     |  17 +-
 .../vector/storage/SparseVectorStorageTest.java    |  17 +-
 .../ml/math/stat/DistributionMixtureTest.java      |  17 +-
 .../stat/MultivariateGaussianDistributionTest.java |  17 +-
 .../apache/ignite/ml/math/stat/StatsTestSuite.java |  17 +-
 .../ignite/ml/multiclass/MultiClassTestSuite.java  |  17 +-
 .../ignite/ml/multiclass/OneVsRestTrainerTest.java |  17 +-
 .../discrete/DiscreteNaiveBayesModelTest.java      |  17 +-
 .../discrete/DiscreteNaiveBayesTest.java           |  17 +-
 .../discrete/DiscreteNaiveBayesTrainerTest.java    |  17 +-
 .../gaussian/GaussianNaiveBayesModelTest.java      |  17 +-
 .../gaussian/GaussianNaiveBayesTest.java           |  17 +-
 .../gaussian/GaussianNaiveBayesTrainerTest.java    |  17 +-
 .../org/apache/ignite/ml/nn/LossFunctionsTest.java |  17 +-
 .../apache/ignite/ml/nn/MLPConstInitializer.java   |  17 +-
 .../test/java/org/apache/ignite/ml/nn/MLPTest.java |  17 +-
 .../java/org/apache/ignite/ml/nn/MLPTestSuite.java |  17 +-
 .../ignite/ml/nn/MLPTrainerIntegrationTest.java    |  17 +-
 .../org/apache/ignite/ml/nn/MLPTrainerTest.java    |  17 +-
 .../MLPTrainerMnistIntegrationTest.java            |  17 +-
 .../ml/nn/performance/MLPTrainerMnistTest.java     |  17 +-
 .../ignite/ml/nn/performance/MnistMLPTestUtil.java |  17 +-
 .../apache/ignite/ml/pipeline/PipelineMdlTest.java |  17 +-
 .../apache/ignite/ml/pipeline/PipelineTest.java    |  17 +-
 .../ignite/ml/pipeline/PipelineTestSuite.java      |  17 +-
 .../ml/preprocessing/PreprocessingTestSuite.java   |  17 +-
 .../binarization/BinarizationPreprocessorTest.java |  17 +-
 .../binarization/BinarizationTrainerTest.java      |  17 +-
 .../preprocessing/encoding/EncoderTrainerTest.java |  17 +-
 .../encoding/OneHotEncoderPreprocessorTest.java    |  17 +-
 .../encoding/StringEncoderPreprocessorTest.java    |  17 +-
 .../imputing/ImputerPreprocessorTest.java          |  17 +-
 .../preprocessing/imputing/ImputerTrainerTest.java |  17 +-
 .../MaxAbsScalerPreprocessorTest.java              |  17 +-
 .../maxabsscaling/MaxAbsScalerTrainerTest.java     |  17 +-
 .../MinMaxScalerPreprocessorTest.java              |  17 +-
 .../minmaxscaling/MinMaxScalerTrainerTest.java     |  17 +-
 .../NormalizationPreprocessorTest.java             |  17 +-
 .../normalization/NormalizationTrainerTest.java    |  17 +-
 .../StandardScalerPreprocessorTest.java            |  17 +-
 .../standardscaling/StandardScalerTrainerTest.java |  17 +-
 .../ml/regressions/RegressionsTestSuite.java       |  17 +-
 .../linear/LinearRegressionLSQRTrainerTest.java    |  17 +-
 .../linear/LinearRegressionModelTest.java          |  17 +-
 .../linear/LinearRegressionSGDTrainerTest.java     |  17 +-
 .../logistic/LogisticRegressionModelTest.java      |  17 +-
 .../logistic/LogisticRegressionSGDTrainerTest.java |  17 +-
 .../ignite/ml/selection/SelectionTestSuite.java    |  17 +-
 .../ml/selection/cv/CrossValidationTest.java       |  17 +-
 .../paramgrid/ParameterSetGeneratorTest.java       |  17 +-
 .../ml/selection/scoring/TestLabelPairCursor.java  |  17 +-
 .../cursor/CacheBasedLabelPairCursorTest.java      |  17 +-
 .../scoring/cursor/LocalLabelPairCursorTest.java   |  17 +-
 .../BinaryClassificationEvaluatorTest.java         |  17 +-
 .../scoring/evaluator/RegressionEvaluatorTest.java |  17 +-
 .../metric/classification/AccuracyTest.java        |  17 +-
 .../BinaryClassificationMetricsTest.java           |  17 +-
 .../BinaryClassificationMetricsValuesTest.java     |  17 +-
 .../metric/classification/FmeasureTest.java        |  17 +-
 .../metric/classification/PrecisionTest.java       |  17 +-
 .../scoring/metric/classification/ROCAUCTest.java  |  17 +-
 .../scoring/metric/classification/RecallTest.java  |  17 +-
 .../metric/regression/RegressionMetricsTest.java   |  17 +-
 .../split/TrainTestDatasetSplitterTest.java        |  17 +-
 .../split/mapper/SHA256UniformMapperTest.java      |  17 +-
 .../ignite/ml/structures/DatasetStructureTest.java |  17 +-
 .../ignite/ml/structures/StructuresTestSuite.java  |  17 +-
 .../apache/ignite/ml/svm/SVMBinaryTrainerTest.java |  17 +-
 .../org/apache/ignite/ml/svm/SVMModelTest.java     |  17 +-
 .../org/apache/ignite/ml/svm/SVMTestSuite.java     |  17 +-
 ...onTreeClassificationTrainerIntegrationTest.java |  17 +-
 .../DecisionTreeClassificationTrainerTest.java     |  17 +-
 ...cisionTreeRegressionTrainerIntegrationTest.java |  17 +-
 .../ml/tree/DecisionTreeRegressionTrainerTest.java |  17 +-
 .../ignite/ml/tree/DecisionTreeTestSuite.java      |  17 +-
 .../ignite/ml/tree/data/DecisionTreeDataTest.java  |  17 +-
 .../ignite/ml/tree/data/TreeDataIndexTest.java     |  17 +-
 .../gini/GiniImpurityMeasureCalculatorTest.java    |  17 +-
 .../impurity/gini/GiniImpurityMeasureTest.java     |  17 +-
 .../mse/MSEImpurityMeasureCalculatorTest.java      |  17 +-
 .../tree/impurity/mse/MSEImpurityMeasureTest.java  |  17 +-
 .../util/SimpleStepFunctionCompressorTest.java     |  17 +-
 .../ml/tree/impurity/util/StepFunctionTest.java    |  17 +-
 .../ml/tree/impurity/util/TestImpurityMeasure.java |  17 +-
 .../DecisionTreeMNISTIntegrationTest.java          |  17 +-
 .../ml/tree/performance/DecisionTreeMNISTTest.java |  17 +-
 .../RandomForestClassifierTrainerTest.java         |  17 +-
 .../randomforest/RandomForestIntegrationTest.java  |  17 +-
 .../RandomForestRegressionTrainerTest.java         |  17 +-
 .../ml/tree/randomforest/RandomForestTest.java     |  17 +-
 .../randomforest/RandomForestTreeTestSuite.java    |  17 +-
 .../ml/tree/randomforest/data/TreeNodeTest.java    |  17 +-
 .../data/impurity/GiniFeatureHistogramTest.java    |  17 +-
 .../data/impurity/ImpurityHistogramTest.java       |  17 +-
 .../data/impurity/MSEHistogramTest.java            |  17 +-
 .../NormalDistributionStatisticsComputerTest.java  |  17 +-
 .../org/apache/ignite/ml/util/LRUCacheTest.java    |  17 +-
 .../org/apache/ignite/ml/util/UtilTestSuite.java   |  17 +-
 .../DataStreamGeneratorFillCacheTest.java          |  17 +-
 .../util/generators/DataStreamGeneratorTest.java   |  17 +-
 .../generators/DataStreamGeneratorTestSuite.java   |  17 +-
 .../scalar/DiscreteRandomProducerTest.java         |  17 +-
 .../primitives/scalar/GaussRandomProducerTest.java |  17 +-
 .../primitives/scalar/RandomProducerTest.java      |  17 +-
 .../scalar/UniformRandomProducerTest.java          |  17 +-
 .../vector/ParametricVectorGeneratorTest.java      |  17 +-
 .../vector/VectorGeneratorPrimitivesTest.java      |  17 +-
 .../primitives/vector/VectorGeneratorTest.java     |  17 +-
 .../vector/VectorGeneratorsFamilyTest.java         |  17 +-
 .../trees/columntrees.manualrun.properties         |  21 +--
 modules/ml/tensorflow-model-parser/pom.xml         |  35 ++--
 .../parser/TensorFlowBaseModelParser.java          |  17 +-
 .../parser/TensorFlowGraphModelParser.java         |  17 +-
 .../parser/TensorFlowSavedModelModelParser.java    |  17 +-
 modules/ml/xgboost-model-parser/pom.xml            |  35 ++--
 .../ignite/ml/xgboost/XGModelComposition.java      |  17 +-
 .../org/apache/ignite/ml/xgboost/package-info.java |  17 +-
 .../ml/xgboost/parser/XGBoostModelBaseVisitor.java |  17 +-
 .../ml/xgboost/parser/XGBoostModelLexer.java       |  17 +-
 .../ml/xgboost/parser/XGBoostModelListener.java    |  17 +-
 .../ml/xgboost/parser/XGBoostModelParser.java      |  17 +-
 .../ml/xgboost/parser/XGBoostModelVisitor.java     |  17 +-
 .../ignite/ml/xgboost/parser/XGModelParser.java    |  17 +-
 .../ignite/ml/xgboost/parser/package-info.java     |  17 +-
 .../ml/xgboost/parser/visitor/XGModelVisitor.java  |  17 +-
 .../parser/visitor/XGTreeDictionaryVisitor.java    |  17 +-
 .../ml/xgboost/parser/visitor/XGTreeVisitor.java   |  17 +-
 .../ml/xgboost/parser/visitor/package-info.java    |  17 +-
 .../ml/xgboost/IgniteMLXGBoostTestSuite.java       |  17 +-
 .../ml/xgboost/parser/XGBoostModelParserTest.java  |  17 +-
 modules/mqtt/licenses/apache-2.0.txt               | 202 ---------------------
 modules/mqtt/licenses/gg-community.txt             |  13 ++
 modules/mqtt/pom.xml                               |  41 ++---
 .../apache/ignite/stream/mqtt/MqttStreamer.java    |  17 +-
 .../apache/ignite/stream/mqtt/package-info.java    |  27 ++-
 .../ignite/stream/mqtt/IgniteMqttStreamerTest.java |  17 +-
 .../stream/mqtt/IgniteMqttStreamerTestSuite.java   |  17 +-
 .../apache/ignite/stream/mqtt/package-info.java    |  27 ++-
 modules/osgi-karaf/licenses/apache-2.0.txt         | 202 ---------------------
 modules/osgi-karaf/licenses/gg-community.txt       |  13 ++
 modules/osgi-karaf/pom.xml                         |  33 ++--
 modules/osgi-karaf/src/main/resources/features.xml |  27 ++-
 modules/osgi-paxlogging/licenses/apache-2.0.txt    | 202 ---------------------
 modules/osgi-paxlogging/licenses/gg-community.txt  |  13 ++
 modules/osgi-paxlogging/pom.xml                    |  33 ++--
 modules/osgi/licenses/apache-2.0.txt               | 202 ---------------------
 modules/osgi/licenses/gg-community.txt             |  13 ++
 modules/osgi/pom.xml                               |  35 ++--
 .../osgi/IgniteAbstractOsgiContextActivator.java   |  17 +-
 .../org/apache/ignite/osgi/IgniteOsgiUtils.java    |  17 +-
 .../classloaders/BundleDelegatingClassLoader.java  |  17 +-
 .../classloaders/ContainerSweepClassLoader.java    |  17 +-
 .../classloaders/OsgiClassLoadingStrategyType.java |  17 +-
 .../ignite/osgi/classloaders/package-info.java     |  27 ++-
 .../java/org/apache/ignite/osgi/package-info.java  |  27 ++-
 .../ignite/osgi/AbstractIgniteKarafTest.java       |  17 +-
 .../osgi/IgniteKarafFeaturesInstallationTest.java  |  17 +-
 .../apache/ignite/osgi/IgniteOsgiServiceTest.java  |  17 +-
 .../apache/ignite/osgi/IgniteOsgiTestSuite.java    |  17 +-
 .../osgi/activators/BasicIgniteTestActivator.java  |  17 +-
 .../ignite/osgi/activators/TestOsgiFlags.java      |  17 +-
 .../ignite/osgi/activators/TestOsgiFlagsImpl.java  |  17 +-
 modules/platforms/cpp/Makefile.am                  |  32 ++--
 modules/platforms/cpp/Makefile.amrel               |  18 +-
 modules/platforms/cpp/binary/Makefile.am           |  32 ++--
 modules/platforms/cpp/binary/configure.ac          |  20 +-
 modules/platforms/cpp/binary/include/Makefile.am   |  32 ++--
 .../cpp/binary/include/ignite/binary/binary.h      |  17 +-
 .../binary/include/ignite/binary/binary_consts.h   |  17 +-
 .../include/ignite/binary/binary_containers.h      |  17 +-
 .../binary/include/ignite/binary/binary_object.h   |  17 +-
 .../include/ignite/binary/binary_raw_reader.h      |  17 +-
 .../include/ignite/binary/binary_raw_writer.h      |  17 +-
 .../binary/include/ignite/binary/binary_reader.h   |  17 +-
 .../cpp/binary/include/ignite/binary/binary_type.h |  17 +-
 .../binary/include/ignite/binary/binary_writer.h   |  17 +-
 .../include/ignite/impl/binary/binary_common.h     |  17 +-
 .../include/ignite/impl/binary/binary_field_meta.h |  17 +-
 .../ignite/impl/binary/binary_id_resolver.h        |  17 +-
 .../ignite/impl/binary/binary_object_header.h      |  17 +-
 .../ignite/impl/binary/binary_object_impl.h        |  17 +-
 .../ignite/impl/binary/binary_reader_impl.h        |  17 +-
 .../include/ignite/impl/binary/binary_schema.h     |  17 +-
 .../ignite/impl/binary/binary_type_handler.h       |  17 +-
 .../include/ignite/impl/binary/binary_type_impl.h  |  17 +-
 .../ignite/impl/binary/binary_type_manager.h       |  17 +-
 .../ignite/impl/binary/binary_type_snapshot.h      |  17 +-
 .../ignite/impl/binary/binary_type_updater.h       |  17 +-
 .../include/ignite/impl/binary/binary_utils.h      |  17 +-
 .../ignite/impl/binary/binary_writer_impl.h        |  17 +-
 .../binary/include/ignite/impl/interop/interop.h   |  17 +-
 .../ignite/impl/interop/interop_input_stream.h     |  17 +-
 .../include/ignite/impl/interop/interop_memory.h   |  17 +-
 .../ignite/impl/interop/interop_output_stream.h    |  17 +-
 .../impl/interop/interop_stream_position_guard.h   |  17 +-
 .../cpp/binary/src/binary/binary_containers.cpp    |  17 +-
 .../cpp/binary/src/binary/binary_raw_reader.cpp    |  17 +-
 .../cpp/binary/src/binary/binary_raw_writer.cpp    |  17 +-
 .../cpp/binary/src/binary/binary_reader.cpp        |  17 +-
 .../cpp/binary/src/binary/binary_type.cpp          |  17 +-
 .../cpp/binary/src/binary/binary_writer.cpp        |  17 +-
 .../binary/src/impl/binary/binary_field_meta.cpp   |  17 +-
 .../src/impl/binary/binary_object_header.cpp       |  17 +-
 .../binary/src/impl/binary/binary_object_impl.cpp  |  17 +-
 .../binary/src/impl/binary/binary_reader_impl.cpp  |  17 +-
 .../cpp/binary/src/impl/binary/binary_schema.cpp   |  29 ++-
 .../binary/src/impl/binary/binary_type_handler.cpp |  17 +-
 .../binary/src/impl/binary/binary_type_impl.cpp    |  17 +-
 .../binary/src/impl/binary/binary_type_manager.cpp |  17 +-
 .../src/impl/binary/binary_type_snapshot.cpp       |  17 +-
 .../cpp/binary/src/impl/binary/binary_utils.cpp    |  17 +-
 .../binary/src/impl/binary/binary_writer_impl.cpp  |  17 +-
 .../src/impl/interop/interop_input_stream.cpp      |  17 +-
 .../cpp/binary/src/impl/interop/interop_memory.cpp |  17 +-
 .../src/impl/interop/interop_output_stream.cpp     |  17 +-
 modules/platforms/cpp/common/Makefile.am           |  32 ++--
 modules/platforms/cpp/common/configure.ac          |  20 +-
 modules/platforms/cpp/common/include/Makefile.am   |  32 ++--
 .../cpp/common/include/ignite/common/big_integer.h |  17 +-
 .../cpp/common/include/ignite/common/bits.h        |  17 +-
 .../cpp/common/include/ignite/common/cancelable.h  |  17 +-
 .../cpp/common/include/ignite/common/concurrent.h  |  17 +-
 .../cpp/common/include/ignite/common/decimal.h     |  17 +-
 .../include/ignite/common/default_allocator.h      |  17 +-
 .../include/ignite/common/dynamic_size_array.h     |  17 +-
 .../cpp/common/include/ignite/common/expected.h    |  17 +-
 .../include/ignite/common/fixed_size_array.h       |  17 +-
 .../cpp/common/include/ignite/common/lazy.h        |  17 +-
 .../common/include/ignite/common/platform_utils.h  |  17 +-
 .../cpp/common/include/ignite/common/promise.h     |  17 +-
 .../common/include/ignite/common/reference_impl.h  |  17 +-
 .../common/include/ignite/common/shared_state.h    |  17 +-
 .../cpp/common/include/ignite/common/utils.h       |  17 +-
 modules/platforms/cpp/common/include/ignite/date.h |  17 +-
 .../platforms/cpp/common/include/ignite/future.h   |  17 +-
 modules/platforms/cpp/common/include/ignite/guid.h |  17 +-
 .../cpp/common/include/ignite/ignite_error.h       |  17 +-
 .../cpp/common/include/ignite/reference.h          |  17 +-
 modules/platforms/cpp/common/include/ignite/time.h |  17 +-
 .../cpp/common/include/ignite/timestamp.h          |  17 +-
 .../cpp/common/os/linux/include/Makefile.am        |  32 ++--
 .../common/os/linux/include/ignite/common/common.h |  17 +-
 .../os/linux/include/ignite/common/concurrent_os.h |  17 +-
 .../linux/include/ignite/common/dynamic_load_os.h  |  17 +-
 .../common/os/linux/src/common/concurrent_os.cpp   |  17 +-
 .../common/os/linux/src/common/dynamic_load_os.cpp |  17 +-
 .../common/os/linux/src/common/platform_utils.cpp  |  17 +-
 .../common/os/win/include/ignite/common/common.h   |  17 +-
 .../os/win/include/ignite/common/concurrent_os.h   |  17 +-
 .../os/win/include/ignite/common/dynamic_load_os.h |  17 +-
 .../cpp/common/os/win/src/common/concurrent_os.cpp |  17 +-
 .../common/os/win/src/common/dynamic_load_os.cpp   |  17 +-
 .../common/os/win/src/common/platform_utils.cpp    |  17 +-
 .../cpp/common/src/common/big_integer.cpp          |  17 +-
 modules/platforms/cpp/common/src/common/bits.cpp   |  17 +-
 .../platforms/cpp/common/src/common/concurrent.cpp |  17 +-
 .../platforms/cpp/common/src/common/decimal.cpp    |  17 +-
... 384928 lines suppressed ...


[ignite] 02/17: "README.md", "README.txt", "NOTICE_HADOOP", "NOTICE_IGNITE", "LICENSE", "NOTICE", "LICENSE_HADOOP", "LICENSE_IGNITE"

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit b33f3d2ba43ec1a636ddaa1a44ae232842cbfb8b
Author: mstepachev <ma...@gmail.com>
AuthorDate: Thu Apr 18 14:45:36 2019 +0300

    "README.md", "README.txt", "NOTICE_HADOOP", "NOTICE_IGNITE", "LICENSE", "NOTICE", "LICENSE_HADOOP", "LICENSE_IGNITE"
---
 LICENSE                                            | 213 +-------------
 NOTICE                                             |   4 +-
 README.md                                          | 170 +++++------
 README.txt                                         |  22 +-
 assembly/LICENSE_HADOOP                            | 264 +----------------
 assembly/LICENSE_IGNITE                            | 311 +--------------------
 assembly/NOTICE_HADOOP                             |   4 +-
 assembly/NOTICE_IGNITE                             |   4 +-
 assembly/libs/README.txt                           |  46 +--
 docker/apache-ignite/README.txt                    |  12 +-
 docker/web-agent/README.txt                        |  11 +-
 docker/web-console/standalone/README.txt           |  10 +-
 examples/README.md                                 |  14 +-
 examples/README.txt                                |  21 +-
 examples/config/filesystem/README.txt              |   2 +-
 examples/config/hibernate/README.txt               |   2 +-
 examples/config/servlet/README.txt                 |   2 +-
 ipc/README.txt                                     |   4 +-
 ipc/shmem/README.txt                               |   8 +-
 modules/aop/README.txt                             |   8 +-
 modules/apache-license-gen/README.txt              |  10 +-
 modules/aws/README.txt                             |   8 +-
 modules/camel/README.txt                           |   8 +-
 modules/cassandra/README.txt                       |   8 +-
 modules/cassandra/serializers/README.txt           |  10 +-
 modules/cassandra/store/README.txt                 |   8 +-
 .../store/src/test/bootstrap/aws/README.txt        |   4 +-
 modules/clients/README.txt                         |   6 +-
 modules/cloud/README.txt                           |   8 +-
 modules/compatibility/README.txt                   |   4 +-
 modules/core/src/main/java/META-INF/LICENSE        | 245 +---------------
 modules/core/src/main/java/META-INF/NOTICE         |   4 +-
 modules/dev-utils/README.txt                       |   4 +-
 modules/direct-io/README.txt                       |  16 +-
 modules/extdata/platform/README.txt                |   2 +-
 modules/flink/README.txt                           |  14 +-
 modules/flume/README.txt                           |  10 +-
 modules/gce/README.txt                             |   8 +-
 modules/geospatial/README.txt                      |  16 +-
 modules/hadoop/README.txt                          |   8 +-
 modules/hibernate-4.2/README.txt                   |  16 +-
 modules/hibernate-5.1/README.txt                   |  16 +-
 modules/ignored-tests/README.txt                   |   2 +-
 modules/indexing/README.txt                        |   8 +-
 modules/jcl/README.txt                             |   8 +-
 modules/jms11/README.txt                           |  12 +-
 modules/jta/README.txt                             |   8 +-
 modules/kafka/README.txt                           |  20 +-
 modules/kubernetes/README.txt                      |  10 +-
 modules/log4j/README.txt                           |   8 +-
 modules/log4j2/README.txt                          |   8 +-
 modules/mesos/README.txt                           |  10 +-
 modules/ml/README.txt                              |   8 +-
 modules/mqtt/README.txt                            |  12 +-
 modules/osgi-karaf/README.txt                      |  12 +-
 modules/osgi-paxlogging/README.txt                 |   2 +-
 modules/osgi/README.txt                            |  14 +-
 modules/platforms/README.txt                       |   6 +-
 modules/platforms/cpp/README.md                    | 193 +++++++------
 modules/platforms/cpp/README.txt                   |  36 +--
 modules/platforms/cpp/examples/README.txt          |  14 +-
 modules/platforms/cpp/odbc/README.txt              |  18 +-
 modules/platforms/dotnet/README.md                 | 163 ++++-------
 modules/platforms/dotnet/README.txt                |  20 +-
 modules/platforms/dotnet/docfx/README.txt          |   2 +-
 modules/platforms/dotnet/examples/README.txt       |   2 +-
 .../dotnet/examples/dotnetcore/README.txt          |   2 +-
 modules/platforms/nodejs/README.md                 |   4 +-
 modules/platforms/php/README.md                    |   4 +-
 modules/platforms/python/LICENSE                   | 209 +-------------
 modules/rest-http/README.txt                       |   8 +-
 modules/rocketmq/README.txt                        |   8 +-
 modules/scalar-2.10/README.txt                     |   4 +-
 modules/scalar/README.txt                          |   8 +-
 modules/schedule/README.txt                        |  14 +-
 modules/slf4j/README.txt                           |   8 +-
 modules/spark/README.txt                           |   8 +-
 modules/spring-data-2.0/README.txt                 |   8 +-
 modules/spring-data/README.txt                     |   6 +-
 modules/spring/README.txt                          |   8 +-
 modules/ssh/README.txt                             |   8 +-
 modules/storm/README.txt                           |  14 +-
 modules/tensorflow/README.txt                      |  26 +-
 modules/twitter/README.txt                         |  10 +-
 modules/urideploy/README.txt                       |   8 +-
 modules/visor-console-2.10/README.txt              |   4 +-
 modules/web-console/README.txt                     |  10 +-
 modules/web-console/assembly/README.txt            |   2 +-
 modules/web-console/web-agent/README.txt           |  16 +-
 modules/web/README.txt                             |  12 +-
 modules/yardstick/README.txt                       |  22 +-
 modules/yarn/README.txt                            |  10 +-
 modules/zeromq/README.txt                          |  14 +-
 modules/zookeeper/README.txt                       |  12 +-
 94 files changed, 700 insertions(+), 1928 deletions(-)

diff --git a/LICENSE b/LICENSE
index 6e77825..86ca9b6 100644
--- a/LICENSE
+++ b/LICENSE
@@ -1,212 +1,23 @@
+Copyright 2019 GridGain Systems, Inc. and Contributors.
 
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
+Licensed under the GridGain Community Edition License (the "License");
+you may not use this file except in compliance with the License.
+You may obtain a copy of the License at
 
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+    https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
 
-   1. Definitions.
-
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-
-   END OF TERMS AND CONDITIONS
-
-   APPENDIX: How to apply the Apache License to your work.
-
-      To apply the Apache License to your work, attach the following
-      boilerplate notice, with the fields enclosed by brackets "[]"
-      replaced with your own identifying information. (Don't include
-      the brackets!)  The text should be enclosed in the appropriate
-      comment syntax for the file format. We also recommend that a
-      file or class name and description of purpose be included on the
-      same "printed page" as the copyright notice for easier
-      identification within third-party archives.
-
-   Copyright [yyyy] [name of copyright owner]
-
-   Licensed under the Apache License, Version 2.0 (the "License");
-   you may not use this file except in compliance with the License.
-   You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing, software
-   distributed under the License is distributed on an "AS IS" BASIS,
-   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-   See the License for the specific language governing permissions and
-   limitations under the License.
+Unless required by applicable law or agreed to in writing, software
+distributed under the License is distributed on an "AS IS" BASIS,
+WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+See the License for the specific language governing permissions and
+limitations under the License.
 
 
 
 ==============================================================================
-Apache Ignite Subcomponents:
+GridGain Subcomponents:
 
-The Apache Ignite project contains subcomponents with separate copyright
+The GridGain project contains subcomponents with separate copyright
 notices and license terms. Your use of the source code for the these
 subcomponents is subject to the terms and conditions of the following
 licenses.
diff --git a/NOTICE b/NOTICE
index 0bae434..62c5414 100644
--- a/NOTICE
+++ b/NOTICE
@@ -1,5 +1,5 @@
-Apache Ignite
-Copyright 2019 The Apache Software Foundation
+GridGain
+Copyright 2019 GridGain Systems
 
 This product includes software developed at
 The Apache Software Foundation (http://www.apache.org/).
diff --git a/README.md b/README.md
index 89af2ca..ccedf78 100644
--- a/README.md
+++ b/README.md
@@ -1,54 +1,55 @@
-# Apache Ignite
+# GridGain Community Edition
 
-<a href="https://ignite.apache.org/"><img src="https://ignite.apache.org/images/logo3.png" hspace="20"/></a>
+<a href="https://www.gridgain.com/"><img src="https://www.gridgain.com/themes/gridgain1185/images/svg/gridgain-logo.svg?20180912" hspace="10"  width="300px"/></a><br/><br/>
 
-<a href="https://ci.ignite.apache.org/viewType.html?buildTypeId=IgniteTests24Java8_RunAll&branch_IgniteTests24Java8=%3Cdefault%3E"><img src="https://ci.ignite.apache.org/app/rest/builds/buildType:(id:IgniteTests24Java8_RunAll)/statusIcon.svg"/></a>
 
+The [GridGain][GridGain-homepage] Community Edition (GCE) is a source-available in-memory computing platform built on Apache Ignite.
+GCE includes the [Apache Ignite][apache-ignite-homepage] code base plus improvements and additional functionality developed by GridGain Systems
+to enhance the performance and reliability of Apache Ignite. GCE is a hardened, high-performance version of Apache Ignite
+for mission-critical in-memory computing applications.
 
-## Getting Started
 
-For information on how to get started with Apache Ignite, please visit: [Getting Started][getting-started].
 
-## Full Documentation
+## Getting Started
 
-You can find the full Apache Ignite documentation here: [Full documentation][docs].
+For information on how to get started with GridGain CE, please visit: [Getting Started][getting-started].
 
 
-## What is Apache Ignite?
+## What is GridGain?
 
-[Apache Ignite][apache-ignite-homepage] is a memory-centric distributed <strong>database</strong>, <strong>caching</strong>,
- and <strong>processing</strong> platform for transactional, analytical, and streaming workloads delivering in-memory
+GridGain, built on top of Apache Ignite, is a memory-centric distributed **database**, **caching**,
+ and **processing** platform for transactional, analytical, and streaming workloads delivering in-memory
  speeds at petabyte scale.
 
 <p align="center">
-    <a href="https://ignite.apache.org/whatisignite.html">
-        <img src="https://ignite.apache.org/images/ignite_architecture.png" width="400px"/>
+    <a href="https://www.gridgain.com/">
+        <img src="https://files.readme.io/58b7901-gg_platform.png" width="600px"/>
     </a>
 </p>
 
 ## Memory-Centric Storage
-Apache Ignite is based on distributed memory-centric architecture that combines the performance and scale of in-memory
+GridGain is based on distributed memory-centric architecture that combines the performance and scale of in-memory
 computing together with the disk durability and strong consistency in one system.
 
 The main difference between the memory-centric approach and the traditional disk-centric approach is that the memory
 is treated as a fully functional storage, not just as a caching layer, like most databases do.
-For example, Apache Ignite can function in a pure in-memory mode, in which case it can be treated as an
+For example, GridGain can function in a pure in-memory mode, in which case it can be treated as an
 In-Memory Database (IMDB) and In-Memory Data Grid (IMDG) in one.
 
-On the other hand, when persistence is turned on, Ignite begins to function as a memory-centric system where most of
+On the other hand, when persistence is turned on, GidGain begins to function as a memory-centric system where most of
 the processing happens in memory, but the data and indexes get persisted to disk. The main difference here
-from the traditional disk-centric RDBMS or NoSQL system is that Ignite is strongly consistent, horizontally
+from the traditional disk-centric RDBMS or NoSQL system is that GridGain is strongly consistent, horizontally
 scalable, and supports both SQL and key-value processing APIs.
 
 [Read More](https://ignite.apache.org/arch/memorycentric.html)
 
-## Ignite Persistence
+## Native Persistence
 
-Ignite Native Persistence is a distributed, ACID, and SQL-compliant **disk store** that transparently integrates with
-Ignite memory-centric storage as an optional disk layer storing data and indexes on SSD,
+Native Persistence is a distributed, ACID, and SQL-compliant **disk store** that transparently integrates with
+GridGain memory-centric storage as an optional disk layer storing data and indexes on SSD,
  Flash, 3D XPoint, and other types of non-volatile storages.
 
-With the Ignite Persistence enabled, you no longer need to keep all the data and indexes in memory or warm it
+With the Native Persistence enabled, you no longer need to keep all the data and indexes in memory or warm it
 up after a node or cluster restart because the Durable Memory is tightly coupled with persistence and treats
 it as a secondary memory tier. This implies that if a subset of data or an index is missing in RAM,
 the Durable Memory will take it from the disk.
@@ -62,33 +63,33 @@ the Durable Memory will take it from the disk.
 [Read More](https://ignite.apache.org/arch/persistence.html)
 
 ## ACID Compliance
-Data stored in Ignite is ACID-compliant both in memory and on disk, making Ignite a **strongly consistent** system. Ignite transactions work across the network and can span multiple servers.
+Data stored in GridGain is ACID-compliant both in memory and on disk, making GridGain a **strongly consistent** system. GridGain transactions work across the network and can span multiple servers.
 
 [Read More](https://apacheignite.readme.io/docs/transactions)
 
 ## Complete SQL Support
-Ignite provides full support for SQL, DDL and DML, allowing users to interact with Ignite using pure SQL without writing any code. This means that users can create tables and indexes as well as insert, update, and query data using only SQL. Having such complete SQL support makes Ignite a one-of-a-kind **distributed SQL database**.
+GridGain provides full support for SQL, DDL and DML, allowing users to interact with the cluster using pure SQL without writing any code. This means that users can create tables and indexes as well as insert, update, and query data using only SQL. Having such complete SQL support makes GridGain a one-of-a-kind **distributed SQL database**.
 
 [Read More](https://apacheignite.readme.io/docs/distributed-sql)
 
 ## Key-Value
-The in-memory data grid component in Ignite is a fully transactional **distributed key-value store** that can scale horizontally across 100s of servers in the cluster. When persistence is enabled, Ignite can also store more data than fits in memory and survive full cluster restarts.
+The in-memory data grid component in GridGain is a fully transactional **distributed key-value store** that can scale horizontally across 100s of servers in the cluster. When persistence is enabled, GridGain can also store more data than fits in memory and survive full cluster restarts.
 
 [Read More](https://apacheignite.readme.io/docs/data-grid)
 
 ## Collocated Processing
-Most traditional databases work in a client-server fashion, meaning that data must be brought to the client side for processing. This approach requires lots of data movement from servers to clients and generally does not scale. Ignite, on the other hand, allows for sending light-weight computations to the data, i.e. **collocating** computations with data. As a result, Ignite scales better and minimizes data movement.
+Most traditional databases work in a client-server fashion, meaning that data must be brought to the client side for processing. This approach requires lots of data movement from servers to clients and generally does not scale. GridGain, on the other hand, allows for sending light-weight computations to the data, i.e. **collocating** computations with data. As a result, GridGain scales better and minimizes data movement.
 
 [Read More](https://apacheignite.readme.io/docs/collocate-compute-and-data)
 
 ## Scalability and Durability
-Ignite is an elastic, horizontally scalable distributed system that supports adding and removing cluster nodes on demand. Ignite also allows for storing multiple copies of the data, making it resilient to partial cluster failures. If the persistence is enabled, then data stored in Ignite will also survive full cluster failures. Cluster restarts in Ignite can be very fast, as the data becomes operational instantaneously directly from disk. As a result, the data does not need to be preload [...]
+GridGain is an elastic, horizontally scalable distributed system that supports adding and removing cluster nodes on demand. GridGain also allows for storing multiple copies of the data, making it resilient to partial cluster failures. If the persistence is enabled, then data stored in GridGain will also survive full cluster failures. Cluster restarts in GridGain can be very fast, as the data becomes operational instantaneously directly from disk. As a result, the data does not need to be [...]
 
 [Read More](https://apacheignite.readme.io/docs/clustering)
 
-## Ignite Components
+## GridGain Components
 
-You can view Apache Ignite as a collection of independent, well-integrated components geared to improve performance and
+You can view Apache GridGain as a collection of independent, well-integrated components geared to improve performance and
  scalability of your application.
 
 Some of these components include:
@@ -97,7 +98,6 @@ Some of these components include:
 * [SQL Database](#sql-database)
 * [Compute Grid](#compute-grid)
 * [Service Grid](#service-grid)
-* [Hadoop Accelerator](#hadoop-accelerator)
 * [Spark Shared RDDs and SQL indexes](#spark-shared-rdds)
 
 Below you’ll find a brief explanation for each of them.
@@ -105,7 +105,7 @@ Below you’ll find a brief explanation for each of them.
 
 ### Advanced Clustering
 
-Ignite nodes can [automatically discover](https://apacheignite.readme.io/docs/cluster) each other. This helps to scale the cluster when needed, without having to restart the whole cluster. Developers can also leverage from Ignite’s hybrid cloud support that allows establishing connection between private cloud and public clouds such as Amazon Web Services, providing them with best of both worlds.
+GridGain nodes can [automatically discover](https://apacheignite.readme.io/docs/cluster) each other. This helps to scale the cluster when needed, without having to restart the whole cluster. Developers can also leverage from GridGain’s hybrid cloud support that allows establishing connection between private cloud and public clouds such as Amazon Web Services, providing them with best of both worlds.
 
 <p align="center">
     <a href="https://apacheignite.readme.io/docs/cluster">
@@ -113,7 +113,7 @@ Ignite nodes can [automatically discover](https://apacheignite.readme.io/docs/cl
     </a>
 </p>
 
-Apache Ignite can be deployed on:
+GridGain can be deployed on:
 * [AWS](https://apacheignite.readme.io/docs/aws-deployment)
 * [Docker](https://apacheignite.readme.io/docs/docker-deployment)
 * [Google Compute](https://apacheignite.readme.io/docs/google-compute-deployment)
@@ -124,16 +124,16 @@ Apache Ignite can be deployed on:
 
 ### Data Grid (JCache)
 
-[Ignite data grid](https://apacheignite.readme.io/docs/data-grid) is an in-memory distributed key-value store which can be viewed as a distributed partitioned hash map,
+GridGain data grid is an in-memory distributed key-value store which can be viewed as a distributed partitioned hash map,
 with every cluster node owning a portion of the overall data. This way the more cluster nodes we add, the more data we
 can cache.
 
-Unlike other key-value stores, Ignite determines data locality using a pluggable hashing algorithm. Every client can
+Unlike other key-value stores, GridGain determines data locality using a pluggable hashing algorithm. Every client can
 determine which node a key belongs to by plugging it into a hashing function, without a need for any special mapping
 servers or name nodes.
 
-Ignite data grid supports local, replicated, and partitioned data sets and allows to freely cross query between these
-data sets using standard SQL syntax. Ignite supports standard SQL for querying in-memory data including support for distributed SQL joins.
+GridGain data grid supports local, replicated, and partitioned data sets and allows to freely cross query between these
+data sets using standard SQL syntax. GridGain supports standard SQL for querying in-memory data including support for distributed SQL joins.
 
 <p align="center">
     <a href="https://apacheignite.readme.io/docs/data-grid">
@@ -143,16 +143,16 @@ data sets using standard SQL syntax. Ignite supports standard SQL for querying i
 
 ### SQL Database
 
-Apache Ignite incorporates [distributed SQL database](https://apacheignite.readme.io/docs/distributed-sql) capabilities as a part of its platform. The database is horizontally
+GridGain incorporates [distributed SQL database](https://apacheignite.readme.io/docs/distributed-sql) capabilities as a part of its platform. The database is horizontally
  scalable, fault tolerant and SQL ANSI-99 compliant. It supports all SQL, DDL, and DML commands including SELECT, UPDATE,
   INSERT, MERGE, and DELETE queries. It also provides support for a subset of DDL commands relevant for distributed
   databases.
 
-With Ignite Durable Memory architecture, data as well as indexes can be stored both in memory and, optionally, on disk.
+With GridGain Durable Memory architecture, data as well as indexes can be stored both in memory and, optionally, on disk.
 This allows executing distributed SQL operations across different memory layers achieving in-memory performance with the durability of disk.
 
-You can interact with Apache Ignite using the SQL language via natively developed APIs for Java, .NET and C++, or via
-the Ignite JDBC or ODBC drivers. This provides a true cross-platform connectivity from languages such as PHP, Ruby and more.
+You can interact with GridGain using the SQL language via natively developed APIs for Java, .NET and C++, or via
+the GridGain JDBC or ODBC drivers. This provides a true cross-platform connectivity from languages such as PHP, Ruby and more.
 
 
 <p align="center">
@@ -165,7 +165,7 @@ the Ignite JDBC or ODBC drivers. This provides a true cross-platform connectivit
 ### Compute Grid
 
 [Distributed computations](https://apacheignite.readme.io/docs/compute-grid) are performed in parallel fashion to gain high performance, low latency, and linear scalability.
- Ignite compute grid provides a set of simple APIs that allow users distribute computations and data processing across
+ GridGain compute grid provides a set of simple APIs that allow users distribute computations and data processing across
  multiple computers in the cluster. Distributed parallel processing is based on the ability to take any computation and
  execute it on any set of cluster nodes and return the results back.
 
@@ -193,7 +193,7 @@ We support these features, amongst others:
 [Service Grid](https://apacheignite.readme.io/docs/service-grid) allows for deployments of arbitrary user-defined services on the cluster. You can implement and deploy any
 service, such as custom counters, ID generators, hierarchical maps, etc.
 
-Ignite allows you to control how many instances of your service should be deployed on each cluster node and will
+GridGain allows you to control how many instances of your service should be deployed on each cluster node and will
 automatically ensure proper deployment and fault tolerance of all the services.
 
 <p align="center">
@@ -202,17 +202,9 @@ automatically ensure proper deployment and fault tolerance of all the services.
     </a>
 </p>
 
-### Ignite File System
-
-[Ignite File System](https://apacheignite-fs.readme.io/docs/in-memory-file-system) (IGFS) is an in-memory file system allowing work with files and directories over existing cache
-infrastructure. IGFS can either work as purely in-memory file system, or delegate to another file system (e.g. various
-Hadoop file system implementations) acting as a caching layer.
-
-In addition, IGFS provides API to execute map-reduce tasks over file system data.
-
 ### Distributed Data Structures
 
-Ignite supports complex [data structures](https://apacheignite.readme.io/docs/data-structures) in a distributed fashion:
+GridGain supports complex [data structures](https://apacheignite.readme.io/docs/data-structures) in a distributed fashion:
 
 * [Queues and sets](https://apacheignite.readme.io/docs/queue-and-set): ordinary, bounded, collocated, non-collocated
 * [Atomic types](https://apacheignite.readme.io/docs/atomic-types): `AtomicLong` and `AtomicReference`
@@ -225,16 +217,13 @@ Ignite supports complex [data structures](https://apacheignite.readme.io/docs/da
 [Distributed messaging](https://apacheignite.readme.io/docs/messaging) allows for topic based cluster-wide communication between all nodes. Messages with a specified
 message topic can be distributed to all or sub-group of nodes that have subscribed to that topic.
 
-Ignite messaging is based on publish-subscribe paradigm where publishers and subscribers are connected together by a
+GridGain messaging is based on publish-subscribe paradigm where publishers and subscribers are connected together by a
 common topic. When one of the nodes sends a message A for topic T, it is published on all nodes that have subscribed to T.
 
 ### Distributed Events
 
 [Distributed events](https://apacheignite.readme.io/docs/events) allow applications to receive notifications when a variety of events occur in the distributed grid environment. You can automatically get notified for task executions, read, write or query operations occurring on local or remote nodes within the cluster.
 
-### Hadoop Accelerator
-
-Our [Hadoop Accelerator](https://apacheignite-fs.readme.io/docs/hadoop-accelerator) provides a set of components allowing for in-memory Hadoop job execution and file system operations.
 
 #### MapReduce
 
@@ -247,34 +236,12 @@ boost your Hadoop MapReduce job execution performance.
     </a>
 </p>
 
-#### IGFS - In-Memory File System
-
-A Hadoop-compliant [IGFS](https://apacheignite-fs.readme.io/docs/file-system) File System implementation over which Hadoop can run over in plug-n-play fashion and significantly reduce I/O and improve both, latency and throughput.
-
-<p align="center">
-    <a href="https://apacheignite-fs.readme.io/docs/in-memory-file-system">
-        <img src="https://ignite.apache.org/images/ignite_filesystem.png" height="300" vspace="15"/>
-    </a>
-</p>
-
-#### Secondary File System
-
-An implementation of [`SecondaryFileSystem`](https://apacheignite-fs.readme.io/docs/secondary-file-system). This implementation can be injected into existing IGFS allowing for
-read-through and write-through behavior over any other Hadoop FileSystem implementation (e.g. HDFS). Use it if you
-want your IGFS to become an in-memory caching layer over disk-based HDFS or any other Hadoop-compliant file system.
-
-#### Supported Hadoop distributions
-
-* [Apache Hadoop](https://apacheignite-fs.readme.io/docs/installing-on-apache-hadoop)
-* [Cloudera CDH](https://apacheignite-fs.readme.io/docs/installing-on-cloudera-cdh)
-* [Hortonworks HDP](https://apacheignite-fs.readme.io/docs/installing-on-hortonworks-hdp)
-* [Apache Hive](https://apacheignite-fs.readme.io/docs/running-apache-hive-over-ignited-hadoop)
 
 ### Spark Shared RDDs
 
-Apache Ignite provides an implementation of Spark RDD abstraction which allows to easily share state in memory across Spark jobs.
+GridGain provides an implementation of Spark RDD abstraction which allows to easily share state in memory across Spark jobs.
 
-The main difference between native Spark `RDD` and `IgniteRDD` is that Ignite RDD provides a [shared in-memory](https://apacheignite-fs.readme.io/docs/ignite-for-spark) view on data across different Spark jobs, workers, or applications, while native Spark RDD cannot be seen by other Spark jobs or applications.
+The main difference between native Spark `RDD` and `GridGainRDD` is that GridGain RDD provides a [shared in-memory](https://apacheignite-fs.readme.io/docs/ignite-for-spark) view on data across different Spark jobs, workers, or applications, while native Spark RDD cannot be seen by other Spark jobs or applications.
 
 <p align="center">
     <a href="https://apacheignite-fs.readme.io/docs/ignite-for-spark">
@@ -282,64 +249,65 @@ The main difference between native Spark `RDD` and `IgniteRDD` is that Ignite RD
     </a>
 </p>
 
-## Ignite Facts
+## GridGain Facts
 
-#### Is Ignite a persistent or pure in-memory storage?
-**Both**. Native persistence in Ignite can be turned on and off. This allows Ignite to store data sets bigger than can fit in the available memory. Essentially, the smaller operational data sets can be stored in-memory only, and larger data sets that do not fit in memory can be stored on disk, using memory as a caching layer for better performance.
+#### Is GridGain a persistent or pure in-memory storage?
+**Both**. Native persistence in GridGain can be turned on and off. This allows GridGain to store data sets bigger than can fit in the available memory. Essentially, the smaller operational data sets can be stored in-memory only, and larger data sets that do not fit in memory can be stored on disk, using memory as a caching layer for better performance.
 
 [Read More](https://apacheignite.readme.io/docs/distributed-persistent-store)
 
-#### Is Ignite a distributed database?
-**Yes**. Data in Ignite is either *partitioned* or *replicated* across a cluster of multiple nodes. This provides scalability and adds resilience to the system. Ignite automatically controls how data is partitioned, however, users can plug in their own distribution (affinity) functions and collocate various pieces of data together for efficiency.
+#### Is GridGain a distributed database?
+**Yes**. Data in GridGain is either *partitioned* or *replicated* across a cluster of multiple nodes. This provides scalability and adds resilience to the system. GridGain automatically controls how data is partitioned, however, users can plug in their own distribution (affinity) functions and collocate various pieces of data together for efficiency.
 
 [Read More](https://apacheignite.readme.io/docs/distributed-sql)
 
-#### Is Ignite a relational SQL database?
-**Not fully**. Although Ignite aims to behave like any other relational SQL database, there are differences in how Ignite handles constraints and indexes. Ignite supports *primary* and *secondary* indexes, however, the *uniqueness* can only be enforced for the *primary* indexes. Ignite also does not support *foreign key* constraints.
+#### Is GridGain a relational SQL database?
+**Not fully**. Although GridGain aims to behave like any other relational SQL database, there are differences in how GridGain handles constraints and indexes. GridGain supports *primary* and *secondary* indexes, however, the *uniqueness* can only be enforced for the *primary* indexes. GridGain also does not support *foreign key* constraints.
 
-Essentially, Ignite purposely does not support any constraints that would entail a cluster broadcast message for each update and significantly hurt performance and scalability of the system.
+Essentially, GridGain purposely does not support any constraints that would entail a cluster broadcast message for each update and significantly hurt performance and scalability of the system.
 
 [Read More](https://apacheignite.readme.io/docs/indexes)
 
-#### Is Ignite an in-memory database?
-**Yes**. Even though Ignite *durable memory* works well in-memory and on-disk, the disk persistence can be disabled and Ignite can act as a pure *in-memory database*.
+#### Is GridGain an in-memory database?
+**Yes**. Even though GridGain *durable memory* works well in-memory and on-disk, the disk persistence can be disabled and GridGain can act as a pure *in-memory database*.
 
 [Read More](https://apacheignite.readme.io/docs/distributed-sql)
 
-#### Is Ignite a transactional database?
-**Not fully**. ACID Transactions are supported, but only at *key-value* API level. Ignite also supports *cross-partition* transactions, which means that transactions can span keys residing in different partitions on different servers.
+#### Is GridGain a transactional database?
+**Not fully**. ACID Transactions are supported, but only at *key-value* API level. GridGain also supports *cross-partition* transactions, which means that transactions can span keys residing in different partitions on different servers.
 
-At *SQL* level Ignite supports *atomic*, but not yet *transactional* consistency. Ignite community plans to implement SQL transactions in version 2.2.
+At *SQL* level GridGain supports *atomic*, but not yet *transactional* consistency. GridGain community plans to implement SQL transactions in version 2.2.
 
 [Read More](https://apacheignite.readme.io/docs/sql-queries#known-limitations)
 
-#### Is Ignite a key-value store?
-**Yes**. Ignite provides a feature rich key-value API, that is JCache (JSR-107) compliant and supports Java, C++, and .NET.
+#### Is GridGain a key-value store?
+**Yes**. GridGain provides a feature rich key-value API, that is JCache (JSR-107) compliant and supports Java, C++, and .NET.
 
 [Read More](https://apacheignite.readme.io/docs/data-grid)
 
-#### Is Ignite an in-memory data grid?
-**Yes**. Ignite is a full-featured data grid, which can be used either in pure in-memory mode or with Ignite native persistence. It can also integrate with any 3rd party database, including any RDBMS or NoSQL store.
+#### Is GridGain an in-memory data grid?
+**Yes**. GridGain is a full-featured data grid, which can be used either in pure in-memory mode or with native persistence. It can also integrate with any 3rd party database, including any RDBMS or NoSQL store.
 
 [Read More](https://apacheignite.readme.io/docs/data-grid)
 
 #### What is durable memory?
-Ignite *durable memory* architecture allows Ignite to extend in-memory computing to disk. It is based on a paged-based off-heap memory allocator which becomes durable by persisting to the *write-ahead-log (WAL)* and, then, to main Ignite persistent storage. When persistence is disabled, durable memory acts like a pure in-memory storage.
+GridGain *durable memory* architecture allows GridGain to extend in-memory computing to disk. It is based on a paged-based off-heap memory allocator which becomes durable by persisting to the *write-ahead-log (WAL)* and, then, to main GridGain persistent storage. When persistence is disabled, durable memory acts like a pure in-memory storage.
 
 [Read More](https://apacheignite.readme.io/docs/durable-memory)
 
 #### What is collocated processing?
-Ignite is a distributed system and, therefore, it is important to be able to collocate data with data and compute with data to avoid distributed data noise. Data collocation becomes especially important when performing distributed SQL joins. Ignite also supports sending user logic (functions, lambdas, etc.) directly to the nodes where the data resides and computing on the data locally.
+GridGain is a distributed system and, therefore, it is important to be able to collocate data with data and compute with data to avoid distributed data noise. Data collocation becomes especially important when performing distributed SQL joins. GridGain also supports sending user logic (functions, lambdas, etc.) directly to the nodes where the data resides and computing on the data locally.
 
 [Read More](https://apacheignite.readme.io/docs/collocate-compute-and-data)
 
-## Ignite On Other Platforms
+## GridGain On Other Platforms
 
-<a href="modules/platforms/dotnet">Ignite.NET</a>
+<a href="modules/platforms/dotnet">GridGain.NET</a>
 
-<a href="modules/platforms/cpp">Ignite C++</a>
+<a href="modules/platforms/cpp">GridGain C++</a>
 
 
 [apache-ignite-homepage]: https://ignite.apache.org/
-[getting-started]: https://apacheignite.readme.io/docs/getting-started
-[docs]: https://apacheignite.readme.io/docs
\ No newline at end of file
+[GridGain-homepage]: https://www.gridgain.com/
+[getting-started]: https://docs.gridgain.com/docs
+[docs]: https://docs.gridgain.com/docs
\ No newline at end of file
diff --git a/README.txt b/README.txt
index 2e6add5..0db0d3c 100644
--- a/README.txt
+++ b/README.txt
@@ -1,10 +1,13 @@
-Apache Ignite In-Memory Database and Caching Platform
-=====================================================
+GridGain Community Edition
+===========================
 
-Ignite is a memory-centric distributed database, caching, and processing platform for transactional, analytical,
-and streaming workloads delivering in-memory speeds at petabyte scale.
+The GridGain Community Edition (GCE) is a source-available in-memory computing platform built on Apache Ignite. 
+GCE includes the Apache Ignite code base plus improvements and additional functionality developed by GridGain Systems 
+to enhance the performance and reliability of Apache Ignite. GCE is a hardened, high-performance version of Apache Ignite 
+for mission-critical in-memory computing applications.
 
-The main feature set of Ignite includes:
+
+The main feature set of GridGain Community Edition includes:
 * Memory-Centric Storage
 * Advanced Clustering
 * Distributed Key-Value
@@ -16,11 +19,6 @@ The main feature set of Ignite includes:
 * Distributed Events
 * Streaming & CEP
 
-For information on how to get started with Apache Ignite please visit:
-
-    http://apacheignite.readme.io/docs/getting-started
-
-
-You can find Apache Ignite documentation here:
+For information on how to get started with GridGain please visit:
 
-    http://apacheignite.readme.io/docs
+    https://docs.gridgain.com/docs
\ No newline at end of file
diff --git a/assembly/LICENSE_HADOOP b/assembly/LICENSE_HADOOP
index 3db2360..4f2f7db 100644
--- a/assembly/LICENSE_HADOOP
+++ b/assembly/LICENSE_HADOOP
@@ -1,257 +1,13 @@
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
+Copyright 2019 GridGain Systems, Inc. and Contributors.
 
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-
-   1. Definitions.
-
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-
-   END OF TERMS AND CONDITIONS
-
-   APPENDIX: How to apply the Apache License to your work.
-
-      To apply the Apache License to your work, attach the following
-      boilerplate notice, with the fields enclosed by brackets "[]"
-      replaced with your own identifying information. (Don't include
-      the brackets!)  The text should be enclosed in the appropriate
-      comment syntax for the file format. We also recommend that a
-      file or class name and description of purpose be included on the
-      same "printed page" as the copyright notice for easier
-      identification within third-party archives.
-
-   Copyright [yyyy] [name of copyright owner]
-
-   Licensed under the Apache License, Version 2.0 (the "License");
-   you may not use this file except in compliance with the License.
-   You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing, software
-   distributed under the License is distributed on an "AS IS" BASIS,
-   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-   See the License for the specific language governing permissions and
-   limitations under the License.
-
-
-
-==============================================================================
-Apache Ignite Subcomponents:
-
-The Apache Ignite project contains subcomponents with separate copyright
-notices and license terms. Your use of the source code for the these
-subcomponents is subject to the terms and conditions of the following
-licenses.
-
-
-==============================================================================
-For SnapTree:
-==============================================================================
-This product bundles SnapTree, which is available under the following:
-"3-clause BSD" license. For details, see https://github.com/nbronson/snaptree/blob/master/LICENSE.
-
-==============================================================================
-For JSR 166 classes in "org.jsr166" package
-==============================================================================
-This product bundles JSR-166 classes which are donated to public domain.
-For details, see CC0 1.0 Universal (1.0), Public Domain Dedication,
-http://creativecommons.org/publicdomain/zero/1.0/
-
-==============================================================================
-For JSR107 API and SPI (https://github.com/jsr107/jsr107spec) javax.cache:cache-api:jar:1.0.0
-==============================================================================
-This product bundles JSR107 API and SPI which is available under the following:
-JSR-000107 JCACHE 2.9 Public Review - Updated Specification License. https://raw.github.com/jsr107/jsr107spec/master/LICENSE.txt
-
-==============================================================================
-For JSch (http://www.jcraft.com/jsch/) com.jcraft:jsch:jar:0.1.50
-==============================================================================
-This product bundles JSch which is available under the following:
-Revised BSD. For details, see http://www.jcraft.com/jsch/LICENSE.txt.
-
-==============================================================================
-For JLine (http://nexus.sonatype.org/oss-repository-hosting.html/jline) jline:jline:jar:2.12.1
-==============================================================================
-This product bundles JLine which is available under the following:
-The BSD License. For details, see http://www.opensource.org/licenses/bsd-license.php.
-
-==============================================================================
-For Scala Library (http://www.scala-lang.org/) org.scala-lang:scala-library:jar:2.11.2
-==============================================================================
-This product bundles Scala Library which is available under the following:
-BSD 3-Clause. For details, see http://www.scala-lang.org/license.html.
-
-==============================================================================
-For ASM All (http://asm.objectweb.org/asm-all/) org.ow2.asm:asm-all:jar:5.0.3
-==============================================================================
-This product bundles ASM All which is available under the following:
-BSD. For details, see http://asm.objectweb.org/license.html.
+Licensed under the GridGain Community Edition License (the "License");
+you may not use this file except in compliance with the License.
+You may obtain a copy of the License at
 
+    https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
 
+Unless required by applicable law or agreed to in writing, software
+distributed under the License is distributed on an "AS IS" BASIS,
+WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+See the License for the specific language governing permissions and
+limitations under the License.
\ No newline at end of file
diff --git a/assembly/LICENSE_IGNITE b/assembly/LICENSE_IGNITE
index ce44bea..4f2f7db 100644
--- a/assembly/LICENSE_IGNITE
+++ b/assembly/LICENSE_IGNITE
@@ -1,304 +1,13 @@
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
+Copyright 2019 GridGain Systems, Inc. and Contributors.
 
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+Licensed under the GridGain Community Edition License (the "License");
+you may not use this file except in compliance with the License.
+You may obtain a copy of the License at
 
-   1. Definitions.
+    https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
 
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-
-   END OF TERMS AND CONDITIONS
-
-   APPENDIX: How to apply the Apache License to your work.
-
-      To apply the Apache License to your work, attach the following
-      boilerplate notice, with the fields enclosed by brackets "[]"
-      replaced with your own identifying information. (Don't include
-      the brackets!)  The text should be enclosed in the appropriate
-      comment syntax for the file format. We also recommend that a
-      file or class name and description of purpose be included on the
-      same "printed page" as the copyright notice for easier
-      identification within third-party archives.
-
-   Copyright [yyyy] [name of copyright owner]
-
-   Licensed under the Apache License, Version 2.0 (the "License");
-   you may not use this file except in compliance with the License.
-   You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing, software
-   distributed under the License is distributed on an "AS IS" BASIS,
-   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-   See the License for the specific language governing permissions and
-   limitations under the License.
-
-
-
-==============================================================================
-Apache Ignite Subcomponents:
-
-The Apache Ignite project contains subcomponents with separate copyright
-notices and license terms. Your use of the source code for the these
-subcomponents is subject to the terms and conditions of the following
-licenses.
-
-
-==============================================================================
-For SnapTree:
-==============================================================================
-This product bundles SnapTree, which is available under the following:
-"3-clause BSD" license. For details, see https://github.com/nbronson/snaptree/blob/master/LICENSE.
-
-==============================================================================
-For JSR 166 classes in "org.jsr166" package
-==============================================================================
-This product bundles JSR-166 classes which are donated to public domain.
-For details, see CC0 1.0 Universal (1.0), Public Domain Dedication,
-http://creativecommons.org/publicdomain/zero/1.0/
-
-==============================================================================
-For JSR107 API and SPI (https://github.com/jsr107/jsr107spec) javax.cache:cache-api:jar:1.0.0
-==============================================================================
-This product bundles JSR107 API and SPI which is available under the following:
-JSR-000107 JCACHE 2.9 Public Review - Updated Specification License. https://raw.github.com/jsr107/jsr107spec/master/LICENSE.txt
-
-==============================================================================
-For JSch (http://www.jcraft.com/jsch/) com.jcraft:jsch:jar:0.1.50
-==============================================================================
-This product bundles JSch which is available under the following:
-Revised BSD. For details, see http://www.jcraft.com/jsch/LICENSE.txt.
-
-==============================================================================
-For JLine (http://nexus.sonatype.org/oss-repository-hosting.html/jline) jline:jline:jar:2.12.1
-==============================================================================
-This product bundles JLine which is available under the following:
-The BSD License. For details, see http://www.opensource.org/licenses/bsd-license.php.
-
-==============================================================================
-For Scala Library (http://www.scala-lang.org/) org.scala-lang:scala-library:jar:2.*
-==============================================================================
-This product bundles Scala Library which is available under the following:
-BSD 3-Clause. For details, see http://www.scala-lang.org/license.html.
-
-==============================================================================
-For H2 Database Engine (http://www.h2database.com) com.h2database:h2:jar:1.4.191
-==============================================================================
-This product bundles H2 Database Engine which is available under the following:
-MPL 2.0, and EPL 1.0. For details, see http://h2database.com/html/license.html.
-
-==============================================================================
-For JTidy (http://jtidy.sourceforge.net) net.sf.jtidy:jtidy:jar:r938
-==============================================================================
-This product bundles JTidy which is available under the following:
-Java HTML Tidy License. For details, see http://jtidy.svn.sourceforge.net/viewvc/jtidy/trunk/jtidy/LICENSE.txt?revision=95.
-
-==============================================================================
-For tomcat-servlet-api (http://tomcat.apache.org/) org.apache.tomcat:tomcat-servlet-api:jar:9.0.10
-==============================================================================
-This product bundles tomcat-servlet-api which is available under the following:
-Apache License, Version 2.0 and Common Development And Distribution License (CDDL) Version 1.0. For details, see http://www.apache.org/licenses/LICENSE-2.0.txt and http://www.opensource.org/licenses/cddl1.txt.
-
-==============================================================================
-For AOP alliance (http://aopalliance.sourceforge.net) aopalliance:aopalliance:jar:1.0
-==============================================================================
-This product bundles AOP alliance which is available under the following:
-Public Domain.
-
-==============================================================================
-For AspectJ (http://www.aspectj.org) org.aspectj:*:jar:1.7.2
-==============================================================================
-This product bundles AspectJ which is available under the following:
-Eclipse Public License - v 1.0. For details, see http://www.eclipse.org/legal/epl-v10.html.
-
-==============================================================================
-For Java Transaction API (http://java.sun.com/products/jta) javax.transaction:jta:jar:1.1
-==============================================================================
-This product bundles Java Transaction API which is available under it's own license.
-See http://download.oracle.com/otndocs/jcp/jta-1.1-classes-oth-JSpec/jta-1.1-classes-oth-JSpec-license.html for details.
-
-==============================================================================
-For ASM All (http://asm.objectweb.org/asm-all/) org.ow2.asm:asm-all:jar:5.0.3
-==============================================================================
-This product bundles ASM All which is available under the following:
-BSD. For details, see http://asm.objectweb.org/license.html.
-
-==============================================================================
-For Jetty (http://www.eclipse.org/jetty) org.eclipse.jetty:*:jar:9.2.11.v20150529
-==============================================================================
-This product bundles Jetty which is available under the following:
-Apache Software License - Version 2.0. For details, see http://www.apache.org/licenses/LICENSE-2.0.
-Eclipse Public License - Version 1.0. For details, see http://www.eclipse.org/org/documents/epl-v10.php.
-
-==============================================================================
-For SLF4J API Module (http://www.slf4j.org) org.slf4j:slf4j-api:jar:1.6.4
-==============================================================================
-This product bundles SLF4J API Module which is available under the following:
-MIT License. For details, see http://www.opensource.org/licenses/mit-license.php.
+Unless required by applicable law or agreed to in writing, software
+distributed under the License is distributed on an "AS IS" BASIS,
+WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+See the License for the specific language governing permissions and
+limitations under the License.
\ No newline at end of file
diff --git a/assembly/NOTICE_HADOOP b/assembly/NOTICE_HADOOP
index 0bae434..62c5414 100644
--- a/assembly/NOTICE_HADOOP
+++ b/assembly/NOTICE_HADOOP
@@ -1,5 +1,5 @@
-Apache Ignite
-Copyright 2019 The Apache Software Foundation
+GridGain
+Copyright 2019 GridGain Systems
 
 This product includes software developed at
 The Apache Software Foundation (http://www.apache.org/).
diff --git a/assembly/NOTICE_IGNITE b/assembly/NOTICE_IGNITE
index fffcc7c..df10333 100644
--- a/assembly/NOTICE_IGNITE
+++ b/assembly/NOTICE_IGNITE
@@ -1,5 +1,5 @@
-Apache Ignite
-Copyright 2019 The Apache Software Foundation
+GridGain
+Copyright 2019 GridGain Systems
 
 This product includes software developed at
 The Apache Software Foundation (http://www.apache.org/).
diff --git a/assembly/libs/README.txt b/assembly/libs/README.txt
index 1365cc1..c6233ba 100644
--- a/assembly/libs/README.txt
+++ b/assembly/libs/README.txt
@@ -1,14 +1,14 @@
-Apache Ignite Dependencies
+GridGain Dependencies
 --------------------------
 
-Current folder contains JAR files for all Apache Ignite modules along with their dependencies.
+Current folder contains JAR files for all GridGain modules along with their dependencies.
 When node is started using 'ignite.{sh|bat}' script, all JARs and classes located in
 'libs' folder and all its sub-folders except 'optional' are added to classpath of the node.
 
-By default, only Apache Ignite core JAR and a minimum set of modules is enabled, while other
+By default, only GridGain core JAR and a minimum set of modules is enabled, while other
 modules are located in 'optional' folder and therefore disabled.
 
-To enable any of optional Ignite modules when starting a standalone node,
+To enable any of optional GridGain modules when starting a standalone node,
 move corresponding module folder from 'libs/optional' to 'libs' before running
 'ignite.{sh|bat}' script. The content of the module folder will be added to
 classpath in this case.
@@ -17,7 +17,7 @@ If you need to add your own classes to classpath of the node (e.g., task classes
 to 'libs' folder. You can create a subfolder for convenience as well.
 
 
-Importing Ignite Dependencies In Maven Project
+Importing GridGain Dependencies In Maven Project
 ------------------------------------------------
 
 If you are using Maven to manage dependencies of your project, there are two options:
@@ -26,7 +26,7 @@ If you are using Maven to manage dependencies of your project, there are two opt
   - apache-ignite (all inclusive)
 
 Here is how 'apache-ignite' can be added to your POM file (replace '${ignite.version}'
-with actual Ignite version you are interested in):
+with actual GridGain version you are interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
     xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
@@ -36,7 +36,7 @@ with actual Ignite version you are interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>apache-ignite</artifactId>
             <version>${ignite.version}</version>
         </dependency>
@@ -45,9 +45,9 @@ with actual Ignite version you are interested in):
     ...
 </project>
 
-2. Or import individual Apache Ignite modules a la carte.
+2. Or import individual GridGain modules a la carte.
 
-Alternatively you can import Ignite modules a la carte, one by one.
+Alternatively you can import GridGain modules a la carte, one by one.
 The only required module is 'ignite-core', all others are optional.
 Here is how it can be imported into your POM file:
 
@@ -59,7 +59,7 @@ Here is how it can be imported into your POM file:
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-core</artifactId>
             <version>${ignite.version}</version>
         </dependency>
@@ -76,41 +76,41 @@ The following modules are available:
 - ignite-camel (for Apache Camel integration)
 - ignite-cassandra (for Apache Cassandra integration)
 - ignite-cloud (for Apache JClouds integration) 
-- ignite-flink (for streaming from Apache Flink into Ignite)
-- ignite-flume (for streaming events from Apache Flume into Ignite)
+- ignite-flink (for streaming from Apache Flink into GridGain)
+- ignite-flume (for streaming events from Apache Flume into GridGain)
 - ignite-gce (for automatic cluster discovery on Google Compute Engine)
 - ignite-hadoop (for Apache Hadoop Accelerator)
 - ignite-hibernate (for Hibernate integration)
 - ignite-hibernate5 (for Hibernate5 integration)
 - ignite-indexing (for SQL querying and indexing)
 - ignite-jcl (for Apache Commons logging)
-- ignite-jms11 (for streaming messaging from JMS queue or topic into Ignite)
+- ignite-jms11 (for streaming messaging from JMS queue or topic into GridGain)
 - ignite-jta (for XA integration)
-- ignite-kafka (for streaming messages from Apache Kafka into Ignite)
+- ignite-kafka (for streaming messages from Apache Kafka into GridGain)
 - ignite-logj4 (for Log4j logging)
 - ignite-log4j2 (for Log4j 2 logging)
 - ignite-mesos (for integration with Apache Mesos cluster resource manager)
-- ignite-mqtt (for streaming MQTT topic messages into Ignite)
-- ignite-osgi (to allow Ignite run seemlessly in OSGI containers)
+- ignite-mqtt (for streaming MQTT topic messages into GridGain)
+- ignite-osgi (to allow GridGain run seemlessly in OSGI containers)
 - ignite-osgi-karaf (to seemlessly intall ignite into Apache Karaf container)
 - ignite-osgi-paxlogging (to expose PAX Logging API to Log4j if needed)
 - ignite-rest-http (for HTTP REST messages)
-- ignite-rocketmq (for streaming messages from Apache RocketMQ into Ignite)
+- ignite-rocketmq (for streaming messages from Apache RocketMQ into GridGain)
 - ignite-scalar (for ignite Scala API)
-- ignite-scalar_2.10 (for Ignite Scala 2.10 API)
+- ignite-scalar_2.10 (for GridGain Scala 2.10 API)
 - ignite-schedule (for Cron-based task scheduling)
 - ignite-sl4j (for SL4J logging)
 - ignite-spark (for shared in-memory RDDs and faster SQL for Apache Spark)
 - ignite-spring (for Spring-based configuration support)
 - ignite-ssh (for starting grid nodes on remote machines)
-- ignite-storm (for streaming events from Apache Storm into Ignite)
-- ignite-twitter (for streaming tweets from Twitter into Ignite)
+- ignite-storm (for streaming events from Apache Storm into GridGain)
+- ignite-twitter (for streaming tweets from Twitter into GridGain)
 - ignite-urideploy (for URI-based deployment)
 - ignite-web (for Web Sessions Clustering)
 - ignite-yarn (for integration with Apache Hadoop Yarn)
 - ignite-zookeeper (for cluster discovery based on Apache Zookeeper)
 
-For example, if you want to use Apache Ignite Spring-based configuration,
+For example, if you want to use GridGain Spring-based configuration,
 you should add 'ignite-spring' module like this:
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -122,14 +122,14 @@ you should add 'ignite-spring' module like this:
         ...
         <!-- Core module. -->
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-core</artifactId>
             <version>${ignite.version}</version>
         </dependency>
 
         <!-- Optional. -->
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-spring</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/docker/apache-ignite/README.txt b/docker/apache-ignite/README.txt
index 98d67b2..e8d4d14 100644
--- a/docker/apache-ignite/README.txt
+++ b/docker/apache-ignite/README.txt
@@ -1,21 +1,21 @@
-Apache Ignite Docker module
+GridGain Docker module
 ===========================
-Apache Ignite Docker module provides Dockerfile and accompanying files for building docker image.
+GridGain Docker module provides Dockerfile and accompanying files for building docker image.
 
 
 Build image
 ===========
-1) Build Apache Ignite binary archive as described in DEVNOTES.txt.
+1) Build GridGain binary archive as described in DEVNOTES.txt.
 
-2) Goto Apache Ignite's Docker module directory
+2) Goto GridGain's Docker module directory
 
         cd modules/docker
 
-3) Copy Apache Ignite's binary archive to Docker module directory
+3) Copy GridGain's binary archive to Docker module directory
 
         cp -rfv ../../target/bin/apache-ignite-*.zip
 
-4) Unpack Apache Ignite's binary archive
+4) Unpack GridGain's binary archive
 
         unzip apache-ignite-*.zip
 
diff --git a/docker/web-agent/README.txt b/docker/web-agent/README.txt
index 376e333..9f020ce 100644
--- a/docker/web-agent/README.txt
+++ b/docker/web-agent/README.txt
@@ -1,25 +1,24 @@
-Apache Ignite Web Agent Docker module
+GridGain Web Agent Docker module
 =====================================
-Apache Ignite Web Agent Docker module provides Dockerfile and accompanying files
+GridGain Web Agent Docker module provides Dockerfile and accompanying files
 for building docker image of Web Agent.
 
 
 Build image
 ===========
-1) Build Apache Ignite Web Console module
+1) Build GridGain Web Console module
 
         mvn clean install -T 2C \
                           -Pall-java,all-scala,licenses,web-console \
                           -pl :ignite-web-console -am \
                           -DskipTests
 
-2) Go to Apache Ignite Web Console Docker module directory and copy Apache
-   Ignite Web Agent's binary archive
+2) Go to GridGain Web Console Docker module directory and copy GridGain Web Agent's binary archive
 
         cd docker/web-agent
         cp -rfv ../../modules/web-console/web-agent/target/ignite-web-agent-*.zip ./
 
-3) Unpack and remove Apache Ignite Web Agent's binary archive
+3) Unpack and remove GridGain Web Agent's binary archive
 
         unzip ignite-web-agent-*.zip
         rm -rf ignite-web-agent-*.zip
diff --git a/docker/web-console/standalone/README.txt b/docker/web-console/standalone/README.txt
index c97e792..bccc935 100644
--- a/docker/web-console/standalone/README.txt
+++ b/docker/web-console/standalone/README.txt
@@ -1,10 +1,10 @@
-Apache Ignite Web Console Standalone Docker module
+GridGain Web Console Standalone Docker module
 ==================================================
-Apache Ignite Web Console Standalone Docker module provides Dockerfile and accompanying files
+GridGain Web Console Standalone Docker module provides Dockerfile and accompanying files
 for building docker image of Web Console.
 
 
-Ignite Web Console Standalone Docker Image Build Instructions
+GridGain Web Console Standalone Docker Image Build Instructions
 =============================================================
 1) Build ignite-web-console module
 
@@ -15,8 +15,8 @@ Ignite Web Console Standalone Docker Image Build Instructions
 
         cp -rf modules/web-console/web-agent/target/ignite-web-agent-*.zip docker/web-console/standalone
 
-3) Go to Apache Ignite Web Console Docker module directory and copy Apache
-   Ignite Web Console's frontend and backend directory
+3) Go to GridGain Web Console Docker module directory and copy GridGain
+   Web Console's frontend and backend directory
 
         cd docker/web-console/standalone
         cp -rf ../../../modules/web-console/backend ./
diff --git a/examples/README.md b/examples/README.md
index 1855953..dcdc641 100644
--- a/examples/README.md
+++ b/examples/README.md
@@ -1,13 +1,13 @@
-# Apache Ignite Examples
+# GridGain Examples
 
-This module contains examples of how to run [Apache Ignite](ignite.apache.org) and [Apache Ignite](ignite.apache.org) with 3rd party components.
+This module contains examples of how to run GridGain.
 
 Instructions on how to start examples can be found in [README.txt](README.txt).
 
 How to start examples in the developer's environment, please see [DEVNOTES.txt](DEVNOTES.txt).
 
 ## Running examples on JDK 9/10/11
-Ignite uses proprietary SDK APIs that are not available by default. See also [How to run Ignite on JDK 9,10 and 11](https://apacheignite.readme.io/docs/getting-started#section-running-ignite-with-java-9-10-11)
+GridGain uses proprietary SDK APIs that are not available by default. See also [How to run GridGain on JDK 9,10 and 11](https://docs.gridgain.com/docs/getting-started#section-running-gridgain-with-java-9-10-11)
 
 To set up local IDE to easier access to examples, it is possible to add following options as default for all applications
 
@@ -16,8 +16,7 @@ To set up local IDE to easier access to examples, it is possible to add followin
    --add-exports=java.management/com.sun.jmx.mbeanserver=ALL-UNNAMED
    --add-exports=jdk.internal.jvmstat/sun.jvmstat.monitor=ALL-UNNAMED
    --add-exports=java.base/sun.reflect.generics.reflectiveObjects=ALL-UNNAMED
-   --illegal-access=permit
-   -Djdk.tls.client.protocols=TLSv1.2``
+   --illegal-access=permit``
 
 For example, for IntelliJ IDEA it is possible to use Application Templates.
 
@@ -28,7 +27,4 @@ Use 'Run' -> 'Edit Configuration' menu.
 ## Contributing to Examples
 *Notice* When updating classpath of examples and in case any modifications required in [pom.xml](pom.xml)
 please make sure that corresponding changes were applied to
- * [pom-standalone.xml](pom-standalone.xml),
- * [pom-standalone-lgpl.xml](pom-standalone-lgpl.xml).
- 
- These pom files are finalized during release and placed to examples folder with these examples code.
\ No newline at end of file
+ [pom-standalone.xml](pom-standalone.xml). This pom file is finalized during release and placed to examples folder with these examples code.
\ No newline at end of file
diff --git a/examples/README.txt b/examples/README.txt
index abb5d23..64146a8 100644
--- a/examples/README.txt
+++ b/examples/README.txt
@@ -1,20 +1,20 @@
-Apache Ignite Examples
+GridGain Examples
 ======================
 
-This folder contains code examples for various Apache Ignite functionality.
+This folder contains code examples for various GridGain functionality.
 
 Examples are shipped as a separate Maven project, so to start running you simply need
 to import provided `pom.xml` file into your favourite IDE.
 
 The examples folder contains he following subfolders:
 
-- `config` - contains Ignite configuration files needed for examples.
-- `memcached` - contains PHP script demonstrating how Ignite Cache can be accessed using Memcached client.
-- `rest` - contains PHP script demonstrating how Ignite Cache can be accessed via HTTP API.
+- `config` - contains GridGain configuration files needed for examples.
+- `memcached` - contains PHP script demonstrating how GridGain Cache can be accessed using Memcached client.
+- `rest` - contains PHP script demonstrating how GridGain Cache can be accessed via HTTP API.
 - `sql` - contains sample SQL scripts and data sets.
-- `src/main/java` - contains Java examples for different Ignite modules and features.
+- `src/main/java` - contains Java examples for different GridGain modules and features.
 - `src/main/scala` - contains examples demonstrating usage of API provided by Scalar.
-- `src/main/java-lgpl` - contains lgpl-based examples for different Ignite modules and features.
+- `src/main/java-lgpl` - contains lgpl-based examples for different GridGain modules and features.
 
 Starting Remote Nodes
 =====================
@@ -28,14 +28,13 @@ LGPL
 LGPL examples can be activated by turning lgpl profile on.
 
 lgpl profile required some lgpl-based libs, for example: ignite-hibernate & ignite-schedule.
-In case these libs can not be found by this maven project please download Apache Ignite sources
-at https://ignite.apache.org/download.cgi#sources.
+In case these libs can not be found by this maven project please download GridGain sources.
 
 There are some ways to gain required libs from sources:
 
-1) Run "mvn clean install -DskipTests -P lgpl" at Apache Ignite sources.
+1) Run "mvn clean install -DskipTests -P lgpl" at GridGain sources.
 This case will install lgpl-based libs to local maven repository.
 
-2) Run "mvn clean package -DskipTests -Prelease,lgpl -Dignite.edition=apache-ignite-lgpl" at Apache Ignite sources.
+2) Run "mvn clean package -DskipTests -Prelease,lgpl -Dignite.edition=apache-ignite-lgpl" at GridGain sources.
 Required libs will appear at /target/release-package/libs/optional subfolders.
 Found libs should be copied to global or project's classpath.
diff --git a/examples/config/filesystem/README.txt b/examples/config/filesystem/README.txt
index 4f6ae88..c06d1b8 100644
--- a/examples/config/filesystem/README.txt
+++ b/examples/config/filesystem/README.txt
@@ -4,5 +4,5 @@ FileSystem Configuration Example
 This folder contains configuration files for IgniteFs examples located in
 org.apache.ignite.examples.igfs package.
 
-- example-igfs.xml file is used to start Apache Ignite nodes with IgniteFS configured
+- example-igfs.xml file is used to start GridGain nodes with IgniteFS configured
 - core-site.xml file is used to run Hadoop FS driver over IgniteFs
diff --git a/examples/config/hibernate/README.txt b/examples/config/hibernate/README.txt
index 5b7ab29..5cbf9b5 100644
--- a/examples/config/hibernate/README.txt
+++ b/examples/config/hibernate/README.txt
@@ -2,7 +2,7 @@ Hibernate L2 Cache Configuration Example
 ----------------------------------------
 
 This folder contains example-hibernate-L2-cache.xml file that demonstrates
-how to configure Hibernate to use Apache Ignite cache as an L2 cache provider.
+how to configure Hibernate to use GridGain cache as an L2 cache provider.
 
 This file is also used in Hibernate example located in org.apache.ignite.examples.datagrid.hibernate
 package.
diff --git a/examples/config/servlet/README.txt b/examples/config/servlet/README.txt
index 20d4b90..46ea854 100644
--- a/examples/config/servlet/README.txt
+++ b/examples/config/servlet/README.txt
@@ -2,7 +2,7 @@ Servlet Configuration Example
 -----------------------------
 
 This folder contains web.xml file that demonstrates how to configure any servlet container
-to start a Apache Ignite node inside a Web application.
+to start a GridGain node inside a Web application.
 
 For more information on available configuration properties, etc. refer to our documentation:
 http://apacheignite.readme.io/docs/web-session-clustering
diff --git a/ipc/README.txt b/ipc/README.txt
index 3adc0dc..dadece2 100644
--- a/ipc/README.txt
+++ b/ipc/README.txt
@@ -1,4 +1,4 @@
-Apache Ignite IPC
+GridGain IPC
 -------------------
 
-Contains different Inter-process communication (IPC) implementations for Apache Ignite.
+Contains different Inter-process communication (IPC) implementations for GridGain.
diff --git a/ipc/shmem/README.txt b/ipc/shmem/README.txt
index e11360b..7526897 100644
--- a/ipc/shmem/README.txt
+++ b/ipc/shmem/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite Shared memory IPC library
+GridGain Shared memory IPC library
 ---------------------------------------
 
-Apache Ignite shared memory IPC library implement exchange via shared memory for Apache Ignite.
+GridGain shared memory IPC library implement exchange via shared memory for GridGain.
 
 Building on Linux and Mac OS X
 -------------------
@@ -22,12 +22,12 @@ to see all available command line options. Once the configure script finishes, y
 This will build and install the shared memory library and the headers into the default location on your
 system (which is usually '/usr/local').
 
-Usage with Apache Ignite
+Usage with GridGain
 -------------------
 
 Copy compiled library to folder that already listed in 'java.library.path'
 with name in form: 'libigniteshmem-<ignite-version>.<extension>'.
-Note: Ignite should be restarted.
+Note: GridGain should be restarted.
 
 **************************************************************************************
 *** Additional notes:
diff --git a/modules/aop/README.txt b/modules/aop/README.txt
index 4d04630..a824d60 100644
--- a/modules/aop/README.txt
+++ b/modules/aop/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite AOP Module
+GridGain AOP Module
 ------------------------
 
-Apache Ignite AOP module provides capability to turn any Java method to a distributed closure by
+GridGain AOP module provides capability to turn any Java method to a distributed closure by
 adding @Gridify annotation to it.
 
 To enable AOP module when starting a standalone node, move 'optional/ignite-aop' folder to
@@ -12,7 +12,7 @@ Importing AOP Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add AOP module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -23,7 +23,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-aop</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/apache-license-gen/README.txt b/modules/apache-license-gen/README.txt
index 46f0be9..3b88115 100644
--- a/modules/apache-license-gen/README.txt
+++ b/modules/apache-license-gen/README.txt
@@ -1,16 +1,16 @@
-Apache Ignite License Generator Module
+GridGain License Generator Module
 ------------------------------
 
-Apache Ignite License Generator module is a custom maven resource plugin.
+GridGain License Generator module is a custom maven resource plugin.
 It generates /license/{module name}-licenses.txt file contains list of module's non transitive dependencies.
-Apache Ignite binary distribution contains all non transitive dependencies of it's modules.
+GridGain binary distribution contains all non transitive dependencies of it's modules.
 Set of modules included to binary distribution may vary as well as their dependencies list, versions and licenses.
 Automatic generation of /license/{module name}-licenses.txt file guarantee that binary distribution gives user
-actual information about licenses used by Apache Ignite's modules.
+actual information about licenses used by GridGain's modules.
 
 Note that in case dependency provided under Apache License 2.0 only in will not appear inside generated file.
 
-To use Apache Ignite License Generator Module in your project please add following to pom.xml:
+To use GridGain License Generator Module in your project please add following to pom.xml:
 
 <plugin><!-- generates dependencies licenses -->
      <groupId>org.apache.maven.plugins</groupId>
diff --git a/modules/aws/README.txt b/modules/aws/README.txt
index 1819915..d49b699 100644
--- a/modules/aws/README.txt
+++ b/modules/aws/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite AWS Module
+GridGain AWS Module
 ------------------------
 
-Apache Ignite AWS module provides S3-based implementations of checkpoint SPI and IP finder for TCP discovery.
+GridGain AWS module provides S3-based implementations of checkpoint SPI and IP finder for TCP discovery.
 
 To enable AWS module when starting a standalone node, move 'optional/ignite-aws' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -11,7 +11,7 @@ Importing AWS Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add AWS module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -22,7 +22,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-aws</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/camel/README.txt b/modules/camel/README.txt
index ca119ae..b6c7109 100644
--- a/modules/camel/README.txt
+++ b/modules/camel/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite Camel Module
+GridGain Camel Module
 --------------------------
 
-Apache Ignite Camel provides a streamer to consume cache tuples from a Camel endpoint such as
+GridGain Camel provides a streamer to consume cache tuples from a Camel endpoint such as
 HTTP, TCP, File, FTP, AMQP, SNMP, databases, etc. For more information on available components,
 refer to http://camel.apache.org/components.html.
 
@@ -13,7 +13,7 @@ Importing the Camel module in a Maven project
 ---------------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add the Camel module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -24,7 +24,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-camel</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/cassandra/README.txt b/modules/cassandra/README.txt
index 146e5d4..a82007c 100644
--- a/modules/cassandra/README.txt
+++ b/modules/cassandra/README.txt
@@ -1,13 +1,13 @@
-Apache Ignite Cassandra Module
+GridGain Cassandra Module
 ------------------------
 
-Apache Ignite Cassandra module, used just as a parent container for other Cassandra related modules.
+GridGain Cassandra module, used just as a parent container for other Cassandra related modules.
 
 Importing Cassandra Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Cassandra Store module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -18,7 +18,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-cassandra</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/cassandra/serializers/README.txt b/modules/cassandra/serializers/README.txt
index aaa309f..cedaf23 100644
--- a/modules/cassandra/serializers/README.txt
+++ b/modules/cassandra/serializers/README.txt
@@ -1,8 +1,8 @@
-Apache Ignite Cassandra Serializers Module
+GridGain Cassandra Serializers Module
 ------------------------
 
-Apache Ignite Cassandra Serializers module provides additional serializers to store objects as BLOBs in Cassandra. The
-module could be used as an addition to Ignite Cassandra Store module.
+GridGain Cassandra Serializers module provides additional serializers to store objects as BLOBs in Cassandra. The
+module could be used as an addition to GridGain Cassandra Store module.
 
 To enable Cassandra Serializers module when starting a standalone node, move 'optional/ignite-cassandra-serializers'
 folder to 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will be added to
@@ -13,7 +13,7 @@ Importing Cassandra Serializers Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Cassandra Store module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -24,7 +24,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-cassandra-serializers</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/cassandra/store/README.txt b/modules/cassandra/store/README.txt
index fd72dea..972912b 100644
--- a/modules/cassandra/store/README.txt
+++ b/modules/cassandra/store/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite Cassandra Store Module
+GridGain Cassandra Store Module
 ------------------------
 
-Apache Ignite Cassandra Store module provides CacheStore implementation backed by Cassandra database.
+GridGain Cassandra Store module provides CacheStore implementation backed by Cassandra database.
 
 To enable Cassandra Store module when starting a standalone node, move 'optional/ignite-cassandra-store' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -11,7 +11,7 @@ Importing Cassandra Store Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Cassandra Store module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -22,7 +22,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-cassandra-store</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/cassandra/store/src/test/bootstrap/aws/README.txt b/modules/cassandra/store/src/test/bootstrap/aws/README.txt
index a61b235..548cbec 100644
--- a/modules/cassandra/store/src/test/bootstrap/aws/README.txt
+++ b/modules/cassandra/store/src/test/bootstrap/aws/README.txt
@@ -1,8 +1,8 @@
-Shell scripts to spin up Ignite, Cassandra and Load tests clusters in AWS.
+Shell scripts to spin up GridGain, Cassandra and Load tests clusters in AWS.
 
 1) cassandra - bootstrap scripts for Cassandra cluster nodes
 2) ganglia - bootstrap scripts for Ganglia master and agents
-3) ignite - bootstrap scripts for Ignite cluster nodes
+3) ignite - bootstrap scripts for GridGain cluster nodes
 4) tests - bootstrap scripts for Load Tests cluster nodes
 5) common.sh - definitions for common functions
 6) env.sh - definitions for common variables
diff --git a/modules/clients/README.txt b/modules/clients/README.txt
index 8299c33..f63cdb4 100644
--- a/modules/clients/README.txt
+++ b/modules/clients/README.txt
@@ -1,9 +1,9 @@
 Java Client README
 ==================
-Java Client is a lightweight gateway to Ignite nodes.
+Java Client is a lightweight gateway to GridGain nodes.
 
-Client communicates with grid nodes via REST interface and provides reduced but powerful subset of Ignite API.
-Java Client allows to use Ignite features from devices and environments where fully-functional Ignite node
+Client communicates with grid nodes via REST interface and provides reduced but powerful subset of GridGain API.
+Java Client allows to use GridGain features from devices and environments where fully-functional GridGain node
 could not (or should not) be started.
 
 Client vs Grid Node
diff --git a/modules/cloud/README.txt b/modules/cloud/README.txt
index c57a5da..dd92a12 100644
--- a/modules/cloud/README.txt
+++ b/modules/cloud/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite Cloud Module
+GridGain Cloud Module
 ------------------------
 
-Apache Ignite Cloud module provides Apache jclouds implementations of IP finder for TCP discovery.
+GridGain Cloud module provides Apache jclouds implementations of IP finder for TCP discovery.
 
 To enable Cloud module when starting a standalone node, move 'optional/ignite-cloud' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -11,7 +11,7 @@ Importing Cloud Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Cloud module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -22,7 +22,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-cloud</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/compatibility/README.txt b/modules/compatibility/README.txt
index f2743ec..6c8b466 100644
--- a/modules/compatibility/README.txt
+++ b/modules/compatibility/README.txt
@@ -1,5 +1,5 @@
-Apache Ignite Compatibility Tests
+GridGain Compatibility Tests
 ------------------------
 
 Special module contains testing framework which provides methods for testing backward compatibility.
-It allows to start Ignite-cluster in multiversion mode. It means that nodes with different build version is allowed to join topology.
\ No newline at end of file
+It allows to start GridGain-cluster in multiversion mode. It means that nodes with different build version is allowed to join topology.
\ No newline at end of file
diff --git a/modules/core/src/main/java/META-INF/LICENSE b/modules/core/src/main/java/META-INF/LICENSE
index c971434..4f2f7db 100644
--- a/modules/core/src/main/java/META-INF/LICENSE
+++ b/modules/core/src/main/java/META-INF/LICENSE
@@ -1,238 +1,13 @@
+Copyright 2019 GridGain Systems, Inc. and Contributors.
 
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
+Licensed under the GridGain Community Edition License (the "License");
+you may not use this file except in compliance with the License.
+You may obtain a copy of the License at
 
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+    https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
 
-   1. Definitions.
-
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-
-   END OF TERMS AND CONDITIONS
-
-   APPENDIX: How to apply the Apache License to your work.
-
-      To apply the Apache License to your work, attach the following
-      boilerplate notice, with the fields enclosed by brackets "[]"
-      replaced with your own identifying information. (Don't include
-      the brackets!)  The text should be enclosed in the appropriate
-      comment syntax for the file format. We also recommend that a
-      file or class name and description of purpose be included on the
-      same "printed page" as the copyright notice for easier
-      identification within third-party archives.
-
-   Copyright [yyyy] [name of copyright owner]
-
-   Licensed under the Apache License, Version 2.0 (the "License");
-   you may not use this file except in compliance with the License.
-   You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing, software
-   distributed under the License is distributed on an "AS IS" BASIS,
-   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-   See the License for the specific language governing permissions and
-   limitations under the License.
-
-
-
-==============================================================================
-Apache Ignite Subcomponents:
-
-The Apache Ignite project contains subcomponents with separate copyright
-notices and license terms. Your use of the source code for the these
-subcomponents is subject to the terms and conditions of the following
-licenses.
-
-
-==============================================================================
-For SnapTree:
-==============================================================================
-This product bundles SnapTree, which is available under a
-"3-clause BSD" license.  For details, see
-https://github.com/nbronson/snaptree/blob/master/LICENSE.
-
-==============================================================================
-For JSR 166 classes in "org.jsr166" package
-==============================================================================
-This product bundles JSR-166 classes which are donated to public domain.
-For details, see CC0 1.0 Universal (1.0), Public Domain Dedication,
-http://creativecommons.org/publicdomain/zero/1.0/
-
-==============================================================================
-For books used for tests in "org.apache.ignite.internal.processors.hadoop.books"
-==============================================================================
-This code bundles book text files used for testing purposes which contain
-the following header:
-
-This eBook is for the use of anyone anywhere at no cost and with
-almost no restrictions whatsoever.  You may copy it, give it away or
-re-use it under the terms of the Project Gutenberg License included
-with this eBook or online at www.gutenberg.org
+Unless required by applicable law or agreed to in writing, software
+distributed under the License is distributed on an "AS IS" BASIS,
+WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+See the License for the specific language governing permissions and
+limitations under the License.
\ No newline at end of file
diff --git a/modules/core/src/main/java/META-INF/NOTICE b/modules/core/src/main/java/META-INF/NOTICE
index 0bae434..62c5414 100644
--- a/modules/core/src/main/java/META-INF/NOTICE
+++ b/modules/core/src/main/java/META-INF/NOTICE
@@ -1,5 +1,5 @@
-Apache Ignite
-Copyright 2019 The Apache Software Foundation
+GridGain
+Copyright 2019 GridGain Systems
 
 This product includes software developed at
 The Apache Software Foundation (http://www.apache.org/).
diff --git a/modules/dev-utils/README.txt b/modules/dev-utils/README.txt
index f839c4f..e10baad 100644
--- a/modules/dev-utils/README.txt
+++ b/modules/dev-utils/README.txt
@@ -1,5 +1,5 @@
-Apache Ignite Development Utils
+GridGain Development Utils
 ------------------------
 
-Special module contains Ignite development utilities. These utilities may be useful when analyzing PDS artifacts,
+Special module contains GridGain development utilities. These utilities may be useful when analyzing PDS artifacts,
 such as WAL or page storage, in field deployments.
diff --git a/modules/direct-io/README.txt b/modules/direct-io/README.txt
index 95d4401..f7d2582 100644
--- a/modules/direct-io/README.txt
+++ b/modules/direct-io/README.txt
@@ -1,20 +1,20 @@
-Apache Ignite Direct IO Module
+GridGain Direct IO Module
 -------------------------------------
 
-Apache Ignite Direct IO is plugin, which provides page store with ability to write and read cache partitions
+GridGain Direct IO is plugin, which provides page store with ability to write and read cache partitions
 in O_DIRECT mode.
 
 OS gets the data and stores it in a file buffer cache. Similarly, for every write operation,
 the OS first writes the data in a cache and then transfers to the disk. To eliminate this process you can enable
 Direct I/O in which case the data is read and written directly from/to the disk bypassing the file buffer cache.
 
-Direct I/O plugin in Ignite is used for the checkpointing process where the dirty pages in RAM are written to the disk.
+Direct I/O plugin in GridGain is used for the checkpointing process where the dirty pages in RAM are written to the disk.
 
 Importing Direct I/O Pluging In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Direct IO Module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -25,7 +25,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-direct-io</artifactId>
             <version>${ignite.version}</version>
         </dependency>
@@ -36,14 +36,14 @@ interested in):
 
 Importing Direct I/O Pluging In Gradle Project
 -------------------------------------
-For gradle you can add compile dependency, where igniteVersion is actual Ignite version:
+For gradle you can add compile dependency, where igniteVersion is actual GridGain version:
 
-compile group: 'org.apache.ignite', name: 'ignite-direct-io', version: igniteVersion
+compile group: 'org.gridgain', name: 'ignite-direct-io', version: igniteVersion
 
 Additional setup is not required. Once plugin is available in classpath, it will be used for Durable Memory IO.
 
 -------------------------------------
-See more information in Apache Ignite documentation:
+See more information in GridGain documentation:
 https://apacheignite.readme.io/docs/durable-memory-tuning#section-enabling-direct-i-o
 
 and description of internal desing can be found in Wiki:
diff --git a/modules/extdata/platform/README.txt b/modules/extdata/platform/README.txt
index cb583ca..d39d9e7 100644
--- a/modules/extdata/platform/README.txt
+++ b/modules/extdata/platform/README.txt
@@ -1,4 +1,4 @@
-Apache Ignite Platform Tests
+GridGain Platform Tests
 ------------------------
 
 Special module for platform tests.
diff --git a/modules/flink/README.txt b/modules/flink/README.txt
index a198b1b..449e2db 100644
--- a/modules/flink/README.txt
+++ b/modules/flink/README.txt
@@ -1,14 +1,14 @@
-Apache Ignite Flink Sink Module
+GridGain Flink Sink Module
 -----------------------------------
 
-Apache Ignite Flink Sink module is a streaming connector to inject Flink data into Ignite cache.
+GridGain Flink Sink module is a streaming connector to inject Flink data into GridGain cache.
 
-Starting data transfer to Ignite can be done with the following steps.
+Starting data transfer to GridGain can be done with the following steps.
 
-1. Import Ignite Flink Sink Module in Maven Project
+1. Import GridGain Flink Sink Module in Maven Project
 
 If you are using Maven to manage dependencies of your project, you can add Flink module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -19,7 +19,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-flink</artifactId>
             <version>${ignite.version}</version>
         </dependency>
@@ -28,6 +28,6 @@ interested in):
     ...
 </project>
 
-2. Create an Ignite configuration file (see example-ignite.xml) and make sure it is accessible from the sink.
+2. Create an GridGain configuration file (see example-ignite.xml) and make sure it is accessible from the sink.
 
 3. Make sure your data input to the sink is specified. For example `input.addSink(igniteSinkObject)`
diff --git a/modules/flume/README.txt b/modules/flume/README.txt
index adcd021..ff34d68 100644
--- a/modules/flume/README.txt
+++ b/modules/flume/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite Flume Sink Module
+GridGain Flume Sink Module
 -------------------------------
 
-IgniteSink is a Flume sink that extracts Events from an associated Flume channel and injects into an Ignite cache.
+IgniteSink is a Flume sink that extracts Events from an associated Flume channel and injects into an GridGain cache.
 Flume 1.7.0 is supported.
 
 IgniteSink, which can be found in 'optional/ignite-flume', and its dependencies have to be included in the agent's classpath,
@@ -12,7 +12,7 @@ as described in the following subsection, before starting the Flume agent.
 1. Create a transformer by implementing EventTransformer interface.
 2. Create 'ignite' directory inside plugins.d directory which is located in ${FLUME_HOME}. If the plugins.d directory is not there, create it.
 3. Build it and copy to ${FLUME_HOME}/plugins.d/ignite-sink/lib.
-4. Copy other Ignite-related jar files from Apache Ignite distribution to ${FLUME_HOME}/plugins.d/ignite-sink/libext to have them as shown below.
+4. Copy other GridGain-related jar files from GridGain distribution to ${FLUME_HOME}/plugins.d/ignite-sink/libext to have them as shown below.
 
 ```
 plugins.d/
@@ -31,9 +31,9 @@ plugins.d/
         `-- spring-expression-4.1.0.RELEASE.jar
 ```
 
-4. In Flume configuration file, specify Ignite configuration XML file's location with cache properties
+4. In Flume configuration file, specify GridGain configuration XML file's location with cache properties
 (see [Apache Ignite](https://apacheignite.readme.io/) with cache name specified for cache creation,
-cache name (same as in Ignite configuration file), your EventTransformer's implementation class,
+cache name (same as in GridGain configuration file), your EventTransformer's implementation class,
 and, optionally, batch size (default -- 100).
 
 ```
diff --git a/modules/gce/README.txt b/modules/gce/README.txt
index 22c0cb9..860603d 100644
--- a/modules/gce/README.txt
+++ b/modules/gce/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite GCE Module
+GridGain GCE Module
 ------------------------
 
-Apache Ignite GCE module provides Google Cloud Storage based implementations of IP finder for TCP discovery.
+GridGain GCE module provides Google Cloud Storage based implementations of IP finder for TCP discovery.
 
 To enable GCE module when starting a standalone node, move 'optional/ignite-gce' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -11,7 +11,7 @@ Importing GCE Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add GCE module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -22,7 +22,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-gce</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/geospatial/README.txt b/modules/geospatial/README.txt
index 59143a0..fcfbf74 100644
--- a/modules/geospatial/README.txt
+++ b/modules/geospatial/README.txt
@@ -1,18 +1,18 @@
-Apache Ignite Geospatial Module
+GridGain Geospatial Module
 -----------------------------
 
-Apache Ignite geospatial module provides capabilities to geospatial index cache type.
+GridGain geospatial module provides capabilities to geospatial index cache type.
 
 To enable geospatial module when starting a standalone node, move 'optional/ignite-geospatial' folder to
 'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
-Note! This module can be used only when Ignite indexing module is enabled.
+Note! This module can be used only when GridGain indexing module is enabled.
 
 Importing geospatial Module In Maven Project
 ------------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add geospatial module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -23,7 +23,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-geospatial</artifactId>
             <version>${ignite.version}</version>
         </dependency>
@@ -36,13 +36,13 @@ interested in):
 LGPL dependencies
 -----------------
 
-Ignite includes the following optional LGPL dependencies:
+GridGain includes the following optional LGPL dependencies:
  - Hibernate L2 Cache Integration, http://hibernate.org/orm/
  - JTS Topology Suite for Geospatial indexing, http://tsusiatsoftware.net/jts/main.html
  - cron4j for cron-based task scheduling, http://www.sauronsoftware.it/projects/cron4j
 
-Apache binary releases cannot include LGPL dependencies. If you would like include
+GridGain binary releases cannot include LGPL dependencies. If you would like include
 optional LGPL dependencies into your release, you should download the source release
-from Ignite website and do the build with the following maven command:
+from GridGain website and do the build with the following maven command:
 
 mvn clean package -DskipTests -Prelease,lgpl
diff --git a/modules/hadoop/README.txt b/modules/hadoop/README.txt
index ecd47e0..1d4860c 100644
--- a/modules/hadoop/README.txt
+++ b/modules/hadoop/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite Hadoop Module
+GridGain Hadoop Module
 ---------------------------
 
-Apache Ignite Hadoop module provides In-Memory MapReduce engine and driver to use IGFS as Hadoop file system
+GridGain Hadoop module provides In-Memory MapReduce engine and driver to use IGFS as Hadoop file system
 which are 100% compatible with HDFS and YARN.
 
 To enable Hadoop module when starting a standalone node, move 'optional/ignite-hadoop' folder to
@@ -12,7 +12,7 @@ Importing Hadoop Module In Maven Project
 ----------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Hadoop module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -23,7 +23,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-hadoop</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/hibernate-4.2/README.txt b/modules/hibernate-4.2/README.txt
index 096b9d7..85bc95b 100644
--- a/modules/hibernate-4.2/README.txt
+++ b/modules/hibernate-4.2/README.txt
@@ -1,8 +1,8 @@
-Apache Ignite Hibernate Module
+GridGain Hibernate Module
 ------------------------------
 
-Apache Ignite Hibernate module provides Hibernate second-level cache (L2 cache) implementation based
-on Apache Ignite In-Memory Data Grid.
+GridGain Hibernate module provides Hibernate second-level cache (L2 cache) implementation based
+on GridGain In-Memory Data Grid.
 
 To enable Hibernate module when starting a standalone node, move 'optional/ignite-hibernate' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -12,7 +12,7 @@ Importing Hibernate Module In Maven Project
 -------------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Hibernate module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -23,7 +23,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-hibernate_4.2</artifactId>
             <version>${ignite.version}</version>
         </dependency>
@@ -36,13 +36,13 @@ interested in):
 LGPL dependencies
 -----------------
 
-Ignite includes the following optional LGPL dependencies:
+GridGain includes the following optional LGPL dependencies:
  - Hibernate L2 Cache Integration, http://hibernate.org/orm/
  - JTS Topology Suite for Geospatial indexing, http://tsusiatsoftware.net/jts/main.html
  - cron4j for cron-based task scheduling, http://www.sauronsoftware.it/projects/cron4j
 
-Apache binary releases cannot include LGPL dependencies. If you would like include
+GridGain binary releases cannot include LGPL dependencies. If you would like include
 optional LGPL dependencies into your release, you should download the source release
-from Ignite website and do the build with the following maven command:
+from GridGain website and do the build with the following maven command:
 
 mvn clean package -DskipTests -Prelease,lgpl
diff --git a/modules/hibernate-5.1/README.txt b/modules/hibernate-5.1/README.txt
index 53c5d18..e9d3ae0 100644
--- a/modules/hibernate-5.1/README.txt
+++ b/modules/hibernate-5.1/README.txt
@@ -1,8 +1,8 @@
-Apache Ignite Hibernate Module
+GridGain Hibernate Module
 ------------------------------
 
-Apache Ignite Hibernate module provides Hibernate second-level cache (L2 cache) implementation based
-on Apache Ignite In-Memory Data Grid.
+GridGain Hibernate module provides Hibernate second-level cache (L2 cache) implementation based
+on GridGain In-Memory Data Grid.
 
 To enable Hibernate module when starting a standalone node, move 'optional/ignite-hibernate5' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -12,7 +12,7 @@ Importing Hibernate Module In Maven Project
 -------------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Hibernate module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -23,7 +23,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-hibernate_5.1</artifactId>
             <version>${ignite.version}</version>
         </dependency>
@@ -36,13 +36,13 @@ interested in):
 LGPL dependencies
 -----------------
 
-Ignite includes the following optional LGPL dependencies:
+GridGain includes the following optional LGPL dependencies:
  - Hibernate L2 Cache Integration, http://hibernate.org/orm/
  - JTS Topology Suite for Geospatial indexing, http://tsusiatsoftware.net/jts/main.html
  - cron4j for cron-based task scheduling, http://www.sauronsoftware.it/projects/cron4j
 
-Apache binary releases cannot include LGPL dependencies. If you would like include
+GridGain binary releases cannot include LGPL dependencies. If you would like include
 optional LGPL dependencies into your release, you should download the source release
-from Ignite website and do the build with the following maven command:
+from GridGain website and do the build with the following maven command:
 
 mvn clean package -DskipTests -Prelease,lgpl
diff --git a/modules/ignored-tests/README.txt b/modules/ignored-tests/README.txt
index 70f728d..f8feea0 100644
--- a/modules/ignored-tests/README.txt
+++ b/modules/ignored-tests/README.txt
@@ -1,4 +1,4 @@
-Apache Ignite Ignored Tests
+GridGain Ignored Tests
 ------------------------
 
 Special module containing ignored and flaky tests grouped in a single test suite.
\ No newline at end of file
diff --git a/modules/indexing/README.txt b/modules/indexing/README.txt
index f0ea6ba..fa5aff5 100644
--- a/modules/indexing/README.txt
+++ b/modules/indexing/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite Indexing Module
+GridGain Indexing Module
 -----------------------------
 
-Apache Ignite indexing module provides capabilities to index cache context and run SQL, full text or
+GridGain indexing module provides capabilities to index cache context and run SQL, full text or
 individual field queries against these indexes.
 
 To enable indexing module when starting a standalone node, move 'optional/ignite-indexing' folder to
@@ -12,7 +12,7 @@ Importing indexing Module In Maven Project
 ------------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add indexing module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -23,7 +23,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-indexing</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/jcl/README.txt b/modules/jcl/README.txt
index ac37421..ece38bf 100644
--- a/modules/jcl/README.txt
+++ b/modules/jcl/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite JCL Module
+GridGain JCL Module
 ------------------------
 
-Apache Ignite JCL module provides GridLogger implementation that can delegate to any logger based
+GridGain JCL module provides GridLogger implementation that can delegate to any logger based
 on Jakarta Commons Logging (JCL).
 
 To enable JCL module when starting a standalone node, move 'optional/ignite-jcl' folder to
@@ -12,7 +12,7 @@ Importing JCL Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add JCL module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -23,7 +23,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-jcl</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/jms11/README.txt b/modules/jms11/README.txt
index 3f0d213..55654b6 100644
--- a/modules/jms11/README.txt
+++ b/modules/jms11/README.txt
@@ -1,14 +1,14 @@
-Apache Ignite JMS 1.1 Module
+GridGain JMS 1.1 Module
 ----------------------------
 
-Apache Ignite JMS 1.1 module provides a streamer to consume JMS queue and topic messages into
-Apache Ignite caches.
+GridGain JMS 1.1 module provides a streamer to consume JMS queue and topic messages into
+GridGain caches.
 
-Importing Apache Ignite JMS 1.1 Module In Maven Project
+Importing GridGain JMS 1.1 Module In Maven Project
 --------------------------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add the JMS 1.1 module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -19,7 +19,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-jms11</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/jta/README.txt b/modules/jta/README.txt
index c6c08b2a..6a8913f 100644
--- a/modules/jta/README.txt
+++ b/modules/jta/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite JTA Module
+GridGain JTA Module
 ------------------------
 
-Apache Ignite JTA module provides capabilities to integrate Apache Ignite cache transactions with JTA.
+GridGain JTA module provides capabilities to integrate GridGain cache transactions with JTA.
 
 To enable JTA module when starting a standalone node, move 'optional/ignite-jta' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -11,7 +11,7 @@ Importing JTA Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add JTA module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -22,7 +22,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-jta</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/kafka/README.txt b/modules/kafka/README.txt
index 686c7ce..d04f338 100644
--- a/modules/kafka/README.txt
+++ b/modules/kafka/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite Kafka Streamer Module
+GridGain Kafka Streamer Module
 -----------------------------------
 
-Apache Ignite Kafka Streamer module provides streaming from Kafka to Ignite cache.
+GridGain Kafka Streamer module provides streaming from Kafka to GridGain cache.
 
 There are two ways this can be achieved:
 - importing Kafka Streamer module in your Maven project and instantiate KafkaStreamer for data streaming;
@@ -9,10 +9,10 @@ There are two ways this can be achieved:
 
 Below are the details.
 
-## Importing Ignite Kafka Streamer Module In Maven Project
+## Importing GridGain Kafka Streamer Module In Maven Project
 
 If you are using Maven to manage dependencies of your project, you can add Kafka module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -23,7 +23,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-kafka</artifactId>
             <version>${ignite.version}</version>
         </dependency>
@@ -33,9 +33,9 @@ interested in):
 </project>
 
 
-## Streaming Data to Ignite via Kafka Connect
+## Streaming Data to GridGain via Kafka Connect
 
-Sink Connector will help you export data from Kafka to Ignite cache. It polls data from Kafka topics and writes it to the user-specified cache.
+Sink Connector will help you export data from Kafka to GridGain cache. It polls data from Kafka topics and writes it to the user-specified cache.
 For more information on Kafka Connect, see [Kafka Documentation](http://kafka.apache.org/documentation.html#connect).
 
 Connector can be found in 'optional/ignite-kafka.' It and its dependencies have to be on the classpath of a Kafka running instance,
@@ -93,7 +93,7 @@ where 'cacheName' is the name of the cache you specify in '/some-path/ignite.xml
 will be pulled and stored. 'cacheAllowOverwrite' is set to true if you want to enable overwriting existing values in cache.
 You can also set 'cachePerNodeDataSize' and 'cachePerNodeParOps' to adjust per-node buffer and the maximum number
 of parallel stream operations for a single node.
-If you need to create an Ignite key from a Kafka value, implement StreamSingleTupleExtractor and specify it as 'singleTupleExtractorCls'.
+If you need to create an GridGain key from a Kafka value, implement StreamSingleTupleExtractor and specify it as 'singleTupleExtractorCls'.
 
 See example-ignite.xml in tests for a simple cache configuration file example.
 
@@ -134,7 +134,7 @@ http://node1:8080/ignite?cmd=size&cacheName=cache1
 
 ## Streaming Cache Event Data to Kafka via Kafka Connect
 
-Source connector enables listening to Ignite cache events and, upon filtering, stream them to Kafka.
+Source connector enables listening to GridGain cache events and, upon filtering, stream them to Kafka.
 
 Connector can be found in 'optional/ignite-kafka.' It and its dependencies have to be on the classpath of a Kafka running instance,
 as described in the following subsection.
@@ -191,7 +191,7 @@ igniteCfg=/some-path/ignite.xml
 ```
 where 'cacheName' is the name of the cache you specify in '/some-path/ignite.xml' and the data from 'testTopic1,testTopic2'
 will be pulled and stored. Also consider using 'evtBufferSize' and 'evtBatchSize' for tuning the internal queue
-used to safely transfer data from Ignite cache to Kafka.
+used to safely transfer data from GridGain cache to Kafka.
 
 The following cache events can be specified in the connector configurations:
 - CREATED
diff --git a/modules/kubernetes/README.txt b/modules/kubernetes/README.txt
index a9a5a09..e8b3f8f 100644
--- a/modules/kubernetes/README.txt
+++ b/modules/kubernetes/README.txt
@@ -1,8 +1,8 @@
-Apache Ignite Kubernetes Module
+GridGain Kubernetes Module
 ------------------------
 
-Apache Ignite Kubernetes module provides a TCP Discovery IP Finder that uses a dedicated Kubernetes service
-for IP addresses lookup of Apache Ignite pods containerized by Kubernetes.
+GridGain Kubernetes module provides a TCP Discovery IP Finder that uses a dedicated Kubernetes service
+for IP addresses lookup of GridGain pods containerized by Kubernetes.
 
 To enable Kubernetes module when starting a standalone node, move 'optional/ignite-kubernetes' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -12,7 +12,7 @@ Importing Kubernetes Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Kubernetes module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -23,7 +23,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-kubernetes</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/log4j/README.txt b/modules/log4j/README.txt
index 4bd1b4b..b78db7e 100644
--- a/modules/log4j/README.txt
+++ b/modules/log4j/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite Log4J Module
+GridGain Log4J Module
 --------------------------
 
-Apache Ignite Log4J module provides IgniteLogger implementation based on Apache Log4J.
+GridGain Log4J module provides IgniteLogger implementation based on Apache Log4J.
 
 To enable Log4J module when starting a standalone node, move 'optional/ignite-log4j' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -11,7 +11,7 @@ Importing Log4J Module In Maven Project
 ---------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Log4J module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -22,7 +22,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-log4j</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/log4j2/README.txt b/modules/log4j2/README.txt
index 6e21b7a..9e0e4c0 100644
--- a/modules/log4j2/README.txt
+++ b/modules/log4j2/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite Log4J2 Module
+GridGain Log4J2 Module
 --------------------------
 
-Apache Ignite Log4J2 module provides IgniteLogger implementation based on Apache Log4J2.
+GridGain Log4J2 module provides IgniteLogger implementation based on Apache Log4J2.
 
 To enable Log4J2 module when starting a standalone node, move 'optional/ignite-log4j2' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -24,7 +24,7 @@ Importing Log4J2 Module In Maven Project
 ---------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Log4J2 module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -35,7 +35,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-log4j2</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/mesos/README.txt b/modules/mesos/README.txt
index e5e4bbb..1cb62ee 100644
--- a/modules/mesos/README.txt
+++ b/modules/mesos/README.txt
@@ -1,13 +1,13 @@
-Apache Ignite Mesos Module
+GridGain Mesos Module
 ------------------------
 
-Apache Ignite Mesos module provides integration Apache Ignite with Apache Mesos.
+GridGain Mesos module provides integration GridGain with Apache Mesos.
 
-Importing Apache Ignite Mesos Module In Maven Project
+Importing GridGain Mesos Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Mesos module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -18,7 +18,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-mesos</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/ml/README.txt b/modules/ml/README.txt
index d7e2fb9..8f4a556 100644
--- a/modules/ml/README.txt
+++ b/modules/ml/README.txt
@@ -1,16 +1,16 @@
-Apache Ignite ML Grid Module
+GridGain ML Grid Module
 ----------------------------
 
-Apache Ignite ML Grid module provides machine learning features, along with involved methods of linear algebra and relevant data structures, including on heap and off heap, dense and sparse, local and distributed implementations.
+GridGain ML Grid module provides machine learning features, along with involved methods of linear algebra and relevant data structures, including on heap and off heap, dense and sparse, local and distributed implementations.
 
 # Local build with javadoc
 
 Run from project root:
 mvn clean package -DskipTests -pl modules/ml -am
 
-Apache binary releases cannot include LGPL dependencies. If you would like to activate native BLAS optimizations
+GridGain binary releases cannot include LGPL dependencies. If you would like to activate native BLAS optimizations
 into your build, you should download the source release
-from Ignite website and do the build with the following maven command:
+from GridGain website and do the build with the following maven command:
 
 mvn clean package -Plgpl -DskipTests -pl modules/ml -am
 
diff --git a/modules/mqtt/README.txt b/modules/mqtt/README.txt
index 62a1589..b37a9d7 100644
--- a/modules/mqtt/README.txt
+++ b/modules/mqtt/README.txt
@@ -1,14 +1,14 @@
-Apache Ignite MQTT Module
+GridGain MQTT Module
 -------------------------
 
-Apache Ignite MQTT module provides a streamer to consume MQTT topic messages into
-Apache Ignite caches.
+GridGain MQTT module provides a streamer to consume MQTT topic messages into
+GridGain caches.
 
-Importing Apache Ignite MQTT Module In Maven Project
+Importing GridGain MQTT Module In Maven Project
 ----------------------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add the MQTT module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -19,7 +19,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-mqtt</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/osgi-karaf/README.txt b/modules/osgi-karaf/README.txt
index 6bd1555..42e977f 100644
--- a/modules/osgi-karaf/README.txt
+++ b/modules/osgi-karaf/README.txt
@@ -1,18 +1,18 @@
-Apache Ignite OSGi Karaf Integration Module
+GridGain OSGi Karaf Integration Module
 -------------------------------------------
 
-This module contains a feature repository to facilitate installing Apache Ignite into an Apache Karaf container.
+This module contains a feature repository to facilitate installing GridGain into an Apache Karaf container.
 
 Use the following Karaf command:
 
-    karaf@root()> feature:repo-add mvn:org.apache.ignite/ignite-osgi-karaf/${ignite.version}/xml/features
+    karaf@root()> feature:repo-add mvn:org.gridgain/ignite-osgi-karaf/${ignite.version}/xml/features
 
-Replacing ${ignite.version} with the Apache Ignite version you woudl like to install.
+Replacing ${ignite.version} with the GridGain version you would like to install.
 
-You may now list the Ignite features that are available for installation:
+You may now list the GridGain features that are available for installation:
 
     karaf@root()> feature:list | grep ignite
 
 Each feature installs the corresponding ignite module + its dependencies.
 
-We include an global feature with name 'ignite-all' that collectively installs all Ignite features at once.
+We include an global feature with name 'ignite-all' that collectively installs all GridGain features at once.
diff --git a/modules/osgi-paxlogging/README.txt b/modules/osgi-paxlogging/README.txt
index f6346f1..08342f3 100644
--- a/modules/osgi-paxlogging/README.txt
+++ b/modules/osgi-paxlogging/README.txt
@@ -1,4 +1,4 @@
-Apache Ignite OSGi Pax Logging Fragment Module
+GridGain OSGi Pax Logging Fragment Module
 ----------------------------------------------
 
 This module is an OSGi fragment that exposes the following packages from the Pax Logging API bundle:
diff --git a/modules/osgi/README.txt b/modules/osgi/README.txt
index 439c450..00df4ae 100644
--- a/modules/osgi/README.txt
+++ b/modules/osgi/README.txt
@@ -1,13 +1,13 @@
-Apache Ignite OSGi Integration Module
+GridGain OSGi Integration Module
 -------------------------------------
 
-This module provides the bridging components to make Apache Ignite run seamlessly inside an OSGi container
-like Apache Karaf. It provides a Bundle Activator to initialize Ignite, along with different classloaders
+This module provides the bridging components to make GridGain run seamlessly inside an OSGi container
+like Apache Karaf. It provides a Bundle Activator to initialize GridGain, along with different classloaders
 facilitate class resolution within an OSGi environment.
 
-If using Ignite within Apache Karaf, please refer to the osgi-karaf and osgi-paxlogging modules too:
+If using GridGain within Apache Karaf, please refer to the osgi-karaf and osgi-paxlogging modules too:
 
-  - osgi-karaf contains a feature repository to facilitate installing Ignite into a Karaf container.
+  - osgi-karaf contains a feature repository to facilitate installing GridGain into a Karaf container.
   - osgi-paxlogging contains an OSGi fragment required to make pax-logging-api expose certain log4j packages
     required by ignite-log4j
 
@@ -15,7 +15,7 @@ Importing the ignite-osgi module in a Maven project
 ---------------------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add the ignite-osgi module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are interested in):
+dependency like this (replace '${ignite.version}' with actual GridGain version you are interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
     xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
@@ -25,7 +25,7 @@ dependency like this (replace '${ignite.version}' with actual Ignite version you
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-osgi</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/platforms/README.txt b/modules/platforms/README.txt
index 6268a88..aaeaf9e 100644
--- a/modules/platforms/README.txt
+++ b/modules/platforms/README.txt
@@ -1,6 +1,6 @@
-Apache Ignite Platforms
+GridGain Platforms
 ==================================
 
 Contains integrations with other platforms, most notably:
- * Apache Ignite.NET
- * Apache Ignite C++
\ No newline at end of file
+ * GridGain.NET
+ * GridGain C++
\ No newline at end of file
diff --git a/modules/platforms/cpp/README.md b/modules/platforms/cpp/README.md
index 8d0f6d2..8be405c 100644
--- a/modules/platforms/cpp/README.md
+++ b/modules/platforms/cpp/README.md
@@ -1,99 +1,118 @@
-# Apache Ignite C++ SDK
+# Apache Ignite.NET SDK
 
-<a href="https://ignite.apache.org/"><img src="https://ignite.apache.org/images/logo3.png" hspace="20"/></a>
+<a href="https://www.gridgain.com/"><img src="https://www.gridgain.com/themes/gridgain1185/images/svg/gridgain-logo.svg?20180912" hspace="10"  width="300px"/></a><br/><br/>
 
+<a href="https://www.nuget.org/packages?q=Apache.Ignite"><img src="https://img.shields.io/nuget/v/Apache.Ignite.svg" /></a>
 
-## Getting Started
+<a href="https://www.myget.org/gallery/apache-ignite-net-nightly"><img src="https://img.shields.io/myget/apache-ignite-net-nightly/vpre/Apache.Ignite.svg" /></a>
+
+<a href="https://ci.ignite.apache.org/viewType.html?buildTypeId=IgniteTests24Java8_IgnitePlatformNet&branch_IgniteTests24Java8=<default>"><img src="http://ci.ignite.apache.org/app/rest/builds/buildType:(id:IgniteTests24Java8_IgnitePlatformNet)/statusIcon" /></a>
 
-For information on how to get started with Apache Ignite, please visit: [Getting Started][getting-started].
+## Getting Started
 
-## Full Documentation
+For information on how to get started with GridGain, please visit: [Getting Started][getting-started].
 
-You can find the full Apache Ignite documentation here: [Full documentation][docs].
 
-## What is Apache Ignite?
+## What is GridGain?
 
-[Apache Ignite][apache-ignite-homepage] is a memory-centric multi-model distributed
- <strong>database</strong>, <strong>caching</strong>, and <strong>processing</strong> platform for
- transactional, analytical, and streaming workloads, delivering in-memory speeds at petabyte scale.
+GridGain, built on top of Apache Ignite, is a memory-centric distributed **database**, **caching**,
+ and **processing** platform for transactional, analytical, and streaming workloads delivering in-memory
+ speeds at petabyte scale.
 
 <p align="center">
-    <a href="https://apacheignite-cpp.readme.io/docs/">
-        <img src="https://ignite.apache.org/images/durable-memory.png" width="900px"/>
+    <a href="https://www.gridgain.com/">
+        <img src="https://files.readme.io/58b7901-gg_platform.png" width="600px"/>
     </a>
 </p>
 
-## Durable Memory
-Ignite's durable memory component treats RAM not just as a caching layer but as a complete fully functional storage layer. This means that users can turn the persistence on and off as needed. If the persistence is off, then Ignite can act as a distributed **in-memory database** or **in-memory data grid**, depending on whether you prefer to use SQL or key-value APIs. If the persistence is turned on, then Ignite becomes a distributed, **horizontally scalable database** that guarantees full [...]
+## Memory-Centric Storage
+GridGain is based on distributed memory-centric architecture that combines the performance and scale of in-memory
+computing together with the disk durability and strong consistency in one system.
 
-[Read More](https://apacheignite-cpp.readme.io/docs/durable-memory)
+The main difference between the memory-centric approach and the traditional disk-centric approach is that the memory
+is treated as a fully functional storage, not just as a caching layer, like most databases do.
+For example, GridGain can function in a pure in-memory mode, in which case it can be treated as an
+In-Memory Database (IMDB) and In-Memory Data Grid (IMDG) in one.
 
-## Ignite Persistence
+On the other hand, when persistence is turned on, GidGain begins to function as a memory-centric system where most of
+the processing happens in memory, but the data and indexes get persisted to disk. The main difference here
+from the traditional disk-centric RDBMS or NoSQL system is that GridGain is strongly consistent, horizontally
+[Read More](https://apacheignite-net.readme.io/docs/durable-memory)
 
-Ignite Native Persistence is a distributed, ACID, and SQL-compliant **disk store** that transparently integrates with Ignite's Durable Memory as an optional disk layer storing data and indexes on SSD, Flash, 3D XPoint, and other types of non-volatile storages.
+## Native Persistence
 
-With the Ignite Persistence enabled, you no longer need to keep all the data and indexes in memory or warm it up after a node or cluster restart because the Durable Memory is tightly coupled with persistence and treats it as a secondary memory tier. This implies that if a subset of data or an index is missing in RAM, the Durable Memory will take it from the disk.
+Native Persistence is a distributed, ACID, and SQL-compliant **disk store** that transparently integrates with
+GridGain memory-centric storage as an optional disk layer storing data and indexes on SSD,
+ Flash, 3D XPoint, and other types of non-volatile storages.
 
+With the Native Persistence enabled, you no longer need to keep all the data and indexes in memory or warm it
+up after a node or cluster restart because the Durable Memory is tightly coupled with persistence and treats
+it as a secondary memory tier. This implies that if a subset of data or an index is missing in RAM,
+the Durable Memory will take it from the disk.
 <p align="center">
     <a href="https://apacheignite.readme.io/docs/distributed-persistent-store">
         <img src="https://ignite.apache.org/images/native_persistence.png?renew" width="400px"/>
     </a>
 </p>
 
-[Read More](https://apacheignite-cpp.readme.io/docs/ignite-persistence)
+[Read More](https://apacheignite-net.readme.io/docs/ignite-persistent-store)
 
 ## ACID Compliance
-Data stored in Ignite is ACID-compliant both in memory and on disk, making Ignite a **strongly consistent** system. Ignite transactions work across the network and can span multiple servers.
+Data stored in GridGain is ACID-compliant both in memory and on disk, making GridGain a **strongly consistent** system. GridGain transactions work across the network and can span multiple servers.
 
-[Read More](https://apacheignite-cpp.readme.io/docs/transactions)
+[Read More](https://apacheignite-net.readme.io/docs/transactions)
 
 ## Complete SQL Support
-Ignite provides full support for SQL, DDL and DML, allowing users to interact with Ignite using pure SQL without writing any code. This means that users can create tables and indexes as well as insert, update, and query data using only SQL. Having such complete SQL support makes Ignite a one-of-a-kind **distributed SQL database**.
+GridGain provides full support for SQL, DDL and DML, allowing users to interact with GridGain using pure SQL without writing any code. This means that users can create tables and indexes as well as insert, update, and query data using only SQL. Having such complete SQL support makes GridGain a one-of-a-kind **distributed SQL database**.
 
-[Read More](https://apacheignite-cpp.readme.io/docs/sql-database)
+[Read More](https://apacheignite-net.readme.io/docs/sql-database)
 
 ## Key-Value
-The in-memory data grid component in Ignite is a fully transactional **distributed key-value store** that can scale horizontally across 100s of servers in the cluster. When persistence is enabled, Ignite can also store more data than fits in memory and survive full cluster restarts.
+The in-memory data grid component in GridGain is a fully transactional **distributed key-value store** that can scale horizontally across 100s of servers in the cluster. When persistence is enabled, GridGain can also store more data than fits in memory and survive full cluster restarts.
 
-[Read More](https://apacheignite-cpp.readme.io/docs/data-grid)
+[Read More](https://apacheignite-net.readme.io/docs/data-grid)
 
 ## Collocated Processing
-Most traditional databases work in a client-server fashion, meaning that data must be brought to the client side for processing. This approach requires lots of data movement from servers to clients and generally does not scale. Ignite, on the other hand, allows for sending light-weight computations to the data, i.e. **collocating** computations with data. As a result, Ignite scales better and minimizes data movement.
+Most traditional databases work in a client-server fashion, meaning that data must be brought to the client side for processing. This approach requires lots of data movement from servers to clients and generally does not scale. GridGain, on the other hand, allows for sending light-weight computations to the data, i.e. **collocating** computations with data. As a result, GridGain scales better and minimizes data movement.
 
-[Read More](https://apacheignite.readme.io/docs/collocate-compute-and-data)
+[Read More](https://apacheignite-net.readme.io/docs/colocate-compute-and-data)
 
 ## Scalability and Durability
-Ignite is an elastic, horizontally scalable distributed system that supports adding and removing cluster nodes on demand. Ignite also allows for storing multiple copies of the data, making it resilient to partial cluster failures. If the persistence is enabled, then data stored in Ignite will also survive full cluster failures. Cluster restarts in Ignite can be very fast, as the data becomes operational instantaneously directly from disk. As a result, the data does not need to be preload [...]
+GridGain is an elastic, horizontally scalable distributed system that supports adding and removing cluster nodes on demand. GridGain also allows for storing multiple copies of the data, making it resilient to partial cluster failures. If the persistence is enabled, then data stored in GridGain will also survive full cluster failures. Cluster restarts in GridGain can be very fast, as the data becomes operational instantaneously directly from disk. As a result, the data does not need to be [...]
 
-[Read More](https://apacheignite-cpp.readme.io/docs/cluster)
+[Read More](https://apacheignite-net.readme.io/docs/cluster)
 
 ## Ignite and Ignite C++
 * Ignite C++ is built on top of Ignite.
 * Ignite C++ starts the JVM in the same process and communicates with it via JNI.
 * .NET, C++ and Java nodes can join the same cluster, use the same caches, and interoperate using common binary protocol.
 * Java compute jobs can execute on any node (Java, .NET, C++).
+* .NET compute jobs can only execute on .NET nodes.
 
-## Ignite Components
+GridGain.NET also has Thin Client mode (see `Ignition.StartClient()`), which does not start JVM and does not require Java on machine.
 
-You can view Apache Ignite as a collection of independent, well-integrated components geared to improve performance and
+## GridGain Components
+
+You can view GridGain as a collection of independent, well-integrated components geared to improve performance and
  scalability of your application.
 
 Some of these components include:
 * [Advanced Clustering](#advanced-clustering)
-* [Data Grid](#data-grid-jcache)
+* [Data Grid](##data-grid-jcache)
 * [SQL Database](#sql-database)
 * [Compute Grid](#compute-grid)
+* [Service Grid](#service-grid)
 
 Below you’ll find a brief explanation for each of them:
 
 ## Advanced Clustering
 
-Ignite nodes can [automatically discover](https://apacheignite-cpp.readme.io/docs/cluster) each other. This helps to scale the cluster when needed, without having to restart the whole cluster.
-Developers can also leverage Ignite’s hybrid cloud support that allows establishing connection between private cloud and public clouds
+GridGain nodes can [automatically discover](https://apacheignite-net.readme.io/docs/cluster) each other. This helps to scale the cluster when needed, without having to restart the whole cluster.
+Developers can also leverage GridGain’s hybrid cloud support that allows establishing connection between private cloud and public clouds
 such as Amazon Web Services, providing them with best of both worlds.
 
 <p align="center">
-    <a href="https://apacheignite-cpp.readme.io/docs/cluster">
+    <a href="https://apacheignite-net.readme.io/docs/cluster">
         <img src="https://ignite.apache.org/images/advanced-clustering.png" />
     </a>
 </p>
@@ -101,120 +120,100 @@ such as Amazon Web Services, providing them with best of both worlds.
 
 ## Data Grid (Cache)
 
-[Ignite data grid](https://apacheignite-cpp.readme.io/docs/data-grid) is an in-memory distributed key-value store which can be viewed as a distributed partitioned `Dictionary`, with every cluster node
+[GridGain data grid](https://apacheignite-net.readme.io/docs/data-grid) is an in-memory distributed key-value store which can be viewed as a distributed partitioned `Dictionary`, with every cluster node
 owning a portion of the overall data. This way the more cluster nodes we add, the more data we can cache.
 
-Unlike other key-value stores, Ignite determines data locality using a pluggable hashing algorithm. Every client can determine which node a key
+Unlike other key-value stores, GridGain determines data locality using a pluggable hashing algorithm. Every client can determine which node a key
 belongs to by plugging it into a hashing function, without a need for any special mapping servers or name nodes.
 
-Ignite data grid supports local, replicated, and partitioned data sets and allows to freely cross query between these data sets using standard SQL and LINQ syntax.
-Ignite supports standard SQL and LINQ for querying in-memory data including support for distributed joins.
+GridGain data grid supports local, replicated, and partitioned data sets and allows to freely cross query between these data sets using standard SQL and LINQ syntax.
+GridGain supports standard SQL and LINQ for querying in-memory data including support for distributed joins.
 
 <p align="center">
-    <a href="https://apacheignite-cpp.readme.io/docs/data-grid">
+    <a href="https://apacheignite-net.readme.io/docs/data-grid">
         <img src="https://ignite.apache.org/images/data_grid.png" vspace="15" width="450px"/>
     </a>
 </p>
 
 ## SQL Database
 
-Apache Ignite incorporates [distributed SQL database](https://apacheignite-cpp.readme.io/docs/sql-database) capabilities as a part of its platform. The database is horizontally
+GridGain incorporates [distributed SQL database](https://apacheignite-net.readme.io/docs/sql-database) capabilities as a part of its platform. The database is horizontally
  scalable, fault tolerant and SQL ANSI-99 compliant. It supports all SQL, DDL, and DML commands including SELECT, UPDATE,
   INSERT, MERGE, and DELETE queries. It also provides support for a subset of DDL commands relevant for distributed
   databases.
 
-With Ignite Durable Memory architecture, data as well as indexes can be stored both in memory and, optionally, on disk.
+With GridGain Durable Memory architecture, data as well as indexes can be stored both in memory and, optionally, on disk.
 This allows executing distributed SQL operations across different memory layers achieving in-memory performance with the durability of disk.
 
-You can interact with Apache Ignite using the SQL language via natively developed APIs for Java, .NET and C++, or via
-the Ignite JDBC or ODBC drivers. This provides a true cross-platform connectivity from languages such as PHP, Ruby and more.
+You can interact with GridGain using the SQL language via natively developed APIs for Java, .NET and C++, or via
+the GridGain JDBC or ODBC drivers. This provides a true cross-platform connectivity from languages such as PHP, Ruby and more.
 
 
 <p align="center">
-    <a href="https://apacheignite-cpp.readme.io/docs/sql-database">
+    <a href="https://apacheignite-net.readme.io/docs/sql-database">
         <img src="https://ignite.apache.org/images/sql_database.png" vspace="15" width="400px"/>
     </a>
 </p>
 
 ## Compute Grid
 
-[Distributed computations](https://apacheignite-cpp.readme.io/docs/compute-grid) are performed in parallel fashion to gain high performance, low latency, and linear scalability.
-Ignite compute grid provides a set of simple APIs that allow users distribute computations and data processing across multiple computers in the cluster.
+[Distributed computations](https://apacheignite-net.readme.io/docs/compute-grid) are performed in parallel fashion to gain high performance, low latency, and linear scalability.
+GridGain compute grid provides a set of simple APIs that allow users distribute computations and data processing across multiple computers in the cluster.
 Distributed parallel processing is based on the ability to take any computation and execute it on any set of cluster nodes and return the results back.
 
 <p align="center">
-    <a href="https://apacheignite-cpp.readme.io/docs/compute-grid">
+    <a href="https://apacheignite-net.readme.io/docs/compute-grid">
         <img src="https://ignite.apache.org/images/collocated_processing.png" vspace="15" width="400px"/>
     </a>
 </p>
 
 We support these features, amongst others:
 
-* [Distributed Closure Execution](https://apacheignite-cpp.readme.io/docs/distributed-closures)
-* [Load Balancing](https://apacheignite-cpp.readme.io/docs/load-balancing)
-* [Job Scheduling](https://apacheignite-cpp.readme.io/docs/job-scheduling)
-* [Fault Tolerance](https://apacheignite-cpp.readme.io/docs/fault-tolerance)
-
-
-## Ignite Facts
-
-#### Is Ignite a persistent or pure in-memory storage?
-**Both**. Native persistence in Ignite can be turned on and off. This allows Ignite to store data sets bigger than can fit in the available memory. Essentially, the smaller operational data sets can be stored in-memory only, and larger data sets that do not fit in memory can be stored on disk, using memory as a caching layer for better performance.
-
-[Read More](https://apacheignite-cpp.readme.io/docs/ignite-persistence)
-
-#### Is Ignite a distributed database?
-**Yes**. Data in Ignite is either *partitioned* or *replicated* across a cluster of multiple nodes. This provides scalability and adds resilience to the system. Ignite automatically controls how data is partitioned, however, users can plug in their own distribution (affinity) functions and collocate various pieces of data together for efficiency.
+* [Distributed Closure Execution](https://apacheignite-net.readme.io/docs/distributed-closures)
+* [MapReduce & ForkJoin Processing](https://apacheignite-net.readme.io/docs/mapreduce-forkjoin)
+* [Collocation of Compute and Data](https://apacheignite-net.readme.io/docs/colocate-compute-and-data)
+* [Fault Tolerance](https://apacheignite-net.readme.io/docs/fault-tolerance)
 
-[Read More](https://apacheignite-cpp.readme.io/docs/sql-database)
+## Service Grid
 
-#### Is Ignite a relational SQL database?
-**Not fully**. Although Ignite aims to behave like any other relational SQL database, there are differences in how Ignite handles constraints and indexes. Ignite supports *primary* and *secondary* indexes, however, the *uniqueness* can only be enforced for the *primary* indexes. Ignite also does not support *foreign key* constraints.
+[Service Grid](https://apacheignite-net.readme.io/docs/service-grid) allows for deployments of arbitrary user-defined services on the cluster. You can implement and deploy any service, such as custom counters, ID generators, hierarchical maps, etc.
 
-Essentially, Ignite purposely does not support any constraints that would entail a cluster broadcast message for each update and significantly hurt performance and scalability of the system.
+GridGain allows you to control how many instances of your service should be deployed on each cluster node and will automatically ensure proper deployment and fault tolerance of all the services.
 
-[Read More](https://apacheignite-cpp.readme.io/docs/sql-database)
-
-#### Is Ignite an in-memory database?
-**Yes**. Even though Ignite *durable memory* works well in-memory and on-disk, the disk persistence can be disabled and Ignite can act as a pure *in-memory database*.
-
-[Read More](https://apacheignite-cpp.readme.io/docs/sql-database)
-
-#### Is Ignite a transactional database?
-**Not fully**. ACID Transactions are supported, but only at *key-value* API level. Ignite also supports *cross-partition* transactions, which means that transactions can span keys residing in different partitions on different servers.
-
-At *SQL* level Ignite supports *atomic*, but not yet *transactional* consistency. Ignite community plans to implement SQL transactions in version 2.4.
-
-[Read More](https://apacheignite-cpp.readme.io/docs/sql-database)
+<p align="center">
+    <a href="https://apacheignite-net.readme.io/docs/service-grid">
+        <img src="https://ignite.apache.org/images/service_grid.png" vspace="15" width="400px"/>
+    </a>
+</p>
 
-#### Is Ignite a key-value store?
-**Yes**. Ignite provides a feature rich key-value API, that is JCache (JSR-107) compliant and supports Java, C++, and .NET.
+## Distributed Data Structures
 
-[Read More](https://apacheignite-cpp.readme.io/docs/data-grid)
+GridGain.NET supports complex [data structures](https://apacheignite-net.readme.io/docs/atomic-types) in a distributed fashion: `AtomicLong`, `AtomicReference`, `AtomicSequence`.
 
-#### Is Ignite an in-memory data grid?
-**Yes**. Ignite is a full-featured data grid, which can be used either in pure in-memory mode or with Ignite native persistence. It can also integrate with any 3rd party database, including any RDBMS or NoSQL store.
+## Distributed Messaging
 
-[Read More](https://apacheignite-cpp.readme.io/docs/data-grid)
+[Distributed messaging](https://apacheignite-net.readme.io/docs/topic-based) allows for topic based cluster-wide communication between all nodes. Messages with a specified message topic can be distributed to
+all or sub-group of nodes that have subscribed to that topic.
 
-#### What is durable memory?
-Ignite *durable memory* architecture allows Ignite to extend in-memory computing to disk. It is based on a paged-based off-heap memory allocator which becomes durable by persisting to the *write-ahead-log (WAL)* and, then, to main Ignite persistent storage. When persistence is disabled, durable memory acts like a pure in-memory storage.
+GridGain messaging is based on publish-subscribe paradigm where publishers and subscribers are connected together by a common topic.
+When one of the nodes sends a message A for topic T, it is published on all nodes that have subscribed to T.
 
-[Read More](https://apacheignite-cpp.readme.io/docs/durable-memory)
+## Distributed Events
 
-#### What is collocated processing?
-Ignite is a distributed system and, therefore, it is important to be able to collocate data with data and compute with data to avoid distributed data noise. Data collocation becomes especially important when performing distributed SQL joins. Ignite also supports sending user logic (functions, lambdas, etc.) directly to the nodes where the data resides and computing on the data locally.
+[Distributed events](https://apacheignite-net.readme.io/docs/local-and-remote-events) allow applications to receive notifications when a variety of events occur in the distributed grid environment.
+You can automatically get notified for task executions, read, write or query operations occurring on local or remote nodes within the cluster.
 
-[Read More](https://apacheignite.readme.io/docs/collocate-compute-and-data)
+## ASP.NET Integration
 
+GridGain.NET provides [Output Cache](https://apacheignite-net.readme.io/docs/aspnet-output-caching) and [Session State](https://apacheignite-net.readme.io/docs/aspnet-session-state-caching) clustering: boost performance by storing cache and session data in GridGain distributed cache.
 
-## Ignite On Other Platforms
+## Entity Framework Integration
 
-<a href="https://github.com/apache/ignite">Java</a>
+GridGain.NET [Entity Framework Second Level Cache](https://apacheignite-net.readme.io/docs/entity-framework-second-level-cache) improves Entity Framework performance by storing query results in GridGain caches.
 
-<a href="https://github.com/apache/ignite/tree/master/modules/platforms/dotnet">Ignite.Net</a>
 
 
 [apache-ignite-homepage]: https://ignite.apache.org/
-[getting-started]: https://apacheignite-cpp.readme.io/docs/getting-started-1
-[docs]: https://apacheignite-cpp.readme.io/docs
\ No newline at end of file
+[GridGain-homepage]: https://www.gridgain.com/
+[getting-started]: https://docs.gridgain.com/docs
+[docs]: https://docs.gridgain.com/docs
diff --git a/modules/platforms/cpp/README.txt b/modules/platforms/cpp/README.txt
index a0a35d4..c3cae85 100644
--- a/modules/platforms/cpp/README.txt
+++ b/modules/platforms/cpp/README.txt
@@ -1,11 +1,11 @@
-Apache Ignite C++
+GridGain C++
 ==================================
 
-Apache Ignite C++ provides data grid functionality.
-Using Apache Ignite C++ APIs you can perform concurrent operations on
+GridGain C++ provides data grid functionality.
+Using GridGain C++ APIs you can perform concurrent operations on
 the data stored in cache.
 
-Apache Ignite C++ can access cluster and share data with .Net and
+GridGain C++ can access cluster and share data with .Net and
 Java applications using binary object format.
 
 Support for the following will be added in next releases:
@@ -28,23 +28,23 @@ Linux info
 
 Files list:
 
- * ignite - executable to start standalone Ignite C++ node.
- * libignite.so - Ignite C++ API library.
- * libignite-odbc.so - Ignite ODBC driver.
- * libignite-thin-client.so - Ignite C++ thin client library.
+ * ignite - executable to start standalone GridGain C++ node.
+ * libignite.so - GridGain C++ API library.
+ * libignite-odbc.so - GridGain ODBC driver.
+ * libignite-thin-client.so - GridGain C++ thin client library.
  
 Development:
 
- * IGNITE_HOME environment variable must be set to Ignite installation directory.
+ * IGNITE_HOME environment variable must be set to GridGain installation directory.
  * Once both libraries are built and installed, required headers are placed in the
    "/usr/local/include/ignite" directory.
- * Apache Ignite C++ depends on jni.h file located inside ${JAVA_HOME}/include directory.
+ * GridGain C++ depends on jni.h file located inside ${JAVA_HOME}/include directory.
    Add this directory to headers search path: "-I${JAVA_HOME}/include".
  * Library is placed in the "/usr/local/lib" directory. Link it to your project: "-lignite".
- * Ignite depends on "libjvm.so" library shipped with Java. Typically this library is
+ * GridGain depends on "libjvm.so" library shipped with Java. Typically this library is
    located inside $JAVA_HOME/jre/lib/amd64/server directory. Ensure that LD_LIBRARY_PATH
    environment variable points to this directory.
- * To start Apache Ignite as a standalone node use "ignite" binary.
+ * To start GridGain as a standalone node use "ignite" binary.
 
  
 Windows info
@@ -52,14 +52,14 @@ Windows info
 
 Files list:
 
- * ignite.exe - executable to start standalone Ignite C++ node.
- * ignite.core.dll - Ignite C++ API library.
- * ignite.odbc.dll - Ignite ODBC driver.
- * ignite.thin-client.dll - Ignite thin C++ client.
+ * ignite.exe - executable to start standalone GridGain C++ node.
+ * ignite.core.dll - GridGain C++ API library.
+ * ignite.odbc.dll - GridGain ODBC driver.
+ * ignite.thin-client.dll - GridGain thin C++ client.
  
 Development:
 
- * IGNITE_HOME environment variable must be set to Ignite installation directory.
+ * IGNITE_HOME environment variable must be set to GridGain installation directory.
  * Update Include Directories in Project Properties with paths to:
    * $(IGNITE_HOME)\platforms\cpp\common\include
    * $(IGNITE_HOME)\platforms\cpp\common\os\win\include
@@ -82,4 +82,4 @@ Development:
    ignite.thin-client.dll libraries. The easiest way to achieve this is to either make
    sure these files are in %PATH%, or to put them into the output directory of your
    project with help of PostBuild events.
- * To start Apache Ignite as a standalone node or Windows service use ignite.exe
+ * To start GridGain as a standalone node or Windows service use ignite.exe
diff --git a/modules/platforms/cpp/examples/README.txt b/modules/platforms/cpp/examples/README.txt
index 823f12d..dcf6d60 100644
--- a/modules/platforms/cpp/examples/README.txt
+++ b/modules/platforms/cpp/examples/README.txt
@@ -1,16 +1,16 @@
-Apache Ignite C++ Examples
+GridGain C++ Examples
 ==================================
 
 Common requirements
 ----------------------------------
  * Java Development Kit (JDK) must be installed: https://java.com/en/download/index.jsp
  * JAVA_HOME environment variable must be set pointing to Java installation directory.
- * IGNITE_HOME environment variable must be set to Ignite installation directory.
- * Ignite must be built and packaged using Maven. You can use the following Maven command: mvn clean package -DskipTests
- * Apache Ignite C++ must be built according to instructions for your platform. Refer to
+ * IGNITE_HOME environment variable must be set to GridGain installation directory.
+ * GridGain must be built and packaged using Maven. You can use the following Maven command: mvn clean package -DskipTests
+ * GridGain C++ must be built according to instructions for your platform. Refer to
    $IGNITE_HOME/platforms/cpp/DEVNOTES.txt for instructions.
  * For odbc-example additionally ODBC Driver Manager must be present and installed on your platform and
-   Apache Ignite ODBC driver must be built and installed according to instructions for your platform. Refer to
+   GridGain ODBC driver must be built and installed according to instructions for your platform. Refer to
    $IGNITE_HOME/platforms/cpp/DEVNOTES.txt for build instructions and to $IGNITE_HOME/platforms/cpp/odbc/README.txt.
    for installation instructions.
 
@@ -31,8 +31,8 @@ Before running examples ensure that:
  * LD_LIBRARY_PATH environment variable is set and pointing to a directory with "libjvm.so" library. Typically this
    library is located in $JAVA_HOME/jre/lib/amd64/server directory.
  * For odbc-example additionaly ODBC Driver Manager must be present and installed on your platform and
-   Apache Ignite ODBC driver must be built and installed according to instructions for your platform.
- * For odbc-example make sure that path to Ignite libraries is added to LD_LIBRARY_PATH (usually it is /usr/local/lib).
+   GridGain ODBC driver must be built and installed according to instructions for your platform.
+ * For odbc-example make sure that path to GridGain libraries is added to LD_LIBRARY_PATH (usually it is /usr/local/lib).
 
 Running examples on Windows
 ----------------------------------
diff --git a/modules/platforms/cpp/odbc/README.txt b/modules/platforms/cpp/odbc/README.txt
index 3a83f84..981f62c 100644
--- a/modules/platforms/cpp/odbc/README.txt
+++ b/modules/platforms/cpp/odbc/README.txt
@@ -1,20 +1,20 @@
-Apache Ignite ODBC driver
+GridGain ODBC driver
 =======================================
 
-Apache Ignite provides ODBC driver that can be used to retrieve distributed 
+GridGain provides ODBC driver that can be used to retrieve distributed
 data from cache using standard SQL queries and native ODBC API.
 
 For more info on ODBC please refer to ODBC Programmer's Reference at
 https://msdn.microsoft.com/en-us/library/ms714177.aspx
 
-To use Apache Ignite ODBC driver you first need to build and install it for
+To use GridGain ODBC driver you first need to build and install it for
 your system. You can find driver installation instructions below. For build
 instruction please refer to $IGNITE_HOME/platforms/cpp/DEVNOTES.txt.
 
 Connection string and DSN arguments
 =======================================
 
-Apache Ignite ODBC driver supports and uses following connection string/DSN
+GridGain ODBC driver supports and uses following connection string/DSN
 arguments:
 
 1. Address of the node to connect to:
@@ -33,11 +33,11 @@ Installing ODBC driver on Linux
 =======================================
 
 To be able to build and install ODBC driver on Linux you first need to install
-ODBC Driver Manager. Apache Ignite ODBC driver has been tested with UnixODBC
+ODBC Driver Manager. GridGain ODBC driver has been tested with UnixODBC
 (http://www.unixodbc.org). 
 
-Once you have built and installed Ignite ODBC Driver i.e. libignite-odbc.so it
-is most likely placed to /usr/local/lib. To install and be able to use Ignite
+Once you have built and installed GridGain ODBC Driver i.e. libignite-odbc.so it
+is most likely placed to /usr/local/lib. To install and be able to use GridGain
 ODBC driver you should perfrom the following steps:
 
 1. Ensure linker is able to locate all dependencies of the ODBC driver. You
@@ -51,7 +51,7 @@ ODBC driver you should perfrom the following steps:
    and ensure that "Driver" parameter of the "Apache Ignite" section points
    to the right location where libignite-odbc.so is located.
 
-3. To install Apache Ignite ODBC driver use the following command:
+3. To install GridGain ODBC driver use the following command:
    $ odbcinst -i -d -f $IGNITE_HOME/platforms/cpp/odbc/install/ignite-odbc-install.ini
    To perform this command you most likely will need root privileges.
 
@@ -92,7 +92,7 @@ Thats it. Your driver/drivers are installed.
 After the installation
 =======================================
 
-Now Apache Ignite ODBC driver is installed and ready for use. You can connect
+Now GridGain ODBC driver is installed and ready for use. You can connect
 to it and use it like to any other ODBC driver.
 
 For further instruction on the usage of the ODBC driver please refer to the
diff --git a/modules/platforms/dotnet/README.md b/modules/platforms/dotnet/README.md
index 4830940..5b60cc5 100644
--- a/modules/platforms/dotnet/README.md
+++ b/modules/platforms/dotnet/README.md
@@ -1,6 +1,6 @@
-# Apache Ignite.NET SDK
+# GridGain.NET SDK
 
-<a href="https://ignite.apache.org/"><img src="https://ignite.apache.org/images/logo3.png" hspace="20"/></a><img src="https://ptupitsyn.github.io/images/net-framework.png" hspace="20" />
+<a href="https://www.gridgain.com/"><img src="https://www.gridgain.com/themes/gridgain1185/images/svg/gridgain-logo.svg?20180912" hspace="10"  width="300px"/></a><br/><br/>
 
 <a href="https://www.nuget.org/packages?q=Apache.Ignite"><img src="https://img.shields.io/nuget/v/Apache.Ignite.svg" /></a>
 
@@ -10,35 +10,45 @@
 
 ## Getting Started
 
-For information on how to get started with Apache Ignite, please visit: [Getting Started][getting-started].
+For information on how to get started with GridGain, please visit: [Getting Started][getting-started].
 
-## Full Documentation
 
-You can find the full Apache Ignite documentation here: [Full documentation][docs].
+## What is GridGain?
 
-## What is Apache Ignite?
-
-[Apache Ignite][apache-ignite-homepage] is a memory-centric multi-model distributed
- <strong>database</strong>, <strong>caching</strong>, and <strong>processing</strong> platform for
- transactional, analytical, and streaming workloads, delivering in-memory speeds at petabyte scale.
+GridGain, built on top of Apache Ignite, is a memory-centric distributed **database**, **caching**,
+ and **processing** platform for transactional, analytical, and streaming workloads delivering in-memory
+ speeds at petabyte scale.
 
 <p align="center">
-    <a href="https://apacheignite-net.readme.io/docs/">
-        <img src="https://ignite.apache.org/images/durable-memory.png" width="900px"/>
+    <a href="https://www.gridgain.com/">
+        <img src="https://files.readme.io/58b7901-gg_platform.png" width="600px"/>
     </a>
 </p>
 
-## Durable Memory
-Ignite's durable memory component treats RAM not just as a caching layer but as a complete fully functional storage layer. This means that users can turn the persistence on and off as needed. If the persistence is off, then Ignite can act as a distributed **in-memory database** or **in-memory data grid**, depending on whether you prefer to use SQL or key-value APIs. If the persistence is turned on, then Ignite becomes a distributed, **horizontally scalable database** that guarantees full [...]
+## Memory-Centric Storage
+GridGain is based on distributed memory-centric architecture that combines the performance and scale of in-memory
+computing together with the disk durability and strong consistency in one system.
 
-[Read More](https://apacheignite-net.readme.io/docs/durable-memory)
+The main difference between the memory-centric approach and the traditional disk-centric approach is that the memory
+is treated as a fully functional storage, not just as a caching layer, like most databases do.
+For example, GridGain can function in a pure in-memory mode, in which case it can be treated as an
+In-Memory Database (IMDB) and In-Memory Data Grid (IMDG) in one.
 
-## Ignite Persistence
+On the other hand, when persistence is turned on, GidGain begins to function as a memory-centric system where most of
+the processing happens in memory, but the data and indexes get persisted to disk. The main difference here
+from the traditional disk-centric RDBMS or NoSQL system is that GridGain is strongly consistent, horizontally
+[Read More](https://apacheignite-net.readme.io/docs/durable-memory)
 
-Ignite Native Persistence is a distributed, ACID, and SQL-compliant **disk store** that transparently integrates with Ignite's Durable Memory as an optional disk layer storing data and indexes on SSD, Flash, 3D XPoint, and other types of non-volatile storages.
+## Native Persistence
 
-With the Ignite Persistence enabled, you no longer need to keep all the data and indexes in memory or warm it up after a node or cluster restart because the Durable Memory is tightly coupled with persistence and treats it as a secondary memory tier. This implies that if a subset of data or an index is missing in RAM, the Durable Memory will take it from the disk.
+Native Persistence is a distributed, ACID, and SQL-compliant **disk store** that transparently integrates with
+GridGain memory-centric storage as an optional disk layer storing data and indexes on SSD,
+ Flash, 3D XPoint, and other types of non-volatile storages.
 
+With the Native Persistence enabled, you no longer need to keep all the data and indexes in memory or warm it
+up after a node or cluster restart because the Durable Memory is tightly coupled with persistence and treats
+it as a secondary memory tier. This implies that if a subset of data or an index is missing in RAM,
+the Durable Memory will take it from the disk.
 <p align="center">
     <a href="https://apacheignite.readme.io/docs/distributed-persistent-store">
         <img src="https://ignite.apache.org/images/native_persistence.png?renew" width="400px"/>
@@ -48,43 +58,43 @@ With the Ignite Persistence enabled, you no longer need to keep all the data and
 [Read More](https://apacheignite-net.readme.io/docs/ignite-persistent-store)
 
 ## ACID Compliance
-Data stored in Ignite is ACID-compliant both in memory and on disk, making Ignite a **strongly consistent** system. Ignite transactions work across the network and can span multiple servers.
+Data stored in GridGain is ACID-compliant both in memory and on disk, making GridGain a **strongly consistent** system. GridGain transactions work across the network and can span multiple servers.
 
 [Read More](https://apacheignite-net.readme.io/docs/transactions)
 
 ## Complete SQL Support
-Ignite provides full support for SQL, DDL and DML, allowing users to interact with Ignite using pure SQL without writing any code. This means that users can create tables and indexes as well as insert, update, and query data using only SQL. Having such complete SQL support makes Ignite a one-of-a-kind **distributed SQL database**.
+GridGain provides full support for SQL, DDL and DML, allowing users to interact with GridGain using pure SQL without writing any code. This means that users can create tables and indexes as well as insert, update, and query data using only SQL. Having such complete SQL support makes GridGain a one-of-a-kind **distributed SQL database**.
 
 [Read More](https://apacheignite-net.readme.io/docs/sql-database)
 
 ## Key-Value
-The in-memory data grid component in Ignite is a fully transactional **distributed key-value store** that can scale horizontally across 100s of servers in the cluster. When persistence is enabled, Ignite can also store more data than fits in memory and survive full cluster restarts.
+The in-memory data grid component in GridGain is a fully transactional **distributed key-value store** that can scale horizontally across 100s of servers in the cluster. When persistence is enabled, GridGain can also store more data than fits in memory and survive full cluster restarts.
 
 [Read More](https://apacheignite-net.readme.io/docs/data-grid)
 
 ## Collocated Processing
-Most traditional databases work in a client-server fashion, meaning that data must be brought to the client side for processing. This approach requires lots of data movement from servers to clients and generally does not scale. Ignite, on the other hand, allows for sending light-weight computations to the data, i.e. **collocating** computations with data. As a result, Ignite scales better and minimizes data movement.
+Most traditional databases work in a client-server fashion, meaning that data must be brought to the client side for processing. This approach requires lots of data movement from servers to clients and generally does not scale. GridGain, on the other hand, allows for sending light-weight computations to the data, i.e. **collocating** computations with data. As a result, GridGain scales better and minimizes data movement.
 
 [Read More](https://apacheignite-net.readme.io/docs/colocate-compute-and-data)
 
 ## Scalability and Durability
-Ignite is an elastic, horizontally scalable distributed system that supports adding and removing cluster nodes on demand. Ignite also allows for storing multiple copies of the data, making it resilient to partial cluster failures. If the persistence is enabled, then data stored in Ignite will also survive full cluster failures. Cluster restarts in Ignite can be very fast, as the data becomes operational instantaneously directly from disk. As a result, the data does not need to be preload [...]
+GridGain is an elastic, horizontally scalable distributed system that supports adding and removing cluster nodes on demand. GridGain also allows for storing multiple copies of the data, making it resilient to partial cluster failures. If the persistence is enabled, then data stored in GridGain will also survive full cluster failures. Cluster restarts in GridGain can be very fast, as the data becomes operational instantaneously directly from disk. As a result, the data does not need to be [...]
 
 [Read More](https://apacheignite-net.readme.io/docs/cluster)
 
-## Ignite and Ignite.NET
+## GridGain and GridGain.NET
 
-* Ignite.NET is built on top of Ignite.
+* GridGain.NET is built on top of GridGain.
 * .NET starts the JVM in the same process and communicates with it via JNI.
 * .NET, C++ and Java nodes can join the same cluster, use the same caches, and interoperate using common binary protocol.
 * Java compute jobs can execute on any node (Java, .NET, C++).
 * .NET compute jobs can only execute on .NET nodes.
 
-Ignite.NET also has Thin Client mode (see `Ignition.StartClient()`), which does not start JVM and does not require Java on machine.
+GridGain.NET also has Thin Client mode (see `Ignition.StartClient()`), which does not start JVM and does not require Java on machine.
 
-## Ignite Components
+## GridGain Components
 
-You can view Apache Ignite as a collection of independent, well-integrated components geared to improve performance and
+You can view GridGain as a collection of independent, well-integrated components geared to improve performance and
  scalability of your application.
 
 Some of these components include:
@@ -98,8 +108,8 @@ Below you’ll find a brief explanation for each of them:
 
 ## Advanced Clustering
 
-Ignite nodes can [automatically discover](https://apacheignite-net.readme.io/docs/cluster) each other. This helps to scale the cluster when needed, without having to restart the whole cluster.
-Developers can also leverage Ignite’s hybrid cloud support that allows establishing connection between private cloud and public clouds
+GridGain nodes can [automatically discover](https://apacheignite-net.readme.io/docs/cluster) each other. This helps to scale the cluster when needed, without having to restart the whole cluster.
+Developers can also leverage GridGain’s hybrid cloud support that allows establishing connection between private cloud and public clouds
 such as Amazon Web Services, providing them with best of both worlds.
 
 <p align="center">
@@ -111,14 +121,14 @@ such as Amazon Web Services, providing them with best of both worlds.
 
 ## Data Grid (Cache)
 
-[Ignite data grid](https://apacheignite-net.readme.io/docs/data-grid) is an in-memory distributed key-value store which can be viewed as a distributed partitioned `Dictionary`, with every cluster node
+[GridGain data grid](https://apacheignite-net.readme.io/docs/data-grid) is an in-memory distributed key-value store which can be viewed as a distributed partitioned `Dictionary`, with every cluster node
 owning a portion of the overall data. This way the more cluster nodes we add, the more data we can cache.
 
-Unlike other key-value stores, Ignite determines data locality using a pluggable hashing algorithm. Every client can determine which node a key
+Unlike other key-value stores, GridGain determines data locality using a pluggable hashing algorithm. Every client can determine which node a key
 belongs to by plugging it into a hashing function, without a need for any special mapping servers or name nodes.
 
-Ignite data grid supports local, replicated, and partitioned data sets and allows to freely cross query between these data sets using standard SQL and LINQ syntax.
-Ignite supports standard SQL and LINQ for querying in-memory data including support for distributed joins.
+GridGain data grid supports local, replicated, and partitioned data sets and allows to freely cross query between these data sets using standard SQL and LINQ syntax.
+GridGain supports standard SQL and LINQ for querying in-memory data including support for distributed joins.
 
 <p align="center">
     <a href="https://apacheignite-net.readme.io/docs/data-grid">
@@ -128,16 +138,16 @@ Ignite supports standard SQL and LINQ for querying in-memory data including supp
 
 ## SQL Database
 
-Apache Ignite incorporates [distributed SQL database](https://apacheignite-net.readme.io/docs/sql-database) capabilities as a part of its platform. The database is horizontally
+GridGain incorporates [distributed SQL database](https://apacheignite-net.readme.io/docs/sql-database) capabilities as a part of its platform. The database is horizontally
  scalable, fault tolerant and SQL ANSI-99 compliant. It supports all SQL, DDL, and DML commands including SELECT, UPDATE,
   INSERT, MERGE, and DELETE queries. It also provides support for a subset of DDL commands relevant for distributed
   databases.
 
-With Ignite Durable Memory architecture, data as well as indexes can be stored both in memory and, optionally, on disk.
+With GridGain Durable Memory architecture, data as well as indexes can be stored both in memory and, optionally, on disk.
 This allows executing distributed SQL operations across different memory layers achieving in-memory performance with the durability of disk.
 
-You can interact with Apache Ignite using the SQL language via natively developed APIs for Java, .NET and C++, or via
-the Ignite JDBC or ODBC drivers. This provides a true cross-platform connectivity from languages such as PHP, Ruby and more.
+You can interact with GridGain using the SQL language via natively developed APIs for Java, .NET and C++, or via
+the GridGain JDBC or ODBC drivers. This provides a true cross-platform connectivity from languages such as PHP, Ruby and more.
 
 
 <p align="center">
@@ -149,7 +159,7 @@ the Ignite JDBC or ODBC drivers. This provides a true cross-platform connectivit
 ## Compute Grid
 
 [Distributed computations](https://apacheignite-net.readme.io/docs/compute-grid) are performed in parallel fashion to gain high performance, low latency, and linear scalability.
-Ignite compute grid provides a set of simple APIs that allow users distribute computations and data processing across multiple computers in the cluster.
+GridGain compute grid provides a set of simple APIs that allow users distribute computations and data processing across multiple computers in the cluster.
 Distributed parallel processing is based on the ability to take any computation and execute it on any set of cluster nodes and return the results back.
 
 <p align="center">
@@ -169,7 +179,7 @@ We support these features, amongst others:
 
 [Service Grid](https://apacheignite-net.readme.io/docs/service-grid) allows for deployments of arbitrary user-defined services on the cluster. You can implement and deploy any service, such as custom counters, ID generators, hierarchical maps, etc.
 
-Ignite allows you to control how many instances of your service should be deployed on each cluster node and will automatically ensure proper deployment and fault tolerance of all the services.
+GridGain allows you to control how many instances of your service should be deployed on each cluster node and will automatically ensure proper deployment and fault tolerance of all the services.
 
 <p align="center">
     <a href="https://apacheignite-net.readme.io/docs/service-grid">
@@ -179,14 +189,14 @@ Ignite allows you to control how many instances of your service should be deploy
 
 ## Distributed Data Structures
 
-Ignite.NET supports complex [data structures](https://apacheignite-net.readme.io/docs/atomic-types) in a distributed fashion: `AtomicLong`, `AtomicReference`, `AtomicSequence`.
+GridGain.NET supports complex [data structures](https://apacheignite-net.readme.io/docs/atomic-types) in a distributed fashion: `AtomicLong`, `AtomicReference`, `AtomicSequence`.
 
 ## Distributed Messaging
 
 [Distributed messaging](https://apacheignite-net.readme.io/docs/topic-based) allows for topic based cluster-wide communication between all nodes. Messages with a specified message topic can be distributed to
 all or sub-group of nodes that have subscribed to that topic.
 
-Ignite messaging is based on publish-subscribe paradigm where publishers and subscribers are connected together by a common topic.
+GridGain messaging is based on publish-subscribe paradigm where publishers and subscribers are connected together by a common topic.
 When one of the nodes sends a message A for topic T, it is published on all nodes that have subscribed to T.
 
 ## Distributed Events
@@ -196,74 +206,15 @@ You can automatically get notified for task executions, read, write or query ope
 
 ## ASP.NET Integration
 
-Ignite.NET provides [Output Cache](https://apacheignite-net.readme.io/docs/aspnet-output-caching) and [Session State](https://apacheignite-net.readme.io/docs/aspnet-session-state-caching) clustering: boost performance by storing cache and session data in Ignite distributed cache. 
+GridGain.NET provides [Output Cache](https://apacheignite-net.readme.io/docs/aspnet-output-caching) and [Session State](https://apacheignite-net.readme.io/docs/aspnet-session-state-caching) clustering: boost performance by storing cache and session data in GridGain distributed cache.
 
 ## Entity Framework Integration
 
-Ignite.NET [Entity Framework Second Level Cache](https://apacheignite-net.readme.io/docs/entity-framework-second-level-cache) improves Entity Framework performance by storing query results in Ignite caches. 
-
-## Ignite Facts
-
-#### Is Ignite a persistent or pure in-memory storage?
-**Both**. Native persistence in Ignite can be turned on and off. This allows Ignite to store data sets bigger than can fit in the available memory. Essentially, the smaller operational data sets can be stored in-memory only, and larger data sets that do not fit in memory can be stored on disk, using memory as a caching layer for better performance.
-
-[Read More](https://apacheignite-net.readme.io/docs/ignite-persistent-store)
-
-#### Is Ignite a distributed database?
-**Yes**. Data in Ignite is either *partitioned* or *replicated* across a cluster of multiple nodes. This provides scalability and adds resilience to the system. Ignite automatically controls how data is partitioned, however, users can plug in their own distribution (affinity) functions and collocate various pieces of data together for efficiency.
-
-[Read More](https://apacheignite-net.readme.io/docs/sql-database) 
-
-#### Is Ignite a relational SQL database?
-**Not fully**. Although Ignite aims to behave like any other relational SQL database, there are differences in how Ignite handles constraints and indexes. Ignite supports *primary* and *secondary* indexes, however, the *uniqueness* can only be enforced for the *primary* indexes. Ignite also does not support *foreign key* constraints. 
-
-Essentially, Ignite purposely does not support any constraints that would entail a cluster broadcast message for each update and significantly hurt performance and scalability of the system.
-
-[Read More](https://apacheignite-net.readme.io/docs/sql-database) 
-
-#### Is Ignite an in-memory database?
-**Yes**. Even though Ignite *durable memory* works well in-memory and on-disk, the disk persistence can be disabled and Ignite can act as a pure *in-memory database*.
-
-[Read More](https://apacheignite-net.readme.io/docs/sql-database) 
-
-#### Is Ignite a transactional database?
-**Not fully**. ACID Transactions are supported, but only at *key-value* API level. Ignite also supports *cross-partition* transactions, which means that transactions can span keys residing in different partitions on different servers.
+GridGain.NET [Entity Framework Second Level Cache](https://apacheignite-net.readme.io/docs/entity-framework-second-level-cache) improves Entity Framework performance by storing query results in GridGain caches.
 
-At *SQL* level Ignite supports *atomic*, but not yet *transactional* consistency. Ignite community plans to implement SQL transactions in version 2.4.
-
-[Read More](https://apacheignite-net.readme.io/docs/sql-database) 
-
-#### Is Ignite a key-value store?
-**Yes**. Ignite provides a feature rich key-value API, that is JCache (JSR-107) compliant and supports Java, C++, and .NET.
-
-[Read More](https://apacheignite-net.readme.io/docs/data-grid) 
-
-#### Is Ignite an in-memory data grid?
-**Yes**. Ignite is a full-featured data grid, which can be used either in pure in-memory mode or with Ignite native persistence. It can also integrate with any 3rd party database, including any RDBMS or NoSQL store.
-
-[Read More](https://apacheignite-net.readme.io/docs/data-grid) 
-
-#### What is durable memory?
-Ignite *durable memory* architecture allows Ignite to extend in-memory computing to disk. It is based on a paged-based off-heap memory allocator which becomes durable by persisting to the *write-ahead-log (WAL)* and, then, to main Ignite persistent storage. When persistence is disabled, durable memory acts like a pure in-memory storage.
-
-[Read More](https://apacheignite-net.readme.io/docs/durable-memory) 
-
-#### What is collocated processing?
-Ignite is a distributed system and, therefore, it is important to be able to collocate data with data and compute with data to avoid distributed data noise. Data collocation becomes especially important when performing distributed SQL joins. Ignite also supports sending user logic (functions, lambdas, etc.) directly to the nodes where the data resides and computing on the data locally.
-
-[Read More](https://apacheignite-net.readme.io/docs/colocate-compute-and-data) 
 
 
 [apache-ignite-homepage]: https://ignite.apache.org/
-[getting-started]: https://apacheignite-net.readme.io/docs/getting-started-2
-[docs]: https://apacheignite-net.readme.io/docs
-
-## Contribute to Ignite.NET
-
-See [Ignite.NET Development](https://cwiki.apache.org/confluence/display/IGNITE/Ignite.NET+Development) on wiki.
-
-## Ignite On Other Platforms
-
-<a href="https://github.com/apache/ignite">Java</a>
-
-<a href="https://github.com/apache/ignite/tree/master/modules/platforms/cpp">Ignite C++</a>
\ No newline at end of file
+[GridGain-homepage]: https://www.gridgain.com/
+[getting-started]: https://docs.gridgain.com/docs
+[docs]: https://docs.gridgain.com/docs
diff --git a/modules/platforms/dotnet/README.txt b/modules/platforms/dotnet/README.txt
index 7521dfe..730bf48 100644
--- a/modules/platforms/dotnet/README.txt
+++ b/modules/platforms/dotnet/README.txt
@@ -1,21 +1,21 @@
-Apache Ignite.NET
+GridGain.NET
 ==================================
 
-Apache Ignite.NET provides a full featured .NET data grid and .NET compute grid functionality.
-Using Apache Ignite.NET APIs you can execute any computation closure on the grid,
+GridGain.NET provides a full featured .NET data grid and .NET compute grid functionality.
+Using GridGain.NET APIs you can execute any computation closure on the grid,
 perform concurrent operations on the data stored in cache, start ACID transactions,
 create distributed locks, subscribe for event listeners, etc.
 
 Files list:
 
- * Apache.Ignite.exe - executable to start standalone Ignite.NET node.
+ * Apache.Ignite.exe - executable to start standalone GridGain.NET node.
  * Apache.Ignite.exe.config - standalone node configuration file.
- * Apache.Ignite.Core.dll - Ignite.NET API library.
+ * Apache.Ignite.Core.dll - GridGain.NET API library.
  * Apache.Ignite.Core.xml - Library XML documentation.
- * Apache.Ignite.Linq.dll - Ignite LINQ Provider library.
- * Apache.Ignite.AspNet.dll - Ignite ASP.NET integration.
- * Apache.Ignite.NLog.dll - Ignite NLog logger.
- * Apache.Ignite.Log4Net.dll - Ignite Log4Net logger.
+ * Apache.Ignite.Linq.dll - GridGain LINQ Provider library.
+ * Apache.Ignite.AspNet.dll - GridGain ASP.NET integration.
+ * Apache.Ignite.NLog.dll - GridGain NLog logger.
+ * Apache.Ignite.Log4Net.dll - GridGain Log4Net logger.
  * IgniteConfigurationSection.xsd - Configuration XML schema.
 
 
@@ -32,7 +32,7 @@ Development
  
  * Add Apache.Ignite.Core.dll to your project references.
 
- * To start Apache Ignite as a standalone node or Windows service use Apache.Ignite.exe.
+ * To start GridGain as a standalone node or Windows service use Apache.Ignite.exe.
 
 Links
 
diff --git a/modules/platforms/dotnet/docfx/README.txt b/modules/platforms/dotnet/docfx/README.txt
index 4698356..fdfcab9 100644
--- a/modules/platforms/dotnet/docfx/README.txt
+++ b/modules/platforms/dotnet/docfx/README.txt
@@ -1,2 +1,2 @@
-Apache Ignite.NET DocFX Project
+GridGain.NET DocFX Project
 See https://dotnet.github.io/docfx/ for more details.
\ No newline at end of file
diff --git a/modules/platforms/dotnet/examples/README.txt b/modules/platforms/dotnet/examples/README.txt
index db38a35..2c73dae 100644
--- a/modules/platforms/dotnet/examples/README.txt
+++ b/modules/platforms/dotnet/examples/README.txt
@@ -1,4 +1,4 @@
-Apache Ignite.NET Examples
+GridGain.NET Examples
 ==================================
 
 Windows-only. See dotnetcore folder for cross-platform .NET-core based examples.
diff --git a/modules/platforms/dotnet/examples/dotnetcore/README.txt b/modules/platforms/dotnet/examples/dotnetcore/README.txt
index 26c6c1f..5690e1a 100644
--- a/modules/platforms/dotnet/examples/dotnetcore/README.txt
+++ b/modules/platforms/dotnet/examples/dotnetcore/README.txt
@@ -1,4 +1,4 @@
-Apache Ignite.NET Examples for .NET Core
+GridGain.NET Examples for .NET Core
 ========================================
 
 Cross-platform examples, run on Windows, Linux, macOS.
diff --git a/modules/platforms/nodejs/README.md b/modules/platforms/nodejs/README.md
index 4792caa..f3ef6ed 100644
--- a/modules/platforms/nodejs/README.md
+++ b/modules/platforms/nodejs/README.md
@@ -1,4 +1,4 @@
-# NodeJS Client for Apache Ignite #
+# NodeJS Client for GridGain #
 
 ## Installation ##
 
@@ -29,4 +29,4 @@ npm link
 npm link apache-ignite-client #linking examples (optional)
 ```
 
-For more information, see [Apache Ignite Node.JS Thin Client documentation](https://apacheignite.readme.io/docs/nodejs-thin-client).
+For more information, see [GridGain Node.JS Thin Client documentation](https://apacheignite.readme.io/docs/nodejs-thin-client).
\ No newline at end of file
diff --git a/modules/platforms/php/README.md b/modules/platforms/php/README.md
index d6cd51d..b8e9610 100644
--- a/modules/platforms/php/README.md
+++ b/modules/platforms/php/README.md
@@ -1,4 +1,4 @@
-# PHP Thin Client #
+# PHP Thin Client for GridGain #
 
 ## Installation ##
 
@@ -34,4 +34,4 @@ To use the client in your application, include `vendor/autoload.php` file, gener
 require_once "<local_ignite_path>/vendor/autoload.php";
 ```
 
-For more information, see [Apache Ignite PHP Thin Client documentation](https://apacheignite.readme.io/docs/php-thin-client).
+For more information, see [GridGain PHP Thin Client documentation](https://apacheignite.readme.io/docs/php-thin-client).
\ No newline at end of file
diff --git a/modules/platforms/python/LICENSE b/modules/platforms/python/LICENSE
index d645695..4f2f7db 100644
--- a/modules/platforms/python/LICENSE
+++ b/modules/platforms/python/LICENSE
@@ -1,202 +1,13 @@
+Copyright 2019 GridGain Systems, Inc. and Contributors.
 
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
+Licensed under the GridGain Community Edition License (the "License");
+you may not use this file except in compliance with the License.
+You may obtain a copy of the License at
 
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+    https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
 
-   1. Definitions.
-
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-
-   END OF TERMS AND CONDITIONS
-
-   APPENDIX: How to apply the Apache License to your work.
-
-      To apply the Apache License to your work, attach the following
-      boilerplate notice, with the fields enclosed by brackets "[]"
-      replaced with your own identifying information. (Don't include
-      the brackets!)  The text should be enclosed in the appropriate
-      comment syntax for the file format. We also recommend that a
-      file or class name and description of purpose be included on the
-      same "printed page" as the copyright notice for easier
-      identification within third-party archives.
-
-   Copyright [yyyy] [name of copyright owner]
-
-   Licensed under the Apache License, Version 2.0 (the "License");
-   you may not use this file except in compliance with the License.
-   You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing, software
-   distributed under the License is distributed on an "AS IS" BASIS,
-   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-   See the License for the specific language governing permissions and
-   limitations under the License.
+Unless required by applicable law or agreed to in writing, software
+distributed under the License is distributed on an "AS IS" BASIS,
+WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+See the License for the specific language governing permissions and
+limitations under the License.
\ No newline at end of file
diff --git a/modules/rest-http/README.txt b/modules/rest-http/README.txt
index 0df2cf5..3e6b3b2 100644
--- a/modules/rest-http/README.txt
+++ b/modules/rest-http/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite REST-HTTP Module
+GridGain REST-HTTP Module
 ------------------------------
 
-Apache Ignite REST-HTTP module provides Jetty-based server which can be used to execute tasks and/or cache commands
+GridGain REST-HTTP module provides Jetty-based server which can be used to execute tasks and/or cache commands
 in grid using REST approach via HTTP protocol.
 
 To enable REST-HTTP module when starting a standalone node, move 'optional/ignite-rest-http' folder to
@@ -12,7 +12,7 @@ Importing REST-HTTP Module In Maven Project
 -------------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add REST-HTTP module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -23,7 +23,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-rest-http</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/rocketmq/README.txt b/modules/rocketmq/README.txt
index 55a117b..d130dd9 100644
--- a/modules/rocketmq/README.txt
+++ b/modules/rocketmq/README.txt
@@ -1,9 +1,9 @@
-Apache Ignite RocketMQ Streamer Module
+GridGain RocketMQ Streamer Module
 --------------------------------------
 
-Apache Ignite RocketMQ Streamer module provides streaming from RocketMQ to Ignite cache.
+GridGain RocketMQ Streamer module provides streaming from RocketMQ to GridGain cache.
 
-To use Ignite RocketMQ Streamer module, first import it to your Maven project.
+To use GridGain RocketMQ Streamer module, first import it to your Maven project.
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
     xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
@@ -13,7 +13,7 @@ To use Ignite RocketMQ Streamer module, first import it to your Maven project.
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-rocketmq</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/scalar-2.10/README.txt b/modules/scalar-2.10/README.txt
index 535a193..f0092a6 100644
--- a/modules/scalar-2.10/README.txt
+++ b/modules/scalar-2.10/README.txt
@@ -1,4 +1,4 @@
-Apache Ignite Scalar Module
+GridGain Scalar Module
 ---------------------------
 
-Apache Ignite Scalar module to be build with Scala 2.10.
+GridGain Scalar module to be build with Scala 2.10.
diff --git a/modules/scalar/README.txt b/modules/scalar/README.txt
index 38c5879..1ecaa3f 100644
--- a/modules/scalar/README.txt
+++ b/modules/scalar/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite Scalar Module
+GridGain Scalar Module
 ---------------------------
 
-Apache Ignite Scalar module provides Scala-based DSL with extensions and shortcuts for Apache Ignite API.
+GridGain Scalar module provides Scala-based DSL with extensions and shortcuts for GridGain API.
 
 To enable Scalar module when starting a standalone node, move 'optional/ignite-scalar' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -11,7 +11,7 @@ Importing Scalar Module In Maven Project
 ----------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Scalar module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -22,7 +22,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-scalar</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/schedule/README.txt b/modules/schedule/README.txt
index 27490c4..b05dbe2 100644
--- a/modules/schedule/README.txt
+++ b/modules/schedule/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite Schedule Module
+GridGain Schedule Module
 -----------------------------
 
-Apache Ignite Schedule module provides functionality for scheduling jobs locally using UNIX cron-based syntax.
+GridGain Schedule module provides functionality for scheduling jobs locally using UNIX cron-based syntax.
 
 To enable Schedule module when starting a standalone node, move 'optional/ignite-schedule' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -11,7 +11,7 @@ Importing Schedule Module In Maven Project
 ------------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Schedule module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -22,7 +22,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-schedule</artifactId>
             <version>${ignite.version}</version>
         </dependency>
@@ -35,13 +35,13 @@ interested in):
 LGPL dependencies
 -----------------
 
-Ignite includes the following optional LGPL dependencies:
+GridGain includes the following optional LGPL dependencies:
  - Hibernate L2 Cache Integration, http://hibernate.org/orm/
  - JTS Topology Suite for Geospatial indexing, http://tsusiatsoftware.net/jts/main.html
  - cron4j for cron-based task scheduling, http://www.sauronsoftware.it/projects/cron4j
 
-Apache binary releases cannot include LGPL dependencies. If you would like include
+GridGain binary releases cannot include LGPL dependencies. If you would like include
 optional LGPL dependencies into your release, you should download the source release
-from Ignite website and do the build with the following maven command:
+from GridGain website and do the build with the following maven command:
 
 mvn clean package -DskipTests -Prelease,lgpl
diff --git a/modules/slf4j/README.txt b/modules/slf4j/README.txt
index 2583ce3..d44dcf5 100644
--- a/modules/slf4j/README.txt
+++ b/modules/slf4j/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite SLF4J Module
+GridGain SLF4J Module
 --------------------------
 
-Apache Ignite SLF4J module provides GridLogger implementation based on SLF4J.
+GridGain SLF4J module provides GridLogger implementation based on SLF4J.
 
 To enable SLF4J module when starting a standalone node, move 'optional/ignite-slf4j' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -11,7 +11,7 @@ Importing SLF4J Module In Maven Project
 ---------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add SLF4J module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -22,7 +22,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-slf4j</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/spark/README.txt b/modules/spark/README.txt
index 589a050..a612837 100644
--- a/modules/spark/README.txt
+++ b/modules/spark/README.txt
@@ -1,8 +1,8 @@
-Apache Ignite Spark Module
+GridGain Spark Module
 ---------------------------
 
-Apache Ignite provides an implementation of Spark RDD abstraction which enables easy access to Ignite caches.
-Ignite RDD does not keep it's state in the memory of the Spark application and provides a view of the corresponding
-Ignite cache. Depending on the chosen deployment mode this state may exist only during the lifespan of the Spark
+GridGain provides an implementation of Spark RDD abstraction which enables easy access to GridGain caches.
+GridGain RDD does not keep it's state in the memory of the Spark application and provides a view of the corresponding
+GridGain cache. Depending on the chosen deployment mode this state may exist only during the lifespan of the Spark
 application (embedded mode) or may exist outside of the Spark application (standalone mode), allowing seamless
 sharing of the state between multiple Spark jobs.
\ No newline at end of file
diff --git a/modules/spring-data-2.0/README.txt b/modules/spring-data-2.0/README.txt
index f74d97a..fbc81d3 100644
--- a/modules/spring-data-2.0/README.txt
+++ b/modules/spring-data-2.0/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite Spring Module
+GridGain Spring Module
 ---------------------------
 
-Apache Ignite Spring Data 2.0 module provides an integration with Spring Data 2.0 framework.
+GridGain Spring Data 2.0 module provides an integration with Spring Data 2.0 framework.
 
 To enable Spring Data 2.0 module when starting a standalone node, move 'optional/ignite-spring-data' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -11,7 +11,7 @@ Importing Spring Data 2.0 Module In Maven Project
 ----------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Spring module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -22,7 +22,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-spring-data_2.0</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/spring-data/README.txt b/modules/spring-data/README.txt
index d957fb6..5c8c179 100644
--- a/modules/spring-data/README.txt
+++ b/modules/spring-data/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite Spring Module
+GridGain Spring Module
 ---------------------------
 
-Apache Ignite Spring Data module provides an integration with Spring Data framework.
+GridGain Spring Data module provides an integration with Spring Data framework.
 
 To enable Spring Data module when starting a standalone node, move 'optional/ignite-spring-data' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -22,7 +22,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-spring-data</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/spring/README.txt b/modules/spring/README.txt
index 24718b7..1cff1d3 100644
--- a/modules/spring/README.txt
+++ b/modules/spring/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite Spring Module
+GridGain Spring Module
 ---------------------------
 
-Apache Ignite Spring module provides resources injection capabilities and parser for Spring-based
+GridGain Spring module provides resources injection capabilities and parser for Spring-based
 configuration XML files.
 
 To enable Spring module when starting a standalone node, move 'optional/ignite-spring' folder to
@@ -12,7 +12,7 @@ Importing Spring Module In Maven Project
 ----------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Spring module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -23,7 +23,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-spring</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/ssh/README.txt b/modules/ssh/README.txt
index a0876e7..c069740 100644
--- a/modules/ssh/README.txt
+++ b/modules/ssh/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite SSH Module
+GridGain SSH Module
 ------------------------
 
-Apache Ignite SSH module provides capabilities to start Apache Ignite nodes on remote machines via SSH.
+GridGain SSH module provides capabilities to start GridGain nodes on remote machines via SSH.
 
 To enable SSH module when starting a standalone node, move 'optional/ignite-ssh' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -11,7 +11,7 @@ Importing SSH Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add SSH module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -22,7 +22,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-ssh</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/storm/README.txt b/modules/storm/README.txt
index 684fdb5..567b11d 100644
--- a/modules/storm/README.txt
+++ b/modules/storm/README.txt
@@ -1,14 +1,14 @@
-Apache Ignite Storm Streamer Module
+GridGain Storm Streamer Module
 -----------------------------------
 
-Apache Ignite Storm Streamer module provides streaming via Storm to Ignite cache.
+GridGain Storm Streamer module provides streaming via Storm to GridGain cache.
 
-Starting data transfer to Ignite cache can be done with the following steps.
+Starting data transfer to GridGain cache can be done with the following steps.
 
-1. Import Ignite Storm Streamer Module In Maven Project
+1. Import GridGain Storm Streamer Module In Maven Project
 
 If you are using Maven to manage dependencies of your project, you can add Storm module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -19,7 +19,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-storm</artifactId>
             <version>${ignite.version}</version>
         </dependency>
@@ -28,7 +28,7 @@ interested in):
     ...
 </project>
 
-2. Create an Ignite configuration file (see example-ignite.xml) and make sure it is accessible from the streamer.
+2. Create an GridGain configuration file (see example-ignite.xml) and make sure it is accessible from the streamer.
 
 3. Make sure your key-value data input to the streamer is specified with the field named "ignite"
 (or a different one you configure with StormStreamer.setIgniteTupleField(...)).
diff --git a/modules/tensorflow/README.txt b/modules/tensorflow/README.txt
index 21ea88d..08fc397 100644
--- a/modules/tensorflow/README.txt
+++ b/modules/tensorflow/README.txt
@@ -1,14 +1,14 @@
-Apache Ignite TensorFlow Integration Module
+GridGain TensorFlow Integration Module
 ------------------------
 
-Apache Ignite TensorFlow Integration Module allowed using TensorFlow with Apache Ignite. In this scenario Apache Ignite
+GridGain TensorFlow Integration Module allowed using TensorFlow with GridGain. In this scenario GridGain
 will be a datasource for any TensorFlow model training.
 
-Import Apache Ignite TensorFlow Integration Module In Maven Project
+Import GridGain TensorFlow Integration Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add TensorFlow module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -19,7 +19,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-tensorflow</artifactId>
             <version>${ignite.version}</version>
         </dependency>
@@ -30,13 +30,13 @@ interested in):
 -------------------------------------
 
 TensorFlow integration module provides command line tool that allows to start, maintain and stop distributed deep
-learning utilizing Apache Ignite infrastructure and data. This tool provides several commands that are shown here:
+learning utilizing GridGain infrastructure and data. This tool provides several commands that are shown here:
 
 Usage: ignite-tf [-hV] [-c=<cfg>] [COMMAND]
-Apache Ignite and TensorFlow integration command line utility that allows to
-start, maintain and stop distributed deep learning utilizing Apache Ignite
+GridGain and TensorFlow integration command line utility that allows to
+start, maintain and stop distributed deep learning utilizing GridGain
 infrastructure and data.
-  -c, --config=<cfg>   Apache Ignite client configuration.
+  -c, --config=<cfg>   GridGain client configuration.
   -h, --help           Show this help message and exit.
   -V, --version        Print version information and exit.
 Commands:
@@ -55,7 +55,7 @@ Starts a new TensorFlow cluster and attaches to user script process.
       JOB_DIR          Job folder (or zip archive).
       JOB_CMD          Job command.
       [JOB_ARGS...]    Job arguments.
-  -c, --config=<cfg>   Apache Ignite client configuration.
+  -c, --config=<cfg>   GridGain client configuration.
   -h, --help           Show this help message and exit.
   -V, --version        Print version information and exit.
 
@@ -65,16 +65,16 @@ commands accepts cluster identifier as a parameter:
 Usage: ignite-tf attach [-hV] [-c=<cfg>] CLUSTER_ID
 Attaches to running TensorFlow cluster (user script process).
       CLUSTER_ID       Cluster identifier.
-  -c, --config=<cfg>   Apache Ignite client configuration.
+  -c, --config=<cfg>   GridGain client configuration.
   -h, --help           Show this help message and exit.
   -V, --version        Print version information and exit.
 
 Usage: ignite-tf stop [-hV] [-c=<cfg>] CLUSTER_ID
 Stops a running TensorFlow cluster.
       CLUSTER_ID       Cluster identifier.
-  -c, --config=<cfg>   Apache Ignite client configuration.
+  -c, --config=<cfg>   GridGain client configuration.
   -h, --help           Show this help message and exit.
   -V, --version        Print version information and exit.
 
-To find out what TensorFlow clusters are currently running on top of Apache Ignite you can use "ps" command that doesn't
+To find out what TensorFlow clusters are currently running on top of GridGain you can use "ps" command that doesn't
 require arguments.
\ No newline at end of file
diff --git a/modules/twitter/README.txt b/modules/twitter/README.txt
index 1c412f9..2838a2a 100644
--- a/modules/twitter/README.txt
+++ b/modules/twitter/README.txt
@@ -1,17 +1,17 @@
-Apache Ignite Twitter Streamer Module
+GridGain Twitter Streamer Module
 ------------------------
 
-Apache Ignite Twitter Streamer module provides streaming from Twitter to Ignite cache.
+GridGain Twitter Streamer module provides streaming from Twitter to GridGain cache.
 
 To enable Twitter Streamer module when starting a standalone node, move 'optional/ignite-twitter' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
-Importing Ignite Twitter Streamer Module In Maven Project
+Importing GridGain Twitter Streamer Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add JCL module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -22,7 +22,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-twitter</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/urideploy/README.txt b/modules/urideploy/README.txt
index dc3defd..4637d1b 100644
--- a/modules/urideploy/README.txt
+++ b/modules/urideploy/README.txt
@@ -1,7 +1,7 @@
-Apache Ignite URI Deploy Module
+GridGain URI Deploy Module
 -------------------------------
 
-Apache Ignite URI Deploy module provides capabilities to deploy tasks from different sources like
+GridGain URI Deploy module provides capabilities to deploy tasks from different sources like
 File System, HTTP, or even Email.
 
 To enable URI Deploy module when starting a standalone node, move 'optional/ignite-urideploy' folder to
@@ -12,7 +12,7 @@ Importing URI Deploy Module In Maven Project
 --------------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add URI Deploy module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -23,7 +23,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-urideploy</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/visor-console-2.10/README.txt b/modules/visor-console-2.10/README.txt
index 1a018b9..d38c9ec 100644
--- a/modules/visor-console-2.10/README.txt
+++ b/modules/visor-console-2.10/README.txt
@@ -1,4 +1,4 @@
-Apache Ignite Visor Console Module
+GridGain Visor Console Module
 ---------------------------
 
-Apache Ignite Visor Console module to be build with Scala 2.10.
+GridGain Visor Console module to be build with Scala 2.10.
diff --git a/modules/web-console/README.txt b/modules/web-console/README.txt
index 286082c..ce0dd6f 100644
--- a/modules/web-console/README.txt
+++ b/modules/web-console/README.txt
@@ -1,9 +1,9 @@
-Ignite Web Console
+GridGain Web Console
 ======================================
-An Interactive Configuration Wizard and Management Tool for Apache Ignite
+An Interactive Configuration Wizard and Management Tool for GridGain
 
-The Apache Ignite Web Console includes an interactive configuration wizard which helps you create and download configuration
- files for your Apache Ignite cluster. The tool also provides management capabilities which allow you to run SQL queries
+The GridGain Web Console includes an interactive configuration wizard which helps you create and download configuration
+ files for your GridGain cluster. The tool also provides management capabilities which allow you to run SQL queries
  on your in-memory cache as well as view execution plans, in-memory schema, and streaming charts.
 
 In order to simplify evaluation of Web Console demo mode was implemented.
@@ -21,7 +21,7 @@ In order to simplify evaluation of Web Console demo mode was implemented.
 
  Demo for SQL.
    How to evaluate:
-    In this mode internal Ignite node will be started. Cache created and populated with data.
+    In this mode internal GridGain node will be started. Cache created and populated with data.
      1) Click "SQL" in Ignite Web Console top menu.
      2) "Demo" notebook with preconfigured queries will be opened.
      3) You can also execute any SQL queries for tables: "Country, Department, Employee, Parking, Car".
diff --git a/modules/web-console/assembly/README.txt b/modules/web-console/assembly/README.txt
index e88e345..88ee192 100644
--- a/modules/web-console/assembly/README.txt
+++ b/modules/web-console/assembly/README.txt
@@ -2,7 +2,7 @@ Requirements
 -------------------------------------
 1. JDK 8 suitable for your platform.
 2. Supported browsers: Chrome, Firefox, Safari, Edge.
-3. Ignite cluster should be started with `ignite-rest-http` module in classpath.
+3. GridGain cluster should be started with `ignite-rest-http` module in classpath.
  For this copy `ignite-rest-http` folder from `libs\optional` to `libs` folder.
 
 How to run
diff --git a/modules/web-console/web-agent/README.txt b/modules/web-console/web-agent/README.txt
index 6b29902..db94bea 100644
--- a/modules/web-console/web-agent/README.txt
+++ b/modules/web-console/web-agent/README.txt
@@ -1,11 +1,11 @@
 Ignite Web Agent
 ======================================
-Ignite Web Agent is a java standalone application that allow to connect Ignite Grid to Ignite Web Console.
+Ignite Web Agent is a java standalone application that allow to connect GridGain Grid to Ignite Web Console.
 Ignite Web Agent communicates with grid nodes via REST interface and connects to Ignite Web Console via web-socket.
 
 Two main functions of Ignite Web Agent:
- 1. Proxy between Ignite Web Console and Ignite Grid to execute SQL statements and collect metrics for monitoring.
-   You may need to specify URI for connect to Ignite REST server via "-n" option.
+ 1. Proxy between Ignite Web Console and GridGain Grid to execute SQL statements and collect metrics for monitoring.
+   You may need to specify URI for connect to GridGain REST server via "-n" option.
 
  2. Proxy between Ignite Web Console and user RDBMS to collect database metadata for later indexed types configuration.
    You may need to copy JDBC driver into "./jdbc-drivers" subfolder or specify path via "-d" option.
@@ -44,9 +44,9 @@ Security tokens:
   3) One may specify several comma-separated list of tokens using configuration file or command line arguments of web agent.
 
 Ignite Web agent requirements:
-  1) In order to communicate with web agent Ignite node should be started with REST server (copy "ignite-rest-http" folder from "libs/optional/" to "libs/").
+  1) In order to communicate with web agent GridGain node should be started with REST server (copy "ignite-rest-http" folder from "libs/optional/" to "libs/").
   2) Configure web agent server-uri property with address where Web Console is running.
-  3) Configure web agent node-uri property with Ignite nodes URI(s).
+  3) Configure web agent node-uri property with GridGain nodes URI(s).
 
 Options:
   -h, --help
@@ -58,7 +58,7 @@ Options:
     Path to folder with JDBC drivers
     Default value: ./jdbc-drivers
   -n, --node-uri
-    Comma-separated list of URIs for connect to Ignite node via REST
+    Comma-separated list of URIs for connect to GridGain node via REST
     Default value: http://localhost:8080
   -nl, --node-login
     User name that will be used to connect to secured cluster
@@ -90,7 +90,7 @@ Options:
      to server and cluster
 
 How to build:
-  To build from sources run following command in Ignite project root folder:
+  To build from sources run following command in GridGain project root folder:
   mvn clean package -pl :ignite-web-agent -am -P web-console -DskipTests=true
 
 Demo of Ignite Web Agent:
@@ -109,7 +109,7 @@ Demo of Ignite Web Agent:
 
    2) Demo for SQL.
      How to evaluate:
-     In this mode internal Ignite node will be started. Cache created and populated with data.
+     In this mode internal GridGain node will be started. Cache created and populated with data.
        2.1) Click "SQL" in Ignite Web Console top menu.
        2.2) "Demo" notebook with preconfigured queries will be opened.
        2.3) You can also execute any SQL queries for tables: "Country, Department, Employee, Parking, Car".
diff --git a/modules/web/README.txt b/modules/web/README.txt
index 68f62b3..bbfe932 100644
--- a/modules/web/README.txt
+++ b/modules/web/README.txt
@@ -1,9 +1,9 @@
-Apache Ignite Web Module
+GridGain Web Module
 ------------------------
 
-Apache Ignite Web module provides Apache Ignite node startups based on servlet and servlet context listener
-which allow to start Apache Ignite inside any web container. Additionally this module provides
-capabilities to cache web sessions in Apache Ignite cache.
+GridGain Web module provides GridGain node startups based on servlet and servlet context listener
+which allow to start GridGain inside any web container. Additionally this module provides
+capabilities to cache web sessions in GridGain cache.
 
 To enable Web module when starting a standalone node, move 'optional/ignite-web' folder to
 'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
@@ -13,7 +13,7 @@ Importing Web Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Web module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -24,7 +24,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-web</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/yardstick/README.txt b/modules/yardstick/README.txt
index 71ed387..e6589b7 100644
--- a/modules/yardstick/README.txt
+++ b/modules/yardstick/README.txt
@@ -1,7 +1,7 @@
-Yardstick Ignite Benchmarks
+Yardstick GridGain Benchmarks
 ===========================
-Apache Ignite benchmarks are written on top of Yardstick Framework (https://github.com/gridgain/yardstick)
-and allow you to measure performance of various Apache Ignite components and modules.
+GridGain benchmarks are written on top of Yardstick Framework (https://github.com/gridgain/yardstick)
+and allow you to measure performance of various GridGain components and modules.
 
 The documentation below describes how to execute and configure already assembled benchmarks. If you need to add new
 benchmarks or build existing one then refer to instruction from `DEVNOTES.txt` in source directory.
@@ -10,7 +10,7 @@ Visit Yardstick Repository (https://github.com/gridgain/yardstick) for detailed
 graphs generation and how the frameworks works.
 
 
-Running Ignite Benchmarks Locally
+Running GridGain Benchmarks Locally
 =================================
 
 The simplest way to start with benchmarking is to use one of the executable scripts available under `benchmarks\bin`
@@ -31,10 +31,10 @@ To get more information about available benchmarks and configuration parameters
 to “Provided Benchmarks” and “Properties And Command Line Arguments” sections below.
 
 
-Running Ignite Benchmarks Remotely
+Running GridGain Benchmarks Remotely
 ==================================
 
-To benchmark Apache Ignite across several remote hosts the following steps need
+To benchmark GridGain across several remote hosts the following steps need
 to be done:
 
 1. Go to `config/ignite-remote-config.xml` and replace
@@ -53,7 +53,7 @@ Replace `localhost` occurrences in the same places in
 `config/benchmark-remote.properties` files if you plan to execute a full set of
 benchmarks available.
 
-3. Upload Ignite Yardstick Benchmarks to one of your DRIVERS host in its own working directory.
+3. Upload GridGain Yardstick Benchmarks to one of your DRIVERS host in its own working directory.
 
 4. Log in on the remote host that will be the DRIVER and execute the following command:
 
@@ -106,8 +106,8 @@ The following benchmarks are provided:
 
 Properties And Command Line Arguments
 =====================================
-Note that this section only describes configuration parameters specific to Ignite benchmarks, and not for Yardstick
-framework. To run Ignite benchmarks and generate graphs, you will need to run them using Yardstick framework scripts in
+Note that this section only describes configuration parameters specific to GridGain benchmarks, and not for Yardstick
+framework. To run GridGain benchmarks and generate graphs, you will need to run them using Yardstick framework scripts in
 `bin` folder.
 
 Refer to Yardstick Documentation (https://github.com/gridgain/yardstick) for common Yardstick properties
@@ -116,7 +116,7 @@ and command line arguments for running Yardstick scripts.
 The following Ignite benchmark properties can be defined in the benchmark configuration:
 
 * `-b <num>` or `--backups <num>` - Number of backups for every key
-* `-cfg <path>` or `--Config <path>` - Path to Ignite configuration file
+* `-cfg <path>` or `--Config <path>` - Path to GridGain configuration file
 * `-cs` or `--cacheStore` - Enable or disable cache store readThrough, writeThrough
 * `-cl` or `--client` - Client flag. Use this flag if you running more than one `DRIVER`, otherwise additional drivers
 would behave like a `servers`.
@@ -128,7 +128,7 @@ would behave like a `servers`.
 * `-rd or --restartdelay` - Restart delay in seconds
 * `-rs or --restartsleep` - Restart sleep in seconds
 * `-rth <host>` or `--restHost <host>` - REST TCP host
-* `-rtp <num>` or `--restPort <num>` - REST TCP port, indicates that a Ignite node is ready to process Ignite Clients
+* `-rtp <num>` or `--restPort <num>` - REST TCP port, indicates that a GridGain node is ready to process GridGain Clients
 * `-ss` or `--syncSend` - Flag indicating whether synchronous send is used in `TcpCommunicationSpi`
 * `-txc <value>` or `--txConcurrency <value>` - Cache transaction concurrency control, either `OPTIMISTIC` or
     `PESSIMISTIC` (defined in `CacheTxConcurrency`)
diff --git a/modules/yarn/README.txt b/modules/yarn/README.txt
index 5cdd4a2..9f8f540 100644
--- a/modules/yarn/README.txt
+++ b/modules/yarn/README.txt
@@ -1,13 +1,13 @@
-Apache Ignite Yarn Module
+GridGain Yarn Module
 ------------------------
 
-Apache Ignite Yarn module provides integration Apache Ignite with Apache Hadoop Yarn.
+GridGain Yarn module provides integration GridGain with Apache Hadoop Yarn.
 
-Importing Apache Ignite Yarn Module In Maven Project
+Importing GridGain Yarn Module In Maven Project
 -------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add Cloud module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -18,7 +18,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-yarn</artifactId>
             <version>${ignite.version}</version>
         </dependency>
diff --git a/modules/zeromq/README.txt b/modules/zeromq/README.txt
index aeb86f8..4393375 100644
--- a/modules/zeromq/README.txt
+++ b/modules/zeromq/README.txt
@@ -1,14 +1,14 @@
-Apache Ignite ZeroMQ Streamer Module
+GridGain ZeroMQ Streamer Module
 ------------------------
 
-Apache Ignite ZeroMQ Streamer module provides streaming from ZeroMQ to Ignite cache.
+GridGain ZeroMQ Streamer module provides streaming from ZeroMQ to GridGain cache.
 
-Starting data transfer to Ignite cache can be done with the following steps.
+Starting data transfer to GridGain cache can be done with the following steps.
 
-1. Import Ignite ZeroMQ Streamer Module In Maven Project
+1. Import GridGain ZeroMQ Streamer Module In Maven Project
 
 If you are using Maven to manage dependencies of your project, you can add ZeroMQ module
-dependency like this (replace '${ignite.version}' with actual Ignite version you are
+dependency like this (replace '${ignite.version}' with actual GridGain version you are
 interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -19,7 +19,7 @@ interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-zeromq</artifactId>
             <version>${ignite.version}</version>
         </dependency>
@@ -28,7 +28,7 @@ interested in):
     ...
 </project>
 
-2. Create an Ignite configuration file (see example-ignite.xml) and make sure it is accessible from the streamer.
+2. Create an GridGain configuration file (see example-ignite.xml) and make sure it is accessible from the streamer.
 
 3. Create your StreamSingleTupleExtractor or StreamMultipleTupleExtractor, an example can be found in the tests folder
 ZeroMqStringSingleTupleExtractor.java. Now it is necessary to add in a streamer
diff --git a/modules/zookeeper/README.txt b/modules/zookeeper/README.txt
index 6d400ad..121ffa2 100644
--- a/modules/zookeeper/README.txt
+++ b/modules/zookeeper/README.txt
@@ -1,14 +1,14 @@
-Apache Ignite ZooKeeper Module
+GridGain ZooKeeper Module
 ------------------------------
 
-Apache Ignite ZooKeeper module provides a TCP Discovery IP Finder that uses a ZooKeeper
-directory to locate other Ignite nodes to connect to.
+GridGain ZooKeeper module provides a TCP Discovery IP Finder that uses a ZooKeeper
+directory to locate other GridGain nodes to connect to.
 
-Importing Apache Ignite ZooKeeper Module In Maven Project
+Importing GridGain ZooKeeper Module In Maven Project
 ---------------------------------------------------------
 
 If you are using Maven to manage dependencies of your project, you can add the ZooKeeper
-module dependency like this (replace '${ignite.version}' with actual Ignite version you
+module dependency like this (replace '${ignite.version}' with actual GridGain version you
 are interested in):
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
@@ -19,7 +19,7 @@ are interested in):
     <dependencies>
         ...
         <dependency>
-            <groupId>org.apache.ignite</groupId>
+            <groupId>org.gridgain</groupId>
             <artifactId>ignite-zookeeper</artifactId>
             <version>${ignite.version}</version>
         </dependency>


[ignite] 09/17: WC-930 Web Console: Use native select for "form-field-dropdown" component.

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 86b691abe457ec53b5f0b62775b12f0a2d3d3dc6
Author: Ilya Borisov <ib...@gridgain.com>
AuthorDate: Wed Apr 24 15:57:32 2019 +0700

    WC-930 Web Console: Use native select for "form-field-dropdown" component.
---
 .../components/queries-notebook/template.tpl.pug   |  6 ++-
 .../modal-import-models/template.tpl.pug           | 11 ++--
 .../cache-edit-form/templates/memory.pug           |  2 +-
 .../cluster-edit-form/templates/collision.pug      |  2 +-
 .../cluster-edit-form/templates/load-balancing.pug |  1 +
 .../cluster-edit-form/templates/memory.pug         |  1 +
 .../igfs-edit-form/templates/general.pug           |  2 +-
 .../components/igfs-edit-form/templates/misc.pug   |  2 +-
 .../components/model-edit-form/templates/query.pug |  4 +-
 .../frontend/app/configuration/services/Models.ts  |  8 +--
 .../frontend/app/configuration/types/index.ts      | 11 +++-
 .../app/primitives/form-field/dropdown.pug         | 60 +++++++++++++++-------
 .../frontend/app/primitives/form-field/index.scss  | 45 +++++++++++-----
 13 files changed, 105 insertions(+), 50 deletions(-)

diff --git a/modules/web-console/frontend/app/components/page-queries/components/queries-notebook/template.tpl.pug b/modules/web-console/frontend/app/components/page-queries/components/queries-notebook/template.tpl.pug
index ea7108b..d5f0276 100644
--- a/modules/web-console/frontend/app/components/page-queries/components/queries-notebook/template.tpl.pug
+++ b/modules/web-console/frontend/app/components/page-queries/components/queries-notebook/template.tpl.pug
@@ -77,7 +77,8 @@ mixin query-settings
                 label: 'Rows per page:',
                 model: 'paragraph.pageSize',
                 name: '"pageSize" + paragraph.id',
-                options: 'pageSizesOptions'
+                options: 'pageSizesOptions',
+                inline: true
             })
 
         .form-field--inline(
@@ -89,7 +90,8 @@ mixin query-settings
                 label: 'Max pages:',
                 model: 'paragraph.maxPages',
                 name: '"maxPages" + paragraph.id',
-                options: 'maxPages'
+                options: 'maxPages',
+                inline: true
             })
 
         .form-field--inline(
diff --git a/modules/web-console/frontend/app/configuration/components/modal-import-models/template.tpl.pug b/modules/web-console/frontend/app/configuration/components/modal-import-models/template.tpl.pug
index 76d6a48..71bb3a8 100644
--- a/modules/web-console/frontend/app/configuration/components/modal-import-models/template.tpl.pug
+++ b/modules/web-console/frontend/app/configuration/components/modal-import-models/template.tpl.pug
@@ -130,16 +130,15 @@ mixin td-ellipses-lbl(w, lbl)
                         .pc-form-grid-col-30
                             +form-field__dropdown({
                                 label: 'Action:',
-                                model: 'importCommon.action'
-                            })(
-                                bs-options='item.value as item.label for item in importActions'
-                            )
+                                model: 'importCommon.action',
+                                options: 'importActions'
+                            })
                         .pc-form-grid-col-30
                             +form-field__dropdown({
                                 label: 'Cache:',
-                                model: 'importCommon.cacheOrTemplate'
+                                model: 'importCommon.cacheOrTemplate',
+                                options: 'importCommon.cachesOrTemplates'
                             })(
-                                bs-options='item.value as item.label for item in importCommon.cachesOrTemplates'
                                 ng-change='$ctrl.onCacheSelect(importCommon.cacheOrTemplate)'
                             )
                         .pc-form-grid-col-60.pc-form-grid__text-only-item
diff --git a/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cache-edit-form/templates/memory.pug b/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cache-edit-form/templates/memory.pug
index a3504e5..657ccb6 100644
--- a/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cache-edit-form/templates/memory.pug
+++ b/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cache-edit-form/templates/memory.pug
@@ -148,7 +148,7 @@ panel-collapsible(ng-form=form on-open=`ui.loadPanel('${form}')`)
                     name: '"offHeapMode"',
                     required: `$ctrl.Caches.offHeapMode.required(${model})`,
                     placeholder: '{{::$ctrl.Caches.offHeapMode.default}}',
-                    options: '{{::$ctrl.Caches.offHeapModes}}',
+                    options: '::$ctrl.Caches.offHeapModes',
                     tip: `Off-heap storage mode
                     <ul>
                         <li>Disabled - Off-heap storage is disabled</li>
diff --git a/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cluster-edit-form/templates/collision.pug b/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cluster-edit-form/templates/collision.pug
index 24d7d3f..457389e 100644
--- a/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cluster-edit-form/templates/collision.pug
+++ b/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cluster-edit-form/templates/collision.pug
@@ -33,7 +33,7 @@ panel-collapsible(ng-form=form on-open=`ui.loadPanel('${form}')`)
                     label:'CollisionSpi:',
                     model: modelCollisionKind,
                     name: '"collisionKind"',
-                    placeholder: 'Choose discovery',
+                    placeholder: 'Choose collision SPI',
                     options: '[\
                         {value: "JobStealing", label: "Job stealing"},\
                         {value: "FifoQueue", label: "FIFO queue"},\
diff --git a/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cluster-edit-form/templates/load-balancing.pug b/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cluster-edit-form/templates/load-balancing.pug
index 8728869..75c17a5 100644
--- a/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cluster-edit-form/templates/load-balancing.pug
+++ b/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cluster-edit-form/templates/load-balancing.pug
@@ -48,6 +48,7 @@ panel-collapsible(ng-form=form on-open=`ui.loadPanel('${form}')`)
                                     model: '$item.kind',
                                     name: '"loadBalancingKind"',
                                     required: true,
+                                    placeholder: 'Choose among the following...',
                                     options: '::$ctrl.Clusters.loadBalancingKinds',
                                     tip: `Provides the next best balanced node for job execution
                                     <ul>
diff --git a/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cluster-edit-form/templates/memory.pug b/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cluster-edit-form/templates/memory.pug
index ca25dd0..f9f69a1 100644
--- a/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cluster-edit-form/templates/memory.pug
+++ b/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/cluster-edit-form/templates/memory.pug
@@ -37,6 +37,7 @@ ng-show='$ctrl.available(["2.0.0", "2.3.0"])'
                     label: 'Page size:',
                     model: `${model}.pageSize`,
                     name: '"MemoryConfigurationPageSize"',
+                    placeholder: 'Choose among the following...',
                     options: `$ctrl.Clusters.memoryConfiguration.pageSize.values`,
                     tip: 'Every memory region is split on pages of fixed size'
                 })
diff --git a/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/igfs-edit-form/templates/general.pug b/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/igfs-edit-form/templates/general.pug
index 0b03e7e..66fd2d8 100644
--- a/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/igfs-edit-form/templates/general.pug
+++ b/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/igfs-edit-form/templates/general.pug
@@ -46,7 +46,7 @@ panel-collapsible(opened=`::true` ng-form=form)
                     model: `${model}.defaultMode`,
                     name: '"defaultMode"',
                     placeholder: '{{::$ctrl.IGFSs.defaultMode.default}}',
-                    options: '{{::$ctrl.IGFSs.defaultMode.values}}',
+                    options: '::$ctrl.IGFSs.defaultMode.values',
                     tip: `
                     Mode to specify how IGFS interacts with Hadoop file system
                     <ul>
diff --git a/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/igfs-edit-form/templates/misc.pug b/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/igfs-edit-form/templates/misc.pug
index 92fe130..3d58f03b 100644
--- a/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/igfs-edit-form/templates/misc.pug
+++ b/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/igfs-edit-form/templates/misc.pug
@@ -191,7 +191,7 @@ panel-collapsible(ng-form=form on-open=`ui.loadPanel('${form}')`)
                                             name: '"mode"',
                                             required: true,
                                             placeholder: 'Choose igfs mode',
-                                            options: '{{::$ctrl.IGFSs.defaultMode.values}}'
+                                            options: '::$ctrl.IGFSs.defaultMode.values'
                                         })(
                                             ng-model-options='{allowInvalid: true}'
                                         )
diff --git a/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/model-edit-form/templates/query.pug b/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/model-edit-form/templates/query.pug
index b1df8db..089865b 100644
--- a/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/model-edit-form/templates/query.pug
+++ b/modules/web-console/frontend/app/configuration/components/page-configure-advanced/components/model-edit-form/templates/query.pug
@@ -264,7 +264,7 @@ panel-collapsible(ng-form=form opened=`!!${model}.queryMetadata`)
                                         model: `queryIndex.inlineSizeType`,
                                         name: '"InlineSizeKind"',
                                         placeholder: '{{::$ctrl.Models.inlineSizeType.default}}',
-                                        options: '{{::$ctrl.Models.inlineSizeTypes}}',
+                                        options: '::$ctrl.Models.inlineSizeTypes',
                                         tip: `Inline size
                                             <ul>
                                                 <li>Auto - Determine inline size automatically</li>
@@ -314,7 +314,7 @@ panel-collapsible(ng-form=form opened=`!!${model}.queryMetadata`)
                                                             placeholder: `{{ ${queryFields}.length > 0 ? 'Choose index field' : 'No fields configured' }}`,
                                                             options: queryFields
                                                         })(
-                                                            bs-options=`queryField.name as queryField.name for queryField in ${queryFields}`
+                                                            ng-options=`queryField.name as queryField.name for queryField in ${queryFields}`
                                                             ng-disabled=`${queryFields}.length === 0`
                                                             ng-model-options='{allowInvalid: true}'
                                                             ignite-unique='queryIndex.fields'
diff --git a/modules/web-console/frontend/app/configuration/services/Models.ts b/modules/web-console/frontend/app/configuration/services/Models.ts
index 76aaa5e..63e6575 100644
--- a/modules/web-console/frontend/app/configuration/services/Models.ts
+++ b/modules/web-console/frontend/app/configuration/services/Models.ts
@@ -16,7 +16,7 @@
 
 import ObjectID from 'bson-objectid';
 import omit from 'lodash/fp/omit';
-import {DomainModel, IndexField, ShortDomainModel, Index, Field, KeyField, ValueField} from '../types';
+import {DomainModel, IndexField, ShortDomainModel, Index, Field, KeyField, ValueField, InlineSizeType} from '../types';
 
 export default class Models {
     static $inject = ['$http'];
@@ -59,10 +59,12 @@ export default class Models {
     ];
 
     inlineSizeType = {
-        _val(queryIndex) {
+        _val(queryIndex: Index): InlineSizeType {
             return (queryIndex.inlineSizeType === null || queryIndex.inlineSizeType === void 0) ? -1 : queryIndex.inlineSizeType;
         },
-        onChange: (queryIndex) => {
+        onChange: (queryIndex?: Index): void => {
+            // Undefined queryIndex did not happen until native selects were introduced
+            if (!queryIndex) return;
             const inlineSizeType = this.inlineSizeType._val(queryIndex);
             switch (inlineSizeType) {
                 case 1:
diff --git a/modules/web-console/frontend/app/configuration/types/index.ts b/modules/web-console/frontend/app/configuration/types/index.ts
index 22e7754..f37cda2 100644
--- a/modules/web-console/frontend/app/configuration/types/index.ts
+++ b/modules/web-console/frontend/app/configuration/types/index.ts
@@ -65,11 +65,20 @@ export interface IndexField {
     name?: string,
     direction?: boolean
 }
+
+export enum InlineSizeType {
+    'AUTO' = -1,
+    'DISABLED' = 0,
+    'CUSTOM' = 1
+}
+
 export interface Index {
     _id: string,
     name: string,
     indexType: IndexTypes,
-    fields: Array<IndexField>
+    fields: Array<IndexField>,
+    inlineSize: number | null,
+    inlineSizeType: InlineSizeType
 }
 
 export interface DomainModel {
diff --git a/modules/web-console/frontend/app/primitives/form-field/dropdown.pug b/modules/web-console/frontend/app/primitives/form-field/dropdown.pug
index d7bb278..a259e15 100644
--- a/modules/web-console/frontend/app/primitives/form-field/dropdown.pug
+++ b/modules/web-console/frontend/app/primitives/form-field/dropdown.pug
@@ -14,32 +14,56 @@
     limitations under the License.
 
 
-mixin form-field__dropdown({ label, model, name, disabled, required, multiple, placeholder, placeholderEmpty, options, optionLabel = 'label', tip, tipOpts, change })
+mixin form-field__dropdown({ label, model, name, disabled, required, multiple, placeholder, placeholderEmpty, options, optionLabel = 'label', tip, tipOpts, inline = false, change })
     -var errLbl = label ? label.substring(0, label.length - 1) : 'Field';
 
     mixin __form-field__input()
-        button.select-toggle(
-            type='button'
-            id=`{{ ${name} }}Input`
-            name=`{{ ${name} }}`
+        if !inline && !multiple
 
-            data-placeholder=placeholderEmpty ? `{{ ${options}.length > 0 ? '${placeholder}' : '${placeholderEmpty}' }}` : placeholder
-            
-            ng-model=model
-            ng-disabled=disabled && `${disabled}`
-            ng-required=required && `${required}`
-            ng-ref='$input'
-            ng-ref-read='ngModel'
+            select(
+                id=`{{ ${name} }}Input`
+                name=`{{ ${name} }}`
 
-            ng-change=change && `${change}`
+                ng-model=model
+                ng-disabled=disabled && `${disabled}`
+                ng-required=required && `${required}`
+                ng-ref='$input'
+                ng-ref-read='ngModel'
+                ng-change=change && `${change}`
 
-            bs-select
-            bs-options=`item.value as item.${optionLabel} for item in ${options}`
+                multiple=multiple ? '' : false
+            )&attributes(attributes.attributes)
+                if !multiple && placeholder
+                    option(value='' hidden) #{placeholderEmpty ? `{{ ${options}.length > 0 ? '${placeholder}' : '${placeholderEmpty}' }}` : placeholder}
+                option(
+                    ng-repeat=`item in ${options} track by item.value`
+                    ng-value='item.value'
+                    ng-bind=`item.${optionLabel}`
+                )
 
-            data-multiple=multiple ? '1' : false
+        else
 
-            tabindex='0'
-        )&attributes(attributes.attributes)
+            button.select-toggle(
+                type='button'
+                id=`{{ ${name} }}Input`
+                name=`{{ ${name} }}`
+
+                data-placeholder=placeholderEmpty ? `{{ ${options}.length > 0 ? '${placeholder}' : '${placeholderEmpty}' }}` : placeholder
+                
+                ng-model=model
+                ng-disabled=disabled && `${disabled}`
+                ng-required=required && `${required}`
+                ng-ref='$input'
+                ng-ref-read='ngModel'
+                ng-change=change && `${change}`
+
+                bs-select
+                bs-options=`item.value as item.${optionLabel} for item in ${options}`
+
+                data-multiple=multiple ? '1' : false
+
+                tabindex='0'
+            )&attributes(attributes.attributes)
 
     .form-field.form-field__dropdown.ignite-form-field(id=`{{ ${name} }}Field`)
         +form-field__label({ label, name, required, disabled })
diff --git a/modules/web-console/frontend/app/primitives/form-field/index.scss b/modules/web-console/frontend/app/primitives/form-field/index.scss
index e4367a9..f068d1d 100644
--- a/modules/web-console/frontend/app/primitives/form-field/index.scss
+++ b/modules/web-console/frontend/app/primitives/form-field/index.scss
@@ -88,16 +88,6 @@
                     &:disabled {
                         opacity: .5;
                     }
-
-
-                    &:focus {
-                        border-color: $ignite-brand-success;
-                        box-shadow: inset 0 1px 3px 0 rgba($ignite-brand-success, .5);
-                    }
-
-                    &:disabled {
-                        opacity: .5;
-                    }
                 }
 
                 & > input[type='number'] {
@@ -219,6 +209,7 @@
         }
 
         & > input,
+        & > select:not([multiple]),
         & > button:not(.btn-ignite) {
             outline: none;
             overflow: visible;
@@ -274,6 +265,10 @@
                 right: 36px;
             }
         }
+        & > select.ng-invalid.ng-touched:not([multiple]) {
+            background-position: calc(100% - 36px) 50%;
+            padding-right: calc(28px + 26px);
+        }
     }
 
     &__control-group {
@@ -375,12 +370,16 @@
                 right: 10px;
             }
         }
+        & > select.ng-invalid.ng-touched:not([multiple]) {
+            background-position: calc(100% - 10px) 50%;
+            padding-right: calc(28px + 26px);
+        }
     }
 
     .form-field__errors {
         position: relative;
         
-        padding: 5px 10px 0px;
+        padding: 5px 10px 0;
 
         color: $ignite-brand-primary;
         font-size: 12px;
@@ -594,14 +593,14 @@
                 border: none;
                 box-shadow: none;
 
-                background: linear-gradient(to right, rgb(0, 103, 185), transparent) 0px 25px / 0px, 
+                background: linear-gradient(to right, rgb(0, 103, 185), transparent) 0 25px / 0px,
                             linear-gradient(to right, rgb(0, 103, 185) 70%, transparent 0%) 0% 0% / 8px 1px repeat-x,
                             0% 0% / 0px, 0% 0% / 4px;
                 background-size: 0, 8px 1px, 0, 0;
                 background-position: 1px 25px;
 
-                padding-left: 0px;
-                padding-right: 0px;
+                padding-left: 0;
+                padding-right: 0;
                 margin-left: 10px;
                 margin-right: 10px;
 
@@ -648,6 +647,24 @@
         > button:not(.btn-ignite) {
             padding-top: 10px;
         }
+        select:not([multiple]) {
+            -webkit-appearance: unset;
+            appearance: unset;
+            background-image: url(data:image/svg+xml;base64,PHN2ZyB2ZXJzaW9uPSIxLjEiIHZpZXdCb3g9IjAgMCA4IDQiIHhtbG5zPSJodHRwOi8vd3d3LnczLm9yZy8yMDAwL3N2ZyI+PHBhdGggZD0ibTAgMGg4bC00IDR6IiBmaWxsPSIjMzkzOTM5Ii8+PC9zdmc+);
+            background-size: 8px 4px;
+            background-repeat: no-repeat;
+            background-position: calc(100% - 10px) 50%;
+            padding-right: 28px;
+        }
+        // "Placeholder" color
+        select.ng-empty {
+            color: rgba(66, 66, 66, 0.5);
+
+            // Resets option color back to normal
+            option {
+                color: #393939;
+            }
+        }
     }
 }
 


[ignite] 13/17: gg-17381 GridCompatibilityJdbcFromCurClientToPrevSrvTest#runJdbcThinTests fails in master fixed

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit a0b683e4c437ec7c68815fc1da326a723725adaa
Author: alapin <la...@gmail.com>
AuthorDate: Thu Apr 25 12:55:15 2019 +0300

    gg-17381 GridCompatibilityJdbcFromCurClientToPrevSrvTest#runJdbcThinTests fails in master fixed
---
 .../internal/processors/odbc/jdbc/JdbcQueryExecuteResult.java       | 6 ++++--
 1 file changed, 4 insertions(+), 2 deletions(-)

diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/odbc/jdbc/JdbcQueryExecuteResult.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/odbc/jdbc/JdbcQueryExecuteResult.java
index 58be2db..73fc29c 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/odbc/jdbc/JdbcQueryExecuteResult.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/odbc/jdbc/JdbcQueryExecuteResult.java
@@ -25,6 +25,8 @@ import org.apache.ignite.internal.sql.optimizer.affinity.PartitionResult;
 import org.apache.ignite.internal.sql.optimizer.affinity.PartitionResultMarshaler;
 import org.apache.ignite.internal.util.typedef.internal.S;
 
+import static org.apache.ignite.internal.processors.odbc.jdbc.JdbcConnectionContext.VER_2_8_0;
+
 /**
  * JDBC query execute result.
  */
@@ -140,7 +142,7 @@ public class JdbcQueryExecuteResult extends JdbcResult {
 
         writer.writeBoolean(partRes != null);
 
-        if (partRes != null)
+        if (ver.compareTo(VER_2_8_0) >= 0 && partRes != null)
             PartitionResultMarshaler.marshal(writer, partRes);
     }
 
@@ -163,7 +165,7 @@ public class JdbcQueryExecuteResult extends JdbcResult {
             updateCnt = reader.readLong();
         }
 
-        if (reader.readBoolean())
+        if (ver.compareTo(VER_2_8_0) >= 0 && reader.readBoolean())
             partRes = PartitionResultMarshaler.unmarshal(reader);
     }
 


[ignite] 08/17: WC-902 Web Console: Re-implemented "Profile" page on Angular.

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit e5673e450bdfb8b1ca38e4bfc74753ff67356dff
Author: Ilya Borisov <ib...@gridgain.com>
AuthorDate: Wed Apr 24 15:37:41 2019 +0700

    WC-902 Web Console: Re-implemented "Profile" page on Angular.
---
 .../e2e/testcafe/components/FormField.js           |   13 +
 .../e2e/testcafe/components/PanelCollapsible.js    |   10 +
 .../e2e/testcafe/fixtures/user-profile/profile.js  |    3 +-
 modules/web-console/e2e/testcafe/package.json      |   12 +-
 .../e2e/testcafe/page-models/pageProfile.js        |   26 +-
 modules/web-console/frontend/.babelrc              |    1 +
 modules/web-console/frontend/.eslintrc             |    3 +-
 .../components/copyToClipboardButton.component.ts  |   64 +
 .../components/form-field/autofocus.directive.ts}  |   19 +-
 .../components/form-field/error.component.ts}      |   29 +-
 .../components/form-field/errorStyles.provider.ts} |   14 +-
 .../components/form-field/errors.component.ts      |   79 +
 .../components/form-field/formField.component.scss |  175 +++
 .../components/form-field/formField.component.ts   |  125 ++
 .../components/form-field/hint.component.ts}       |   28 +-
 .../app-angular/components/form-field/index.ts     |   36 +
 .../passwordVisibilityToggleButton.component.ts    |   62 +
 .../form-field/scrollToFirstInvalid.directive.ts   |   61 +
 .../components/form-field/tooltip.component.ts}    |   45 +-
 .../form-field/validationMessages.provider.ts}     |   23 +-
 .../app-angular/components/igniteIcon.component.ts |   55 +
 .../components/page-profile/component.ts           |  150 ++
 .../components/page-profile/style.scss             |   28 +-
 .../components/page-profile/template.html          |   93 ++
 .../components/panelCollapsible.component.ts       |  152 ++
 .../components/serviceBootstrap.ts}                |   28 +-
 .../web-console/frontend/app-angular/downgrade.ts  |   37 +
 modules/web-console/frontend/app-angular/index.ts  |  116 ++
 .../style.scss => app-angular/states.ts}           |   27 +-
 .../web-console/frontend/app-angular/style.scss    |   66 +
 .../style.scss => app-angular/upgrade.ts}          |   27 +-
 .../web-console/frontend/app/{app.js => app.ts}    |   13 +-
 .../form-field/showValidationError.directive.ts    |    3 +-
 .../app/components/page-profile/controller.js      |   97 --
 .../app/components/page-profile/template.pug       |  161 ---
 .../frontend/app/components/page-signin/run.ts     |    3 +-
 .../components/modal-import-models/component.js    |    2 +-
 .../app/modules/agent/AgentManager.service.js      |    4 +-
 .../getting-started/GettingStarted.provider.js     |    4 +-
 .../frontend/app/modules/user/Auth.service.ts      |    5 +-
 .../user/{User.service.js => User.service.ts}      |   65 +-
 modules/web-console/frontend/app/vendor.js         |    4 +-
 modules/web-console/frontend/index.js              |    4 +-
 modules/web-console/frontend/package-lock.json     | 1507 +++++++++-----------
 modules/web-console/frontend/package.json          |   25 +-
 .../frontend/public/stylesheets/style.scss         |   18 +-
 modules/web-console/frontend/tsconfig.json         |    7 +-
 .../web-console/frontend/webpack/webpack.common.js |    7 +
 48 files changed, 2211 insertions(+), 1325 deletions(-)

diff --git a/modules/web-console/e2e/testcafe/components/FormField.js b/modules/web-console/e2e/testcafe/components/FormField.js
index 3862390..e0170db 100644
--- a/modules/web-console/e2e/testcafe/components/FormField.js
+++ b/modules/web-console/e2e/testcafe/components/FormField.js
@@ -69,6 +69,19 @@ export class FormField {
     }
 }
 
+export class AngularFormField extends FormField {
+    static ROOT_SELECTOR = 'form-field';
+    static LABEL_SELECTOR = 'label';
+    static CONTROL_SELECTOR = '[formcontrolname]';
+    static ERRORS_SELECTOR = 'form-field-errors';
+
+    async selectOption(label) {
+        await t
+            .click(this.control)
+            .click(this.control.find('option').withText(label));
+    }
+}
+
 /**
  * Not really a custom field, use for form fields at login and profile screens, these don't have "ignite" prefix
  */
diff --git a/modules/web-console/e2e/testcafe/components/PanelCollapsible.js b/modules/web-console/e2e/testcafe/components/PanelCollapsible.js
index c8d49e0..4c8e813 100644
--- a/modules/web-console/e2e/testcafe/components/PanelCollapsible.js
+++ b/modules/web-console/e2e/testcafe/components/PanelCollapsible.js
@@ -25,3 +25,13 @@ export class PanelCollapsible {
         });
     }
 }
+
+export class AngularPanelCollapsible {
+    constructor(title) {
+        this._selector = Selector('panel-collapsible-angular>.heading>.title').withText(title).parent('panel-collapsible-angular');
+        this.heading = this._selector.find('.heading');
+        this.body = this._selector.addCustomDOMProperties({
+            isOpened: (el) => el.hasAttribute('open')
+        });
+    }
+}
diff --git a/modules/web-console/e2e/testcafe/fixtures/user-profile/profile.js b/modules/web-console/e2e/testcafe/fixtures/user-profile/profile.js
index b9a67f9..99a0fe3 100644
--- a/modules/web-console/e2e/testcafe/fixtures/user-profile/profile.js
+++ b/modules/web-console/e2e/testcafe/fixtures/user-profile/profile.js
@@ -14,7 +14,6 @@
  * limitations under the License.
  */
 
-import { Selector } from 'testcafe';
 import { dropTestDB, insertTestUser, resolveUrl } from '../../environment/envtools';
 import { createRegularUser } from '../../roles';
 import {pageProfile} from '../../page-models/pageProfile';
@@ -55,5 +54,5 @@ test('Testing user data change', async(t) => {
         .expect(pageProfile.lastName.control.value).eql(lastName)
         .expect(pageProfile.email.control.value).eql(email)
         .expect(pageProfile.company.control.value).eql(company)
-        .expect(pageProfile.country.control.innerText).eql(country);
+        .expect(pageProfile.country.control.value).eql(country);
 });
diff --git a/modules/web-console/e2e/testcafe/package.json b/modules/web-console/e2e/testcafe/package.json
index 6cba09e..c9dc872 100644
--- a/modules/web-console/e2e/testcafe/package.json
+++ b/modules/web-console/e2e/testcafe/package.json
@@ -24,9 +24,9 @@
   ],
   "dependencies": {
     "app-module-path": "2.2.0",
-    "cross-env": "5.1.1",
-    "glob": "7.1.2",
-    "lodash": "4.17.10",
+    "cross-env": "5.2.0",
+    "glob": "7.1.3",
+    "lodash": "4.17.11",
     "minimist": "1.2.0",
     "mongodb": "2.2.33",
     "node-cmd": "3.0.0",
@@ -38,5 +38,11 @@
     "testcafe-reporter-teamcity": "1.0.9",
     "type-detect": "4.0.3",
     "util": "0.10.3"
+  },
+  "devDependencies": {
+    "@typescript-eslint/eslint-plugin": "^1.7.0",
+    "@typescript-eslint/parser": "^1.7.0",
+    "eslint": "^5.16.0",
+    "typescript": "^3.4.5"
   }
 }
diff --git a/modules/web-console/e2e/testcafe/page-models/pageProfile.js b/modules/web-console/e2e/testcafe/page-models/pageProfile.js
index a130218..08f9195 100644
--- a/modules/web-console/e2e/testcafe/page-models/pageProfile.js
+++ b/modules/web-console/e2e/testcafe/page-models/pageProfile.js
@@ -14,26 +14,26 @@
  * limitations under the License.
  */
 
-import {CustomFormField} from '../components/FormField';
-import {PanelCollapsible} from '../components/PanelCollapsible';
+import {AngularFormField} from '../components/FormField';
+import {AngularPanelCollapsible} from '../components/PanelCollapsible';
 import {Selector} from 'testcafe';
 
 export const pageProfile = {
-    firstName: new CustomFormField({id: 'firstNameInput'}),
-    lastName: new CustomFormField({id: 'lastNameInput'}),
-    email: new CustomFormField({id: 'emailInput'}),
-    phone: new CustomFormField({id: 'phoneInput'}),
-    country: new CustomFormField({id: 'countryInput'}),
-    company: new CustomFormField({id: 'companyInput'}),
+    firstName: new AngularFormField({id: 'firstName'}),
+    lastName: new AngularFormField({id: 'lastName'}),
+    email: new AngularFormField({id: 'email'}),
+    phone: new AngularFormField({id: 'phone'}),
+    country: new AngularFormField({id: 'country'}),
+    company: new AngularFormField({id: 'company'}),
     securityToken: {
-        panel: new PanelCollapsible('security token'),
+        panel: new AngularPanelCollapsible('security token'),
         generateTokenButton: Selector('a').withText('Generate Random Security Token?'),
-        value: new CustomFormField({id: 'securityTokenInput'})
+        value: new AngularFormField({id: 'securityToken'})
     },
     password: {
-        panel: new PanelCollapsible('password'),
-        newPassword: new CustomFormField({id: 'passwordInput'}),
-        confirmPassword: new CustomFormField({id: 'passwordConfirmInput'})
+        panel: new AngularPanelCollapsible('password'),
+        newPassword: new AngularFormField({id: 'newPassword'}),
+        confirmPassword: new AngularFormField({id: 'confirmPassword'})
     },
     saveChangesButton: Selector('.btn-ignite.btn-ignite--success').withText('Save Changes')
 };
diff --git a/modules/web-console/frontend/.babelrc b/modules/web-console/frontend/.babelrc
index b68592c..c9d4d00 100644
--- a/modules/web-console/frontend/.babelrc
+++ b/modules/web-console/frontend/.babelrc
@@ -8,6 +8,7 @@
         "@babel/preset-typescript"
     ],
     "plugins": [
+        ["@babel/plugin-proposal-decorators", {"legacy": true}],
         ["@babel/plugin-proposal-class-properties", { "loose" : true }],
         "@babel/plugin-proposal-object-rest-spread",
         "@babel/plugin-syntax-dynamic-import",
diff --git a/modules/web-console/frontend/.eslintrc b/modules/web-console/frontend/.eslintrc
index 0cfc9a2..bd18a20 100644
--- a/modules/web-console/frontend/.eslintrc
+++ b/modules/web-console/frontend/.eslintrc
@@ -70,7 +70,8 @@ rules:
     max-nested-callbacks: [1, 4]
     max-params: [0, 3]
     max-statements: [0, 10]
-    new-cap: 2
+    // This rule conflicts with TS decorators
+    // new-cap: 2
     new-parens: 2
     no-alert: 2
     no-array-constructor: 2
diff --git a/modules/web-console/frontend/app-angular/components/copyToClipboardButton.component.ts b/modules/web-console/frontend/app-angular/components/copyToClipboardButton.component.ts
new file mode 100644
index 0000000..f5f061d
--- /dev/null
+++ b/modules/web-console/frontend/app-angular/components/copyToClipboardButton.component.ts
@@ -0,0 +1,64 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import {Component, Input, Inject} from '@angular/core';
+import {default as IgniteCopyToClipboardFactory} from 'app/services/CopyToClipboard.service';
+
+@Component({
+    selector: 'copy-to-clipboard-button',
+    template: `
+        <button
+            (click)='copy()'
+            [popper]='content'
+            popperApplyClass='ignite-popper,ignite-popper__tooltip'
+            popperTrigger='hover'
+            popperAppendTo='body'
+            type='button'
+        >
+            <ignite-icon name='copy'></ignite-icon>
+        </button>
+        <popper-content #content><ng-content></ng-content></popper-content>
+    `,
+    styles: [`
+        :host {
+            display: inline-flex;
+            align-items: center;
+            justify-content: center;
+        }
+        button {
+            border: none;
+            margin: 0;
+            padding: 0;
+            background: none;
+            display: inline-flex;
+        }
+        button:hover, button:active {
+            color: #0067b9;
+        }
+    `]
+})
+export class CopyToClipboardButton {
+    @Input()
+    value: string;
+
+    private copy() {
+        this.IgniteCopyToClipboard.copy(this.value);
+    }
+
+    static parameters = [[new Inject('IgniteCopyToClipboard')]];
+
+    constructor(private IgniteCopyToClipboard: ReturnType<typeof IgniteCopyToClipboardFactory>) {}
+}
diff --git a/modules/web-console/frontend/app/components/page-profile/style.scss b/modules/web-console/frontend/app-angular/components/form-field/autofocus.directive.ts
similarity index 65%
copy from modules/web-console/frontend/app/components/page-profile/style.scss
copy to modules/web-console/frontend/app-angular/components/form-field/autofocus.directive.ts
index a64c892..41b3883 100644
--- a/modules/web-console/frontend/app/components/page-profile/style.scss
+++ b/modules/web-console/frontend/app-angular/components/form-field/autofocus.directive.ts
@@ -14,20 +14,15 @@
  * limitations under the License.
  */
 
-page-profile {
-    max-width: 800px;
-    display: block;
+import {Directive, AfterViewInit, Inject, ElementRef} from '@angular/core';
 
-    panel-collapsible {
-        width: 100%;
-    }
+@Directive({selector: 'input[autofocus]'})
+export class Autofocus implements AfterViewInit {
+    static parameters = [[new Inject(ElementRef)]];
 
-    footer {
-        display: flex;
-        justify-content: flex-end;
-    }
+    constructor(private el: ElementRef<HTMLInputElement>) {}
 
-    .btn-ignite + .btn-ignite {
-        margin-left: 10px;
+    ngAfterViewInit() {
+        setTimeout(() => this.el.nativeElement.focus(), 0);
     }
 }
diff --git a/modules/web-console/frontend/app/components/page-profile/style.scss b/modules/web-console/frontend/app-angular/components/form-field/error.component.ts
similarity index 50%
copy from modules/web-console/frontend/app/components/page-profile/style.scss
copy to modules/web-console/frontend/app-angular/components/form-field/error.component.ts
index a64c892..0ac55c4 100644
--- a/modules/web-console/frontend/app/components/page-profile/style.scss
+++ b/modules/web-console/frontend/app-angular/components/form-field/error.component.ts
@@ -14,20 +14,25 @@
  * limitations under the License.
  */
 
-page-profile {
-    max-width: 800px;
-    display: block;
+import {Component, Input, ViewChild, Inject, ElementRef, AfterViewInit, TemplateRef} from '@angular/core';
+import {FormField} from './formField.component';
 
-    panel-collapsible {
-        width: 100%;
-    }
+@Component({
+    selector: 'form-field-error',
+    template: `<ng-template #errorTemplate><ng-content></ng-content></ng-template>`
+})
+export class FormFieldError implements AfterViewInit {
+    @Input()
+    error: string;
 
-    footer {
-        display: flex;
-        justify-content: flex-end;
-    }
+    @ViewChild('errorTemplate')
+    template: TemplateRef<any>;
+
+    static parameters = [[new Inject(ElementRef)], [new Inject(FormField)]];
+
+    constructor(private ref: ElementRef, private formField: FormField) {}
 
-    .btn-ignite + .btn-ignite {
-        margin-left: 10px;
+    ngAfterViewInit() {
+        this.formField.addExtraErrorMessage(this.error, this.template);
     }
 }
diff --git a/modules/web-console/frontend/app/components/page-profile/component.js b/modules/web-console/frontend/app-angular/components/form-field/errorStyles.provider.ts
similarity index 79%
rename from modules/web-console/frontend/app/components/page-profile/component.js
rename to modules/web-console/frontend/app-angular/components/form-field/errorStyles.provider.ts
index 07e5784..ce30704 100644
--- a/modules/web-console/frontend/app/components/page-profile/component.js
+++ b/modules/web-console/frontend/app-angular/components/form-field/errorStyles.provider.ts
@@ -14,10 +14,12 @@
  * limitations under the License.
  */
 
-import template from './template.pug';
-import controller from './controller';
+export enum FormFieldRequiredMarkerStyles {
+    OPTIONAL = 'optional',
+    REQUIRED = 'required'
+}
 
-export default {
-    template,
-    controller
-};
+export enum FormFieldErrorStyles {
+    INLINE = 'inline',
+    ICON = 'icon'
+}
diff --git a/modules/web-console/frontend/app-angular/components/form-field/errors.component.ts b/modules/web-console/frontend/app-angular/components/form-field/errors.component.ts
new file mode 100644
index 0000000..4576b3a
--- /dev/null
+++ b/modules/web-console/frontend/app-angular/components/form-field/errors.component.ts
@@ -0,0 +1,79 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import {Component, Input, Inject} from '@angular/core';
+import {FormFieldErrorStyles} from './errorStyles.provider';
+import {VALIDATION_MESSAGES} from './validationMessages.provider';
+
+@Component({
+    selector: 'form-field-errors',
+    template: `
+        <ng-template #validationMessage>
+            <ng-template *ngIf='extraErrorMessages[errorType]' [ngTemplateOutlet]='extraErrorMessages[errorType]'></ng-template>
+            <ng-container *ngIf='!extraErrorMessages[errorType] && defaultMessages[errorType]'>{{defaultMessages[errorType]}}</ng-container>
+            <ng-container *ngIf='!extraErrorMessages[errorType] && !defaultMessages[errorType]'>Value is invalid: {{errorType}}</ng-container>
+        </ng-template>
+        <div *ngIf='errorStyle === "inline"' class='inline'>
+            <ng-container *ngTemplateOutlet='validationMessage'></ng-container>
+        </div>
+        <div *ngIf='errorStyle === "icon"' class='icon'>
+            <popper-content #popper>
+                <ng-container *ngTemplateOutlet='validationMessage'></ng-container>
+            </popper-content>
+            <ignite-icon
+                name='attention'
+                [popper]='popper'
+                popperApplyClass='ignite-popper,ignite-popper__error'
+                popperTrigger='hover'
+                popperPlacement='top'
+                popperAppendTo='body'
+            ></ignite-icon>
+        </div>
+    `,
+    styles: [`
+        :host {
+            display: block;
+        }
+        .inline {
+            padding: 5px 10px 0;
+            color: #ee2b27;
+            font-size: 12px;
+            line-height: 14px;
+        }
+        .icon {
+            color: #ee2b27;
+            width: 100%;
+            height: 100%;
+            display: flex;
+            align-items: center;
+            justify-content: center;
+        }
+    `]
+})
+export class FormFieldErrors<T extends {[errorType: string]: string}> {
+    @Input()
+    errorStyle: FormFieldErrorStyles;
+
+    @Input()
+    extraErrorMessages: T = {} as T;
+
+    @Input()
+    errorType: keyof T;
+
+    static parameters = [[new Inject(VALIDATION_MESSAGES)]];
+
+    constructor(private defaultMessages: VALIDATION_MESSAGES) {}
+}
diff --git a/modules/web-console/frontend/app-angular/components/form-field/formField.component.scss b/modules/web-console/frontend/app-angular/components/form-field/formField.component.scss
new file mode 100644
index 0000000..44ee8f0
--- /dev/null
+++ b/modules/web-console/frontend/app-angular/components/form-field/formField.component.scss
@@ -0,0 +1,175 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+form-field {
+    --required-label-gap: 0.25em;
+    --input-height: 36px;
+    --overlay-item-width: 16px;
+    --overlay-item-gap: 10px;
+
+    &.form-field__icon-error {
+        display: grid;
+        grid-template-areas: 'title title' 'control overlay' 'error-inline error-inline';
+        grid-template-columns: auto min-content;
+
+        .angular-form-field__label {
+            grid-area: title;
+        }
+
+        .angular-form-field__input {
+            grid-column: control / overlay;
+            grid-row: control;
+        }
+    }
+
+    .angular-form-field__input[data-overlay-items-count="1"] {
+        input {
+            padding-right: calc(1 * (var(--overlay-item-width) + var(--overlay-item-gap)) + var(--overlay-item-gap));
+        }
+    }
+
+    .angular-form-field__input[data-overlay-items-count="2"] {
+        input {
+            padding-right: calc(2 * (var(--overlay-item-width) + var(--overlay-item-gap)) + var(--overlay-item-gap));
+        }
+    }
+
+    .input-overlay {
+        grid-area: overlay;
+        display: grid;
+        justify-content: flex-end;
+        grid-auto-columns: var(--overlay-item-width);
+        grid-auto-flow: column;
+        padding-right: var(--overlay-item-gap);
+        grid-gap: var(--overlay-item-gap);
+        z-index: 2;
+        // Fixes z-order in Edge
+        transform: translateZ(1px);
+    }
+
+    input, select {
+        box-sizing: border-box;
+        height: var(input-height);
+        padding: 9px 10px;
+        border: solid 1px #c5c5c5;
+        border-radius: 4px;
+        background-color: #ffffff;
+        color: #393939;
+        font-size: 14px;
+        line-height: 16px;
+        width: 100%;
+
+        &[disabled] {
+            opacity: 0.5;
+        }
+
+        &::placeholder {
+            color: rgba(66, 66, 66, 0.5);
+            text-align: left;
+        }
+    }
+    select {
+        -webkit-appearance: unset;
+        appearance: unset;
+        background-image: url(data:image/svg+xml;base64,PHN2ZyB2ZXJzaW9uPSIxLjEiIHZpZXdCb3g9IjAgMCA4IDQiIHhtbG5zPSJodHRwOi8vd3d3LnczLm9yZy8yMDAwL3N2ZyI+PHBhdGggZD0ibTAgMGg4bC00IDR6IiBmaWxsPSIjMzkzOTM5Ii8+PC9zdmc+);
+        background-size: 8px 4px;
+        background-repeat: no-repeat;
+        background-position: calc(100% - 10px) 50%;
+    }
+    .angular-form-field__label {
+        display: flex;
+    }
+    .angular-form-field__label {
+        margin: 0 0 4px;
+        color: #424242;
+        font-size: 14px;
+        line-height: 1.25;
+        width: 100%;
+
+        &:before {
+            content: ':';
+            order: 2;
+        }
+
+        form-field-tooltip {
+            order: 3;
+            margin-left: var(--required-label-gap);
+            align-self: center;
+        }
+    }
+    &.form-field__optional .angular-form-field__label {
+        &:after {
+            content: '(optional)';
+            color: #757575;
+            order: 1;
+            margin-left: var(--required-label-gap);
+        }
+    }
+    &.form-field__required .angular-form-field__label {
+        &:after {
+            content: '*';
+            color: #ee2b27;
+            order: 4;
+            margin-left: var(--required-label-gap);
+        }
+    }
+
+    &[type='checkbox'] {
+        grid-template-areas: 'control title overlay' 'error-inline error-inline error-inline';
+        grid-template-columns: 12px 1fr auto;
+
+        .angular-form-field__label {
+            margin: 0 0 0 10px;
+
+            &:before {
+                display: none !important;
+            }
+        }
+
+        .angular-form-field__input {
+            grid-area: control;
+
+            &> input[type='checkbox'] {
+                border-radius: 2px;
+
+                background-image: url(/images/checkbox.svg);
+                width: 12px !important;
+                height: 12px !important;
+                -webkit-appearance: none;
+                -moz-appearance: none;
+                appearance: none;
+                background-repeat: no-repeat;
+                background-size: 100%;
+                padding: 0;
+                margin: 0;
+                border: none;
+
+                &:checked {
+                    background-image: url(/images/checkbox-active.svg);
+                }
+
+                &:disabled {
+                    opacity: 0.5;
+                }
+
+                &:focus {
+                    outline: none;
+                    box-shadow: 0 0 0 2px rgba(0, 103, 185, .3);
+                }
+            }
+        }
+    }
+}
diff --git a/modules/web-console/frontend/app-angular/components/form-field/formField.component.ts b/modules/web-console/frontend/app-angular/components/form-field/formField.component.ts
new file mode 100644
index 0000000..7e84220
--- /dev/null
+++ b/modules/web-console/frontend/app-angular/components/form-field/formField.component.ts
@@ -0,0 +1,125 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import {Component, AfterViewInit, Inject, Input, ContentChild, HostBinding, Injectable} from '@angular/core';
+import {FormFieldErrorStyles, FormFieldRequiredMarkerStyles} from './index';
+import {FormFieldHint} from './hint.component';
+import {FormControlName, FormControl} from '@angular/forms';
+import './formField.component.scss';
+
+@Injectable({
+    providedIn: 'root'
+})
+export class FORM_FIELD_OPTIONS {
+    requiredMarkerStyle: FormFieldRequiredMarkerStyles = FormFieldRequiredMarkerStyles.REQUIRED;
+    errorStyle: FormFieldErrorStyles = FormFieldErrorStyles.ICON
+}
+
+@Component({
+    selector: 'form-field',
+    template: `
+        <ng-template #errors>
+            <form-field-errors
+                *ngIf='(control?.dirty || control?.touched) && control?.invalid'
+                [errorStyle]='errorStyle'
+                [errorType]='_getErrorType(control?.control)'
+                [extraErrorMessages]='extraMessages'
+            ></form-field-errors>
+        </ng-template>
+        <div class="angular-form-field__label">
+            <ng-content select="label"></ng-content>
+            <form-field-tooltip *ngIf='hint' [content]='hint.popper'></form-field-tooltip>
+        </div>
+        <div class="angular-form-field__input" [attr.data-overlay-items-count]='overlayEl.childElementCount'>
+            <ng-content></ng-content>
+        </div>
+        <div class="input-overlay" #overlayEl>
+            <ng-container *ngIf='errorStyle === "icon"'>
+                <ng-container *ngTemplateOutlet='errors'></ng-container>
+            </ng-container>
+            <ng-content select='[formFieldOverlay]'></ng-content>
+        </div>
+        <ng-container *ngIf='errorStyle === "inline"'>
+            <ng-container *ngTemplateOutlet='errors'></ng-container>
+        </ng-container>
+    `,
+    styles: [`
+        .angular-form-field__input {
+            position: relative;
+        }
+        .input-overlay {
+            display: grid;
+        }
+    `]
+})
+export class FormField implements AfterViewInit {
+    static parameters = [[new Inject(FORM_FIELD_OPTIONS)]];
+
+    constructor(options: FORM_FIELD_OPTIONS) {
+        this.errorStyle = options.errorStyle;
+        this.requiredMarkerStyle = options.requiredMarkerStyle;
+    }
+
+    @Input()
+    errorStyle: FormFieldErrorStyles;
+
+    @Input()
+    requiredMarkerStyle: FormFieldRequiredMarkerStyles;
+
+    extraMessages = {};
+
+    @ContentChild(FormControlName)
+    control: FormControlName;
+
+    @ContentChild(FormFieldHint)
+    hint: FormFieldHint;
+
+    @HostBinding('class.form-field__required')
+    isRequired: boolean;
+
+    @HostBinding('class.form-field__optional')
+    isOptional: boolean;
+
+    @HostBinding('class.form-field__icon-error')
+    get isIconError() {
+        return this.errorStyle === FormFieldErrorStyles.ICON;
+    }
+
+    @HostBinding('class.form-field__inline-error')
+    get isInlineError() {
+        return this.errorStyle === FormFieldErrorStyles.INLINE;
+    }
+
+    ngAfterViewInit() {
+        // setTimeout fixes ExpressionChangedAfterItHasBeenCheckedError
+        setTimeout(() => {
+            const hasRequired: boolean = this.control && this.control.control && this.control.control.validator && this.control.control.validator({}).required;
+            this.isOptional = this.requiredMarkerStyle === FormFieldRequiredMarkerStyles.OPTIONAL && !hasRequired;
+            this.isRequired = this.requiredMarkerStyle === FormFieldRequiredMarkerStyles.REQUIRED && hasRequired;
+        }, 0);
+    }
+
+    _getErrorType(control: FormControl): string {
+        return control.errors ? Object.entries(control.errors).filter(([key, invalid]) => invalid).map(([key]) => key).pop() : void 0;
+    }
+
+    addExtraErrorMessage(key, message) {
+        this.extraMessages = {
+            ...this.extraMessages,
+            [key]: message
+        };
+    }
+}
diff --git a/modules/web-console/frontend/app/components/page-profile/style.scss b/modules/web-console/frontend/app-angular/components/form-field/hint.component.ts
similarity index 67%
copy from modules/web-console/frontend/app/components/page-profile/style.scss
copy to modules/web-console/frontend/app-angular/components/form-field/hint.component.ts
index a64c892..84eb747 100644
--- a/modules/web-console/frontend/app/components/page-profile/style.scss
+++ b/modules/web-console/frontend/app-angular/components/form-field/hint.component.ts
@@ -14,20 +14,18 @@
  * limitations under the License.
  */
 
-page-profile {
-    max-width: 800px;
-    display: block;
+import {Component, ViewChild} from '@angular/core';
+import {PopperContent} from 'ngx-popper';
 
-    panel-collapsible {
-        width: 100%;
-    }
-
-    footer {
-        display: flex;
-        justify-content: flex-end;
-    }
-
-    .btn-ignite + .btn-ignite {
-        margin-left: 10px;
-    }
+@Component({
+    selector: 'form-field-hint',
+    template: `
+        <popper-content>
+            <ng-content></ng-content>
+        </popper-content>
+    `
+})
+export class FormFieldHint {
+    @ViewChild(PopperContent)
+    popper: PopperContent
 }
diff --git a/modules/web-console/frontend/app-angular/components/form-field/index.ts b/modules/web-console/frontend/app-angular/components/form-field/index.ts
new file mode 100644
index 0000000..50fe9bc
--- /dev/null
+++ b/modules/web-console/frontend/app-angular/components/form-field/index.ts
@@ -0,0 +1,36 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import {FormFieldHint} from './hint.component';
+import {FormFieldError} from './error.component';
+import {FormField, FORM_FIELD_OPTIONS} from './formField.component';
+import {Autofocus} from './autofocus.directive';
+import {FormFieldTooltip} from './tooltip.component';
+import {PasswordVisibilityToggleButton} from './passwordVisibilityToggleButton.component';
+import {ScrollToFirstInvalid} from './scrollToFirstInvalid.directive';
+
+export {
+    FormFieldHint,
+    FormFieldError,
+    FormField, FORM_FIELD_OPTIONS,
+    Autofocus,
+    FormFieldTooltip,
+    PasswordVisibilityToggleButton,
+    ScrollToFirstInvalid
+};
+
+export * from './errorStyles.provider';
+export * from './validationMessages.provider';
diff --git a/modules/web-console/frontend/app-angular/components/form-field/passwordVisibilityToggleButton.component.ts b/modules/web-console/frontend/app-angular/components/form-field/passwordVisibilityToggleButton.component.ts
new file mode 100644
index 0000000..67b6855
--- /dev/null
+++ b/modules/web-console/frontend/app-angular/components/form-field/passwordVisibilityToggleButton.component.ts
@@ -0,0 +1,62 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import {Component, Input} from '@angular/core';
+
+@Component({
+    selector: 'password-visibility-toggle-button-angular',
+    template: `
+        <button
+            type='button'
+            (click)='toggleVisibility()'
+            [popper]='isVisible ? "Hide password" : "Show password"'
+            popperApplyClass='ignite-popper,ignite-popper__tooltip'
+            popperAppendTo='body'
+            popperTrigger='hover'
+            popperPlacement='top'
+        >
+            <ignite-icon [name]='isVisible ? "eyeOpened" : "eyeClosed"'></ignite-icon>
+        </button>
+    `,
+    styles: [`
+        :host {
+            display: inline-flex;
+            align-items: center;
+            justify-content: center;
+        }
+        button {
+            border: none;
+            margin: 0;
+            padding: 0;
+            background: none;
+            display: inline-flex;
+        }
+        button:hover, button:active {
+            color: #0067b9;
+        }
+    `]
+})
+export class PasswordVisibilityToggleButton {
+    @Input()
+    passwordEl: HTMLInputElement;
+
+    isVisible: boolean = false;
+
+    toggleVisibility() {
+        this.isVisible = !this.isVisible;
+        this.passwordEl.setAttribute('type', this.isVisible ? 'text' : 'password');
+    }
+}
diff --git a/modules/web-console/frontend/app-angular/components/form-field/scrollToFirstInvalid.directive.ts b/modules/web-console/frontend/app-angular/components/form-field/scrollToFirstInvalid.directive.ts
new file mode 100644
index 0000000..9762cb2
--- /dev/null
+++ b/modules/web-console/frontend/app-angular/components/form-field/scrollToFirstInvalid.directive.ts
@@ -0,0 +1,61 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import {Directive, HostListener, Input, Inject, ElementRef} from '@angular/core';
+import {NgForm} from '@angular/forms';
+
+@Directive({
+    selector: '[scrollToFirstInvalid]'
+})
+export class ScrollToFirstInvalid {
+    @Input()
+    formGroup: NgForm;
+
+    @HostListener('ngSubmit', ['$event'])
+    onSubmit(e: Event) {
+        if (this.formGroup.invalid) {
+            const invalidEl = this.findFirstInvalid();
+            if (invalidEl) {
+                this.scrollIntoView(invalidEl);
+                invalidEl.focus();
+                invalidEl.blur();
+                invalidEl.focus();
+                setTimeout(() => this.maybeShowValidationErrorPopover(invalidEl), 0);
+            }
+        }
+    }
+
+    private maybeShowValidationErrorPopover(el: HTMLInputElement): void {
+        try {
+            el.closest('form-field').querySelector('form-field-errors ignite-icon').dispatchEvent(new MouseEvent('mouseenter'));
+        }
+        catch (ignored) {
+            // No-op.
+        }
+    }
+
+    private findFirstInvalid(): HTMLInputElement | null {
+        return this.el.nativeElement.querySelector('.ng-invalid:not(panel-collapsible-angular)');
+    }
+
+    private scrollIntoView(el: Element): void {
+        el.scrollIntoView({block: 'center'});
+    }
+
+    static parameters = [[new Inject(ElementRef)]];
+
+    constructor(private el: ElementRef<HTMLFormElement>) {}
+}
diff --git a/modules/web-console/frontend/app/components/page-profile/index.js b/modules/web-console/frontend/app-angular/components/form-field/tooltip.component.ts
similarity index 52%
rename from modules/web-console/frontend/app/components/page-profile/index.js
rename to modules/web-console/frontend/app-angular/components/form-field/tooltip.component.ts
index 2072cfd..23f50ac 100644
--- a/modules/web-console/frontend/app/components/page-profile/index.js
+++ b/modules/web-console/frontend/app-angular/components/form-field/tooltip.component.ts
@@ -14,23 +14,30 @@
  * limitations under the License.
  */
 
-import angular from 'angular';
-import component from './component';
-import './style.scss';
+import {Component, Input} from '@angular/core';
+import {PopperContent} from 'ngx-popper';
 
-export default angular
-    .module('ignite-console.page-profile', [
-        'ignite-console.user'
-    ])
-    .config(['$stateProvider', ($stateProvider) => {
-        // set up the states
-        $stateProvider.state('base.settings.profile', {
-            url: '/profile',
-            component: 'pageProfile',
-            permission: 'profile',
-            tfMetaTags: {
-                title: 'User profile'
-            }
-        });
-    }])
-    .component('pageProfile', component);
+@Component({
+    selector: 'form-field-tooltip',
+    template: `
+        <ignite-icon
+            name='info'
+            [popper]='content'
+            popperApplyClass='ignite-popper,ignite-popper__tooltip'
+            popperTrigger='hover'
+            popperAppendTo='body'
+        ></ignite-icon>
+    `,
+    styles: [`
+        :host {
+            display: inline-flex;
+        }
+        ignite-icon {
+            color: #0067b9;
+        }
+    `]
+})
+export class FormFieldTooltip {
+    @Input()
+    content: PopperContent
+}
diff --git a/modules/web-console/frontend/app/components/page-profile/style.scss b/modules/web-console/frontend/app-angular/components/form-field/validationMessages.provider.ts
similarity index 73%
copy from modules/web-console/frontend/app/components/page-profile/style.scss
copy to modules/web-console/frontend/app-angular/components/form-field/validationMessages.provider.ts
index a64c892..d2a192a 100644
--- a/modules/web-console/frontend/app/components/page-profile/style.scss
+++ b/modules/web-console/frontend/app-angular/components/form-field/validationMessages.provider.ts
@@ -14,20 +14,13 @@
  * limitations under the License.
  */
 
-page-profile {
-    max-width: 800px;
-    display: block;
+import {Injectable} from '@angular/core';
 
-    panel-collapsible {
-        width: 100%;
-    }
-
-    footer {
-        display: flex;
-        justify-content: flex-end;
-    }
-
-    .btn-ignite + .btn-ignite {
-        margin-left: 10px;
-    }
+@Injectable({
+    providedIn: 'root'
+})
+export class VALIDATION_MESSAGES {
+    required = 'Value is required';
+    email = 'Email has invalid format';
+    passwordMatch = 'Passwords do not match';
 }
diff --git a/modules/web-console/frontend/app-angular/components/igniteIcon.component.ts b/modules/web-console/frontend/app-angular/components/igniteIcon.component.ts
new file mode 100644
index 0000000..526bdb6
--- /dev/null
+++ b/modules/web-console/frontend/app-angular/components/igniteIcon.component.ts
@@ -0,0 +1,55 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import {Component, Inject, Input, OnChanges} from '@angular/core';
+import {default as IgniteIconsService} from 'app/components/ignite-icon/service';
+
+@Component({
+    selector: 'ignite-icon',
+    template: `<svg [attr.viewBox]='viewbox'><svg:use [attr.xlink:href]="url" [attr.href]='url'></svg:use></svg>`,
+    styles: [`
+        :host {
+            width: 16px;
+            height: 16px;
+            display: inline-flex;
+        }
+        svg {
+            width: 100%;
+            height: 100%;
+        }
+    `]
+})
+export class IgniteIcon implements OnChanges {
+    @Input()
+    name: string;
+    viewbox: string;
+
+    static parameters = [
+        [new Inject('IgniteIcon')]
+    ];
+
+    constructor(private icons: IgniteIconsService) {}
+
+    get url() {
+        return `${window.location.href}#${this.name}`;
+    }
+
+    ngOnChanges() {
+        const icon = this.icons.getIcon(this.name);
+        if (icon)
+            this.viewbox = icon.viewBox;
+    }
+}
diff --git a/modules/web-console/frontend/app-angular/components/page-profile/component.ts b/modules/web-console/frontend/app-angular/components/page-profile/component.ts
new file mode 100644
index 0000000..a200b52
--- /dev/null
+++ b/modules/web-console/frontend/app-angular/components/page-profile/component.ts
@@ -0,0 +1,150 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import omit from 'lodash/fp/omit';
+import {merge} from 'rxjs';
+import {tap, filter} from 'rxjs/operators';
+import {Component, Inject, OnInit, OnDestroy} from '@angular/core';
+import {FormGroup, FormControl, Validators, FormBuilder} from '@angular/forms';
+import templateUrl from 'file-loader!./template.html';
+import {default as CountriesFactory, Country} from 'app/services/Countries.service';
+import {default as UserFactory, User} from 'app/modules/user/User.service';
+import {Confirm} from 'app/services/Confirm.service';
+import {default as LegacyUtilsFactory} from 'app/services/LegacyUtils.service';
+import {
+    FORM_FIELD_OPTIONS, FormFieldRequiredMarkerStyles, FormFieldErrorStyles
+} from '../form-field';
+import './style.scss';
+
+const passwordMatch = (newPassword: string) => (confirmPassword: FormControl) => newPassword === confirmPassword.value
+    ? null
+    : {passwordMatch: true};
+
+const disableFormGroup = (fg: FormGroup) => {fg.disable(); return fg;};
+
+@Component({
+    selector: 'page-profile',
+    templateUrl,
+    viewProviders: [
+        {
+            provide: FORM_FIELD_OPTIONS,
+            useValue: {
+                requiredMarkerStyle: FormFieldRequiredMarkerStyles.OPTIONAL,
+                errorStyle: FormFieldErrorStyles.ICON
+            }
+        }
+    ]
+})
+export class PageProfile implements OnInit, OnDestroy {
+    static parameters = [
+        [new Inject('IgniteCountries')],
+        [new Inject('User')],
+        [new Inject('Confirm')],
+        [new Inject('IgniteLegacyUtils')],
+        [new Inject(FormBuilder)]
+    ];
+
+    constructor(
+        Countries: ReturnType<typeof CountriesFactory>,
+        private User: ReturnType<typeof UserFactory>,
+        private Confirm: Confirm,
+        private LegacyUtils: ReturnType<typeof LegacyUtilsFactory>,
+        private fb: FormBuilder
+    ) {
+        this.countries = Countries.getAll();
+    }
+
+    countries: Country[];
+    user: User;
+    isLoading: boolean = false;
+
+    async ngOnInit() {
+        this.user = await this.User.read();
+        this.form.patchValue(this.user);
+    }
+
+    ngOnDestroy() {
+        this.subscriber.unsubscribe();
+    }
+
+    async saveUser(): Promise<void> {
+        if (this.form.invalid) return;
+        this.isLoading = true;
+        try {
+            const user = await this.User.save(this.prepareFormValue(this.form));
+            this.form.patchValue(user);
+            this.form.get('passwordPanelOpened').setValue(false);
+        } finally {
+            this.isLoading = false;
+        }
+    }
+
+    prepareFormValue(form: PageProfile['form']): Partial<User> {
+        return {
+            ...omit(['password', 'passwordPanelOpened'])(form.value),
+            token: form.controls.token.value,
+            ...form.value.passwordPanelOpened ? {password: form.value.password.new} : {}
+        };
+    }
+
+    async generateToken() {
+        try {
+            await this.Confirm.confirm('Are you sure you want to change security token?<br>If you change the token you will need to restart the agent.');
+            this.form.get('token').setValue(this.LegacyUtils.randomString(20));
+        }
+        catch (ignored) {
+            // No-op.
+        }
+    }
+
+    form = this.fb.group({
+        firstName: ['', Validators.required],
+        lastName: ['', Validators.required],
+        email: ['', [Validators.required, Validators.email]],
+        phone: '',
+        country: ['', Validators.required],
+        company: ['', Validators.required],
+        password: disableFormGroup(this.fb.group({
+            new: ['', Validators.required],
+            confirm: ''
+        })),
+        tokenPanelOpened: false,
+        passwordPanelOpened: false,
+        token: this.fb.control({value: '', disabled: true}, [Validators.required])
+    });
+
+    subscriber = merge(
+        this.form.get('passwordPanelOpened').valueChanges.pipe(
+            tap((opened: boolean) => {
+                this.form.get('password')[opened ? 'enable' : 'disable']();
+                this.form.get('password').updateValueAndValidity();
+                if (opened) this.form.get('password').reset();
+            })
+        ),
+        this.form.get('password.new').valueChanges.pipe(
+            tap((newPassword: string) => {
+                this.form.get('password.confirm').setValidators([Validators.required, passwordMatch(newPassword)]);
+                this.form.get('password.confirm').updateValueAndValidity();
+            })
+        ),
+        this.form.get('tokenPanelOpened').valueChanges.pipe(
+            filter((opened) => opened === false),
+            tap(async() => {
+                this.form.get('token').reset((await this.User.read()).token);
+            })
+        )
+    ).subscribe();
+}
diff --git a/modules/web-console/frontend/app/components/page-profile/style.scss b/modules/web-console/frontend/app-angular/components/page-profile/style.scss
similarity index 63%
copy from modules/web-console/frontend/app/components/page-profile/style.scss
copy to modules/web-console/frontend/app-angular/components/page-profile/style.scss
index a64c892..c0170f9 100644
--- a/modules/web-console/frontend/app/components/page-profile/style.scss
+++ b/modules/web-console/frontend/app-angular/components/page-profile/style.scss
@@ -15,19 +15,33 @@
  */
 
 page-profile {
-    max-width: 800px;
     display: block;
+    max-width: 800px;
 
-    panel-collapsible {
-        width: 100%;
+    .form-grid {
+        display: grid;
+        grid-template-columns: 1fr 1fr;
+        grid-gap: var(--form-gap);
+
+        .span-1 {
+            grid-column: span 1;
+        }
+        .span-2 {
+            grid-column: span 2;
+        }
     }
 
-    footer {
+    .security-token-generate-button-container {
+        align-items: flex-end;
         display: flex;
-        justify-content: flex-end;
+        padding-bottom: 9px;
     }
 
-    .btn-ignite + .btn-ignite {
-        margin-left: 10px;
+    footer {
+        display: grid;
+        grid-auto-flow: column;
+        grid-auto-columns: max-content;
+        justify-content: flex-end;
+        grid-gap: var(--form-gap);
     }
 }
diff --git a/modules/web-console/frontend/app-angular/components/page-profile/template.html b/modules/web-console/frontend/app-angular/components/page-profile/template.html
new file mode 100644
index 0000000..df8952b
--- /dev/null
+++ b/modules/web-console/frontend/app-angular/components/page-profile/template.html
@@ -0,0 +1,93 @@
+<!--
+ Copyright 2019 GridGain Systems, Inc. and Contributors.
+ 
+ Licensed under the GridGain Community Edition License (the "License");
+ you may not use this file except in compliance with the License.
+ You may obtain a copy of the License at
+ 
+     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ 
+ Unless required by applicable law or agreed to in writing, software
+ distributed under the License is distributed on an "AS IS" BASIS,
+ WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ See the License for the specific language governing permissions and
+ limitations under the License.
+-->
+
+<global-progress-line [isLoading]='isLoading'></global-progress-line>
+<header class="header-with-selector">
+    <div><h1>User profile</h1></div>        
+</header>
+<form [formGroup]='form' (ngSubmit)='saveUser()' id='user' scrollToFirstInvalid class="form-grid">
+    <form-field class='span-1'>
+        <label for='firstName'>First name</label>
+        <input type="text" formControlName='firstName' id='firstName' autofocus>
+    </form-field>
+    <form-field class='span-1'>
+        <label for='lastName'>Last name</label>
+        <input type="text" formControlName='lastName' id='lastName'>
+    </form-field>
+    <form-field class='span-2'>
+        <label for='email'>Email</label>
+        <input type="email" formControlName='email' id='email' autocomplete="username email">
+    </form-field>
+    <form-field class='span-1'>
+        <label for='phone'>Phone</label>
+        <input type="tel" formControlName='phone' id='phone' placeholder='Input phone (ex.: +15417543010)'>
+    </form-field>
+    <form-field class='span-1'>
+        <label for='country'>Country/Region</label>
+        <select formControlName='country' id='country'>
+            <option *ngFor='let country of countries' [value]="country.value">{{country.label}}</option>
+        </select>
+    </form-field>
+    <form-field class='span-2'>
+        <label for='company'>Company</label>
+        <input type="text" formControlName='company' id='company'>
+    </form-field>
+    <panel-collapsible-angular class='span-2' #securityTokenPanel formControlName='tokenPanelOpened'>
+        <span panelTitle>{{ securityTokenPanel.opened ? 'Cancel security token changing...' : 'Show security token...' }}</span>
+        <div class='form-grid'>
+            <form-field class="span-1">
+                <form-field-hint>The security token is used for authentication of Web agent</form-field-hint>
+                <label for="securityToken">Security Token</label>
+                <copy-to-clipboard-button formFieldOverlay [value]='form.controls.token.value'>Copy security token to clipboard</copy-to-clipboard-button>
+                <input
+                    id='securityToken'
+                    type="text"
+                    placeholder='No security token. Please regenerate.'
+                    formControlName='token'
+                >
+            </form-field>
+            <span class="span-1 security-token-generate-button-container">
+                <a (click)='generateToken()'>Generate Random Security Token?</a>
+            </span>
+        </div>
+    </panel-collapsible-angular>
+    <panel-collapsible-angular class='span-2' formControlName='passwordPanelOpened' [formGroup]='form.controls.password'>
+        <span panelTitle>{{ form.value.passwordPanelOpened ? 'Cancel password changing...' : 'Change password...' }}</span>
+        <div class="form-grid" *ngIf='form.value.passwordPanelOpened'>
+            <!-- https://www.chromium.org/developers/design-documents/create-amazing-password-forms -->
+            <!-- https://stackoverflow.com/a/48736294/333777 -->
+            <input type="text" name="email" [value]='form.value.email' autocomplete="username email" style="display: none;">
+            <form-field class='span-2'>
+                <label for="newPassword">New password</label>
+                <password-visibility-toggle-button-angular formFieldOverlay [passwordEl]='passwordEl'></password-visibility-toggle-button-angular>
+                <input type="password" formControlName='new' id='newPassword' #passwordEl autofocus autocomplete="new-password">
+            </form-field>
+            <form-field class='span-2'>
+                <label for="confirmPassword">Confirm password</label>
+                <password-visibility-toggle-button-angular formFieldOverlay [passwordEl]='confirmPasswordEl'></password-visibility-toggle-button-angular>
+                <input type="password" formControlName='confirm' id='confirmPassword' #confirmPasswordEl autocomplete="new-password">
+            </form-field>
+        </div>
+    </panel-collapsible-angular>
+</form>
+<hr>
+<footer>
+    <a class="btn-ignite btn-ignite--link-success" uiSref="default-state">Cancel</a>
+    <button type='submit' class="btn-ignite btn-ignite--success" form='user' [disabled]='isLoading'>
+        <ignite-icon name="checkmark" class='icon-left'></ignite-icon>
+        Save Changes
+    </button>
+</footer>
\ No newline at end of file
diff --git a/modules/web-console/frontend/app-angular/components/panelCollapsible.component.ts b/modules/web-console/frontend/app-angular/components/panelCollapsible.component.ts
new file mode 100644
index 0000000..3c55187
--- /dev/null
+++ b/modules/web-console/frontend/app-angular/components/panelCollapsible.component.ts
@@ -0,0 +1,152 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import {Component, Input, forwardRef, HostBinding} from '@angular/core';
+import {NG_VALUE_ACCESSOR, ControlValueAccessor} from '@angular/forms';
+
+@Component({
+    selector: 'panel-collapsible-angular',
+    template: `
+        <div class="heading" (click)='toggle()' (keyup.enter)='toggle()' (keyup.space)='toggle()' tabindex='0'>
+            <ignite-icon class='status' [name]='opened ? "collapse" : "expand"'></ignite-icon>
+            <div class="title">
+                <ng-content select='[panelTitle]'></ng-content>
+            </div>
+            <div class="description">
+                <ng-content select='[panelDescription]'></ng-content>
+            </div>
+            <div class="actions" (click)='$event.stopPropagation()'>
+                <ng-content select='[panelActions]'></ng-content>
+            </div>
+        </div>
+        <div class="content" [hidden]='!opened'>
+            <ng-content></ng-content>
+        </div>
+    `,
+    styles: [`
+        :host {
+            display: flex;
+            flex-direction: column;
+            border-radius: 0 0 4px 4px;
+            background-color: #ffffff;
+            box-shadow: 0 2px 4px 0 rgba(0, 0, 0, 0.2);
+        }
+
+        :host[disabled] {
+            opacity: 0.5;
+        }
+
+        :host > .heading .status {
+            margin-right: 10px;
+            color: #757575;
+            width: 13px;
+            height: 13px;
+        }
+
+        :host > .heading {
+            padding: 30px 20px 30px;
+            color: #393939;
+            display: flex;
+            flex-direction: row;
+            align-items: baseline;
+            user-select: none;
+            cursor: pointer;
+            line-height: 1.42857;
+        }
+
+        :host > .heading .title {
+            font-size: 16px;
+            margin-right: 8px;
+            white-space: nowrap;
+            overflow: hidden;
+            text-overflow: ellipsis;
+        }
+
+        :host > .heading .description {
+            font-size: 12px;
+            color: #757575;
+            flex: 1 1;
+        }
+
+        :host > .heading .actions {
+            margin-left: auto;
+            flex: 0 0 auto;
+
+            & > panel-actions {
+                display: flex;
+                flex-direction: row;
+
+                & > * {
+                    flex: 0 0 auto;
+                    margin-left: 10px;
+                }
+            }
+        }
+
+        :host > .content {
+            border-top: 1px solid #dddddd;
+            padding: 15px 20px;
+        }
+    `],
+    providers: [{
+        provide: NG_VALUE_ACCESSOR,
+        useExisting: forwardRef(() => PanelCollapsible),
+        multi: true
+    }]
+})
+export class PanelCollapsible implements ControlValueAccessor {
+    @Input()
+    opened: boolean = false;
+
+    @HostBinding('attr.open')
+    private get openAttr() {
+        return this.opened ? '' : void 0;
+    }
+
+    @Input()
+    disabled: string;
+
+    private _onChange?: (value: PanelCollapsible['opened']) => void;
+
+    toggle() {
+        if (this.opened)
+            this.close();
+        else
+            this.open();
+    }
+
+    open() {
+        if (this.disabled) return;
+        this.opened = true;
+        if (this._onChange) this._onChange(this.opened);
+    }
+
+    close() {
+        if (this.disabled) return;
+        this.opened = false;
+        if (this._onChange) this._onChange(this.opened);
+    }
+
+    writeValue(value: PanelCollapsible['opened']) {
+        this.opened = value;
+    }
+
+    registerOnChange(fn) {
+        this._onChange = fn;
+    }
+
+    registerOnTouched() {}
+}
diff --git a/modules/web-console/frontend/app/components/page-profile/style.scss b/modules/web-console/frontend/app-angular/components/serviceBootstrap.ts
similarity index 59%
copy from modules/web-console/frontend/app/components/page-profile/style.scss
copy to modules/web-console/frontend/app-angular/components/serviceBootstrap.ts
index a64c892..486a12f 100644
--- a/modules/web-console/frontend/app/components/page-profile/style.scss
+++ b/modules/web-console/frontend/app-angular/components/serviceBootstrap.ts
@@ -14,20 +14,22 @@
  * limitations under the License.
  */
 
-page-profile {
-    max-width: 800px;
-    display: block;
-
-    panel-collapsible {
-        width: 100%;
-    }
+/**
+ * This component ensures that Angular starts before AngularJS
+ * https://github.com/ui-router/angular-hybrid/issues/98
+ */
 
-    footer {
-        display: flex;
-        justify-content: flex-end;
-    }
+import {Component} from '@angular/core';
 
-    .btn-ignite + .btn-ignite {
-        margin-left: 10px;
+@Component({
+    selector: 'service-bootstrap',
+    template: ''
+})
+export class ServiceBootstrapComponent {
+    constructor() {
+        const injector = angular.element(document.body).injector();
+        const urlService = injector.get('$urlService');
+        urlService.listen();
+        urlService.sync();
     }
 }
diff --git a/modules/web-console/frontend/app-angular/downgrade.ts b/modules/web-console/frontend/app-angular/downgrade.ts
new file mode 100644
index 0000000..4c86835
--- /dev/null
+++ b/modules/web-console/frontend/app-angular/downgrade.ts
@@ -0,0 +1,37 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+import {ServiceBootstrapComponent} from './components/serviceBootstrap';
+import {platformBrowserDynamic} from '@angular/platform-browser-dynamic';
+import {downgradeModule, downgradeComponent } from '@angular/upgrade/static';
+import {StaticProvider} from '@angular/core';
+
+export const downgradeModuleFactory = (ngModule) => {
+    const boostrapFn = (extraProviders: StaticProvider[]) => {
+        const platformRef = platformBrowserDynamic(extraProviders);
+        return platformRef.bootstrapModule(ngModule);
+    };
+    const downgradedModule = downgradeModule(boostrapFn);
+
+    angular
+        .module(downgradedModule)
+        .directive('serviceBootstrap', downgradeComponent({component: ServiceBootstrapComponent}))
+        .run(['$compile', '$rootScope', ($compile: ng.ICompileService, $root: ng.IRootScopeService) => {
+            $compile('<service-bootstrap></service-bootstrap>')($root);
+        }]);
+
+    return downgradedModule;
+};
diff --git a/modules/web-console/frontend/app-angular/index.ts b/modules/web-console/frontend/app-angular/index.ts
new file mode 100644
index 0000000..9cd6161
--- /dev/null
+++ b/modules/web-console/frontend/app-angular/index.ts
@@ -0,0 +1,116 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+// See https://angular.io/guide/deployment#enable-runtime-production-mode for details.
+import {enableProdMode} from '@angular/core';
+if (process.env.NODE_ENV === 'production') enableProdMode();
+
+import './style.scss';
+
+import {NgModule, Inject} from '@angular/core';
+import {BrowserModule} from '@angular/platform-browser';
+import {UIRouterUpgradeModule} from '@uirouter/angular-hybrid';
+import {UIRouter} from '@uirouter/angular';
+import {UpgradeModule} from '@angular/upgrade/static';
+import {NgxPopperModule} from 'ngx-popper';
+
+import {ServiceBootstrapComponent} from './components/serviceBootstrap';
+export {ServiceBootstrapComponent};
+import {PageProfile} from './components/page-profile/component';
+export {PageProfile};
+import {IgniteIcon} from './components/igniteIcon.component';
+import {PanelCollapsible} from './components/panelCollapsible.component';
+import {CopyToClipboardButton} from './components/copyToClipboardButton.component';
+
+import {FormFieldHint} from './components/form-field/hint.component';
+import {FormFieldErrors} from './components/form-field/errors.component';
+import {FormFieldError} from './components/form-field/error.component';
+import {FormField} from './components/form-field/formField.component';
+import {Autofocus} from './components/form-field/autofocus.directive';
+import {FormFieldTooltip} from './components/form-field/tooltip.component';
+import {PasswordVisibilityToggleButton} from './components/form-field/passwordVisibilityToggleButton.component';
+import {ScrollToFirstInvalid} from './components/form-field/scrollToFirstInvalid.directive';
+
+import {ReactiveFormsModule} from '@angular/forms';
+
+import {upgradedComponents} from './upgrade';
+
+export const declarations = [
+    ServiceBootstrapComponent,
+    PageProfile,
+    IgniteIcon,
+    PanelCollapsible,
+    CopyToClipboardButton,
+    FormFieldHint,
+    FormFieldErrors,
+    FormFieldError,
+    FormField,
+    Autofocus,
+    FormFieldTooltip,
+    PasswordVisibilityToggleButton,
+    ScrollToFirstInvalid,
+    ...upgradedComponents
+];
+
+export const entryComponents = [
+    ServiceBootstrapComponent,
+    PageProfile
+];
+
+export const upgradeService = (token: string) => ({
+    provide: token,
+    useFactory: (i) => i.get(token),
+    deps: ['$injector']
+});
+
+export const providers = [
+    'IgniteLegacyUtils',
+    'Confirm',
+    'IgniteCountries',
+    'User',
+    'IgniteIcons',
+    'IgniteCopyToClipboard'
+].map(upgradeService);
+
+import {states} from './states';
+
+@NgModule({
+    imports: [
+        BrowserModule,
+        ReactiveFormsModule,
+        UpgradeModule,
+        UIRouterUpgradeModule.forRoot({states}),
+        NgxPopperModule.forRoot({
+            applyClass: 'ignite-popper',
+            appendTo: 'body',
+            boundariesElement: 'ui-view.content'
+        })
+    ],
+    providers,
+    declarations,
+    entryComponents,
+    exports: [
+        ...declarations,
+        NgxPopperModule
+    ]
+})
+export class IgniteWebConsoleModule {
+    static parameters = [[new Inject(UIRouter)]];
+
+    constructor(private router: UIRouter) {}
+
+    ngDoBootstrap() {}
+}
diff --git a/modules/web-console/frontend/app/components/page-profile/style.scss b/modules/web-console/frontend/app-angular/states.ts
similarity index 66%
copy from modules/web-console/frontend/app/components/page-profile/style.scss
copy to modules/web-console/frontend/app-angular/states.ts
index a64c892..0235fc24 100644
--- a/modules/web-console/frontend/app/components/page-profile/style.scss
+++ b/modules/web-console/frontend/app-angular/states.ts
@@ -14,20 +14,17 @@
  * limitations under the License.
  */
 
-page-profile {
-    max-width: 800px;
-    display: block;
+import {NgHybridStateDeclaration} from '@uirouter/angular-hybrid';
+import {PageProfile} from '.';
 
-    panel-collapsible {
-        width: 100%;
+export const states: NgHybridStateDeclaration[] = [
+    {
+        name: 'base.settings.profile',
+        url: '/profile',
+        component: PageProfile,
+        permission: 'profile',
+        tfMetaTags: {
+            title: 'User profile'
+        }
     }
-
-    footer {
-        display: flex;
-        justify-content: flex-end;
-    }
-
-    .btn-ignite + .btn-ignite {
-        margin-left: 10px;
-    }
-}
+];
diff --git a/modules/web-console/frontend/app-angular/style.scss b/modules/web-console/frontend/app-angular/style.scss
new file mode 100644
index 0000000..774f8f4
--- /dev/null
+++ b/modules/web-console/frontend/app-angular/style.scss
@@ -0,0 +1,66 @@
+/*
+ * Copyright 2019 GridGain Systems, Inc. and Contributors.
+ * 
+ * Licensed under the GridGain Community Edition License (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ * 
+ *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+ * 
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+.ignite-popper.ngxp__container {
+    --arrow-offset: 6px;
+    --target-margin: 8px;
+
+    background-color: var(--ignite-popper-background-color);
+    box-shadow: none !important;
+    border-color: var(--ignite-popper-border-color);
+    color: var(--ignite-popper-font-color);
+    padding: 12px;
+    border-radius: 4px;
+    max-width: 400px;
+    // Above app header
+    z-index: 11;
+
+    &[x-placement^="right"] {
+        margin-left: var(--target-margin);
+
+        .ngxp__arrow {
+            left: calc(-1 * var(--arrow-offset))
+        }
+    }
+
+    &[x-placement^="left"] {
+        margin-right: var(--target-margin);
+
+        .ngxp__arrow {
+            right: calc(-1 * var(--arrow-offset))
+        }
+    }
+
+    .ngxp__inner {
+        font-size: 12px;
+    }
+
+    .ngxp__arrow {
+        border-color: var(--ignite-popper-border-color);
+    }
+}
+
+.ignite-popper__tooltip {
+    --ignite-popper-background-color: white;
+    --ignite-popper-border-color: #ccc;
+    --ignite-popper-font-color: inherit;
+}
+
+.ignite-popper__error {
+    --ignite-popper-background-color: var(--error-red);
+    --ignite-popper-border-color: var(--error-red);
+    --ignite-popper-font-color: white;
+}
diff --git a/modules/web-console/frontend/app/components/page-profile/style.scss b/modules/web-console/frontend/app-angular/upgrade.ts
similarity index 56%
rename from modules/web-console/frontend/app/components/page-profile/style.scss
rename to modules/web-console/frontend/app-angular/upgrade.ts
index a64c892..84d0d83 100644
--- a/modules/web-console/frontend/app/components/page-profile/style.scss
+++ b/modules/web-console/frontend/app-angular/upgrade.ts
@@ -14,20 +14,23 @@
  * limitations under the License.
  */
 
-page-profile {
-    max-width: 800px;
-    display: block;
+import {UpgradeComponent} from '@angular/upgrade/static';
+import {Directive, ElementRef, Injector, Inject, Input} from '@angular/core';
 
-    panel-collapsible {
-        width: 100%;
-    }
+@Directive({
+    selector: 'global-progress-line'
+})
+export class GlobalProgressLine extends UpgradeComponent {
+    static parameters = [[new Inject(ElementRef)], [new Inject(Injector)]];
 
-    footer {
-        display: flex;
-        justify-content: flex-end;
+    constructor(elRef: ElementRef, injector: Injector) {
+        super('globalProgressLine', elRef, injector);
     }
 
-    .btn-ignite + .btn-ignite {
-        margin-left: 10px;
-    }
+    @Input()
+    isLoading: boolean
 }
+
+export const upgradedComponents = [
+    GlobalProgressLine
+];
diff --git a/modules/web-console/frontend/app/app.js b/modules/web-console/frontend/app/app.ts
similarity index 97%
rename from modules/web-console/frontend/app/app.js
rename to modules/web-console/frontend/app/app.ts
index 7474dfc..756571f 100644
--- a/modules/web-console/frontend/app/app.js
+++ b/modules/web-console/frontend/app/app.ts
@@ -135,7 +135,6 @@ import igniteChartSelector from './components/ignite-chart-series-selector';
 import statusOutput from './components/status-output';
 import timedRedirection from './components/timed-redirection';
 
-import pageProfile from './components/page-profile';
 import pagePasswordChanged from './components/page-password-changed';
 import pagePasswordReset from './components/page-password-reset';
 import pageSignup from './components/page-signup';
@@ -153,6 +152,9 @@ import igniteServices from './services';
 import baseTemplate from 'views/base.pug';
 import * as icons from '../public/images/icons';
 
+import uiRouter from '@uirouter/angularjs';
+import {upgradeModule} from '@uirouter/angular-hybrid';
+
 export default angular
     .module('ignite-console', [
         // Optional AngularJS modules.
@@ -174,7 +176,8 @@ export default angular
         'ui.grid.resizeColumns',
         'ui.grid.saveState',
         'ui.grid.selection',
-        'ui.router',
+        uiRouter,
+        upgradeModule.name,
         // Base modules.
         'ignite-console.core',
         'ignite-console.ace',
@@ -227,7 +230,6 @@ export default angular
         connectedClustersDialog.name,
         igniteListOfRegisteredUsers.name,
         dialogAdminCreateUser.name,
-        pageProfile.name,
         pageLanding.name,
         pagePasswordChanged.name,
         pagePasswordReset.name,
@@ -250,6 +252,8 @@ export default angular
         noDataCmp.name,
         globalProgressBar.name
     ])
+    // Routing should wait until Angular loads. Angular app part will start it back using serviceBootstrap component.
+    .config(['$urlServiceProvider', ($urlService) => $urlService.deferIntercept()])
     .service('$exceptionHandler', $exceptionHandler)
     // Directives.
     .directive('igniteAutoFocus', igniteAutoFocus)
@@ -371,7 +375,10 @@ export default angular
         /**
          * @param {ng.IRootScopeService} $root
          * @param {ng.IHttpService} $http
+         * @param $state
          * @param {ReturnType<typeof import('./services/Messages.service').default>} Messages
+         * @param User
+         * @param Notebook
          */
         ($root, $http, $state, Messages, User, Notebook) => { // eslint-disable-line no-shadow
             $root.revertIdentity = () => {
diff --git a/modules/web-console/frontend/app/components/form-field/showValidationError.directive.ts b/modules/web-console/frontend/app/components/form-field/showValidationError.directive.ts
index 1e1e1ab..80bc7e6 100644
--- a/modules/web-console/frontend/app/components/form-field/showValidationError.directive.ts
+++ b/modules/web-console/frontend/app/components/form-field/showValidationError.directive.ts
@@ -22,7 +22,8 @@ const scrollIntoView = (() => {
     return (el: HTMLElement) => {
         try {
             el.scrollIntoView({block: 'center'});
-        } catch (e) {
+        }
+        catch (ignored) {
             el.scrollIntoView();
         }
     };
diff --git a/modules/web-console/frontend/app/components/page-profile/controller.js b/modules/web-console/frontend/app/components/page-profile/controller.js
deleted file mode 100644
index 088bfa6..0000000
--- a/modules/web-console/frontend/app/components/page-profile/controller.js
+++ /dev/null
@@ -1,97 +0,0 @@
-/*
- * Copyright 2019 GridGain Systems, Inc. and Contributors.
- * 
- * Licensed under the GridGain Community Edition License (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- * 
- *     https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
- * 
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-import _ from 'lodash';
-
-export default class PageProfileController {
-    static $inject = [
-        '$rootScope', '$scope', '$http', 'IgniteLegacyUtils', 'IgniteMessages', 'IgniteFocus', 'IgniteConfirm', 'IgniteCountries', 'User', 'IgniteFormUtils'
-    ];
-
-    /**
-     * @param {ng.IRootScopeService} $root
-     * @param {ng.IScope} $scope
-     * @param {ng.IHttpService} $http
-     * @param {ReturnType<typeof import('app/services/LegacyUtils.service').default>} LegacyUtils
-     * @param {ReturnType<typeof import('app/services/Messages.service').default>} Messages
-     * @param {ReturnType<typeof import('app/services/Focus.service').default>} Focus
-     * @param {import('app/services/Confirm.service').Confirm} Confirm
-     * @param {ReturnType<typeof import('app/services/Countries.service').default>} Countries
-     * @param {ReturnType<typeof import('app/modules/user/User.service').default>} User
-     * @param {ReturnType<typeof import('app/services/FormUtils.service').default>} FormUtils
-     */
-    constructor($root, $scope, $http, LegacyUtils, Messages, Focus, Confirm, Countries, User, FormUtils) {
-        this.$root = $root;
-        this.$scope = $scope;
-        this.$http = $http;
-        this.LegacyUtils = LegacyUtils;
-        this.Messages = Messages;
-        this.Focus = Focus;
-        this.Confirm = Confirm;
-        this.Countries = Countries;
-        this.User = User;
-        this.FormUtils = FormUtils;
-
-        this.isLoading = false;
-    }
-
-    $onInit() {
-        this.ui = {};
-
-        this.User.read()
-            .then((user) => this.ui.user = _.cloneDeep(user));
-
-        this.ui.countries = this.Countries.getAll();
-    }
-
-    onSecurityTokenPanelClose() {
-        this.ui.user.token = this.$root.user.token;
-    }
-
-    generateToken() {
-        this.Confirm.confirm('Are you sure you want to change security token?<br>If you change the token you will need to restart the agent.')
-            .then(() => this.ui.user.token = this.LegacyUtils.randomString(20));
-    }
-
-    onPasswordPanelClose() {
-        delete this.ui.user.password;
-        delete this.ui.user.confirm;
-    }
-
-    saveUser() {
-        if (this.form.$invalid) {
-            this.FormUtils.triggerValidation(this.form);
-
-            return;
-        }
-
-        this.isLoading = true;
-
-        return this.$http.post('/api/v1/profile/save', this.ui.user)
-            .then(this.User.load)
-            .then(() => {
-                this.ui.expandedPassword = this.ui.expandedToken = false;
-
-                this.Messages.showInfo('Profile saved.');
-
-                this.Focus.move('profile-username');
-
-                this.$root.$broadcast('user', this.ui.user);
-            })
-            .catch((res) => this.Messages.showError('Failed to save profile: ', res))
-            .finally(() => this.isLoading = false);
-    }
-}
diff --git a/modules/web-console/frontend/app/components/page-profile/template.pug b/modules/web-console/frontend/app/components/page-profile/template.pug
deleted file mode 100644
index e307b12..0000000
--- a/modules/web-console/frontend/app/components/page-profile/template.pug
+++ /dev/null
@@ -1,161 +0,0 @@
-//-
-    Copyright 2019 GridGain Systems, Inc. and Contributors.
-    
-    Licensed under the GridGain Community Edition License (the "License");
-    you may not use this file except in compliance with the License.
-    You may obtain a copy of the License at
-    
-        https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
-    
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
-
-
-include /app/helpers/jade/mixins
-
-div
-    global-progress-line(is-loading='$ctrl.isLoading')
-
-    header.header-with-selector
-        div
-            h1 User profile
-
-    -var form = '$ctrl.form'
-    form.theme--ignite(name='$ctrl.form' novalidate)
-        .row
-            .col-50
-                +form-field__text({
-                    label: 'First name:',
-                    model: '$ctrl.ui.user.firstName',
-                    name: '"firstName"',
-                    required: true,
-                    placeholder: 'Input first name'
-                })(
-                ignite-auto-focus
-                    ignite-on-enter-focus-move='lastNameInput'
-                )
-            .col-50
-                +form-field__text({
-                    label: 'Last name:',
-                    model: '$ctrl.ui.user.lastName',
-                    name: '"lastName"',
-                    required: true,
-                    placeholder: 'Input last name'
-                })(
-                    ignite-on-enter-focus-move='emailInput'
-                )
-        .row
-            .col-100
-                +form-field__email({
-                    label: 'Email:',
-                    model: '$ctrl.ui.user.email',
-                    name: '"email"',
-                    required: true,
-                    placeholder: 'Input email'
-                })(
-                    ignite-on-enter-focus-move='phoneInput'
-                )
-        .row
-            .col-50
-                +form-field__phone({
-                    label: 'Phone:',
-                    model: '$ctrl.ui.user.phone',
-                    name: '"phone"',
-                    optional: true,
-                    placeholder: 'Input phone (ex.: +15417543010)'
-                })(
-                    ignite-on-enter-focus-move='companyInput'
-                )
-            .col-50
-                +form-field__dropdown({
-                    label: 'Country/Region:',
-                    model: '$ctrl.ui.user.country',
-                    name: '"country"',
-                    required: true,
-                    placeholder: 'Choose your country/region',
-                    options: '$ctrl.ui.countries'
-                })
-        .row
-            .col-100
-                +form-field__text({
-                    label: 'Company:',
-                    model: '$ctrl.ui.user.company',
-                    name: '"company"',
-                    required: true,
-                    placeholder: 'Input company name'
-                })(
-                    ignite-on-enter-focus-move='countryInput'
-                )
-
-        .row#security-token-section
-            .col-100
-                panel-collapsible(
-                    opened='$ctrl.ui.expandedToken'
-                    on-open='$ctrl.ui.expandedToken = true'
-                    on-close='$ctrl.onSecurityTokenPanelClose()'
-                )
-                    panel-title
-                        | {{ $panel.opened ? 'Cancel security token changing...' : 'Show security token...' }}
-                    panel-content
-                        .row
-                            .col-50
-                                +form-field__text({
-                                    label: 'Security Token:',
-                                    model: '$ctrl.ui.user.token',
-                                    tip: 'The security token is used for authentication of Web agent',
-                                    name: '"securityToken"',
-                                    placeholder: 'No security token. Regenerate please.'
-                                })(
-                                    autocomplete='security-token'
-                                    ng-disabled='::true'
-                                    copy-input-value-button='Copy security token to clipboard'
-                                )
-                            .col-50
-                                a(ng-click='$ctrl.generateToken()') Generate Random Security Token?
-
-        .row
-            .col-100
-                panel-collapsible(
-                    opened='$ctrl.ui.expandedPassword'
-                    on-open='$ctrl.ui.expandedPassword = true'
-                    on-close='$ctrl.onPasswordPanelClose()'
-                )
-                    panel-title
-                        | {{ $panel.opened ? 'Cancel password changing...' : 'Change password...' }}
-                    panel-content(ng-if='$panel.opened')
-                        .row
-                            .col-100
-                                +form-field__password({
-                                    label: 'New password:',
-                                    model: '$ctrl.ui.user.password',
-                                    name: '"password"',
-                                    required: true,
-                                    placeholder: 'New password'
-                                })(
-                                    ignite-auto-focus
-                                    ignite-on-enter-focus-move='passwordConfirmInput'
-                                )
-
-                        .row
-                            .col-100
-                                +form-field__password({
-                                    label: 'Confirm password:',
-                                    model: 'user.confirm',
-                                    name: '"passwordConfirm"',
-                                    required: true,
-                                    placeholder: 'Confirm new password'
-                                })(
-                                    ignite-on-enter-focus-move='passwordConfirmInput'
-                                    ignite-match='$ctrl.ui.user.password'
-                                )
-
-    hr
-
-    footer
-        a.btn-ignite.btn-ignite--link-success(type='button' ui-sref='default-state') Cancel
-        button.btn-ignite.btn-ignite--success(ng-click='$ctrl.saveUser()' ng-disabled='$ctrl.isLoading')
-            svg.icon-left(ignite-icon='checkmark')
-            | Save Changes
diff --git a/modules/web-console/frontend/app/components/page-signin/run.ts b/modules/web-console/frontend/app/components/page-signin/run.ts
index c66c990..7590c55 100644
--- a/modules/web-console/frontend/app/components/page-signin/run.ts
+++ b/modules/web-console/frontend/app/components/page-signin/run.ts
@@ -47,7 +47,8 @@ export function registerState($uiRouter: UIRouter) {
                         const restored = trans.router.stateService.target(name, params);
 
                         return restored.valid() ? restored : 'default-state';
-                    } catch (ignored) {
+                    }
+                    catch (ignored) {
                         return 'default-state';
                     }
                 })
diff --git a/modules/web-console/frontend/app/configuration/components/modal-import-models/component.js b/modules/web-console/frontend/app/configuration/components/modal-import-models/component.js
index 722c6b7..d7553f6 100644
--- a/modules/web-console/frontend/app/configuration/components/modal-import-models/component.js
+++ b/modules/web-console/frontend/app/configuration/components/modal-import-models/component.js
@@ -424,7 +424,7 @@ export class ModalImportModels {
                     }
                 });
             }
-            catch (ignore) {
+            catch (ignored) {
                 // No-op.
             }
         }
diff --git a/modules/web-console/frontend/app/modules/agent/AgentManager.service.js b/modules/web-console/frontend/app/modules/agent/AgentManager.service.js
index 7a0185b..2081c04 100644
--- a/modules/web-console/frontend/app/modules/agent/AgentManager.service.js
+++ b/modules/web-console/frontend/app/modules/agent/AgentManager.service.js
@@ -175,7 +175,7 @@ export default class AgentManager {
         try {
             return JSON.parse(localStorage.cluster);
         }
-        catch (ignore) {
+        catch (ignored) {
             return null;
         }
         finally {
@@ -284,7 +284,7 @@ export default class AgentManager {
         try {
             localStorage.cluster = JSON.stringify(cluster);
         }
-        catch (ignore) {
+        catch (ignored) {
             // No-op.
         }
     }
diff --git a/modules/web-console/frontend/app/modules/getting-started/GettingStarted.provider.js b/modules/web-console/frontend/app/modules/getting-started/GettingStarted.provider.js
index 315f97f..8bc019e 100644
--- a/modules/web-console/frontend/app/modules/getting-started/GettingStarted.provider.js
+++ b/modules/web-console/frontend/app/modules/getting-started/GettingStarted.provider.js
@@ -106,7 +106,7 @@ export function service($root, $modal, igniteGettingStarted) {
         try {
             localStorage.showGettingStarted = !scope.ui.dontShowGettingStarted;
         }
-        catch (ignore) {
+        catch (ignored) {
             // No-op.
         }
 
@@ -122,7 +122,7 @@ export function service($root, $modal, igniteGettingStarted) {
                 scope.ui.dontShowGettingStarted = !(_.isNil(localStorage.showGettingStarted)
                         || localStorage.showGettingStarted === 'true');
             }
-            catch (ignore) {
+            catch (ignored) {
                 // No-op.
             }
 
diff --git a/modules/web-console/frontend/app/modules/user/Auth.service.ts b/modules/web-console/frontend/app/modules/user/Auth.service.ts
index 8481b85..c066663 100644
--- a/modules/web-console/frontend/app/modules/user/Auth.service.ts
+++ b/modules/web-console/frontend/app/modules/user/Auth.service.ts
@@ -90,8 +90,9 @@ export default class AuthService {
     async resendSignupConfirmation(email: string) {
         try {
             return await this.$http.post('/api/v1/activation/resend/', {email});
-        } catch (res) {
-            throw res.data;
+        }
+        catch (err) {
+            throw err.data;
         }
     }
 }
diff --git a/modules/web-console/frontend/app/modules/user/User.service.js b/modules/web-console/frontend/app/modules/user/User.service.ts
similarity index 58%
rename from modules/web-console/frontend/app/modules/user/User.service.js
rename to modules/web-console/frontend/app/modules/user/User.service.ts
index 60a70da..aa47d3a 100644
--- a/modules/web-console/frontend/app/modules/user/User.service.js
+++ b/modules/web-console/frontend/app/modules/user/User.service.ts
@@ -15,31 +15,35 @@
  */
 
 import {ReplaySubject} from 'rxjs';
+import {StateService} from '@uirouter/angularjs';
+import {default as MessagesFactory} from 'app/services/Messages.service';
 
-/**
- * @typedef User
- * @prop {string} _id
- * @prop {boolean} admin
- * @prop {string} country
- * @prop {string} email
- * @prop {string} firstName
- * @prop {string} lastName
- * @prop {string} lastActivity
- * @prop {string} lastLogin
- * @prop {string} registered
- * @prop {string} token
- */
+export type User = {
+    _id: string,
+    admin: boolean,
+    country: string,
+    email: string,
+    phone?: string,
+    company?: string,
+    firstName: string,
+    lastName: string,
+    lastActivity: string,
+    lastLogin: string,
+    registered: string,
+    token: string
+}
 
-/**
- * @param {ng.IQService} $q
- * @param {ng.auto.IInjectorService} $injector
- * @param {ng.IRootScopeService} $root
- * @param {import('@uirouter/angularjs').StateService} $state
- * @param {ng.IHttpService} $http
- */
-export default function User($q, $injector, $root, $state, $http) {
-    /** @type {ng.IPromise<User>} */
-    let user;
+User.$inject = ['$q', '$injector', '$rootScope', '$state', '$http', 'IgniteMessages'];
+
+export default function User(
+    $q: ng.IQService,
+    $injector: ng.auto.IInjectorService,
+    $root: ng.IRootScopeService,
+    $state: StateService,
+    $http: ng.IHttpService,
+    IgniteMessages: ReturnType<typeof MessagesFactory>
+) {
+    let user: ng.IPromise<User>;
 
     const current$ = new ReplaySubject(1);
 
@@ -77,8 +81,19 @@ export default function User($q, $injector, $root, $state, $http) {
             delete $root.IgniteDemoMode;
 
             sessionStorage.removeItem('IgniteDemoMode');
+        },
+
+        async save(user: Partial<User>): Promise<User> {
+            try {
+                const {data: updatedUser} = await $http.post<User>('/api/v1/profile/save', user);
+                await this.load();
+                IgniteMessages.showInfo('Profile saved.');
+                $root.$broadcast('user', updatedUser);
+                return updatedUser;
+            }
+            catch (e) {
+                IgniteMessages.showError('Failed to save profile: ', e);
+            }
         }
     };
 }
-
-User.$inject = ['$q', '$injector', '$rootScope', '$state', '$http'];
diff --git a/modules/web-console/frontend/app/vendor.js b/modules/web-console/frontend/app/vendor.js
index aa12b34..377c738 100644
--- a/modules/web-console/frontend/app/vendor.js
+++ b/modules/web-console/frontend/app/vendor.js
@@ -24,7 +24,9 @@ import 'angular-strap/dist/angular-strap.tpl';
 import 'angular1-async-filter';
 
 import 'angular-messages';
-import '@uirouter/angularjs';
+
+import 'core-js/es7/reflect';
+import 'zone.js/dist/zone';
 
 import 'resize-observer-polyfill';
 
diff --git a/modules/web-console/frontend/index.js b/modules/web-console/frontend/index.js
index d1bb4b8..c317247 100644
--- a/modules/web-console/frontend/index.js
+++ b/modules/web-console/frontend/index.js
@@ -18,5 +18,7 @@ import angular from 'angular';
 
 import igniteConsole from './app/app';
 import configurationLazyModule from './app/configuration/index.lazy';
+import {IgniteWebConsoleModule} from './app-angular';
+import {downgradeModuleFactory} from './app-angular/downgrade';
 
-angular.bootstrap(document, [igniteConsole.name, configurationLazyModule.name], {strictDi: true});
+angular.bootstrap(document, [igniteConsole.name, configurationLazyModule.name, downgradeModuleFactory(IgniteWebConsoleModule)], {strictDi: true});
diff --git a/modules/web-console/frontend/package-lock.json b/modules/web-console/frontend/package-lock.json
index 459e517..4e4f928 100644
--- a/modules/web-console/frontend/package-lock.json
+++ b/modules/web-console/frontend/package-lock.json
@@ -4,6 +4,76 @@
   "lockfileVersion": 1,
   "requires": true,
   "dependencies": {
+    "@angular/common": {
+      "version": "7.2.2",
+      "resolved": "https://registry.npmjs.org/@angular/common/-/common-7.2.2.tgz",
+      "integrity": "sha512-43EcR3mbM+dKH4VE1EYS1HxSuEToxxv5XPktKqdzY95g8PBOxe11ifcXoYHgImd7YOWzcKoy0k6yQbX3o0cZ8g==",
+      "requires": {
+        "tslib": "^1.9.0"
+      }
+    },
+    "@angular/compiler": {
+      "version": "7.2.2",
+      "resolved": "https://registry.npmjs.org/@angular/compiler/-/compiler-7.2.2.tgz",
+      "integrity": "sha512-vjPreOVPca6HSuDmj7N1w5u8hwXdm98gEPo2wqQMVuJd6qvGEyLYE9FsHc0XCchyQEKSybAYl1dwsjZq2nNSvQ==",
+      "requires": {
+        "tslib": "^1.9.0"
+      }
+    },
+    "@angular/core": {
+      "version": "7.2.2",
+      "resolved": "https://registry.npmjs.org/@angular/core/-/core-7.2.2.tgz",
+      "integrity": "sha512-kQ0HxUYAPvly8b3aibTGbiodFnBBgo3asXAQuPgFjYYEqcKR1zZII7PQdaEF9kb9sfm/IKLKj4nd9fZ0gcgqZg==",
+      "requires": {
+        "tslib": "^1.9.0"
+      }
+    },
+    "@angular/forms": {
+      "version": "7.2.2",
+      "resolved": "https://registry.npmjs.org/@angular/forms/-/forms-7.2.2.tgz",
+      "integrity": "sha512-IsvVuUnzIA2ryRmh7l42AANPZFSyNcwqZNtxbmRq2wm3Lfed64U0rsRWWNqipjz7QTxZ2SRdAlP+XDgzg8hvMQ==",
+      "requires": {
+        "tslib": "^1.9.0"
+      }
+    },
+    "@angular/language-service": {
+      "version": "7.2.4",
+      "resolved": "https://registry.npmjs.org/@angular/language-service/-/language-service-7.2.4.tgz",
+      "integrity": "sha512-A9Rud/27hHMSUUjpgn57nVeLsoYgdvFwJhtlZA/oCuSpmlD+LqqBsEpPhivwn++u44+DSrFXsic29jlFnsBotw==",
+      "dev": true
+    },
+    "@angular/platform-browser": {
+      "version": "7.2.2",
+      "resolved": "https://registry.npmjs.org/@angular/platform-browser/-/platform-browser-7.2.2.tgz",
+      "integrity": "sha512-eiaqHq26PVASx1kTngBDkFkXhaJzEjoGtc5I+wQUef8CUjq6ZViWz8tUgiiDPOWdqUKUacRZG4q6VR/6uwQj0A==",
+      "requires": {
+        "tslib": "^1.9.0"
+      }
+    },
+    "@angular/platform-browser-dynamic": {
+      "version": "7.2.2",
+      "resolved": "https://registry.npmjs.org/@angular/platform-browser-dynamic/-/platform-browser-dynamic-7.2.2.tgz",
+      "integrity": "sha512-bw5PuzMzjKMecB4slG/btmvxgn4qFWhNmJVpf2pbtZW7NtZz3HlrqipYzMk9XrCUDGjtwy7O2Z71C3ujI748iw==",
+      "requires": {
+        "tslib": "^1.9.0"
+      }
+    },
+    "@angular/router": {
+      "version": "7.2.2",
+      "resolved": "https://registry.npmjs.org/@angular/router/-/router-7.2.2.tgz",
+      "integrity": "sha512-+cBC+JxbPdjk+Nyqq27PKkjfIdnc+H+xjMGrkO6dlAKhVMGxyNaYt5NUNugb8XJPsQ1XNXyzwTfZK6jcAGLw6w==",
+      "requires": {
+        "tslib": "^1.9.0"
+      }
+    },
+    "@angular/upgrade": {
+      "version": "7.2.2",
+      "resolved": "https://registry.npmjs.org/@angular/upgrade/-/upgrade-7.2.2.tgz",
+      "integrity": "sha512-eKqJuAgu3vce0oHB7BxF4imprvWfLmJbEB2sXtR1ZjeCR/c4WP7CwDaLA5GBKadsJ7oWrS+N7U3Ay+CFJ64pUQ==",
+      "requires": {
+        "tslib": "^1.9.0"
+      }
+    },
     "@babel/code-frame": {
       "version": "7.0.0",
       "resolved": "https://registry.npmjs.org/@babel/code-frame/-/code-frame-7.0.0.tgz",
@@ -86,6 +156,19 @@
         "@babel/types": "^7.0.0"
       }
     },
+    "@babel/helper-create-class-features-plugin": {
+      "version": "7.3.0",
+      "resolved": "https://registry.npmjs.org/@babel/helper-create-class-features-plugin/-/helper-create-class-features-plugin-7.3.0.tgz",
+      "integrity": "sha512-DUsQNS2CGLZZ7I3W3fvh0YpPDd6BuWJlDl+qmZZpABZHza2ErE3LxtEzLJFHFC1ZwtlAXvHhbFYbtM5o5B0WBw==",
+      "dev": true,
+      "requires": {
+        "@babel/helper-function-name": "^7.1.0",
+        "@babel/helper-member-expression-to-functions": "^7.0.0",
+        "@babel/helper-optimise-call-expression": "^7.0.0",
+        "@babel/helper-plugin-utils": "^7.0.0",
+        "@babel/helper-replace-supers": "^7.2.3"
+      }
+    },
     "@babel/helper-define-map": {
       "version": "7.1.0",
       "resolved": "https://registry.npmjs.org/@babel/helper-define-map/-/helper-define-map-7.1.0.tgz",
@@ -294,6 +377,17 @@
         "@babel/plugin-syntax-class-properties": "^7.0.0"
       }
     },
+    "@babel/plugin-proposal-decorators": {
+      "version": "7.3.0",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-proposal-decorators/-/plugin-proposal-decorators-7.3.0.tgz",
+      "integrity": "sha512-3W/oCUmsO43FmZIqermmq6TKaRSYhmh/vybPfVFwQWdSb8xwki38uAIvknCRzuyHRuYfCYmJzL9or1v0AffPjg==",
+      "dev": true,
+      "requires": {
+        "@babel/helper-create-class-features-plugin": "^7.3.0",
+        "@babel/helper-plugin-utils": "^7.0.0",
+        "@babel/plugin-syntax-decorators": "^7.2.0"
+      }
+    },
     "@babel/plugin-proposal-json-strings": {
       "version": "7.2.0",
       "resolved": "https://registry.npmjs.org/@babel/plugin-proposal-json-strings/-/plugin-proposal-json-strings-7.2.0.tgz",
@@ -353,6 +447,15 @@
         "@babel/helper-plugin-utils": "^7.0.0"
       }
     },
+    "@babel/plugin-syntax-decorators": {
+      "version": "7.2.0",
+      "resolved": "https://registry.npmjs.org/@babel/plugin-syntax-decorators/-/plugin-syntax-decorators-7.2.0.tgz",
+      "integrity": "sha512-38QdqVoXdHUQfTpZo3rQwqQdWtCn5tMv4uV6r2RMfTqNBuv4ZBhz79SfaQWKTVmxHjeFv/DnXVC/+agHCklYWA==",
+      "dev": true,
+      "requires": {
+        "@babel/helper-plugin-utils": "^7.0.0"
+      }
+    },
     "@babel/plugin-syntax-dynamic-import": {
       "version": "7.0.0",
       "resolved": "https://registry.npmjs.org/@babel/plugin-syntax-dynamic-import/-/plugin-syntax-dynamic-import-7.0.0.tgz",
@@ -1049,25 +1152,37 @@
         }
       }
     },
+    "@uirouter/angular": {
+      "version": "3.0.0",
+      "resolved": "https://registry.npmjs.org/@uirouter/angular/-/angular-3.0.0.tgz",
+      "integrity": "sha512-HgAl0tk+RxuspC6vSNINMlzjTJgo+TFSpJ37OQgY7WEU7OrEDCdftVITJHyU/J87UES1ajalJljeq0/fI8Sv7g==",
+      "requires": {
+        "@uirouter/core": "5.0.23",
+        "@uirouter/rx": "0.5.0"
+      }
+    },
+    "@uirouter/angular-hybrid": {
+      "version": "7.0.0",
+      "resolved": "https://registry.npmjs.org/@uirouter/angular-hybrid/-/angular-hybrid-7.0.0.tgz",
+      "integrity": "sha512-9/lpRJhU6mCBsxl1tWUtbYVTeYgjTm1kprd8AOyqQ2SElIX63CZDg4I90CDDFJm4M70QLMHCNW8zZmlhglPufg==",
+      "requires": {
+        "@uirouter/angular": "3.0.0",
+        "@uirouter/angularjs": "1.0.22",
+        "@uirouter/core": "5.0.23"
+      }
+    },
     "@uirouter/angularjs": {
-      "version": "1.0.20",
-      "resolved": "https://registry.npmjs.org/@uirouter/angularjs/-/angularjs-1.0.20.tgz",
-      "integrity": "sha512-fY6bsesTL/tg8gyFHXaIjD1r5b7Ac+SYupodO9OzT4/gKI0YC+uGzLpQESAiXlT3fsxdEPVBzdtAbzXDwCKdEA==",
+      "version": "1.0.22",
+      "resolved": "https://registry.npmjs.org/@uirouter/angularjs/-/angularjs-1.0.22.tgz",
+      "integrity": "sha512-d0SvdbXAav+Z6gCJd7gmn2eXEUtO3RvYcSLwtPaE8+7QiWHpSKNfGdD4D3noXhO2yUTz/AwaxsiRFMCwgVI0UQ==",
       "requires": {
-        "@uirouter/core": "5.0.21"
-      },
-      "dependencies": {
-        "@uirouter/core": {
-          "version": "5.0.21",
-          "resolved": "https://registry.npmjs.org/@uirouter/core/-/core-5.0.21.tgz",
-          "integrity": "sha512-QWHc0wT00qtYNkT0BXZaFNLLHZyux0qJjF8c2WklW5/Q0Z866NoJjJErEMWjQb/AR+olkR2NlfEEi8KTQU2OpA=="
-        }
+        "@uirouter/core": "5.0.23"
       }
     },
     "@uirouter/core": {
-      "version": "5.0.19",
-      "resolved": "https://registry.npmjs.org/@uirouter/core/-/core-5.0.19.tgz",
-      "integrity": "sha512-wow+CKRThUAQkiTLNQCBsKQIU3NbH8GGH/w/TrcjKdvkZQA2jQB9QSqmmZxj7XNoZXY7QVcSSc4DWmxuSeAWmQ=="
+      "version": "5.0.23",
+      "resolved": "https://registry.npmjs.org/@uirouter/core/-/core-5.0.23.tgz",
+      "integrity": "sha512-rwFOH++z/KY8y+h0IOpQ5uC8Nim6E0EBCQrIjhVCr+XKYXgpK+VdtuOLFdogvbJ3AAi5Z7ei00qdEr7Did5CAg=="
     },
     "@uirouter/rx": {
       "version": "0.5.0",
@@ -1266,8 +1381,7 @@
     "abbrev": {
       "version": "1.1.1",
       "resolved": "https://registry.npmjs.org/abbrev/-/abbrev-1.1.1.tgz",
-      "integrity": "sha512-nne9/IiQ/hzIhY6pdDnbBtz7DjPTKrY00P/zvPSm5pOFkl6xuGrGnXn/VtTNNfNtAfZ9/1RtehkszU9qcTii0Q==",
-      "dev": true
+      "integrity": "sha512-nne9/IiQ/hzIhY6pdDnbBtz7DjPTKrY00P/zvPSm5pOFkl6xuGrGnXn/VtTNNfNtAfZ9/1RtehkszU9qcTii0Q=="
     },
     "accepts": {
       "version": "1.3.5",
@@ -1418,9 +1532,9 @@
       "dev": true
     },
     "angular": {
-      "version": "1.7.6",
-      "resolved": "https://registry.npmjs.org/angular/-/angular-1.7.6.tgz",
-      "integrity": "sha512-QELpvuMIe1FTGniAkRz93O6A+di0yu88niDwcdzrSqtUHNtZMgtgFS4f7W/6Gugbuwej8Kyswlmymwdp8iPCWg=="
+      "version": "1.7.7",
+      "resolved": "https://registry.npmjs.org/angular/-/angular-1.7.7.tgz",
+      "integrity": "sha512-MH3JEGd8y/EkNCKJ8EV6Ch0j9X0rZTta/QVIDpBWaIdfh85/e5KO8+ZKgvWIb02MQuiS20pDFmMFlv4ZaLcLWg=="
     },
     "angular-acl": {
       "version": "0.1.10",
@@ -1616,12 +1730,6 @@
       "integrity": "sha512-hNfzcOV8W4NdualtqBFPyVO+54DSJuZGY9qT4pRroB6S9e3iiido2ISIC5h9R2sPJ8H3FHCIiEnsv1lPXO3KtQ==",
       "dev": true
     },
-    "array-slice": {
-      "version": "0.2.3",
-      "resolved": "https://registry.npmjs.org/array-slice/-/array-slice-0.2.3.tgz",
-      "integrity": "sha1-3Tz7gO15c6dRF82sabC5nshhhvU=",
-      "dev": true
-    },
     "array-union": {
       "version": "1.0.2",
       "resolved": "https://registry.npmjs.org/array-union/-/array-union-1.0.2.tgz",
@@ -1924,8 +2032,7 @@
     "balanced-match": {
       "version": "1.0.0",
       "resolved": "https://registry.npmjs.org/balanced-match/-/balanced-match-1.0.0.tgz",
-      "integrity": "sha1-ibTRmasr7kneFk6gK4nORi1xt2c=",
-      "dev": true
+      "integrity": "sha1-ibTRmasr7kneFk6gK4nORi1xt2c="
     },
     "base": {
       "version": "0.11.2",
@@ -2144,7 +2251,6 @@
       "version": "1.1.11",
       "resolved": "https://registry.npmjs.org/brace-expansion/-/brace-expansion-1.1.11.tgz",
       "integrity": "sha512-iCuPHDFgrHX7H2vEI/5xpz07zSHB00TpugqhmYtVmMO6518mCuRMoOYFldEBl0g187ufozdaHgWKcYFb61qGiA==",
-      "dev": true,
       "requires": {
         "balanced-match": "^1.0.0",
         "concat-map": "0.0.1"
@@ -2577,9 +2683,9 @@
       "dev": true
     },
     "chokidar": {
-      "version": "2.1.2",
-      "resolved": "https://registry.npmjs.org/chokidar/-/chokidar-2.1.2.tgz",
-      "integrity": "sha512-IwXUx0FXc5ibYmPC2XeEj5mpXoV66sR+t3jqu2NS2GYwCktt3KF1/Qqjws/NkegajBA4RbZ5+DDwlOiJsxDHEg==",
+      "version": "2.1.5",
+      "resolved": "https://registry.npmjs.org/chokidar/-/chokidar-2.1.5.tgz",
+      "integrity": "sha512-i0TprVWp+Kj4WRPtInjexJ8Q+BqTE909VpH8xVhXrJkoc5QC8VO9TryGOqTr+2hljzc1sC62t22h5tZePodM/A==",
       "dev": true,
       "requires": {
         "anymatch": "^2.0.0",
@@ -2593,7 +2699,7 @@
         "normalize-path": "^3.0.0",
         "path-is-absolute": "^1.0.0",
         "readdirp": "^2.2.1",
-        "upath": "^1.1.0"
+        "upath": "^1.1.1"
       },
       "dependencies": {
         "normalize-path": {
@@ -2601,14 +2707,19 @@
           "resolved": "https://registry.npmjs.org/normalize-path/-/normalize-path-3.0.0.tgz",
           "integrity": "sha512-6eZs5Ls3WtCisHWp9S2GUy8dqkpGi4BVSz3GaqiE6ezub0512ESztXUwUB6C6IKbQkY2Pnb/mD4WYojCRwcwLA==",
           "dev": true
+        },
+        "upath": {
+          "version": "1.1.2",
+          "resolved": "https://registry.npmjs.org/upath/-/upath-1.1.2.tgz",
+          "integrity": "sha512-kXpym8nmDmlCBr7nKdIx8P2jNBa+pBpIUFRnKJ4dr8htyYGJFokkr2ZvERRtUN+9SY+JqXouNgUPtv6JQva/2Q==",
+          "dev": true
         }
       }
     },
     "chownr": {
       "version": "1.1.1",
       "resolved": "https://registry.npmjs.org/chownr/-/chownr-1.1.1.tgz",
-      "integrity": "sha512-j38EvO5+LHX84jlo6h4UzmOwi0UgW61WRyPtJz4qaadK5eY3BTS5TY/S1Stc3Uk2lIM6TPevAlULiEJwie860g==",
-      "dev": true
+      "integrity": "sha512-j38EvO5+LHX84jlo6h4UzmOwi0UgW61WRyPtJz4qaadK5eY3BTS5TY/S1Stc3Uk2lIM6TPevAlULiEJwie860g=="
     },
     "chrome-trace-event": {
       "version": "1.0.0",
@@ -2908,15 +3019,6 @@
       "integrity": "sha1-FopHAXVran9RoSzgyXv6KMCE7WM=",
       "dev": true
     },
-    "combine-lists": {
-      "version": "1.0.1",
-      "resolved": "https://registry.npmjs.org/combine-lists/-/combine-lists-1.0.1.tgz",
-      "integrity": "sha1-RYwH4J4NkA/Ci3Cj/sLazR0st/Y=",
-      "dev": true,
-      "requires": {
-        "lodash": "^4.5.0"
-      }
-    },
     "combined-stream": {
       "version": "1.0.7",
       "resolved": "https://registry.npmjs.org/combined-stream/-/combined-stream-1.0.7.tgz",
@@ -2963,24 +3065,24 @@
       },
       "dependencies": {
         "mime-db": {
-          "version": "1.38.0",
-          "resolved": "https://registry.npmjs.org/mime-db/-/mime-db-1.38.0.tgz",
-          "integrity": "sha512-bqVioMFFzc2awcdJZIzR3HjZFX20QhilVS7hytkKrv7xFAn8bM1gzc/FOX2awLISvWe0PV8ptFKcon+wZ5qYkg==",
+          "version": "1.39.0",
+          "resolved": "https://registry.npmjs.org/mime-db/-/mime-db-1.39.0.tgz",
+          "integrity": "sha512-DTsrw/iWVvwHH+9Otxccdyy0Tgiil6TWK/xhfARJZF/QFhwOgZgOIvA2/VIGpM8U7Q8z5nDmdDWC6tuVMJNibw==",
           "dev": true
         }
       }
     },
     "compression": {
-      "version": "1.7.3",
-      "resolved": "https://registry.npmjs.org/compression/-/compression-1.7.3.tgz",
-      "integrity": "sha512-HSjyBG5N1Nnz7tF2+O7A9XUhyjru71/fwgNb7oIsEVHR0WShfs2tIS/EySLgiTe98aOK18YDlMXpzjCXY/n9mg==",
+      "version": "1.7.4",
+      "resolved": "https://registry.npmjs.org/compression/-/compression-1.7.4.tgz",
+      "integrity": "sha512-jaSIDzP9pZVS4ZfQ+TzvtiWhdpFhE2RDHz8QJkpX9SIpLq88VueF5jJw6t+6CUQcAoA6t+x89MLrWAqpfDE8iQ==",
       "dev": true,
       "requires": {
         "accepts": "~1.3.5",
         "bytes": "3.0.0",
-        "compressible": "~2.0.14",
+        "compressible": "~2.0.16",
         "debug": "2.6.9",
-        "on-headers": "~1.0.1",
+        "on-headers": "~1.0.2",
         "safe-buffer": "5.1.2",
         "vary": "~1.1.2"
       },
@@ -3005,8 +3107,7 @@
     "concat-map": {
       "version": "0.0.1",
       "resolved": "https://registry.npmjs.org/concat-map/-/concat-map-0.0.1.tgz",
-      "integrity": "sha1-2Klr13/Wjfd5OnMDajug1UBdR3s=",
-      "dev": true
+      "integrity": "sha1-2Klr13/Wjfd5OnMDajug1UBdR3s="
     },
     "concat-stream": {
       "version": "1.6.2",
@@ -3208,8 +3309,7 @@
     "core-js": {
       "version": "2.6.2",
       "resolved": "https://registry.npmjs.org/core-js/-/core-js-2.6.2.tgz",
-      "integrity": "sha512-NdBPF/RVwPW6jr0NCILuyN9RiqLo2b1mddWHkUL+VnvcB7dzlnBJ1bXYntjpTGOgkZiiLWj2JxmOr7eGE3qK6g==",
-      "dev": true
+      "integrity": "sha512-NdBPF/RVwPW6jr0NCILuyN9RiqLo2b1mddWHkUL+VnvcB7dzlnBJ1bXYntjpTGOgkZiiLWj2JxmOr7eGE3qK6g=="
     },
     "core-util-is": {
       "version": "1.0.2",
@@ -3508,9 +3608,9 @@
       }
     },
     "date-format": {
-      "version": "1.2.0",
-      "resolved": "https://registry.npmjs.org/date-format/-/date-format-1.2.0.tgz",
-      "integrity": "sha1-YV6CjiM90aubua4JUODOzPpuytg=",
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/date-format/-/date-format-2.0.0.tgz",
+      "integrity": "sha512-M6UqVvZVgFYqZL1SfHsRGIQSz3ZL+qgbsV5Lp1Vj61LZVYuEwcMXYay7DRDtYs2HQQBK5hQtQ0fD9aEJ89V0LA==",
       "dev": true
     },
     "date-now": {
@@ -3562,6 +3662,13 @@
       "integrity": "sha1-9dJgKStmDghO/0zbyfCK0yR0SLU=",
       "dev": true
     },
+    "deep-extend": {
+      "version": "0.6.0",
+      "resolved": "https://registry.npmjs.org/deep-extend/-/deep-extend-0.6.0.tgz",
+      "integrity": "sha512-LOHxIOaPYdHlJRtCQfDIVZtfw/ufM8+rVj649RIHzcm/vGwQRXFt6OPqIFWsm2XEMrNIEtWR64sY1LEKD2vAOA==",
+      "dev": true,
+      "optional": true
+    },
     "deep-is": {
       "version": "0.1.3",
       "resolved": "https://registry.npmjs.org/deep-is/-/deep-is-0.1.3.tgz",
@@ -3575,9 +3682,9 @@
       "dev": true
     },
     "default-gateway": {
-      "version": "4.0.1",
-      "resolved": "https://registry.npmjs.org/default-gateway/-/default-gateway-4.0.1.tgz",
-      "integrity": "sha512-JnSsMUgrBFy9ycs+tmOvLHN1GpILe+hNSUrIVM8mXjymfcBH9a7LJjOdoHLuUqKGuCUk6mSIPJjZ11Zszrg3oQ==",
+      "version": "4.2.0",
+      "resolved": "https://registry.npmjs.org/default-gateway/-/default-gateway-4.2.0.tgz",
+      "integrity": "sha512-h6sMrVB1VMWVrW13mSc6ia/DwYYw5MN6+exNu1OaJeFac5aSAvwM7lZ0NVfTABuSkQelr4h5oebg3KB1XPdjgA==",
       "dev": true,
       "requires": {
         "execa": "^1.0.0",
@@ -3641,17 +3748,17 @@
       "dev": true
     },
     "del": {
-      "version": "3.0.0",
-      "resolved": "https://registry.npmjs.org/del/-/del-3.0.0.tgz",
-      "integrity": "sha1-U+z2mf/LyzljdpGrE7rxYIGXZuU=",
+      "version": "4.1.0",
+      "resolved": "https://registry.npmjs.org/del/-/del-4.1.0.tgz",
+      "integrity": "sha512-C4kvKNlYrwXhKxz97BuohF8YoGgQ23Xm9lvoHmgT7JaPGprSEjk3+XFled74Yt/x0ZABUHg2D67covzAPUKx5Q==",
       "dev": true,
       "requires": {
         "globby": "^6.1.0",
-        "is-path-cwd": "^1.0.0",
-        "is-path-in-cwd": "^1.0.0",
-        "p-map": "^1.1.1",
-        "pify": "^3.0.0",
-        "rimraf": "^2.2.8"
+        "is-path-cwd": "^2.0.0",
+        "is-path-in-cwd": "^2.0.0",
+        "p-map": "^2.0.0",
+        "pify": "^4.0.1",
+        "rimraf": "^2.6.3"
       },
       "dependencies": {
         "globby": {
@@ -3674,6 +3781,12 @@
               "dev": true
             }
           }
+        },
+        "pify": {
+          "version": "4.0.1",
+          "resolved": "https://registry.npmjs.org/pify/-/pify-4.0.1.tgz",
+          "integrity": "sha512-uB80kBFb/tfd68bVleG9T5GGsGPjJrLAUpR5PZIrhBnIaRTQRjqdJSsIKkOP6OAIFbj7GOrcudc5pNjZ+geV2g==",
+          "dev": true
         }
       }
     },
@@ -3711,11 +3824,12 @@
       "integrity": "sha1-l4hXRCxEdJ5CBmE+N5RiBYJqvYA=",
       "dev": true
     },
-    "detect-file": {
-      "version": "1.0.0",
-      "resolved": "https://registry.npmjs.org/detect-file/-/detect-file-1.0.0.tgz",
-      "integrity": "sha1-8NZtA2cqglyxtzvbP+YjEMjlUrc=",
-      "dev": true
+    "detect-libc": {
+      "version": "1.0.3",
+      "resolved": "https://registry.npmjs.org/detect-libc/-/detect-libc-1.0.3.tgz",
+      "integrity": "sha1-+hN8S9aY7fVc1c0CrFWfkaTEups=",
+      "dev": true,
+      "optional": true
     },
     "detect-node": {
       "version": "2.0.4",
@@ -3920,6 +4034,12 @@
         "minimalistic-crypto-utils": "^1.0.0"
       }
     },
+    "emoji-regex": {
+      "version": "7.0.3",
+      "resolved": "https://registry.npmjs.org/emoji-regex/-/emoji-regex-7.0.3.tgz",
+      "integrity": "sha512-CwBLREIQ7LvYFB0WyRvwhq5N5qPhc6PMjD6bYggFlI5YyDgl+0vxq5VHbMOFqLg7hfWzmu8T5Z1QofhmTIhItA==",
+      "dev": true
+    },
     "emojis-list": {
       "version": "2.1.0",
       "resolved": "https://registry.npmjs.org/emojis-list/-/emojis-list-2.1.0.tgz",
@@ -4415,34 +4535,6 @@
         }
       }
     },
-    "expand-braces": {
-      "version": "0.1.2",
-      "resolved": "https://registry.npmjs.org/expand-braces/-/expand-braces-0.1.2.tgz",
-      "integrity": "sha1-SIsdHSRRyz06axks/AMPRMWFX+o=",
-      "dev": true,
-      "requires": {
-        "array-slice": "^0.2.3",
-        "array-unique": "^0.2.1",
-        "braces": "^0.1.2"
-      },
-      "dependencies": {
-        "array-unique": {
-          "version": "0.2.1",
-          "resolved": "https://registry.npmjs.org/array-unique/-/array-unique-0.2.1.tgz",
-          "integrity": "sha1-odl8yvy8JiXMcPrc6zalDFiwGlM=",
-          "dev": true
-        },
-        "braces": {
-          "version": "0.1.5",
-          "resolved": "https://registry.npmjs.org/braces/-/braces-0.1.5.tgz",
-          "integrity": "sha1-wIVxEIUpHYt1/ddOqw+FlygHEeY=",
-          "dev": true,
-          "requires": {
-            "expand-range": "^0.1.0"
-          }
-        }
-      }
-    },
     "expand-brackets": {
       "version": "2.1.4",
       "resolved": "https://registry.npmjs.org/expand-brackets/-/expand-brackets-2.1.4.tgz",
@@ -4493,39 +4585,6 @@
         }
       }
     },
-    "expand-range": {
-      "version": "0.1.1",
-      "resolved": "https://registry.npmjs.org/expand-range/-/expand-range-0.1.1.tgz",
-      "integrity": "sha1-TLjtoJk8pW+k9B/ELzy7TMrf8EQ=",
-      "dev": true,
-      "requires": {
-        "is-number": "^0.1.1",
-        "repeat-string": "^0.2.2"
-      },
-      "dependencies": {
-        "is-number": {
-          "version": "0.1.1",
-          "resolved": "https://registry.npmjs.org/is-number/-/is-number-0.1.1.tgz",
-          "integrity": "sha1-aaevEWlj1HIG7JvZtIoUIW8eOAY=",
-          "dev": true
-        },
-        "repeat-string": {
-          "version": "0.2.2",
-          "resolved": "https://registry.npmjs.org/repeat-string/-/repeat-string-0.2.2.tgz",
-          "integrity": "sha1-x6jTI2BoNiBZp+RlH8aITosftK4=",
-          "dev": true
-        }
-      }
-    },
-    "expand-tilde": {
-      "version": "2.0.2",
-      "resolved": "https://registry.npmjs.org/expand-tilde/-/expand-tilde-2.0.2.tgz",
-      "integrity": "sha1-l+gBqgUt8CRU3kawK/YhZCzchQI=",
-      "dev": true,
-      "requires": {
-        "homedir-polyfill": "^1.0.1"
-      }
-    },
     "expose-loader": {
       "version": "0.7.5",
       "resolved": "https://registry.npmjs.org/expose-loader/-/expose-loader-0.7.5.tgz",
@@ -4891,29 +4950,6 @@
         "locate-path": "^2.0.0"
       }
     },
-    "findup-sync": {
-      "version": "2.0.0",
-      "resolved": "https://registry.npmjs.org/findup-sync/-/findup-sync-2.0.0.tgz",
-      "integrity": "sha1-kyaxSIwi0aYIhlCoaQGy2akKLLw=",
-      "dev": true,
-      "requires": {
-        "detect-file": "^1.0.0",
-        "is-glob": "^3.1.0",
-        "micromatch": "^3.0.4",
-        "resolve-dir": "^1.0.1"
-      },
-      "dependencies": {
-        "is-glob": {
-          "version": "3.1.0",
-          "resolved": "https://registry.npmjs.org/is-glob/-/is-glob-3.1.0.tgz",
-          "integrity": "sha1-e6WuJCF4BKxwcHuWkiVnSGzD6Eo=",
-          "dev": true,
-          "requires": {
-            "is-extglob": "^2.1.0"
-          }
-        }
-      }
-    },
     "flat": {
       "version": "4.1.0",
       "resolved": "https://registry.npmjs.org/flat/-/flat-4.1.0.tgz",
@@ -5062,6 +5098,25 @@
         "null-check": "^1.0.0"
       }
     },
+    "fs-extra": {
+      "version": "7.0.1",
+      "resolved": "https://registry.npmjs.org/fs-extra/-/fs-extra-7.0.1.tgz",
+      "integrity": "sha512-YJDaCJZEnBmcbw13fvdAM9AwNOJwOzrE4pqMqBq5nFiEqXUqHwlK4B+3pUw6JNvfSPtX05xFHtYy/1ni01eGCw==",
+      "dev": true,
+      "requires": {
+        "graceful-fs": "^4.1.2",
+        "jsonfile": "^4.0.0",
+        "universalify": "^0.1.0"
+      }
+    },
+    "fs-minipass": {
+      "version": "1.2.5",
+      "resolved": "https://registry.npmjs.org/fs-minipass/-/fs-minipass-1.2.5.tgz",
+      "integrity": "sha512-JhBl0skXjUPCFH7x6x61gQxrKyXsxB5gcgePLZCwfyCGGsTISMoIeObbrvVeP6Xmyaudw4TT43qV2Gz+iyd2oQ==",
+      "requires": {
+        "minipass": "^2.2.1"
+      }
+    },
     "fs-write-stream-atomic": {
       "version": "1.0.10",
       "resolved": "https://registry.npmjs.org/fs-write-stream-atomic/-/fs-write-stream-atomic-1.0.10.tgz",
@@ -5077,8 +5132,7 @@
     "fs.realpath": {
       "version": "1.0.0",
       "resolved": "https://registry.npmjs.org/fs.realpath/-/fs.realpath-1.0.0.tgz",
-      "integrity": "sha1-FQStJSMVjKpA20onh8sBQRmU6k8=",
-      "dev": true
+      "integrity": "sha1-FQStJSMVjKpA20onh8sBQRmU6k8="
     },
     "fsevents": {
       "version": "1.2.7",
@@ -5091,137 +5145,23 @@
         "node-pre-gyp": "^0.10.0"
       },
       "dependencies": {
-        "abbrev": {
-          "version": "1.1.1",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
         "ansi-regex": {
           "version": "2.1.1",
-          "bundled": true,
-          "dev": true
-        },
-        "aproba": {
-          "version": "1.2.0",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "are-we-there-yet": {
-          "version": "1.1.5",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "delegates": "^1.0.0",
-            "readable-stream": "^2.0.6"
-          }
-        },
-        "balanced-match": {
-          "version": "1.0.0",
-          "bundled": true,
-          "dev": true
-        },
-        "brace-expansion": {
-          "version": "1.1.11",
-          "bundled": true,
-          "dev": true,
-          "requires": {
-            "balanced-match": "^1.0.0",
-            "concat-map": "0.0.1"
-          }
-        },
-        "chownr": {
-          "version": "1.1.1",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "code-point-at": {
-          "version": "1.1.0",
-          "bundled": true,
-          "dev": true
-        },
-        "concat-map": {
-          "version": "0.0.1",
-          "bundled": true,
-          "dev": true
-        },
-        "console-control-strings": {
-          "version": "1.1.0",
-          "bundled": true,
-          "dev": true
-        },
-        "core-util-is": {
-          "version": "1.0.2",
-          "bundled": true,
-          "dev": true,
-          "optional": true
+          "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-2.1.1.tgz",
+          "integrity": "sha1-w7M6te42DYbg5ijwRorn7yfWVN8="
         },
         "debug": {
           "version": "2.6.9",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
+          "resolved": "https://registry.npmjs.org/debug/-/debug-2.6.9.tgz",
+          "integrity": "sha512-bC7ElrdJaJnPbAP+1EotYvqZsb3ecl5wi6Bfi6BJTUcNowp6cvspg0jXznRTKDjm/E7AdgFBVeAPVMNcKGsHMA==",
           "requires": {
             "ms": "2.0.0"
           }
         },
-        "deep-extend": {
-          "version": "0.6.0",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "delegates": {
-          "version": "1.0.0",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "detect-libc": {
-          "version": "1.0.3",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "fs-minipass": {
-          "version": "1.2.5",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "minipass": "^2.2.1"
-          }
-        },
-        "fs.realpath": {
-          "version": "1.0.0",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "gauge": {
-          "version": "2.7.4",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "aproba": "^1.0.3",
-            "console-control-strings": "^1.0.0",
-            "has-unicode": "^2.0.0",
-            "object-assign": "^4.1.0",
-            "signal-exit": "^3.0.0",
-            "string-width": "^1.0.1",
-            "strip-ansi": "^3.0.1",
-            "wide-align": "^1.1.0"
-          }
-        },
         "glob": {
           "version": "7.1.3",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
+          "resolved": "https://registry.npmjs.org/glob/-/glob-7.1.3.tgz",
+          "integrity": "sha512-vcfuiIxogLV4DlGBHIUOwI0IbrJ8HWPc4MU7HzviGeNho/UJDfi6B5p3sHeWIQ0KGIU0Jpxi5ZHxemQfLkkAwQ==",
           "requires": {
             "fs.realpath": "^1.0.0",
             "inflight": "^1.0.4",
@@ -5231,255 +5171,42 @@
             "path-is-absolute": "^1.0.0"
           }
         },
-        "has-unicode": {
-          "version": "2.0.1",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "iconv-lite": {
-          "version": "0.4.24",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "safer-buffer": ">= 2.1.2 < 3"
-          }
-        },
-        "ignore-walk": {
-          "version": "3.0.1",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "minimatch": "^3.0.4"
-          }
-        },
-        "inflight": {
-          "version": "1.0.6",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "once": "^1.3.0",
-            "wrappy": "1"
-          }
-        },
-        "inherits": {
-          "version": "2.0.3",
-          "bundled": true,
-          "dev": true
-        },
-        "ini": {
-          "version": "1.3.5",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
         "is-fullwidth-code-point": {
           "version": "1.0.0",
-          "bundled": true,
-          "dev": true,
+          "resolved": "https://registry.npmjs.org/is-fullwidth-code-point/-/is-fullwidth-code-point-1.0.0.tgz",
+          "integrity": "sha1-754xOG8DGn8NZDr4L95QxFfvAMs=",
           "requires": {
             "number-is-nan": "^1.0.0"
           }
         },
-        "isarray": {
-          "version": "1.0.0",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "minimatch": {
-          "version": "3.0.4",
-          "bundled": true,
-          "dev": true,
-          "requires": {
-            "brace-expansion": "^1.1.7"
-          }
-        },
         "minimist": {
           "version": "0.0.8",
-          "bundled": true,
-          "dev": true
-        },
-        "minipass": {
-          "version": "2.3.5",
-          "bundled": true,
-          "dev": true,
-          "requires": {
-            "safe-buffer": "^5.1.2",
-            "yallist": "^3.0.0"
-          }
-        },
-        "minizlib": {
-          "version": "1.2.1",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "minipass": "^2.2.1"
-          }
-        },
-        "mkdirp": {
-          "version": "0.5.1",
-          "bundled": true,
-          "dev": true,
-          "requires": {
-            "minimist": "0.0.8"
-          }
+          "resolved": "https://registry.npmjs.org/minimist/-/minimist-0.0.8.tgz",
+          "integrity": "sha1-hX/Kv8M5fSYluCKCYuhqp6ARsF0="
         },
         "ms": {
           "version": "2.0.0",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "needle": {
-          "version": "2.2.4",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "debug": "^2.1.2",
-            "iconv-lite": "^0.4.4",
-            "sax": "^1.2.4"
-          }
-        },
-        "node-pre-gyp": {
-          "version": "0.10.3",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "detect-libc": "^1.0.2",
-            "mkdirp": "^0.5.1",
-            "needle": "^2.2.1",
-            "nopt": "^4.0.1",
-            "npm-packlist": "^1.1.6",
-            "npmlog": "^4.0.2",
-            "rc": "^1.2.7",
-            "rimraf": "^2.6.1",
-            "semver": "^5.3.0",
-            "tar": "^4"
-          }
+          "resolved": "https://registry.npmjs.org/ms/-/ms-2.0.0.tgz",
+          "integrity": "sha1-VgiurfwAvmwpAd9fmGF4jeDVl8g="
         },
         "nopt": {
           "version": "4.0.1",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
+          "resolved": "https://registry.npmjs.org/nopt/-/nopt-4.0.1.tgz",
+          "integrity": "sha1-0NRoWv1UFRk8jHUFYC0NF81kR00=",
           "requires": {
             "abbrev": "1",
             "osenv": "^0.1.4"
           }
         },
-        "npm-bundled": {
-          "version": "1.0.5",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "npm-packlist": {
-          "version": "1.2.0",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "ignore-walk": "^3.0.1",
-            "npm-bundled": "^1.0.1"
-          }
-        },
-        "npmlog": {
-          "version": "4.1.2",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "are-we-there-yet": "~1.1.2",
-            "console-control-strings": "~1.1.0",
-            "gauge": "~2.7.3",
-            "set-blocking": "~2.0.0"
-          }
-        },
-        "number-is-nan": {
-          "version": "1.0.1",
-          "bundled": true,
-          "dev": true
-        },
-        "object-assign": {
-          "version": "4.1.1",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "once": {
-          "version": "1.4.0",
-          "bundled": true,
-          "dev": true,
-          "requires": {
-            "wrappy": "1"
-          }
-        },
-        "os-homedir": {
-          "version": "1.0.2",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "os-tmpdir": {
-          "version": "1.0.2",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "osenv": {
-          "version": "0.1.5",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "os-homedir": "^1.0.0",
-            "os-tmpdir": "^1.0.0"
-          }
-        },
-        "path-is-absolute": {
-          "version": "1.0.1",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
         "process-nextick-args": {
           "version": "2.0.0",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "rc": {
-          "version": "1.2.8",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "deep-extend": "^0.6.0",
-            "ini": "~1.3.0",
-            "minimist": "^1.2.0",
-            "strip-json-comments": "~2.0.1"
-          },
-          "dependencies": {
-            "minimist": {
-              "version": "1.2.0",
-              "bundled": true,
-              "dev": true,
-              "optional": true
-            }
-          }
+          "resolved": "https://registry.npmjs.org/process-nextick-args/-/process-nextick-args-2.0.0.tgz",
+          "integrity": "sha512-MtEC1TqN0EU5nephaJ4rAtThHtC86dNN9qCuEhtshvpVBkAW5ZO7BASN9REnF9eoXGcRub+pFuKEpOHE+HbEMw=="
         },
         "readable-stream": {
           "version": "2.3.6",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
+          "resolved": "https://registry.npmjs.org/readable-stream/-/readable-stream-2.3.6.tgz",
+          "integrity": "sha512-tQtKA9WIAhBF3+VLAseyMqZeBjW0AHJoxOtYqSUZNJxauErmLbVm2FW1y+J/YA9dUrAC39ITejlZWhVIwawkKw==",
           "requires": {
             "core-util-is": "~1.0.0",
             "inherits": "~2.0.3",
@@ -5490,88 +5217,26 @@
             "util-deprecate": "~1.0.1"
           }
         },
-        "rimraf": {
-          "version": "2.6.3",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "glob": "^7.1.3"
-          }
-        },
-        "safe-buffer": {
-          "version": "5.1.2",
-          "bundled": true,
-          "dev": true
-        },
-        "safer-buffer": {
-          "version": "2.1.2",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "sax": {
-          "version": "1.2.4",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "semver": {
-          "version": "5.6.0",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "set-blocking": {
-          "version": "2.0.0",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "signal-exit": {
-          "version": "3.0.2",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "string-width": {
-          "version": "1.0.2",
-          "bundled": true,
-          "dev": true,
-          "requires": {
-            "code-point-at": "^1.0.0",
-            "is-fullwidth-code-point": "^1.0.0",
-            "strip-ansi": "^3.0.0"
-          }
-        },
         "string_decoder": {
           "version": "1.1.1",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
+          "resolved": "https://registry.npmjs.org/string_decoder/-/string_decoder-1.1.1.tgz",
+          "integrity": "sha512-n/ShnvDi6FHbbVfviro+WojiFzv+s8MPMHBczVePfUpDJLwoLT0ht1l4YwBCbi8pJAveEEdnkHyPyTP/mzRfwg==",
           "requires": {
             "safe-buffer": "~5.1.0"
           }
         },
         "strip-ansi": {
           "version": "3.0.1",
-          "bundled": true,
-          "dev": true,
+          "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-3.0.1.tgz",
+          "integrity": "sha1-ajhfuIU9lS1f8F0Oiq+UJ43GPc8=",
           "requires": {
             "ansi-regex": "^2.0.0"
           }
         },
-        "strip-json-comments": {
-          "version": "2.0.1",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
         "tar": {
           "version": "4.4.8",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
+          "resolved": "https://registry.npmjs.org/tar/-/tar-4.4.8.tgz",
+          "integrity": "sha512-LzHF64s5chPQQS0IYBn9IN5h3i98c12bo4NCO7e0sGM2llXQ3p2FGC5sdENN4cTW48O915Sh+x+EXx7XW96xYQ==",
           "requires": {
             "chownr": "^1.1.1",
             "fs-minipass": "^1.2.5",
@@ -5582,30 +5247,10 @@
             "yallist": "^3.0.2"
           }
         },
-        "util-deprecate": {
-          "version": "1.0.2",
-          "bundled": true,
-          "dev": true,
-          "optional": true
-        },
-        "wide-align": {
-          "version": "1.1.3",
-          "bundled": true,
-          "dev": true,
-          "optional": true,
-          "requires": {
-            "string-width": "^1.0.2 || 2"
-          }
-        },
-        "wrappy": {
-          "version": "1.0.2",
-          "bundled": true,
-          "dev": true
-        },
         "yallist": {
           "version": "3.0.3",
-          "bundled": true,
-          "dev": true
+          "resolved": "https://registry.npmjs.org/yallist/-/yallist-3.0.3.tgz",
+          "integrity": "sha512-S+Zk8DEWE6oKpV+vI3qWkaK+jSbIK86pCwe2IF/xwIpQ8jEuxpw9NyaGjmp9+BoJv5FV2piqCDcoCtStppiq2A=="
         }
       }
     },
@@ -5790,36 +5435,12 @@
       "integrity": "sha1-jFoUlNIGbFcMw7/kSWF1rMTVAqs=",
       "dev": true
     },
-    "global-modules": {
-      "version": "1.0.0",
-      "resolved": "https://registry.npmjs.org/global-modules/-/global-modules-1.0.0.tgz",
-      "integrity": "sha512-sKzpEkf11GpOFuw0Zzjzmt4B4UZwjOcG757PPvrfhxcLFbq0wpsgpOqxpxtxFiCG4DtG93M6XRVbF2oGdev7bg==",
-      "dev": true,
-      "requires": {
-        "global-prefix": "^1.0.1",
-        "is-windows": "^1.0.1",
-        "resolve-dir": "^1.0.0"
-      }
-    },
     "global-modules-path": {
       "version": "2.3.1",
       "resolved": "https://registry.npmjs.org/global-modules-path/-/global-modules-path-2.3.1.tgz",
       "integrity": "sha512-y+shkf4InI7mPRHSo2b/k6ix6+NLDtyccYv86whhxrSGX9wjPX1VMITmrDbE1eh7zkzhiWtW2sHklJYoQ62Cxg==",
       "dev": true
     },
-    "global-prefix": {
-      "version": "1.0.2",
-      "resolved": "https://registry.npmjs.org/global-prefix/-/global-prefix-1.0.2.tgz",
-      "integrity": "sha1-2/dDxsFJklk8ZVVoy2btMsASLr4=",
-      "dev": true,
-      "requires": {
-        "expand-tilde": "^2.0.2",
-        "homedir-polyfill": "^1.0.1",
-        "ini": "^1.3.4",
-        "is-windows": "^1.0.1",
-        "which": "^1.2.14"
-      }
-    },
     "globals": {
       "version": "11.10.0",
       "resolved": "https://registry.npmjs.org/globals/-/globals-11.10.0.tgz",
@@ -6035,15 +5656,6 @@
         "minimalistic-crypto-utils": "^1.0.1"
       }
     },
-    "homedir-polyfill": {
-      "version": "1.0.3",
-      "resolved": "https://registry.npmjs.org/homedir-polyfill/-/homedir-polyfill-1.0.3.tgz",
-      "integrity": "sha512-eSmmWE5bZTK2Nou4g0AI3zZ9rswp7GRKoKXS1BLUkvPviOqs4YTN1djQIqrXy9k5gEtdLPy86JjRwsNM9tnDcA==",
-      "dev": true,
-      "requires": {
-        "parse-passwd": "^1.0.0"
-      }
-    },
     "hosted-git-info": {
       "version": "2.7.1",
       "resolved": "https://registry.npmjs.org/hosted-git-info/-/hosted-git-info-2.7.1.tgz",
@@ -6412,6 +6024,16 @@
       "integrity": "sha1-2B8kA3bQuk8Nd4lyw60lh0EXpGM=",
       "dev": true
     },
+    "ignore-walk": {
+      "version": "3.0.1",
+      "resolved": "https://registry.npmjs.org/ignore-walk/-/ignore-walk-3.0.1.tgz",
+      "integrity": "sha512-DTVlMx3IYPe0/JJcYP7Gxg7ttZZu3IInhuEhbchuqneY9wWe5Ojy2mXLBaQFUQmo0AW2r3qG7m1mg86js+gnlQ==",
+      "dev": true,
+      "optional": true,
+      "requires": {
+        "minimatch": "^3.0.4"
+      }
+    },
     "image-size": {
       "version": "0.5.5",
       "resolved": "https://registry.npmjs.org/image-size/-/image-size-0.5.5.tgz",
@@ -6479,7 +6101,6 @@
       "version": "1.0.6",
       "resolved": "https://registry.npmjs.org/inflight/-/inflight-1.0.6.tgz",
       "integrity": "sha1-Sb1jMdfQLQwJvJEKEHW6gWW1bfk=",
-      "dev": true,
       "requires": {
         "once": "^1.3.0",
         "wrappy": "1"
@@ -6494,7 +6115,8 @@
       "version": "1.3.5",
       "resolved": "https://registry.npmjs.org/ini/-/ini-1.3.5.tgz",
       "integrity": "sha512-RZY5huIKCMRWDUqZlEi72f/lmXKMvuszcMBduliQ3nnWbx9X/ZBQO7DijMEYS9EhHBb2qacRUMtC7svLwe0lcw==",
-      "dev": true
+      "dev": true,
+      "optional": true
     },
     "inquirer": {
       "version": "6.2.1",
@@ -6535,12 +6157,12 @@
       }
     },
     "internal-ip": {
-      "version": "4.2.0",
-      "resolved": "https://registry.npmjs.org/internal-ip/-/internal-ip-4.2.0.tgz",
-      "integrity": "sha512-ZY8Rk+hlvFeuMmG5uH1MXhhdeMntmIaxaInvAmzMq/SHV8rv4Kh+6GiQNNDQd0wZFrcO+FiTBo8lui/osKOyJw==",
+      "version": "4.3.0",
+      "resolved": "https://registry.npmjs.org/internal-ip/-/internal-ip-4.3.0.tgz",
+      "integrity": "sha512-S1zBo1D6zcsyuC6PMmY5+55YMILQ9av8lotMx447Bq6SAgo/sDK6y6uUKmuYhW7eacnIhFfsPmCNYdDzsnnDCg==",
       "dev": true,
       "requires": {
-        "default-gateway": "^4.0.1",
+        "default-gateway": "^4.2.0",
         "ipaddr.js": "^1.9.0"
       },
       "dependencies": {
@@ -6773,15 +6395,15 @@
       }
     },
     "is-path-cwd": {
-      "version": "1.0.0",
-      "resolved": "https://registry.npmjs.org/is-path-cwd/-/is-path-cwd-1.0.0.tgz",
-      "integrity": "sha1-0iXsIxMuie3Tj9p2dHLmLmXxEG0=",
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/is-path-cwd/-/is-path-cwd-2.0.0.tgz",
+      "integrity": "sha512-m5dHHzpOXEiv18JEORttBO64UgTEypx99vCxQLjbBvGhOJxnTNglYoFXxwo6AbsQb79sqqycQEHv2hWkHZAijA==",
       "dev": true
     },
     "is-path-in-cwd": {
-      "version": "1.0.1",
-      "resolved": "https://registry.npmjs.org/is-path-in-cwd/-/is-path-in-cwd-1.0.1.tgz",
-      "integrity": "sha512-FjV1RTW48E7CWM7eE/J2NJvAEEVektecDBVBE5Hh3nM1Jd0kvhHtX68Pr3xsDf857xt3Y4AkwVULK1Vku62aaQ==",
+      "version": "2.0.0",
+      "resolved": "https://registry.npmjs.org/is-path-in-cwd/-/is-path-in-cwd-2.0.0.tgz",
+      "integrity": "sha512-6Vz5Gc9s/sDA3JBVu0FzWufm8xaBsqy1zn8Q6gmvGP6nSDMw78aS4poBNeatWjaRpTpxxLn1WOndAiOlk+qY8A==",
       "dev": true,
       "requires": {
         "is-path-inside": "^1.0.0"
@@ -7037,6 +6659,15 @@
         }
       }
     },
+    "jsonfile": {
+      "version": "4.0.0",
+      "resolved": "https://registry.npmjs.org/jsonfile/-/jsonfile-4.0.0.tgz",
+      "integrity": "sha1-h3Gq4HmbZAdrdmQPygWPnBDjPss=",
+      "dev": true,
+      "requires": {
+        "graceful-fs": "^4.1.6"
+      }
+    },
     "jsprim": {
       "version": "1.4.1",
       "resolved": "https://registry.npmjs.org/jsprim/-/jsprim-1.4.1.tgz",
@@ -7079,28 +6710,27 @@
       }
     },
     "karma": {
-      "version": "4.0.0",
-      "resolved": "https://registry.npmjs.org/karma/-/karma-4.0.0.tgz",
-      "integrity": "sha512-EFoFs3F6G0BcUGPNOn/YloGOb3h09hzTguyXlg6loHlKY76qbJikkcyPk43m2kfRF65TUGda/mig29QQtyhm1g==",
+      "version": "4.0.1",
+      "resolved": "https://registry.npmjs.org/karma/-/karma-4.0.1.tgz",
+      "integrity": "sha512-ind+4s03BqIXas7ZmraV3/kc5+mnqwCd+VDX1FndS6jxbt03kQKX2vXrWxNLuCjVYmhMwOZosAEKMM0a2q7w7A==",
       "dev": true,
       "requires": {
         "bluebird": "^3.3.0",
         "body-parser": "^1.16.1",
+        "braces": "^2.3.2",
         "chokidar": "^2.0.3",
         "colors": "^1.1.0",
-        "combine-lists": "^1.0.0",
         "connect": "^3.6.0",
         "core-js": "^2.2.0",
         "di": "^0.0.1",
         "dom-serialize": "^2.2.0",
-        "expand-braces": "^0.1.1",
         "flatted": "^2.0.0",
         "glob": "^7.1.1",
         "graceful-fs": "^4.1.2",
         "http-proxy": "^1.13.0",
         "isbinaryfile": "^3.0.0",
-        "lodash": "^4.17.5",
-        "log4js": "^3.0.0",
+        "lodash": "^4.17.11",
+        "log4js": "^4.0.0",
         "mime": "^2.3.1",
         "minimatch": "^3.0.2",
         "optimist": "^0.6.1",
@@ -7530,33 +7160,16 @@
       }
     },
     "log4js": {
-      "version": "3.0.6",
-      "resolved": "https://registry.npmjs.org/log4js/-/log4js-3.0.6.tgz",
-      "integrity": "sha512-ezXZk6oPJCWL483zj64pNkMuY/NcRX5MPiB0zE6tjZM137aeusrOnW1ecxgF9cmwMWkBMhjteQxBPoZBh9FDxQ==",
+      "version": "4.1.0",
+      "resolved": "https://registry.npmjs.org/log4js/-/log4js-4.1.0.tgz",
+      "integrity": "sha512-eDa+zZPeVEeK6QGJAePyXM6pg4P3n3TO5rX9iZMVY48JshsTyLJZLIL5HipI1kQ2qLsSyOpUqNND/C5H4WhhiA==",
       "dev": true,
       "requires": {
-        "circular-json": "^0.5.5",
-        "date-format": "^1.2.0",
-        "debug": "^3.1.0",
+        "date-format": "^2.0.0",
+        "debug": "^4.1.1",
+        "flatted": "^2.0.0",
         "rfdc": "^1.1.2",
-        "streamroller": "0.7.0"
-      },
-      "dependencies": {
-        "circular-json": {
-          "version": "0.5.9",
-          "resolved": "https://registry.npmjs.org/circular-json/-/circular-json-0.5.9.tgz",
-          "integrity": "sha512-4ivwqHpIFJZBuhN3g/pEcdbnGUywkBblloGbkglyloVjjR3uT6tieI89MVOfbP2tHX5sgb01FuLgAOzebNlJNQ==",
-          "dev": true
-        },
-        "debug": {
-          "version": "3.2.6",
-          "resolved": "https://registry.npmjs.org/debug/-/debug-3.2.6.tgz",
-          "integrity": "sha512-mel+jf7nrtEl5Pn1Qx46zARXKDpBbvzezse7p7LqINmdoIk8PYP5SySaxEmYv6TZ0JyEKA1hsCId6DIhgITtWQ==",
-          "dev": true,
-          "requires": {
-            "ms": "^2.1.1"
-          }
-        }
+        "streamroller": "^1.0.4"
       }
     },
     "loglevel": {
@@ -7784,9 +7397,9 @@
       }
     },
     "mime": {
-      "version": "2.4.0",
-      "resolved": "https://registry.npmjs.org/mime/-/mime-2.4.0.tgz",
-      "integrity": "sha512-ikBcWwyqXQSHKtciCcctu9YfPbFYZ4+gbHEmE0Q8jzcTYQg5dHCr3g2wwAZjPoJfQVXZq6KXAjpXOTf5/cjT7w==",
+      "version": "2.4.2",
+      "resolved": "https://registry.npmjs.org/mime/-/mime-2.4.2.tgz",
+      "integrity": "sha512-zJBfZDkwRu+j3Pdd2aHsR5GfH2jIWhmL1ZzBoc+X+3JEti2hbArWcyJ+1laC1D2/U/W1a/+Cegj0/OnEU2ybjg==",
       "dev": true
     },
     "mime-db": {
@@ -7874,16 +7487,39 @@
       "version": "3.0.4",
       "resolved": "https://registry.npmjs.org/minimatch/-/minimatch-3.0.4.tgz",
       "integrity": "sha512-yJHVQEhyqPLUTgt9B83PXu6W3rx4MvvHvSUvToogpwoGDOUQ+yDrR0HRot+yOCdCO7u4hX3pWft6kWBBcqh0UA==",
-      "dev": true,
       "requires": {
         "brace-expansion": "^1.1.7"
       }
     },
-    "minimist": {
-      "version": "1.2.0",
-      "resolved": "https://registry.npmjs.org/minimist/-/minimist-1.2.0.tgz",
-      "integrity": "sha1-o1AIsg9BOD7sH7kU9M1d95omQoQ=",
-      "dev": true
+    "minimist": {
+      "version": "1.2.0",
+      "resolved": "https://registry.npmjs.org/minimist/-/minimist-1.2.0.tgz",
+      "integrity": "sha1-o1AIsg9BOD7sH7kU9M1d95omQoQ=",
+      "dev": true
+    },
+    "minipass": {
+      "version": "2.3.5",
+      "resolved": "https://registry.npmjs.org/minipass/-/minipass-2.3.5.tgz",
+      "integrity": "sha512-Gi1W4k059gyRbyVUZQ4mEqLm0YIUiGYfvxhF6SIlk3ui1WVxMTGfGdQ2SInh3PDrRTVvPKgULkpJtT4RH10+VA==",
+      "requires": {
+        "safe-buffer": "^5.1.2",
+        "yallist": "^3.0.0"
+      },
+      "dependencies": {
+        "yallist": {
+          "version": "3.0.3",
+          "resolved": "https://registry.npmjs.org/yallist/-/yallist-3.0.3.tgz",
+          "integrity": "sha512-S+Zk8DEWE6oKpV+vI3qWkaK+jSbIK86pCwe2IF/xwIpQ8jEuxpw9NyaGjmp9+BoJv5FV2piqCDcoCtStppiq2A=="
+        }
+      }
+    },
+    "minizlib": {
+      "version": "1.2.1",
+      "resolved": "https://registry.npmjs.org/minizlib/-/minizlib-1.2.1.tgz",
+      "integrity": "sha512-7+4oTUOWKg7AuL3vloEWekXY2/D20cevzsrNT2kGWm+39J9hGTCBv8VI5Pm5lXZ/o3/mdR4f8rflAPhnQb8mPA==",
+      "requires": {
+        "minipass": "^2.2.1"
+      }
     },
     "mississippi": {
       "version": "2.0.0",
@@ -7952,7 +7588,6 @@
       "version": "0.5.1",
       "resolved": "https://registry.npmjs.org/mkdirp/-/mkdirp-0.5.1.tgz",
       "integrity": "sha1-MAV0OOrGz3+MR2fzhkjWaX11yQM=",
-      "dev": true,
       "requires": {
         "minimist": "0.0.8"
       },
@@ -7960,15 +7595,14 @@
         "minimist": {
           "version": "0.0.8",
           "resolved": "https://registry.npmjs.org/minimist/-/minimist-0.0.8.tgz",
-          "integrity": "sha1-hX/Kv8M5fSYluCKCYuhqp6ARsF0=",
-          "dev": true
+          "integrity": "sha1-hX/Kv8M5fSYluCKCYuhqp6ARsF0="
         }
       }
     },
     "mocha": {
-      "version": "6.0.1",
-      "resolved": "https://registry.npmjs.org/mocha/-/mocha-6.0.1.tgz",
-      "integrity": "sha512-tQzCxWqxSD6Oyg5r7Ptbev0yAMD8p+Vfh4snPFuiUsWqYj0eVYTDT2DkEY307FTj0WRlIWN9rWMMAUzRmijgVQ==",
+      "version": "6.1.3",
+      "resolved": "https://registry.npmjs.org/mocha/-/mocha-6.1.3.tgz",
+      "integrity": "sha512-QdE/w//EPHrqgT5PNRUjRVHy6IJAzAf1R8n2O8W8K2RZ+NbPfOD5cBDp+PGa2Gptep37C/TdBiaNwakppEzEbg==",
       "dev": true,
       "requires": {
         "ansi-colors": "3.2.3",
@@ -7976,23 +7610,23 @@
         "debug": "3.2.6",
         "diff": "3.5.0",
         "escape-string-regexp": "1.0.5",
-        "findup-sync": "2.0.0",
+        "find-up": "3.0.0",
         "glob": "7.1.3",
         "growl": "1.10.5",
         "he": "1.2.0",
-        "js-yaml": "3.12.0",
+        "js-yaml": "3.13.0",
         "log-symbols": "2.2.0",
         "minimatch": "3.0.4",
         "mkdirp": "0.5.1",
         "ms": "2.1.1",
-        "node-environment-flags": "1.0.4",
+        "node-environment-flags": "1.0.5",
         "object.assign": "4.1.0",
         "strip-json-comments": "2.0.1",
         "supports-color": "6.0.0",
         "which": "1.3.1",
         "wide-align": "1.1.3",
-        "yargs": "12.0.5",
-        "yargs-parser": "11.1.1",
+        "yargs": "13.2.2",
+        "yargs-parser": "13.0.0",
         "yargs-unparser": "1.5.0"
       },
       "dependencies": {
@@ -8003,9 +7637,9 @@
           "dev": true
         },
         "camelcase": {
-          "version": "5.0.0",
-          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-5.0.0.tgz",
-          "integrity": "sha512-faqwZqnWxbxn+F1d399ygeamQNy3lPp/H9H6rNrqYh4FSVCtcY+3cub1MxA8o9mDd55mM8Aghuu/kuyYA6VTsA==",
+          "version": "5.3.1",
+          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-5.3.1.tgz",
+          "integrity": "sha512-L28STB170nwWS63UjtlEOE3dldQApaJXZkOI1uMFfzf3rRuPegHaHesyee+YxQ+W6SvRDQV6UrdOdRiR153wJg==",
           "dev": true
         },
         "cliui": {
@@ -8017,6 +7651,18 @@
             "string-width": "^2.1.1",
             "strip-ansi": "^4.0.0",
             "wrap-ansi": "^2.0.0"
+          },
+          "dependencies": {
+            "string-width": {
+              "version": "2.1.1",
+              "resolved": "https://registry.npmjs.org/string-width/-/string-width-2.1.1.tgz",
+              "integrity": "sha512-nOqH59deCq9SRHlxq1Aw85Jnt4w6KvLKqWVik6oA9ZklXLNIOlqg4F2yrT1MVaTjAqvVwdfeZ7w7aCvJD7ugkw==",
+              "dev": true,
+              "requires": {
+                "is-fullwidth-code-point": "^2.0.0",
+                "strip-ansi": "^4.0.0"
+              }
+            }
           }
         },
         "debug": {
@@ -8049,6 +7695,12 @@
             "locate-path": "^3.0.0"
           }
         },
+        "get-caller-file": {
+          "version": "2.0.5",
+          "resolved": "https://registry.npmjs.org/get-caller-file/-/get-caller-file-2.0.5.tgz",
+          "integrity": "sha512-DyFP3BM/3YHTQOCUL/w0OZHR0lpKeGrxotcHWcqNEdnltqFwXVfhEBQ94eIo34AfQpo0rGki4cyIiftY06h2Fg==",
+          "dev": true
+        },
         "glob": {
           "version": "7.1.3",
           "resolved": "https://registry.npmjs.org/glob/-/glob-7.1.3.tgz",
@@ -8070,9 +7722,9 @@
           "dev": true
         },
         "js-yaml": {
-          "version": "3.12.0",
-          "resolved": "https://registry.npmjs.org/js-yaml/-/js-yaml-3.12.0.tgz",
-          "integrity": "sha512-PIt2cnwmPfL4hKNwqeiuz4bKfnzHTBv6HyVgjahA6mPLwPDzjDWrplJBMjHUFxku/N3FlmrbyPclad+I+4mJ3A==",
+          "version": "3.13.0",
+          "resolved": "https://registry.npmjs.org/js-yaml/-/js-yaml-3.13.0.tgz",
+          "integrity": "sha512-pZZoSxcCYco+DIKBTimr67J6Hy+EYGZDY/HCWC+iAEA9h1ByhMXAIVUXMcMFpOCxQ/xjXmPI2MkDL5HRm5eFrQ==",
           "dev": true,
           "requires": {
             "argparse": "^1.0.7",
@@ -8110,9 +7762,9 @@
           }
         },
         "p-limit": {
-          "version": "2.1.0",
-          "resolved": "https://registry.npmjs.org/p-limit/-/p-limit-2.1.0.tgz",
-          "integrity": "sha512-NhURkNcrVB+8hNfLuysU8enY5xn2KXphsHBaC2YmRNTZRc7RWusw6apSpdEj3jo4CMb6W9nrF6tTnsJsJeyu6g==",
+          "version": "2.2.0",
+          "resolved": "https://registry.npmjs.org/p-limit/-/p-limit-2.2.0.tgz",
+          "integrity": "sha512-pZbTJpoUsCzV48Mc9Nh51VbwO0X9cuPFE8gYwx9BTCt9SF8/b7Zljd2fVgOxhIF/HDTKgpVzs+GPhyKfjLLFRQ==",
           "dev": true,
           "requires": {
             "p-try": "^2.0.0"
@@ -8128,11 +7780,45 @@
           }
         },
         "p-try": {
+          "version": "2.2.0",
+          "resolved": "https://registry.npmjs.org/p-try/-/p-try-2.2.0.tgz",
+          "integrity": "sha512-R4nPAVTAU0B9D35/Gk3uJf/7XYbQcyohSKdvAxIRSNghFl4e71hVoGnBNQz9cWaXxO2I10KTC+3jMdvvoKw6dQ==",
+          "dev": true
+        },
+        "require-main-filename": {
           "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/p-try/-/p-try-2.0.0.tgz",
-          "integrity": "sha512-hMp0onDKIajHfIkdRk3P4CdCmErkYAxxDtP3Wx/4nZ3aGlau2VKh3mZpcuFkH27WQkL/3WBCPOktzA9ZOAnMQQ==",
+          "resolved": "https://registry.npmjs.org/require-main-filename/-/require-main-filename-2.0.0.tgz",
+          "integrity": "sha512-NKN5kMDylKuldxYLSUfrbo5Tuzh4hd+2E8NPPX02mZtn1VuREQToYe/ZdlJy+J3uCpfaiGF05e7B8W0iXbQHmg==",
           "dev": true
         },
+        "string-width": {
+          "version": "3.1.0",
+          "resolved": "https://registry.npmjs.org/string-width/-/string-width-3.1.0.tgz",
+          "integrity": "sha512-vafcv6KjVZKSgz06oM/H6GDBrAtz8vdhQakGjFIvNrHA6y3HCF1CInLy+QLq8dTJPQ1b+KDUqDFctkdRW44e1w==",
+          "dev": true,
+          "requires": {
+            "emoji-regex": "^7.0.1",
+            "is-fullwidth-code-point": "^2.0.0",
+            "strip-ansi": "^5.1.0"
+          },
+          "dependencies": {
+            "ansi-regex": {
+              "version": "4.1.0",
+              "resolved": "https://registry.npmjs.org/ansi-regex/-/ansi-regex-4.1.0.tgz",
+              "integrity": "sha512-1apePfXM1UOSqw0o9IiFAovVz9M5S1Dg+4TrDwfMewQ6p/rmMueb7tWZjQ1rx4Loy1ArBggoqGpfqqdI4rondg==",
+              "dev": true
+            },
+            "strip-ansi": {
+              "version": "5.2.0",
+              "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-5.2.0.tgz",
+              "integrity": "sha512-DuRs1gKbBqsMKIZlrffwlug8MHkcnpjs5VPmL1PAh+mA30U0DTotfDZ0d2UUsXpPmPmMMJ6W773MaA3J+lbiWA==",
+              "dev": true,
+              "requires": {
+                "ansi-regex": "^4.1.0"
+              }
+            }
+          }
+        },
         "strip-ansi": {
           "version": "4.0.0",
           "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-4.0.0.tgz",
@@ -8158,29 +7844,28 @@
           "dev": true
         },
         "yargs": {
-          "version": "12.0.5",
-          "resolved": "https://registry.npmjs.org/yargs/-/yargs-12.0.5.tgz",
-          "integrity": "sha512-Lhz8TLaYnxq/2ObqHDql8dX8CJi97oHxrjUcYtzKbbykPtVW9WB+poxI+NM2UIzsMgNCZTIf0AQwsjK5yMAqZw==",
+          "version": "13.2.2",
+          "resolved": "https://registry.npmjs.org/yargs/-/yargs-13.2.2.tgz",
+          "integrity": "sha512-WyEoxgyTD3w5XRpAQNYUB9ycVH/PQrToaTXdYXRdOXvEy1l19br+VJsc0vcO8PTGg5ro/l/GY7F/JMEBmI0BxA==",
           "dev": true,
           "requires": {
             "cliui": "^4.0.0",
-            "decamelize": "^1.2.0",
             "find-up": "^3.0.0",
-            "get-caller-file": "^1.0.1",
-            "os-locale": "^3.0.0",
+            "get-caller-file": "^2.0.1",
+            "os-locale": "^3.1.0",
             "require-directory": "^2.1.1",
-            "require-main-filename": "^1.0.1",
+            "require-main-filename": "^2.0.0",
             "set-blocking": "^2.0.0",
-            "string-width": "^2.0.0",
+            "string-width": "^3.0.0",
             "which-module": "^2.0.0",
-            "y18n": "^3.2.1 || ^4.0.0",
-            "yargs-parser": "^11.1.1"
+            "y18n": "^4.0.0",
+            "yargs-parser": "^13.0.0"
           }
         },
         "yargs-parser": {
-          "version": "11.1.1",
-          "resolved": "https://registry.npmjs.org/yargs-parser/-/yargs-parser-11.1.1.tgz",
-          "integrity": "sha512-C6kB/WJDiaxONLJQnF8ccx9SEeoTTLek8RVbaOIsrAUS8VrBEXfmeSnCZxygc+XC2sNMBIwOOnfcxiynjHsVSQ==",
+          "version": "13.0.0",
+          "resolved": "https://registry.npmjs.org/yargs-parser/-/yargs-parser-13.0.0.tgz",
+          "integrity": "sha512-w2LXjoL8oRdRQN+hOyppuXs+V/fVAYtpcrRxZuF7Kt/Oc+Jr2uAcVntaUTNT6w5ihoWfFDpNY8CPx1QskxZ/pw==",
           "dev": true,
           "requires": {
             "camelcase": "^5.0.0",
@@ -8286,6 +7971,37 @@
       "resolved": "https://registry.npmjs.org/natural-compare-lite/-/natural-compare-lite-1.4.0.tgz",
       "integrity": "sha1-F7CVgZiJef3a/gIB6TG6kzyWy7Q="
     },
+    "needle": {
+      "version": "2.2.4",
+      "resolved": "https://registry.npmjs.org/needle/-/needle-2.2.4.tgz",
+      "integrity": "sha512-HyoqEb4wr/rsoaIDfTH2aVL9nWtQqba2/HvMv+++m8u0dz808MaagKILxtfeSN7QU7nvbQ79zk3vYOJp9zsNEA==",
+      "dev": true,
+      "optional": true,
+      "requires": {
+        "debug": "^2.1.2",
+        "iconv-lite": "^0.4.4",
+        "sax": "^1.2.4"
+      },
+      "dependencies": {
+        "debug": {
+          "version": "2.6.9",
+          "resolved": "https://registry.npmjs.org/debug/-/debug-2.6.9.tgz",
+          "integrity": "sha512-bC7ElrdJaJnPbAP+1EotYvqZsb3ecl5wi6Bfi6BJTUcNowp6cvspg0jXznRTKDjm/E7AdgFBVeAPVMNcKGsHMA==",
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "ms": "2.0.0"
+          }
+        },
+        "ms": {
+          "version": "2.0.0",
+          "resolved": "https://registry.npmjs.org/ms/-/ms-2.0.0.tgz",
+          "integrity": "sha1-VgiurfwAvmwpAd9fmGF4jeDVl8g=",
+          "dev": true,
+          "optional": true
+        }
+      }
+    },
     "negotiator": {
       "version": "0.6.1",
       "resolved": "https://registry.npmjs.org/negotiator/-/negotiator-0.6.1.tgz",
@@ -8298,6 +8014,14 @@
       "integrity": "sha512-MFh0d/Wa7vkKO3Y3LlacqAEeHK0mckVqzDieUKTT+KGxi+zIpeVsFxymkIiRpbpDziHc290Xr9A1O4Om7otoRA==",
       "dev": true
     },
+    "ngx-popper": {
+      "version": "6.0.7",
+      "resolved": "https://registry.npmjs.org/ngx-popper/-/ngx-popper-6.0.7.tgz",
+      "integrity": "sha512-1IOjp1r1We7NJdJxjOGwUhjJEzCWkbIvupJyo5wLjNG0vEp0X/KWI7SEhm2ZCrrA1zeuuWSJEti5ejSHpl0y0Q==",
+      "requires": {
+        "tslib": "^1.9.0"
+      }
+    },
     "nice-try": {
       "version": "1.0.5",
       "resolved": "https://registry.npmjs.org/nice-try/-/nice-try-1.0.5.tgz",
@@ -8314,12 +8038,21 @@
       }
     },
     "node-environment-flags": {
-      "version": "1.0.4",
-      "resolved": "https://registry.npmjs.org/node-environment-flags/-/node-environment-flags-1.0.4.tgz",
-      "integrity": "sha512-M9rwCnWVLW7PX+NUWe3ejEdiLYinRpsEre9hMkU/6NS4h+EEulYaDH1gCEZ2gyXsmw+RXYDaV2JkkTNcsPDJ0Q==",
+      "version": "1.0.5",
+      "resolved": "https://registry.npmjs.org/node-environment-flags/-/node-environment-flags-1.0.5.tgz",
+      "integrity": "sha512-VNYPRfGfmZLx0Ye20jWzHUjyTW/c+6Wq+iLhDzUI4XmhrDd9l/FozXV3F2xOaXjvp0co0+v1YSR3CMP6g+VvLQ==",
       "dev": true,
       "requires": {
-        "object.getownpropertydescriptors": "^2.0.3"
+        "object.getownpropertydescriptors": "^2.0.3",
+        "semver": "^5.7.0"
+      },
+      "dependencies": {
+        "semver": {
+          "version": "5.7.0",
+          "resolved": "https://registry.npmjs.org/semver/-/semver-5.7.0.tgz",
+          "integrity": "sha512-Ya52jSX2u7QKghxeoFGpLwCtGlt7j0oY9DYb5apt9nPlJ42ID+ulTXESnt/qAQcoSERyZ5sl3LDIOw0nAn/5DA==",
+          "dev": true
+        }
       }
     },
     "node-fetch": {
@@ -8478,6 +8211,61 @@
         }
       }
     },
+    "node-pre-gyp": {
+      "version": "0.10.3",
+      "resolved": "https://registry.npmjs.org/node-pre-gyp/-/node-pre-gyp-0.10.3.tgz",
+      "integrity": "sha512-d1xFs+C/IPS8Id0qPTZ4bUT8wWryfR/OzzAFxweG+uLN85oPzyo2Iw6bVlLQ/JOdgNonXLCoRyqDzDWq4iw72A==",
+      "dev": true,
+      "optional": true,
+      "requires": {
+        "detect-libc": "^1.0.2",
+        "mkdirp": "^0.5.1",
+        "needle": "^2.2.1",
+        "nopt": "^4.0.1",
+        "npm-packlist": "^1.1.6",
+        "npmlog": "^4.0.2",
+        "rc": "^1.2.7",
+        "rimraf": "^2.6.1",
+        "semver": "^5.3.0",
+        "tar": "^4"
+      },
+      "dependencies": {
+        "nopt": {
+          "version": "4.0.1",
+          "resolved": "https://registry.npmjs.org/nopt/-/nopt-4.0.1.tgz",
+          "integrity": "sha1-0NRoWv1UFRk8jHUFYC0NF81kR00=",
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "abbrev": "1",
+            "osenv": "^0.1.4"
+          }
+        },
+        "tar": {
+          "version": "4.4.8",
+          "resolved": "https://registry.npmjs.org/tar/-/tar-4.4.8.tgz",
+          "integrity": "sha512-LzHF64s5chPQQS0IYBn9IN5h3i98c12bo4NCO7e0sGM2llXQ3p2FGC5sdENN4cTW48O915Sh+x+EXx7XW96xYQ==",
+          "dev": true,
+          "optional": true,
+          "requires": {
+            "chownr": "^1.1.1",
+            "fs-minipass": "^1.2.5",
+            "minipass": "^2.3.4",
+            "minizlib": "^1.1.1",
+            "mkdirp": "^0.5.0",
+            "safe-buffer": "^5.1.2",
+            "yallist": "^3.0.2"
+          }
+        },
+        "yallist": {
+          "version": "3.0.3",
+          "resolved": "https://registry.npmjs.org/yallist/-/yallist-3.0.3.tgz",
+          "integrity": "sha512-S+Zk8DEWE6oKpV+vI3qWkaK+jSbIK86pCwe2IF/xwIpQ8jEuxpw9NyaGjmp9+BoJv5FV2piqCDcoCtStppiq2A==",
+          "dev": true,
+          "optional": true
+        }
+      }
+    },
     "node-releases": {
       "version": "1.1.3",
       "resolved": "https://registry.npmjs.org/node-releases/-/node-releases-1.1.3.tgz",
@@ -8623,6 +8411,24 @@
         "sort-keys": "^1.0.0"
       }
     },
+    "npm-bundled": {
+      "version": "1.0.5",
+      "resolved": "https://registry.npmjs.org/npm-bundled/-/npm-bundled-1.0.5.tgz",
+      "integrity": "sha512-m/e6jgWu8/v5niCUKQi9qQl8QdeEduFA96xHDDzFGqly0OOjI7c+60KM/2sppfnUU9JJagf+zs+yGhqSOFj71g==",
+      "dev": true,
+      "optional": true
+    },
+    "npm-packlist": {
+      "version": "1.2.0",
+      "resolved": "https://registry.npmjs.org/npm-packlist/-/npm-packlist-1.2.0.tgz",
+      "integrity": "sha512-7Mni4Z8Xkx0/oegoqlcao/JpPCPEMtUvsmB0q7mgvlMinykJLSRTYuFqoQLYgGY8biuxIeiHO+QNJKbCfljewQ==",
+      "dev": true,
+      "optional": true,
+      "requires": {
+        "ignore-walk": "^3.0.1",
+        "npm-bundled": "^1.0.1"
+      }
+    },
     "npm-run-path": {
       "version": "2.0.2",
       "resolved": "https://registry.npmjs.org/npm-run-path/-/npm-run-path-2.0.2.tgz",
@@ -8668,8 +8474,7 @@
     "number-is-nan": {
       "version": "1.0.1",
       "resolved": "https://registry.npmjs.org/number-is-nan/-/number-is-nan-1.0.1.tgz",
-      "integrity": "sha1-CXtgK1NCKlIsGvuHkDGDNpQaAR0=",
-      "dev": true
+      "integrity": "sha1-CXtgK1NCKlIsGvuHkDGDNpQaAR0="
     },
     "nvd3": {
       "version": "1.8.6",
@@ -8819,7 +8624,6 @@
       "version": "1.4.0",
       "resolved": "https://registry.npmjs.org/once/-/once-1.4.0.tgz",
       "integrity": "sha1-WDsap3WWHUsROsF9nFC6753Xa9E=",
-      "dev": true,
       "requires": {
         "wrappy": "1"
       }
@@ -8834,9 +8638,9 @@
       }
     },
     "opn": {
-      "version": "5.4.0",
-      "resolved": "https://registry.npmjs.org/opn/-/opn-5.4.0.tgz",
-      "integrity": "sha512-YF9MNdVy/0qvJvDtunAOzFw9iasOQHpVthTCvGzxt61Il64AYSGdK+rYwld7NAfk9qJ7dt+hymBNSc9LNYS+Sw==",
+      "version": "5.5.0",
+      "resolved": "https://registry.npmjs.org/opn/-/opn-5.5.0.tgz",
+      "integrity": "sha512-PqHpggC9bLV0VeWcdKhkpxY+3JTzetLSqTCWL/z/tFIbI6G8JCjondXklT1JinczLz2Xib62sSp0T/gKT4KksA==",
       "dev": true,
       "requires": {
         "is-wsl": "^1.1.0"
@@ -8898,8 +8702,7 @@
     "os-homedir": {
       "version": "1.0.2",
       "resolved": "https://registry.npmjs.org/os-homedir/-/os-homedir-1.0.2.tgz",
-      "integrity": "sha1-/7xJiDNuDoM94MFox+8VISGqf7M=",
-      "dev": true
+      "integrity": "sha1-/7xJiDNuDoM94MFox+8VISGqf7M="
     },
     "os-locale": {
       "version": "1.4.0",
@@ -8913,14 +8716,12 @@
     "os-tmpdir": {
       "version": "1.0.2",
       "resolved": "https://registry.npmjs.org/os-tmpdir/-/os-tmpdir-1.0.2.tgz",
-      "integrity": "sha1-u+Z0BseaqFxc/sdm/lc0VV36EnQ=",
-      "dev": true
+      "integrity": "sha1-u+Z0BseaqFxc/sdm/lc0VV36EnQ="
     },
     "osenv": {
       "version": "0.1.5",
       "resolved": "https://registry.npmjs.org/osenv/-/osenv-0.1.5.tgz",
       "integrity": "sha512-0CWcCECdMVc2Rw3U5w9ZjqX6ga6ubk1xDVKxtBQPK7wis/0F2r9T6k4ydGYhecl7YUBxBVxhL5oisPsNxAPe2g==",
-      "dev": true,
       "requires": {
         "os-homedir": "^1.0.0",
         "os-tmpdir": "^1.0.0"
@@ -8968,9 +8769,9 @@
       }
     },
     "p-map": {
-      "version": "1.2.0",
-      "resolved": "https://registry.npmjs.org/p-map/-/p-map-1.2.0.tgz",
-      "integrity": "sha512-r6zKACMNhjPJMTl8KcFH4li//gkrXWfbD6feV8l6doRHlzljFWGJ2AP6iKaCJXyZmAUMOPtvbW7EXkbWO/pLEA==",
+      "version": "2.1.0",
+      "resolved": "https://registry.npmjs.org/p-map/-/p-map-2.1.0.tgz",
+      "integrity": "sha512-y3b8Kpd8OAN444hxfBbFfj1FY/RjtTd8tzYwhUqNYXx0fXx2iX4maP4Qr6qhIKbQXI02wTLAda4fYUbDagTUFw==",
       "dev": true
     },
     "p-try": {
@@ -9067,12 +8868,6 @@
         "error-ex": "^1.2.0"
       }
     },
-    "parse-passwd": {
-      "version": "1.0.0",
-      "resolved": "https://registry.npmjs.org/parse-passwd/-/parse-passwd-1.0.0.tgz",
-      "integrity": "sha1-bVuTSkVpk7I9N/QKOC1vFmao5cY=",
-      "dev": true
-    },
     "parseqs": {
       "version": "0.0.5",
       "resolved": "https://registry.npmjs.org/parseqs/-/parseqs-0.0.5.tgz",
@@ -9116,8 +8911,7 @@
     "path-is-absolute": {
       "version": "1.0.1",
       "resolved": "https://registry.npmjs.org/path-is-absolute/-/path-is-absolute-1.0.1.tgz",
-      "integrity": "sha1-F0uSaHNVNP+8es5r9TpanhtcX18=",
-      "dev": true
+      "integrity": "sha1-F0uSaHNVNP+8es5r9TpanhtcX18="
     },
     "path-is-inside": {
       "version": "1.0.2",
@@ -9224,6 +9018,11 @@
       "integrity": "sha512-ARhBOdzS3e41FbkW/XWrTEtukqqLoK5+Z/4UeDaLuSW+39JPeFgs4gCGqsrJHVZX0fUrx//4OF0K1CUGwlIFow==",
       "dev": true
     },
+    "popper.js": {
+      "version": "1.14.7",
+      "resolved": "https://registry.npmjs.org/popper.js/-/popper.js-1.14.7.tgz",
+      "integrity": "sha512-4q1hNvoUre/8srWsH7hnoSJ5xVmIL4qgz+s4qf2TnJIMyZFUFMGH+9vE7mXynAlHSZ/NdTmmow86muD0myUkVQ=="
+    },
     "portfinder": {
       "version": "1.0.20",
       "resolved": "https://registry.npmjs.org/portfinder/-/portfinder-1.0.20.tgz",
@@ -10351,9 +10150,9 @@
       "dev": true
     },
     "querystringify": {
-      "version": "2.1.0",
-      "resolved": "https://registry.npmjs.org/querystringify/-/querystringify-2.1.0.tgz",
-      "integrity": "sha512-sluvZZ1YiTLD5jsqZcDmFyV2EwToyXZBfpoVOmktMmW+VEnhgakFHnasVph65fOjGPTWN0Nw3+XQaSeMayr0kg==",
+      "version": "2.1.1",
+      "resolved": "https://registry.npmjs.org/querystringify/-/querystringify-2.1.1.tgz",
+      "integrity": "sha512-w7fLxIRCRT7U8Qu53jQnJyPkYZIaR4n5151KMfcJlO/A9397Wxb1amJvROTK6TOnp7PfoAmg/qXiNHI+08jRfA==",
       "dev": true
     },
     "randombytes": {
@@ -10404,6 +10203,19 @@
         }
       }
     },
+    "rc": {
+      "version": "1.2.8",
+      "resolved": "https://registry.npmjs.org/rc/-/rc-1.2.8.tgz",
+      "integrity": "sha512-y3bGgqKj3QBdxLbLkomlohkvsA8gdAiUQlSBJnBhfn+BPxg4bc62d8TcBW15wavDfgexCgccckhcZvywyQYPOw==",
+      "dev": true,
+      "optional": true,
+      "requires": {
+        "deep-extend": "^0.6.0",
+        "ini": "~1.3.0",
+        "minimist": "^1.2.0",
+        "strip-json-comments": "~2.0.1"
+      }
+    },
     "read-pkg": {
       "version": "1.1.0",
       "resolved": "https://registry.npmjs.org/read-pkg/-/read-pkg-1.1.0.tgz",
@@ -10842,16 +10654,6 @@
         }
       }
     },
-    "resolve-dir": {
-      "version": "1.0.1",
-      "resolved": "https://registry.npmjs.org/resolve-dir/-/resolve-dir-1.0.1.tgz",
-      "integrity": "sha1-eaQGRMNivoLybv/nOcm7U4IEb0M=",
-      "dev": true,
-      "requires": {
-        "expand-tilde": "^2.0.0",
-        "global-modules": "^1.0.0"
-      }
-    },
     "resolve-from": {
       "version": "4.0.0",
       "resolved": "https://registry.npmjs.org/resolve-from/-/resolve-from-4.0.0.tgz",
@@ -11825,9 +11627,9 @@
       },
       "dependencies": {
         "readable-stream": {
-          "version": "3.1.1",
-          "resolved": "https://registry.npmjs.org/readable-stream/-/readable-stream-3.1.1.tgz",
-          "integrity": "sha512-DkN66hPyqDhnIQ6Jcsvx9bFjhw214O4poMBcIMgPVpQvNy9a0e0Uhg5SqySyDKAmUlwt8LonTBz1ezOnM8pUdA==",
+          "version": "3.3.0",
+          "resolved": "https://registry.npmjs.org/readable-stream/-/readable-stream-3.3.0.tgz",
+          "integrity": "sha512-EsI+s3k3XsW+fU8fQACLN59ky34AZ14LoeVZpYwmZvldCFo0r0gnelwF2TcMjLor/BTL5aDJVBMkss0dthToPw==",
           "dev": true,
           "requires": {
             "inherits": "^2.0.3",
@@ -12001,15 +11803,16 @@
       "dev": true
     },
     "streamroller": {
-      "version": "0.7.0",
-      "resolved": "https://registry.npmjs.org/streamroller/-/streamroller-0.7.0.tgz",
-      "integrity": "sha512-WREzfy0r0zUqp3lGO096wRuUp7ho1X6uo/7DJfTlEi0Iv/4gT7YHqXDjKC2ioVGBZtE8QzsQD9nx1nIuoZ57jQ==",
+      "version": "1.0.4",
+      "resolved": "https://registry.npmjs.org/streamroller/-/streamroller-1.0.4.tgz",
+      "integrity": "sha512-Wc2Gm5ygjSX8ZpW9J7Y9FwiSzTlKSvcl0FTTMd3rn7RoxDXpBW+xD9TY5sWL2n0UR61COB0LG1BQvN6nTUQbLQ==",
       "dev": true,
       "requires": {
-        "date-format": "^1.2.0",
+        "async": "^2.6.1",
+        "date-format": "^2.0.0",
         "debug": "^3.1.0",
-        "mkdirp": "^0.5.1",
-        "readable-stream": "^2.3.0"
+        "fs-extra": "^7.0.0",
+        "lodash": "^4.17.10"
       },
       "dependencies": {
         "debug": {
@@ -12020,36 +11823,6 @@
           "requires": {
             "ms": "^2.1.1"
           }
-        },
-        "process-nextick-args": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/process-nextick-args/-/process-nextick-args-2.0.0.tgz",
-          "integrity": "sha512-MtEC1TqN0EU5nephaJ4rAtThHtC86dNN9qCuEhtshvpVBkAW5ZO7BASN9REnF9eoXGcRub+pFuKEpOHE+HbEMw==",
-          "dev": true
-        },
-        "readable-stream": {
-          "version": "2.3.6",
-          "resolved": "https://registry.npmjs.org/readable-stream/-/readable-stream-2.3.6.tgz",
-          "integrity": "sha512-tQtKA9WIAhBF3+VLAseyMqZeBjW0AHJoxOtYqSUZNJxauErmLbVm2FW1y+J/YA9dUrAC39ITejlZWhVIwawkKw==",
-          "dev": true,
-          "requires": {
-            "core-util-is": "~1.0.0",
-            "inherits": "~2.0.3",
-            "isarray": "~1.0.0",
-            "process-nextick-args": "~2.0.0",
-            "safe-buffer": "~5.1.1",
-            "string_decoder": "~1.1.1",
-            "util-deprecate": "~1.0.1"
-          }
-        },
-        "string_decoder": {
-          "version": "1.1.1",
-          "resolved": "https://registry.npmjs.org/string_decoder/-/string_decoder-1.1.1.tgz",
-          "integrity": "sha512-n/ShnvDi6FHbbVfviro+WojiFzv+s8MPMHBczVePfUpDJLwoLT0ht1l4YwBCbi8pJAveEEdnkHyPyTP/mzRfwg==",
-          "dev": true,
-          "requires": {
-            "safe-buffer": "~5.1.0"
-          }
         }
       }
     },
@@ -12828,6 +12601,12 @@
         "imurmurhash": "^0.1.4"
       }
     },
+    "universalify": {
+      "version": "0.1.2",
+      "resolved": "https://registry.npmjs.org/universalify/-/universalify-0.1.2.tgz",
+      "integrity": "sha512-rBJeI5CXAlmy1pV+617WB9J63U6XcazHHF2f2dbJix4XzpUF0RS3Zbj0FGIOCAva5P/d/GBOYaACQ1w+0azUkg==",
+      "dev": true
+    },
     "unpipe": {
       "version": "1.0.0",
       "resolved": "https://registry.npmjs.org/unpipe/-/unpipe-1.0.0.tgz",
@@ -12926,9 +12705,9 @@
       }
     },
     "url-parse": {
-      "version": "1.4.4",
-      "resolved": "https://registry.npmjs.org/url-parse/-/url-parse-1.4.4.tgz",
-      "integrity": "sha512-/92DTTorg4JjktLNLe6GPS2/RvAd/RGr6LuktmWSMLEOa6rjnlrFXNgSbSmkNvCoL2T028A0a1JaJLzRMlFoHg==",
+      "version": "1.4.5",
+      "resolved": "https://registry.npmjs.org/url-parse/-/url-parse-1.4.5.tgz",
+      "integrity": "sha512-4XDvC5vZRjEpjP0L4znrWeoH8P8F0XGBlfLdABi/6oV4o8xUVbTpyrxWHxkK2bT0pSIpcjdIzSoWUhlUfawCAQ==",
       "dev": true,
       "requires": {
         "querystringify": "^2.0.0",
@@ -13394,47 +13173,47 @@
       }
     },
     "webpack-dev-server": {
-      "version": "3.2.0",
-      "resolved": "https://registry.npmjs.org/webpack-dev-server/-/webpack-dev-server-3.2.0.tgz",
-      "integrity": "sha512-CUGPLQsUBVKa/qkZl1MMo8krm30bsOHAP8jtn78gUICpT+sR3esN4Zb0TSBzOEEQJF0zHNEbwx5GHInkqcmlsA==",
+      "version": "3.3.1",
+      "resolved": "https://registry.npmjs.org/webpack-dev-server/-/webpack-dev-server-3.3.1.tgz",
+      "integrity": "sha512-jY09LikOyGZrxVTXK0mgIq9y2IhCoJ05848dKZqX1gAGLU1YDqgpOT71+W53JH/wI4v6ky4hm+KvSyW14JEs5A==",
       "dev": true,
       "requires": {
         "ansi-html": "0.0.7",
         "bonjour": "^3.5.0",
-        "chokidar": "^2.0.0",
-        "compression": "^1.5.2",
-        "connect-history-api-fallback": "^1.3.0",
+        "chokidar": "^2.1.5",
+        "compression": "^1.7.4",
+        "connect-history-api-fallback": "^1.6.0",
         "debug": "^4.1.1",
-        "del": "^3.0.0",
-        "express": "^4.16.2",
-        "html-entities": "^1.2.0",
+        "del": "^4.1.0",
+        "express": "^4.16.4",
+        "html-entities": "^1.2.1",
         "http-proxy-middleware": "^0.19.1",
         "import-local": "^2.0.0",
-        "internal-ip": "^4.0.0",
+        "internal-ip": "^4.2.0",
         "ip": "^1.1.5",
-        "killable": "^1.0.0",
-        "loglevel": "^1.4.1",
-        "opn": "^5.1.0",
-        "portfinder": "^1.0.9",
+        "killable": "^1.0.1",
+        "loglevel": "^1.6.1",
+        "opn": "^5.5.0",
+        "portfinder": "^1.0.20",
         "schema-utils": "^1.0.0",
-        "selfsigned": "^1.9.1",
-        "semver": "^5.6.0",
-        "serve-index": "^1.7.2",
+        "selfsigned": "^1.10.4",
+        "semver": "^6.0.0",
+        "serve-index": "^1.9.1",
         "sockjs": "0.3.19",
         "sockjs-client": "1.3.0",
         "spdy": "^4.0.0",
-        "strip-ansi": "^3.0.0",
+        "strip-ansi": "^3.0.1",
         "supports-color": "^6.1.0",
         "url": "^0.11.0",
-        "webpack-dev-middleware": "^3.5.1",
+        "webpack-dev-middleware": "^3.6.2",
         "webpack-log": "^2.0.0",
-        "yargs": "12.0.2"
+        "yargs": "12.0.5"
       },
       "dependencies": {
         "ajv": {
-          "version": "6.9.2",
-          "resolved": "https://registry.npmjs.org/ajv/-/ajv-6.9.2.tgz",
-          "integrity": "sha512-4UFy0/LgDo7Oa/+wOAlj44tp9K78u38E5/359eSrqEp1Z5PdVfimCcs7SluXMP755RUQu6d2b4AvF0R1C9RZjg==",
+          "version": "6.10.0",
+          "resolved": "https://registry.npmjs.org/ajv/-/ajv-6.10.0.tgz",
+          "integrity": "sha512-nffhOpkymDECQyR0mnsUtoCE8RlX38G0rYP+wgLWFyZuUyuuojSSvi/+euOiQBIn63whYwYVIIH1TvE3tu4OEg==",
           "dev": true,
           "requires": {
             "fast-deep-equal": "^2.0.1",
@@ -13450,9 +13229,9 @@
           "dev": true
         },
         "camelcase": {
-          "version": "4.1.0",
-          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-4.1.0.tgz",
-          "integrity": "sha1-1UVjW+HjPFQmScaRc+Xeas+uNN0=",
+          "version": "5.3.1",
+          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-5.3.1.tgz",
+          "integrity": "sha512-L28STB170nwWS63UjtlEOE3dldQApaJXZkOI1uMFfzf3rRuPegHaHesyee+YxQ+W6SvRDQV6UrdOdRiR153wJg==",
           "dev": true
         },
         "cliui": {
@@ -13483,15 +13262,6 @@
             }
           }
         },
-        "decamelize": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/decamelize/-/decamelize-2.0.0.tgz",
-          "integrity": "sha512-Ikpp5scV3MSYxY39ymh45ZLEecsTdv/Xj2CaQfI8RLMuwi7XvjX9H/fhraiSuU+C5w5NTDu4ZU72xNiZnurBPg==",
-          "dev": true,
-          "requires": {
-            "xregexp": "4.0.0"
-          }
-        },
         "fast-deep-equal": {
           "version": "2.0.1",
           "resolved": "https://registry.npmjs.org/fast-deep-equal/-/fast-deep-equal-2.0.1.tgz",
@@ -13560,9 +13330,9 @@
           }
         },
         "p-limit": {
-          "version": "2.1.0",
-          "resolved": "https://registry.npmjs.org/p-limit/-/p-limit-2.1.0.tgz",
-          "integrity": "sha512-NhURkNcrVB+8hNfLuysU8enY5xn2KXphsHBaC2YmRNTZRc7RWusw6apSpdEj3jo4CMb6W9nrF6tTnsJsJeyu6g==",
+          "version": "2.2.0",
+          "resolved": "https://registry.npmjs.org/p-limit/-/p-limit-2.2.0.tgz",
+          "integrity": "sha512-pZbTJpoUsCzV48Mc9Nh51VbwO0X9cuPFE8gYwx9BTCt9SF8/b7Zljd2fVgOxhIF/HDTKgpVzs+GPhyKfjLLFRQ==",
           "dev": true,
           "requires": {
             "p-try": "^2.0.0"
@@ -13578,9 +13348,9 @@
           }
         },
         "p-try": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/p-try/-/p-try-2.0.0.tgz",
-          "integrity": "sha512-hMp0onDKIajHfIkdRk3P4CdCmErkYAxxDtP3Wx/4nZ3aGlau2VKh3mZpcuFkH27WQkL/3WBCPOktzA9ZOAnMQQ==",
+          "version": "2.2.0",
+          "resolved": "https://registry.npmjs.org/p-try/-/p-try-2.2.0.tgz",
+          "integrity": "sha512-R4nPAVTAU0B9D35/Gk3uJf/7XYbQcyohSKdvAxIRSNghFl4e71hVoGnBNQz9cWaXxO2I10KTC+3jMdvvoKw6dQ==",
           "dev": true
         },
         "pkg-dir": {
@@ -13603,6 +13373,12 @@
             "ajv-keywords": "^3.1.0"
           }
         },
+        "semver": {
+          "version": "6.0.0",
+          "resolved": "https://registry.npmjs.org/semver/-/semver-6.0.0.tgz",
+          "integrity": "sha512-0UewU+9rFapKFnlbirLi3byoOuhrSsli/z/ihNnvM24vgF+8sNBiI1LZPBSH9wJKUwaUbw+s3hToDLCXkrghrQ==",
+          "dev": true
+        },
         "strip-ansi": {
           "version": "3.0.1",
           "resolved": "https://registry.npmjs.org/strip-ansi/-/strip-ansi-3.0.1.tgz",
@@ -13622,9 +13398,9 @@
           }
         },
         "webpack-dev-middleware": {
-          "version": "3.6.0",
-          "resolved": "https://registry.npmjs.org/webpack-dev-middleware/-/webpack-dev-middleware-3.6.0.tgz",
-          "integrity": "sha512-oeXA3m+5gbYbDBGo4SvKpAHJJEGMoekUbHgo1RK7CP1sz7/WOSeu/dWJtSTk+rzDCLkPwQhGocgIq6lQqOyOwg==",
+          "version": "3.6.2",
+          "resolved": "https://registry.npmjs.org/webpack-dev-middleware/-/webpack-dev-middleware-3.6.2.tgz",
+          "integrity": "sha512-A47I5SX60IkHrMmZUlB0ZKSWi29TZTcPz7cha1Z75yYOsgWh/1AcPmQEbC8ZIbU3A1ytSv1PMU0PyPz2Lmz2jg==",
           "dev": true,
           "requires": {
             "memory-fs": "^0.4.1",
@@ -13640,13 +13416,13 @@
           "dev": true
         },
         "yargs": {
-          "version": "12.0.2",
-          "resolved": "https://registry.npmjs.org/yargs/-/yargs-12.0.2.tgz",
-          "integrity": "sha512-e7SkEx6N6SIZ5c5H22RTZae61qtn3PYUE8JYbBFlK9sYmh3DMQ6E5ygtaG/2BW0JZi4WGgTR2IV5ChqlqrDGVQ==",
+          "version": "12.0.5",
+          "resolved": "https://registry.npmjs.org/yargs/-/yargs-12.0.5.tgz",
+          "integrity": "sha512-Lhz8TLaYnxq/2ObqHDql8dX8CJi97oHxrjUcYtzKbbykPtVW9WB+poxI+NM2UIzsMgNCZTIf0AQwsjK5yMAqZw==",
           "dev": true,
           "requires": {
             "cliui": "^4.0.0",
-            "decamelize": "^2.0.0",
+            "decamelize": "^1.2.0",
             "find-up": "^3.0.0",
             "get-caller-file": "^1.0.1",
             "os-locale": "^3.0.0",
@@ -13656,16 +13432,17 @@
             "string-width": "^2.0.0",
             "which-module": "^2.0.0",
             "y18n": "^3.2.1 || ^4.0.0",
-            "yargs-parser": "^10.1.0"
+            "yargs-parser": "^11.1.1"
           }
         },
         "yargs-parser": {
-          "version": "10.1.0",
-          "resolved": "https://registry.npmjs.org/yargs-parser/-/yargs-parser-10.1.0.tgz",
-          "integrity": "sha512-VCIyR1wJoEBZUqk5PA+oOBF6ypbwh5aNB3I50guxAL/quggdfs4TtNHQrSazFA3fYZ+tEqfs0zIGlv0c/rgjbQ==",
+          "version": "11.1.1",
+          "resolved": "https://registry.npmjs.org/yargs-parser/-/yargs-parser-11.1.1.tgz",
+          "integrity": "sha512-C6kB/WJDiaxONLJQnF8ccx9SEeoTTLek8RVbaOIsrAUS8VrBEXfmeSnCZxygc+XC2sNMBIwOOnfcxiynjHsVSQ==",
           "dev": true,
           "requires": {
-            "camelcase": "^4.1.0"
+            "camelcase": "^5.0.0",
+            "decamelize": "^1.2.0"
           }
         }
       }
@@ -13852,8 +13629,7 @@
     "wrappy": {
       "version": "1.0.2",
       "resolved": "https://registry.npmjs.org/wrappy/-/wrappy-1.0.2.tgz",
-      "integrity": "sha1-tSQ9jz7BqjXxNkYFvA0QNuMKtp8=",
-      "dev": true
+      "integrity": "sha1-tSQ9jz7BqjXxNkYFvA0QNuMKtp8="
     },
     "write": {
       "version": "0.2.1",
@@ -13879,12 +13655,6 @@
       "resolved": "https://registry.npmjs.org/xmlhttprequest-ssl/-/xmlhttprequest-ssl-1.5.5.tgz",
       "integrity": "sha1-wodrBhaKrcQOV9l+gRkayPQ5iz4="
     },
-    "xregexp": {
-      "version": "4.0.0",
-      "resolved": "https://registry.npmjs.org/xregexp/-/xregexp-4.0.0.tgz",
-      "integrity": "sha512-PHyM+sQouu7xspQQwELlGwwd05mXUFqwFYfqPO0cC7x4fxyHnnuetmQr6CjJiafIDoH4MogHb9dOoJzR/Y4rFg==",
-      "dev": true
-    },
     "xtend": {
       "version": "4.0.1",
       "resolved": "https://registry.npmjs.org/xtend/-/xtend-4.0.1.tgz",
@@ -14083,9 +13853,9 @@
           "dev": true
         },
         "camelcase": {
-          "version": "5.0.0",
-          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-5.0.0.tgz",
-          "integrity": "sha512-faqwZqnWxbxn+F1d399ygeamQNy3lPp/H9H6rNrqYh4FSVCtcY+3cub1MxA8o9mDd55mM8Aghuu/kuyYA6VTsA==",
+          "version": "5.3.1",
+          "resolved": "https://registry.npmjs.org/camelcase/-/camelcase-5.3.1.tgz",
+          "integrity": "sha512-L28STB170nwWS63UjtlEOE3dldQApaJXZkOI1uMFfzf3rRuPegHaHesyee+YxQ+W6SvRDQV6UrdOdRiR153wJg==",
           "dev": true
         },
         "cliui": {
@@ -14145,9 +13915,9 @@
           }
         },
         "p-limit": {
-          "version": "2.1.0",
-          "resolved": "https://registry.npmjs.org/p-limit/-/p-limit-2.1.0.tgz",
-          "integrity": "sha512-NhURkNcrVB+8hNfLuysU8enY5xn2KXphsHBaC2YmRNTZRc7RWusw6apSpdEj3jo4CMb6W9nrF6tTnsJsJeyu6g==",
+          "version": "2.2.0",
+          "resolved": "https://registry.npmjs.org/p-limit/-/p-limit-2.2.0.tgz",
+          "integrity": "sha512-pZbTJpoUsCzV48Mc9Nh51VbwO0X9cuPFE8gYwx9BTCt9SF8/b7Zljd2fVgOxhIF/HDTKgpVzs+GPhyKfjLLFRQ==",
           "dev": true,
           "requires": {
             "p-try": "^2.0.0"
@@ -14163,9 +13933,9 @@
           }
         },
         "p-try": {
-          "version": "2.0.0",
-          "resolved": "https://registry.npmjs.org/p-try/-/p-try-2.0.0.tgz",
-          "integrity": "sha512-hMp0onDKIajHfIkdRk3P4CdCmErkYAxxDtP3Wx/4nZ3aGlau2VKh3mZpcuFkH27WQkL/3WBCPOktzA9ZOAnMQQ==",
+          "version": "2.2.0",
+          "resolved": "https://registry.npmjs.org/p-try/-/p-try-2.2.0.tgz",
+          "integrity": "sha512-R4nPAVTAU0B9D35/Gk3uJf/7XYbQcyohSKdvAxIRSNghFl4e71hVoGnBNQz9cWaXxO2I10KTC+3jMdvvoKw6dQ==",
           "dev": true
         },
         "strip-ansi": {
@@ -14219,6 +13989,11 @@
       "version": "0.1.2",
       "resolved": "https://registry.npmjs.org/yeast/-/yeast-0.1.2.tgz",
       "integrity": "sha1-AI4G2AlDIMNy28L47XagymyKxBk="
+    },
+    "zone.js": {
+      "version": "0.8.29",
+      "resolved": "https://registry.npmjs.org/zone.js/-/zone.js-0.8.29.tgz",
+      "integrity": "sha512-mla2acNCMkWXBD+c+yeUrBUrzOxYMNFdQ6FGfigGGtEVBPJx07BQeJekjt9DmH1FtZek4E9rE1eRR9qQpxACOQ=="
     }
   }
 }
diff --git a/modules/web-console/frontend/package.json b/modules/web-console/frontend/package.json
index d24adfe..5d6e34a 100644
--- a/modules/web-console/frontend/package.json
+++ b/modules/web-console/frontend/package.json
@@ -26,11 +26,21 @@
     "win32"
   ],
   "dependencies": {
+    "@angular/common": "^7.2.2",
+    "@angular/compiler": "^7.2.2",
+    "@angular/core": "^7.2.2",
+    "@angular/forms": "^7.2.2",
+    "@angular/platform-browser": "^7.2.2",
+    "@angular/platform-browser-dynamic": "^7.2.2",
+    "@angular/router": "^7.2.2",
+    "@angular/upgrade": "^7.2.2",
     "@babel/plugin-transform-parameters": "7.0.0",
-    "@uirouter/angularjs": "1.0.20",
-    "@uirouter/core": "5.0.19",
+    "@uirouter/angular": "^3.0.0",
+    "@uirouter/angular-hybrid": "^7.0.0",
+    "@uirouter/angularjs": "^1.0.22",
+    "@uirouter/core": "^5.0.23",
     "@uirouter/rx": "0.5.0",
-    "angular": "1.7.6",
+    "angular": "^1.7.7",
     "angular-acl": "0.1.10",
     "angular-animate": "1.7.6",
     "angular-aria": "1.7.6",
@@ -51,6 +61,7 @@
     "bson-objectid": "1.1.5",
     "chart.js": "2.7.2",
     "chartjs-plugin-streaming": "1.6.1",
+    "core-js": "^2.6.0",
     "file-saver": "1.3.3",
     "font-awesome": "4.7.0",
     "jquery": "3.2.1",
@@ -59,19 +70,25 @@
     "jszip": "3.1.5",
     "lodash": "4.17.11",
     "natural-compare-lite": "1.4.0",
+    "ngx-popper": "^6.0.7",
     "nvd3": "1.8.6",
     "outdent": "0.5.0",
     "pako": "1.0.6",
+    "popper.js": "^1.14.7",
     "resize-observer-polyfill": "1.5.0",
     "roboto-font": "0.1.0",
     "rxjs": "6.3.3",
     "socket.io-client": "2.1.1",
-    "tf-metatags": "2.0.0"
+    "tf-metatags": "2.0.0",
+    "zone.js": "^0.8.29"
   },
   "devDependencies": {
+    "@angular/language-service": "^7.2.4",
     "@babel/core": "7.0.1",
     "@babel/plugin-proposal-class-properties": "7.0.0",
+    "@babel/plugin-proposal-decorators": "^7.2.2",
     "@babel/plugin-proposal-object-rest-spread": "7.0.0",
+    "@babel/plugin-syntax-decorators": "^7.2.0",
     "@babel/plugin-syntax-dynamic-import": "7.0.0",
     "@babel/preset-env": "7.0.0",
     "@babel/preset-typescript": "7.1.0",
diff --git a/modules/web-console/frontend/public/stylesheets/style.scss b/modules/web-console/frontend/public/stylesheets/style.scss
index 2e6a887..602853f 100644
--- a/modules/web-console/frontend/public/stylesheets/style.scss
+++ b/modules/web-console/frontend/public/stylesheets/style.scss
@@ -24,6 +24,12 @@
 :root {
     --sans-serif-font: Roboto;
     --serif-font: Roboto_slab;
+    --page-side-padding: 30px;
+    --form-gap: 10px;
+    --error-red-R: 238;
+    --error-red-G: 43;
+    --error-red-B: 39;
+    --error-red: rgb(var(--error-red-R), var(--error-red-G), var(--error-red-B));
 }
 
 body {
@@ -258,10 +264,6 @@ body {
     flex-direction: column;
 }
 
-:root {
-    --page-side-padding: 30px;
-}
-
 .wrapper {
     --header-height: 62px;
 
@@ -1308,14 +1310,6 @@ input[type="number"] {
     -moz-appearance: textfield;
 }
 
-input.ng-dirty.ng-invalid, button.ng-dirty.ng-invalid {
-    border-color: $ignite-invalid-color;
-
-    :focus {
-        border-color: $ignite-invalid-color;
-    }
-}
-
 .form-control-feedback {
     display: inline-block;
     color: $brand-primary;
diff --git a/modules/web-console/frontend/tsconfig.json b/modules/web-console/frontend/tsconfig.json
index 531a381..f06925c 100644
--- a/modules/web-console/frontend/tsconfig.json
+++ b/modules/web-console/frontend/tsconfig.json
@@ -7,7 +7,12 @@
         "noEmit": true,
         "allowJs": true,
         "checkJs": true,
-        "baseUrl": "."
+        "baseUrl": ".",
+        "experimentalDecorators": true,
+        "emitDecoratorMetadata": true,
+        "plugins": [
+            {"name": "@angular/language-service"}
+        ]
     },
     "exclude": [
         "build"
diff --git a/modules/web-console/frontend/webpack/webpack.common.js b/modules/web-console/frontend/webpack/webpack.common.js
index a93faf1..3cb8764 100644
--- a/modules/web-console/frontend/webpack/webpack.common.js
+++ b/modules/web-console/frontend/webpack/webpack.common.js
@@ -129,6 +129,13 @@ const config = {
             {
                 test: require.resolve('nvd3'),
                 use: 'expose-loader?nv'
+            },
+            {
+                // Mark files inside `@angular/core` as using SystemJS style dynamic imports.
+                // Removing this will cause deprecation warnings to appear.
+                // https://github.com/angular/angular/issues/21560#issuecomment-433601967
+                test: /[\/\\]@angular[\/\\]core[\/\\].+\.js$/,
+                parser: { system: true } // enable SystemJS
             }
         ]
     },


[ignite] 16/17: GG-17393 [IGNITE-11277] Use maven plugin as default code style checker for project (#11)

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 88b7a5ca8df3c0f710184d334eb0cd313dac2403
Author: Peter Ivanov <mr...@gmail.com>
AuthorDate: Fri Apr 26 09:00:18 2019 +0300

    GG-17393 [IGNITE-11277] Use maven plugin as default code style checker for project (#11)
---
 checkstyle/checkstyle-suppressions.xml             |   24 +
 checkstyle/checkstyle.xml                          |   42 +
 .../change/OptimizeMakeChangeFitnessFunction.java  |    9 +-
 .../OptimizeMakeChangeTerminateCriteria.java       |   11 +-
 .../helloworld/HelloWorldFitnessFunction.java      |    9 +-
 .../helloworld/HelloWorldTerminateCriteria.java    |   11 +-
 .../genetic/knapsack/KnapsackFitnessFunction.java  |    9 +-
 .../knapsack/KnapsackTerminateCriteria.java        |   11 +-
 .../ml/genetic/movie/MovieFitnessFunction.java     |    9 +-
 .../ml/genetic/movie/MovieTerminateCriteria.java   |   11 +-
 idea/disabled_plugins.txt                          |  113 --
 idea/ignite_inspections_teamcity.xml               | 1461 --------------------
 .../benchmarks/jmh/cache/JmhCacheBenchmark.java    |    9 +-
 .../jmh/notify/JmhWaitStategyBenchmark.java        |    2 +-
 .../test/java/org/apache/ignite/tests/MyPojo.java  |    9 +-
 .../store/cassandra/common/CassandraHelper.java    |    3 +-
 .../client/util/ClientConsistentHashSelfTest.java  |    8 +-
 .../internal/processors/rest/TestBinaryClient.java |    2 +-
 .../processors/rest/TestMemcacheClient.java        |    2 +-
 .../tcp/redis/RedisCommonAbstractTest.java         |    2 +-
 .../org/apache/ignite/internal/IgniteKernal.java   |    1 -
 .../client/GridClientPartitionAffinity.java        |    2 +-
 .../ignite/internal/cluster/IgniteClusterImpl.java |    1 -
 .../internal/commandline/CommandHandler.java       |    1 -
 .../managers/discovery/ClusterMetricsImpl.java     |    1 -
 .../processors/cache/GridCacheAdapter.java         |    1 -
 .../processors/cache/GridCacheMapEntry.java        |    2 +-
 .../cache/IgniteCacheOffheapManagerImpl.java       |    1 -
 .../dht/GridDhtTxAbstractEnlistFuture.java         |    1 -
 .../distributed/dht/GridDhtTxPrepareFuture.java    |    1 -
 .../cache/distributed/dht/atomic/UpdateErrors.java |    4 +-
 .../topology/GridDhtPartitionsStateValidator.java  |    1 -
 .../cache/persistence/DbCheckpointListener.java    |    1 -
 .../cache/persistence/GridCacheOffheapManager.java |    2 +-
 .../cache/persistence/tree/io/DataPageIO.java      |    1 -
 .../processors/cacheobject/NoOpBinary.java         |    2 +-
 .../processors/platform/PlatformContextImpl.java   |    1 -
 .../tcp/internal/DiscoveryDataPacket.java          |    2 +-
 .../java/org/jsr166/ConcurrentLinkedDeque8.java    |   24 +-
 .../ignite/cache/ResetLostPartitionTest.java       |    2 -
 .../store/jdbc/model/TestJdbcPojoDataSource.java   |    7 +-
 .../IgniteClientReconnectAbstractTest.java         |    1 -
 .../GridDeploymentMessageCountSelfTest.java        |    2 +-
 .../optimized/OptimizedMarshallerSelfTest.java     |    4 +-
 .../optimized/OptimizedObjectStreamSelfTest.java   |    2 +-
 .../cache/CacheFutureExceptionSelfTest.java        |    4 +-
 .../cache/GridCacheLifecycleAwareSelfTest.java     |    2 +-
 .../cache/GridCacheOnCopyFlagAbstractSelfTest.java |    2 +-
 .../cache/GridCachePutAllFailoverSelfTest.java     |    1 -
 .../cache/IgniteCachePutAllRestartTest.java        |    1 -
 .../cache/IgniteDynamicCacheStartSelfTest.java     |    4 +-
 .../processors/cache/IgniteTxAbstractTest.java     |    3 +-
 .../IgniteSequenceInternalCleanupTest.java         |    2 +-
 ...chePartitionedQueueCreateMultiNodeSelfTest.java |    2 +-
 .../CacheGetInsideLockChangingTopologyTest.java    |    1 -
 .../GridCacheModuloAffinityFunction.java           |    2 +-
 .../IgniteBinaryMetadataUpdateNodeRestartTest.java |    1 -
 .../distributed/IgniteCacheGetRestartTest.java     |    1 -
 .../IgniteCacheNearRestartRollbackSelfTest.java    |    1 -
 .../dht/IgniteCachePutRetryAbstractSelfTest.java   |    1 -
 ...acheAtomicInvalidPartitionHandlingSelfTest.java |    2 +-
 .../near/GridCacheNearMetricsSelfTest.java         |    2 +-
 ...acheRebalancingUnmarshallingFailedSelfTest.java |    1 -
 ...itePdsCacheStartStopWithFreqCheckpointTest.java |    2 +-
 .../IgnitePdsContinuousRestartTest.java            |    1 -
 .../pagemem/IgniteThrottlingUnitTest.java          |    2 +-
 .../PageMemoryLazyAllocationWithPDSTest.java       |    3 -
 .../standbycluster/AbstractNodeJoinTemplate.java   |    2 +-
 .../wal/ExplicitWalDeltaConsistencyTest.java       |    2 -
 .../processors/igfs/IgfsCacheSelfTest.java         |    2 +-
 .../processors/igfs/IgfsDataManagerSelfTest.java   |    2 +-
 .../processors/igfs/IgfsMetaManagerSelfTest.java   |    2 +-
 .../processors/igfs/IgfsOneClientNodeTest.java     |    2 +-
 .../processors/igfs/IgfsProcessorSelfTest.java     |    2 +-
 .../processors/igfs/IgfsStreamsSelfTest.java       |    2 +-
 .../DistributedMetaStoragePersistentTest.java      |    4 -
 ...GridStartupWithUndefinedIgniteHomeSelfTest.java |    2 +-
 .../spi/discovery/tcp/IgniteClientConnectTest.java |    1 -
 .../tcp/TcpDiscoveryNetworkIssuesTest.java         |    1 -
 .../discovery/tcp/TcpDiscoverySpiMBeanTest.java    |    1 -
 .../junits/IgniteConfigVariationsAbstractTest.java |    2 +-
 .../junits/JUnit3TestLegacySupport.java            |    1 -
 ...bjectsSimpleNameMapperComputeGridTestSuite.java |    1 -
 ...IgniteBinarySimpleNameMapperBasicTestSuite.java |    1 -
 ...inarySimpleNameMapperCacheFullApiTestSuite.java |    1 -
 .../source/flink/FlinkIgniteSourceSelfTest.java    |    2 +-
 .../processors/hadoop/HadoopExternalSplit.java     |    2 +-
 .../processors/hadoop/HadoopSplitWrapper.java      |    2 +-
 .../HadoopFileSystemCounterWriterDelegateImpl.java |    2 +-
 .../HadoopIgfsSecondaryFileSystemDelegateImpl.java |    4 +-
 .../hadoop/jobtracker/HadoopJobMetadata.java       |    2 +-
 .../processors/query/h2/H2CachedStatementKey.java  |    1 -
 .../processors/query/h2/dml/DmlArguments.java      |    2 +-
 .../processors/query/h2/sql/GridSqlElement.java    |   12 +-
 .../cache/BinarySerializationQuerySelfTest.java    |    4 +-
 ...acheQueryAfterDynamicCacheStartFailureTest.java |    5 +-
 .../cache/IgniteCacheSqlDmlErrorSelfTest.java      |    1 -
 .../IgniteCacheSqlInsertValidationSelfTest.java    |    1 -
 .../DynamicColumnsAbstractConcurrentSelfTest.java  |    1 -
 .../cache/index/DynamicIndexAbstractSelfTest.java  |   10 +-
 .../processors/cache/index/StaticCacheDdlTest.java |    1 -
 ...eMvccReplicatedSqlTxQueriesWithReducerTest.java |    2 +-
 .../persistence/db/wal/IgniteWalRecoveryTest.java  |    1 -
 .../query/IgniteQueryDedicatedPoolTest.java        |    1 -
 .../query/KillQueryOnClientDisconnectTest.java     |    4 +-
 .../GridIndexRebuildWithMvccEnabledSelfTest.java   |    4 +-
 .../cache/GridJtaLifecycleAwareSelfTest.java       |    6 +-
 .../kubernetes/TcpDiscoveryKubernetesIpFinder.java |    8 +-
 .../ignite/ml/clustering/kmeans/KMeansModel.java   |   10 +-
 .../org/apache/ignite/ml/genetic/CrossOverJob.java |    4 +-
 .../apache/ignite/ml/genetic/CrossOverTask.java    |   21 +-
 .../org/apache/ignite/ml/genetic/FitnessJob.java   |    8 +-
 .../org/apache/ignite/ml/genetic/FitnessTask.java  |   17 +-
 .../java/org/apache/ignite/ml/genetic/GAGrid.java  |   14 +-
 .../org/apache/ignite/ml/genetic/MutateJob.java    |    6 +-
 .../org/apache/ignite/ml/genetic/MutateTask.java   |   19 +-
 .../ignite/ml/genetic/TruncateSelectionJob.java    |    6 +-
 .../ignite/ml/genetic/TruncateSelectionTask.java   |   19 +-
 .../ignite/ml/knn/NNClassificationModel.java       |    2 +-
 .../ignite/ml/math/primitives/matrix/Matrix.java   |    4 +-
 .../matrix/storage/DenseMatrixStorage.java         |    2 +-
 .../matrix/storage/SparseMatrixStorage.java        |    4 +-
 .../apache/ignite/ml/nn/MultilayerPerceptron.java  |    6 +-
 .../ignite/ml/nn/ReplicatedVectorMatrix.java       |    2 +-
 .../apache/ignite/ml/trainers/DatasetTrainer.java  |    2 +-
 .../test/java/org/apache/ignite/ml/TestUtils.java  |    6 +-
 .../vector/VectorImplementationsFixtures.java      |    2 +-
 .../binarization/BinarizationTrainerTest.java      |    1 -
 .../BinaryClassificationEvaluatorTest.java         |    1 -
 .../scoring/evaluator/RegressionEvaluatorTest.java |    1 -
 .../classloaders/BundleDelegatingClassLoader.java  |   19 +-
 .../spark/JavaEmbeddedIgniteRDDSelfTest.java       |    2 -
 .../core/util/PythonProcessBuilderSupplier.java    |    8 +-
 .../uri/scanners/UriDeploymentScannerManager.java  |   16 +-
 .../uri/GridUriDeploymentAbstractSelfTest.java     |    2 +-
 .../apache/ignite/yardstick/IgniteThinClient.java  |    2 +-
 .../org/apache/ignite/yarn/ApplicationMaster.java  |   12 +-
 .../zk/internal/ZookeeperClusterNode.java          |    6 +-
 .../zk/curator/TestingZooKeeperServer.java         |    4 +-
 parent/pom.xml                                     |   47 +-
 140 files changed, 280 insertions(+), 1970 deletions(-)

diff --git a/checkstyle/checkstyle-suppressions.xml b/checkstyle/checkstyle-suppressions.xml
new file mode 100644
index 0000000..3273169
--- /dev/null
+++ b/checkstyle/checkstyle-suppressions.xml
@@ -0,0 +1,24 @@
+<?xml version="1.0"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<!DOCTYPE suppressions PUBLIC
+    "-//Checkstyle//DTD SuppressionFilter Configuration 1.2//EN"
+    "https://checkstyle.org/dtds/suppressions_1_2.dtd">
+<suppressions>
+</suppressions>
diff --git a/checkstyle/checkstyle.xml b/checkstyle/checkstyle.xml
new file mode 100644
index 0000000..58848e2
--- /dev/null
+++ b/checkstyle/checkstyle.xml
@@ -0,0 +1,42 @@
+<?xml version="1.0"?>
+
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one or more
+  contributor license agreements.  See the NOTICE file distributed with
+  this work for additional information regarding copyright ownership.
+  The ASF licenses this file to You under the Apache License, Version 2.0
+  (the "License"); you may not use this file except in compliance with
+  the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<!DOCTYPE module PUBLIC "-//Puppy Crawl//DTD Check Configuration 1.3//EN"
+    "http://www.puppycrawl.com/dtds/configuration_1_3.dtd">
+<module name="Checker">
+    <property name="charset" value="UTF-8"/>
+
+    <property name="fileExtensions" value="java, properties, xml"/>
+
+    <!-- Whitespaces Checks. See: http://checkstyle.sourceforge.net/config_whitespace.html -->
+    <module name="FileTabCharacter">
+        <property name="eachLine" value="true"/>
+    </module>
+
+    <module name="TreeWalker">
+        <!-- Import Checks. See: http://checkstyle.sourceforge.net/config_imports.html -->
+        <module name="UnusedImports"/>
+
+        <!--Modifiers Checks. See: http://checkstyle.sourceforge.net/config_modifier.html-->
+        <module name="ModifierOrder"/>
+
+        <!--Annotation checks. See: http://checkstyle.sourceforge.net/config_annotation.html-->
+        <module name="MissingOverride"/>
+    </module>
+</module>
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/change/OptimizeMakeChangeFitnessFunction.java b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/change/OptimizeMakeChangeFitnessFunction.java
index 749cddb..fa89eb2 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/change/OptimizeMakeChangeFitnessFunction.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/change/OptimizeMakeChangeFitnessFunction.java
@@ -37,13 +37,8 @@ public class OptimizeMakeChangeFitnessFunction implements IFitnessFunction {
         this.targetAmount = targetAmount;
     }
 
-    /**
-     * Calculate fitness.
-     *
-     * @param genes List of genes.
-     * @return Fitness value.
-     */
-    public double evaluate(List<Gene> genes) {
+    /** {@inheritDoc} */
+    @Override public double evaluate(List<Gene> genes) {
         int changeAmount = getAmountOfChange(genes);
         int totalCoins = getTotalNumberOfCoins(genes);
         int changeDifference = Math.abs(targetAmount - changeAmount);
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/change/OptimizeMakeChangeTerminateCriteria.java b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/change/OptimizeMakeChangeTerminateCriteria.java
index 8abf5c9..23bba5f 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/change/OptimizeMakeChangeTerminateCriteria.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/change/OptimizeMakeChangeTerminateCriteria.java
@@ -45,15 +45,8 @@ public class OptimizeMakeChangeTerminateCriteria implements ITerminateCriteria {
         this.logConsumer = logConsumer;
     }
 
-    /**
-     * Check whether termination condition is met.
-     *
-     * @param fittestChromosome Most fit chromosome at for the nth generation.
-     * @param averageFitnessScore Average fitness score as of the nth generation.
-     * @param currGeneration Current generation.
-     * @return Status whether condition is met or not.
-     */
-    public boolean isTerminationConditionMet(Chromosome fittestChromosome, double averageFitnessScore,
+    /** {@inheritDoc} */
+    @Override public boolean isTerminationConditionMet(Chromosome fittestChromosome, double averageFitnessScore,
         int currGeneration) {
         boolean isTerminate = true;
 
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/helloworld/HelloWorldFitnessFunction.java b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/helloworld/HelloWorldFitnessFunction.java
index 56c32b6..b70b7bf 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/helloworld/HelloWorldFitnessFunction.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/helloworld/HelloWorldFitnessFunction.java
@@ -32,13 +32,8 @@ import org.apache.ignite.ml.genetic.IFitnessFunction;
  * contains 11 characters.</p>
  */
 public class HelloWorldFitnessFunction implements IFitnessFunction {
-    /**
-     * Calculate fitness.
-     *
-     * @param genes List of Genes.
-     * @return Fitness value.
-     */
-    public double evaluate(List<Gene> genes) {
+    /** {@inheritDoc} */
+    @Override public double evaluate(List<Gene> genes) {
         double matches = 0;
 
         for (int i = 0; i < genes.size(); i++) {
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/helloworld/HelloWorldTerminateCriteria.java b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/helloworld/HelloWorldTerminateCriteria.java
index a1d0379..a5a6968 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/helloworld/HelloWorldTerminateCriteria.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/helloworld/HelloWorldTerminateCriteria.java
@@ -47,15 +47,8 @@ public class HelloWorldTerminateCriteria implements ITerminateCriteria {
         this.logConsumer = logConsumer;
     }
 
-    /**
-     * Check whether termination condition is met.
-     *
-     * @param fittestChromosome Most fit chromosome at for the nth generation.
-     * @param averageFitnessScore Average fitness score as of the nth generation.
-     * @param currGeneration Current generation.
-     * @return Status whether condition is met or not.
-     */
-    public boolean isTerminationConditionMet(Chromosome fittestChromosome, double averageFitnessScore,
+    /** {@inheritDoc} */
+    @Override public boolean isTerminationConditionMet(Chromosome fittestChromosome, double averageFitnessScore,
         int currGeneration) {
         boolean isTerminate = true;
 
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/knapsack/KnapsackFitnessFunction.java b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/knapsack/KnapsackFitnessFunction.java
index b90457e..cce32a1 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/knapsack/KnapsackFitnessFunction.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/knapsack/KnapsackFitnessFunction.java
@@ -30,13 +30,8 @@ import org.apache.ignite.ml.genetic.IFitnessFunction;
  * To do this, we total the weights and values of all the genes within a chromosome.</p>
  */
 public class KnapsackFitnessFunction implements IFitnessFunction {
-    /**
-     * Calculate fitness.
-     *
-     * @param genes List of Genes.
-     * @return Fitness value.
-     */
-    public double evaluate(List<Gene> genes) {
+    /** {@inheritDoc} */
+    @Override public double evaluate(List<Gene> genes) {
         double val = 0;
         double weight = 0;
 
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/knapsack/KnapsackTerminateCriteria.java b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/knapsack/KnapsackTerminateCriteria.java
index 634b0d9..acf22fd 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/knapsack/KnapsackTerminateCriteria.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/knapsack/KnapsackTerminateCriteria.java
@@ -47,15 +47,8 @@ public class KnapsackTerminateCriteria implements ITerminateCriteria {
         this.logConsumer = logConsumer;
     }
 
-    /**
-     * Check whether termination condition is met.
-     *
-     * @param fittestChromosome Most fit chromosome at for the nth generation.
-     * @param averageFitnessScore Average fitness score as of the nth generation.
-     * @param currGeneration Current generation.
-     * @return Status whether condition is met or not.
-     */
-    public boolean isTerminationConditionMet(Chromosome fittestChromosome, double averageFitnessScore,
+    /** {@inheritDoc} */
+    @Override public boolean isTerminationConditionMet(Chromosome fittestChromosome, double averageFitnessScore,
         int currGeneration) {
         boolean isTerminate = true;
 
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/movie/MovieFitnessFunction.java b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/movie/MovieFitnessFunction.java
index 6fc8685..ecc29b0 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/movie/MovieFitnessFunction.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/movie/MovieFitnessFunction.java
@@ -45,13 +45,8 @@ public class MovieFitnessFunction implements IFitnessFunction {
         this.genres = genres;
     }
 
-    /**
-     * Calculate fitness score.
-     *
-     * @param genes List of Genes.
-     * @return Fitness score.
-     */
-    public double evaluate(List<Gene> genes) {
+    /** {@inheritDoc} */
+    @Override public double evaluate(List<Gene> genes) {
         double score = 0;
         List<String> duplicates = new ArrayList<>();
         int badSolution = 1;
diff --git a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/movie/MovieTerminateCriteria.java b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/movie/MovieTerminateCriteria.java
index 1ed61a3..d742ab9 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ml/genetic/movie/MovieTerminateCriteria.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ml/genetic/movie/MovieTerminateCriteria.java
@@ -48,15 +48,8 @@ public class MovieTerminateCriteria implements ITerminateCriteria {
 
     }
 
-    /**
-     * Check whether termination condition is met.
-     *
-     * @param fittestChromosome Most fit chromosome at for the nth generation.
-     * @param averageFitnessScore Average fitness score as of the nth generation.
-     * @param currGeneration Current generation.
-     * @return Status whether condition is met or not.
-     */
-    public boolean isTerminationConditionMet(Chromosome fittestChromosome, double averageFitnessScore,
+    /** {@inheritDoc} */
+    @Override public boolean isTerminationConditionMet(Chromosome fittestChromosome, double averageFitnessScore,
         int currGeneration) {
         boolean isTerminate = true;
 
diff --git a/idea/disabled_plugins.txt b/idea/disabled_plugins.txt
deleted file mode 100644
index 1dad326..0000000
--- a/idea/disabled_plugins.txt
+++ /dev/null
@@ -1,113 +0,0 @@
-AntSupport
-CVS
-ClearcasePlugin
-Coverage
-DevKit
-Emma
-GenerateToString
-Geronimo
-Glassfish
-Guice
-HtmlTools
-IdeaServerPlugin
-Inspection-JS
-InspectionGadgets
-IntentionPowerPack
-J2ME
-JBoss
-JSIntentionPowerPack
-JSR45Plugin
-JSTestDriver Plugin
-JUnit
-Java EE: Web Services (JAX-WS)
-JavaScript
-JavaScriptDebugger
-Jetty
-NodeJS
-Osmorc
-PerforceDirectPlugin
-Pythonid
-QuirksMode
-Refactor-X
-Resin
-SourceSafe
-StrutsAssistant
-Subversion
-TFS
-TestNG-J
-Tomcat
-Type Migration
-W3Validators
-WebServicesPlugin
-WebSphere
-Weblogic
-XPathView
-XSLT-Debugger
-ZKM
-com.android.tools.idea.smali
-com.intellij.aop
-com.intellij.apacheConfig
-com.intellij.appengine
-com.intellij.aspectj
-com.intellij.beanValidation
-com.intellij.cdi
-com.intellij.commander
-com.intellij.copyright
-com.intellij.css
-com.intellij.database
-com.intellij.diagram
-com.intellij.dmserver
-com.intellij.dsm
-com.intellij.flex
-com.intellij.freemarker
-com.intellij.guice
-com.intellij.gwt
-com.intellij.hibernate
-com.intellij.java-i18n
-com.intellij.java.cucumber
-com.intellij.javaee
-com.intellij.javaee.view
-com.intellij.jsf
-com.intellij.jsp
-com.intellij.persistence
-com.intellij.phing
-com.intellij.seam
-com.intellij.seam.pageflow
-com.intellij.seam.pages
-com.intellij.spring
-com.intellij.spring.batch
-com.intellij.spring.data
-com.intellij.spring.integration
-com.intellij.spring.osgi
-com.intellij.spring.roo
-com.intellij.spring.security
-com.intellij.spring.webflow
-com.intellij.spring.ws
-com.intellij.struts2
-com.intellij.tapestry
-com.intellij.tasks
-com.intellij.tcserver
-com.intellij.uiDesigner
-com.intellij.velocity
-com.jetbrains.jarFinder
-com.jetbrains.php
-com.jetbrains.php.framework
-com.jetbrains.plugins.asp
-com.jetbrains.plugins.webDeployment
-hg4idea
-org.coffeescript
-org.intellij.grails
-org.intellij.groovy
-org.intellij.intelliLang
-org.jetbrains.android
-org.jetbrains.idea.eclipse
-org.jetbrains.idea.maven.ext
-org.jetbrains.kotlin
-org.jetbrains.plugins.django-db-config
-org.jetbrains.plugins.github
-org.jetbrains.plugins.gradle
-org.jetbrains.plugins.haml
-org.jetbrains.plugins.less
-org.jetbrains.plugins.ruby
-org.jetbrains.plugins.sass
-org.jetbrains.plugins.yaml
\ No newline at end of file
diff --git a/idea/ignite_inspections_teamcity.xml b/idea/ignite_inspections_teamcity.xml
deleted file mode 100644
index 10d3c21..0000000
--- a/idea/ignite_inspections_teamcity.xml
+++ /dev/null
@@ -1,1461 +0,0 @@
-<profile version="1.0">
-    <option name="myName" value="ignite_inspections_teamcity" />
-    <!-- Enabled inspetions -->
-    <inspection_tool class="SizeReplaceableByIsEmpty" enabled="true" level="ERROR" enabled_by_default="true" />
-    <inspection_tool class="UnusedImport" enabled="true" level="ERROR" enabled_by_default="true"/>
-    <inspection_tool class="MissingOverrideAnnotation" enabled="true" level="ERROR" enabled_by_default="true">
-        <option name="ignoreObjectMethods" value="true" />
-        <option name="ignoreAnonymousClassMethods" value="false" />
-    </inspection_tool>
-    <inspection_tool class="MissortedModifiers" enabled="true" level="ERROR" enabled_by_default="true">
-        <option name="m_requireAnnotationsFirst" value="false" />
-    </inspection_tool>
-    <inspection_tool class="RedundantSuppression" enabled="true" level="ERROR" enabled_by_default="true" />
-    <inspection_tool class="ProblematicWhitespace" enabled="true" level="ERROR" enabled_by_default="true" />
-    <!-- Disabled inspetions -->
-    <inspection_tool class="AbsoluteAlignmentInUserInterface" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AbstractBeanReferencesInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="AbstractClassExtendsConcreteClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AbstractClassNamingConvention" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AbstractClassNeverImplemented" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AbstractClassWithoutAbstractMethods" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AbstractMethodCallInConstructor" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AbstractMethodOverridesAbstractMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AbstractMethodOverridesConcreteMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AbstractMethodWithMissingImplementations" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AccessStaticViaInstance" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AccessToNonThreadSafeStaticFieldFromInstance" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AccessToStaticFieldLockedOnInstance" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AddVarianceModifier" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AlphaUnsortedPropertiesFile" enabled="false" level="INFO" enabled_by_default="false"/>
-    <inspection_tool class="AmbiguousFieldAccess" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AmbiguousMethodCall" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="Annotation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AnnotationClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AnnotationNamingConvention" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_regex" value="[A-Z][A-Za-z\d]*"/>
-        <option name="m_minLength" value="8"/>
-        <option name="m_maxLength" value="64"/>
-    </inspection_tool>
-    <inspection_tool class="Annotator" enabled="false" level="ERROR" enabled_by_default="false" />
-    <inspection_tool class="Anonymous2MethodRef" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AnonymousClassVariableHidesContainingMethodVariable" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AnonymousInnerClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AnonymousInnerClassMayBeStatic" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AnonymousHasLambdaAlternative" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="AntDuplicateTargetsInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="AntMissingPropertiesFileInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="AntResolveInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="AppEngineDeprecatedRuntimeInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AppEngineForbiddenCode" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="AppEngineThreadsafeCGIHandlerInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AppEngineThreadsafeInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ArchaicSystemPropertyAccess" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ArgNamesErrorsInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="ArgNamesWarningsInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AroundAdviceStyleInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ArrayCreationWithoutNewKeyword" enabled="false" level="INFORMATION" enabled_by_default="false"/>
-    <inspection_tool class="ArrayEquality" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ArrayEquals" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ArrayHashCode" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ArrayInDataClass" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ArrayObjectsEquals" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ArraysAsListWithZeroOrOneArgument" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssertAsName" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssertEqualsBetweenInconvertibleTypes" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssertEqualsBetweenInconvertibleTypesTestNG" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssertEqualsCalledOnArray" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssertEqualsMayBeAssertSame" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssertMessageNotString" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssertStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssertWithSideEffects" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssertionCanBeIf" enabled="false" level="INFORMATION" enabled_by_default="false"/>
-    <inspection_tool class="AssertsWithoutMessages" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssertsWithoutMessagesTestNG" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssignmentToCatchBlockParameter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssignmentToCollectionFieldFromParameter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssignmentToDateFieldFromParameter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssignmentToForLoopParameter" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_checkForeachParameters" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="AssignmentToLambdaParameter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssignmentToMethodParameter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssignmentToNull" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AssignmentToStaticFieldFromInstanceMethod" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreAddedToCollection" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="AutoCloseableResource" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="AutoUnboxing" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreBooleanMethods" value="false"/>
-        <option name="ignoreInAnnotationInterface" value="true"/>
-        <option name="onlyWarnOnBaseMethods" value="true"/>
-        <option name="questionString"
-                value="add,are,can,check,contains,could,endsWith,equals,has,is,matches,must,put,remove,shall,should,startsWith,was,were,will,would"/>
-    </inspection_tool>
-    <inspection_tool class="AtomicFieldUpdaterIssues" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="AtomicFieldUpdaterNotStaticFinal" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="BigDecimalMethodWithoutRoundingCalled" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="BooleanParameter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="BooleanVariableAlwaysNegated" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="BooleanConstructor" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="BooleanMethodIsAlwaysInverted" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="BoundFieldAssignment" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="BoxingBoxedValue" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="BpmnConfigDomInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="BreakStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="BreakStatementWithLabel" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="BuildoutUnresolvedPartInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="BusyWait" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="BvConfigDomInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="BvConstraintMappingsInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="CStyleArrayDeclaration" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CachedNumberConstructorCall" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CallToNativeMethodWhileLocked" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CallToSimpleGetterInClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CallToSimpleSetterInClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CallToStringConcatCanBeReplacedByOperator" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CanBeFinal" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="REPORT_CLASSES" value="false"/>
-        <option name="REPORT_METHODS" value="false"/>
-        <option name="REPORT_FIELDS" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="CanBeParameter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CanBePrimaryConstructorProperty" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CanBeVal" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CastCanBeRemovedNarrowingVariableType" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="CastConflictsWithInstanceof" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CastThatLosesPrecision" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CastToConcreteClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CastToIncompatibleInterface" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CaughtExceptionImmediatelyRethrown" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ChainedEquality" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ChainedMethodCall" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ChangeToOperator" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ChannelResource" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="insideTryAllowed" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="CharsetObjectCanBeUsed" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="CharUsedInArithmeticContext" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CharacterComparison" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CheckDtdRefs" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="CheckEmptyScriptTag" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CheckImageSize" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CheckNodeTest" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CheckTagEmptyBody" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CheckValidXmlInScriptTagBody" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="CheckXmlFileWithXercesValidator" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="CheckedExceptionClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ClashingGetters" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ClashingTraitMethods" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ClassEscapesItsScope" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ClassInDefaultPackage" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="ClassInitializer" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ClassInitializerMayBeStatic" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ClassMayBeInterface" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ClassNameDiffersFromFileName" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ClassNamePrefixedWithPackageName" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ClassNameSameAsAncestorName" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ClassNamingConvention" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_regex" value="[A-Z][A-Za-z\d]*"/>
-        <option name="m_minLength" value="8"/>
-        <option name="m_maxLength" value="64"/>
-    </inspection_tool>
-    <inspection_tool class="ClassNewInstance" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ClassReferencesSubclass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ClassWithMultipleLoggers" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="loggerNamesString"
-                value="java.util.logging.Logger,org.slf4j.Logger,org.apache.commons.logging.Log,org.apache.log4j.Logger"/>
-    </inspection_tool>
-    <inspection_tool class="ClassWithOnlyPrivateConstructors" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ClassWithTooManyDependencies" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="limit" value="10"/>
-    </inspection_tool>
-    <inspection_tool class="ClassWithTooManyDependents" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="limit" value="10"/>
-    </inspection_tool>
-    <inspection_tool class="ClassWithTooManyTransitiveDependencies" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="limit" value="35"/>
-    </inspection_tool>
-    <inspection_tool class="ClassWithTooManyTransitiveDependents" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="limit" value="35"/>
-    </inspection_tool>
-    <inspection_tool class="ClassWithoutLogger" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="loggerNamesString"
-                value="java.util.logging.Logger,org.slf4j.Logger,org.apache.commons.logging.Log,org.apache.log4j.Logger"/>
-        <option name="ignoreSuperLoggers" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="CloneCallsSuperClone" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CloneDeclaresCloneNotSupported" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CodeBlock2Expr" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CollectionAddAllCanBeReplacedWithConstructor" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CollectionAddedToSelf" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CollectionContainsUrl" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CollectionsMustHaveInitialCapacity" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ComparableImplementedButEqualsNotOverridden" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ComparatorCombinators" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="ComparatorMethodParameterNotUsed" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="ComparatorResultComparison" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="ComparingDiffCollectionKinds" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="ComparingUnrelatedTypes" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="ComparatorNotSerializable" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CompareToUsesNonFinalVariable" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ComparisonOfShortAndChar" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ComparisonToNaN" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ComponentNotRegistered" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="CHECK_ACTIONS" value="true"/>
-        <option name="IGNORE_NON_PUBLIC" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="ComponentRegistrationProblems" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="ConditionalBreakInInfiniteLoop" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="ConditionCoveredByFurtherCondition" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="ConditionSignal" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConditionalExpression" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreSimpleAssignmentsAndReturns" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="ConditionalExpressionWithIdenticalBranches" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConflictingAnnotations" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConflictingExtensionProperty" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConfusingElse" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConfusingFloatingPointLiteral" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConfusingMainMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConfusingOctalEscape" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConstantAssertCondition" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConstantConditionIf" enabled="false" level="WEAK WARNING" enabled_by_default="false" />
-    <inspection_tool class="ConstantConditionalExpression" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="SUGGEST_NULLABLE_ANNOTATIONS" value="false"/>
-        <option name="DONT_REPORT_TRUE_ASSERT_STATEMENTS" value="false"/>
-        <option name="REPORT_NULLS_PASSED_TO_NOT_NULL_PARAMETER" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="ConstantConditions" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="SUGGEST_NULLABLE_ANNOTATIONS" value="true" />
-        <option name="DONT_REPORT_TRUE_ASSERT_STATEMENTS" value="true" />
-    </inspection_tool>
-    <inspection_tool class="ConstantExpression" enabled="false" level="INFORMATION" enabled_by_default="false" />
-    <inspection_tool class="ConstantDeclaredInAbstractClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConstantDeclaredInInterface" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConstantIfStatement" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="onlyCheckImmutables" value="false"/>
-        <option name="m_regex" value="[A-Z][A-Z_\d]*"/>
-        <option name="m_minLength" value="5"/>
-        <option name="m_maxLength" value="32"/>
-    </inspection_tool>
-    <inspection_tool class="ConstantOnLHSOfComparison" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConstantOnRHSOfComparison" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConstantStringIntern" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConstantValueVariableUse" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConstraintValidatorCreator" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ContextComponentScanInconsistencyInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="ContextJavaBeanUnresolvedMethodsInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ContinueOrBreakFromFinallyBlock" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ContinueStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ContinueStatementWithLabel" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="Contract" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ControlFlowStatementWithoutBraces" enabled="false" level="INFORMATION" enabled_by_default="false"/>
-    <inspection_tool class="Convert2Diamond" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="Convert2Lambda" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="reportNotAnnotatedInterfaces" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="Convert2MethodRef" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="Convert2streamapi" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConvertAnnotations" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConvertJavadoc" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConvertOldAnnotations" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ConvertToStringTemplate" enabled="false" level="INFO" enabled_by_default="false"/>
-    <inspection_tool class="CopyConstructorMissesField" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="CovariantCompareTo" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CovariantEquals" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CyclicClassDependency" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="CyclicPackageDependency" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DanglingJavadoc" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DataProviderReturnType" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="DateToString" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DeclareCollectionAsInterface" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreLocalVariables" value="false"/>
-        <option name="ignorePrivateMethodsAndFields" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="DeclareParentsInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="DefaultAnnotationParam" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DefaultFileTemplate" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="CHECK_FILE_HEADER" value="true"/>
-        <option name="CHECK_TRY_CATCH_SECTION" value="true"/>
-        <option name="CHECK_METHOD_BODY" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="DefaultNotLastCaseInSwitch" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DelegatesTo" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="Dependency" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="DeprecatedIsStillUsed" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="DeprecatedMavenDependency" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="DeprecatedViewBound" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="Deprecation" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="DeprecatedCallableAddReplaceWith" enabled="false" level="INFO" enabled_by_default="false"/>
-    <inspection_tool class="DeprecatedClassUsageInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DeprecatedGemInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="Deprecation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DialogTitleCapitalization" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DiamondCanBeReplacedWithExplicitTypeArguments" enabled="false" level="INFORMATION" enabled_by_default="false"/>
-    <inspection_tool class="DivideByZero" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DollarSignInName" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DontUsePairConstructor" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DoubleBraceInitialization" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DoubleCheckedLocking" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreOnVolatileVariables" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="DoubleLiteralMayBeFloatLiteral" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DoubleNegation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DriverManagerGetConnection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DuplicateBooleanBranch" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DuplicateCondition" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreMethodCalls" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="DuplicateExpressions" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DuplicateMnemonic" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DuplicatePropertyInspection" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="CURRENT_FILE" value="true"/>
-        <option name="MODULE_WITH_DEPENDENCIES" value="false"/>
-        <option name="CHECK_DUPLICATE_VALUES" value="true"/>
-        <option name="CHECK_DUPLICATE_KEYS" value="true"/>
-        <option name="CHECK_DUPLICATE_KEYS_WITH_DIFFERENT_VALUES" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="DuplicateStringLiteralInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DuplicateThrows" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DuplicatedBeanNamesInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="DuplicatedBlockNamesInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DuplicatedDataProviderNames" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="Duplicates" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="DynamicRegexReplaceableByCompiledPattern" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ELDeferredExpressionsInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ELMethodSignatureInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ELSpecValidationInJSP" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ELValidationInJSP" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EjbClassBasicInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="EjbClassWarningsInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EjbDomInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="EjbEntityClassInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="EjbEntityHomeInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="EjbEntityInterfaceInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="EjbEnvironmentInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="EjbInterceptorInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="EjbInterceptorWarningsInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EjbInterfaceMethodInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="EjbInterfaceSignatureInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="EjbProhibitedPackageUsageInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EjbQlInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="EjbRemoteRequirementsInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="EjbSessionHomeInterfaceInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="EjbStaticAccessInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EjbThisExpressionInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ElementOnlyUsedFromTestCode" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EmptyCatchBlock" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_includeComments" value="true"/>
-        <option name="m_ignoreTestCases" value="true"/>
-        <option name="m_ignoreIgnoreParameter" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="EmptyClass" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignorableAnnotations">
-            <value/>
-        </option>
-        <option name="ignoreClassWithParameterization" value="false"/>
-        <option name="ignoreThrowables" value="true"/>
-        <option name="commentsAreContent" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="EmptyFinallyBlock" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EmptyInitializer" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EmptyMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EmptyStatementBody" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_reportEmptyBlocks" value="true"/>
-        <option name="commentsAreContent" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="EqualityToSameElements" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="EqualsOnSuspiciousObject" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="EmptySynchronizedStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EmptyTryBlock" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EmptyWebServiceClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EndBlockNamesInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EnumAsName" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EnumClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EnumSwitchStatementWhichMissesCases" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreSwitchStatementsWithDefault" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="EnumeratedClassNamingConvention" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_regex" value="[A-Z][A-Za-z\d]*"/>
-        <option name="m_minLength" value="8"/>
-        <option name="m_maxLength" value="64"/>
-    </inspection_tool>
-    <inspection_tool class="EnumeratedConstantNamingConvention" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_regex" value="[A-Z][A-Z_\d]*"/>
-        <option name="m_minLength" value="5"/>
-        <option name="m_maxLength" value="32"/>
-    </inspection_tool>
-    <inspection_tool class="EqualityOperatorComparesObjects" enabled="false" level="INFORMATION" enabled_by_default="false"/>
-    <inspection_tool class="EqualsAndHashcode" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EqualsBetweenInconvertibleTypes" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EqualsCalledOnEnumConstant" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EqualsHashCodeCalledOnUrl" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EqualsOrHashCode" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EqualsReplaceableByObjectsCall" enabled="false" level="INFORMATION" enabled_by_default="false"/>
-    <inspection_tool class="EqualsUsesNonFinalVariable" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EqualsWhichDoesntCheckParameterClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="EqualsWithItself" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ErrorRethrown" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ExceptionFromCatchWhichDoesntWrap" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ExceptionNameDoesntEndWithException" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ExpectedExceptionNeverThrown" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ExpectedExceptionNeverThrownTestNG" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ExtendsAnnotation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ExtendsConcreteCollection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ExtendsObject" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ExtendsTagPositionInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ExtendsThread" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ExtendsThrowable" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ExtendsUtilityClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ExtensionPointBeanClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ExternalizableWithSerializationMethods" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ExternalizableWithoutPublicNoArgConstructor" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="FaceletsDetectingInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="FacesModelInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="FallthruInSwitchStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="FeatureEnvy" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreTestCases" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="FieldAccessedSynchronizedAndUnsynchronized" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="countGettersAndSetters" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="FieldCanBeLocal" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="FieldHidesSuperclassField" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_ignoreInvisibleFields" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="FieldMayBeFinal" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="FieldMayBeStatic" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="FileEqualsUsage" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="FinalClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="FinalMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="FinalMethodInFinalClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="FinalPrivateMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="FinalStaticMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="Finalize" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreTrivialFinalizers" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="FinalizeNotProtected" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="FinallyBlockCannotCompleteNormally" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="FloatingPointEquality" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="FlowRequiredBeanTypeInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="ForCanBeForeach" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="REPORT_INDEXED_LOOP" value="true"/>
-        <option name="ignoreUntypedCollections" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="ForLoopReplaceableByWhile" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_ignoreLoopsWithoutConditions" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="ForLoopThatDoesntUseLoopVariable" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ForLoopWithMissingComponent" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ForeachStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="Guava" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="HardCodedStringLiteral" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="HardcodedActionUrl" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="HardwiredNamespacePrefix" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="HasPlatformType" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="HashCodeUsesNonFinalVariable" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="HibernateConfigDomFacetInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="HibernateConfigDomInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="HibernateMappingDatasourceDomInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="HibernateMappingDomInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="HibernateResource" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="insideTryAllowed" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="HtmlDeprecatedTag" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="HtmlExtraClosingTag" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="HtmlFormInputWithoutLabel" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="HtmlNonExistentInternetResource" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="HtmlPresentationalElement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="HtmlTagCanBeJavadocTag" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="HtmlUnknownAnchorTarget" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="HtmlUnknownAttribute" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="myValues">
-            <value>
-                <list size="0"/>
-            </value>
-        </option>
-        <option name="myCustomValuesEnabled" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="HtmlUnknownBooleanAttribute" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="HtmlUnknownTag" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="myValues">
-            <value>
-                <list size="4">
-                    <item index="0" class="java.lang.String" itemvalue="nobr"/>
-                    <item index="1" class="java.lang.String" itemvalue="noembed"/>
-                    <item index="2" class="java.lang.String" itemvalue="comment"/>
-                    <item index="3" class="java.lang.String" itemvalue="noscript"/>
-                </list>
-            </value>
-        </option>
-        <option name="myCustomValuesEnabled" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="HtmlUnknownTarget" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IOResource" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoredTypesString"
-                value="java.io.ByteArrayOutputStream,java.io.ByteArrayInputStream,java.io.StringBufferInputStream,java.io.CharArrayWriter,java.io.CharArrayReader,java.io.StringWriter,java.io.StringReader"/>
-        <option name="insideTryAllowed" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="IfCanBeAssertion" enabled="false" level="INFORMATION" enabled_by_default="false"/>
-    <inspection_tool class="IfCanBeSwitch" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="minimumBranches" value="3"/>
-        <option name="suggestIntSwitches" value="false"/>
-        <option name="suggestEnumSwitches" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="IfMayBeConditional" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IfNullToElvis" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IfStatementWithIdenticalBranches" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IfStatementWithTooManyBranches" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IfThenToElvis" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IfThenToSafeAccess" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IgnoreResultOfCall" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_reportAllNonLibraryCalls" value="false"/>
-        <option name="callCheckString"
-                value="java.io.File,.*,java.io.InputStream,read|skip|available|markSupported,java.io.Reader,read|skip|ready|markSupported,java.lang.Boolean,.*,java.lang.Byte,.*,java.lang.Character,.*,java.lang.Double,.*,java.lang.Float,.*,java.lang.Integer,.*,java.lang.Long,.*,java.lang.Math,.*,java.lang.Object,equals|hashCode|toString,java.lang.Short,.*,java.lang.StrictMath,.*,java.lang.String,.*,java.math.BigInteger,.*,java.math.BigDecimal,.*,java.net.InetAddress,.*,java.net.URI,.*,jav [...]
-    </inspection_tool>
-    <inspection_tool class="IgnoredJUnitTest" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ImplicitArrayToString" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ImplicitCallToSuper" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ImplicitDefaultCharsetUsage" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ImplicitNumericConversion" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ImplicitTypeConversion" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="BITS" value="1720"/>
-        <option name="FLAG_EXPLICIT_CONVERSION" value="true"/>
-        <option name="IGNORE_NODESET_TO_BOOLEAN_VIA_STRING" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="ImplicitlyExposedWebServiceMethods" enabled="false" level="INFO" enabled_by_default="false"/>
-    <inspection_tool class="IncompatibleMask" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IncompleteProperty" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="InconsistentResourceBundle" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="IncorrectOnMessageMethodsInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="IncrementDecrementUsedAsExpression" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IndexOfReplaceableByContains" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IndexZeroUsage" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InfiniteLoopStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InfiniteRecursion" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InjectOfNonPublicMember" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InjectionNotApplicable" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="InjectionValueTypeInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="InnerClassMayBeStatic" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InnerClassOnInterface" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_ignoreInnerInterfaces" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="InnerClassReferencedViaSubclass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InnerClassVariableHidesOuterClassVariable" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_ignoreInvisibleFields" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="InspectionDescriptionNotFoundInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InspectionMappingConsistency" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InspectionUsingGrayColors" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InstanceMethodNamingConvention" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InstanceVariableInitialization" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InstanceVariableNamingConvention" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InstanceVariableOfConcreteClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InstanceVariableUninitializedUse" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InstanceofCatchParameter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InstanceofChain" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreInstanceofOnLibraryClasses" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="InstanceofIncompatibleInterface" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InstanceofInterfaces" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InstanceofThis" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InstantiatingObjectToGetClassObject" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InstantiationOfUtilityClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IntLiteralMayBeLongLiteral" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IntegerDivisionInFloatingPointContext" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IntegerMultiplicationImplicitCastToLong" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IntentionDescriptionNotFoundInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InterceptionAnnotationWithoutRuntimeRetention" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InterfaceMayBeAnnotatedFunctional" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InterfaceMethodClashesWithObject" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InterfaceNamingConvention" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InterfaceNeverImplemented" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreInterfacesThatOnlyDeclareConstants" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="IntroduceWhenSubject" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InvalidI18nProperty" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="InvalidImplementedBy" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InvalidProvidedBy" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="InvalidRequestParameters" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IteratorHasNextCallsIteratorNext" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="IteratorNextDoesNotThrowNoSuchElementException" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JDBCResource" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JNDIResource" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JUnit3MethodNamingConvention" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JUnit3StyleTestMethodInJUnit4Class" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JUnit4AnnotatedMethodInJUnit3TestCase" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JUnit4MethodNamingConvention" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JUnitAbstractTestClassNamingConvention" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_regex" value="[A-Z][A-Za-z\d]*TestCase"/>
-        <option name="m_minLength" value="12"/>
-        <option name="m_maxLength" value="64"/>
-    </inspection_tool>
-    <inspection_tool class="JUnitDatapoint" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JUnitRule" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JUnitTestClassNamingConvention" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_regex" value="[A-Z][A-Za-z\d]*Test"/>
-        <option name="m_minLength" value="8"/>
-        <option name="m_maxLength" value="64"/>
-    </inspection_tool>
-    <inspection_tool class="JUnitTestNG" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="Java8CollectionsApi" enabled="false" level="INFORMATION" enabled_by_default="false"/>
-    <inspection_tool class="Java8ReplaceMapGet" enabled="false" level="INFORMATION" enabled_by_default="false"/>
-    <inspection_tool class="Java8ArraySetAll" enabled="false" level="INFORMATION" enabled_by_default="false" />
-    <inspection_tool class="Java8CollectionRemoveIf" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="Java8ListSort" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="Java8MapApi" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="Java8MapForEach" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="Java9CollectionFactory" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="Java9ModuleExportsPackageToItself" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="Java9RedundantRequiresStatement" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="Java9ReflectionClassVisibility" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="Java9UndeclaredServiceUsage" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="JavaDoc" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="TOP_LEVEL_CLASS_OPTIONS">
-            <value>
-                <option name="ACCESS_JAVADOC_REQUIRED_FOR" value="none"/>
-                <option name="REQUIRED_TAGS" value=""/>
-            </value>
-        </option>
-        <option name="INNER_CLASS_OPTIONS">
-            <value>
-                <option name="ACCESS_JAVADOC_REQUIRED_FOR" value="none"/>
-                <option name="REQUIRED_TAGS" value=""/>
-            </value>
-        </option>
-        <option name="METHOD_OPTIONS">
-            <value>
-                <option name="ACCESS_JAVADOC_REQUIRED_FOR" value="none"/>
-                <option name="REQUIRED_TAGS" value="@return@param@throws or @exception"/>
-            </value>
-        </option>
-        <option name="FIELD_OPTIONS">
-            <value>
-                <option name="ACCESS_JAVADOC_REQUIRED_FOR" value="none"/>
-                <option name="REQUIRED_TAGS" value=""/>
-            </value>
-        </option>
-        <option name="IGNORE_DEPRECATED" value="false"/>
-        <option name="IGNORE_JAVADOC_PERIOD" value="true"/>
-        <option name="IGNORE_DUPLICATED_THROWS" value="false"/>
-        <option name="IGNORE_POINT_TO_ITSELF" value="false"/>
-        <option name="myAdditionalJavadocTags" value=""/>
-    </inspection_tool>
-    <inspection_tool class="JavaFxDefaultTag" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JavaFxUnresolvedFxIdReference" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JavaFxUnresolvedStyleClassReference" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JavaFxUnusedImports" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JavaLangImport" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JavaStylePropertiesInvocation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JavaModuleNaming" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="JavaMutatorMethodAccessedAsParameterless" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="JavaMutatorMethodOverriddenAsParameterless" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="JavaMutatorMethodOverridenAsParameterless" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="JavaReflectionInvocation" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="JavaReflectionMemberAccess" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="JavaRequiresAutoModule" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="JavacQuirks" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="JavadocHtmlLint" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="JavadocReference" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="CHECK_NON_ANNOTATED_REFERENCES" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="LawOfDemeter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LengthOneStringInIndexOf" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LengthOneStringsInConcatenation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LessResolvedByNameOnly" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LessUnresolvedMixin" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LessUnresolvedVariable" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LimitedScopeInnerClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ListIndexOfReplaceableByContains" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ListenerMayUseAdapter" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="checkForEmptyMethods" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="LiteralAsArgToStringEquals" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LocalCanBeFinal" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LocalVariableHidingMemberVariable" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_ignoreInvisibleFields" value="true"/>
-        <option name="m_ignoreStaticMethods" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="LocalVariableNamingConvention" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LocalVariableOfConcreteClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LogStatementGuardedByLogCondition" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LoggerInitializedWithForeignClass" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="loggerClassName"
-                value="org.apache.log4j.Logger,org.slf4j.LoggerFactory,org.apache.commons.logging.LogFactory,java.util.logging.Logger"/>
-        <option name="loggerFactoryMethodName" value="getLogger,getLogger,getLog,getLogger"/>
-    </inspection_tool>
-    <inspection_tool class="LoggingConditionDisagreesWithLogStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LongLiteralsEndingWithLowercaseL" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LoopConditionNotUpdatedInsideLoop" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LoopStatementsThatDontLoop" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LoopWithImplicitTerminationCondition" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="LossyEncoding" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MVCPathVariableInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MagicCharacter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MagicConstant" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MagicNumber" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MakoArgumentListInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MalformedFormatString" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MalformedRegex" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MalformedSetUpTearDown" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MalformedXPath" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ManagedBeanClassInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="ManagedBeanInconsistencyInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="ManualArrayCopy" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ManualArrayToCollectionCopy" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MapReplaceableByEnumMap" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MarkerInterface" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MathRandomCastToInt" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MavenDuplicateDependenciesInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MavenDuplicatePluginInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MavenModelInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="MavenRedundantGroupId" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MethodCanBeVariableArityMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MethodMayBeStatic" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_onlyPrivateOrFinal" value="true"/>
-        <option name="m_ignoreEmptyMethods" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="MethodMayBeSynchronized" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MethodNameSameAsClassName" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MethodNameSameAsParentName" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MethodNamesDifferOnlyByCase" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MethodOnlyUsedFromInnerClass" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreMethodsAccessedFromAnonymousClass" value="false"/>
-        <option name="ignoreStaticMethodsFromNonStaticInnerClass" value="false"/>
-        <option name="onlyReportStaticMethods" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="MethodOverloadsParentMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MethodOverridesPackageLocalMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MethodOverridesPrivateMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MethodOverridesStaticMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MethodRefCanBeReplacedWithLambda" enabled="false" level="INFORMATION" enabled_by_default="false"/>
-    <inspection_tool class="MethodReturnAlwaysConstant" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MethodReturnOfConcreteClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MigrateAssertToMatcherAssert" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MimeType" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="MinMaxValuesInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MinitestFrameworkSupportInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MismatchedArrayReadWrite" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MismatchedCollectionQueryUpdate" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="queryNames">
-            <value/>
-        </option>
-        <option name="updateNames">
-            <value/>
-        </option>
-    </inspection_tool>
-    <inspection_tool class="MismatchedStringBuilderQueryUpdate" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MisorderedAssertEqualsArgumentsTestNG" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MisorderedAssertEqualsParameters" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MissedExecutable" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MissingAspectjAutoproxyInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MissingDeprecatedAnnotation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MissingFinalNewline" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="MissingMnemonic" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MissingPackageInfo" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MisspelledCompareTo" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MisspelledEquals" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MisspelledHashcode" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MisspelledHeader" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MisspelledMethodName" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MisspelledSetUp" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MisspelledTearDown" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MisspelledToString" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MultiCatchCanBeSplit" enabled="false" level="INFORMATION" enabled_by_default="false"/>
-    <inspection_tool class="MultipleBindingAnnotations" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MultipleDeclaration" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MultipleExceptionsDeclaredOnTestMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MultipleInjectedConstructorsForClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MultipleMethodDesignatorsInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MultipleRepositoryUrls" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MultipleTopLevelClassesInFile" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="MultipleTypedDeclaration" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NakedNotify" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NativeMethodNamingConvention" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NegatedConditional" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NegatedConditionalExpression" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NegatedEqualityExpression" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NegatedIfElse" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NegativelyNamedBooleanVariable" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NestedAssignment" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NestedConditionalExpression" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NestedMethodCall" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NestedSwitchStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NestedSynchronizedStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NestedTryStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NewExceptionWithoutArguments" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NewInstanceOfSingleton" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NewStringBufferWithCharArgument" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NoButtonGroup" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NoExplicitFinalizeCalls" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NoLabelFor" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NoScrollPane" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonAtomicOperationOnVolatileField" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonBooleanMethodNameMayNotStartWithQuestion" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonExceptionNameEndsWithException" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonFinalFieldInEnum" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonFinalFieldOfException" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonFinalStaticVariableUsedInClassInitialization" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonFinalUtilityClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonJREEmulationClassesInClientCode" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="NonJaxWsWebServices" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonProtectedConstructorInAbstractClass" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_ignoreNonPublicClasses" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="NonReproducibleMathCall" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonSerializableFieldInSerializableClass" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignorableAnnotations">
-            <value/>
-        </option>
-        <option name="ignoreAnonymousInnerClasses" value="false"/>
-        <option name="superClassString" value=""/>
-    </inspection_tool>
-    <inspection_tool class="NonSerializableObjectBoundToHttpSession" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonSerializableObjectPassedToObjectStream" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonSerializableServiceParameters" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="NonSerializableWithSerialVersionUIDField" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonSerializableWithSerializationMethods" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonShortCircuitBoolean" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonStaticFinalLogger" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="loggerClassName" value="java.util.logging.Logger"/>
-    </inspection_tool>
-    <inspection_tool class="NonSynchronizedMethodOverridesSynchronizedMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NonThreadSafeLazyInitialization" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NoopMethodInAbstractClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NotifyCalledOnCondition" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NotifyNotInSynchronizedContext" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NotifyWithoutCorrespondingWait" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NullArgumentToVariableArgMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NullThrown" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NullableProblems" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="REPORT_NULLABLE_METHOD_OVERRIDES_NOTNULL" value="true"/>
-        <option name="REPORT_NOT_ANNOTATED_METHOD_OVERRIDES_NOTNULL" value="true"/>
-        <option name="REPORT_NOTNULL_PARAMETER_OVERRIDES_NULLABLE" value="true"/>
-        <option name="REPORT_NOT_ANNOTATED_PARAMETER_OVERRIDES_NOTNULL" value="true"/>
-        <option name="REPORT_NOT_ANNOTATED_GETTER" value="true"/>
-        <option name="IGNORE_EXTERNAL_SUPER_NOTNULL" value="true"/>
-        <option name="REPORT_NOT_ANNOTATED_SETTER_PARAMETER" value="true"/>
-        <option name="REPORT_ANNOTATION_NOT_PROPAGATED_TO_OVERRIDERS" value="true"/>
-        <option name="REPORT_NULLS_PASSED_TO_NON_ANNOTATED_METHOD" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="NumberEquality" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NumericOverflow" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="NumericToString" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ObviousNullCheck" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="ObjectAllocationInLoop" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ObjectEquality" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ObjectEqualsNull" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ObjectInstantiationInEqualsHashCode" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ObjectLiteralToLambda" enabled="false" level="INFO" enabled_by_default="false"/>
-    <inspection_tool class="ObjectNotify" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ObjectToString" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ObsoleteCollection" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreRequiredObsoleteCollectionTypes" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="ObviousNullCheck" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="OptionEqualsSome" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="OptionalAssignedToNull" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="OptionalIsPresent" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="OverwrittenKey" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="OctalAndDecimalIntegersMixed" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="OctalLiteral" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="OnDemandImport" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="OneButtonGroup" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="OneWayWebMethod" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="OptionalContainsCollection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="OptionalGetWithoutIsPresent" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="OptionalUsedAsFieldOrParameterType" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="OverloadedMethodsWithSameNumberOfParameters" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="OverloadedVarargsMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="OverlyComplexArithmeticExpression" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="OverlyComplexBooleanExpression" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="OverlyStrongTypeCast" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreInMatchingInstanceof" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="OverridableMethodCallDuringObjectConstruction" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="OverriddenMethodCallDuringObjectConstruction" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="OverridingDeprecatedMember" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PackageAccessibility" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="PackageDirectoryMismatch" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PackageDotHtmlMayBePackageInfo" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PackageInfoWithoutPackage" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PackageNamingConvention" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_regex" value="[a-z]*"/>
-        <option name="m_minLength" value="3"/>
-        <option name="m_maxLength" value="16"/>
-    </inspection_tool>
-    <inspection_tool class="PageflowModelInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="PagesFileModelInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="PagesModelInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="ParameterCanBeLocal" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ParameterHidingMemberVariable" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ParameterNameDiffersFromOverriddenParameter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ParameterNamingConvention" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ParameterOfConcreteClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ParameterTypePreventsOverriding" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ParameterizedParametersStaticCollection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PathAnnotation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PatternNotApplicable" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="PatternOverriddenByNonAnnotatedMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PatternValidation" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="CHECK_NON_CONSTANT_VALUES" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="PlaceholderCountMatchesArgumentCount" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PlayCustomTagNameInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PlayPropertyInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PluginXmlValidity" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="PointcutMethodStyleInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PointlessArithmeticExpression" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_ignoreExpressionsContainingConstants" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="PointlessBinding" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PointlessBitwiseExpression" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_ignoreExpressionsContainingConstants" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="PointlessBooleanExpression" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_ignoreExpressionsContainingConstants" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="PointlessIndexOfComparison" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PointlessNullCheck" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PostfixTemplateDescriptionNotFound" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PrimitiveArrayArgumentToVariableArgMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ProblematicVarargsMethodOverride" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ProtectedInFinal" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ProtectedMemberInFinalClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PublicConstructor" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PublicConstructorInNonPublicClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PublicFieldAccessedInSynchronizedContext" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="PublicMethodNotExposedInInterface" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignorableAnnotations">
-            <value/>
-        </option>
-        <option name="onlyWarnIfContainingClassImplementsAnInterface" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="PublicMethodWithoutLogging" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="Query_bound_parameters" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="Query_index_required" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="Query_restricted" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="QuestionableName" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="QuickFixGetFamilyNameViolation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RSReferenceInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RandomDoubleForRandomInteger" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RawTypeCanBeGeneric" enabled="false" level="INFORMATION" enabled_by_default="false"/>
-    <inspection_tool class="RawUseOfParameterizedType" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ReadObjectAndWriteObjectPrivate" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ReadObjectInitialization" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ReadResolveAndWriteReplaceProtected" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantArrayCreation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantCast" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="IGNORE_ANNOTATED_METHODS" value="true"/>
-        <option name="IGNORE_SUSPICIOUS_METHOD_CALLS" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="RedundantClassCall" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantCollectionOperation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantCompareCall" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantFieldInitialization" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantImplements" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantLambdaParameterType" enabled="false" level="INFORMATION" enabled_by_default="false"/>
-    <inspection_tool class="RedundantMethodOverride" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantModalityModifier" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantSamConstructor" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantScopeBinding" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantSemicolon" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantStringFormatCall" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantThrows" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantThrowsDeclaration" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantToBinding" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantToProviderBinding" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantTypeArguments" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RedundantTypeConversion" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="CHECK_ANY" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="RedundantVisibilityModifier" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RegExpDuplicateAlternationBranch" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="RegExpEmptyAlternationBranch" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="RegExpEscapedMetaCharacter" enabled="false" level="INFORMATION" enabled_by_default="false" />
-    <inspection_tool class="RegExpOctalEscape" enabled="false" level="INFORMATION" enabled_by_default="false" />
-    <inspection_tool class="RegExpRedundantEscape" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="RegExpRepeatedSpace" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="RegExpSingleCharAlternation" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="RegExpUnexpectedAnchor" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="ReferencesToClassesFromDefaultPackagesInJSPFile" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="ReflectionForUnavailableAnnotation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RefusedBequest" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreEmptySuperMethods" value="false"/>
-        <option name="onlyReportWhenAnnotated" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="RemoveCurlyBracesFromTemplate" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RemoveExplicitSuperQualifier" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RemoveExplicitTypeArguments" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RemoveForLoopIndices" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ReplaceAllDot" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ReplaceAssignmentWithOperatorAssignment" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreLazyOperators" value="true"/>
-        <option name="ignoreObscureOperators" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="ReplaceGetOrSet" enabled="false" level="INFO" enabled_by_default="false"/>
-    <inspection_tool class="ReplaceWithOperatorAssignment" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="RequiredArtifactTypeInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="RequiredAttributes" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="myAdditionalRequiredHtmlAttributes" value=""/>
-    </inspection_tool>
-    <inspection_tool class="RequiredBeanTypeInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="RestWrongDefaultValueInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="Restricted_Python_calls" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ResultOfObjectAllocationIgnored" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ResultSetIndexZero" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ReturnFromFinallyBlock" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ReturnNull" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ReturnOfInnerClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ReturnThis" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ReuseOfLocalVariable" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SafeLock" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SafeVarargsDetector" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SamePackageImport" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SameParameterValue" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SameReturnValue" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SameVersion" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SameVersionIDEPlugin" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SeamAnnotationIncorrectSignatureInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SeamAnnotationsInconsistencyInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SeamBijectionIllegalScopeParameterInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SeamBijectionTypeMismatchInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SeamBijectionUndefinedContextVariableInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SeamDomModelInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SeamDuplicateComponentsInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SeamIllegalComponentScopeInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SeamJamComponentInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SecondUnsafeCall" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SelfIncludingJspFiles" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SerialPersistentFieldsWithWrongSignature" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SerialVersionUIDNotStaticFinal" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SerializableHasSerialVersionUIDField" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreAnonymousInnerClasses" value="false"/>
-        <option name="superClassString" value=""/>
-    </inspection_tool>
-    <inspection_tool class="SerializableHasSerializationMethods" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreAnonymousInnerClasses" value="false"/>
-        <option name="superClassString" value=""/>
-    </inspection_tool>
-    <inspection_tool class="SerializableInnerClassHasSerialVersionUIDField" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreAnonymousInnerClasses" value="false"/>
-        <option name="superClassString" value=""/>
-    </inspection_tool>
-    <inspection_tool class="SerializableInnerClassWithNonSerializableOuterClass" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreAnonymousInnerClasses" value="false"/>
-        <option name="superClassString" value=""/>
-    </inspection_tool>
-    <inspection_tool class="SerializableStoresNonSerializable" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SerializableWithUnconstructableAncestor" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ServerEndpointInconsistencyInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="ServletWithoutMappingInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SessionScopedInjectsRequestScoped" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SetReplaceableByEnumSet" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SetupCallsSuperSetup" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SetupIsPublicVoidNoArg" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SharedThreadLocalRandom" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ShiftOutOfRange" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SignalWithoutCorrespondingAwait" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SillyAssignment" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SimpleDateFormatWithoutLocale" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SimplifiableAnnotation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SimplifiableBooleanExpression" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SimplifiableConditionalExpression" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SimplifiableEqualsExpression" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SimplifiableIfStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SimplifiableJUnitAssertion" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SimplifyAssertNotNull" enabled="false" level="INFO" enabled_by_default="false"/>
-    <inspection_tool class="SimplifyBooleanWithConstants" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SimplifyFor" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SimplifyNegatedBinaryExpression" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SimplifyStreamApiCallChains" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="Since15" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SingleCharAlternation" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="SingleClassImport" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SingleElementAnnotation" enabled="false" level="INFORMATION" enabled_by_default="false"/>
-    <inspection_tool class="SingleStatementInBlock" enabled="false" level="INFORMATION" enabled_by_default="false"/>
-    <inspection_tool class="Singleton" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SingletonInjectsScoped" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SleepWhileHoldingLock" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SocketResource" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="insideTryAllowed" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="SpellCheckingInspection" enabled="false" level="TYPO" enabled_by_default="false">
-        <option name="processCode" value="true"/>
-        <option name="processLiterals" value="true"/>
-        <option name="processComments" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="SortedCollectionWithNonComparableKeys" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="SpringAopErrorsInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringAopWarningsInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringBatchModel" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringBeanAttributesInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringBeanAutowiringInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringBeanConstructorArgInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringBeanDepedencyCheckInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringBeanInstantiationInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringBeanLookupMethodInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringBeanNameConventionInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringContextConfigurationInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringDataJpaMethodInconsistencyInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringElInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringFacetCodeInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringFacetInspection" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="checkTestFiles" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="SpringFacetProgrammaticInspection" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringFactoryMethodInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringHandlersSchemasHighlighting" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringIncorrectResourceTypeInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringInjectionValueConsistencyInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringInjectionValueStyleInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringIntegrationDeprecations21" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringIntegrationModel" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringJavaAutowiringInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringJavaConfigExternalBeansErrorInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringJavaConfigInconsistencyInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringMVCInitBinder" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringMVCViewInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringMessageDispatcherWebXmlInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringModelInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringOsgiElementsInconsistencyInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringOsgiListenerInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringOsgiServiceCommonInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringPlaceholdersInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringPublicFactoryMethodInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringReplacedMethodsInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringRequiredAnnotationInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringRequiredPropertyInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringScopesInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringSecurityDebugActivatedInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringSecurityElementsInconsistencyInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringSecurityFiltersConfiguredInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringSecurityModelInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringStaticMembersAutowiringInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringTransactionalComponentInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringWebServiceAnnotationsInconsistencyInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SpringWebServicesConfigurationsInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SpringXmlModelInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SqlAddNotNullColumnInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlAmbiguousColumnInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlAutoIncrementDuplicateInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlCheckUsingColumnsInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlConstantConditionInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlDeliverTableNameInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlDeprecateTypeInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlDerivedTableAliasInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlDialectInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlDropIndexedColumnInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlIdentifierInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlInsertValuesInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlNoDataSourceInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlNullComparisonInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlPostgresqlSelectFromProcedureInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlResolveInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlShouldBeInGroupByInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SqlTypeInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StandardVariableNames" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StatefulEp" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StaticCallOnSubclass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StaticCollection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StaticFieldReferenceOnSubclass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StaticImport" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StaticInheritance" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StaticInitializerReferencesSubClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StaticMethodNamingConvention" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StaticMethodOnlyUsedInOneClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StaticNonFinalField" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StaticPseudoFunctionalStyleMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StaticSuite" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StaticVariableInitialization" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StaticVariableNamingConvention" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StaticVariableOfConcreteClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StaticVariableUninitializedUse" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringBufferField" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringBufferMustHaveInitialCapacity" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringBufferReplaceableByString" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringBufferReplaceableByStringBuilder" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringBufferToStringInConcatenation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringCompareTo" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringConcatenation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringConcatenationArgumentToLogCall" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringConcatenationInFormatCall" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringConcatenationInLoops" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringConcatenationInMessageFormatCall" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringConcatenationInsideStringBufferAppend" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringConcatenationMissingWhitespace" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringConstructor" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreSubstringArguments" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="StringEquality" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringEquals" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringEqualsEmptyString" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringEqualsIgnoreCase" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringReplaceableByStringBuffer" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringToString" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringToUpperWithoutLocale" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringTokenizer" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="StringTokenizerDelimiter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="Struts2ModelInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="StrutsInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="StrutsTilesInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="StrutsValidatorFormInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="StrutsValidatorInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SubstringZero" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SubtractionInCompareTo" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SuperClassHasFrequentlyUsedInheritors" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SuperTearDownInFinally" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SuppressionAnnotation" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SuspiciousArrayMethodCall" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="SuspiciousEqualsCombination" enabled="false" level="WEAK WARNING" enabled_by_default="false" />
-    <inspection_tool class="SuspiciousArrayCast" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SuspiciousIndentAfterControlStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SuspiciousLiteralUnderscore" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SuspiciousLocalesLanguages" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SuspiciousMethodCalls" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="REPORT_CONVERTIBLE_METHOD_CALLS" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="SuspiciousNameCombination" enabled="false" level="WARNING" enabled_by_default="false">
-        <group names="x,width,left,right"/>
-        <group names="y,height,top,bottom"/>
-    </inspection_tool>
-    <inspection_tool class="SuspiciousSystemArraycopy" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SuspiciousToArrayCall" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SwitchStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SwitchStatementDensity" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SwitchStatementWithConfusingDeclaration" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SwitchStatementWithTooFewBranches" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SwitchStatementWithTooManyBranches" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SwitchStatementsWithoutDefault" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SynchronizationOnGetClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SynchronizationOnLocalVariableOrMethodParameter" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="reportLocalVariables" value="true"/>
-        <option name="reportMethodParameters" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="SynchronizationOnStaticField" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SynchronizeOnLock" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SynchronizeOnNonFinalField" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SynchronizeOnThis" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SynchronizedMethod" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SynchronizedOnLiteralObject" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SyntaxError" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="SystemGC" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="SystemOutErr" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreSupers" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="TestMethodInProductCode" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="TestMethodIsPublicVoidNoArg" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="TestMethodWithoutAssertion" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="TestNGDataProvider" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="TestNGMethodNamingConvention" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="TextLabelInSwitchStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ThisEscapedInConstructor" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ThreadDeathRethrown" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ThreadDumpStack" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="useRighthandTypeAsWeakestTypeInAssignments" value="true"/>
-        <option name="useParameterizedTypeForCollectionMethods" value="true"/>
-        <option name="doNotWeakenToJavaLangObject" value="true"/>
-        <option name="onlyWeakentoInterface" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="ThrowFromFinallyBlock" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="ThrowableInstanceNeverThrown" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="ThrowableNotThrown" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="ThrowablePrintedToSystemOut" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="ThrowableResultOfMethodCallIgnored" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="ToArrayCallWithZeroLengthArrayArgument" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="TrivialIf" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="TryFinallyCanBeTryWithResources" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="TryStatementWithMultipleResources" enabled="false" level="INFORMATION" enabled_by_default="false" />
-    <inspection_tool class="TryWithIdenticalCatches" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="TypeParameterExtendsFinalClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="TypeParameterExtendsObject" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="TypeParameterHidesVisibleType" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="TypeParameterNamingConvention" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UNCHECKED_WARNING" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnaryPlus" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UncheckedExceptionClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnclearBinaryExpression" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnconditionalWait" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnconstructableTestCase" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UndeclaredTests" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UndesirableClassUsage" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UninstantiableBinding" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UninstantiableImplementedByClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UninstantiableProvidedByClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnknownLanguage" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="UnknownManifestPackage" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessarilyQualifiedInnerClassAccess" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessarilyQualifiedStaticUsage" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_ignoreStaticFieldAccesses" value="false"/>
-        <option name="m_ignoreStaticMethodCalls" value="false"/>
-        <option name="m_ignoreStaticAccessFromStaticContext" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="UnnecessarilyQualifiedStaticallyImportedElement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryBlockStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryBoxing" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryBreak" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryCallToStringValueOf" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryConditionalExpression" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryConstantArrayCreationExpression" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryConstructor" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryContinue" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryDefault" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryEmptyArrayUsage" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryEnumModifier" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryExplicitNumericCast" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryFinalOnLocalVariableOrParameter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryFullyQualifiedName" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_ignoreJavadoc" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="UnnecessaryInheritDoc" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryInitCause" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryInterfaceModifier" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryJavaDocLink" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryLabelOnBreakStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryLabelOnContinueStatement" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryLocalVariable" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="m_ignoreImmediatelyReturnedVariables" value="false"/>
-        <option name="m_ignoreAnnotatedVariables" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="UnnecessaryModuleDependencyInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryParentheses" enabled="false" level="INFORMATION" enabled_by_default="false">
-        <option name="ignoreClarifyingParentheses" value="false"/>
-        <option name="ignoreParenthesesOnConditionals" value="false"/>
-        <option name="ignoreParenthesesOnLambdaParameter" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="UnnecessaryQualifiedReference" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryQualifierForThis" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryReturn" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessarySemicolon" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryStaticInjection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessarySuperConstructor" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessarySuperQualifier" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryTemporaryOnConversionFromString" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryTemporaryOnConversionToString" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryThis" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryToStringCall" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryUnaryMinus" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryUnboxing" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnnecessaryUnicodeEscape" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnparsedCustomBeanInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnpredictableBigDecimalConstructorCall" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnproxyableBeanTypesInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="UnqualifiedFieldAccess" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnqualifiedInnerClassAccess" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnqualifiedMethodAccess" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnqualifiedStaticUsage" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnregisteredActivator" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="UnresolvedMessageChannel" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnresolvedPropertyKey" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="UnresolvedReference" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="UnsafeReturnStatementVisitor" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnsafeVfsRecursion" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnusedAssignment" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="REPORT_PREFIX_EXPRESSIONS" value="false"/>
-        <option name="REPORT_POSTFIX_EXPRESSIONS" value="true"/>
-        <option name="REPORT_REDUNDANT_INITIALIZER" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="UnusedCatchParameter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnusedDeclaration" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ADD_MAINS_TO_ENTRIES" value="true"/>
-        <option name="ADD_APPLET_TO_ENTRIES" value="false"/>
-        <option name="ADD_SERVLET_TO_ENTRIES" value="false"/>
-        <option name="ADD_NONJAVA_TO_ENTRIES" value="true"/>
-    </inspection_tool>
-    <inspection_tool class="UnusedLabel" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnusedLibrary" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnusedMessageFormatParameter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnusedProperty" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnusedReceiverParameter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnusedReturnValue" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UnusedSymbol" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UpperCaseFieldNameNotConstant" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UseBulkOperation" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="UseCompareMethod" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="UseCouple" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UseDPIAwareInsets" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UseJBColor" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UseOfObsoleteAssert" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UseOfObsoleteDateTimeApi" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UseOfPropertiesAsHashtable" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UsePrimitiveTypes" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UsePropertyAccessSyntax" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UseVirtualFileEquals" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UtilSchemaInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="UtilityClass" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UtilityClassCanBeEnum" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UtilityClassWithPublicConstructor" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="UtilityClassWithoutPrivateConstructor" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ValidExternallyBoundObject" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="ValidatorConfigModelInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="ValidatorModelInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="VarargParameter" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="VariableNotUsedInsideIf" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="VoidMethodAnnotatedWithGET" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="VolatileArrayField" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="VolatileLongOrDoubleField" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="WSReferenceInspection" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="WaitCalledOnCondition" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="WaitNotInLoop" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="WaitNotInSynchronizedContext" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="WaitOrAwaitWithoutTimeout" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="WaitWhileHoldingTwoLocks" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="WaitWithoutCorrespondingNotify" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="WeakerAccess" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="SUGGEST_PACKAGE_LOCAL_FOR_MEMBERS" value="false"/>
-        <option name="SUGGEST_PACKAGE_LOCAL_FOR_TOP_CLASSES" value="false"/>
-        <option name="SUGGEST_PRIVATE_FOR_INNERS" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="WebProperties" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="WebWarnings" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="WebflowConfigModelInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="WebflowModelInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="WebflowSetupInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="Weblogic" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="WhileCanBeForeach" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="WhileLoopSpinsOnField" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="ignoreNonEmtpyLoops" value="false"/>
-    </inspection_tool>
-    <inspection_tool class="WrapperTypeMayBePrimitive" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="WrongImportPackage" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="WrongPackageStatement" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="WrongPropertyKeyValueDelimiter" enabled="false" level="WEAK WARNING" enabled_by_default="false"/>
-    <inspection_tool class="WrongTopLevelPackageInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="WsdlHighlightingInspection" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="XmlDefaultAttributeValue" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="XmlDuplicatedId" enabled="false" level="ERROR" enabled_by_default="false" />
-    <inspection_tool class="XmlHighlighting" enabled="false" level="ERROR" enabled_by_default="false" />
-    <inspection_tool class="XmlInvalidId" enabled="false" level="ERROR" enabled_by_default="false" />
-    <inspection_tool class="XmlPathReference" enabled="false" level="ERROR" enabled_by_default="false" />
-    <inspection_tool class="XmlUnboundNsPrefix" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="XmlUnusedNamespaceDeclaration" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="XmlWrongFileType" enabled="false" level="WARNING" enabled_by_default="false" />
-    <inspection_tool class="XmlWrongRootElement" enabled="false" level="ERROR" enabled_by_default="false" />
-    <inspection_tool class="XsltDeclarations" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="XsltTemplateInvocation" enabled="false" level="ERROR" enabled_by_default="false"/>
-    <inspection_tool class="XsltUnusedDeclaration" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="XsltVariableShadowing" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="ZeroLengthArrayInitialization" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="dependsOnMethodTestNG" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="groupsTestNG" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="groups">
-            <value>
-                <list size="0"/>
-            </value>
-        </option>
-    </inspection_tool>
-    <inspection_tool class="gwtRawAsyncCallback" enabled="false" level="WARNING" enabled_by_default="false"/>
-    <inspection_tool class="unused" enabled="false" level="WARNING" enabled_by_default="false">
-        <option name="LOCAL_VARIABLE" value="true"/>
-        <option name="FIELD" value="true"/>
-        <option name="METHOD" value="true"/>
-        <option name="CLASS" value="true"/>
-        <option name="PARAMETER" value="true"/>
-        <option name="REPORT_PARAMETER_FOR_PUBLIC_METHODS" value="true"/>
-        <option name="ADD_MAINS_TO_ENTRIES" value="true"/>
-        <option name="ADD_APPLET_TO_ENTRIES" value="false"/>
-        <option name="ADD_SERVLET_TO_ENTRIES" value="false"/>
-        <option name="ADD_NONJAVA_TO_ENTRIES" value="true"/>
-    </inspection_tool>
-</profile>
diff --git a/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/cache/JmhCacheBenchmark.java b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/cache/JmhCacheBenchmark.java
index 80aa2b1..a362a0f 100644
--- a/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/cache/JmhCacheBenchmark.java
+++ b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/cache/JmhCacheBenchmark.java
@@ -31,13 +31,8 @@ import java.util.concurrent.ThreadLocalRandom;
  */
 @SuppressWarnings("unchecked")
 public class JmhCacheBenchmark extends JmhCacheAbstractBenchmark {
-    /**
-     * Set up routine.
-     *
-     * @throws Exception If failed.
-     */
-
-    public void setup() throws Exception {
+    /** {@inheritDoc} */
+    @Override public void setup() throws Exception {
         super.setup();
 
         IgniteDataStreamer<Integer, IntValue> dataLdr = node.dataStreamer(cache.getName());
diff --git a/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/notify/JmhWaitStategyBenchmark.java b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/notify/JmhWaitStategyBenchmark.java
index 75ecb1a..fc69614 100644
--- a/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/notify/JmhWaitStategyBenchmark.java
+++ b/modules/benchmarks/src/main/java/org/apache/ignite/internal/benchmarks/jmh/notify/JmhWaitStategyBenchmark.java
@@ -198,7 +198,7 @@ public class JmhWaitStategyBenchmark extends JmhCacheAbstractBenchmark {
 
     /** {@inheritDoc} */
     @TearDown
-    public void tearDown() throws Exception {
+    @Override public void tearDown() throws Exception {
         Ignition.stopAll(true);
     }
 
diff --git a/modules/cassandra/serializers/src/test/java/org/apache/ignite/tests/MyPojo.java b/modules/cassandra/serializers/src/test/java/org/apache/ignite/tests/MyPojo.java
index 1d8f879..bba2617 100644
--- a/modules/cassandra/serializers/src/test/java/org/apache/ignite/tests/MyPojo.java
+++ b/modules/cassandra/serializers/src/test/java/org/apache/ignite/tests/MyPojo.java
@@ -62,13 +62,8 @@ public class MyPojo implements Serializable {
         this.ref = ref;
     }
 
-    /**
-     * Compare POJOs.
-     *
-     * @param obj POJO to compare with.
-     * @return {@code true} if equals.
-     */
-    public boolean equals(Object obj) {
+    /** {@inheritDoc} */
+    @Override public boolean equals(Object obj) {
         if (!(obj instanceof MyPojo))
             return false;
 
diff --git a/modules/cassandra/store/src/main/java/org/apache/ignite/cache/store/cassandra/common/CassandraHelper.java b/modules/cassandra/store/src/main/java/org/apache/ignite/cache/store/cassandra/common/CassandraHelper.java
index a3afd94..bacc8a6 100644
--- a/modules/cassandra/store/src/main/java/org/apache/ignite/cache/store/cassandra/common/CassandraHelper.java
+++ b/modules/cassandra/store/src/main/java/org/apache/ignite/cache/store/cassandra/common/CassandraHelper.java
@@ -23,7 +23,6 @@ import com.datastax.driver.core.exceptions.DriverException;
 import com.datastax.driver.core.exceptions.InvalidQueryException;
 import com.datastax.driver.core.exceptions.NoHostAvailableException;
 import com.datastax.driver.core.exceptions.ReadTimeoutException;
-
 import java.net.InetSocketAddress;
 import java.util.Map;
 import java.util.regex.Pattern;
@@ -99,7 +98,7 @@ public class CassandraHelper {
         while (e != null) {
             if (e instanceof InvalidQueryException &&
                 (TABLE_EXIST_ERROR1.matcher(e.getMessage()).matches() ||
-                	TABLE_EXIST_ERROR3.matcher(e.getMessage()).matches() ||
+                    TABLE_EXIST_ERROR3.matcher(e.getMessage()).matches() ||
                     KEYSPACE_EXIST_ERROR1.matcher(e.getMessage()).matches() ||
                     KEYSPACE_EXIST_ERROR2.matcher(e.getMessage()).matches()))
                 return true;
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/client/util/ClientConsistentHashSelfTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/client/util/ClientConsistentHashSelfTest.java
index b06c5e2..e73f7ca 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/client/util/ClientConsistentHashSelfTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/client/util/ClientConsistentHashSelfTest.java
@@ -103,8 +103,8 @@ public class ClientConsistentHashSelfTest extends GridCommonAbstractTest {
 
         try {
             // Add several objects with the same hash without neither natural ordering nor comparator.
-            hash.addNode(new Object() { public int hashCode() { return 0; } }, 1);
-            hash.addNode(new Object() { public int hashCode() { return 0; } }, 1);
+            hash.addNode(new Object() { @Override public int hashCode() { return 0; } }, 1);
+            hash.addNode(new Object() { @Override public int hashCode() { return 0; } }, 1);
 
             fail("Expects failed due to internal TreeSet requires comparator or natural ordering.");
         }
@@ -121,8 +121,8 @@ public class ClientConsistentHashSelfTest extends GridCommonAbstractTest {
         }, null);
 
         // Add several objects with the same hash into consistent hash with explicit comparator.
-        hash.addNode(new Object() { public int hashCode() { return 0; } }, 1);
-        hash.addNode(new Object() { public int hashCode() { return 0; } }, 1);
+        hash.addNode(new Object() { @Override public int hashCode() { return 0; } }, 1);
+        hash.addNode(new Object() { @Override public int hashCode() { return 0; } }, 1);
 
         info("Expected pass due to internal TreeSet has explicit comparator.");
     }
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/TestBinaryClient.java b/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/TestBinaryClient.java
index 1f9e6af..39dc886 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/TestBinaryClient.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/TestBinaryClient.java
@@ -224,7 +224,7 @@ final class TestBinaryClient {
         rdr.start();
     }
 
-    /** {@inheritDoc} */
+    /** */
     public void shutdown() throws IgniteCheckedException {
         try {
             if (rdr != null) {
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/TestMemcacheClient.java b/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/TestMemcacheClient.java
index ce31a73..3d5b21b 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/TestMemcacheClient.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/TestMemcacheClient.java
@@ -247,7 +247,7 @@ final class TestMemcacheClient {
         rdr.start();
     }
 
-    /** {@inheritDoc} */
+    /** */
     public void shutdown() throws IgniteCheckedException {
         try {
             if (rdr != null) {
diff --git a/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/protocols/tcp/redis/RedisCommonAbstractTest.java b/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/protocols/tcp/redis/RedisCommonAbstractTest.java
index b60a6a7..dfd319d 100644
--- a/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/protocols/tcp/redis/RedisCommonAbstractTest.java
+++ b/modules/clients/src/test/java/org/apache/ignite/internal/processors/rest/protocols/tcp/redis/RedisCommonAbstractTest.java
@@ -99,7 +99,7 @@ public class RedisCommonAbstractTest extends GridCommonAbstractTest {
         return grid(0).cache(DFLT_CACHE_NAME);
     }
 
-    /** {@inheritDoc} */
+    /** */
     protected int gridCount() {
         return GRID_CNT;
     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java b/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
index 4396a60..093fcc3 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
@@ -145,7 +145,6 @@ import org.apache.ignite.internal.processors.hadoop.HadoopProcessorAdapter;
 import org.apache.ignite.internal.processors.job.GridJobProcessor;
 import org.apache.ignite.internal.processors.jobmetrics.GridJobMetricsProcessor;
 import org.apache.ignite.internal.processors.marshaller.GridMarshallerMappingProcessor;
-import org.apache.ignite.internal.processors.metastorage.DistributedMetaStorage;
 import org.apache.ignite.internal.processors.metastorage.persistence.DistributedMetaStorageImpl;
 import org.apache.ignite.internal.processors.nodevalidation.DiscoveryNodeValidationProcessor;
 import org.apache.ignite.internal.processors.nodevalidation.OsDiscoveryNodeValidationProcessor;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/client/GridClientPartitionAffinity.java b/modules/core/src/main/java/org/apache/ignite/internal/client/GridClientPartitionAffinity.java
index a855faa1..f291188 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/client/GridClientPartitionAffinity.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/client/GridClientPartitionAffinity.java
@@ -246,7 +246,7 @@ public class GridClientPartitionAffinity implements GridClientDataAffinity, Grid
         return lookup.get(nodeInfo);
     }
 
-    /** {@inheritDoc} */
+    /** */
     private int partition(Object key) {
         return Math.abs(key.hashCode() % getPartitions());
     }
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 69f8f05..8ca28ff 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
@@ -68,7 +68,6 @@ import org.apache.ignite.lang.IgnitePredicate;
 import org.apache.ignite.lang.IgniteProductVersion;
 import org.jetbrains.annotations.Nullable;
 
-import static org.apache.ignite.IgniteSystemProperties.getBoolean;
 import static org.apache.ignite.internal.IgniteNodeAttributes.ATTR_IPS;
 import static org.apache.ignite.internal.IgniteNodeAttributes.ATTR_MACS;
 import static org.apache.ignite.internal.util.nodestart.IgniteNodeStartUtils.parseFile;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/commandline/CommandHandler.java b/modules/core/src/main/java/org/apache/ignite/internal/commandline/CommandHandler.java
index 48686f2..2d0fcec 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/commandline/CommandHandler.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/commandline/CommandHandler.java
@@ -54,7 +54,6 @@ import org.apache.ignite.internal.client.GridClientFactory;
 import org.apache.ignite.internal.client.GridClientHandshakeException;
 import org.apache.ignite.internal.client.GridClientNode;
 import org.apache.ignite.internal.client.GridServerUnreachableException;
-import org.apache.ignite.internal.client.impl.GridClientImpl;
 import org.apache.ignite.internal.client.impl.connection.GridClientConnectionResetException;
 import org.apache.ignite.internal.client.ssl.GridSslBasicContextFactory;
 import org.apache.ignite.internal.commandline.argument.CommandArgUtils;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/ClusterMetricsImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/ClusterMetricsImpl.java
index 679f848..c87c47a 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/ClusterMetricsImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/ClusterMetricsImpl.java
@@ -17,7 +17,6 @@
 package org.apache.ignite.internal.managers.discovery;
 
 import java.util.Collection;
-import java.util.concurrent.Future;
 import java.util.concurrent.TimeUnit;
 import org.apache.ignite.cluster.ClusterMetrics;
 import org.apache.ignite.internal.GridKernalContext;
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 47c96b1..59cc513 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
@@ -88,7 +88,6 @@ import org.apache.ignite.internal.processors.cache.affinity.GridCacheAffinityImp
 import org.apache.ignite.internal.processors.cache.distributed.IgniteExternalizableExpiryPolicy;
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtCacheAdapter;
 import org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtTopologyFuture;
-import org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtTxLocalAdapter;
 import org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtInvalidPartitionException;
 import org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtLocalPartition;
 import org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtPartitionTopology;
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 98867a3c..2d3b898 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
@@ -700,7 +700,7 @@ public abstract class GridCacheMapEntry extends GridMetadataAwareAdapter impleme
             readerArgs);
     }
 
-    /** {@inheritDoc} */
+    /** */
     @SuppressWarnings({"TooBroadScope"})
     private Object innerGet0(
         GridCacheVersion nextVer,
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheOffheapManagerImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheOffheapManagerImpl.java
index 6ea64b5..59c45f6 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheOffheapManagerImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheOffheapManagerImpl.java
@@ -35,7 +35,6 @@ import javax.cache.processor.EntryProcessor;
 import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.IgniteException;
 import org.apache.ignite.IgniteLogger;
-import org.apache.ignite.IgniteSystemProperties;
 import org.apache.ignite.internal.NodeStoppingException;
 import org.apache.ignite.internal.pagemem.FullPageId;
 import org.apache.ignite.internal.pagemem.wal.record.delta.DataPageMvccMarkUpdatedRecord;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtTxAbstractEnlistFuture.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtTxAbstractEnlistFuture.java
index ca7466d..cf2bc86 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtTxAbstractEnlistFuture.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtTxAbstractEnlistFuture.java
@@ -51,7 +51,6 @@ import org.apache.ignite.internal.processors.cache.distributed.near.GridNearTxAb
 import org.apache.ignite.internal.processors.cache.mvcc.MvccCoordinator;
 import org.apache.ignite.internal.processors.cache.mvcc.MvccSnapshot;
 import org.apache.ignite.internal.processors.cache.mvcc.MvccUtils;
-import org.apache.ignite.internal.processors.cache.mvcc.txlog.TxState;
 import org.apache.ignite.internal.processors.cache.persistence.CacheDataRowAdapter;
 import org.apache.ignite.internal.processors.cache.query.IgniteQueryErrorCode;
 import org.apache.ignite.internal.processors.cache.tree.mvcc.data.MvccDataRow;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtTxPrepareFuture.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtTxPrepareFuture.java
index cba506b..29f6d4a 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtTxPrepareFuture.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/GridDhtTxPrepareFuture.java
@@ -74,7 +74,6 @@ import org.apache.ignite.internal.processors.cache.version.GridCacheVersion;
 import org.apache.ignite.internal.processors.dr.GridDrType;
 import org.apache.ignite.internal.processors.timeout.GridTimeoutObjectAdapter;
 import org.apache.ignite.internal.transactions.IgniteTxOptimisticCheckedException;
-import org.apache.ignite.internal.transactions.IgniteTxTimeoutCheckedException;
 import org.apache.ignite.internal.util.GridLeanSet;
 import org.apache.ignite.internal.util.future.GridCompoundFuture;
 import org.apache.ignite.internal.util.future.GridFutureAdapter;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/UpdateErrors.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/UpdateErrors.java
index a8facf7..4a41025 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/UpdateErrors.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/UpdateErrors.java
@@ -125,7 +125,7 @@ public class UpdateErrors implements Message {
         err.addSuppressed(e);
     }
 
-    /** {@inheritDoc} */
+    /** */
     void prepareMarshal(GridCacheMessage msg, GridCacheContext cctx) throws IgniteCheckedException {
         msg.prepareMarshalCacheObjects(failedKeys, cctx);
 
@@ -133,7 +133,7 @@ public class UpdateErrors implements Message {
             errBytes = U.marshal(cctx.marshaller(), err);
     }
 
-    /** {@inheritDoc} */
+    /** */
     void finishUnmarshal(GridCacheMessage msg, GridCacheContext cctx, ClassLoader ldr) throws IgniteCheckedException {
         msg.finishUnmarshalCacheObjects(failedKeys, cctx, ldr);
 
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionsStateValidator.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionsStateValidator.java
index 8ea8025..7c44cb8 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionsStateValidator.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/GridDhtPartitionsStateValidator.java
@@ -32,7 +32,6 @@ import org.apache.ignite.internal.processors.cache.GridCacheSharedContext;
 import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.CachePartitionPartialCountersMap;
 import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture;
 import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsSingleMessage;
-import org.apache.ignite.internal.processors.cache.mvcc.MvccUtils;
 import org.apache.ignite.internal.util.typedef.internal.SB;
 import org.apache.ignite.lang.IgniteProductVersion;
 import org.jetbrains.annotations.Nullable;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/DbCheckpointListener.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/DbCheckpointListener.java
index ff808d9..0923ad5 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/DbCheckpointListener.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/DbCheckpointListener.java
@@ -18,7 +18,6 @@ package org.apache.ignite.internal.processors.cache.persistence;
 
 import java.util.concurrent.Executor;
 import org.apache.ignite.IgniteCheckedException;
-import org.apache.ignite.internal.processors.cache.persistence.pagemem.CheckpointMetricsTracker;
 import org.apache.ignite.internal.processors.cache.persistence.partstate.PartitionAllocationMap;
 import org.jetbrains.annotations.Nullable;
 
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 77a53e2..cb9d5e5 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
@@ -183,7 +183,7 @@ public class GridCacheOffheapManager extends IgniteCacheOffheapManagerImpl imple
     }
 
     /** {@inheritDoc} */
-    public void beforeCheckpointBegin(Context ctx) throws IgniteCheckedException {
+    @Override public void beforeCheckpointBegin(Context ctx) throws IgniteCheckedException {
         if (!ctx.nextSnapshot())
             syncMetadata(ctx);
     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/DataPageIO.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/DataPageIO.java
index c4c733a..b9cbb44 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/DataPageIO.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/tree/io/DataPageIO.java
@@ -21,7 +21,6 @@ import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.internal.pagemem.PageUtils;
 import org.apache.ignite.internal.processors.cache.CacheObject;
 import org.apache.ignite.internal.processors.cache.mvcc.MvccUtils;
-import org.apache.ignite.internal.processors.cache.mvcc.MvccVersion;
 import org.apache.ignite.internal.processors.cache.persistence.CacheDataRow;
 import org.apache.ignite.internal.processors.cache.tree.mvcc.data.MvccUpdateResult;
 import org.apache.ignite.internal.processors.cache.version.GridCacheVersion;
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cacheobject/NoOpBinary.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cacheobject/NoOpBinary.java
index c64be42..014976b 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cacheobject/NoOpBinary.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cacheobject/NoOpBinary.java
@@ -84,7 +84,7 @@ public class NoOpBinary implements IgniteBinary {
         throw unsupported();
     }
 
-    /** {@inheritDoc} */
+    /** */
     private BinaryObjectException unsupported() {
         return new BinaryObjectException("Binary marshaller is not configured.");
     }
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformContextImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformContextImpl.java
index 7a2f0e0..11f6038 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformContextImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformContextImpl.java
@@ -66,7 +66,6 @@ import org.apache.ignite.internal.processors.platform.memory.PlatformOutputStrea
 import org.apache.ignite.internal.processors.platform.message.PlatformMessageFilter;
 import org.apache.ignite.internal.processors.platform.messaging.PlatformMessageFilterImpl;
 import org.apache.ignite.internal.processors.platform.utils.PlatformUtils;
-import org.apache.ignite.lang.IgniteProductVersion;
 import org.jetbrains.annotations.Nullable;
 
 import java.sql.Timestamp;
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/internal/DiscoveryDataPacket.java b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/internal/DiscoveryDataPacket.java
index 616c0fd..8e31bb3 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/internal/DiscoveryDataPacket.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/internal/DiscoveryDataPacket.java
@@ -321,7 +321,7 @@ public class DiscoveryDataPacket implements Serializable {
      * @param b Source of bytes.
      * @return Made int.
      */
-    static private int makeInt(byte[] b) {
+    private static int makeInt(byte[] b) {
         return (((b[3]) << 24) |
             ((b[2] & 0xff) << 16) |
             ((b[1] & 0xff) << 8) |
diff --git a/modules/core/src/main/java/org/jsr166/ConcurrentLinkedDeque8.java b/modules/core/src/main/java/org/jsr166/ConcurrentLinkedDeque8.java
index 9315fec..8ee9909 100644
--- a/modules/core/src/main/java/org/jsr166/ConcurrentLinkedDeque8.java
+++ b/modules/core/src/main/java/org/jsr166/ConcurrentLinkedDeque8.java
@@ -1143,17 +1143,13 @@ public class ConcurrentLinkedDeque8<E>
         return null;
     }
 
-    /**
-     * @throws NoSuchElementException {@inheritDoc}
-     */
-    public E getFirst() {
+    /** {@inheritDoc} */
+    @Override public E getFirst() {
         return screenNullResult(peekFirst());
     }
 
-    /**
-     * @throws NoSuchElementException {@inheritDoc}
-     */
-    public E getLast() {
+    /** {@inheritDoc} */
+    @Override public E getLast() {
         return screenNullResult(peekLast());
     }
 
@@ -1179,17 +1175,13 @@ public class ConcurrentLinkedDeque8<E>
         return null;
     }
 
-    /**
-     * @throws NoSuchElementException {@inheritDoc}
-     */
-    public E removeFirst() {
+    /** {@inheritDoc} */
+    @Override public E removeFirst() {
         return screenNullResult(pollFirst());
     }
 
-    /**
-     * @throws NoSuchElementException {@inheritDoc}
-     */
-    public E removeLast() {
+    /**{@inheritDoc} */
+    @Override public E removeLast() {
         return screenNullResult(pollLast());
     }
 
diff --git a/modules/core/src/test/java/org/apache/ignite/cache/ResetLostPartitionTest.java b/modules/core/src/test/java/org/apache/ignite/cache/ResetLostPartitionTest.java
index 50203d6..de0ba9c 100644
--- a/modules/core/src/test/java/org/apache/ignite/cache/ResetLostPartitionTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/cache/ResetLostPartitionTest.java
@@ -32,9 +32,7 @@ import org.apache.ignite.internal.processors.cache.distributed.dht.topology.Grid
 import org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtPartitionTopologyImpl;
 import org.apache.ignite.internal.util.typedef.internal.CU;
 import org.apache.ignite.internal.util.typedef.internal.U;
-import org.apache.ignite.testframework.MvccFeatureChecker;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
-import org.junit.Assume;
 import org.junit.Test;
 
 import static org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtPartitionState.LOST;
diff --git a/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/model/TestJdbcPojoDataSource.java b/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/model/TestJdbcPojoDataSource.java
index a2351be..03f9267 100644
--- a/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/model/TestJdbcPojoDataSource.java
+++ b/modules/core/src/test/java/org/apache/ignite/cache/store/jdbc/model/TestJdbcPojoDataSource.java
@@ -164,12 +164,12 @@ public class TestJdbcPojoDataSource implements DataSource {
         throw new SQLFeatureNotSupportedException();
     }
 
-    /** {@inheritDoc} */
+    /** */
     private Connection createConnection() throws SQLException {
         return DriverManager.getConnection(url, username, password);
     }
 
-    /** {@inheritDoc} */
+    /** */
     private class ConnectionHolder implements Connection {
         /** */
         private Connection conn;
@@ -191,8 +191,7 @@ public class TestJdbcPojoDataSource implements DataSource {
         }
 
         /** {@inheritDoc} */
-        @Override
-        public void close() throws SQLException {
+        @Override public void close() throws SQLException {
             if (!perThreadMode)
                 conn.close();
         }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/IgniteClientReconnectAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/internal/IgniteClientReconnectAbstractTest.java
index 189d3bb..03b3033 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/IgniteClientReconnectAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/IgniteClientReconnectAbstractTest.java
@@ -33,7 +33,6 @@ import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.IgniteClientDisconnectedException;
 import org.apache.ignite.IgniteException;
 import org.apache.ignite.IgniteLogger;
-import org.apache.ignite.IgniteSystemProperties;
 import org.apache.ignite.cluster.ClusterNode;
 import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.events.Event;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/managers/deployment/GridDeploymentMessageCountSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/managers/deployment/GridDeploymentMessageCountSelfTest.java
index e9411f4..351f670 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/managers/deployment/GridDeploymentMessageCountSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/managers/deployment/GridDeploymentMessageCountSelfTest.java
@@ -67,7 +67,7 @@ public class GridDeploymentMessageCountSelfTest extends GridCommonAbstractTest {
         return cfg;
     }
 
-    /** {@inheritDoc} */
+    /** */
     @Test
     public void testTaskDeployment() throws Exception {
         ClassLoader ldr = getExternalClassLoader();
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/marshaller/optimized/OptimizedMarshallerSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/marshaller/optimized/OptimizedMarshallerSelfTest.java
index e53d610..d7731e0 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/marshaller/optimized/OptimizedMarshallerSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/marshaller/optimized/OptimizedMarshallerSelfTest.java
@@ -137,7 +137,7 @@ public class OptimizedMarshallerSelfTest extends GridMarshallerAbstractTest {
             this.val = val;
         }
 
-        /** {@inheritDoc} */
+        /** */
         private void writeObject(ObjectOutputStream out) throws IOException {
             try {
                 byte[] arr = marshal(str);
@@ -152,7 +152,7 @@ public class OptimizedMarshallerSelfTest extends GridMarshallerAbstractTest {
             }
         }
 
-        /** {@inheritDoc} */
+        /** */
         private void readObject(ObjectInputStream in) throws IOException {
             try {
                 byte[] arr = new byte[in.readInt()];
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/marshaller/optimized/OptimizedObjectStreamSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/marshaller/optimized/OptimizedObjectStreamSelfTest.java
index 36ebc9b..755ce03 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/marshaller/optimized/OptimizedObjectStreamSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/marshaller/optimized/OptimizedObjectStreamSelfTest.java
@@ -2265,7 +2265,7 @@ public class OptimizedObjectStreamSelfTest extends GridCommonAbstractTest {
             this.name = name;
         }
 
-        /** {@inheritDoc} */
+        /** */
         private void writeObject(ObjectOutputStream stream) throws IOException {
             stream.defaultWriteObject();
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheFutureExceptionSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheFutureExceptionSelfTest.java
index 939c8fe..8cf6a57 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheFutureExceptionSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CacheFutureExceptionSelfTest.java
@@ -139,12 +139,12 @@ public class CacheFutureExceptionSelfTest extends GridCommonAbstractTest {
      * Test class.
      */
     private static class NotSerializableClass implements Serializable {
-        /** {@inheritDoc}*/
+        /** */
         private void writeObject(ObjectOutputStream out) throws IOException {
             out.writeObject(this);
         }
 
-        /** {@inheritDoc}*/
+        /** */
         private void readObject(ObjectInputStream in) throws IOException, ClassNotFoundException {
             if (fail)
                 throw new RuntimeException("Deserialization failed.");
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheLifecycleAwareSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheLifecycleAwareSelfTest.java
index 6124489..86d7251 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheLifecycleAwareSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheLifecycleAwareSelfTest.java
@@ -163,7 +163,7 @@ public class GridCacheLifecycleAwareSelfTest extends GridAbstractLifecycleAwareS
             return res;
         }
 
-        /** {@inheritDoc} */
+        /** */
         public List<ClusterNode> nodes(int part, Collection<ClusterNode> nodes) {
             return new ArrayList<>(nodes);
         }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheOnCopyFlagAbstractSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheOnCopyFlagAbstractSelfTest.java
index dbd375e..852d83c 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheOnCopyFlagAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheOnCopyFlagAbstractSelfTest.java
@@ -84,7 +84,7 @@ public abstract class GridCacheOnCopyFlagAbstractSelfTest extends GridCommonAbst
         return c;
     }
 
-    /** {@inheritDoc} */
+    /** */
     @SuppressWarnings("unchecked")
     protected CacheConfiguration cacheConfiguration() throws Exception {
         CacheConfiguration ccfg = defaultCacheConfiguration();
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePutAllFailoverSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePutAllFailoverSelfTest.java
index 75e336e..5aa43b2 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePutAllFailoverSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePutAllFailoverSelfTest.java
@@ -36,7 +36,6 @@ import org.apache.ignite.IgniteCache;
 import org.apache.ignite.IgniteCompute;
 import org.apache.ignite.IgniteException;
 import org.apache.ignite.IgniteLogger;
-import org.apache.ignite.IgniteSystemProperties;
 import org.apache.ignite.cache.CacheAtomicityMode;
 import org.apache.ignite.cluster.ClusterNode;
 import org.apache.ignite.compute.ComputeJobContext;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCachePutAllRestartTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCachePutAllRestartTest.java
index 0d69b9b..bf58e70 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCachePutAllRestartTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCachePutAllRestartTest.java
@@ -25,7 +25,6 @@ import java.util.concurrent.atomic.AtomicBoolean;
 import javax.cache.CacheException;
 import org.apache.ignite.Ignite;
 import org.apache.ignite.IgniteCache;
-import org.apache.ignite.IgniteSystemProperties;
 import org.apache.ignite.cache.CacheMode;
 import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.IgniteConfiguration;
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 7b8dbf3..d64e68c 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
@@ -872,7 +872,7 @@ public class IgniteDynamicCacheStartSelfTest extends GridCommonAbstractTest {
         }
     }
 
-    /** {@inheritDoc} */
+    /** */
     @Test
     public void testGetOrCreate() throws Exception {
         try {
@@ -934,7 +934,7 @@ public class IgniteDynamicCacheStartSelfTest extends GridCommonAbstractTest {
         }
     }
 
-    /** {@inheritDoc} */
+    /** */
     @Test
     public void testGetOrCreateCollection() throws Exception {
         final int cacheCnt = 3;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteTxAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteTxAbstractTest.java
index 3c45bf3..70886c4 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteTxAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteTxAbstractTest.java
@@ -38,7 +38,6 @@ import org.apache.ignite.transactions.Transaction;
 import org.apache.ignite.transactions.TransactionConcurrency;
 import org.apache.ignite.transactions.TransactionIsolation;
 import org.apache.ignite.transactions.TransactionOptimisticException;
-import org.apache.ignite.transactions.TransactionSerializationException;
 
 import static org.apache.ignite.transactions.TransactionConcurrency.OPTIMISTIC;
 import static org.apache.ignite.transactions.TransactionIsolation.SERIALIZABLE;
@@ -91,7 +90,7 @@ abstract class IgniteTxAbstractTest extends GridCommonAbstractTest {
      */
     protected abstract boolean printMemoryStats();
 
-    /** {@inheritDoc} */
+    /** */
     private void debug(String msg) {
         if (isTestDebug())
             info(msg);
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteSequenceInternalCleanupTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteSequenceInternalCleanupTest.java
index b6f8b40..707395f 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteSequenceInternalCleanupTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteSequenceInternalCleanupTest.java
@@ -74,7 +74,7 @@ public class IgniteSequenceInternalCleanupTest extends GridCommonAbstractTest {
         return cfg;
     }
 
-    /** {@inheritDoc} */
+    /** */
     protected AtomicConfiguration atomicConfiguration() {
         AtomicConfiguration cfg = new AtomicConfiguration();
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/partitioned/GridCachePartitionedQueueCreateMultiNodeSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/partitioned/GridCachePartitionedQueueCreateMultiNodeSelfTest.java
index fc7f33d..4611c96 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/partitioned/GridCachePartitionedQueueCreateMultiNodeSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/partitioned/GridCachePartitionedQueueCreateMultiNodeSelfTest.java
@@ -87,7 +87,7 @@ public class GridCachePartitionedQueueCreateMultiNodeSelfTest extends IgniteColl
         return c;
     }
 
-    /** {@inheritDoc} */
+    /** */
     protected CacheConfiguration cacheConfiguration() {
         CacheConfiguration cc = defaultCacheConfiguration();
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheGetInsideLockChangingTopologyTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheGetInsideLockChangingTopologyTest.java
index c717192..8d30333 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheGetInsideLockChangingTopologyTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CacheGetInsideLockChangingTopologyTest.java
@@ -27,7 +27,6 @@ import javax.cache.CacheException;
 import org.apache.ignite.Ignite;
 import org.apache.ignite.IgniteCache;
 import org.apache.ignite.IgniteException;
-import org.apache.ignite.IgniteSystemProperties;
 import org.apache.ignite.cache.CacheAtomicityMode;
 import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.IgniteConfiguration;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCacheModuloAffinityFunction.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCacheModuloAffinityFunction.java
index 167fa93..7e38a2f 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCacheModuloAffinityFunction.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/GridCacheModuloAffinityFunction.java
@@ -104,7 +104,7 @@ public class GridCacheModuloAffinityFunction implements AffinityFunction {
         return Collections.unmodifiableList(res);
     }
 
-    /** {@inheritDoc} */
+    /** */
     public Collection<ClusterNode> nodes(int part, Collection<ClusterNode> nodes) {
         List<ClusterNode> sorted = new ArrayList<>(nodes);
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteBinaryMetadataUpdateNodeRestartTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteBinaryMetadataUpdateNodeRestartTest.java
index bc003c6..d329ca9 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteBinaryMetadataUpdateNodeRestartTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteBinaryMetadataUpdateNodeRestartTest.java
@@ -25,7 +25,6 @@ import javax.cache.processor.MutableEntry;
 import org.apache.ignite.Ignite;
 import org.apache.ignite.IgniteCache;
 import org.apache.ignite.IgniteException;
-import org.apache.ignite.IgniteSystemProperties;
 import org.apache.ignite.cache.CacheAtomicityMode;
 import org.apache.ignite.cache.CacheEntryProcessor;
 import org.apache.ignite.cluster.ClusterTopologyException;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCacheGetRestartTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCacheGetRestartTest.java
index d75092a..202111f 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCacheGetRestartTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCacheGetRestartTest.java
@@ -25,7 +25,6 @@ import java.util.concurrent.atomic.AtomicInteger;
 import org.apache.ignite.Ignite;
 import org.apache.ignite.IgniteCache;
 import org.apache.ignite.IgniteDataStreamer;
-import org.apache.ignite.IgniteSystemProperties;
 import org.apache.ignite.cache.CacheMode;
 import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.IgniteConfiguration;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCacheNearRestartRollbackSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCacheNearRestartRollbackSelfTest.java
index b706d8e..605560c 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCacheNearRestartRollbackSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCacheNearRestartRollbackSelfTest.java
@@ -30,7 +30,6 @@ import javax.cache.processor.EntryProcessorException;
 import javax.cache.processor.MutableEntry;
 import org.apache.ignite.Ignite;
 import org.apache.ignite.IgniteCache;
-import org.apache.ignite.IgniteSystemProperties;
 import org.apache.ignite.cache.CacheAtomicityMode;
 import org.apache.ignite.cache.CacheRebalanceMode;
 import org.apache.ignite.cache.CacheWriteSynchronizationMode;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteCachePutRetryAbstractSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteCachePutRetryAbstractSelfTest.java
index 70b8c86..ce23bec 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteCachePutRetryAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/IgniteCachePutRetryAbstractSelfTest.java
@@ -33,7 +33,6 @@ import javax.cache.processor.EntryProcessorResult;
 import javax.cache.processor.MutableEntry;
 import org.apache.ignite.Ignite;
 import org.apache.ignite.IgniteCache;
-import org.apache.ignite.IgniteSystemProperties;
 import org.apache.ignite.cache.CacheAtomicityMode;
 import org.apache.ignite.cache.CacheEntryProcessor;
 import org.apache.ignite.cache.CachePartialUpdateException;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridCacheAtomicInvalidPartitionHandlingSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridCacheAtomicInvalidPartitionHandlingSelfTest.java
index c3294da..7e985a6 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridCacheAtomicInvalidPartitionHandlingSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridCacheAtomicInvalidPartitionHandlingSelfTest.java
@@ -90,7 +90,7 @@ public class GridCacheAtomicInvalidPartitionHandlingSelfTest extends GridCommonA
         return cfg;
     }
 
-    /** {@inheritDoc} */
+    /** */
     protected CacheConfiguration cacheConfiguration() {
         CacheConfiguration ccfg = new CacheConfiguration(DEFAULT_CACHE_NAME);
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearMetricsSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearMetricsSelfTest.java
index d644dd4..dc1c305 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearMetricsSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearMetricsSelfTest.java
@@ -50,7 +50,7 @@ public class GridCacheNearMetricsSelfTest extends GridCacheAbstractSelfTest {
         return false;
     }
 
-    /** {@inheritDoc} */
+    /** */
     protected boolean perEntryMetricsEnabled() {
         return true;
     }
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/rebalancing/GridCacheRebalancingUnmarshallingFailedSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/rebalancing/GridCacheRebalancingUnmarshallingFailedSelfTest.java
index 96a8a4a..9c0686e 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/rebalancing/GridCacheRebalancingUnmarshallingFailedSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/rebalancing/GridCacheRebalancingUnmarshallingFailedSelfTest.java
@@ -31,7 +31,6 @@ import org.apache.ignite.internal.binary.BinaryMarshaller;
 import org.apache.ignite.internal.marshaller.optimized.OptimizedMarshaller;
 import org.apache.ignite.marshaller.Marshaller;
 import org.apache.ignite.marshaller.jdk.JdkMarshaller;
-import org.apache.ignite.testframework.config.GridTestProperties;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
 import org.apache.ignite.thread.IgniteThread;
 import org.junit.Test;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheStartStopWithFreqCheckpointTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheStartStopWithFreqCheckpointTest.java
index 10978ff..a84b6ed 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheStartStopWithFreqCheckpointTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsCacheStartStopWithFreqCheckpointTest.java
@@ -78,7 +78,7 @@ public class IgnitePdsCacheStartStopWithFreqCheckpointTest extends GridCommonAbs
         return cfg;
     }
 
-    /** {@inheritDoc} */
+    /** */
     private CacheConfiguration cacheConfiguration(int cacheIdx) {
         CacheConfiguration ccfg = new CacheConfiguration(CACHE_NAME + cacheIdx)
             .setAtomicityMode(CacheAtomicityMode.TRANSACTIONAL)
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsContinuousRestartTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsContinuousRestartTest.java
index f406c69..93b6f85 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsContinuousRestartTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/IgnitePdsContinuousRestartTest.java
@@ -43,7 +43,6 @@ import org.apache.ignite.internal.util.typedef.internal.U;
 import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.MvccFeatureChecker;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
-import org.junit.Assume;
 import org.junit.Test;
 
 /**
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/IgniteThrottlingUnitTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/IgniteThrottlingUnitTest.java
index 4616ae9..6d66b46 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/IgniteThrottlingUnitTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/IgniteThrottlingUnitTest.java
@@ -212,7 +212,7 @@ public class IgniteThrottlingUnitTest {
     public void tooMuchPagesMarkedDirty() {
         PagesWriteSpeedBasedThrottle throttle = new PagesWriteSpeedBasedThrottle(pageMemory2g, null, stateChecker, log);
 
-        // 363308	350004	348976	10604
+        // 363308 350004 348976 10604
         long time = throttle.getParkTime(0.75,
             ((350004 + 348976) / 2),
             350004 - 10604,
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryLazyAllocationWithPDSTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryLazyAllocationWithPDSTest.java
index 03a81db..37ae9b8 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryLazyAllocationWithPDSTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/pagemem/PageMemoryLazyAllocationWithPDSTest.java
@@ -17,13 +17,10 @@
 package org.apache.ignite.internal.processors.cache.persistence.pagemem;
 
 import org.apache.ignite.IgniteCache;
-import org.apache.ignite.IgniteCheckedException;
-import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.DataRegionConfiguration;
 import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.failure.StopNodeFailureHandler;
 import org.apache.ignite.internal.IgniteEx;
-import org.apache.ignite.testframework.GridTestUtils;
 import org.jetbrains.annotations.NotNull;
 import org.junit.Ignore;
 import org.junit.Test;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/standbycluster/AbstractNodeJoinTemplate.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/standbycluster/AbstractNodeJoinTemplate.java
index c47b623..a3db5ba 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/standbycluster/AbstractNodeJoinTemplate.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/standbycluster/AbstractNodeJoinTemplate.java
@@ -299,7 +299,7 @@ public abstract class AbstractNodeJoinTemplate extends GridCommonAbstractTest {
                             .setMaxSize(100 * 1024 * 1024)));
     }
 
-    /** {@inheritDoc} */
+    /** */
     protected IgniteConfiguration persistentCfg(IgniteConfiguration cfg) throws Exception {
         cfg.setDataStorageConfiguration(new DataStorageConfiguration()
             .setDefaultDataRegionConfiguration(new DataRegionConfiguration()
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/ExplicitWalDeltaConsistencyTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/ExplicitWalDeltaConsistencyTest.java
index 66bde78..52496a0 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/ExplicitWalDeltaConsistencyTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/wal/ExplicitWalDeltaConsistencyTest.java
@@ -19,8 +19,6 @@ package org.apache.ignite.internal.processors.cache.persistence.wal;
 import org.apache.ignite.IgniteCache;
 import org.apache.ignite.internal.IgniteEx;
 import org.apache.ignite.internal.processors.cache.persistence.wal.memtracker.PageMemoryTrackerPluginProvider;
-import org.apache.ignite.testframework.MvccFeatureChecker;
-import org.junit.Assume;
 import org.junit.Test;
 
 /**
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsCacheSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsCacheSelfTest.java
index 0447607..fefab7b 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsCacheSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsCacheSelfTest.java
@@ -68,7 +68,7 @@ public class IgfsCacheSelfTest extends IgfsCommonAbstractTest {
         return cfg;
     }
 
-    /** {@inheritDoc} */
+    /** */
     protected CacheConfiguration cacheConfiguration(@NotNull String cacheName) {
         CacheConfiguration cacheCfg = defaultCacheConfiguration();
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsDataManagerSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsDataManagerSelfTest.java
index 352a049..59fae77 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsDataManagerSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsDataManagerSelfTest.java
@@ -97,7 +97,7 @@ public class IgfsDataManagerSelfTest extends IgfsCommonAbstractTest {
         return cfg;
     }
 
-    /** {@inheritDoc} */
+    /** */
     protected CacheConfiguration cacheConfiguration(@NotNull String cacheName) {
         CacheConfiguration cacheCfg = defaultCacheConfiguration();
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsMetaManagerSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsMetaManagerSelfTest.java
index 958bc52..1824366 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsMetaManagerSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsMetaManagerSelfTest.java
@@ -82,7 +82,7 @@ public class IgfsMetaManagerSelfTest extends IgfsCommonAbstractTest {
         return cfg;
     }
 
-    /** {@inheritDoc} */
+    /** */
     protected CacheConfiguration cacheConfiguration(@NotNull String cacheName) {
         CacheConfiguration cacheCfg = defaultCacheConfiguration();
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsOneClientNodeTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsOneClientNodeTest.java
index a4b7764..e9cc465 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsOneClientNodeTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsOneClientNodeTest.java
@@ -64,7 +64,7 @@ public class IgfsOneClientNodeTest extends GridCommonAbstractTest {
         return cfg;
     }
 
-    /** {@inheritDoc} */
+    /** */
     protected CacheConfiguration cacheConfiguration(@NotNull String cacheName) {
         CacheConfiguration cacheCfg = defaultCacheConfiguration();
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsProcessorSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsProcessorSelfTest.java
index cd4d9a5..14dfbc3 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsProcessorSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsProcessorSelfTest.java
@@ -118,7 +118,7 @@ public class IgfsProcessorSelfTest extends IgfsCommonAbstractTest {
         return cfg;
     }
 
-    /** {@inheritDoc} */
+    /** */
     protected CacheConfiguration cacheConfiguration(@NotNull String cacheName) {
         CacheConfiguration cacheCfg = defaultCacheConfiguration();
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsStreamsSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsStreamsSelfTest.java
index 71d3d10..3b554fe 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsStreamsSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsStreamsSelfTest.java
@@ -119,7 +119,7 @@ public class IgfsStreamsSelfTest extends IgfsCommonAbstractTest {
         return cfg;
     }
 
-    /** {@inheritDoc} */
+    /** */
     protected CacheConfiguration cacheConfiguration(@NotNull String cacheName) {
         CacheConfiguration cacheCfg = defaultCacheConfiguration();
 
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/metastorage/DistributedMetaStoragePersistentTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/metastorage/DistributedMetaStoragePersistentTest.java
index c7b2e09..39a35ed 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/metastorage/DistributedMetaStoragePersistentTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/metastorage/DistributedMetaStoragePersistentTest.java
@@ -20,11 +20,7 @@ import java.io.Serializable;
 import java.util.ArrayList;
 import java.util.List;
 import java.util.Map;
-import java.util.concurrent.ThreadLocalRandom;
-import java.util.concurrent.atomic.AtomicBoolean;
-import java.util.concurrent.atomic.AtomicInteger;
 import org.apache.ignite.internal.IgniteEx;
-import org.apache.ignite.internal.IgniteInternalFuture;
 import org.apache.ignite.internal.processors.cache.persistence.IgniteCacheDatabaseSharedManager;
 import org.apache.ignite.internal.processors.cache.persistence.metastorage.MetaStorage;
 import org.apache.ignite.internal.processors.metastorage.persistence.DistributedMetaStorageImpl;
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/util/GridStartupWithUndefinedIgniteHomeSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/util/GridStartupWithUndefinedIgniteHomeSelfTest.java
index 8fc0a25..db3ad37 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/util/GridStartupWithUndefinedIgniteHomeSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/util/GridStartupWithUndefinedIgniteHomeSelfTest.java
@@ -48,7 +48,7 @@ public class GridStartupWithUndefinedIgniteHomeSelfTest {
     /** */
     private static final int GRID_COUNT = 2;
 
-    /** {@inheritDoc} */
+    /** */
     @After
     public void tearDown() {
         // Next grid in the same VM shouldn't use cached values produced by these tests.
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 9917ce7..74281ce 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
@@ -29,7 +29,6 @@ import javax.cache.CacheException;
 import org.apache.ignite.Ignite;
 import org.apache.ignite.IgniteCache;
 import org.apache.ignite.IgniteCheckedException;
-import org.apache.ignite.IgniteSystemProperties;
 import org.apache.ignite.cache.CacheMode;
 import org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction;
 import org.apache.ignite.configuration.CacheConfiguration;
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryNetworkIssuesTest.java b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryNetworkIssuesTest.java
index 3438ca6..cba8272 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryNetworkIssuesTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoveryNetworkIssuesTest.java
@@ -33,7 +33,6 @@ import org.apache.ignite.spi.IgniteSpiOperationTimeoutHelper;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder;
 import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
-import org.junit.After;
 import org.junit.Test;
 
 /**
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpiMBeanTest.java b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpiMBeanTest.java
index c70ff62..f6490ab 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpiMBeanTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpiMBeanTest.java
@@ -38,7 +38,6 @@ import java.util.concurrent.CountDownLatch;
 import org.junit.Test;
 
 import static java.util.concurrent.TimeUnit.MILLISECONDS;
-import static org.apache.ignite.events.EventType.EVT_NODE_FAILED;
 import static org.apache.ignite.events.EventType.EVT_NODE_SEGMENTED;
 
 /**
diff --git a/modules/core/src/test/java/org/apache/ignite/testframework/junits/IgniteConfigVariationsAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/testframework/junits/IgniteConfigVariationsAbstractTest.java
index fd3a0e2..a275a3a 100644
--- a/modules/core/src/test/java/org/apache/ignite/testframework/junits/IgniteConfigVariationsAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/testframework/junits/IgniteConfigVariationsAbstractTest.java
@@ -221,7 +221,7 @@ public abstract class IgniteConfigVariationsAbstractTest extends GridCommonAbstr
         return resCfg;
     }
 
-    /** {@inheritDoc} */
+    /** */
     protected final int gridCount() {
         return testsCfg.gridCount();
     }
diff --git a/modules/core/src/test/java/org/apache/ignite/testframework/junits/JUnit3TestLegacySupport.java b/modules/core/src/test/java/org/apache/ignite/testframework/junits/JUnit3TestLegacySupport.java
index 3021813..e2e4b1a 100644
--- a/modules/core/src/test/java/org/apache/ignite/testframework/junits/JUnit3TestLegacySupport.java
+++ b/modules/core/src/test/java/org/apache/ignite/testframework/junits/JUnit3TestLegacySupport.java
@@ -18,7 +18,6 @@ package org.apache.ignite.testframework.junits;
 
 import org.junit.Rule;
 import org.junit.rules.TestName;
-import org.junit.runners.model.Statement;
 
 /**
  * Supports compatibility with old tests that expect specific threading behavior of JUnit 3 TestCase class,
diff --git a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBinaryObjectsSimpleNameMapperComputeGridTestSuite.java b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBinaryObjectsSimpleNameMapperComputeGridTestSuite.java
index 1b9c1bb..5168606 100644
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBinaryObjectsSimpleNameMapperComputeGridTestSuite.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBinaryObjectsSimpleNameMapperComputeGridTestSuite.java
@@ -16,7 +16,6 @@
 
 package org.apache.ignite.testsuites;
 
-import org.apache.ignite.internal.binary.BinaryMarshaller;
 import org.apache.ignite.testframework.config.GridTestProperties;
 import org.junit.BeforeClass;
 import org.junit.runner.RunWith;
diff --git a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBinarySimpleNameMapperBasicTestSuite.java b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBinarySimpleNameMapperBasicTestSuite.java
index 5ece507..ec05881 100644
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBinarySimpleNameMapperBasicTestSuite.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBinarySimpleNameMapperBasicTestSuite.java
@@ -16,7 +16,6 @@
 
 package org.apache.ignite.testsuites;
 
-import org.apache.ignite.internal.binary.BinaryMarshaller;
 import org.apache.ignite.testframework.config.GridTestProperties;
 import org.junit.BeforeClass;
 import org.junit.runner.RunWith;
diff --git a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBinarySimpleNameMapperCacheFullApiTestSuite.java b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBinarySimpleNameMapperCacheFullApiTestSuite.java
index 6dd6fd9..a3e27ef 100644
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBinarySimpleNameMapperCacheFullApiTestSuite.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteBinarySimpleNameMapperCacheFullApiTestSuite.java
@@ -16,7 +16,6 @@
 
 package org.apache.ignite.testsuites;
 
-import org.apache.ignite.internal.binary.BinaryMarshaller;
 import org.apache.ignite.testframework.config.GridTestProperties;
 import org.junit.BeforeClass;
 import org.junit.runner.RunWith;
diff --git a/modules/flink/src/test/java/org/apache/ignite/source/flink/FlinkIgniteSourceSelfTest.java b/modules/flink/src/test/java/org/apache/ignite/source/flink/FlinkIgniteSourceSelfTest.java
index 1c3760e..7122b6d 100644
--- a/modules/flink/src/test/java/org/apache/ignite/source/flink/FlinkIgniteSourceSelfTest.java
+++ b/modules/flink/src/test/java/org/apache/ignite/source/flink/FlinkIgniteSourceSelfTest.java
@@ -59,7 +59,7 @@ public class FlinkIgniteSourceSelfTest extends GridCommonAbstractTest {
     /** Ignite Source instance */
     private IgniteSource igniteSrc;
 
-    /** {@inheritDoc} */
+    /** */
     @SuppressWarnings("unchecked")
     @Before
     public void setUpTest() throws Exception {
diff --git a/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/HadoopExternalSplit.java b/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/HadoopExternalSplit.java
index b091ae7..b4a49f8 100644
--- a/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/HadoopExternalSplit.java
+++ b/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/HadoopExternalSplit.java
@@ -90,7 +90,7 @@ public class HadoopExternalSplit extends HadoopInputSplit {
     }
 
     /** {@inheritDoc} */
-    public String toString() {
+    @Override public String toString() {
         return S.toString(HadoopExternalSplit.class, this, "hosts", Arrays.toString(hosts));
     }
 }
\ No newline at end of file
diff --git a/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/HadoopSplitWrapper.java b/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/HadoopSplitWrapper.java
index bdf95d6..e7cc996 100644
--- a/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/HadoopSplitWrapper.java
+++ b/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/HadoopSplitWrapper.java
@@ -121,7 +121,7 @@ public class HadoopSplitWrapper extends HadoopInputSplit {
     }
 
     /** {@inheritDoc} */
-    public String toString() {
+    @Override public String toString() {
         return S.toString(HadoopSplitWrapper.class, this, "hosts", Arrays.toString(hosts));
     }
 }
\ No newline at end of file
diff --git a/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/impl/delegate/HadoopFileSystemCounterWriterDelegateImpl.java b/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/impl/delegate/HadoopFileSystemCounterWriterDelegateImpl.java
index 1832f93..ed3f930 100644
--- a/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/impl/delegate/HadoopFileSystemCounterWriterDelegateImpl.java
+++ b/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/impl/delegate/HadoopFileSystemCounterWriterDelegateImpl.java
@@ -59,7 +59,7 @@ public class HadoopFileSystemCounterWriterDelegateImpl implements HadoopFileSyst
     }
 
     /** {@inheritDoc} */
-    public void write(HadoopJobEx job, HadoopCounters cntrs) throws IgniteCheckedException {
+    @Override public void write(HadoopJobEx job, HadoopCounters cntrs) throws IgniteCheckedException {
         Configuration hadoopCfg = HadoopUtils.safeCreateConfiguration();
 
         final HadoopJobInfo jobInfo = job.info();
diff --git a/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/impl/delegate/HadoopIgfsSecondaryFileSystemDelegateImpl.java b/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/impl/delegate/HadoopIgfsSecondaryFileSystemDelegateImpl.java
index ce95303..4e7650a 100644
--- a/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/impl/delegate/HadoopIgfsSecondaryFileSystemDelegateImpl.java
+++ b/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/impl/delegate/HadoopIgfsSecondaryFileSystemDelegateImpl.java
@@ -408,12 +408,12 @@ public class HadoopIgfsSecondaryFileSystemDelegateImpl implements HadoopIgfsSeco
     }
 
     /** {@inheritDoc} */
-    public void start() {
+    @Override public void start() {
         factory.start();
     }
 
     /** {@inheritDoc} */
-    public void stop() {
+    @Override public void stop() {
         factory.stop();
     }
 
diff --git a/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/jobtracker/HadoopJobMetadata.java b/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/jobtracker/HadoopJobMetadata.java
index 62c91ef..3d1e4b9 100644
--- a/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/jobtracker/HadoopJobMetadata.java
+++ b/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/jobtracker/HadoopJobMetadata.java
@@ -307,7 +307,7 @@ public class HadoopJobMetadata implements Externalizable {
     }
 
     /** {@inheritDoc} */
-    public String toString() {
+    @Override public String toString() {
         return S.toString(HadoopJobMetadata.class, this, "pendingMaps", pendingSplits.size(),
             "pendingReduces", pendingReducers.size(), "failCause", failCause == null ? null :
                 failCause.getClass().getName());
diff --git a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/H2CachedStatementKey.java b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/H2CachedStatementKey.java
index 58db7b9..df142dd 100644
--- a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/H2CachedStatementKey.java
+++ b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/H2CachedStatementKey.java
@@ -17,7 +17,6 @@
 package org.apache.ignite.internal.processors.query.h2;
 
 import org.apache.ignite.cache.query.SqlFieldsQuery;
-import org.apache.ignite.internal.processors.query.h2.dml.UpdatePlanBuilder;
 import org.apache.ignite.internal.util.typedef.F;
 import org.apache.ignite.internal.util.typedef.internal.S;
 
diff --git a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/dml/DmlArguments.java b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/dml/DmlArguments.java
index b1ae656..ef7ca1d 100644
--- a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/dml/DmlArguments.java
+++ b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/dml/DmlArguments.java
@@ -70,7 +70,7 @@ public class DmlArguments {
         }
 
         /** {@inheritDoc} */
-        public Object get(Object[] params) {
+        @Override public Object get(Object[] params) {
             return val;
         }
     }
diff --git a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/sql/GridSqlElement.java b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/sql/GridSqlElement.java
index 1c26ea3..72c9ab4 100644
--- a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/sql/GridSqlElement.java
+++ b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/sql/GridSqlElement.java
@@ -37,10 +37,8 @@ public abstract class GridSqlElement implements GridSqlAst {
         this.children = children;
     }
 
-    /**
-     * @return Optional expression result type (if this is an expression and result type is known).
-     */
-    public GridSqlType resultType() {
+    /** {@inheritDoc} */
+    @Override public GridSqlType resultType() {
         return resultType;
     }
 
@@ -86,10 +84,8 @@ public abstract class GridSqlElement implements GridSqlAst {
         children.set(idx, child);
     }
 
-    /**
-     * @return Number of children.
-     */
-    public int size() {
+    /** {@inheritDoc} */
+    @Override public int size() {
         return children.size();
     }
 
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/BinarySerializationQuerySelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/BinarySerializationQuerySelfTest.java
index d9d1adb..f2bb668 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/BinarySerializationQuerySelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/BinarySerializationQuerySelfTest.java
@@ -405,12 +405,12 @@ public class BinarySerializationQuerySelfTest extends GridCommonAbstractTest {
             this.val = val;
         }
 
-        /** {@inheritDoc} */
+        /** */
         private void writeObject(ObjectOutputStream s) throws IOException{
             s.writeInt(val);
         }
 
-        /** {@inheritDoc} */
+        /** */
         private void readObject(ObjectInputStream s) throws IOException, ClassNotFoundException {
             val = s.readInt();
         }
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/CacheQueryAfterDynamicCacheStartFailureTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/CacheQueryAfterDynamicCacheStartFailureTest.java
index 4a7d884..a21d6ba 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/CacheQueryAfterDynamicCacheStartFailureTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/CacheQueryAfterDynamicCacheStartFailureTest.java
@@ -39,7 +39,7 @@ public class CacheQueryAfterDynamicCacheStartFailureTest extends IgniteAbstractD
     }
 
     /** {@inheritDoc} */
-    protected CacheConfiguration createCacheConfiguration(String cacheName) {
+    @Override protected CacheConfiguration createCacheConfiguration(String cacheName) {
         CacheConfiguration cfg = new CacheConfiguration()
             .setName(cacheName)
             .setIndexedTypes(Integer.class, Value.class);
@@ -47,7 +47,8 @@ public class CacheQueryAfterDynamicCacheStartFailureTest extends IgniteAbstractD
         return cfg;
     }
 
-    protected void checkCacheOperations(IgniteCache<Integer, Value> cache) throws Exception {
+    /** {@inheritDoc} */
+    @Override protected void checkCacheOperations(IgniteCache<Integer, Value> cache) throws Exception {
         super.checkCacheOperations(cache);
 
         // Check SQL API.
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheSqlDmlErrorSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheSqlDmlErrorSelfTest.java
index 8ebb39f..9c8639b 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheSqlDmlErrorSelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheSqlDmlErrorSelfTest.java
@@ -27,7 +27,6 @@ import org.apache.ignite.internal.processors.query.IgniteSQLException;
 import org.apache.ignite.internal.processors.query.h2.dml.UpdatePlanBuilder;
 import org.apache.ignite.internal.util.typedef.F;
 import org.apache.ignite.testframework.GridTestUtils;
-import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
 import org.junit.Before;
 import org.junit.Test;
 
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheSqlInsertValidationSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheSqlInsertValidationSelfTest.java
index 62a132e..b89b241 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheSqlInsertValidationSelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheSqlInsertValidationSelfTest.java
@@ -33,7 +33,6 @@ import org.apache.ignite.internal.processors.cache.index.AbstractIndexingCommonT
 import org.apache.ignite.internal.processors.query.IgniteSQLException;
 import org.apache.ignite.internal.processors.query.h2.dml.UpdatePlanBuilder;
 import org.apache.ignite.testframework.GridTestUtils;
-import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
 import org.apache.ignite.transactions.TransactionDuplicateKeyException;
 import org.junit.Test;
 
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/DynamicColumnsAbstractConcurrentSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/DynamicColumnsAbstractConcurrentSelfTest.java
index b69b0a6..1b67745 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/DynamicColumnsAbstractConcurrentSelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/DynamicColumnsAbstractConcurrentSelfTest.java
@@ -29,7 +29,6 @@ import java.util.concurrent.CountDownLatch;
 import java.util.concurrent.ThreadLocalRandom;
 import java.util.concurrent.atomic.AtomicBoolean;
 import java.util.concurrent.atomic.AtomicInteger;
-import java.util.concurrent.locks.StampedLock;
 import javax.cache.Cache;
 import org.apache.ignite.Ignite;
 import org.apache.ignite.IgniteCache;
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/DynamicIndexAbstractSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/DynamicIndexAbstractSelfTest.java
index 5c7894d..8169fa5 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/DynamicIndexAbstractSelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/DynamicIndexAbstractSelfTest.java
@@ -118,14 +118,8 @@ public abstract class DynamicIndexAbstractSelfTest extends AbstractSchemaSelfTes
         return commonConfiguration(idx).setClientMode(true);
     }
 
-    /**
-     * Create common node configuration.
-     *
-     * @param idx Index.
-     * @return Configuration.
-     * @throws Exception If failed.
-     */
-    protected IgniteConfiguration commonConfiguration(int idx) throws Exception {
+    /** {@inheritDoc} */
+    @Override protected IgniteConfiguration commonConfiguration(int idx) throws Exception {
         IgniteConfiguration cfg = super.getConfiguration(getTestIgniteInstanceName(idx));
 
         cfg.setFailureHandler(new StopNodeFailureHandler());
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/StaticCacheDdlTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/StaticCacheDdlTest.java
index 0a7f156..3130bfd 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/StaticCacheDdlTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/index/StaticCacheDdlTest.java
@@ -37,7 +37,6 @@ import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
 import org.junit.After;
 import org.junit.Assert;
 import org.junit.Before;
-import org.junit.Ignore;
 import org.junit.Test;
 
 /**
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccReplicatedSqlTxQueriesWithReducerTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccReplicatedSqlTxQueriesWithReducerTest.java
index 288d137..d035918 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccReplicatedSqlTxQueriesWithReducerTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/mvcc/CacheMvccReplicatedSqlTxQueriesWithReducerTest.java
@@ -23,7 +23,7 @@ import static org.apache.ignite.cache.CacheMode.REPLICATED;
 /** */
 public class CacheMvccReplicatedSqlTxQueriesWithReducerTest extends CacheMvccSqlTxQueriesWithReducerAbstractTest {
     /** {@inheritDoc} */
-    protected CacheMode cacheMode() {
+    @Override protected CacheMode cacheMode() {
         return REPLICATED;
     }
 }
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteWalRecoveryTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteWalRecoveryTest.java
index 7869604..18df698 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteWalRecoveryTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/IgniteWalRecoveryTest.java
@@ -42,7 +42,6 @@ import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.IgniteCompute;
 import org.apache.ignite.IgniteException;
 import org.apache.ignite.IgniteLogger;
-import org.apache.ignite.IgniteSystemProperties;
 import org.apache.ignite.cache.CacheAtomicityMode;
 import org.apache.ignite.cache.CacheMode;
 import org.apache.ignite.cache.CacheRebalanceMode;
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/IgniteQueryDedicatedPoolTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/IgniteQueryDedicatedPoolTest.java
index 0a11395..fa2ff42 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/IgniteQueryDedicatedPoolTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/IgniteQueryDedicatedPoolTest.java
@@ -35,7 +35,6 @@ import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.internal.managers.communication.GridIoManager;
 import org.apache.ignite.internal.managers.communication.GridIoPolicy;
 import org.apache.ignite.internal.processors.cache.CacheEntryImpl;
-import org.apache.ignite.internal.processors.cache.query.GridCacheTwoStepQuery;
 import org.apache.ignite.internal.util.typedef.F;
 import org.apache.ignite.lang.IgniteBiPredicate;
 import org.apache.ignite.spi.IgniteSpiAdapter;
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 fa4dd27..c8d9321 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
@@ -96,7 +96,7 @@ public class KillQueryOnClientDisconnectTest extends GridCommonAbstractTest {
         stmt = conn.createStatement();
     }
 
-    /** {@inheritDoc} */
+    /** */
     protected IgniteEx clientNode() {
         IgniteEx clientNode = grid(1);
 
@@ -105,7 +105,7 @@ public class KillQueryOnClientDisconnectTest extends GridCommonAbstractTest {
         return clientNode;
     }
 
-    /** {@inheritDoc} */
+    /** */
     protected IgniteEx serverNode() {
         IgniteEx srvNode = grid(0);
 
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/GridIndexRebuildWithMvccEnabledSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/GridIndexRebuildWithMvccEnabledSelfTest.java
index b0b0a0e..9d077d0 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/GridIndexRebuildWithMvccEnabledSelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/query/h2/GridIndexRebuildWithMvccEnabledSelfTest.java
@@ -45,7 +45,7 @@ public class GridIndexRebuildWithMvccEnabledSelfTest extends GridIndexRebuildSel
 
     /** {@inheritDoc} */
     @Test
-    public void testIndexRebuild() throws Exception {
+    @Override public void testIndexRebuild() throws Exception {
         IgniteEx srv = startServer();
 
         execute(srv, "CREATE TABLE T(k int primary key, v int) WITH \"cache_name=T,wrap_value=false," +
@@ -89,7 +89,7 @@ public class GridIndexRebuildWithMvccEnabledSelfTest extends GridIndexRebuildSel
     }
 
     /** {@inheritDoc} */
-    protected void checkDataState(IgniteEx srv, boolean afterRebuild) throws IgniteCheckedException {
+    @Override protected void checkDataState(IgniteEx srv, boolean afterRebuild) throws IgniteCheckedException {
         IgniteInternalCache icache = srv.cachex(CACHE_NAME);
 
         assertNotNull(icache);
diff --git a/modules/jta/src/test/java/org/apache/ignite/internal/processors/cache/GridJtaLifecycleAwareSelfTest.java b/modules/jta/src/test/java/org/apache/ignite/internal/processors/cache/GridJtaLifecycleAwareSelfTest.java
index 56b0883..f76c894 100644
--- a/modules/jta/src/test/java/org/apache/ignite/internal/processors/cache/GridJtaLifecycleAwareSelfTest.java
+++ b/modules/jta/src/test/java/org/apache/ignite/internal/processors/cache/GridJtaLifecycleAwareSelfTest.java
@@ -145,7 +145,7 @@ public class GridJtaLifecycleAwareSelfTest extends GridAbstractLifecycleAwareSel
         // No-op, see anothre tests.
     }
 
-    /** {@inheritDoc} */
+    /** */
     @Test
     public void testCacheLookupLifecycleAware() throws Exception {
         tmConfigurationType = TmConfigurationType.CACHE_LOOKUP;
@@ -153,7 +153,7 @@ public class GridJtaLifecycleAwareSelfTest extends GridAbstractLifecycleAwareSel
         checkLifecycleAware();
     }
 
-    /** {@inheritDoc} */
+    /** */
     @Test
     public void testGlobalLookupLifecycleAware() throws Exception {
         tmConfigurationType = TmConfigurationType.GLOBAL_LOOKUP;
@@ -161,7 +161,7 @@ public class GridJtaLifecycleAwareSelfTest extends GridAbstractLifecycleAwareSel
         checkLifecycleAware();
     }
 
-    /** {@inheritDoc} */
+    /** */
     @Test
     public void testFactoryLifecycleAware() throws Exception {
         tmConfigurationType = TmConfigurationType.FACTORY;
diff --git a/modules/kubernetes/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/kubernetes/TcpDiscoveryKubernetesIpFinder.java b/modules/kubernetes/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/kubernetes/TcpDiscoveryKubernetesIpFinder.java
index 6164a38..01f66b2 100644
--- a/modules/kubernetes/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/kubernetes/TcpDiscoveryKubernetesIpFinder.java
+++ b/modules/kubernetes/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/kubernetes/TcpDiscoveryKubernetesIpFinder.java
@@ -91,15 +91,15 @@ public class TcpDiscoveryKubernetesIpFinder extends TcpDiscoveryIpFinderAdapter
     /** Trust manager. */
     private TrustManager[] trustAll = new TrustManager[] {
         new X509TrustManager() {
-            public void checkServerTrusted(X509Certificate[] certs, String authType) {}
-            public void checkClientTrusted(X509Certificate[] certs, String authType) {}
-            public X509Certificate[] getAcceptedIssuers() { return null; }
+            @Override public void checkServerTrusted(X509Certificate[] certs, String authType) {}
+            @Override public void checkClientTrusted(X509Certificate[] certs, String authType) {}
+            @Override public X509Certificate[] getAcceptedIssuers() { return null; }
         }
     };
 
     /** Host verifier. */
     private HostnameVerifier trustAllHosts = new HostnameVerifier() {
-        public boolean verify(String hostname, SSLSession session) {
+        @Override public boolean verify(String hostname, SSLSession session) {
             return true;
         }
     };
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 7f17d62..eb2b50a 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
@@ -52,21 +52,17 @@ public class KMeansModel implements ClusterizationModel<Vector, Integer>, Export
         return distanceMeasure;
     }
 
-    /** Amount of centers in clusterization. */
+    /** {@inheritDoc} */
     @Override public int getAmountOfClusters() {
         return centers.length;
     }
 
-    /** Get centers of clusters. */
+    /** {@inheritDoc} */
     @Override public Vector[] getCenters() {
         return Arrays.copyOf(centers, centers.length);
     }
 
-    /**
-     * Predict closest center index for a given vector.
-     *
-     * @param vec Vector.
-     */
+    /** {@inheritDoc} */
     @Override public Integer predict(Vector vec) {
         int res = -1;
         double minDist = Double.POSITIVE_INFINITY;
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverJob.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverJob.java
index 8542bae..6b136c8 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverJob.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverJob.java
@@ -92,9 +92,7 @@ public class CrossOverJob extends ComputeJobAdapter {
         return newGeneKeys;
     }
 
-    /**
-     * Perform crossover operation
-     */
+    /** {@inheritDoc} */
     @Override public Object execute() throws IgniteException {
 
         if (this.crossOverRate > Math.random()) {
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverTask.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverTask.java
index d19a3d3..0e62dd0 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverTask.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/CrossOverTask.java
@@ -57,13 +57,7 @@ public class CrossOverTask extends ComputeTaskAdapter<List<Long>, Boolean> {
         this.cfg = cfg;
     }
 
-    /**
-     * Map Jobs to nodes using data affinity.
-     *
-     * @param nodes Cluster Nodes
-     * @param chromosomeKeys Primary keys for respective chromosomes
-     * @return A map of nodes to jobs.
-     */
+    /** {@inheritDoc} */
     @Override public Map map(List<ClusterNode> nodes, List<Long> chromosomeKeys) throws IgniteException {
 
         Map<ComputeJob, ClusterNode> map = new HashMap<>();
@@ -79,22 +73,13 @@ public class CrossOverTask extends ComputeTaskAdapter<List<Long>, Boolean> {
         return map;
     }
 
-    /**
-     * We return TRUE if success, else Exection is thrown.
-     *
-     * @param list ComputeJobResult
-     * @return Boolean value; if operationa was successful return true, otherwise Exception
-     */
+    /** {@inheritDoc} */
     @Override public Boolean reduce(List<ComputeJobResult> list) throws IgniteException {
         // TODO Auto-generated method stub
         return Boolean.TRUE;
     }
 
-    /**
-     * @param res ComputeJobResult
-     * @param rcvd List of ComputeJobResult
-     * @return ComputeJobResultPolicy
-     */
+    /** {@inheritDoc} */
     @Override public ComputeJobResultPolicy result(ComputeJobResult res, List<ComputeJobResult> rcvd) {
         IgniteException err = res.getException();
 
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessJob.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessJob.java
index bdefffd..34bc719 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessJob.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessJob.java
@@ -57,13 +57,7 @@ public class FitnessJob extends ComputeJobAdapter {
         this.fitnessFuncton = fitnessFunction;
     }
 
-    /**
-     * Perform fitness operation utilizing IFitnessFunction
-     *
-     * Update chromosome's fitness value
-     *
-     * @return Fitness score
-     */
+    /** {@inheritDoc} */
     @Override public Double execute() throws IgniteException {
 
         IgniteCache<Long, Chromosome> populationCache = ignite.cache(GAGridConstants.POPULATION_CACHE);
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessTask.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessTask.java
index 62f8406..c38ec50 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessTask.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/FitnessTask.java
@@ -49,11 +49,7 @@ public class FitnessTask extends ComputeTaskAdapter<List<Long>, Boolean> {
         this.cfg = cfg;
     }
 
-    /**
-     * @param nodes List of ClusterNode
-     * @param chromosomeKeys List of chromosome keys
-     * @return Map of jobs to nodes
-     */
+    /** {@inheritDoc} */
     @Override public Map map(List<ClusterNode> nodes, List<Long> chromosomeKeys) throws IgniteException {
 
         Map<ComputeJob, ClusterNode> map = new HashMap<>();
@@ -71,20 +67,13 @@ public class FitnessTask extends ComputeTaskAdapter<List<Long>, Boolean> {
         return map;
     }
 
-    /**
-     * @param list List of ComputeJobResult
-     * @return Boolean value
-     */
+    /** {@inheritDoc} */
     @Override public Boolean reduce(List<ComputeJobResult> list) throws IgniteException {
 
         return Boolean.TRUE;
     }
 
-    /**
-     * @param res ComputeJobResult
-     * @param rcvd List of ComputeJobResult
-     * @return ComputeJobResultPolicy
-     */
+    /** {@inheritDoc} */
     @Override public ComputeJobResultPolicy result(ComputeJobResult res, List<ComputeJobResult> rcvd) {
         IgniteException err = res.getException();
 
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/GAGrid.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/GAGrid.java
index ba68341..723bc1f 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/GAGrid.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/GAGrid.java
@@ -218,7 +218,7 @@ public class GAGrid {
      * @return Map of primary key/fitness score pairs for chromosomes.
      */
     private LinkedHashMap<Long,Double> getChromosomesByFittest() {
-    	LinkedHashMap<Long, Double> orderChromKeysByFittest  = new LinkedHashMap<>();
+        LinkedHashMap<Long, Double> orderChromKeysByFittest = new LinkedHashMap<>();
     	
         String orderDirection = "desc";
 
@@ -233,9 +233,9 @@ public class GAGrid {
         List<List<?>> res = cursor.getAll();
           		
         for (List row : res) {
-        	Long key = (Long)row.get(0);
-        	Double fitnessScore= (Double)row.get(1);
-        	orderChromKeysByFittest.put(key, fitnessScore);
+            Long key = (Long)row.get(0);
+            Double fitnessScore = (Double)row.get(1);
+            orderChromKeysByFittest.put(key, fitnessScore);
         }
         
         return orderChromKeysByFittest;
@@ -337,7 +337,7 @@ public class GAGrid {
      * @return List of primary Keys for respective chromosomes that will breed
      */
     private List<Long> selectByRouletteWheel(LinkedHashMap map) {
-    	List<Long> populationKeys = this.ignite.compute().execute(new RouletteWheelSelectionTask(this.cfg), map);
+        List<Long> populationKeys = this.ignite.compute().execute(new RouletteWheelSelectionTask(this.cfg), map);
     	
         return populationKeys;
     }
@@ -434,9 +434,9 @@ public class GAGrid {
      * @return List of Chromosome primary keys
      */
     List<Long> getPopulationKeys() {
-    	 String fittestSQL = "select _key from Chromosome";
+        String fittestSQL = "select _key from Chromosome";
 
-         // Execute query to retrieve keys for ALL Chromosomes
+        // Execute query to retrieve keys for ALL Chromosomes
          QueryCursor<List<?>> cursor = populationCache.query(new SqlFieldsQuery(fittestSQL));
 
          List<List<?>> res = cursor.getAll();
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateJob.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateJob.java
index 1e8378dd..8bd4455 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateJob.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateJob.java
@@ -53,11 +53,7 @@ public class MutateJob extends ComputeJobAdapter {
         this.mutatedGeneKeys = mutatedGeneKeys;
     }
 
-    /**
-     * Perform mutation
-     *
-     * @return Boolean value
-     */
+    /** {@inheritDoc} */
     @Override public Boolean execute() throws IgniteException {
 
         IgniteCache<Long, Chromosome> populationCache = ignite.cache(GAGridConstants.POPULATION_CACHE);
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateTask.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateTask.java
index 2b35a3e..d6dd812 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateTask.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/MutateTask.java
@@ -73,11 +73,7 @@ public class MutateTask extends ComputeTaskAdapter<List<Long>, Boolean> {
         return mutatedGenes;
     }
 
-    /**
-     * @param nodes List of ClusterNode
-     * @param chromosomeKeys Primary keys for respective chromosomes
-     * @return Mapping compute jobs to nodes.
-     */
+    /** {@inheritDoc} */
     @Override public Map map(List<ClusterNode> nodes, List<Long> chromosomeKeys) throws IgniteException {
 
         Map<ComputeJob, ClusterNode> map = new HashMap<>();
@@ -91,21 +87,12 @@ public class MutateTask extends ComputeTaskAdapter<List<Long>, Boolean> {
         return map;
     }
 
-    /**
-     * We return TRUE if success, else Exection is thrown.
-     *
-     * @param list List of ComputeJobResult
-     * @return Boolean value
-     */
+    /** {@inheritDoc} */
     @Override public Boolean reduce(List<ComputeJobResult> list) throws IgniteException {
         return Boolean.TRUE;
     }
 
-    /**
-     * @param res ComputeJobResult
-     * @param rcvd List of ComputeJobResult
-     * @return ComputeJobResultPolicy
-     */
+    /** {@inheritDoc} */
     @Override public ComputeJobResultPolicy result(ComputeJobResult res, List<ComputeJobResult> rcvd) {
         IgniteException err = res.getException();
 
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionJob.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionJob.java
index b35b89d..7440a8a 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionJob.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionJob.java
@@ -48,11 +48,7 @@ public class TruncateSelectionJob extends ComputeJobAdapter {
         this.mutatedGeneKeys = mutatedGeneKeys;
     }
 
-    /**
-     * Perform mutation
-     *
-     * @return Boolean value
-     */
+    /** {@inheritDoc} */
     @Override public Boolean execute() throws IgniteException {
 
         IgniteCache<Long, Chromosome> populationCache = ignite.cache(GAGridConstants.POPULATION_CACHE);
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionTask.java b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionTask.java
index 7a2802e..343cc07 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionTask.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/genetic/TruncateSelectionTask.java
@@ -106,11 +106,7 @@ public class TruncateSelectionTask extends ComputeTaskAdapter<List<Long>, Boolea
         return list;
     }
 
-    /**
-     * @param nodes List of ClusterNode.
-     * @param chromosomeKeys Primary keys for respective chromosomes.
-     * @return Map of nodes to jobs.
-     */
+    /** {@inheritDoc} */
     @Override public Map map(List<ClusterNode> nodes, List<Long> chromosomeKeys) throws IgniteException {
         Map<ComputeJob, ClusterNode> map = new HashMap<>();
         Affinity affinity = ignite.affinity(GAGridConstants.POPULATION_CACHE);
@@ -128,21 +124,12 @@ public class TruncateSelectionTask extends ComputeTaskAdapter<List<Long>, Boolea
         return map;
     }
 
-    /**
-     * We return TRUE if success, else Exception is thrown.
-     *
-     * @param list List of ComputeJobResult.
-     * @return Boolean value.
-     */
+    /** {@inheritDoc} */
     @Override public Boolean reduce(List<ComputeJobResult> list) throws IgniteException {
         return Boolean.TRUE;
     }
 
-    /**
-     * @param res ComputeJobResult.
-     * @param rcvd List of ComputeJobResult.
-     * @return ComputeJobResultPolicy.
-     */
+    /** {@inheritDoc} */
     @Override public ComputeJobResultPolicy result(ComputeJobResult res, List<ComputeJobResult> rcvd) {
         IgniteException err = res.getException();
 
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/knn/NNClassificationModel.java b/modules/ml/src/main/java/org/apache/ignite/ml/knn/NNClassificationModel.java
index 66d1934..ef7ba3e 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/knn/NNClassificationModel.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/knn/NNClassificationModel.java
@@ -227,6 +227,6 @@ public abstract class NNClassificationModel implements IgniteModel<Vector, Doubl
         this.stgy = mdl.stgy;
     }
 
-    /** */
+    /** {@inheritDoc} */
     @Override public abstract <P> void saveModel(Exporter<KNNModelFormat, P> exporter, P path);
 }
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/Matrix.java b/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/Matrix.java
index 0856854..1669e54 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/Matrix.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/Matrix.java
@@ -504,9 +504,7 @@ public interface Matrix extends MetaAttributes, Externalizable, StorageOpsMetric
      */
     public Vector viewDiagonal();
 
-    /**
-     * Destroys matrix if managed outside of JVM. It's a no-op in all other cases.
-     */
+    /** {@inheritDoc} */
     @Override public default void destroy() {
         // No-op.
     }
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/storage/DenseMatrixStorage.java b/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/storage/DenseMatrixStorage.java
index 2f61e47..d161ed9 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/storage/DenseMatrixStorage.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/storage/DenseMatrixStorage.java
@@ -182,7 +182,7 @@ public class DenseMatrixStorage implements MatrixStorage {
         data = (double[])in.readObject();
     }
 
-    /** Get the access mode of this storage. */
+    /** {@inheritDoc} */
     @Override public int accessMode() {
         return stoMode;
     }
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/storage/SparseMatrixStorage.java b/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/storage/SparseMatrixStorage.java
index 3f2d986..8ad0c25 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/storage/SparseMatrixStorage.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/math/primitives/matrix/storage/SparseMatrixStorage.java
@@ -67,9 +67,7 @@ public class SparseMatrixStorage implements MatrixStorage, StorageConstants {
         sto = new HashMap<>();
     }
 
-    /**
-     * @return Matrix elements storage mode.
-     */
+    /** {@inheritDoc} */
     @Override public int storageMode() {
         return stoMode;
     }
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 ef13fcb..2ab4f88 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
@@ -353,8 +353,10 @@ public class MultilayerPerceptron implements IgniteModel<Matrix, Matrix>, Smooth
     }
 
     /** {@inheritDoc} */
-    @Override public Vector differentiateByParameters(IgniteFunction<Vector, IgniteDifferentiableVectorToDoubleFunction> loss,
-                                                      Matrix inputsBatch, Matrix truthBatch) {
+    @Override public Vector differentiateByParameters(
+        IgniteFunction<Vector, IgniteDifferentiableVectorToDoubleFunction> loss,
+        Matrix inputsBatch, Matrix truthBatch
+    ) {
         // Backpropagation algorithm is used here.
         int batchSize = inputsBatch.columnSize();
         double invBatchSize = 1 / (double)batchSize;
diff --git a/modules/ml/src/main/java/org/apache/ignite/ml/nn/ReplicatedVectorMatrix.java b/modules/ml/src/main/java/org/apache/ignite/ml/nn/ReplicatedVectorMatrix.java
index 3047077..9d49f55 100644
--- a/modules/ml/src/main/java/org/apache/ignite/ml/nn/ReplicatedVectorMatrix.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/nn/ReplicatedVectorMatrix.java
@@ -172,7 +172,7 @@ class ReplicatedVectorMatrix implements Matrix {
         return asCol ? new ReplicatedVectorMatrix(swap(row1, row2), replicationCnt, asCol) : this;
     }
 
-    /** {@inheritDoc} */
+    /** */
     private Vector swap(int idx1, int idx2) {
         double val = vector.getX(idx1);
 
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 997d8f8..a41a77c 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
@@ -337,7 +337,7 @@ public abstract class DatasetTrainer<M extends IgniteModel, L> {
                 return new PatchedPreprocessor<K, V, L1, L>(func, extractor);
             }
 
-            /** {@inheritDoc} */
+            /** */
             public <K, V> M fit(DatasetBuilder<K, V> datasetBuilder,
                                 Vectorizer<K, V, Integer, L1> extractor) {
                 return old.fit(datasetBuilder, getNewExtractor(extractor));
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 c83cb38..6f4aea6 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
@@ -447,7 +447,7 @@ public class TestUtils {
      */
     public static <I, O, M extends IgniteModel<I, O>, L> DatasetTrainer<M, L> constantTrainer(M ml) {
         return new DatasetTrainer<M, L>() {
-            /** {@inheritDoc} */
+            /** */
             public <K, V, C extends Serializable> M fit(DatasetBuilder<K, V> datasetBuilder,
                 Vectorizer<K, V, C, L> extractor) {
                 return ml;
@@ -467,8 +467,8 @@ public class TestUtils {
                 return null;
             }
 
-            /** {@inheritDoc} */
-             public <K, V, C extends Serializable> M updateModel(M mdl, DatasetBuilder<K, V> datasetBuilder,
+            /** */
+            public <K, V, C extends Serializable> M updateModel(M mdl, DatasetBuilder<K, V> datasetBuilder,
                 Vectorizer<K, V, C, L> extractor) {
                 return ml;
             }
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/vector/VectorImplementationsFixtures.java b/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/vector/VectorImplementationsFixtures.java
index bbc87b0..be76ac5 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/vector/VectorImplementationsFixtures.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/math/primitives/vector/VectorImplementationsFixtures.java
@@ -214,7 +214,7 @@ class VectorImplementationsFixtures {
             return (size, delta) -> ctor.apply(size + delta, extras[extraIdx]);
         }
 
-        /** */
+        /** {@inheritDoc} */
         @Override void selfTest() {
             final Set<Integer> extraIdxs = new HashSet<>();
 
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/preprocessing/binarization/BinarizationTrainerTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/preprocessing/binarization/BinarizationTrainerTest.java
index f711690..5a76647 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/preprocessing/binarization/BinarizationTrainerTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/preprocessing/binarization/BinarizationTrainerTest.java
@@ -24,7 +24,6 @@ import org.apache.ignite.ml.dataset.DatasetBuilder;
 import org.apache.ignite.ml.dataset.feature.extractor.Vectorizer;
 import org.apache.ignite.ml.dataset.feature.extractor.impl.DummyVectorizer;
 import org.apache.ignite.ml.dataset.impl.local.LocalDatasetBuilder;
-import org.apache.ignite.ml.math.functions.IgniteBiFunction;
 import org.apache.ignite.ml.math.primitives.vector.Vector;
 import org.apache.ignite.ml.math.primitives.vector.VectorUtils;
 import org.junit.Test;
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/selection/scoring/evaluator/BinaryClassificationEvaluatorTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/selection/scoring/evaluator/BinaryClassificationEvaluatorTest.java
index 9e0bd23..e0cfab8 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/selection/scoring/evaluator/BinaryClassificationEvaluatorTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/selection/scoring/evaluator/BinaryClassificationEvaluatorTest.java
@@ -21,7 +21,6 @@ import org.apache.ignite.ml.dataset.feature.extractor.Vectorizer;
 import org.apache.ignite.ml.dataset.feature.extractor.impl.DummyVectorizer;
 import org.apache.ignite.ml.knn.NNClassificationModel;
 import org.apache.ignite.ml.knn.classification.KNNClassificationTrainer;
-import org.apache.ignite.ml.math.functions.IgniteBiFunction;
 import org.apache.ignite.ml.math.primitives.vector.Vector;
 import org.apache.ignite.ml.math.primitives.vector.VectorUtils;
 import org.apache.ignite.ml.selection.scoring.metric.classification.Accuracy;
diff --git a/modules/ml/src/test/java/org/apache/ignite/ml/selection/scoring/evaluator/RegressionEvaluatorTest.java b/modules/ml/src/test/java/org/apache/ignite/ml/selection/scoring/evaluator/RegressionEvaluatorTest.java
index 8028e5f..b7cb26a 100644
--- a/modules/ml/src/test/java/org/apache/ignite/ml/selection/scoring/evaluator/RegressionEvaluatorTest.java
+++ b/modules/ml/src/test/java/org/apache/ignite/ml/selection/scoring/evaluator/RegressionEvaluatorTest.java
@@ -23,7 +23,6 @@ import org.apache.ignite.ml.dataset.impl.local.LocalDatasetBuilder;
 import org.apache.ignite.ml.knn.regression.KNNRegressionModel;
 import org.apache.ignite.ml.knn.regression.KNNRegressionTrainer;
 import org.apache.ignite.ml.math.distances.EuclideanDistance;
-import org.apache.ignite.ml.math.functions.IgniteBiFunction;
 import org.apache.ignite.ml.math.primitives.vector.Vector;
 import org.apache.ignite.ml.math.primitives.vector.VectorUtils;
 import org.apache.ignite.ml.selection.scoring.metric.regression.RegressionMetricValues;
diff --git a/modules/osgi/src/main/java/org/apache/ignite/osgi/classloaders/BundleDelegatingClassLoader.java b/modules/osgi/src/main/java/org/apache/ignite/osgi/classloaders/BundleDelegatingClassLoader.java
index a66d724..4659bd8 100644
--- a/modules/osgi/src/main/java/org/apache/ignite/osgi/classloaders/BundleDelegatingClassLoader.java
+++ b/modules/osgi/src/main/java/org/apache/ignite/osgi/classloaders/BundleDelegatingClassLoader.java
@@ -70,26 +70,13 @@ public class BundleDelegatingClassLoader extends ClassLoader {
         return resource;
     }
 
-    /**
-     * Finds a given resource from within the {@link #bundle}.
-     *
-     * @param name The resource name.
-     * @return URLs of resources.
-     * @throws IOException
-     */
+    /** {@inheritDoc} */
     @SuppressWarnings({"unchecked", "rawtypes"})
-    protected Enumeration findResources(String name) throws IOException {
+    @Override protected Enumeration findResources(String name) throws IOException {
         return bundle.getResources(name);
     }
 
-    /**
-     * Loads a class trying the {@link #bundle} first, falling back to the ClassLoader {@link #clsLdr}.
-     *
-     * @param name Class name.
-     * @param resolve {@code true} to resolve the class.
-     * @return The Class.
-     * @throws ClassNotFoundException
-     */
+    /** {@inheritDoc} */
     @Override protected Class<?> loadClass(String name, boolean resolve) throws ClassNotFoundException {
         Class<?> cls;
 
diff --git a/modules/spark/src/test/java/org/apache/ignite/spark/JavaEmbeddedIgniteRDDSelfTest.java b/modules/spark/src/test/java/org/apache/ignite/spark/JavaEmbeddedIgniteRDDSelfTest.java
index d602209..8f3b691 100644
--- a/modules/spark/src/test/java/org/apache/ignite/spark/JavaEmbeddedIgniteRDDSelfTest.java
+++ b/modules/spark/src/test/java/org/apache/ignite/spark/JavaEmbeddedIgniteRDDSelfTest.java
@@ -24,8 +24,6 @@ import org.apache.ignite.configuration.CacheConfiguration;
 import org.apache.ignite.configuration.IgniteConfiguration;
 import org.apache.ignite.internal.util.typedef.F;
 import org.apache.ignite.lang.IgniteOutClosure;
-import org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
 import org.apache.spark.SparkConf;
 import org.apache.spark.api.java.JavaRDD;
diff --git a/modules/tensorflow/src/main/java/org/apache/ignite/tensorflow/core/util/PythonProcessBuilderSupplier.java b/modules/tensorflow/src/main/java/org/apache/ignite/tensorflow/core/util/PythonProcessBuilderSupplier.java
index 824e18a..7ea2c15 100644
--- a/modules/tensorflow/src/main/java/org/apache/ignite/tensorflow/core/util/PythonProcessBuilderSupplier.java
+++ b/modules/tensorflow/src/main/java/org/apache/ignite/tensorflow/core/util/PythonProcessBuilderSupplier.java
@@ -47,12 +47,8 @@ public class PythonProcessBuilderSupplier implements SerializableSupplier<Proces
         this.meta = meta;
     }
 
-    /**
-     * Returns process builder to be used to start Python process.
-     *
-     * @return Process builder to be used to start Python process.
-     */
-    public ProcessBuilder get() {
+    /** {@inheritDoc} */
+    @Override public ProcessBuilder get() {
         String python = System.getenv(PYTHON_ENV_NAME);
 
         if (python == null)
diff --git a/modules/urideploy/src/main/java/org/apache/ignite/spi/deployment/uri/scanners/UriDeploymentScannerManager.java b/modules/urideploy/src/main/java/org/apache/ignite/spi/deployment/uri/scanners/UriDeploymentScannerManager.java
index ba93dcd..181a22b 100644
--- a/modules/urideploy/src/main/java/org/apache/ignite/spi/deployment/uri/scanners/UriDeploymentScannerManager.java
+++ b/modules/urideploy/src/main/java/org/apache/ignite/spi/deployment/uri/scanners/UriDeploymentScannerManager.java
@@ -163,14 +163,14 @@ public class UriDeploymentScannerManager implements UriDeploymentScannerContext
     }
 
     /** {@inheritDoc} */
-    public boolean isCancelled() {
+    @Override public boolean isCancelled() {
         assert scannerThread != null;
 
         return scannerThread.isInterrupted();
     }
 
     /** {@inheritDoc} */
-    public File createTempFile(String fileName, File tmpDir) throws IOException {
+    @Override public File createTempFile(String fileName, File tmpDir) throws IOException {
         assert fileName != null;
 
         int idx = fileName.lastIndexOf('.');
@@ -189,32 +189,32 @@ public class UriDeploymentScannerManager implements UriDeploymentScannerContext
     }
 
     /** {@inheritDoc} */
-    public boolean isFirstScan() {
+    @Override public boolean isFirstScan() {
         return firstScan;
     }
 
     /** {@inheritDoc} */
-    public URI getUri() {
+    @Override public URI getUri() {
         return uri;
     }
 
     /** {@inheritDoc} */
-    public File getDeployDirectory() {
+    @Override public File getDeployDirectory() {
         return deployDir;
     }
 
     /** {@inheritDoc} */
-    public FilenameFilter getFilter() {
+    @Override public FilenameFilter getFilter() {
         return filter;
     }
 
     /** {@inheritDoc} */
-    public GridUriDeploymentScannerListener getListener() {
+    @Override public GridUriDeploymentScannerListener getListener() {
         return lsnr;
     }
 
     /** {@inheritDoc} */
-    public IgniteLogger getLogger() {
+    @Override public IgniteLogger getLogger() {
         return log;
     }
 
diff --git a/modules/urideploy/src/test/java/org/apache/ignite/spi/deployment/uri/GridUriDeploymentAbstractSelfTest.java b/modules/urideploy/src/test/java/org/apache/ignite/spi/deployment/uri/GridUriDeploymentAbstractSelfTest.java
index 8002a40..d90a14b 100644
--- a/modules/urideploy/src/test/java/org/apache/ignite/spi/deployment/uri/GridUriDeploymentAbstractSelfTest.java
+++ b/modules/urideploy/src/test/java/org/apache/ignite/spi/deployment/uri/GridUriDeploymentAbstractSelfTest.java
@@ -92,7 +92,7 @@ public abstract class GridUriDeploymentAbstractSelfTest extends GridSpiAbstractT
     protected void waitForTask(String taskName, boolean expectDeployed, long timeout) throws IgniteCheckedException {
         assertTrue("Failed to wait for (un)deployment of " + taskName,
             GridTestUtils.waitForCondition(new GridAbsPredicateX() {
-                public boolean applyx() throws IgniteCheckedException {
+                @Override public boolean applyx() throws IgniteCheckedException {
                     if (expectDeployed)
                         return getSpi().findResource(taskName) != null;
                     else
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteThinClient.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteThinClient.java
index b6ae026..6a10d92 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteThinClient.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteThinClient.java
@@ -55,7 +55,7 @@ public class IgniteThinClient {
         this.client = client;
     }
 
-    /** {@inheritDoc} */
+    /** */
     public IgniteClient start(BenchmarkConfiguration cfg, String host) throws Exception {
         IgniteBenchmarkArguments args = new IgniteBenchmarkArguments();
 
diff --git a/modules/yarn/src/main/java/org/apache/ignite/yarn/ApplicationMaster.java b/modules/yarn/src/main/java/org/apache/ignite/yarn/ApplicationMaster.java
index 3a5c946..628319b 100644
--- a/modules/yarn/src/main/java/org/apache/ignite/yarn/ApplicationMaster.java
+++ b/modules/yarn/src/main/java/org/apache/ignite/yarn/ApplicationMaster.java
@@ -106,7 +106,7 @@ public class ApplicationMaster implements AMRMClientAsync.CallbackHandler {
     }
 
     /** {@inheritDoc} */
-    public synchronized void onContainersAllocated(List<Container> conts) {
+    @Override public synchronized void onContainersAllocated(List<Container> conts) {
         for (Container c : conts) {
             if (checkContainer(c)) {
                 try {
@@ -225,7 +225,7 @@ public class ApplicationMaster implements AMRMClientAsync.CallbackHandler {
     }
 
     /** {@inheritDoc} */
-    public synchronized void onContainersCompleted(List<ContainerStatus> statuses) {
+    @Override public synchronized void onContainersCompleted(List<ContainerStatus> statuses) {
         for (ContainerStatus status : statuses) {
             containers.remove(status.getContainerId());
 
@@ -235,7 +235,7 @@ public class ApplicationMaster implements AMRMClientAsync.CallbackHandler {
     }
 
     /** {@inheritDoc} */
-    public synchronized void onNodesUpdated(List<NodeReport> updated) {
+    @Override public synchronized void onNodesUpdated(List<NodeReport> updated) {
         for (NodeReport node : updated) {
             // If node unusable.
             if (node.getNodeState().isUnusable()) {
@@ -255,17 +255,17 @@ public class ApplicationMaster implements AMRMClientAsync.CallbackHandler {
     }
 
     /** {@inheritDoc} */
-    public void onShutdownRequest() {
+    @Override public void onShutdownRequest() {
         // No-op.
     }
 
     /** {@inheritDoc} */
-    public void onError(Throwable t) {
+    @Override public void onError(Throwable t) {
         nmClient.stop();
     }
 
     /** {@inheritDoc} */
-    public float getProgress() {
+    @Override public float getProgress() {
         return 50;
     }
 
diff --git a/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/internal/ZookeeperClusterNode.java b/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/internal/ZookeeperClusterNode.java
index 6c9ee71..fcbc19e 100644
--- a/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/internal/ZookeeperClusterNode.java
+++ b/modules/zookeeper/src/main/java/org/apache/ignite/spi/discovery/zk/internal/ZookeeperClusterNode.java
@@ -157,7 +157,7 @@ public class ZookeeperClusterNode implements IgniteClusterNode, Externalizable,
     }
 
     /** {@inheritDoc} */
-    public void setConsistentId(Serializable consistentId) {
+    @Override public void setConsistentId(Serializable consistentId) {
         this.consistentId = consistentId;
 
         final Map<String, Object> map = new HashMap<>(attrs);
@@ -210,7 +210,7 @@ public class ZookeeperClusterNode implements IgniteClusterNode, Externalizable,
     }
 
     /** {@inheritDoc} */
-    public void setMetrics(ClusterMetrics metrics) {
+    @Override public void setMetrics(ClusterMetrics metrics) {
         assert metrics != null;
 
         this.metrics = metrics;
@@ -230,7 +230,7 @@ public class ZookeeperClusterNode implements IgniteClusterNode, Externalizable,
     }
 
     /** {@inheritDoc} */
-    public void setCacheMetrics(Map<Integer, CacheMetrics> cacheMetrics) {
+    @Override public void setCacheMetrics(Map<Integer, CacheMetrics> cacheMetrics) {
         this.cacheMetrics = cacheMetrics != null ? cacheMetrics : Collections.<Integer, CacheMetrics>emptyMap();
     }
 
diff --git a/modules/zookeeper/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/zk/curator/TestingZooKeeperServer.java b/modules/zookeeper/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/zk/curator/TestingZooKeeperServer.java
index eee1670..2ee583f 100644
--- a/modules/zookeeper/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/zk/curator/TestingZooKeeperServer.java
+++ b/modules/zookeeper/src/test/java/org/apache/ignite/spi/discovery/tcp/ipfinder/zk/curator/TestingZooKeeperServer.java
@@ -78,7 +78,7 @@ public class TestingZooKeeperServer extends QuorumPeerMain implements Closeable
     }
 
     /** {@inheritDoc} */
-    public QuorumPeer getQuorumPeer() {
+    @Override public QuorumPeer getQuorumPeer() {
         return main.getQuorumPeer();
     }
 
@@ -152,7 +152,7 @@ public class TestingZooKeeperServer extends QuorumPeerMain implements Closeable
             return;
 
         new Thread(new Runnable() {
-            public void run() {
+            @Override public void run() {
                 try {
                     QuorumPeerConfig config = configBuilder.buildConfig(thisInstanceIndex);
                     main.runFromConfig(config);
diff --git a/parent/pom.xml b/parent/pom.xml
index 9de9e8b..57ee597 100644
--- a/parent/pom.xml
+++ b/parent/pom.xml
@@ -102,6 +102,8 @@
         <lucene.version>7.4.0</lucene.version>
         <lz4.version>1.5.0</lz4.version>
         <maven.bundle.plugin.version>3.5.0</maven.bundle.plugin.version>
+        <maven.checkstyle.plugin.version>3.0.0</maven.checkstyle.plugin.version>
+        <checkstyle.puppycrawl.version>8.19</checkstyle.puppycrawl.version>
         <mockito.version>1.10.19</mockito.version>
         <mysql.connector.version>8.0.13</mysql.connector.version>
         <netlibjava.version>1.1.2</netlibjava.version>
@@ -790,6 +792,45 @@
 
     <profiles>
         <profile>
+            <id>checkstyle</id>
+            <build>
+                <plugins>
+                    <plugin>
+                        <groupId>org.apache.maven.plugins</groupId>
+                        <artifactId>maven-checkstyle-plugin</artifactId>
+                        <version>${maven.checkstyle.plugin.version}</version>
+                        <executions>
+                            <execution>
+                                <id>style</id>
+                                <goals>
+                                    <goal>check</goal>
+                                </goals>
+                                <phase>validate</phase>
+                                <configuration>
+                                    <consoleOutput>true</consoleOutput>
+                                    <logViolationsToConsole>true</logViolationsToConsole>
+                                    <failsOnError>false</failsOnError>
+                                    <failOnViolation>false</failOnViolation>
+                                    <outputFile>${project.build.directory}/checkstyle-result.xml</outputFile>
+                                    <configLocation>../checkstyle/checkstyle.xml</configLocation>
+                                    <suppressionsLocation>../checkstyle/checkstyle-suppressions.xml</suppressionsLocation>
+                                    <includeTestSourceDirectory>true</includeTestSourceDirectory>
+                                </configuration>
+                            </execution>
+                        </executions>
+                        <dependencies>
+                            <dependency>
+                                <groupId>com.puppycrawl.tools</groupId>
+                                <artifactId>checkstyle</artifactId>
+                                <version>${checkstyle.puppycrawl.version}</version>
+                            </dependency>
+                        </dependencies>
+                    </plugin>
+                </plugins>
+            </build>
+        </profile>
+
+        <profile>
             <id>check-licenses</id>
             <build>
                 <plugins>
@@ -863,10 +904,7 @@
                                         <exclude>**/keystore/ca/*serial</exclude><!--auto generated files-->
                                         <exclude>**/META-INF/services/**</exclude> <!-- Interface mappings: cannot be changed -->
                                         <!--special excludes-->
-                                        <exclude>idea/disabled_plugins.txt</exclude>
                                         <exclude>idea/ignite_codeStyle.xml</exclude>
-                                        <exclude>idea/ignite_inspections.xml</exclude>
-                                        <exclude>idea/ignite_inspections_teamcity.xml</exclude>
                                         <exclude>**/DEVNOTES*.txt</exclude>
                                         <exclude>**/NOTICE*</exclude>
                                         <exclude>**/LICENSE*</exclude>
@@ -981,6 +1019,8 @@
                                         <exclude>**/web-console/frontend/**/*.svg</exclude>
                                         <!--Packaging -->
                                         <exclude>packaging/**</exclude>
+                                        <!-- Checkstyle -->
+                                        <exclude>checkstyle/**</exclude>
                                     </excludes>
                                 </configuration>
                             </execution>
@@ -1266,6 +1306,5 @@
                 </pluginManagement>
             </build>
         </profile>
-
     </profiles>
 </project>


[ignite] 07/17: WC-1051 Web Console: Fixed Wrong layout for grids and "no-data" component.

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 8ac02946afe314f61f970fccf67e3113f8454eb6
Author: Ilya Borisov <ib...@gridgain.com>
AuthorDate: Tue Apr 23 10:33:20 2019 +0700

    WC-1051 Web Console: Fixed Wrong layout for grids and "no-data" component.
---
 .../components/page-queries/components/queries-notebooks-list/style.scss | 1 -
 1 file changed, 1 deletion(-)

diff --git a/modules/web-console/frontend/app/components/page-queries/components/queries-notebooks-list/style.scss b/modules/web-console/frontend/app/components/page-queries/components/queries-notebooks-list/style.scss
index 8e95885..7cce499 100644
--- a/modules/web-console/frontend/app/components/page-queries/components/queries-notebooks-list/style.scss
+++ b/modules/web-console/frontend/app/components/page-queries/components/queries-notebooks-list/style.scss
@@ -22,7 +22,6 @@
 
 .queries-notebooks-list {
   grid-no-data {
-    top: -6px;
     background: white;
   }
 


[ignite] 17/17: GG-17462: Mute failed test.

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit b204c103de1b14618eb46710988c317ed7f201dd
Author: Andrey V. Mashenkov <an...@gmail.com>
AuthorDate: Fri Apr 26 13:17:35 2019 +0300

    GG-17462: Mute failed test.
---
 .../internal/processors/cache/IgniteClientCacheStartFailoverTest.java   | 2 ++
 1 file changed, 2 insertions(+)

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 2d91f92..bb0dfa2 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
@@ -49,6 +49,7 @@ import org.apache.ignite.lang.IgnitePredicate;
 import org.apache.ignite.plugin.extensions.communication.Message;
 import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
+import org.junit.Ignore;
 import org.junit.Test;
 
 import static org.apache.ignite.cache.CacheAtomicityMode.ATOMIC;
@@ -436,6 +437,7 @@ public class IgniteClientCacheStartFailoverTest extends GridCommonAbstractTest {
     /**
      * @throws Exception If failed.
      */
+    @Ignore("https://ggsystems.atlassian.net/browse/GG-17462")
     @Test
     public void testClientStartCloseServersRestart() throws Exception {
         final int SRVS = 4;


[ignite] 05/17: Update Ignite version in properties

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 0f056b2edb13a43b78df20890e2b61cb6f5bbb65
Author: Dmitriy Pavlov <dp...@apache.org>
AuthorDate: Tue Apr 16 18:45:12 2019 +0300

    Update Ignite version in properties
---
 modules/core/src/main/resources/ignite.properties | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/modules/core/src/main/resources/ignite.properties b/modules/core/src/main/resources/ignite.properties
index eec8edf..8bdd598 100644
--- a/modules/core/src/main/resources/ignite.properties
+++ b/modules/core/src/main/resources/ignite.properties
@@ -13,7 +13,7 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 #
-ignite.version=2.7.0-SNAPSHOT
+ignite.version=8.8.0-SNAPSHOT
 ignite.build=0
 ignite.revision=DEV
 ignite.rel.date=01011970


[ignite] 14/17: GG-17352I .NET: Add baseline auto-adjust parameters (definition, run-time change)

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 7515a2901e6a8ecef46fc3694b19dee9544a61df
Author: Alexandr Shapkin <as...@gridgain.com>
AuthorDate: Thu Apr 25 13:06:03 2019 +0300

    GG-17352I .NET: Add baseline auto-adjust parameters (definition, run-time change)
    
    Signed-off-by: Dmitriy Govorukhin <dm...@gmail.com>
---
 .../processors/platform/PlatformProcessorImpl.java | 30 ++++++++++++++++++
 .../Cache/PersistenceTest.cs                       | 37 ++++++++++++++++++++++
 .../dotnet/Apache.Ignite.Core/Cluster/ICluster.cs  | 24 ++++++++++++++
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs       | 31 +++++++++++++++++-
 4 files changed, 121 insertions(+), 1 deletion(-)

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 32f50d5..12c660f 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
@@ -171,6 +171,18 @@ public class PlatformProcessorImpl extends GridProcessorAdapter implements Platf
     /** */
     private static final int OP_NODE_VERSION = 31;
 
+    /** */
+    private static final int OP_IS_BASELINE_AUTO_ADJ_ENABLED = 32;
+
+    /** */
+    private static final int OP_SET_BASELINE_AUTO_ADJ_ENABLED = 33;
+
+    /** */
+    private static final int OP_GET_BASELINE_AUTO_ADJ_TIMEOUT = 34;
+
+    /** */
+    private static final int OP_SET_BASELINE_AUTO_ADJ_TIMEOUT = 35;
+
     /** Start latch. */
     private final CountDownLatch startLatch = new CountDownLatch(1);
 
@@ -445,6 +457,12 @@ public class PlatformProcessorImpl extends GridProcessorAdapter implements Platf
 
                 return 0;
             }
+
+            case OP_SET_BASELINE_AUTO_ADJ_TIMEOUT: {
+                ctx.grid().cluster().baselineAutoAdjustTimeout(val);
+
+                return 0;
+            }
         }
 
         return PlatformAbstractTarget.throwUnsupported(type);
@@ -505,6 +523,18 @@ public class PlatformProcessorImpl extends GridProcessorAdapter implements Platf
 
             case OP_IS_WAL_ENABLED:
                 return ctx.grid().cluster().isWalEnabled(reader.readString()) ? TRUE : FALSE;
+
+            case OP_IS_BASELINE_AUTO_ADJ_ENABLED:
+                return ctx.grid().cluster().isBaselineAutoAdjustEnabled() ? TRUE : FALSE;
+
+            case OP_SET_BASELINE_AUTO_ADJ_ENABLED:
+                boolean isEnabled = reader.readBoolean();
+                ctx.grid().cluster().baselineAutoAdjustEnabled(isEnabled);
+
+                return 0;
+
+            case OP_GET_BASELINE_AUTO_ADJ_TIMEOUT:
+                return ctx.grid().cluster().baselineAutoAdjustTimeout();
         }
 
         return PlatformAbstractTarget.throwUnsupported(type);
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Cache/PersistenceTest.cs b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Cache/PersistenceTest.cs
index 6afc3aa..c703596 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Cache/PersistenceTest.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Cache/PersistenceTest.cs
@@ -22,6 +22,7 @@ namespace Apache.Ignite.Core.Tests.Cache
     using Apache.Ignite.Core.Cache.Affinity.Rendezvous;
     using Apache.Ignite.Core.Cache.Configuration;
     using Apache.Ignite.Core.Cache.Store;
+    using Apache.Ignite.Core.Cluster;
     using Apache.Ignite.Core.Common;
     using Apache.Ignite.Core.Configuration;
     using NUnit.Framework;
@@ -323,6 +324,42 @@ namespace Apache.Ignite.Core.Tests.Cache
         }
 
         /// <summary>
+        /// Test the configuration of IsBaselineAutoAdjustEnabled flag
+        /// </summary>
+        [Test]
+        public void TestBaselineTopologyAutoAdjustEnabledDisabled()
+        {
+            using (var ignite = Ignition.Start(GetPersistentConfiguration()))
+            {
+                ICluster cluster = ignite.GetCluster();
+                cluster.SetActive(true);
+
+                bool isEnabled = cluster.IsBaselineAutoAdjustEnabled();
+                cluster.SetBaselineAutoAdjustEnabledFlag(!isEnabled);
+
+                Assert.AreNotEqual(isEnabled, cluster.IsBaselineAutoAdjustEnabled());
+            }
+        }
+
+        /// <summary>
+        /// Test the configuration of BaselineAutoAdjustTimeout property
+        /// </summary>
+        [Test]
+        public void TestBaselineTopologyAutoAdjustTimeoutWriteRead()
+        {
+            const long newTimeout = 333000;
+            using (var ignite = Ignition.Start(GetPersistentConfiguration()))
+            {
+                ICluster cluster = ignite.GetCluster();
+                cluster.SetActive(true);
+
+                cluster.SetBaselineAutoAdjustTimeout(newTimeout);
+
+                Assert.AreEqual(newTimeout, cluster.GetBaselineAutoAdjustTimeout());
+            }
+        }
+
+        /// <summary>
         /// Checks active state.
         /// </summary>
         private static void CheckIsActive(IIgnite ignite, bool isActive)
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core/Cluster/ICluster.cs b/modules/platforms/dotnet/Apache.Ignite.Core/Cluster/ICluster.cs
index ae1de71..84ed03d 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core/Cluster/ICluster.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Core/Cluster/ICluster.cs
@@ -160,5 +160,29 @@ namespace Apache.Ignite.Core.Cluster
         /// </summary>
         /// <param name="timeout"></param>
         void SetTxTimeoutOnPartitionMapExchange(TimeSpan timeout);
+
+        /// <summary>
+        /// Returns value of manual baseline control or auto adjusting baseline.
+        /// </summary>
+        /// <returns><c>true</c> If cluster in auto-adjust. <c>false</c> If cluster in manual.</returns>
+        bool IsBaselineAutoAdjustEnabled();
+
+        /// <summary>
+        /// Sets the value of manual baseline control or auto adjusting baseline.
+        /// </summary>
+        /// <param name="isBaselineAutoAdjustEnabled"><c>true</c> If cluster in auto-adjust. <c>false</c> If cluster in manual.</param>
+        void SetBaselineAutoAdjustEnabledFlag(bool isBaselineAutoAdjustEnabled);
+
+        /// <summary>
+        /// Gets the value of time which we would wait before the actual topology change since last server topology change(node join/left/fail).
+        /// </summary>
+        /// <returns>Timeout value</returns>
+        long GetBaselineAutoAdjustTimeout();
+
+        /// <summary>
+        /// Sets the value of time which we would wait before the actual topology change since last server topology change(node join/left/fail).
+        /// </summary>
+        /// <param name="baselineAutoAdjustTimeout">Timeout value</param>
+        void SetBaselineAutoAdjustTimeout(long baselineAutoAdjustTimeout);
     }
 }
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Ignite.cs b/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Ignite.cs
index 03bc69f..e0f31f6 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Ignite.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Ignite.cs
@@ -92,7 +92,11 @@ namespace Apache.Ignite.Core.Impl
             EnableWal = 28,
             IsWalEnabled = 29,
             SetTxTimeoutOnPartitionMapExchange = 30,
-            GetNodeVersion = 31
+            GetNodeVersion = 31,
+            IsBaselineAutoAdjustmentEnabled = 32,
+            SetBaselineAutoAdjustmentEnabled = 33,
+            GetBaselineAutoAdjustTimeout = 34,
+            SetBaselineAutoAdjustTimeout = 35
         }
 
         /** */
@@ -845,6 +849,7 @@ namespace Apache.Ignite.Core.Impl
             return DoOutOp((int) Op.IsWalEnabled, w => w.WriteString(cacheName)) == True;
         }
 
+        /** <inheritdoc /> */
         public void SetTxTimeoutOnPartitionMapExchange(TimeSpan timeout)
         {
             DoOutOp((int) Op.SetTxTimeoutOnPartitionMapExchange, 
@@ -852,6 +857,30 @@ namespace Apache.Ignite.Core.Impl
         }
 
         /** <inheritdoc /> */
+        public bool IsBaselineAutoAdjustEnabled()
+        {
+            return DoOutOp((int) Op.IsBaselineAutoAdjustmentEnabled, s => s.ReadBool()) == True;
+        }
+
+        /** <inheritdoc /> */
+        public void SetBaselineAutoAdjustEnabledFlag(bool isBaselineAutoAdjustEnabled)
+        {
+            DoOutOp((int) Op.SetBaselineAutoAdjustmentEnabled, w => w.WriteBoolean(isBaselineAutoAdjustEnabled));
+        }
+
+        /** <inheritdoc /> */
+        public long GetBaselineAutoAdjustTimeout()
+        {
+            return DoOutOp((int) Op.GetBaselineAutoAdjustTimeout, s => s.ReadLong());
+        }
+
+        /** <inheritdoc /> */
+        public void SetBaselineAutoAdjustTimeout(long baselineAutoAdjustTimeout)
+        {
+            DoOutInOp((int) Op.SetBaselineAutoAdjustTimeout, baselineAutoAdjustTimeout);
+        }
+
+        /** <inheritdoc /> */
 #pragma warning disable 618
         public IPersistentStoreMetrics GetPersistentStoreMetrics()
         {


[ignite] 04/17: Ignoring RST files with unapproved licenses, temp fix until correct solution is found

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit be3f3def0a3ccc5bab33a8aebffb8a47ddb87267
Author: Dmitriy Pavlov <dp...@apache.org>
AuthorDate: Tue Apr 16 16:27:46 2019 +0300

    Ignoring RST files with unapproved licenses, temp fix until correct solution is found
---
 parent/pom.xml | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/parent/pom.xml b/parent/pom.xml
index fdddaf4..3546ebe 100644
--- a/parent/pom.xml
+++ b/parent/pom.xml
@@ -965,7 +965,7 @@
                                         <exclude>modules/platforms/python/**/*.md</exclude><!--markdown can not be commented-->
                                         <exclude>modules/platforms/python/docs/Makefile</exclude><!--sphinx files: BSD license-->
                                         <exclude>modules/platforms/python/docs/conf.py</exclude><!--sphinx files: BSD license-->
-                                        <exclude>modules/platforms/python/docs/source/**/*.rst</exclude><!--sphinx-apidoc generated files-->
+                                        <exclude>modules/platforms/python/docs/**/*.rst</exclude><!--sphinx-apidoc generated files-->
                                         <exclude>modules/platforms/python/requirements/**/*.txt</exclude><!--plain text can not be commented-->
                                         <!--web console-->
                                         <exclude>**/web-console/**/.eslintrc</exclude>


[ignite] 06/17: Copyright 2019 GridGain Systems, Inc. and Contributors.

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 58ae2a840f92415c60d0dae62d9e0b1a04d84e39
Author: mstepachev <ma...@gmail.com>
AuthorDate: Fri Apr 19 08:31:48 2019 +0300

    Copyright 2019 GridGain Systems, Inc. and Contributors.
---
 .../dotnet/Apache.Ignite.Core/NuGet/Install.ps1      | 20 +++++++++++---------
 .../dotnet/Apache.Ignite.Core/NuGet/PostBuild.ps1    | 20 +++++++++++---------
 .../dotnet/Apache.Ignite.Core/NuGet/Uninstall.ps1    | 20 +++++++++++---------
 .../platforms/python/pyignite/connection/__init__.py | 14 --------------
 packaging/deb/copyright                              |  7 ++++---
 5 files changed, 37 insertions(+), 44 deletions(-)

diff --git a/modules/platforms/dotnet/Apache.Ignite.Core/NuGet/Install.ps1 b/modules/platforms/dotnet/Apache.Ignite.Core/NuGet/Install.ps1
index 19e5484..09cedc3 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core/NuGet/Install.ps1
+++ b/modules/platforms/dotnet/Apache.Ignite.Core/NuGet/Install.ps1
@@ -1,14 +1,16 @@
-#    Licensed under the Apache License, Version 2.0 (the "License");
-#    you may not use this file except in compliance with the License.
-#    You may obtain a copy of the License at
+#  Copyright 2019 GridGain Systems, Inc. and Contributors.
 #
-#        http://www.apache.org/licenses/LICENSE-2.0
+#  Licensed under the GridGain Community Edition License (the "License");
+#  you may not use this file except in compliance with the License.
+#  You may obtain a copy of the License at
 #
-#    Unless required by applicable law or agreed to in writing, software
-#    distributed under the License is distributed on an "AS IS" BASIS,
-#    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-#    See the License for the specific language governing permissions and
-#    limitations under the License.
+#      https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+#
+#  Unless required by applicable law or agreed to in writing, software
+#  distributed under the License is distributed on an "AS IS" BASIS,
+#  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+#  See the License for the specific language governing permissions and
+#  limitations under the License.
 
 param($installPath, $toolsPath, $package, $project)
 
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core/NuGet/PostBuild.ps1 b/modules/platforms/dotnet/Apache.Ignite.Core/NuGet/PostBuild.ps1
index 27e823c..0fa233c 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core/NuGet/PostBuild.ps1
+++ b/modules/platforms/dotnet/Apache.Ignite.Core/NuGet/PostBuild.ps1
@@ -1,14 +1,16 @@
-#    Licensed under the Apache License, Version 2.0 (the "License");
-#    you may not use this file except in compliance with the License.
-#    You may obtain a copy of the License at
+#  Copyright 2019 GridGain Systems, Inc. and Contributors.
 #
-#        http://www.apache.org/licenses/LICENSE-2.0
+#  Licensed under the GridGain Community Edition License (the "License");
+#  you may not use this file except in compliance with the License.
+#  You may obtain a copy of the License at
 #
-#    Unless required by applicable law or agreed to in writing, software
-#    distributed under the License is distributed on an "AS IS" BASIS,
-#    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-#    See the License for the specific language governing permissions and
-#    limitations under the License.
+#      https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+#
+#  Unless required by applicable law or agreed to in writing, software
+#  distributed under the License is distributed on an "AS IS" BASIS,
+#  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+#  See the License for the specific language governing permissions and
+#  limitations under the License.
 
 $solutionDir = [System.IO.Path]::GetDirectoryName($dte.Solution.FullName) + "\"
 $path = $installPath.Replace($solutionDir, "`$(SolutionDir)")
diff --git a/modules/platforms/dotnet/Apache.Ignite.Core/NuGet/Uninstall.ps1 b/modules/platforms/dotnet/Apache.Ignite.Core/NuGet/Uninstall.ps1
index 4ec71a8..a05ebda 100644
--- a/modules/platforms/dotnet/Apache.Ignite.Core/NuGet/Uninstall.ps1
+++ b/modules/platforms/dotnet/Apache.Ignite.Core/NuGet/Uninstall.ps1
@@ -1,14 +1,16 @@
-#    Licensed under the Apache License, Version 2.0 (the "License");
-#    you may not use this file except in compliance with the License.
-#    You may obtain a copy of the License at
+#  Copyright 2019 GridGain Systems, Inc. and Contributors.
 #
-#        http://www.apache.org/licenses/LICENSE-2.0
+#  Licensed under the GridGain Community Edition License (the "License");
+#  you may not use this file except in compliance with the License.
+#  You may obtain a copy of the License at
 #
-#    Unless required by applicable law or agreed to in writing, software
-#    distributed under the License is distributed on an "AS IS" BASIS,
-#    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-#    See the License for the specific language governing permissions and
-#    limitations under the License.
+#      https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
+#
+#  Unless required by applicable law or agreed to in writing, software
+#  distributed under the License is distributed on an "AS IS" BASIS,
+#  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+#  See the License for the specific language governing permissions and
+#  limitations under the License.
 
 param($installPath, $toolsPath, $package, $project)
 
diff --git a/modules/platforms/python/pyignite/connection/__init__.py b/modules/platforms/python/pyignite/connection/__init__.py
index 27447d3..30903cc 100644
--- a/modules/platforms/python/pyignite/connection/__init__.py
+++ b/modules/platforms/python/pyignite/connection/__init__.py
@@ -13,20 +13,6 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 #
-# Licensed to the Apache Software Foundation (ASF) under one or more
-# contributor license agreements.  See the NOTICE file distributed with
-# this work for additional information regarding copyright ownership.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
-#
-#      http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
 
 """
 This module contains `Connection` class, that wraps TCP socket handling,
diff --git a/packaging/deb/copyright b/packaging/deb/copyright
index 7a6cacb..e6b8d1e 100644
--- a/packaging/deb/copyright
+++ b/packaging/deb/copyright
@@ -1,12 +1,13 @@
-Licensed under the Apache License, Version 2.0 (the "License");
+Copyright 2019 GridGain Systems, Inc. and Contributors.
+
+Licensed under the GridGain Community Edition License (the "License");
 you may not use this file except in compliance with the License.
 You may obtain a copy of the License at
 
-    http://www.apache.org/licenses/LICENSE-2.0
+    https://www.gridgain.com/products/software/community-edition/gridgain-community-edition-license
 
 Unless required by applicable law or agreed to in writing, software
 distributed under the License is distributed on an "AS IS" BASIS,
 WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 See the License for the specific language governing permissions and
 limitations under the License.
-


[ignite] 12/17: GG-17382 Fixed whitespaces

Posted by am...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

amashenkov pushed a commit to branch gg-17462
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 4173880a1ed55b92b4c00cefbdee9f4f032a0fcb
Author: Alexey Goncharuk <al...@gmail.com>
AuthorDate: Thu Apr 25 11:41:20 2019 +0300

    GG-17382 Fixed whitespaces
---
 assembly/dependencies-apache-ignite-hadoop.xml     |  6 ++---
 assembly/dependencies-apache-ignite-lgpl.xml       |  6 ++---
 assembly/dependencies-apache-ignite.xml            |  6 ++---
 assembly/dependencies-sqlline.xml                  |  6 ++---
 assembly/dependencies-visor-console.xml            |  6 ++---
 assembly/docfiles/tools.js                         |  6 ++---
 assembly/release-apache-ignite-base.xml            |  6 ++---
 assembly/release-apache-ignite-hadoop.xml          |  6 ++---
 assembly/release-apache-ignite-lgpl.xml            |  6 ++---
 assembly/release-apache-ignite.xml                 |  6 ++---
 assembly/release-base.xml                          |  6 ++---
 assembly/release-scala.xml                         |  6 ++---
 assembly/release-yardstick.xml                     |  6 ++---
 assembly/test.xml                                  |  6 ++---
 bin/control.sh                                     |  6 ++---
 bin/ignite-tf.sh                                   |  6 ++---
 bin/ignite.sh                                      |  6 ++---
 bin/igniterouter.sh                                |  6 ++---
 bin/ignitevisorcmd.sh                              |  6 ++---
 bin/include/build-classpath.sh                     |  6 ++---
 bin/include/functions.sh                           |  6 ++---
 bin/include/parseargs.sh                           |  6 ++---
 bin/include/service.sh                             |  6 ++---
 bin/include/setenv.sh                              |  6 ++---
 bin/setup-hadoop.sh                                |  6 ++---
 config/apache-ignite-lgpl/default-config.xml       |  6 ++---
 config/apache-ignite/default-config.xml            |  6 ++---
 config/default-config.xml                          |  6 ++---
 config/example-kube.xml                            |  6 ++---
 config/hadoop/default-config.xml                   |  6 ++---
 config/ignite-log4j.xml                            |  6 ++---
 config/ignite-log4j2.xml                           |  6 ++---
 config/java.util.logging.properties                |  6 ++---
 config/router/default-router.xml                   |  6 ++---
 config/wsl-default-config.xml                      |  6 ++---
 dev-tools/build.gradle                             |  6 ++---
 dev-tools/gradle/wrapper/gradle-wrapper.properties |  6 ++---
 dev-tools/gradlew                                  |  6 ++---
 dev-tools/slurp.sh                                 |  6 ++---
 dev-tools/src/main/groovy/jiraslurp.groovy         |  6 ++---
 doap_Ignite.rdf                                    |  6 ++---
 docker/apache-ignite/Dockerfile                    |  6 ++---
 docker/apache-ignite/run.sh                        |  6 ++---
 docker/web-agent/Dockerfile                        |  6 ++---
 docker/web-console/standalone/Dockerfile           |  6 ++---
 docker/web-console/standalone/docker-entrypoint.sh |  6 ++---
 docker/web-console/standalone/nginx/nginx.conf     |  6 ++---
 .../web-console/standalone/nginx/web-console.conf  |  6 ++---
 .../config/encryption/example-encrypted-store.xml  |  6 ++---
 examples/config/example-cache.xml                  |  6 ++---
 examples/config/example-data-regions.xml           |  6 ++---
 examples/config/example-default.xml                |  6 ++---
 examples/config/example-ignite-ml.xml              |  6 ++---
 examples/config/example-ignite.xml                 |  6 ++---
 examples/config/filesystem/core-site.xml           |  6 ++---
 examples/config/filesystem/example-igfs.xml        |  6 ++---
 .../hibernate/example-hibernate-L2-cache.xml       |  6 ++---
 .../persistentstore/example-persistent-store.xml   |  6 ++---
 examples/config/redis/example-redis.xml            |  6 ++---
 examples/config/servlet/WEB-INF/web.xml            |  6 ++---
 examples/config/spark/example-shared-rdd.xml       |  6 ++---
 examples/memcached/memcached-example.php           |  6 ++---
 examples/pom-standalone-lgpl.xml                   |  6 ++---
 examples/pom-standalone.xml                        |  6 ++---
 examples/pom.xml                                   |  6 ++---
 examples/redis/redis-example.php                   |  6 ++---
 examples/redis/redis-example.py                    |  6 ++---
 examples/rest/http-rest-example.php                |  6 ++---
 .../examples/datagrid/SpatialQueryExample.java     |  6 ++---
 .../hibernate/HibernateL2CacheExample.java         |  6 ++---
 .../ignite/examples/datagrid/hibernate/Post.java   |  6 ++---
 .../ignite/examples/datagrid/hibernate/User.java   |  6 ++---
 .../examples/datagrid/hibernate/package-info.java  |  6 ++---
 .../store/hibernate/CacheHibernatePersonStore.java |  6 ++---
 .../hibernate/CacheHibernateStoreExample.java      |  6 ++---
 .../datagrid/store/hibernate/Person.hbm.xml        |  6 ++---
 .../datagrid/store/hibernate/hibernate.cfg.xml     |  6 ++---
 .../datagrid/store/hibernate/package-info.java     |  6 ++---
 .../misc/schedule/ComputeScheduleExample.java      |  6 ++---
 .../examples/misc/schedule/package-info.java       |  6 ++---
 .../apache/ignite/examples/ExampleNodeStartup.java |  6 ++---
 .../org/apache/ignite/examples/ExamplesUtils.java  |  6 ++---
 .../ComputeClientBinaryTaskExecutionExample.java   |  6 ++---
 .../binary/computegrid/ComputeClientTask.java      |  6 ++---
 .../examples/binary/computegrid/package-info.java  |  6 ++---
 .../datagrid/CacheClientBinaryPutGetExample.java   |  6 ++---
 .../datagrid/CacheClientBinaryQueryExample.java    |  6 ++---
 .../examples/binary/datagrid/package-info.java     |  6 ++---
 .../ignite/examples/binary/package-info.java       |  6 ++---
 .../examples/client/ClientPutGetExample.java       |  6 ++---
 .../examples/cluster/ClusterGroupExample.java      |  6 ++---
 .../ignite/examples/cluster/package-info.java      |  6 ++---
 .../examples/computegrid/ComputeAsyncExample.java  |  6 ++---
 .../computegrid/ComputeBroadcastExample.java       |  6 ++---
 .../computegrid/ComputeCallableExample.java        |  6 ++---
 .../computegrid/ComputeClosureExample.java         |  6 ++---
 .../ComputeContinuousMapperExample.java            |  6 ++---
 .../ComputeFibonacciContinuationExample.java       |  6 ++---
 .../computegrid/ComputeReducerExample.java         |  6 ++---
 .../computegrid/ComputeRunnableExample.java        |  6 ++---
 .../computegrid/ComputeTaskMapExample.java         |  6 ++---
 .../computegrid/ComputeTaskSplitExample.java       |  6 ++---
 .../failover/ComputeFailoverExample.java           |  6 ++---
 .../failover/ComputeFailoverNodeStartup.java       |  6 ++---
 .../computegrid/failover/package-info.java         |  6 ++---
 .../examples/computegrid/montecarlo/Credit.java    |  6 ++---
 .../computegrid/montecarlo/CreditRiskExample.java  |  6 ++---
 .../computegrid/montecarlo/CreditRiskManager.java  |  6 ++---
 .../computegrid/montecarlo/package-info.java       |  6 ++---
 .../ignite/examples/computegrid/package-info.java  |  6 ++---
 .../examples/datagrid/CacheAffinityExample.java    |  6 ++---
 .../ignite/examples/datagrid/CacheApiExample.java  |  6 ++---
 .../examples/datagrid/CacheAsyncApiExample.java    |  6 ++---
 .../datagrid/CacheContinuousAsyncQueryExample.java |  6 ++---
 .../datagrid/CacheContinuousQueryExample.java      |  6 ++---
 ...CacheContinuousQueryWithTransformerExample.java |  6 ++---
 .../datagrid/CacheDataStreamerExample.java         |  6 ++---
 .../datagrid/CacheEntryProcessorExample.java       |  6 ++---
 .../examples/datagrid/CacheEventsExample.java      |  6 ++---
 .../examples/datagrid/CachePutGetExample.java      |  6 ++---
 .../examples/datagrid/CacheQueryExample.java       |  6 ++---
 .../examples/datagrid/CacheTransactionExample.java |  6 ++---
 .../examples/datagrid/DataRegionsExample.java      |  6 ++---
 .../ignite/examples/datagrid/package-info.java     |  6 ++---
 .../starschema/CacheStarSchemaExample.java         |  6 ++---
 .../examples/datagrid/starschema/DimProduct.java   |  6 ++---
 .../examples/datagrid/starschema/DimStore.java     |  6 ++---
 .../examples/datagrid/starschema/FactPurchase.java |  6 ++---
 .../examples/datagrid/starschema/package-info.java |  6 ++---
 .../datagrid/store/CacheLoadOnlyStoreExample.java  |  6 ++---
 .../datagrid/store/auto/CacheAutoStoreExample.java |  6 ++---
 .../examples/datagrid/store/auto/package-info.java |  6 ++---
 .../datagrid/store/jdbc/CacheJdbcPersonStore.java  |  6 ++---
 .../datagrid/store/jdbc/CacheJdbcStoreExample.java |  6 ++---
 .../examples/datagrid/store/jdbc/package-info.java |  6 ++---
 .../examples/datagrid/store/package-info.java      |  6 ++---
 .../store/spring/CacheSpringPersonStore.java       |  6 ++---
 .../store/spring/CacheSpringStoreExample.java      |  6 ++---
 .../datagrid/store/spring/package-info.java        |  6 ++---
 .../datastructures/IgniteAtomicLongExample.java    |  6 ++---
 .../IgniteAtomicReferenceExample.java              |  6 ++---
 .../IgniteAtomicSequenceExample.java               |  6 ++---
 .../datastructures/IgniteAtomicStampedExample.java |  6 ++---
 .../IgniteCountDownLatchExample.java               |  6 ++---
 .../IgniteExecutorServiceExample.java              |  6 ++---
 .../examples/datastructures/IgniteLockExample.java |  6 ++---
 .../datastructures/IgniteQueueExample.java         |  6 ++---
 .../datastructures/IgniteSemaphoreExample.java     |  6 ++---
 .../examples/datastructures/IgniteSetExample.java  |  6 ++---
 .../examples/datastructures/package-info.java      |  6 ++---
 .../examples/encryption/EncryptedCacheExample.java |  6 ++---
 .../ignite/examples/events/EventsExample.java      |  6 ++---
 .../ignite/examples/events/package-info.java       |  6 ++---
 .../apache/ignite/examples/igfs/IgfsExample.java   |  6 ++---
 .../ignite/examples/igfs/IgfsMapReduceExample.java |  6 ++---
 .../ignite/examples/igfs/IgfsNodeStartup.java      |  6 ++---
 .../apache/ignite/examples/igfs/package-info.java  |  6 ++---
 .../examples/messaging/MessagingExample.java       |  6 ++---
 .../messaging/MessagingPingPongExample.java        |  6 ++---
 .../MessagingPingPongListenActorExample.java       |  6 ++---
 .../ignite/examples/messaging/package-info.java    |  6 ++---
 .../misc/client/memcache/MemcacheRestExample.java  |  6 ++---
 .../memcache/MemcacheRestExampleNodeStartup.java   |  6 ++---
 .../misc/client/memcache/package-info.java         |  6 ++---
 .../ignite/examples/misc/client/package-info.java  |  6 ++---
 .../misc/deployment/DeploymentExample.java         |  6 ++---
 .../examples/misc/deployment/package-info.java     |  6 ++---
 .../examples/misc/lifecycle/LifecycleExample.java  |  6 ++---
 .../examples/misc/lifecycle/package-info.java      |  6 ++---
 .../apache/ignite/examples/misc/package-info.java  |  6 ++---
 .../misc/springbean/SpringBeanExample.java         |  6 ++---
 .../examples/misc/springbean/package-info.java     |  6 ++---
 .../examples/misc/springbean/spring-bean.xml       |  6 ++---
 .../ml/TrainingWithBinaryObjectExample.java        |  6 ++---
 .../clustering/CustomersClusterizationExample.java |  6 ++---
 .../ml/clustering/GmmClusterizationExample.java    |  6 ++---
 .../ml/clustering/KMeansClusterizationExample.java |  6 ++---
 .../examples/ml/clustering/package-info.java       |  6 ++---
 .../dataset/AlgorithmSpecificDatasetExample.java   |  6 ++---
 .../ml/dataset/CacheBasedDatasetExample.java       |  6 ++---
 .../ignite/examples/ml/dataset/model/Person.java   |  6 ++---
 .../examples/ml/dataset/model/package-info.java    |  6 ++---
 .../ignite/examples/ml/dataset/package-info.java   |  6 ++---
 .../ignite/examples/ml/genetic/change/Coin.java    |  6 ++---
 .../change/OptimizeMakeChangeFitnessFunction.java  |  6 ++---
 .../change/OptimizeMakeChangeGAExample.java        |  6 ++---
 .../OptimizeMakeChangeTerminateCriteria.java       |  6 ++---
 .../helloworld/HelloWorldFitnessFunction.java      |  6 ++---
 .../ml/genetic/helloworld/HelloWorldGAExample.java | 10 ++++----
 .../helloworld/HelloWorldTerminateCriteria.java    |  6 ++---
 .../ignite/examples/ml/genetic/knapsack/Item.java  |  6 ++---
 .../genetic/knapsack/KnapsackFitnessFunction.java  |  6 ++---
 .../ml/genetic/knapsack/KnapsackGAExample.java     |  6 ++---
 .../knapsack/KnapsackTerminateCriteria.java        |  6 ++---
 .../ignite/examples/ml/genetic/movie/Movie.java    |  6 ++---
 .../ml/genetic/movie/MovieFitnessFunction.java     |  6 ++---
 .../examples/ml/genetic/movie/MovieGAExample.java  |  6 ++---
 .../ml/genetic/movie/MovieTerminateCriteria.java   |  6 ++---
 .../IgniteModelDistributedInferenceExample.java    |  6 ++---
 .../examples/ml/inference/ModelStorageExample.java |  6 ++---
 .../TensorFlowDistributedInferenceExample.java     |  6 ++---
 .../inference/TensorFlowLocalInferenceExample.java |  6 ++---
 .../TensorFlowThreadedInferenceExample.java        |  6 ++---
 .../ignite/examples/ml/inference/package-info.java |  6 ++---
 .../spark/LogRegFromSparkThroughPMMLExample.java   |  6 ++---
 .../modelparser/DecisionTreeFromSparkExample.java  |  6 ++---
 .../DecisionTreeRegressionFromSparkExample.java    |  6 ++---
 .../spark/modelparser/GBTFromSparkExample.java     |  6 ++---
 .../modelparser/GBTRegressionFromSparkExample.java |  6 ++---
 .../spark/modelparser/KMeansFromSparkExample.java  |  6 ++---
 .../LinearRegressionFromSparkExample.java          |  6 ++---
 .../spark/modelparser/LogRegFromSparkExample.java  |  6 ++---
 .../modelparser/RandomForestFromSparkExample.java  |  6 ++---
 .../RandomForestRegressionFromSparkExample.java    |  6 ++---
 .../spark/modelparser/SVMFromSparkExample.java     |  6 ++---
 .../inference/spark/modelparser/package-info.java  |  6 ++---
 .../examples/ml/inference/spark/package-info.java  |  6 ++---
 .../examples/ml/knn/ANNClassificationExample.java  |  6 ++---
 .../examples/ml/knn/IrisClassificationExample.java |  6 ++---
 .../examples/ml/knn/KNNClassificationExample.java  |  6 ++---
 .../examples/ml/knn/KNNRegressionExample.java      |  6 ++---
 .../ignite/examples/ml/knn/package-info.java       |  6 ++---
 .../multiclass/OneVsRestClassificationExample.java |  6 ++---
 .../examples/ml/multiclass/package-info.java       |  6 ++---
 .../DiscreteNaiveBayesTrainerExample.java          |  6 ++---
 .../GaussianNaiveBayesTrainerExample.java          |  6 ++---
 .../examples/ml/naivebayes/package-info.java       |  6 ++---
 .../ignite/examples/ml/nn/MLPTrainerExample.java   |  6 ++---
 .../apache/ignite/examples/ml/nn/package-info.java |  6 ++---
 .../apache/ignite/examples/ml/package-info.java    |  6 ++---
 .../ml/preprocessing/BinarizationExample.java      |  6 ++---
 .../examples/ml/preprocessing/ImputingExample.java |  6 ++---
 .../ml/preprocessing/MaxAbsScalerExample.java      |  6 ++---
 .../ml/preprocessing/MinMaxScalerExample.java      |  6 ++---
 .../ml/preprocessing/NormalizationExample.java     |  6 ++---
 .../ml/preprocessing/StandardScalerExample.java    |  6 ++---
 .../examples/ml/preprocessing/package-info.java    |  6 ++---
 .../linear/BostonHousePricesPredictionExample.java |  6 ++---
 .../linear/LinearRegressionLSQRTrainerExample.java |  6 ++---
 ...gressionLSQRTrainerWithMinMaxScalerExample.java |  6 ++---
 .../linear/LinearRegressionSGDTrainerExample.java  |  6 ++---
 .../ml/regression/linear/package-info.java         |  6 ++---
 .../BaggedLogisticRegressionSGDTrainerExample.java |  6 ++---
 .../regression/logistic/bagged/package-info.java   |  6 ++---
 .../LogisticRegressionSGDTrainerExample.java       |  6 ++---
 .../regression/logistic/binary/package-info.java   |  6 ++---
 .../ml/regression/logistic/package-info.java       |  6 ++---
 .../examples/ml/regression/package-info.java       |  6 ++---
 .../ml/selection/cv/CrossValidationExample.java    |  6 ++---
 .../examples/ml/selection/cv/package-info.java     |  6 ++---
 .../ignite/examples/ml/selection/package-info.java |  6 ++---
 .../ml/selection/scoring/EvaluatorExample.java     |  6 ++---
 .../selection/scoring/MultipleMetricsExample.java  |  6 ++---
 .../selection/scoring/RegressionMetricExample.java |  6 ++---
 .../split/TrainTestDatasetSplitterExample.java     |  6 ++---
 .../examples/ml/selection/split/package-info.java  |  6 ++---
 ...eeClassificationTrainerSQLInferenceExample.java |  6 ++---
 ...onTreeClassificationTrainerSQLTableExample.java |  6 ++---
 .../ignite/examples/ml/sql/package-info.java       |  6 ++---
 .../ml/svm/SVMBinaryClassificationExample.java     |  6 ++---
 .../ignite/examples/ml/svm/package-info.java       |  6 ++---
 .../DecisionTreeClassificationTrainerExample.java  |  6 ++---
 .../tree/DecisionTreeRegressionTrainerExample.java |  6 ++---
 .../examples/ml/tree/FraudDetectionExample.java    |  6 ++---
 .../GDBOnTreesClassificationTrainerExample.java    |  6 ++---
 .../GDBOnTreesRegressionTrainerExample.java        |  6 ++---
 .../examples/ml/tree/boosting/package-info.java    |  6 ++---
 .../ignite/examples/ml/tree/package-info.java      |  6 ++---
 .../RandomForestClassificationExample.java         |  6 ++---
 .../RandomForestRegressionExample.java             |  6 ++---
 .../ml/tree/randomforest/package-info.java         |  6 ++---
 .../ml/tutorial/Step_1_Read_and_Learn.java         |  6 ++---
 .../examples/ml/tutorial/Step_2_Imputing.java      |  6 ++---
 .../examples/ml/tutorial/Step_3_Categorial.java    |  6 ++---
 .../Step_3_Categorial_with_One_Hot_Encoder.java    |  6 ++---
 .../examples/ml/tutorial/Step_4_Add_age_fare.java  |  6 ++---
 .../examples/ml/tutorial/Step_5_Scaling.java       |  6 ++---
 .../ml/tutorial/Step_5_Scaling_with_Pipeline.java  |  6 ++---
 .../ignite/examples/ml/tutorial/Step_6_KNN.java    |  6 ++---
 .../ml/tutorial/Step_7_Split_train_test.java       |  6 ++---
 .../ignite/examples/ml/tutorial/Step_8_CV.java     |  6 ++---
 .../ml/tutorial/Step_8_CV_with_Param_Grid.java     |  6 ++---
 .../Step_8_CV_with_Param_Grid_and_metrics.java     |  6 ++---
 ...V_with_Param_Grid_and_metrics_and_pipeline.java |  6 ++---
 .../ml/tutorial/Step_9_Scaling_With_Stacking.java  |  6 ++---
 .../ignite/examples/ml/tutorial/TitanicUtils.java  |  6 ++---
 .../ml/tutorial/TutorialStepByStepExample.java     |  6 ++---
 .../ignite/examples/ml/tutorial/package-info.java  |  6 ++---
 .../ignite/examples/ml/util/DatasetHelper.java     |  6 ++---
 .../examples/ml/util/MLExamplesCommonArgs.java     |  6 ++---
 .../ParametricVectorGeneratorExample.java          |  6 ++---
 .../util/generators/StandardGeneratorsExample.java |  6 ++---
 .../generators/VectorGeneratorFamilyExample.java   |  6 ++---
 .../VectorGeneratorPrimitivesExample.java          |  6 ++---
 .../examples/ml/util/generators/package-info.java  |  6 ++---
 .../ignite/examples/ml/util/package-info.java      |  6 ++---
 .../ml/xgboost/XGBoostModelParserExample.java      |  6 ++---
 .../ignite/examples/ml/xgboost/package-info.java   |  6 ++---
 .../org/apache/ignite/examples/model/Address.java  |  6 ++---
 .../org/apache/ignite/examples/model/Employee.java |  6 ++---
 .../apache/ignite/examples/model/EmployeeKey.java  |  6 ++---
 .../apache/ignite/examples/model/Organization.java |  6 ++---
 .../ignite/examples/model/OrganizationType.java    |  6 ++---
 .../org/apache/ignite/examples/model/Person.java   |  6 ++---
 .../apache/ignite/examples/model/package-info.java |  6 ++---
 .../org/apache/ignite/examples/package-info.java   |  6 ++---
 .../persistentstore/PersistentStoreExample.java    |  6 ++---
 .../PersistentStoreExampleNodeStartup.java         |  6 ++---
 .../examples/servicegrid/ServicesExample.java      |  6 ++---
 .../examples/servicegrid/SimpleMapService.java     |  6 ++---
 .../examples/servicegrid/SimpleMapServiceImpl.java |  6 ++---
 .../ignite/examples/servicegrid/package-info.java  |  6 ++---
 .../examples/springdata/PersonRepository.java      |  6 ++---
 .../ignite/examples/springdata/SpringAppCfg.java   |  6 ++---
 .../examples/springdata/SpringDataExample.java     |  6 ++---
 .../apache/ignite/examples/sql/SqlDdlExample.java  |  6 ++---
 .../apache/ignite/examples/sql/SqlDmlExample.java  |  6 ++---
 .../ignite/examples/sql/SqlJdbcCopyExample.java    |  6 ++---
 .../apache/ignite/examples/sql/SqlJdbcExample.java |  6 ++---
 .../ignite/examples/sql/SqlQueriesExample.java     |  6 ++---
 .../apache/ignite/examples/sql/package-info.java   |  6 ++---
 .../streaming/StreamTransformerExample.java        |  6 ++---
 .../examples/streaming/StreamVisitorExample.java   |  6 ++---
 .../ignite/examples/streaming/package-info.java    |  6 ++---
 .../examples/streaming/wordcount/CacheConfig.java  |  6 ++---
 .../examples/streaming/wordcount/QueryWords.java   |  6 ++---
 .../examples/streaming/wordcount/StreamWords.java  |  6 ++---
 .../examples/streaming/wordcount/package-info.java |  6 ++---
 .../socket/WordsSocketStreamerClient.java          |  6 ++---
 .../socket/WordsSocketStreamerServer.java          |  6 ++---
 .../streaming/wordcount/socket/package-info.java   |  6 ++---
 .../ignite/examples/util/DbH2ServerStartup.java    |  6 ++---
 .../apache/ignite/examples/util/package-info.java  |  6 ++---
 .../examples/ScalarCacheAffinityExample.scala      |  6 ++---
 .../ScalarCacheEntryProcessorExample.scala         |  6 ++---
 .../scalar/examples/ScalarCacheExample.scala       |  6 ++---
 .../ScalarCachePopularNumbersExample.scala         |  6 ++---
 .../scalar/examples/ScalarCacheQueryExample.scala  |  6 ++---
 .../scalar/examples/ScalarClosureExample.scala     |  6 ++---
 .../examples/ScalarContinuationExample.scala       |  6 ++---
 .../scalar/examples/ScalarCreditRiskExample.scala  |  6 ++---
 .../scalar/examples/ScalarJvmCloudExample.scala    |  6 ++---
 .../scalar/examples/ScalarPingPongExample.scala    |  6 ++---
 .../scalar/examples/ScalarPrimeExample.scala       |  6 ++---
 .../examples/ScalarSnowflakeSchemaExample.scala    |  6 ++---
 .../ignite/scalar/examples/ScalarTaskExample.scala |  6 ++---
 .../examples/ScalarWorldShortestMapReduce.scala    |  6 ++---
 .../examples/spark/ScalarSharedRDDExample.scala    |  6 ++---
 .../examples/ml/mleap/MLeapModelParserExample.java |  6 ++---
 .../ignite/examples/ml/mleap/package-info.java     |  6 ++---
 .../examples/spark/IgniteCatalogExample.scala      |  6 ++---
 .../examples/spark/IgniteDataFrameExample.scala    |  6 ++---
 .../spark/IgniteDataFrameWriteExample.scala        |  6 ++---
 .../examples/spark/JavaIgniteCatalogExample.java   |  8 +++----
 .../examples/spark/JavaIgniteDataFrameExample.java |  6 ++---
 .../spark/JavaIgniteDataFrameWriteExample.java     |  6 ++---
 .../ignite/examples/spark/SharedRDDExample.java    |  6 ++---
 .../apache/ignite/examples/spark/package-info.java |  6 ++---
 .../org/apache/ignite/examples/spark/package.scala |  6 ++---
 .../ComputeScheduleExampleMultiNodeSelfTest.java   |  6 ++---
 .../examples/ComputeScheduleExampleSelfTest.java   |  6 ++---
 .../HibernateL2CacheExampleMultiNodeSelfTest.java  |  6 ++---
 .../examples/HibernateL2CacheExampleSelfTest.java  |  6 ++---
 .../SpatialQueryExampleMultiNodeSelfTest.java      |  6 ++---
 .../examples/SpatialQueryExampleSelfTest.java      |  6 ++---
 .../IgniteLgplExamplesSelfTestSuite.java           |  6 ++---
 .../examples/BasicExamplesMultiNodeSelfTest.java   |  6 ++---
 .../ignite/examples/BasicExamplesSelfTest.java     |  6 ++---
 .../examples/CacheClientBinaryExampleTest.java     |  6 ++---
 .../CacheContinuousQueryExamplesSelfTest.java      |  6 ++---
 .../examples/CacheExamplesMultiNodeSelfTest.java   |  6 ++---
 .../ignite/examples/CacheExamplesSelfTest.java     |  6 ++---
 .../examples/CheckpointExamplesSelfTest.java       |  6 ++---
 .../examples/ClusterGroupExampleSelfTest.java      |  6 ++---
 .../examples/ComputeClientBinaryExampleTest.java   |  6 ++---
 .../ContinuationExamplesMultiNodeSelfTest.java     |  6 ++---
 .../examples/ContinuationExamplesSelfTest.java     |  6 ++---
 .../ContinuousMapperExamplesMultiNodeSelfTest.java |  6 ++---
 .../examples/ContinuousMapperExamplesSelfTest.java |  6 ++---
 .../DeploymentExamplesMultiNodeSelfTest.java       |  6 ++---
 .../examples/DeploymentExamplesSelfTest.java       |  6 ++---
 .../examples/EncryptedCacheExampleSelfTest.java    |  6 ++---
 .../examples/EventsExamplesMultiNodeSelfTest.java  |  6 ++---
 .../ignite/examples/EventsExamplesSelfTest.java    |  6 ++---
 .../ignite/examples/IgfsExamplesSelfTest.java      |  6 ++---
 .../ignite/examples/LifecycleExamplesSelfTest.java |  6 ++---
 .../MemcacheRestExamplesMultiNodeSelfTest.java     |  6 ++---
 .../examples/MemcacheRestExamplesSelfTest.java     |  6 ++---
 .../ignite/examples/MessagingExamplesSelfTest.java |  6 ++---
 .../MonteCarloExamplesMultiNodeSelfTest.java       |  6 ++---
 .../examples/MonteCarloExamplesSelfTest.java       |  6 ++---
 .../examples/SpringBeanExamplesSelfTest.java       |  6 ++---
 .../ignite/examples/SpringDataExampleSelfTest.java |  6 ++---
 .../ignite/examples/SqlExamplesSelfTest.java       |  6 ++---
 .../examples/TaskExamplesMultiNodeSelfTest.java    |  6 ++---
 .../ignite/examples/TaskExamplesSelfTest.java      |  6 ++---
 .../testsuites/IgniteExamplesMLTestSuite.java      |  6 ++---
 .../testsuites/IgniteExamplesSelfTestSuite.java    |  6 ++---
 .../examples/ScalarExamplesMultiNodeSelfTest.scala |  6 ++---
 .../tests/examples/ScalarExamplesSelfTest.scala    |  6 ++---
 .../testsuites/ScalarExamplesSelfTestSuite.scala   |  6 ++---
 .../spark/examples/IgniteDataFrameSelfTest.java    |  6 ++---
 .../examples/JavaIgniteDataFrameSelfTest.java      |  6 ++---
 .../spark/examples/SharedRDDExampleSelfTest.java   |  6 ++---
 .../IgniteExamplesSparkSelfTestSuite.java          |  6 ++---
 ipc/shmem/Makefile.am                              |  6 ++---
 ipc/shmem/igniteshmem/Makefile.am                  |  6 ++---
 ...nternal_util_ipc_shmem_IpcSharedMemoryUtils.cpp |  6 ++---
 ipc/shmem/include/Makefile.am                      |  6 ++---
 modules/aop/pom.xml                                |  6 ++---
 .../gridify/aop/aspectj/GridifyAspectJAspect.java  |  6 ++---
 .../aop/aspectj/GridifySetToSetAspectJAspect.java  |  6 ++---
 .../aspectj/GridifySetToValueAspectJAspect.java    |  6 ++---
 .../compute/gridify/aop/aspectj/package-info.java  |  6 ++---
 .../aop/spring/GridifySetToSetSpringAspect.java    |  6 ++---
 .../aop/spring/GridifySetToValueSpringAspect.java  |  6 ++---
 .../gridify/aop/spring/GridifySpringAspect.java    |  6 ++---
 .../gridify/aop/spring/GridifySpringEnhancer.java  |  6 ++---
 .../gridify/aop/spring/GridifySpringPointcut.java  |  6 ++---
 .../compute/gridify/aop/spring/package-info.java   |  6 ++---
 .../src/test/config/aop/aspectj/META-INF/aop.xml   |  6 ++---
 .../org/apache/ignite/gridify/AbstractAopTest.java |  6 ++---
 .../apache/ignite/gridify/BasicAopSelfTest.java    |  6 ++---
 .../ignite/gridify/GridifySetToSetTarget.java      |  6 ++---
 .../gridify/GridifySetToSetTargetInterface.java    |  6 ++---
 .../ignite/gridify/GridifySetToValueTarget.java    |  6 ++---
 .../gridify/GridifySetToValueTargetInterface.java  |  6 ++---
 .../GridifySetToXXXNonSpringAopSelfTest.java       |  6 ++---
 .../gridify/GridifySetToXXXSpringAopSelfTest.java  |  6 ++---
 .../ignite/gridify/NonSpringAopSelfTest.java       |  6 ++---
 .../apache/ignite/gridify/SpringAopSelfTest.java   |  6 ++---
 .../org/apache/ignite/gridify/TestAopTarget.java   |  6 ++---
 .../ignite/gridify/TestAopTargetInterface.java     |  6 ++---
 .../ignite/gridify/TestGridifyException.java       |  6 ++---
 .../org/apache/ignite/gridify/TestGridifyJob.java  |  6 ++---
 .../org/apache/ignite/gridify/TestGridifyTask.java |  6 ++---
 .../gridify/hierarchy/GridifyHierarchyTest.java    |  6 ++---
 .../ignite/gridify/hierarchy/SuperTarget.java      |  6 ++---
 .../apache/ignite/gridify/hierarchy/Target.java    |  6 ++---
 .../ignite/gridify/hierarchy/package-info.java     |  6 ++---
 .../org/apache/ignite/gridify/package-info.java    |  6 ++---
 .../apache/ignite/gridify/test_resource.properties |  6 ++---
 .../optimized/OptimizedMarshallerAopTest.java      |  6 ++---
 .../org/apache/ignite/p2p/P2PGridifySelfTest.java  |  6 ++---
 .../ignite/testsuites/IgniteAopSelfTestSuite.java  |  6 ++---
 .../singlesplit/SingleSplitTestJobTarget.java      |  6 ++---
 .../direct/singlesplit/SingleSplitTestTask.java    |  6 ++---
 .../direct/singlesplit/SingleSplitsLoadTest.java   |  6 ++---
 .../loadtests/direct/singlesplit/package-info.java |  6 ++---
 .../gridify/GridifyLoadTestJobTarget.java          |  6 ++---
 .../loadtests/gridify/GridifyLoadTestTask.java     |  6 ++---
 .../gridify/GridifySingleSplitLoadTest.java        |  6 ++---
 .../java/org/test/gridify/ExternalAopTarget.java   |  6 ++---
 .../org/test/gridify/ExternalGridifyException.java |  6 ++---
 .../java/org/test/gridify/ExternalGridifyTask.java |  6 ++---
 .../test/gridify/ExternalNonSpringAopSelfTest.java |  6 ++---
 .../test/java/org/test/gridify/package-info.java   |  6 ++---
 .../java/org/test/gridify/test_resource.properties |  6 ++---
 modules/apache-license-gen/pom.xml                 |  6 ++---
 modules/aws/pom.xml                                |  6 ++---
 .../ignite/spi/checkpoint/s3/S3CheckpointData.java |  6 ++---
 .../ignite/spi/checkpoint/s3/S3CheckpointSpi.java  |  6 ++---
 .../spi/checkpoint/s3/S3CheckpointSpiMBean.java    |  6 ++---
 .../ignite/spi/checkpoint/s3/S3TimeData.java       |  6 ++---
 .../ignite/spi/checkpoint/s3/package-info.java     |  6 ++---
 .../tcp/ipfinder/elb/TcpDiscoveryElbIpFinder.java  |  6 ++---
 .../discovery/tcp/ipfinder/elb/package-info.java   |  6 ++---
 .../tcp/ipfinder/s3/TcpDiscoveryS3IpFinder.java    |  6 ++---
 .../s3/encrypt/AsymmetricKeyEncryptionService.java |  6 ++---
 .../s3/encrypt/AwsKmsEncryptionService.java        |  6 ++---
 .../tcp/ipfinder/s3/encrypt/EncryptionService.java |  6 ++---
 .../s3/encrypt/SymmetricKeyEncryptionService.java  |  6 ++---
 .../tcp/ipfinder/s3/encrypt/package-info.java      |  6 ++---
 .../discovery/tcp/ipfinder/s3/package-info.java    |  6 ++---
 .../checkpoint/s3/S3CheckpointManagerSelfTest.java |  6 ++---
 .../s3/S3CheckpointSpiConfigSelfTest.java          |  6 ++---
 .../spi/checkpoint/s3/S3CheckpointSpiSelfTest.java |  6 ++---
 ...eckpointSpiStartStopBucketEndpointSelfTest.java |  6 ++---
 ...CheckpointSpiStartStopSSEAlgorithmSelfTest.java |  6 ++---
 .../s3/S3CheckpointSpiStartStopSelfTest.java       |  6 ++---
 .../checkpoint/s3/S3SessionCheckpointSelfTest.java |  6 ++---
 .../ignite/spi/checkpoint/s3/package-info.java     |  6 ++---
 .../elb/TcpDiscoveryElbIpFinderSelfTest.java       |  6 ++---
 .../discovery/tcp/ipfinder/elb/package-info.java   |  6 ++---
 .../s3/TcpDiscoveryS3IpFinderAbstractSelfTest.java |  6 ++---
 ...ryS3IpFinderAwsCredentialsProviderSelfTest.java |  6 ++---
 ...pDiscoveryS3IpFinderAwsCredentialsSelfTest.java |  6 ++---
 ...pDiscoveryS3IpFinderBucketEndpointSelfTest.java |  6 ++---
 ...veryS3IpFinderClientSideEncryptionSelfTest.java |  6 ++---
 .../TcpDiscoveryS3IpFinderKeyPrefixSelfTest.java   |  6 ++---
 ...TcpDiscoveryS3IpFinderSSEAlgorithmSelfTest.java |  6 ++---
 .../tcp/ipfinder/s3/client/DummyObjectListing.java |  6 ++---
 .../ipfinder/s3/client/DummyObjectListingTest.java |  6 ++---
 .../tcp/ipfinder/s3/client/DummyS3Client.java      |  6 ++---
 .../tcp/ipfinder/s3/client/DummyS3ClientTest.java  |  6 ++---
 .../tcp/ipfinder/s3/client/package-info.java       |  6 ++---
 .../AsymmetricKeyEncryptionServiceTest.java        |  6 ++---
 .../s3/encrypt/AwsKmsEncryptionServiceTest.java    |  6 ++---
 .../ipfinder/s3/encrypt/MockEncryptionService.java |  6 ++---
 .../s3/encrypt/MockEncryptionServiceTest.java      |  6 ++---
 .../encrypt/SymmetricKeyEncryptionServiceTest.java |  6 ++---
 .../tcp/ipfinder/s3/encrypt/package-info.java      |  6 ++---
 .../discovery/tcp/ipfinder/s3/package-info.java    |  6 ++---
 .../ignite/testsuites/IgniteElbTestSuite.java      |  6 ++---
 .../ignite/testsuites/IgniteS3TestSuite.java       |  6 ++---
 modules/benchmarks/pom.xml                         |  6 ++---
 .../benchmarks/jmh/JmhAbstractBenchmark.java       |  6 ++---
 .../internal/benchmarks/jmh/algo/BenchmarkCRC.java |  6 ++---
 .../jmh/cache/JmhCacheAbstractBenchmark.java       |  6 ++---
 .../benchmarks/jmh/cache/JmhCacheBenchmark.java    |  6 ++---
 .../jmh/cache/JmhCacheLocksBenchmark.java          |  6 ++---
 .../SmallHashSetsVsReadOnlyViewBenchmark.java      |  6 ++---
 .../JmhKeystoreEncryptionSpiBenchmark.java         |  6 ++---
 .../jmh/future/JmhFutureAdapterBenchmark.java      |  6 ++---
 .../GridDhtPartitionsStateValidatorBenchmark.java  |  6 ++---
 .../benchmarks/jmh/misc/JmhIncrementBenchmark.java |  6 ++---
 .../jmh/notify/JmhParkVsNotifyBenchmark.java       |  6 ++---
 .../jmh/notify/JmhWaitStategyBenchmark.java        |  6 ++---
 .../jmh/runner/JmhIdeBenchmarkRunner.java          |  6 ++---
 .../jmh/sequence/JmhSequenceBenchmark.java         |  6 ++---
 .../jmh/streamer/JmhStreamerAddDataBenchmark.java  |  6 ++---
 .../benchmarks/jmh/tree/BPlusTreeBenchmark.java    |  6 ++---
 .../jol/GridAffinityAssignmentJolBenchmark.java    |  6 ++---
 .../ignite/internal/benchmarks/model/IntValue.java |  6 ++---
 .../ignite/internal/benchmarks/model/Node.java     |  6 ++---
 modules/camel/pom.xml                              |  6 ++---
 .../apache/ignite/stream/camel/CamelStreamer.java  |  6 ++---
 .../apache/ignite/stream/camel/package-info.java   |  6 ++---
 .../stream/camel/IgniteCamelStreamerTest.java      |  6 ++---
 .../stream/camel/IgniteCamelStreamerTestSuite.java |  6 ++---
 .../apache/ignite/stream/camel/package-info.java   |  6 ++---
 .../camel/src/test/resources/camel.test.properties |  6 ++---
 modules/cassandra/pom.xml                          |  6 ++---
 modules/cassandra/serializers/pom.xml              |  6 ++---
 .../store/cassandra/serializer/KryoSerializer.java |  6 ++---
 .../store/cassandra/serializer/package-info.java   |  6 ++---
 .../apache/ignite/tests/KryoSerializerTest.java    |  6 ++---
 .../test/java/org/apache/ignite/tests/MyPojo.java  |  6 ++---
 modules/cassandra/store/pom.xml                    |  6 ++---
 .../cache/store/cassandra/CassandraCacheStore.java |  6 ++---
 .../cassandra/CassandraCacheStoreFactory.java      |  6 ++---
 .../store/cassandra/common/CassandraHelper.java    |  6 ++---
 .../cassandra/common/PropertyMappingHelper.java    |  6 ++---
 .../store/cassandra/common/RandomSleeper.java      |  6 ++---
 .../cache/store/cassandra/common/SystemHelper.java |  6 ++---
 .../cache/store/cassandra/common/package-info.java |  6 ++---
 .../store/cassandra/datasource/Credentials.java    |  6 ++---
 .../store/cassandra/datasource/DataSource.java     |  6 ++---
 .../cassandra/datasource/PlainCredentials.java     |  6 ++---
 .../store/cassandra/datasource/package-info.java   |  6 ++---
 .../ignite/cache/store/cassandra/package-info.java |  6 ++---
 .../persistence/KeyPersistenceSettings.java        |  6 ++---
 .../persistence/KeyValuePersistenceSettings.java   |  6 ++---
 .../persistence/PersistenceController.java         |  6 ++---
 .../cassandra/persistence/PersistenceSettings.java |  6 ++---
 .../cassandra/persistence/PersistenceStrategy.java |  6 ++---
 .../store/cassandra/persistence/PojoField.java     |  6 ++---
 .../cassandra/persistence/PojoFieldAccessor.java   |  6 ++---
 .../store/cassandra/persistence/PojoKeyField.java  |  6 ++---
 .../cassandra/persistence/PojoValueField.java      |  6 ++---
 .../persistence/ValuePersistenceSettings.java      |  6 ++---
 .../store/cassandra/persistence/package-info.java  |  6 ++---
 .../store/cassandra/serializer/JavaSerializer.java |  6 ++---
 .../store/cassandra/serializer/Serializer.java     |  6 ++---
 .../store/cassandra/serializer/package-info.java   |  6 ++---
 .../cassandra/session/BatchExecutionAssistant.java |  6 ++---
 .../cassandra/session/BatchLoaderAssistant.java    |  6 ++---
 .../store/cassandra/session/CassandraSession.java  |  6 ++---
 .../cassandra/session/CassandraSessionImpl.java    |  6 ++---
 .../cassandra/session/ExecutionAssistant.java      |  6 ++---
 .../session/GenericBatchExecutionAssistant.java    |  6 ++---
 .../session/LoadCacheCustomQueryWorker.java        |  6 ++---
 .../session/WrappedPreparedStatement.java          |  6 ++---
 .../store/cassandra/session/WrappedSession.java    |  6 ++---
 .../store/cassandra/session/package-info.java      |  6 ++---
 .../store/cassandra/session/pool/IdleSession.java  |  6 ++---
 .../store/cassandra/session/pool/SessionPool.java  |  6 ++---
 .../store/cassandra/session/pool/package-info.java |  6 ++---
 .../session/transaction/BaseMutation.java          |  6 ++---
 .../session/transaction/DeleteMutation.java        |  6 ++---
 .../cassandra/session/transaction/Mutation.java    |  6 ++---
 .../session/transaction/WriteMutation.java         |  6 ++---
 .../session/transaction/package-info.java          |  6 ++---
 .../cache/store/cassandra/utils/DDLGenerator.java  |  6 ++---
 .../cache/store/cassandra/utils/package-info.java  |  6 ++---
 .../bootstrap/aws/cassandra/cassandra-bootstrap.sh |  6 ++---
 .../test/bootstrap/aws/cassandra/cassandra-env.sh  |  6 ++---
 .../bootstrap/aws/cassandra/cassandra-start.sh     |  6 ++---
 .../aws/cassandra/cassandra-template.yaml          | 14 +++++------
 .../store/src/test/bootstrap/aws/common.sh         |  6 ++---
 .../cassandra/store/src/test/bootstrap/aws/env.sh  |  6 ++---
 .../src/test/bootstrap/aws/ganglia/agent-start.sh  |  6 ++---
 .../bootstrap/aws/ganglia/ganglia-bootstrap.sh     |  6 ++---
 .../test/bootstrap/aws/ignite/ignite-bootstrap.sh  |  6 ++---
 .../ignite/ignite-cassandra-server-template.xml    |  6 ++---
 .../src/test/bootstrap/aws/ignite/ignite-env.sh    |  6 ++---
 .../src/test/bootstrap/aws/ignite/ignite-start.sh  |  6 ++---
 .../store/src/test/bootstrap/aws/logs-collector.sh |  6 ++---
 .../aws/tests/ignite-cassandra-client-template.xml |  6 ++---
 .../test/bootstrap/aws/tests/tests-bootstrap.sh    |  6 ++---
 .../src/test/bootstrap/aws/tests/tests-manager.sh  |  6 ++---
 .../src/test/bootstrap/aws/tests/tests-report.sh   |  6 ++---
 .../apache/ignite/tests/CassandraConfigTest.java   |  6 ++---
 .../tests/CassandraDirectPersistenceLoadTest.java  |  6 ++---
 .../tests/CassandraDirectPersistenceTest.java      |  6 ++---
 .../apache/ignite/tests/CassandraLocalServer.java  |  6 ++---
 .../ignite/tests/CassandraSessionImplTest.java     | 28 +++++++++++-----------
 .../org/apache/ignite/tests/DDLGeneratorTest.java  |  6 ++---
 .../ignite/tests/DatasourceSerializationTest.java  |  6 ++---
 .../tests/IgnitePersistentStoreLoadTest.java       |  6 ++---
 .../ignite/tests/IgnitePersistentStoreTest.java    |  6 ++---
 .../tests/LoadTestsCassandraArtifactsCreator.java  |  6 ++---
 .../org/apache/ignite/tests/load/Generator.java    |  6 ++---
 .../org/apache/ignite/tests/load/IntGenerator.java |  6 ++---
 .../apache/ignite/tests/load/LoadTestDriver.java   |  6 ++---
 .../apache/ignite/tests/load/LongGenerator.java    |  6 ++---
 .../apache/ignite/tests/load/PersonGenerator.java  |  6 ++---
 .../ignite/tests/load/PersonIdGenerator.java       |  6 ++---
 .../apache/ignite/tests/load/StringGenerator.java  |  6 ++---
 .../java/org/apache/ignite/tests/load/Worker.java  |  6 ++---
 .../tests/load/cassandra/BulkReadWorker.java       |  6 ++---
 .../tests/load/cassandra/BulkWriteWorker.java      |  6 ++---
 .../ignite/tests/load/cassandra/ReadWorker.java    |  6 ++---
 .../ignite/tests/load/cassandra/WriteWorker.java   |  6 ++---
 .../ignite/tests/load/cassandra/package-info.java  |  6 ++---
 .../ignite/tests/load/ignite/BulkReadWorker.java   |  6 ++---
 .../ignite/tests/load/ignite/BulkWriteWorker.java  |  6 ++---
 .../ignite/tests/load/ignite/ReadWorker.java       |  6 ++---
 .../ignite/tests/load/ignite/WriteWorker.java      |  6 ++---
 .../ignite/tests/load/ignite/package-info.java     |  6 ++---
 .../org/apache/ignite/tests/load/package-info.java |  6 ++---
 .../java/org/apache/ignite/tests/package-info.java |  6 ++---
 .../java/org/apache/ignite/tests/pojos/Person.java |  6 ++---
 .../org/apache/ignite/tests/pojos/PersonId.java    |  6 ++---
 .../org/apache/ignite/tests/pojos/Product.java     |  6 ++---
 .../apache/ignite/tests/pojos/ProductOrder.java    |  6 ++---
 .../apache/ignite/tests/pojos/SimplePerson.java    |  6 ++---
 .../apache/ignite/tests/pojos/SimplePersonId.java  |  6 ++---
 .../apache/ignite/tests/pojos/package-info.java    |  6 ++---
 .../ignite/tests/utils/CacheStoreHelper.java       |  6 ++---
 .../tests/utils/CassandraAdminCredentials.java     |  6 ++---
 .../apache/ignite/tests/utils/CassandraHelper.java |  6 ++---
 .../ignite/tests/utils/CassandraLifeCycleBean.java |  6 ++---
 .../tests/utils/CassandraRegularCredentials.java   |  6 ++---
 .../ignite/tests/utils/TestCacheSession.java       |  6 ++---
 .../apache/ignite/tests/utils/TestTransaction.java |  6 ++---
 .../org/apache/ignite/tests/utils/TestsHelper.java |  6 ++---
 .../apache/ignite/tests/utils/package-info.java    |  6 ++---
 .../store/IgniteCassandraStoreTestSuite.java       |  6 ++---
 .../testsuites/cassandra/store/package-info.java   |  6 ++---
 .../store/src/test/resources/log4j.properties      |  6 ++---
 .../ignite/tests/cassandra/connection-settings.xml |  6 ++---
 .../ignite/tests/cassandra/connection.properties   |  6 ++---
 .../ignite/tests/cassandra/credentials.properties  |  6 ++---
 .../ignite/tests/cassandra/embedded-cassandra.yaml |  6 ++---
 .../ignite/tests/cassandra/keyspaces.properties    |  6 ++---
 .../tests/persistence/blob/ignite-config.xml       |  6 ++---
 .../persistence/blob/persistence-settings-1.xml    |  6 ++---
 .../persistence/blob/persistence-settings-2.xml    |  6 ++---
 .../persistence/blob/persistence-settings-3.xml    |  6 ++---
 .../persistence/loadall_blob/ignite-config.xml     |  6 ++---
 .../loadall_blob/persistence-settings.xml          |  6 ++---
 .../tests/persistence/pojo/ignite-config.xml       |  6 ++---
 .../apache/ignite/tests/persistence/pojo/order.xml |  6 ++---
 .../persistence/pojo/persistence-settings-1.xml    |  6 ++---
 .../persistence/pojo/persistence-settings-2.xml    |  6 ++---
 .../persistence/pojo/persistence-settings-3.xml    |  6 ++---
 .../persistence/pojo/persistence-settings-4.xml    |  6 ++---
 .../persistence/pojo/persistence-settings-5.xml    |  6 ++---
 .../persistence/pojo/persistence-settings-6.xml    |  6 ++---
 .../ignite/tests/persistence/pojo/product.xml      |  6 ++---
 .../tests/persistence/primitive/ignite-config.xml  |  6 ++---
 .../primitive/ignite-remote-client-config.xml      |  6 ++---
 .../primitive/ignite-remote-server-config.xml      |  6 ++---
 .../primitive/persistence-settings-1.xml           |  6 ++---
 .../primitive/persistence-settings-2.xml           |  6 ++---
 .../store/src/test/resources/tests.properties      |  6 ++---
 .../store/src/test/scripts/cassandra-load-tests.sh |  6 ++---
 .../store/src/test/scripts/ignite-load-tests.sh    |  6 ++---
 .../cassandra/store/src/test/scripts/jvm-opt.sh    |  6 ++---
 .../test/scripts/recreate-cassandra-artifacts.sh   |  6 ++---
 .../clients/config/grid-client-config.properties   |  6 ++---
 .../clients/config/grid-client-spring-config.xml   |  6 ++---
 modules/clients/php/src/GridClient.php             |  6 ++---
 modules/clients/php/src/GridClientCompute.php      |  6 ++---
 .../clients/php/src/GridClientComputeBalancer.php  |  6 ++---
 modules/clients/php/src/GridClientData.php         |  6 ++---
 modules/clients/php/src/GridClientDataAffinity.php |  6 ++---
 modules/clients/php/src/GridClientNode.php         |  6 ++---
 modules/clients/php/src/GridClientNodeFilter.php   |  6 ++---
 modules/clients/pom.xml                            |  6 ++---
 modules/clients/src/test/bin/start-nodes-ssh.sh    |  6 ++---
 modules/clients/src/test/bin/start-nodes.sh        |  6 ++---
 modules/clients/src/test/bin/stop-nodes.sh         |  6 ++---
 .../clients/src/test/config/jdbc-bin-config.xml    |  6 ++---
 .../src/test/config/jdbc-config-cache-store.xml    |  6 ++---
 modules/clients/src/test/config/jdbc-config.xml    |  6 ++---
 .../internal/TaskEventSubjectIdSelfTest.java       |  6 ++---
 .../ClientAbstractMultiThreadedSelfTest.java       |  6 ++---
 .../client/ClientDefaultCacheSelfTest.java         |  6 ++---
 .../internal/client/ClientGetAffinityTask.java     |  6 ++---
 .../ignite/internal/client/ClientHttpTask.java     |  6 ++---
 .../ignite/internal/client/ClientNodeStartup.java  |  6 ++---
 .../client/ClientReconnectionSelfTest.java         |  6 ++---
 .../internal/client/ClientSslNodeStartup.java      |  6 ++---
 .../internal/client/ClientSslParametersTest.java   |  6 ++---
 .../internal/client/ClientStartNodeTask.java       |  6 ++---
 .../ignite/internal/client/ClientStopNodeTask.java |  6 ++---
 .../internal/client/ClientStringLengthTask.java    |  6 ++---
 .../client/ClientTcpMultiThreadedSelfTest.java     |  6 ++---
 .../client/ClientTcpSslAuthenticationSelfTest.java |  6 ++---
 .../client/ClientTcpSslMultiThreadedSelfTest.java  |  6 ++---
 .../ignite/internal/client/ClientTcpTask.java      |  6 ++---
 ...pTaskExecutionAfterTopologyRestartSelfTest.java |  6 ++---
 .../internal/client/ClientTestRestServer.java      |  6 ++---
 .../ignite/internal/client/HashMapStore.java       |  6 ++---
 .../ignite/internal/client/SleepTestTask.java      |  6 ++---
 .../internal/client/TaskSingleJobSplitAdapter.java |  6 ++---
 .../client/impl/ClientCacheFlagsCodecTest.java     |  6 ++---
 .../client/impl/ClientComputeImplSelfTest.java     |  6 ++---
 .../client/impl/ClientDataImplSelfTest.java        |  6 ++---
 .../client/impl/ClientFutureAdapterSelfTest.java   |  6 ++---
 .../ClientPropertiesConfigurationSelfTest.java     |  6 ++---
 .../ClientAbstractConnectivitySelfTest.java        |  6 ++---
 .../ClientAbstractMultiNodeSelfTest.java           |  6 ++---
 .../client/integration/ClientAbstractSelfTest.java |  6 ++---
 .../integration/ClientPreferDirectSelfTest.java    |  6 ++---
 .../integration/ClientTcpConnectivitySelfTest.java |  6 ++---
 .../ClientTcpDirectMultiNodeSelfTest.java          |  6 ++---
 .../integration/ClientTcpDirectSelfTest.java       |  6 ++---
 .../integration/ClientTcpMultiNodeSelfTest.java    |  6 ++---
 .../client/integration/ClientTcpSelfTest.java      |  6 ++---
 .../ClientTcpSslDirectMultiNodeSelfTest.java       |  6 ++---
 .../integration/ClientTcpSslDirectSelfTest.java    |  6 ++---
 .../integration/ClientTcpSslMultiNodeSelfTest.java |  6 ++---
 .../client/integration/ClientTcpSslSelfTest.java   |  6 ++---
 .../ClientTcpUnreachableMultiNodeSelfTest.java     |  6 ++---
 .../client/router/ClientFailedInitSelfTest.java    |  6 ++---
 .../client/router/RouterFactorySelfTest.java       |  6 ++---
 .../client/router/TcpRouterAbstractSelfTest.java   |  6 ++---
 .../client/router/TcpRouterMultiNodeSelfTest.java  |  6 ++---
 .../internal/client/router/TcpRouterSelfTest.java  |  6 ++---
 .../client/router/TcpSslRouterSelfTest.java        |  6 ++---
 .../client/suite/IgniteClientTestSuite.java        |  6 ++---
 .../internal/client/util/ClientByteUtilsTest.java  |  6 ++---
 .../client/util/ClientConsistentHashSelfTest.java  |  6 ++---
 .../client/util/ClientJavaHasherSelfTest.java      |  6 ++---
 .../jdbc2/JdbcAbstractDmlStatementSelfTest.java    |  6 ++---
 .../internal/jdbc2/JdbcAbstractSchemaCaseTest.java |  6 ++---
 .../jdbc2/JdbcAbstractUpdateStatementSelfTest.java |  6 ++---
 ...dbcBinaryMarshallerInsertStatementSelfTest.java |  6 ++---
 ...JdbcBinaryMarshallerMergeStatementSelfTest.java |  6 ++---
 .../apache/ignite/internal/jdbc2/JdbcBlobTest.java |  6 ++---
 .../internal/jdbc2/JdbcBulkLoadSelfTest.java       |  6 ++---
 .../internal/jdbc2/JdbcComplexQuerySelfTest.java   |  6 ++---
 .../internal/jdbc2/JdbcConnectionReopenTest.java   |  6 ++---
 .../internal/jdbc2/JdbcConnectionSelfTest.java     |  6 ++---
 .../jdbc2/JdbcDeleteStatementSelfTest.java         |  6 ++---
 .../jdbc2/JdbcDistributedJoinsQueryTest.java       |  6 ++---
 .../jdbc2/JdbcDynamicIndexAbstractSelfTest.java    |  6 ++---
 ...cDynamicIndexAtomicPartitionedNearSelfTest.java |  6 ++---
 .../JdbcDynamicIndexAtomicPartitionedSelfTest.java |  6 ++---
 .../JdbcDynamicIndexAtomicReplicatedSelfTest.java  |  6 ++---
 ...cIndexTransactionalPartitionedNearSelfTest.java |  6 ++---
 ...namicIndexTransactionalPartitionedSelfTest.java |  6 ++---
 ...ynamicIndexTransactionalReplicatedSelfTest.java |  6 ++---
 .../internal/jdbc2/JdbcEmptyCacheSelfTest.java     |  6 ++---
 .../ignite/internal/jdbc2/JdbcErrorsSelfTest.java  |  6 ++---
 .../jdbc2/JdbcInsertStatementSelfTest.java         |  6 ++---
 .../internal/jdbc2/JdbcLocalCachesSelfTest.java    |  6 ++---
 .../internal/jdbc2/JdbcMergeStatementSelfTest.java |  6 ++---
 .../internal/jdbc2/JdbcMetadataSelfTest.java       |  6 ++---
 .../jdbc2/JdbcNoCacheStreamingSelfTest.java        |  6 ++---
 .../internal/jdbc2/JdbcNoDefaultCacheTest.java     |  6 ++---
 .../jdbc2/JdbcPreparedStatementSelfTest.java       |  6 ++---
 .../internal/jdbc2/JdbcResultSetSelfTest.java      |  6 ++---
 .../internal/jdbc2/JdbcSchemaCaseSelfTest.java     |  6 ++---
 .../ignite/internal/jdbc2/JdbcSpringSelfTest.java  |  6 ++---
 .../jdbc2/JdbcStatementBatchingSelfTest.java       |  6 ++---
 .../internal/jdbc2/JdbcStatementSelfTest.java      |  6 ++---
 .../internal/jdbc2/JdbcStreamingSelfTest.java      |  6 ++---
 .../jdbc2/JdbcStreamingToPublicCacheTest.java      |  6 ++---
 .../jdbc2/JdbcUpdateStatementSelfTest.java         |  6 ++---
 .../rest/AbstractRestProcessorSelfTest.java        |  6 ++---
 .../rest/ChangeStateCommandHandlerTest.java        |  6 ++---
 .../rest/ClientMemcachedProtocolSelfTest.java      |  6 ++---
 .../rest/JettyRestProcessorAbstractSelfTest.java   |  6 ++---
 ...ttyRestProcessorAuthenticationAbstractTest.java |  6 ++---
 ...stProcessorAuthenticationWithCredsSelfTest.java |  6 ++---
 ...stProcessorAuthenticationWithTokenSelfTest.java |  6 ++---
 .../rest/JettyRestProcessorBaselineSelfTest.java   |  6 ++---
 .../rest/JettyRestProcessorCommonSelfTest.java     |  6 ++---
 .../rest/JettyRestProcessorGetAllAsArrayTest.java  |  6 ++---
 .../rest/JettyRestProcessorSignedSelfTest.java     |  6 ++---
 .../rest/JettyRestProcessorUnsignedSelfTest.java   |  6 ++---
 .../rest/RestBinaryProtocolSelfTest.java           |  6 ++---
 .../rest/RestMemcacheProtocolSelfTest.java         |  6 ++---
 .../rest/RestProcessorMultiStartSelfTest.java      |  6 ++---
 .../rest/RestProcessorStartSelfTest.java           |  6 ++---
 .../internal/processors/rest/SimplePerson.java     |  6 ++---
 .../rest/TaskCommandHandlerSelfTest.java           |  6 ++---
 .../rest/TcpRestUnmarshalVulnerabilityTest.java    |  6 ++---
 .../internal/processors/rest/TestBinaryClient.java |  6 ++---
 .../processors/rest/TestMemcacheClient.java        |  6 ++---
 .../ignite/internal/processors/rest/TestTask1.java |  6 ++---
 .../ignite/internal/processors/rest/TestTask2.java |  6 ++---
 .../rest/protocols/tcp/MockNioSession.java         |  6 ++---
 .../rest/protocols/tcp/TcpRestParserSelfTest.java  |  6 ++---
 .../tcp/redis/RedisCommonAbstractTest.java         |  6 ++---
 .../tcp/redis/RedisProtocolConnectSelfTest.java    |  6 ++---
 .../tcp/redis/RedisProtocolGetAllAsArrayTest.java  |  6 ++---
 .../tcp/redis/RedisProtocolServerSelfTest.java     |  6 ++---
 ...ProtocolStringAtomicDatastructuresSelfTest.java |  6 ++---
 .../tcp/redis/RedisProtocolStringSelfTest.java     |  6 ++---
 .../ignite/jdbc/AbstractJdbcPojoQuerySelfTest.java |  6 ++---
 .../ignite/jdbc/JdbcComplexQuerySelfTest.java      |  6 ++---
 .../apache/ignite/jdbc/JdbcConnectionSelfTest.java |  6 ++---
 .../ignite/jdbc/JdbcDefaultNoOpCacheTest.java      |  6 ++---
 .../apache/ignite/jdbc/JdbcEmptyCacheSelfTest.java |  6 ++---
 .../ignite/jdbc/JdbcErrorsAbstractSelfTest.java    |  6 ++---
 .../ignite/jdbc/JdbcLocalCachesSelfTest.java       |  6 ++---
 .../apache/ignite/jdbc/JdbcMetadataSelfTest.java   |  6 ++---
 .../apache/ignite/jdbc/JdbcNoDefaultCacheTest.java |  6 ++---
 .../ignite/jdbc/JdbcPojoLegacyQuerySelfTest.java   |  6 ++---
 .../apache/ignite/jdbc/JdbcPojoQuerySelfTest.java  |  6 ++---
 .../ignite/jdbc/JdbcPreparedStatementSelfTest.java |  6 ++---
 .../apache/ignite/jdbc/JdbcResultSetSelfTest.java  |  6 ++---
 .../apache/ignite/jdbc/JdbcStatementSelfTest.java  |  6 ++---
 .../ignite/jdbc/JdbcThinMetadataSqlMatchTest.java  |  6 ++---
 .../ignite/jdbc/JdbcVersionMismatchSelfTest.java   |  6 ++---
 .../jdbc/suite/IgniteJdbcDriverMvccTestSuite.java  |  6 ++---
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java      |  6 ++---
 ...teJdbcThinDriverAffinityAwarenessTestSuite.java |  6 ++---
 .../thin/JdbcThinAbstractDmlStatementSelfTest.java |  6 ++---
 .../ignite/jdbc/thin/JdbcThinAbstractSelfTest.java |  6 ++---
 .../JdbcThinAbstractUpdateStatementSelfTest.java   |  6 ++---
 .../thin/JdbcThinAffinityAwarenessSelfTest.java    |  6 ++---
 ...cThinAffinityAwarenessTransactionsSelfTest.java |  6 ++---
 .../JdbcThinAuthenticateConnectionSelfTest.java    |  6 ++---
 .../thin/JdbcThinAutoCloseServerCursorTest.java    |  6 ++---
 .../ignite/jdbc/thin/JdbcThinBatchSelfTest.java    |  6 ++---
 .../thin/JdbcThinBulkLoadAbstractSelfTest.java     |  6 ++---
 ...cThinBulkLoadAtomicPartitionedNearSelfTest.java |  6 ++---
 .../JdbcThinBulkLoadAtomicPartitionedSelfTest.java |  6 ++---
 .../JdbcThinBulkLoadAtomicReplicatedSelfTest.java  |  6 ++---
 ...lkLoadTransactionalPartitionedNearSelfTest.java |  6 ++---
 ...inBulkLoadTransactionalPartitionedSelfTest.java |  6 ++---
 ...hinBulkLoadTransactionalReplicatedSelfTest.java |  6 ++---
 .../JdbcThinComplexDmlDdlCustomSchemaSelfTest.java |  6 ++---
 .../jdbc/thin/JdbcThinComplexDmlDdlSelfTest.java   |  6 ++---
 ...inComplexDmlDdlSkipReducerOnUpdateSelfTest.java |  6 ++---
 .../jdbc/thin/JdbcThinComplexQuerySelfTest.java    |  6 ++---
 .../JdbcThinConnectionMultipleAddressesTest.java   |  6 ++---
 .../JdbcThinConnectionMvccEnabledSelfTest.java     |  6 ++---
 .../jdbc/thin/JdbcThinConnectionSSLTest.java       |  6 ++---
 .../jdbc/thin/JdbcThinConnectionSelfTest.java      |  6 ++---
 .../thin/JdbcThinConnectionTimeoutSelfTest.java    |  6 ++---
 .../thin/JdbcThinDataPageScanPropertySelfTest.java |  6 ++---
 .../jdbc/thin/JdbcThinDataSourceSelfTest.java      |  6 ++---
 .../jdbc/thin/JdbcThinDeleteStatementSelfTest.java |  6 ++---
 .../thin/JdbcThinDynamicIndexAbstractSelfTest.java |  6 ++---
 ...nDynamicIndexAtomicPartitionedNearSelfTest.java |  6 ++---
 ...cThinDynamicIndexAtomicPartitionedSelfTest.java |  6 ++---
 ...bcThinDynamicIndexAtomicReplicatedSelfTest.java |  6 ++---
 ...cIndexTransactionalPartitionedNearSelfTest.java |  6 ++---
 ...namicIndexTransactionalPartitionedSelfTest.java |  6 ++---
 ...ynamicIndexTransactionalReplicatedSelfTest.java |  6 ++---
 .../jdbc/thin/JdbcThinEmptyCacheSelfTest.java      |  6 ++---
 .../ignite/jdbc/thin/JdbcThinErrorsSelfTest.java   |  6 ++---
 .../jdbc/thin/JdbcThinInsertStatementSelfTest.java |  6 ++---
 ...InsertStatementSkipReducerOnUpdateSelfTest.java |  6 ++---
 .../jdbc/thin/JdbcThinLocalQueriesSelfTest.java    |  6 ++---
 .../jdbc/thin/JdbcThinMergeStatementSelfTest.java  |  6 ++---
 ...nMergeStatementSkipReducerOnUpdateSelfTest.java |  6 ++---
 .../thin/JdbcThinMetadataPrimaryKeysSelfTest.java  |  6 ++---
 .../ignite/jdbc/thin/JdbcThinMetadataSelfTest.java |  6 ++---
 .../thin/JdbcThinMissingLongArrayResultsTest.java  |  6 ++---
 .../jdbc/thin/JdbcThinMultiStatementSelfTest.java  |  6 ++---
 .../jdbc/thin/JdbcThinNoDefaultSchemaTest.java     |  6 ++---
 .../thin/JdbcThinPreparedStatementLeakTest.java    |  6 ++---
 .../thin/JdbcThinPreparedStatementSelfTest.java    |  6 ++---
 .../jdbc/thin/JdbcThinResultSetSelfTest.java       |  6 ++---
 .../jdbc/thin/JdbcThinSchemaCaseSelfTest.java      |  6 ++---
 .../jdbc/thin/JdbcThinSelectAfterAlterTable.java   |  6 ++---
 .../jdbc/thin/JdbcThinStatementCancelSelfTest.java |  6 ++---
 .../jdbc/thin/JdbcThinStatementSelfTest.java       |  6 ++---
 .../thin/JdbcThinStatementTimeoutSelfTest.java     |  6 ++---
 .../thin/JdbcThinStreamingAbstractSelfTest.java    |  6 ++---
 .../thin/JdbcThinStreamingNotOrderedSelfTest.java  |  6 ++---
 .../thin/JdbcThinStreamingOrderedSelfTest.java     |  6 ++---
 .../thin/JdbcThinStreamingResetStreamTest.java     |  6 ++---
 .../apache/ignite/jdbc/thin/JdbcThinTcpIoTest.java |  6 ++---
 ...dbcThinTransactionsAbstractComplexSelfTest.java |  6 ++---
 ...ransactionsClientAutoCommitComplexSelfTest.java |  6 ++---
 ...nsactionsClientNoAutoCommitComplexSelfTest.java |  6 ++---
 .../thin/JdbcThinTransactionsLeaksMvccTest.java    |  6 ++---
 .../jdbc/thin/JdbcThinTransactionsSelfTest.java    |  6 ++---
 ...ransactionsServerAutoCommitComplexSelfTest.java |  6 ++---
 ...nsactionsServerNoAutoCommitComplexSelfTest.java |  6 ++---
 ...dbcThinTransactionsWithMvccEnabledSelfTest.java |  6 ++---
 .../jdbc/thin/JdbcThinUpdateStatementSelfTest.java |  6 ++---
 ...UpdateStatementSkipReducerOnUpdateSelfTest.java |  6 ++---
 .../jdbc/thin/JdbcThinWalModeChangeSelfTest.java   |  6 ++---
 ...nsactionFinishOnDeactivatedClusterSelfTest.java |  6 ++---
 .../loadtests/client/ClientCacheBenchmark.java     |  6 ++---
 .../client/ClientMarshallerBenchmarkTest.java      |  6 ++---
 .../loadtests/client/ClientTcpSslLoadTest.java     |  6 ++---
 modules/clients/src/test/keystore/ca/oneca.cnf     |  6 ++---
 modules/clients/src/test/keystore/ca/twoca.cnf     |  6 ++---
 modules/clients/src/test/keystore/generate.sh      |  6 ++---
 .../src/test/resources/jetty/rest-jetty-ssl.xml    |  6 ++---
 .../src/test/resources/jetty/rest-jetty.xml        |  6 ++---
 .../src/test/resources/jetty/router-jetty-ssl.xml  |  6 ++---
 .../src/test/resources/jetty/router-jetty.xml      |  6 ++---
 modules/clients/src/test/resources/log4j.xml       |  6 ++---
 .../clients/src/test/resources/spring-cache.xml    |  6 ++---
 .../src/test/resources/spring-router-ssl.xml       |  6 ++---
 .../clients/src/test/resources/spring-router.xml   |  6 ++---
 .../src/test/resources/spring-server-node.xml      |  6 ++---
 .../src/test/resources/spring-server-ssl-node.xml  |  6 ++---
 modules/cloud/pom.xml                              |  6 ++---
 .../ipfinder/cloud/TcpDiscoveryCloudIpFinder.java  |  6 ++---
 .../discovery/tcp/ipfinder/cloud/package-info.java |  6 ++---
 .../cloud/TcpDiscoveryCloudIpFinderSelfTest.java   |  6 ++---
 .../discovery/tcp/ipfinder/cloud/package-info.java |  6 ++---
 .../ignite/testsuites/IgniteCloudTestSuite.java    |  6 ++---
 modules/codegen/pom.xml                            |  6 ++---
 .../ignite/codegen/MessageCodeGenerator.java       |  6 ++---
 modules/compatibility/pom.xml                      |  6 ++---
 .../compatibility/PdsWithTtlCompatibilityTest.java |  6 ++---
 .../apache/ignite/compatibility/package-info.java  |  6 ++---
 .../persistence/FoldersReuseCompatibilityTest.java |  6 ++---
 .../IgnitePKIndexesMigrationToUnwrapPkTest.java    |  6 ++---
 ...IgnitePersistenceCompatibilityAbstractTest.java |  6 ++---
 ...gratingToWalV2SerializerWithCompactionTest.java |  6 ++---
 .../PersistenceBasicCompatibilityTest.java         |  6 ++---
 .../compatibility/persistence/package-info.java    |  6 ++---
 .../junits/CompatibilityTestsFacade.java           |  6 ++---
 .../testframework/junits/Dependency.java           |  6 ++---
 .../junits/IgniteCompatibilityAbstractTest.java    |  6 ++---
 .../junits/IgniteCompatibilityNodeRunner.java      |  6 ++---
 .../junits/logger/ListenedGridTestLog4jLogger.java |  6 ++---
 .../testframework/junits/logger/package-info.java  |  6 ++---
 .../testframework/junits/package-info.java         |  6 ++---
 .../compatibility/testframework/package-info.java  |  6 ++---
 .../plugins/DisabledValidationProcessor.java       |  6 ++---
 .../plugins/TestCompatibilityPluginProvider.java   |  6 ++---
 .../testframework/plugins/package-info.java        |  6 ++---
 .../util/CompatibilityTestsUtils.java              |  6 ++---
 .../testframework/util/MavenUtils.java             |  6 ++---
 .../testframework/util/package-info.java           |  6 ++---
 .../IgniteCompatibilityBasicTestSuite.java         |  6 ++---
 .../compatibility/testsuites/package-info.java     |  6 ++---
 modules/compress/pom.xml                           |  6 ++---
 .../compress/CompressionProcessorImpl.java         |  6 ++---
 .../processors/compress/NativeFileSystemLinux.java |  6 ++---
 .../processors/compress/NativeFileSystemPosix.java |  6 ++---
 .../compress/CompressionConfigurationTest.java     |  6 ++---
 .../compress/CompressionProcessorTest.java         |  6 ++---
 .../DiskPageCompressionIntegrationAsyncTest.java   |  6 ++---
 .../DiskPageCompressionIntegrationTest.java        |  6 ++---
 .../processors/compress/FileSystemUtilsTest.java   |  6 ++---
 .../testsuites/IgnitePdsCompressionTestSuite.java  |  6 ++---
 .../testsuites/IgnitePdsCompressionTestSuite2.java |  6 ++---
 modules/core/pom.xml                               | 12 +++++-----
 .../java/org/apache/ignite/DataRegionMetrics.java  |  6 ++---
 .../apache/ignite/DataRegionMetricsAdapter.java    |  6 ++---
 .../apache/ignite/DataRegionMetricsProvider.java   |  6 ++---
 .../java/org/apache/ignite/DataStorageMetrics.java |  6 ++---
 .../apache/ignite/DataStorageMetricsAdapter.java   |  6 ++---
 .../src/main/java/org/apache/ignite/Ignite.java    |  6 ++---
 .../java/org/apache/ignite/IgniteAtomicLong.java   |  6 ++---
 .../org/apache/ignite/IgniteAtomicReference.java   |  6 ++---
 .../org/apache/ignite/IgniteAtomicSequence.java    |  6 ++---
 .../org/apache/ignite/IgniteAtomicStamped.java     |  6 ++---
 .../ignite/IgniteAuthenticationException.java      |  6 ++---
 .../main/java/org/apache/ignite/IgniteBinary.java  |  6 ++---
 .../main/java/org/apache/ignite/IgniteCache.java   |  6 ++---
 .../ignite/IgniteCacheRestartingException.java     |  6 ++---
 .../org/apache/ignite/IgniteCheckedException.java  |  6 ++---
 .../ignite/IgniteClientDisconnectedException.java  |  6 ++---
 .../main/java/org/apache/ignite/IgniteCluster.java |  6 ++---
 .../main/java/org/apache/ignite/IgniteCompute.java |  6 ++---
 .../java/org/apache/ignite/IgniteCondition.java    |  6 ++---
 .../org/apache/ignite/IgniteCountDownLatch.java    |  6 ++---
 .../java/org/apache/ignite/IgniteDataStreamer.java |  6 ++---
 .../ignite/IgniteDataStreamerTimeoutException.java |  6 ++---
 .../apache/ignite/IgniteDeploymentException.java   |  6 ++---
 .../main/java/org/apache/ignite/IgniteEvents.java  |  6 ++---
 .../java/org/apache/ignite/IgniteException.java    |  6 ++---
 .../java/org/apache/ignite/IgniteFileSystem.java   |  6 ++---
 .../apache/ignite/IgniteIllegalStateException.java |  6 ++---
 .../apache/ignite/IgniteInterruptedException.java  |  6 ++---
 .../java/org/apache/ignite/IgniteJdbcDriver.java   |  6 ++---
 .../apache/ignite/IgniteJdbcThinDataSource.java    |  6 ++---
 .../org/apache/ignite/IgniteJdbcThinDriver.java    |  6 ++---
 .../main/java/org/apache/ignite/IgniteLock.java    |  6 ++---
 .../main/java/org/apache/ignite/IgniteLogger.java  |  6 ++---
 .../java/org/apache/ignite/IgniteMessaging.java    |  6 ++---
 .../main/java/org/apache/ignite/IgniteQueue.java   |  6 ++---
 .../java/org/apache/ignite/IgniteScheduler.java    |  6 ++---
 .../java/org/apache/ignite/IgniteSemaphore.java    |  6 ++---
 .../java/org/apache/ignite/IgniteServices.java     |  6 ++---
 .../src/main/java/org/apache/ignite/IgniteSet.java |  6 ++---
 .../main/java/org/apache/ignite/IgniteState.java   |  6 ++---
 .../org/apache/ignite/IgniteSystemProperties.java  |  6 ++---
 .../java/org/apache/ignite/IgniteTransactions.java |  6 ++---
 .../src/main/java/org/apache/ignite/Ignition.java  |  6 ++---
 .../java/org/apache/ignite/IgnitionListener.java   |  6 ++---
 .../main/java/org/apache/ignite/MemoryMetrics.java |  6 ++---
 .../java/org/apache/ignite/PersistenceMetrics.java |  6 ++---
 .../apache/ignite/binary/BinaryBasicIdMapper.java  |  6 ++---
 .../ignite/binary/BinaryBasicNameMapper.java       |  6 ++---
 .../ignite/binary/BinaryCollectionFactory.java     |  6 ++---
 .../java/org/apache/ignite/binary/BinaryField.java |  6 ++---
 .../org/apache/ignite/binary/BinaryIdMapper.java   |  6 ++---
 .../ignite/binary/BinaryInvalidTypeException.java  |  6 ++---
 .../org/apache/ignite/binary/BinaryMapFactory.java |  6 ++---
 .../org/apache/ignite/binary/BinaryNameMapper.java |  6 ++---
 .../org/apache/ignite/binary/BinaryObject.java     |  6 ++---
 .../apache/ignite/binary/BinaryObjectBuilder.java  |  6 ++---
 .../ignite/binary/BinaryObjectException.java       |  6 ++---
 .../org/apache/ignite/binary/BinaryRawReader.java  |  6 ++---
 .../org/apache/ignite/binary/BinaryRawWriter.java  |  6 ++---
 .../org/apache/ignite/binary/BinaryReader.java     |  6 ++---
 .../ignite/binary/BinaryReflectiveSerializer.java  |  6 ++---
 .../org/apache/ignite/binary/BinarySerializer.java |  6 ++---
 .../java/org/apache/ignite/binary/BinaryType.java  |  6 ++---
 .../ignite/binary/BinaryTypeConfiguration.java     |  6 ++---
 .../org/apache/ignite/binary/BinaryWriter.java     |  6 ++---
 .../org/apache/ignite/binary/Binarylizable.java    |  6 ++---
 .../org/apache/ignite/binary/package-info.java     |  6 ++---
 .../apache/ignite/cache/CacheAtomicityMode.java    |  6 ++---
 .../java/org/apache/ignite/cache/CacheEntry.java   |  6 ++---
 .../cache/CacheEntryEventSerializableFilter.java   |  6 ++---
 .../apache/ignite/cache/CacheEntryProcessor.java   |  6 ++---
 .../apache/ignite/cache/CacheExistsException.java  |  6 ++---
 .../org/apache/ignite/cache/CacheInterceptor.java  |  6 ++---
 .../ignite/cache/CacheInterceptorAdapter.java      |  6 ++---
 .../apache/ignite/cache/CacheInterceptorEntry.java |  6 ++---
 .../apache/ignite/cache/CacheKeyConfiguration.java |  6 ++---
 .../java/org/apache/ignite/cache/CacheManager.java |  6 ++---
 .../java/org/apache/ignite/cache/CacheMetrics.java |  6 ++---
 .../java/org/apache/ignite/cache/CacheMode.java    |  6 ++---
 .../ignite/cache/CachePartialUpdateException.java  |  6 ++---
 .../org/apache/ignite/cache/CachePeekMode.java     |  6 ++---
 .../apache/ignite/cache/CacheRebalanceMode.java    |  6 ++---
 .../ignite/cache/CacheServerNotFoundException.java |  6 ++---
 .../cache/CacheWriteSynchronizationMode.java       |  6 ++---
 .../org/apache/ignite/cache/CachingProvider.java   |  6 ++---
 .../apache/ignite/cache/PartitionLossPolicy.java   |  6 ++---
 .../java/org/apache/ignite/cache/QueryEntity.java  |  6 ++---
 .../org/apache/ignite/cache/QueryEntityPatch.java  |  6 ++---
 .../java/org/apache/ignite/cache/QueryIndex.java   |  6 ++---
 .../org/apache/ignite/cache/QueryIndexType.java    |  6 ++---
 .../org/apache/ignite/cache/affinity/Affinity.java |  6 ++---
 .../affinity/AffinityCentralizedFunction.java      |  6 ++---
 .../ignite/cache/affinity/AffinityFunction.java    |  6 ++---
 .../cache/affinity/AffinityFunctionContext.java    |  6 ++---
 .../apache/ignite/cache/affinity/AffinityKey.java  |  6 ++---
 .../ignite/cache/affinity/AffinityKeyMapped.java   |  6 ++---
 .../ignite/cache/affinity/AffinityKeyMapper.java   |  6 ++---
 .../apache/ignite/cache/affinity/AffinityUuid.java |  6 ++---
 .../apache/ignite/cache/affinity/package-info.java |  6 ++---
 .../ClusterNodeAttributeAffinityBackupFilter.java  |  6 ++---
 .../rendezvous/RendezvousAffinityFunction.java     |  6 ++---
 .../cache/affinity/rendezvous/package-info.java    |  6 ++---
 .../cache/eviction/AbstractEvictionPolicy.java     |  6 ++---
 .../eviction/AbstractEvictionPolicyFactory.java    |  6 ++---
 .../ignite/cache/eviction/EvictableEntry.java      |  6 ++---
 .../ignite/cache/eviction/EvictionFilter.java      |  6 ++---
 .../ignite/cache/eviction/EvictionPolicy.java      |  6 ++---
 .../cache/eviction/fifo/FifoEvictionPolicy.java    |  6 ++---
 .../eviction/fifo/FifoEvictionPolicyFactory.java   |  6 ++---
 .../eviction/fifo/FifoEvictionPolicyMBean.java     |  6 ++---
 .../ignite/cache/eviction/fifo/package-info.java   |  6 ++---
 .../cache/eviction/igfs/IgfsEvictionFilter.java    |  6 ++---
 .../igfs/IgfsPerBlockLruEvictionPolicy.java        |  6 ++---
 .../igfs/IgfsPerBlockLruEvictionPolicyMXBean.java  |  6 ++---
 .../ignite/cache/eviction/igfs/package-info.java   |  6 ++---
 .../cache/eviction/lru/LruEvictionPolicy.java      |  6 ++---
 .../eviction/lru/LruEvictionPolicyFactory.java     |  6 ++---
 .../cache/eviction/lru/LruEvictionPolicyMBean.java |  6 ++---
 .../ignite/cache/eviction/lru/package-info.java    |  6 ++---
 .../apache/ignite/cache/eviction/package-info.java |  6 ++---
 .../ignite/cache/eviction/random/package-info.java |  6 ++---
 .../eviction/sorted/SortedEvictionPolicy.java      |  6 ++---
 .../sorted/SortedEvictionPolicyFactory.java        |  6 ++---
 .../eviction/sorted/SortedEvictionPolicyMBean.java |  6 ++---
 .../ignite/cache/eviction/sorted/package-info.java |  6 ++---
 .../java/org/apache/ignite/cache/package-info.java |  6 ++---
 .../cache/query/AbstractContinuousQuery.java       |  6 ++---
 .../ignite/cache/query/BulkLoadContextCursor.java  |  6 ++---
 .../ignite/cache/query/CacheQueryEntryEvent.java   |  6 ++---
 .../apache/ignite/cache/query/ContinuousQuery.java |  6 ++---
 .../query/ContinuousQueryWithTransformer.java      |  6 ++---
 .../ignite/cache/query/FieldsQueryCursor.java      |  6 ++---
 .../java/org/apache/ignite/cache/query/Query.java  |  6 ++---
 .../cache/query/QueryCancelledException.java       |  6 ++---
 .../org/apache/ignite/cache/query/QueryCursor.java |  6 ++---
 .../ignite/cache/query/QueryDetailMetrics.java     |  6 ++---
 .../apache/ignite/cache/query/QueryMetrics.java    |  6 ++---
 .../ignite/cache/query/QueryRetryException.java    |  6 ++---
 .../org/apache/ignite/cache/query/ScanQuery.java   |  6 ++---
 .../org/apache/ignite/cache/query/SpiQuery.java    |  6 ++---
 .../apache/ignite/cache/query/SqlFieldsQuery.java  |  6 ++---
 .../org/apache/ignite/cache/query/SqlQuery.java    |  6 ++---
 .../org/apache/ignite/cache/query/TextQuery.java   |  6 ++---
 .../cache/query/annotations/QueryGroupIndex.java   |  6 ++---
 .../cache/query/annotations/QuerySqlField.java     |  6 ++---
 .../cache/query/annotations/QuerySqlFunction.java  |  6 ++---
 .../cache/query/annotations/QueryTextField.java    |  6 ++---
 .../cache/query/annotations/package-info.java      |  6 ++---
 .../apache/ignite/cache/query/package-info.java    |  6 ++---
 .../cache/store/CacheLoadOnlyStoreAdapter.java     |  6 ++---
 .../org/apache/ignite/cache/store/CacheStore.java  |  6 ++---
 .../ignite/cache/store/CacheStoreAdapter.java      |  6 ++---
 .../ignite/cache/store/CacheStoreSession.java      |  6 ++---
 .../cache/store/CacheStoreSessionListener.java     |  6 ++---
 .../cache/store/jdbc/CacheAbstractJdbcStore.java   |  6 ++---
 .../cache/store/jdbc/CacheJdbcBlobStore.java       |  6 ++---
 .../store/jdbc/CacheJdbcBlobStoreFactory.java      |  6 ++---
 .../cache/store/jdbc/CacheJdbcPojoStore.java       |  6 ++---
 .../store/jdbc/CacheJdbcPojoStoreFactory.java      |  6 ++---
 .../store/jdbc/CacheJdbcStoreSessionListener.java  |  6 ++---
 .../apache/ignite/cache/store/jdbc/JdbcType.java   |  6 ++---
 .../cache/store/jdbc/JdbcTypeDefaultHasher.java    |  6 ++---
 .../ignite/cache/store/jdbc/JdbcTypeField.java     |  6 ++---
 .../ignite/cache/store/jdbc/JdbcTypeHasher.java    |  6 ++---
 .../store/jdbc/JdbcTypesDefaultTransformer.java    |  6 ++---
 .../cache/store/jdbc/JdbcTypesTransformer.java     |  6 ++---
 .../cache/store/jdbc/dialect/BasicJdbcDialect.java |  6 ++---
 .../cache/store/jdbc/dialect/DB2Dialect.java       |  6 ++---
 .../ignite/cache/store/jdbc/dialect/H2Dialect.java |  6 ++---
 .../cache/store/jdbc/dialect/JdbcDialect.java      |  6 ++---
 .../cache/store/jdbc/dialect/MySQLDialect.java     |  6 ++---
 .../cache/store/jdbc/dialect/OracleDialect.java    |  6 ++---
 .../cache/store/jdbc/dialect/SQLServerDialect.java |  6 ++---
 .../cache/store/jdbc/dialect/package-info.java     |  6 ++---
 .../ignite/cache/store/jdbc/package-info.java      |  6 ++---
 .../apache/ignite/cache/store/package-info.java    |  6 ++---
 .../client/ClientAuthenticationException.java      |  6 ++---
 .../client/ClientAuthorizationException.java       |  6 ++---
 .../java/org/apache/ignite/client/ClientCache.java |  6 ++---
 .../ignite/client/ClientCacheConfiguration.java    |  6 ++---
 .../ignite/client/ClientConnectionException.java   |  6 ++---
 .../org/apache/ignite/client/ClientException.java  |  6 ++---
 .../org/apache/ignite/client/IgniteClient.java     |  6 ++---
 .../java/org/apache/ignite/client/SslMode.java     |  6 ++---
 .../java/org/apache/ignite/client/SslProtocol.java |  6 ++---
 .../org/apache/ignite/cluster/BaselineNode.java    |  6 ++---
 .../org/apache/ignite/cluster/ClusterGroup.java    |  6 ++---
 .../ignite/cluster/ClusterGroupEmptyException.java |  6 ++---
 .../org/apache/ignite/cluster/ClusterMetrics.java  |  6 ++---
 .../org/apache/ignite/cluster/ClusterNode.java     |  6 ++---
 .../ignite/cluster/ClusterStartNodeResult.java     |  6 ++---
 .../ignite/cluster/ClusterTopologyException.java   |  6 ++---
 .../org/apache/ignite/cluster/package-info.java    |  6 ++---
 .../compute/ComputeExecutionRejectedException.java |  6 ++---
 .../java/org/apache/ignite/compute/ComputeJob.java |  6 ++---
 .../apache/ignite/compute/ComputeJobAdapter.java   |  6 ++---
 .../apache/ignite/compute/ComputeJobAfterSend.java |  6 ++---
 .../ignite/compute/ComputeJobBeforeFailover.java   |  6 ++---
 .../apache/ignite/compute/ComputeJobContext.java   |  6 ++---
 .../ignite/compute/ComputeJobContinuation.java     |  6 ++---
 .../compute/ComputeJobContinuationAdapter.java     |  6 ++---
 .../compute/ComputeJobFailoverException.java       |  6 ++---
 .../ignite/compute/ComputeJobMasterLeaveAware.java |  6 ++---
 .../apache/ignite/compute/ComputeJobResult.java    |  6 ++---
 .../ignite/compute/ComputeJobResultPolicy.java     |  6 ++---
 .../apache/ignite/compute/ComputeJobSibling.java   |  6 ++---
 .../apache/ignite/compute/ComputeLoadBalancer.java |  6 ++---
 .../org/apache/ignite/compute/ComputeTask.java     |  6 ++---
 .../apache/ignite/compute/ComputeTaskAdapter.java  |  6 ++---
 .../compute/ComputeTaskCancelledException.java     |  6 ++---
 .../compute/ComputeTaskContinuousMapper.java       |  6 ++---
 .../apache/ignite/compute/ComputeTaskFuture.java   |  6 ++---
 .../apache/ignite/compute/ComputeTaskMapAsync.java |  6 ++---
 .../org/apache/ignite/compute/ComputeTaskName.java |  6 ++---
 .../ignite/compute/ComputeTaskNoResultCache.java   |  6 ++---
 .../apache/ignite/compute/ComputeTaskSession.java  |  6 ++---
 .../ComputeTaskSessionAttributeListener.java       |  6 ++---
 .../compute/ComputeTaskSessionFullSupport.java     |  6 ++---
 .../ignite/compute/ComputeTaskSessionScope.java    |  6 ++---
 .../org/apache/ignite/compute/ComputeTaskSpis.java |  6 ++---
 .../ignite/compute/ComputeTaskSplitAdapter.java    |  6 ++---
 .../compute/ComputeTaskTimeoutException.java       |  6 ++---
 .../compute/ComputeUserUndeclaredException.java    |  6 ++---
 .../org/apache/ignite/compute/gridify/Gridify.java |  6 ++---
 .../ignite/compute/gridify/GridifyArgument.java    |  6 ++---
 .../ignite/compute/gridify/GridifyInput.java       |  6 ++---
 .../ignite/compute/gridify/GridifyInterceptor.java |  6 ++---
 .../ignite/compute/gridify/GridifyNodeFilter.java  |  6 ++---
 .../compute/gridify/GridifyRuntimeException.java   |  6 ++---
 .../ignite/compute/gridify/GridifySetToSet.java    |  6 ++---
 .../ignite/compute/gridify/GridifySetToValue.java  |  6 ++---
 .../ignite/compute/gridify/GridifyTaskAdapter.java |  6 ++---
 .../compute/gridify/GridifyTaskSplitAdapter.java   |  6 ++---
 .../gridify/aop/GridifyArgumentAdapter.java        |  6 ++---
 .../gridify/aop/GridifyDefaultRangeTask.java       |  6 ++---
 .../compute/gridify/aop/GridifyDefaultTask.java    |  6 ++---
 .../gridify/aop/GridifySetToSetAbstractAspect.java |  6 ++---
 .../aop/GridifySetToValueAbstractAspect.java       |  6 ++---
 .../ignite/compute/gridify/aop/package-info.java   |  6 ++---
 .../ignite/compute/gridify/package-info.java       |  6 ++---
 .../org/apache/ignite/compute/package-info.java    |  6 ++---
 .../ignite/configuration/AddressResolver.java      |  6 ++---
 .../ignite/configuration/AtomicConfiguration.java  |  6 ++---
 .../ignite/configuration/BasicAddressResolver.java |  6 ++---
 .../ignite/configuration/BinaryConfiguration.java  |  6 ++---
 .../ignite/configuration/CacheConfiguration.java   |  6 ++---
 .../ignite/configuration/CheckpointWriteOrder.java |  6 ++---
 .../ignite/configuration/ClientConfiguration.java  |  6 ++---
 .../ClientConnectorConfiguration.java              |  6 ++---
 .../configuration/CollectionConfiguration.java     |  6 ++---
 .../configuration/CommunicationFailureContext.java |  6 ++---
 .../CommunicationFailureResolver.java              |  6 ++---
 .../configuration/ConnectorConfiguration.java      |  6 ++---
 .../configuration/ConnectorMessageInterceptor.java |  6 ++---
 .../ignite/configuration/DataPageEvictionMode.java |  6 ++---
 .../configuration/DataRegionConfiguration.java     |  6 ++---
 .../configuration/DataStorageConfiguration.java    |  6 ++---
 .../DefaultCommunicationFailureResolver.java       |  6 ++---
 .../ignite/configuration/DeploymentMode.java       |  6 ++---
 .../ignite/configuration/DiskPageCompression.java  |  6 ++---
 .../configuration/ExecutorConfiguration.java       |  6 ++---
 .../configuration/FileSystemConfiguration.java     |  6 ++---
 .../ignite/configuration/HadoopConfiguration.java  |  6 ++---
 .../ignite/configuration/IgniteConfiguration.java  |  6 ++---
 .../configuration/IgniteReflectionFactory.java     |  6 ++---
 .../ignite/configuration/MemoryConfiguration.java  |  6 ++---
 .../configuration/MemoryPolicyConfiguration.java   |  6 ++---
 .../configuration/NearCacheConfiguration.java      |  6 ++---
 .../ignite/configuration/OdbcConfiguration.java    |  6 ++---
 .../PersistentStoreConfiguration.java              |  6 ++---
 .../configuration/PlatformConfiguration.java       |  6 ++---
 .../ignite/configuration/SerializeSeparately.java  |  6 ++---
 .../configuration/SqlConnectorConfiguration.java   |  6 ++---
 .../ignite/configuration/TopologyValidator.java    |  6 ++---
 .../configuration/TransactionConfiguration.java    |  6 ++---
 .../org/apache/ignite/configuration/WALMode.java   |  6 ++---
 .../apache/ignite/configuration/package-info.java  |  6 ++---
 .../java/org/apache/ignite/events/CacheEvent.java  |  6 ++---
 .../ignite/events/CacheQueryExecutedEvent.java     |  6 ++---
 .../apache/ignite/events/CacheQueryReadEvent.java  |  6 ++---
 .../ignite/events/CacheRebalancingEvent.java       |  6 ++---
 .../org/apache/ignite/events/CheckpointEvent.java  |  6 ++---
 .../ignite/events/ClusterActivationEvent.java      |  6 ++---
 .../org/apache/ignite/events/DeploymentEvent.java  |  6 ++---
 .../org/apache/ignite/events/DiscoveryEvent.java   |  6 ++---
 .../main/java/org/apache/ignite/events/Event.java  |  6 ++---
 .../org/apache/ignite/events/EventAdapter.java     |  6 ++---
 .../org/apache/ignite/events/EventLocalOrder.java  |  6 ++---
 .../java/org/apache/ignite/events/EventType.java   |  6 ++---
 .../java/org/apache/ignite/events/IgfsEvent.java   |  6 ++---
 .../java/org/apache/ignite/events/JobEvent.java    |  6 ++---
 .../java/org/apache/ignite/events/TaskEvent.java   |  6 ++---
 .../events/TransactionStateChangedEvent.java       |  6 ++---
 .../ignite/events/WalSegmentArchivedEvent.java     |  6 ++---
 .../ignite/events/WalSegmentCompactedEvent.java    |  6 ++---
 .../org/apache/ignite/events/package-info.java     |  6 ++---
 .../ignite/failure/AbstractFailureHandler.java     |  6 ++---
 .../org/apache/ignite/failure/FailureContext.java  |  6 ++---
 .../org/apache/ignite/failure/FailureHandler.java  |  6 ++---
 .../org/apache/ignite/failure/FailureType.java     |  6 ++---
 .../apache/ignite/failure/NoOpFailureHandler.java  |  6 ++---
 .../failure/RestartProcessFailureHandler.java      |  6 ++---
 .../ignite/failure/StopNodeFailureHandler.java     |  6 ++---
 .../failure/StopNodeOrHaltFailureHandler.java      |  6 ++---
 .../org/apache/ignite/failure/package-info.java    |  6 ++---
 .../org/apache/ignite/hadoop/HadoopInputSplit.java |  6 ++---
 .../java/org/apache/ignite/hadoop/HadoopJob.java   |  6 ++---
 .../apache/ignite/hadoop/HadoopMapReducePlan.java  |  6 ++---
 .../ignite/hadoop/HadoopMapReducePlanner.java      |  6 ++---
 .../org/apache/ignite/hadoop/package-info.java     |  6 ++---
 .../org/apache/ignite/igfs/IgfsBlockLocation.java  |  6 ++---
 .../igfs/IgfsConcurrentModificationException.java  |  6 ++---
 .../ignite/igfs/IgfsCorruptedFileException.java    |  6 ++---
 .../igfs/IgfsDirectoryNotEmptyException.java       |  6 ++---
 .../java/org/apache/ignite/igfs/IgfsException.java |  6 ++---
 .../main/java/org/apache/ignite/igfs/IgfsFile.java |  6 ++---
 .../ignite/igfs/IgfsGroupDataBlocksKeyMapper.java  |  6 ++---
 .../org/apache/ignite/igfs/IgfsInputStream.java    |  6 ++---
 .../igfs/IgfsInvalidHdfsVersionException.java      |  6 ++---
 .../ignite/igfs/IgfsInvalidPathException.java      |  6 ++---
 .../ignite/igfs/IgfsIpcEndpointConfiguration.java  |  6 ++---
 .../apache/ignite/igfs/IgfsIpcEndpointType.java    |  6 ++---
 .../java/org/apache/ignite/igfs/IgfsMetrics.java   |  6 ++---
 .../main/java/org/apache/ignite/igfs/IgfsMode.java |  6 ++---
 .../ignite/igfs/IgfsOutOfSpaceException.java       |  6 ++---
 .../org/apache/ignite/igfs/IgfsOutputStream.java   |  6 ++---
 .../igfs/IgfsParentNotDirectoryException.java      |  6 ++---
 .../main/java/org/apache/ignite/igfs/IgfsPath.java |  6 ++---
 .../igfs/IgfsPathAlreadyExistsException.java       |  6 ++---
 .../ignite/igfs/IgfsPathIsDirectoryException.java  |  6 ++---
 .../igfs/IgfsPathIsNotDirectoryException.java      |  6 ++---
 .../ignite/igfs/IgfsPathNotFoundException.java     |  6 ++---
 .../org/apache/ignite/igfs/IgfsPathSummary.java    |  6 ++---
 .../org/apache/ignite/igfs/IgfsUserContext.java    |  6 ++---
 .../ignite/igfs/mapreduce/IgfsFileRange.java       |  6 ++---
 .../igfs/mapreduce/IgfsInputStreamJobAdapter.java  |  6 ++---
 .../org/apache/ignite/igfs/mapreduce/IgfsJob.java  |  6 ++---
 .../ignite/igfs/mapreduce/IgfsJobAdapter.java      |  6 ++---
 .../igfs/mapreduce/IgfsRangeInputStream.java       |  6 ++---
 .../ignite/igfs/mapreduce/IgfsRecordResolver.java  |  6 ++---
 .../org/apache/ignite/igfs/mapreduce/IgfsTask.java |  6 ++---
 .../apache/ignite/igfs/mapreduce/IgfsTaskArgs.java |  6 ++---
 .../igfs/mapreduce/IgfsTaskNoReduceAdapter.java    |  6 ++---
 .../apache/ignite/igfs/mapreduce/package-info.java |  6 ++---
 .../records/IgfsByteDelimiterRecordResolver.java   |  6 ++---
 .../records/IgfsFixedLengthRecordResolver.java     |  6 ++---
 .../records/IgfsNewLineRecordResolver.java         |  6 ++---
 .../records/IgfsStringDelimiterRecordResolver.java |  6 ++---
 .../igfs/mapreduce/records/package-info.java       |  6 ++---
 .../java/org/apache/ignite/igfs/package-info.java  |  6 ++---
 .../igfs/secondary/IgfsSecondaryFileSystem.java    |  6 ++---
 .../IgfsSecondaryFileSystemPositionedReadable.java |  6 ++---
 .../local/LocalIgfsSecondaryFileSystem.java        |  6 ++---
 .../ignite/igfs/secondary/local/package-info.java  |  6 ++---
 .../apache/ignite/igfs/secondary/package-info.java |  6 ++---
 .../ignite/internal/AsyncSupportAdapter.java       |  6 ++---
 .../java/org/apache/ignite/internal/ClassSet.java  |  6 ++---
 .../ClusterLocalNodeMetricsMXBeanImpl.java         |  6 ++---
 .../ignite/internal/ClusterMetricsMXBeanImpl.java  |  6 ++---
 .../ignite/internal/ClusterMetricsSnapshot.java    |  6 ++---
 .../ignite/internal/ComputeTaskInternalFuture.java |  6 ++---
 .../ignite/internal/DuplicateTypeIdException.java  |  6 ++---
 .../ignite/internal/ExecutorAwareMessage.java      |  6 ++---
 .../ignite/internal/GridCachePluginContext.java    |  6 ++---
 .../ignite/internal/GridClosureCallMode.java       |  6 ++---
 .../ignite/internal/GridCodegenConverter.java      |  6 ++---
 .../org/apache/ignite/internal/GridComponent.java  |  6 ++---
 .../org/apache/ignite/internal/GridDiagnostic.java |  6 ++---
 .../ignite/internal/GridDirectCollection.java      |  6 ++---
 .../org/apache/ignite/internal/GridDirectMap.java  |  6 ++---
 .../ignite/internal/GridDirectTransient.java       |  6 ++---
 .../ignite/internal/GridEventConsumeHandler.java   |  6 ++---
 .../ignite/internal/GridInternalException.java     |  6 ++---
 .../ignite/internal/GridInternalWrapper.java       |  6 ++---
 .../ignite/internal/GridJobCancelRequest.java      |  6 ++---
 .../apache/ignite/internal/GridJobContextImpl.java |  6 ++---
 .../ignite/internal/GridJobExecuteRequest.java     |  6 ++---
 .../ignite/internal/GridJobExecuteResponse.java    |  6 ++---
 .../apache/ignite/internal/GridJobResultImpl.java  |  6 ++---
 .../apache/ignite/internal/GridJobSessionImpl.java |  6 ++---
 .../apache/ignite/internal/GridJobSiblingImpl.java |  6 ++---
 .../ignite/internal/GridJobSiblingsRequest.java    |  6 ++---
 .../ignite/internal/GridJobSiblingsResponse.java   |  6 ++---
 .../apache/ignite/internal/GridKernalContext.java  |  6 ++---
 .../ignite/internal/GridKernalContextImpl.java     |  6 ++---
 .../apache/ignite/internal/GridKernalGateway.java  |  6 ++---
 .../ignite/internal/GridKernalGatewayImpl.java     |  6 ++---
 .../apache/ignite/internal/GridKernalState.java    |  6 ++---
 .../apache/ignite/internal/GridLoggerProxy.java    |  6 ++---
 .../ignite/internal/GridMessageListenHandler.java  |  6 ++---
 .../ignite/internal/GridPluginComponent.java       |  6 ++---
 .../apache/ignite/internal/GridPluginContext.java  |  6 ++---
 .../apache/ignite/internal/GridProxyListener.java  |  6 ++---
 .../ignite/internal/GridTaskCancelRequest.java     |  6 ++---
 .../ignite/internal/GridTaskNameHashKey.java       |  6 ++---
 .../ignite/internal/GridTaskSessionImpl.java       |  6 ++---
 .../ignite/internal/GridTaskSessionInternal.java   |  6 ++---
 .../ignite/internal/GridTaskSessionRequest.java    |  6 ++---
 .../java/org/apache/ignite/internal/GridTopic.java |  6 ++---
 .../IgniteClientDisconnectedCheckedException.java  |  6 ++---
 .../ignite/internal/IgniteCodeGeneratingFail.java  |  6 ++---
 .../ignite/internal/IgniteComponentType.java       |  6 ++---
 .../apache/ignite/internal/IgniteComputeImpl.java  |  6 ++---
 .../internal/IgniteDeploymentCheckedException.java |  6 ++---
 .../ignite/internal/IgniteDiagnosticAware.java     |  6 ++---
 .../ignite/internal/IgniteDiagnosticInfo.java      |  6 ++---
 .../ignite/internal/IgniteDiagnosticMessage.java   |  6 ++---
 .../internal/IgniteDiagnosticPrepareContext.java   |  6 ++---
 .../apache/ignite/internal/IgniteEventsImpl.java   |  6 ++---
 .../java/org/apache/ignite/internal/IgniteEx.java  |  6 ++---
 .../org/apache/ignite/internal/IgniteFeatures.java |  6 ++---
 .../IgniteFutureCancelledCheckedException.java     |  6 ++---
 .../IgniteFutureTimeoutCheckedException.java       |  6 ++---
 .../ignite/internal/IgniteInternalFuture.java      |  6 ++---
 .../IgniteInterruptedCheckedException.java         |  6 ++---
 .../org/apache/ignite/internal/IgniteKernal.java   |  6 ++---
 .../ignite/internal/IgniteMessagingImpl.java       |  6 ++---
 .../internal/IgniteNeedReconnectException.java     |  6 ++---
 .../ignite/internal/IgniteNodeAttributes.java      |  6 ++---
 .../apache/ignite/internal/IgniteProperties.java   |  6 ++---
 .../ignite/internal/IgniteSchedulerImpl.java       |  6 ++---
 .../apache/ignite/internal/IgniteServicesImpl.java |  6 ++---
 .../ignite/internal/IgniteTransactionsEx.java      |  6 ++---
 .../apache/ignite/internal/IgniteVersionUtils.java |  6 ++---
 .../org/apache/ignite/internal/IgnitionEx.java     |  6 ++---
 .../ignite/internal/IgnitionMXBeanAdapter.java     |  6 ++---
 .../internal/InvalidEnvironmentException.java      |  6 ++---
 .../ignite/internal/LongJVMPauseDetector.java      |  6 ++---
 .../apache/ignite/internal/MappingStoreTask.java   |  6 ++---
 .../ignite/internal/MarshallerContextImpl.java     |  6 ++---
 .../internal/MarshallerMappingFileStore.java       |  6 ++---
 .../ignite/internal/MarshallerPlatformIds.java     |  6 ++---
 .../ignite/internal/NodeStoppingException.java     |  6 ++---
 .../SecurityCredentialsAttrFilterPredicate.java    |  6 ++---
 .../org/apache/ignite/internal/SkipDaemon.java     |  6 ++---
 .../internal/StripedExecutorMXBeanAdapter.java     |  6 ++---
 .../ignite/internal/ThreadPoolMXBeanAdapter.java   |  6 ++---
 .../internal/TransactionMetricsMxBeanImpl.java     |  6 ++---
 .../ignite/internal/TransactionsMXBeanImpl.java    |  6 ++---
 .../internal/UnregisteredBinaryTypeException.java  |  6 ++---
 .../internal/UnregisteredClassException.java       |  6 ++---
 .../binary/BinaryAbstractIdentityResolver.java     |  6 ++---
 .../binary/BinaryArrayIdentityResolver.java        |  6 ++---
 .../binary/BinaryCachingMetadataHandler.java       |  6 ++---
 .../internal/binary/BinaryClassDescriptor.java     |  6 ++---
 .../ignite/internal/binary/BinaryContext.java      |  6 ++---
 .../internal/binary/BinaryContextHolder.java       |  6 ++---
 .../ignite/internal/binary/BinaryEnumCache.java    |  6 ++---
 .../internal/binary/BinaryEnumObjectImpl.java      |  6 ++---
 .../internal/binary/BinaryFieldAccessor.java       |  6 ++---
 .../ignite/internal/binary/BinaryFieldEx.java      |  6 ++---
 .../ignite/internal/binary/BinaryFieldImpl.java    |  6 ++---
 .../internal/binary/BinaryFieldMetadata.java       |  6 ++---
 .../internal/binary/BinaryIdentityResolver.java    |  6 ++---
 .../internal/binary/BinaryInternalMapper.java      |  6 ++---
 .../ignite/internal/binary/BinaryMarshaller.java   |  6 ++---
 .../ignite/internal/binary/BinaryMetadata.java     |  6 ++---
 .../internal/binary/BinaryMetadataCollector.java   |  6 ++---
 .../internal/binary/BinaryMetadataHandler.java     |  6 ++---
 .../internal/binary/BinaryMethodWriteReplacer.java |  6 ++---
 .../internal/binary/BinaryNoopMetadataHandler.java |  6 ++---
 .../ignite/internal/binary/BinaryObjectEx.java     |  6 ++---
 .../ignite/internal/binary/BinaryObjectExImpl.java |  6 ++---
 .../ignite/internal/binary/BinaryObjectImpl.java   |  6 ++---
 .../internal/binary/BinaryObjectOffheapImpl.java   |  6 ++---
 .../internal/binary/BinaryPositionReadable.java    |  6 ++---
 .../ignite/internal/binary/BinaryPrimitives.java   |  6 ++---
 .../ignite/internal/binary/BinaryRawReaderEx.java  |  6 ++---
 .../ignite/internal/binary/BinaryRawWriterEx.java  |  6 ++---
 .../ignite/internal/binary/BinaryReaderExImpl.java |  6 ++---
 .../internal/binary/BinaryReaderHandles.java       |  6 ++---
 .../internal/binary/BinaryReaderHandlesHolder.java |  6 ++---
 .../binary/BinaryReaderHandlesHolderImpl.java      |  6 ++---
 .../ignite/internal/binary/BinarySchema.java       |  6 ++---
 .../internal/binary/BinarySchemaRegistry.java      |  6 ++---
 .../binary/BinarySerializedFieldComparator.java    |  6 ++---
 .../internal/binary/BinaryThreadLocalContext.java  |  6 ++---
 .../ignite/internal/binary/BinaryTreeMap.java      |  6 ++---
 .../binary/BinaryTreeMapWriteReplacer.java         |  6 ++---
 .../ignite/internal/binary/BinaryTreeSet.java      |  6 ++---
 .../binary/BinaryTreeSetWriteReplacer.java         |  6 ++---
 .../ignite/internal/binary/BinaryTypeImpl.java     |  6 ++---
 .../ignite/internal/binary/BinaryTypeProxy.java    |  6 ++---
 .../apache/ignite/internal/binary/BinaryUtils.java |  6 ++---
 .../ignite/internal/binary/BinaryWriteMode.java    |  6 ++---
 .../internal/binary/BinaryWriteReplacer.java       |  6 ++---
 .../ignite/internal/binary/BinaryWriterExImpl.java |  6 ++---
 .../internal/binary/BinaryWriterHandles.java       |  6 ++---
 .../internal/binary/BinaryWriterSchemaHolder.java  |  6 ++---
 .../internal/binary/GridBinaryMarshaller.java      |  6 ++---
 .../binary/builder/BinaryAbstractLazyValue.java    |  6 ++---
 .../internal/binary/builder/BinaryBuilderEnum.java |  6 ++---
 .../binary/builder/BinaryBuilderReader.java        |  6 ++---
 .../builder/BinaryBuilderSerializationAware.java   |  6 ++---
 .../binary/builder/BinaryBuilderSerializer.java    |  6 ++---
 .../binary/builder/BinaryEnumArrayLazyValue.java   |  6 ++---
 .../binary/builder/BinaryLazyArrayList.java        |  6 ++---
 .../binary/builder/BinaryLazyLinkedList.java       |  6 ++---
 .../internal/binary/builder/BinaryLazyMap.java     |  6 ++---
 .../internal/binary/builder/BinaryLazySet.java     |  6 ++---
 .../internal/binary/builder/BinaryLazyValue.java   |  6 ++---
 .../binary/builder/BinaryModifiableLazyValue.java  |  6 ++---
 .../binary/builder/BinaryObjectArrayLazyValue.java |  6 ++---
 .../binary/builder/BinaryObjectBuilderImpl.java    |  6 ++---
 .../binary/builder/BinaryPlainBinaryObject.java    |  6 ++---
 .../binary/builder/BinaryPlainLazyValue.java       |  6 ++---
 .../binary/builder/BinaryValueWithType.java        |  6 ++---
 .../internal/binary/builder/package-info.java      |  6 ++---
 .../ignite/internal/binary/package-info.java       |  6 ++---
 .../binary/streams/BinaryAbstractInputStream.java  |  6 ++---
 .../binary/streams/BinaryAbstractOutputStream.java |  6 ++---
 .../binary/streams/BinaryAbstractStream.java       |  6 ++---
 .../streams/BinaryByteBufferInputStream.java       |  6 ++---
 .../binary/streams/BinaryHeapInputStream.java      |  6 ++---
 .../binary/streams/BinaryHeapOutputStream.java     |  6 ++---
 .../internal/binary/streams/BinaryInputStream.java |  6 ++---
 .../binary/streams/BinaryMemoryAllocator.java      |  6 ++---
 .../binary/streams/BinaryMemoryAllocatorChunk.java |  6 ++---
 .../binary/streams/BinaryOffheapInputStream.java   |  6 ++---
 .../binary/streams/BinaryOffheapOutputStream.java  |  6 ++---
 .../binary/streams/BinaryOutputStream.java         |  6 ++---
 .../internal/binary/streams/BinaryStream.java      |  6 ++---
 .../internal/binary/streams/package-info.java      |  6 ++---
 .../apache/ignite/internal/client/GridClient.java  |  6 ++---
 .../client/GridClientAuthenticationException.java  |  6 ++---
 .../internal/client/GridClientCacheFlag.java       |  6 ++---
 .../internal/client/GridClientCacheMode.java       |  6 ++---
 .../internal/client/GridClientClosedException.java |  6 ++---
 .../internal/client/GridClientClusterState.java    |  6 ++---
 .../ignite/internal/client/GridClientCompute.java  |  6 ++---
 .../internal/client/GridClientConfiguration.java   |  6 ++---
 .../ignite/internal/client/GridClientData.java     |  6 ++---
 .../internal/client/GridClientDataAffinity.java    |  6 ++---
 .../client/GridClientDataConfiguration.java        |  6 ++---
 .../internal/client/GridClientDataMetrics.java     |  6 ++---
 .../client/GridClientDisconnectedException.java    |  6 ++---
 .../internal/client/GridClientException.java       |  6 ++---
 .../ignite/internal/client/GridClientFactory.java  |  6 ++---
 .../ignite/internal/client/GridClientFuture.java   |  6 ++---
 .../internal/client/GridClientFutureListener.java  |  6 ++---
 .../client/GridClientFutureTimeoutException.java   |  6 ++---
 .../client/GridClientHandshakeException.java       |  6 ++---
 .../ignite/internal/client/GridClientNode.java     |  6 ++---
 .../internal/client/GridClientNodeMetrics.java     |  6 ++---
 .../client/GridClientPartitionAffinity.java        |  6 ++---
 .../internal/client/GridClientPredicate.java       |  6 ++---
 .../ignite/internal/client/GridClientProtocol.java |  6 ++---
 .../client/GridClientTopologyListener.java         |  6 ++---
 .../client/GridServerUnreachableException.java     |  6 ++---
 .../client/balancer/GridClientBalancerAdapter.java |  6 ++---
 .../client/balancer/GridClientLoadBalancer.java    |  6 ++---
 .../client/balancer/GridClientRandomBalancer.java  |  6 ++---
 .../balancer/GridClientRoundRobinBalancer.java     |  6 ++---
 .../client/impl/GridClientAbstractProjection.java  |  6 ++---
 .../client/impl/GridClientAndPredicate.java        |  6 ++---
 .../client/impl/GridClientClusterStateImpl.java    |  6 ++---
 .../client/impl/GridClientComputeImpl.java         |  6 ++---
 .../internal/client/impl/GridClientDataImpl.java   |  6 ++---
 .../client/impl/GridClientDataMetricsAdapter.java  |  6 ++---
 .../client/impl/GridClientFutureAdapter.java       |  6 ++---
 .../client/impl/GridClientFutureCallback.java      |  6 ++---
 .../internal/client/impl/GridClientImpl.java       |  6 ++---
 .../internal/client/impl/GridClientNodeImpl.java   |  6 ++---
 .../client/impl/GridClientNodeMetricsAdapter.java  |  6 ++---
 .../client/impl/GridClientThreadFactory.java       |  6 ++---
 .../impl/connection/GridClientConnection.java      |  6 ++---
 .../GridClientConnectionCloseReason.java           |  6 ++---
 .../connection/GridClientConnectionManager.java    |  6 ++---
 .../GridClientConnectionManagerAdapter.java        |  6 ++---
 .../GridClientConnectionManagerOsImpl.java         |  6 ++---
 .../GridClientConnectionResetException.java        |  6 ++---
 .../connection/GridClientNioTcpConnection.java     |  6 ++---
 .../client/impl/connection/GridClientTopology.java |  6 ++---
 .../GridConnectionIdleClosedException.java         |  6 ++---
 .../client/marshaller/GridClientMarshaller.java    |  6 ++---
 .../marshaller/jdk/GridClientJdkMarshaller.java    |  6 ++---
 .../optimized/GridClientOptimizedMarshaller.java   |  6 ++---
 .../GridClientZipOptimizedMarshaller.java          |  6 ++---
 .../internal/client/router/GridRouterFactory.java  |  6 ++---
 .../internal/client/router/GridTcpRouter.java      |  6 ++---
 .../client/router/GridTcpRouterConfiguration.java  |  6 ++---
 .../internal/client/router/GridTcpRouterMBean.java |  6 ++---
 .../client/router/impl/GridRouterClientImpl.java   |  6 ++---
 .../router/impl/GridRouterCommandLineStartup.java  |  6 ++---
 .../client/router/impl/GridTcpRouterImpl.java      |  6 ++---
 .../impl/GridTcpRouterNioListenerAdapter.java      |  6 ++---
 .../impl/GridTcpRouterNioListenerOsImpl.java       |  6 ++---
 .../client/router/impl/GridTcpRouterNioParser.java |  6 ++---
 .../client/ssl/GridSslBasicContextFactory.java     |  6 ++---
 .../internal/client/ssl/GridSslContextFactory.java |  6 ++---
 .../ignite/internal/client/thin/ClientBinary.java  |  6 ++---
 .../client/thin/ClientBinaryMarshaller.java        |  6 ++---
 .../internal/client/thin/ClientCacheEntry.java     |  6 ++---
 .../ignite/internal/client/thin/ClientChannel.java |  6 ++---
 .../client/thin/ClientChannelConfiguration.java    |  6 ++---
 .../ignite/internal/client/thin/ClientError.java   |  6 ++---
 .../client/thin/ClientFieldsQueryCursor.java       |  6 ++---
 .../client/thin/ClientFieldsQueryPager.java        |  6 ++---
 .../internal/client/thin/ClientOperation.java      |  6 ++---
 .../internal/client/thin/ClientProtocolError.java  |  6 ++---
 .../internal/client/thin/ClientQueryCursor.java    |  6 ++---
 .../internal/client/thin/ClientQueryPager.java     |  6 ++---
 .../internal/client/thin/ClientServerError.java    |  6 ++---
 .../ignite/internal/client/thin/ClientUtils.java   |  6 ++---
 .../internal/client/thin/FieldsQueryPager.java     |  6 ++---
 .../internal/client/thin/GenericQueryPager.java    |  6 ++---
 .../internal/client/thin/ProtocolVersion.java      |  6 ++---
 .../ignite/internal/client/thin/QueryPager.java    |  6 ++---
 .../internal/client/thin/ReliableChannel.java      |  6 ++---
 .../apache/ignite/internal/client/thin/Result.java |  6 ++---
 .../internal/client/thin/TcpClientCache.java       |  6 ++---
 .../internal/client/thin/TcpClientChannel.java     |  6 ++---
 .../internal/client/thin/TcpIgniteClient.java      |  6 ++---
 .../client/util/GridClientConsistentHash.java      |  6 ++---
 .../client/util/GridClientStripedLock.java         |  6 ++---
 .../internal/client/util/GridClientUtils.java      |  6 ++---
 .../client/util/GridConcurrentHashSet.java         |  6 ++---
 .../internal/cluster/ClusterGroupAdapter.java      |  6 ++---
 .../cluster/ClusterGroupEmptyCheckedException.java |  6 ++---
 .../ignite/internal/cluster/ClusterGroupEx.java    |  6 ++---
 .../internal/cluster/ClusterNodeLocalMapImpl.java  |  6 ++---
 .../cluster/ClusterStartNodeResultImpl.java        |  6 ++---
 .../cluster/ClusterTopologyCheckedException.java   |  6 ++---
 .../ClusterTopologyServerNotFoundException.java    |  6 ++---
 .../internal/cluster/DetachedClusterNode.java      |  6 ++---
 .../cluster/DistributedBaselineConfiguration.java  |  6 ++---
 .../internal/cluster/IgniteClusterAsyncImpl.java   |  6 ++---
 .../ignite/internal/cluster/IgniteClusterEx.java   |  6 ++---
 .../ignite/internal/cluster/IgniteKillTask.java    |  6 ++---
 .../internal/cluster/NodeOrderComparator.java      |  6 ++---
 .../cluster/NodeOrderLegacyComparator.java         |  6 ++---
 .../internal/cluster/graph/BitSetIterator.java     |  6 ++---
 .../internal/cluster/graph/ClusterGraph.java       |  6 ++---
 .../graph/FullyConnectedComponentSearcher.java     |  6 ++---
 .../ignite/internal/commandline/Arguments.java     |  6 ++---
 .../ignite/internal/commandline/Command.java       |  6 ++---
 .../internal/commandline/CommandHandler.java       |  6 ++---
 .../ignite/internal/commandline/GridConsole.java   |  6 ++---
 .../internal/commandline/GridConsoleAdapter.java   |  6 ++---
 .../ignite/internal/commandline/NoopConsole.java   |  6 ++---
 .../ignite/internal/commandline/OutputFormat.java  |  6 ++---
 .../internal/commandline/argument/CommandArg.java  |  6 ++---
 .../commandline/argument/CommandArgUtils.java      |  6 ++---
 .../commandline/baseline/AutoAdjustCommandArg.java |  6 ++---
 .../commandline/baseline/BaselineArguments.java    |  6 ++---
 .../commandline/baseline/BaselineCommand.java      |  6 ++---
 .../internal/commandline/cache/CacheArguments.java |  6 ++---
 .../internal/commandline/cache/CacheCommand.java   |  6 ++---
 .../cache/argument/DistributionCommandArg.java     |  6 ++---
 .../cache/argument/IdleVerifyCommandArg.java       |  6 ++---
 .../commandline/cache/argument/ListCommandArg.java |  6 ++---
 .../cache/argument/ValidateIndexesCommandArg.java  |  6 ++---
 .../cache/distribution/CacheDistributionGroup.java |  6 ++---
 .../cache/distribution/CacheDistributionNode.java  |  6 ++---
 .../distribution/CacheDistributionPartition.java   |  6 ++---
 .../cache/distribution/CacheDistributionTask.java  |  6 ++---
 .../distribution/CacheDistributionTaskArg.java     |  6 ++---
 .../distribution/CacheDistributionTaskResult.java  |  6 ++---
 .../CacheResetLostPartitionsTask.java              |  6 ++---
 .../CacheResetLostPartitionsTaskArg.java           |  6 ++---
 .../CacheResetLostPartitionsTaskResult.java        |  6 ++---
 .../ComputeTaskCancelledCheckedException.java      |  6 ++---
 .../ComputeTaskTimeoutCheckedException.java        |  6 ++---
 .../internal/direct/DirectMessageReader.java       |  6 ++---
 .../internal/direct/DirectMessageWriter.java       |  6 ++---
 .../internal/direct/state/DirectMessageState.java  |  6 ++---
 .../direct/state/DirectMessageStateItem.java       |  6 ++---
 .../direct/stream/DirectByteBufferStream.java      |  6 ++---
 .../stream/v1/DirectByteBufferStreamImplV1.java    |  6 ++---
 .../stream/v2/DirectByteBufferStreamImplV2.java    |  6 ++---
 .../stream/v3/DirectByteBufferStreamImplV3.java    |  6 ++---
 .../internal/dto/IgniteDataTransferObject.java     |  6 ++---
 .../dto/IgniteDataTransferObjectInput.java         |  6 ++---
 .../dto/IgniteDataTransferObjectOutput.java        |  6 ++---
 .../internal/events/DiscoveryCustomEvent.java      |  6 ++---
 .../internal/executor/GridExecutorService.java     |  6 ++---
 .../ignite/internal/executor/package-info.java     |  6 ++---
 .../internal/igfs/common/IgfsControlResponse.java  |  6 ++---
 .../internal/igfs/common/IgfsDataInputStream.java  |  6 ++---
 .../internal/igfs/common/IgfsDataOutputStream.java |  6 ++---
 .../internal/igfs/common/IgfsHandshakeRequest.java |  6 ++---
 .../internal/igfs/common/IgfsIpcCommand.java       |  6 ++---
 .../ignite/internal/igfs/common/IgfsLogger.java    |  6 ++---
 .../internal/igfs/common/IgfsMarshaller.java       |  6 ++---
 .../ignite/internal/igfs/common/IgfsMessage.java   |  6 ++---
 .../igfs/common/IgfsModeResolverRequest.java       |  6 ++---
 .../igfs/common/IgfsPathControlRequest.java        |  6 ++---
 .../internal/igfs/common/IgfsStatusRequest.java    |  6 ++---
 .../igfs/common/IgfsStreamControlRequest.java      |  6 ++---
 .../ignite/internal/igfs/common/package-info.java  |  6 ++---
 .../ignite/internal/jdbc/JdbcConnection.java       |  6 ++---
 .../ignite/internal/jdbc/JdbcDatabaseMetadata.java |  6 ++---
 .../internal/jdbc/JdbcDriverPropertyInfo.java      |  6 ++---
 .../internal/jdbc/JdbcPreparedStatement.java       |  6 ++---
 .../apache/ignite/internal/jdbc/JdbcResultSet.java |  6 ++---
 .../internal/jdbc/JdbcResultSetMetadata.java       |  6 ++---
 .../apache/ignite/internal/jdbc/JdbcStatement.java |  6 ++---
 .../org/apache/ignite/internal/jdbc/JdbcUtils.java |  6 ++---
 .../ignite/internal/jdbc/thin/AffinityCache.java   |  6 ++---
 .../internal/jdbc/thin/ConnectionProperties.java   |  6 ++---
 .../jdbc/thin/ConnectionPropertiesImpl.java        |  6 ++---
 .../ignite/internal/jdbc/thin/HandshakeResult.java |  6 ++---
 .../JdbcThinAffinityAwarenessMappingGroup.java     |  6 ++---
 .../internal/jdbc/thin/JdbcThinConnection.java     |  6 ++---
 .../jdbc/thin/JdbcThinDatabaseMetadata.java        |  6 ++---
 .../jdbc/thin/JdbcThinParameterMetadata.java       |  6 ++---
 .../thin/JdbcThinPartitionResultDescriptor.java    |  6 ++---
 .../jdbc/thin/JdbcThinPreparedStatement.java       |  6 ++---
 .../internal/jdbc/thin/JdbcThinResultSet.java      |  6 ++---
 .../jdbc/thin/JdbcThinResultSetMetadata.java       |  6 ++---
 .../ignite/internal/jdbc/thin/JdbcThinSSLUtil.java |  6 ++---
 .../internal/jdbc/thin/JdbcThinStatement.java      |  6 ++---
 .../ignite/internal/jdbc/thin/JdbcThinTcpIo.java   |  6 ++---
 .../ignite/internal/jdbc/thin/JdbcThinUtils.java   |  6 ++---
 .../internal/jdbc/thin/QualifiedSQLQuery.java      |  6 ++---
 .../ignite/internal/jdbc2/JdbcBatchUpdateTask.java |  6 ++---
 .../org/apache/ignite/internal/jdbc2/JdbcBlob.java |  6 ++---
 .../ignite/internal/jdbc2/JdbcConnection.java      |  6 ++---
 .../internal/jdbc2/JdbcDatabaseMetadata.java       |  6 ++---
 .../internal/jdbc2/JdbcPreparedStatement.java      |  6 ++---
 .../jdbc2/JdbcQueryMultipleStatementsTask.java     |  6 ++---
 .../ignite/internal/jdbc2/JdbcQueryTask.java       |  6 ++---
 .../ignite/internal/jdbc2/JdbcQueryTaskResult.java |  6 ++---
 .../ignite/internal/jdbc2/JdbcQueryTaskV2.java     |  6 ++---
 .../ignite/internal/jdbc2/JdbcQueryTaskV3.java     |  6 ++---
 .../ignite/internal/jdbc2/JdbcResultSet.java       |  6 ++---
 .../internal/jdbc2/JdbcResultSetMetadata.java      |  6 ++---
 .../ignite/internal/jdbc2/JdbcStatement.java       |  6 ++---
 .../internal/jdbc2/JdbcStatementResultInfo.java    |  6 ++---
 .../jdbc2/JdbcStreamedPreparedStatement.java       |  6 ++---
 .../apache/ignite/internal/jdbc2/JdbcUtils.java    |  6 ++---
 .../internal/logger/platform/PlatformLogger.java   |  6 ++---
 .../ignite/internal/managers/GridManager.java      |  6 ++---
 .../internal/managers/GridManagerAdapter.java      |  6 ++---
 .../internal/managers/IgniteMBeansManager.java     |  6 ++---
 .../managers/checkpoint/GridCheckpointManager.java |  6 ++---
 .../managers/checkpoint/GridCheckpointRequest.java |  6 ++---
 .../internal/managers/checkpoint/package-info.java |  6 ++---
 .../collision/GridCollisionJobContextAdapter.java  |  6 ++---
 .../managers/collision/GridCollisionManager.java   |  6 ++---
 .../internal/managers/collision/package-info.java  |  6 ++---
 .../communication/GridDisconnectListener.java      |  6 ++---
 .../managers/communication/GridIoManager.java      |  6 ++---
 .../managers/communication/GridIoMessage.java      |  6 ++---
 .../communication/GridIoMessageFactory.java        |  6 ++---
 .../managers/communication/GridIoPolicy.java       |  6 ++---
 .../managers/communication/GridIoUserMessage.java  |  6 ++---
 .../communication/GridMessageListener.java         |  6 ++---
 .../communication/IgniteIoTestMessage.java         |  6 ++---
 .../managers/communication/package-info.java       |  6 ++---
 .../managers/deployment/GridDeployment.java        |  6 ++---
 .../deployment/GridDeploymentClassLoader.java      |  6 ++---
 .../deployment/GridDeploymentCommunication.java    |  6 ++---
 .../managers/deployment/GridDeploymentInfo.java    |  6 ++---
 .../deployment/GridDeploymentInfoBean.java         |  6 ++---
 .../deployment/GridDeploymentLocalStore.java       |  6 ++---
 .../managers/deployment/GridDeploymentManager.java |  6 ++---
 .../deployment/GridDeploymentMetadata.java         |  6 ++---
 .../deployment/GridDeploymentPerLoaderStore.java   |  6 ++---
 .../deployment/GridDeploymentPerVersionStore.java  |  6 ++---
 .../managers/deployment/GridDeploymentRequest.java |  6 ++---
 .../deployment/GridDeploymentResponse.java         |  6 ++---
 .../managers/deployment/GridDeploymentStore.java   |  6 ++---
 .../deployment/GridDeploymentStoreAdapter.java     |  6 ++---
 .../internal/managers/deployment/package-info.java |  6 ++---
 .../protocol/gg/GridProtocolHandler.java           |  6 ++---
 .../deployment/protocol/gg/GridUrlConnection.java  |  6 ++---
 .../deployment/protocol/gg/package-info.java       |  6 ++---
 .../managers/discovery/ClusterMetricsImpl.java     |  6 ++---
 .../managers/discovery/ConsistentIdMapper.java     |  6 ++---
 .../managers/discovery/CustomEventListener.java    |  6 ++---
 .../managers/discovery/CustomMessageWrapper.java   |  6 ++---
 .../internal/managers/discovery/DiscoCache.java    |  6 ++---
 .../managers/discovery/DiscoveryCustomMessage.java |  6 ++---
 .../managers/discovery/DiscoveryLocalJoinData.java |  6 ++---
 .../DiscoveryMessageResultsCollector.java          |  6 ++---
 .../DiscoveryServerOnlyCustomMessage.java          |  6 ++---
 .../managers/discovery/GridDiscoveryManager.java   |  6 ++---
 .../discovery/GridDiscoveryTopologySnapshot.java   |  6 ++---
 .../managers/discovery/GridLocalMetrics.java       |  6 ++---
 .../managers/discovery/IgniteClusterNode.java      |  6 ++---
 .../managers/discovery/IgniteDiscoverySpi.java     |  6 ++---
 .../IgniteDiscoverySpiInternalListener.java        |  6 ++---
 .../internal/managers/discovery/package-info.java  |  6 ++---
 .../encryption/GenerateEncryptionKeyRequest.java   |  6 ++---
 .../encryption/GenerateEncryptionKeyResponse.java  |  6 ++---
 .../managers/encryption/GridEncryptionManager.java |  6 ++---
 .../eventstorage/DiscoveryEventListener.java       |  6 ++---
 .../eventstorage/GridEventStorageManager.java      |  6 ++---
 .../eventstorage/GridEventStorageMessage.java      |  6 ++---
 .../eventstorage/GridLocalEventListener.java       |  6 ++---
 .../eventstorage/HighPriorityListener.java         |  6 ++---
 .../managers/eventstorage/package-info.java        |  6 ++---
 .../managers/failover/GridFailoverContextImpl.java |  6 ++---
 .../managers/failover/GridFailoverManager.java     |  6 ++---
 .../internal/managers/failover/package-info.java   |  6 ++---
 .../managers/indexing/GridIndexingManager.java     |  6 ++---
 .../internal/managers/indexing/package-info.java   |  6 ++---
 .../loadbalancer/GridLoadBalancerAdapter.java      |  6 ++---
 .../loadbalancer/GridLoadBalancerManager.java      |  6 ++---
 .../managers/loadbalancer/package-info.java        |  6 ++---
 .../ignite/internal/managers/package-info.java     |  6 ++---
 .../optimized/OptimizedClassDescriptor.java        |  6 ++---
 .../marshaller/optimized/OptimizedFieldType.java   |  6 ++---
 .../marshaller/optimized/OptimizedMarshaller.java  |  6 ++---
 .../optimized/OptimizedMarshallerIdMapper.java     |  6 ++---
 .../optimized/OptimizedMarshallerUtils.java        |  6 ++---
 .../optimized/OptimizedObjectInputStream.java      |  6 ++---
 .../optimized/OptimizedObjectOutputStream.java     |  6 ++---
 .../optimized/OptimizedObjectStreamRegistry.java   |  6 ++---
 .../marshaller/optimized/package-info.java         |  6 ++---
 .../ignite/internal/mem/DirectMemoryProvider.java  |  6 ++---
 .../ignite/internal/mem/DirectMemoryRegion.java    |  6 ++---
 .../internal/mem/IgniteOutOfMemoryException.java   |  6 ++---
 .../apache/ignite/internal/mem/UnsafeChunk.java    |  6 ++---
 .../ignite/internal/mem/file/MappedFile.java       |  6 ++---
 .../mem/file/MappedFileMemoryProvider.java         |  6 ++---
 .../internal/mem/unsafe/UnsafeMemoryProvider.java  |  6 ++---
 .../internal/mxbean/IgniteStandardMXBean.java      |  6 ++---
 .../ignite/internal/mxbean/package-info.java       |  6 ++---
 .../org/apache/ignite/internal/package-info.java   |  6 ++---
 .../apache/ignite/internal/pagemem/FullPageId.java |  6 ++---
 .../ignite/internal/pagemem/PageIdAllocator.java   |  6 ++---
 .../ignite/internal/pagemem/PageIdUtils.java       |  6 ++---
 .../apache/ignite/internal/pagemem/PageMemory.java |  6 ++---
 .../ignite/internal/pagemem/PageSupport.java       |  6 ++---
 .../apache/ignite/internal/pagemem/PageUtils.java  |  6 ++---
 .../pagemem/impl/PageMemoryNoStoreImpl.java        |  6 ++---
 .../pagemem/store/IgnitePageStoreManager.java      |  6 ++---
 .../ignite/internal/pagemem/store/PageStore.java   |  6 ++---
 .../pagemem/wal/IgniteWriteAheadLogManager.java    |  6 ++---
 .../ignite/internal/pagemem/wal/WALIterator.java   |  6 ++---
 .../ignite/internal/pagemem/wal/WALPointer.java    |  6 ++---
 .../internal/pagemem/wal/record/CacheState.java    |  6 ++---
 .../pagemem/wal/record/CheckpointRecord.java       |  6 ++---
 .../pagemem/wal/record/ConsistentCutRecord.java    |  6 ++---
 .../internal/pagemem/wal/record/DataEntry.java     |  6 ++---
 .../internal/pagemem/wal/record/DataRecord.java    |  6 ++---
 .../pagemem/wal/record/EncryptedRecord.java        |  6 ++---
 .../pagemem/wal/record/ExchangeRecord.java         |  6 ++---
 .../pagemem/wal/record/FilteredRecord.java         |  6 ++---
 .../internal/pagemem/wal/record/LazyDataEntry.java |  6 ++---
 .../pagemem/wal/record/LazyMvccDataEntry.java      |  6 ++---
 .../pagemem/wal/record/MarshalledDataEntry.java    |  6 ++---
 .../pagemem/wal/record/MarshalledRecord.java       |  6 ++---
 .../pagemem/wal/record/MemoryRecoveryRecord.java   |  6 ++---
 .../pagemem/wal/record/MetastoreDataRecord.java    |  6 ++---
 .../internal/pagemem/wal/record/MvccDataEntry.java |  6 ++---
 .../pagemem/wal/record/MvccDataRecord.java         |  6 ++---
 .../internal/pagemem/wal/record/MvccTxRecord.java  |  6 ++---
 .../internal/pagemem/wal/record/PageSnapshot.java  |  6 ++---
 .../internal/pagemem/wal/record/RolloverType.java  |  6 ++---
 .../pagemem/wal/record/SnapshotRecord.java         |  6 ++---
 .../pagemem/wal/record/SwitchSegmentRecord.java    |  6 ++---
 .../pagemem/wal/record/TimeStampRecord.java        |  6 ++---
 .../internal/pagemem/wal/record/TxRecord.java      |  6 ++---
 .../pagemem/wal/record/UnwrapDataEntry.java        |  6 ++---
 .../pagemem/wal/record/UnwrapMvccDataEntry.java    |  6 ++---
 .../pagemem/wal/record/UnwrappedDataEntry.java     |  6 ++---
 .../internal/pagemem/wal/record/WALRecord.java     |  6 ++---
 .../wal/record/WalRecordCacheGroupAware.java       |  6 ++---
 .../record/delta/DataPageInsertFragmentRecord.java |  6 ++---
 .../wal/record/delta/DataPageInsertRecord.java     |  6 ++---
 .../delta/DataPageMvccMarkUpdatedRecord.java       |  6 ++---
 .../DataPageMvccUpdateNewTxStateHintRecord.java    |  6 ++---
 .../delta/DataPageMvccUpdateTxStateHintRecord.java |  6 ++---
 .../wal/record/delta/DataPageRemoveRecord.java     |  6 ++---
 .../delta/DataPageSetFreeListPageRecord.java       |  6 ++---
 .../wal/record/delta/DataPageUpdateRecord.java     |  6 ++---
 .../record/delta/DeltaApplicationException.java    |  6 ++---
 .../pagemem/wal/record/delta/FixCountRecord.java   |  6 ++---
 .../wal/record/delta/FixLeftmostChildRecord.java   |  6 ++---
 .../pagemem/wal/record/delta/FixRemoveId.java      |  6 ++---
 .../wal/record/delta/InitNewPageRecord.java        |  6 ++---
 .../wal/record/delta/InnerReplaceRecord.java       |  6 ++---
 .../pagemem/wal/record/delta/InsertRecord.java     |  6 ++---
 .../pagemem/wal/record/delta/MergeRecord.java      |  6 ++---
 .../wal/record/delta/MetaPageAddRootRecord.java    |  6 ++---
 .../wal/record/delta/MetaPageCutRootRecord.java    |  6 ++---
 .../wal/record/delta/MetaPageInitRecord.java       |  6 ++---
 .../record/delta/MetaPageInitRootInlineRecord.java |  6 ++---
 .../wal/record/delta/MetaPageInitRootRecord.java   |  6 ++---
 .../delta/MetaPageUpdateLastAllocatedIndex.java    |  6 ++---
 ...MetaPageUpdateLastSuccessfulFullSnapshotId.java |  6 ++---
 .../MetaPageUpdateLastSuccessfulSnapshotId.java    |  6 ++---
 .../record/delta/MetaPageUpdateNextSnapshotId.java |  6 ++---
 .../delta/MetaPageUpdatePartitionDataRecord.java   |  6 ++---
 .../wal/record/delta/NewRootInitRecord.java        |  6 ++---
 .../pagemem/wal/record/delta/PageDeltaRecord.java  |  6 ++---
 .../record/delta/PageListMetaResetCountRecord.java |  6 ++---
 .../wal/record/delta/PagesListAddPageRecord.java   |  6 ++---
 .../record/delta/PagesListInitNewPageRecord.java   |  6 ++---
 .../record/delta/PagesListRemovePageRecord.java    |  6 ++---
 .../wal/record/delta/PagesListSetNextRecord.java   |  6 ++---
 .../record/delta/PagesListSetPreviousRecord.java   |  6 ++---
 .../wal/record/delta/PartitionDestroyRecord.java   |  6 ++---
 .../wal/record/delta/PartitionMetaStateRecord.java |  6 ++---
 .../pagemem/wal/record/delta/RecycleRecord.java    |  6 ++---
 .../pagemem/wal/record/delta/RemoveRecord.java     |  6 ++---
 .../pagemem/wal/record/delta/ReplaceRecord.java    |  6 ++---
 .../wal/record/delta/RotatedIdPartRecord.java      |  6 ++---
 .../wal/record/delta/SplitExistingPageRecord.java  |  6 ++---
 .../wal/record/delta/SplitForwardPageRecord.java   |  6 ++---
 .../wal/record/delta/TrackingPageDeltaRecord.java  |  6 ++---
 .../ignite/internal/processors/GridProcessor.java  |  6 ++---
 .../internal/processors/GridProcessorAdapter.java  |  6 ++---
 .../processors/affinity/AffinityAssignment.java    |  6 ++---
 .../affinity/AffinityTopologyVersion.java          |  6 ++---
 .../affinity/GridAffinityAssignment.java           |  6 ++---
 .../affinity/GridAffinityAssignmentCache.java      |  6 ++---
 .../affinity/GridAffinityAssignmentV2.java         |  6 ++---
 .../affinity/GridAffinityFunctionContextImpl.java  |  6 ++---
 .../processors/affinity/GridAffinityMessage.java   |  6 ++---
 .../processors/affinity/GridAffinityProcessor.java |  6 ++---
 .../processors/affinity/GridAffinityUtils.java     |  6 ++---
 .../affinity/HistoryAffinityAssignment.java        |  6 ++---
 .../affinity/HistoryAffinityAssignmentImpl.java    |  6 ++---
 .../HistoryAffinityAssignmentShallowCopy.java      |  6 ++---
 .../affinity/IdealAffinityAssignment.java          |  6 ++---
 .../internal/processors/affinity/package-info.java |  6 ++---
 .../authentication/AuthorizationContext.java       |  6 ++---
 .../IgniteAccessControlException.java              |  6 ++---
 .../IgniteAuthenticationProcessor.java             |  6 ++---
 .../internal/processors/authentication/User.java   |  6 ++---
 .../authentication/UserAcceptedMessage.java        |  6 ++---
 .../UserAuthenticateRequestMessage.java            |  6 ++---
 .../UserAuthenticateResponseMessage.java           |  6 ++---
 .../authentication/UserManagementException.java    |  6 ++---
 .../authentication/UserManagementOperation.java    |  6 ++---
 .../UserManagementOperationFinishedMessage.java    |  6 ++---
 .../authentication/UserProposedMessage.java        |  6 ++---
 .../bulkload/BulkLoadAckClientParameters.java      |  6 ++---
 .../processors/bulkload/BulkLoadCacheWriter.java   |  6 ++---
 .../processors/bulkload/BulkLoadCsvFormat.java     |  6 ++---
 .../processors/bulkload/BulkLoadCsvParser.java     |  6 ++---
 .../processors/bulkload/BulkLoadFormat.java        |  6 ++---
 .../processors/bulkload/BulkLoadParser.java        |  6 ++---
 .../processors/bulkload/BulkLoadProcessor.java     |  6 ++---
 .../bulkload/BulkLoadStreamerWriter.java           |  6 ++---
 .../bulkload/pipeline/CharsetDecoderBlock.java     |  6 ++---
 .../bulkload/pipeline/CsvLineProcessorBlock.java   |  6 ++---
 .../bulkload/pipeline/LineSplitterBlock.java       |  6 ++---
 .../bulkload/pipeline/PipelineBlock.java           |  6 ++---
 .../bulkload/pipeline/StrListAppenderBlock.java    |  6 ++---
 .../cache/AutoClosableCursorIterator.java          |  6 ++---
 .../cache/CacheAffinityChangeMessage.java          |  6 ++---
 .../cache/CacheAffinitySharedManager.java          |  6 ++---
 .../processors/cache/CacheClassLoaderMarker.java   |  6 ++---
 .../cache/CacheClientReconnectDiscoveryData.java   |  6 ++---
 .../cache/CacheClusterMetricsMXBeanImpl.java       |  6 ++---
 .../processors/cache/CacheCompressionManager.java  |  6 ++---
 .../cache/CacheConfigurationEnricher.java          |  6 ++---
 .../cache/CacheConfigurationEnrichment.java        |  6 ++---
 .../cache/CacheConfigurationOverride.java          |  6 ++---
 .../cache/CacheConfigurationSplitter.java          |  6 ++---
 .../cache/CacheConfigurationSplitterImpl.java      |  6 ++---
 .../cache/CacheConfigurationSplitterOldFormat.java |  6 ++---
 .../cache/CacheConflictResolutionManager.java      |  6 ++---
 .../internal/processors/cache/CacheData.java       |  6 ++---
 .../cache/CacheDefaultBinaryAffinityKeyMapper.java |  6 ++---
 .../internal/processors/cache/CacheEntryImpl.java  |  6 ++---
 .../internal/processors/cache/CacheEntryImpl0.java |  6 ++---
 .../processors/cache/CacheEntryImplEx.java         |  6 ++---
 .../processors/cache/CacheEntryInfoCollection.java |  6 ++---
 .../processors/cache/CacheEntryPredicate.java      |  6 ++---
 .../cache/CacheEntryPredicateAdapter.java          |  6 ++---
 .../cache/CacheEntryPredicateContainsValue.java    |  6 ++---
 .../cache/CacheEntryPredicateHasValue.java         |  6 ++---
 .../cache/CacheEntryPredicateNoValue.java          |  6 ++---
 .../cache/CacheEntrySerializablePredicate.java     |  6 ++---
 .../processors/cache/CacheEvictableEntryImpl.java  |  6 ++---
 .../processors/cache/CacheEvictionEntry.java       |  6 ++---
 .../processors/cache/CacheEvictionManager.java     |  6 ++---
 .../processors/cache/CacheGroupContext.java        |  6 ++---
 .../internal/processors/cache/CacheGroupData.java  |  6 ++---
 .../processors/cache/CacheGroupDescriptor.java     |  6 ++---
 .../cache/CacheGroupMetricsMXBeanImpl.java         |  6 ++---
 .../cache/CacheInvalidStateException.java          |  6 ++---
 .../processors/cache/CacheInvokeDirectResult.java  |  6 ++---
 .../processors/cache/CacheInvokeEntry.java         |  6 ++---
 .../processors/cache/CacheInvokeResult.java        |  6 ++---
 .../processors/cache/CacheIteratorConverter.java   |  6 ++---
 .../cache/CacheJoinNodeDiscoveryData.java          |  6 ++---
 .../internal/processors/cache/CacheLazyEntry.java  |  6 ++---
 .../cache/CacheLocalMetricsMXBeanImpl.java         |  6 ++---
 .../processors/cache/CacheLockCandidates.java      |  6 ++---
 .../processors/cache/CacheLockCandidatesList.java  |  6 ++---
 .../internal/processors/cache/CacheLockImpl.java   |  6 ++---
 .../processors/cache/CacheMetricsImpl.java         |  6 ++---
 .../processors/cache/CacheMetricsSnapshot.java     |  6 ++---
 .../processors/cache/CacheMetricsSnapshotV2.java   |  6 ++---
 .../cache/CacheNodeCommonDiscoveryData.java        |  6 ++---
 .../internal/processors/cache/CacheObject.java     |  6 ++---
 .../processors/cache/CacheObjectAdapter.java       |  6 ++---
 .../processors/cache/CacheObjectByteArrayImpl.java |  6 ++---
 .../processors/cache/CacheObjectContext.java       |  6 ++---
 .../internal/processors/cache/CacheObjectImpl.java |  6 ++---
 .../processors/cache/CacheObjectUtils.java         |  6 ++---
 .../processors/cache/CacheObjectValueContext.java  |  6 ++---
 .../cache/CacheObjectsReleaseFuture.java           |  6 ++---
 .../cache/CacheOffheapEvictionManager.java         |  6 ++---
 .../processors/cache/CacheOperationContext.java    |  6 ++---
 .../processors/cache/CacheOperationFilter.java     |  6 ++---
 .../cache/CacheOsConflictResolutionManager.java    |  6 ++---
 .../cache/CachePartialUpdateCheckedException.java  |  6 ++---
 .../cache/CachePartitionExchangeWorkerTask.java    |  6 ++---
 .../internal/processors/cache/CachePeekModes.java  |  6 ++---
 .../cache/CacheStatisticsClearMessage.java         |  6 ++---
 .../cache/CacheStatisticsModeChangeMessage.java    |  6 ++---
 .../cache/CacheStatisticsModeChangeTask.java       |  6 ++---
 .../processors/cache/CacheStoppedException.java    |  6 ++---
 .../cache/CacheStoreBalancingWrapper.java          |  6 ++---
 .../cache/CacheStorePartialUpdateException.java    |  6 ++---
 .../internal/processors/cache/CacheType.java       |  6 ++---
 .../cache/CacheWeakQueryIteratorsHolder.java       |  6 ++---
 .../internal/processors/cache/CachesRegistry.java  |  6 ++---
 .../cache/ClientCacheChangeDiscoveryMessage.java   |  6 ++---
 .../ClientCacheChangeDummyDiscoveryMessage.java    |  6 ++---
 .../processors/cache/ClientCacheUpdateTimeout.java |  6 ++---
 .../processors/cache/ClusterCachesInfo.java        |  6 ++---
 .../cache/ClusterCachesReconnectResult.java        |  6 ++---
 .../processors/cache/DynamicCacheChangeBatch.java  |  6 ++---
 .../cache/DynamicCacheChangeFailureMessage.java    |  6 ++---
 .../cache/DynamicCacheChangeRequest.java           |  6 ++---
 .../processors/cache/DynamicCacheDescriptor.java   |  6 ++---
 .../internal/processors/cache/EntryGetResult.java  |  6 ++---
 .../processors/cache/EntryGetWithTtlResult.java    |  6 ++---
 .../cache/EntryProcessorResourceInjectorProxy.java |  6 ++---
 .../internal/processors/cache/ExchangeActions.java |  6 ++---
 .../internal/processors/cache/ExchangeContext.java |  6 ++---
 .../processors/cache/ExchangeDiscoveryEvents.java  |  6 ++---
 .../cache/FetchActiveTxOwnerTraceClosure.java      |  6 ++---
 .../cache/GatewayProtectedCacheProxy.java          |  6 ++---
 .../processors/cache/GridCacheAdapter.java         |  6 ++---
 .../processors/cache/GridCacheAffinityManager.java |  6 ++---
 .../processors/cache/GridCacheAtomicFuture.java    |  6 ++---
 .../cache/GridCacheAtomicVersionComparator.java    |  6 ++---
 .../processors/cache/GridCacheAttributes.java      |  6 ++---
 .../cache/GridCacheClearAllRunnable.java           |  6 ++---
 .../processors/cache/GridCacheCompoundFuture.java  |  6 ++---
 .../cache/GridCacheCompoundIdentityFuture.java     |  6 ++---
 .../processors/cache/GridCacheConcurrentMap.java   |  6 ++---
 .../cache/GridCacheConcurrentMapImpl.java          |  6 ++---
 .../processors/cache/GridCacheContext.java         |  6 ++---
 .../processors/cache/GridCacheContextInfo.java     |  6 ++---
 .../cache/GridCacheDefaultAffinityKeyMapper.java   |  6 ++---
 .../processors/cache/GridCacheDeployable.java      |  6 ++---
 .../cache/GridCacheDeploymentManager.java          |  6 ++---
 .../processors/cache/GridCacheEntryEx.java         |  6 ++---
 .../processors/cache/GridCacheEntryInfo.java       |  6 ++---
 .../cache/GridCacheEntryRedeployException.java     |  6 ++---
 .../cache/GridCacheEntryRemovedException.java      |  6 ++---
 .../processors/cache/GridCacheEventManager.java    |  6 ++---
 .../processors/cache/GridCacheEvictionManager.java |  6 ++---
 .../cache/GridCacheExplicitLockSpan.java           |  6 ++---
 .../cache/GridCacheFilterFailedException.java      |  6 ++---
 .../internal/processors/cache/GridCacheFuture.java |  6 ++---
 .../processors/cache/GridCacheFutureAdapter.java   |  6 ++---
 .../processors/cache/GridCacheGateway.java         |  6 ++---
 .../processors/cache/GridCacheGroupIdMessage.java  |  6 ++---
 .../processors/cache/GridCacheIdMessage.java       |  6 ++---
 .../cache/GridCacheIndexUpdateException.java       |  6 ++---
 .../processors/cache/GridCacheInternal.java        |  6 ++---
 .../processors/cache/GridCacheIoManager.java       |  6 ++---
 .../processors/cache/GridCacheIterator.java        |  6 ++---
 .../cache/GridCacheLoaderWriterStore.java          |  6 ++---
 .../cache/GridCacheLoaderWriterStoreFactory.java   |  6 ++---
 .../cache/GridCacheLocalConcurrentMap.java         |  6 ++---
 .../processors/cache/GridCacheLockCallback.java    |  6 ++---
 .../cache/GridCacheLockTimeoutException.java       |  6 ++---
 .../internal/processors/cache/GridCacheLogger.java |  6 ++---
 .../processors/cache/GridCacheManager.java         |  6 ++---
 .../processors/cache/GridCacheManagerAdapter.java  |  6 ++---
 .../processors/cache/GridCacheMapEntry.java        |  6 ++---
 .../processors/cache/GridCacheMapEntryFactory.java |  6 ++---
 .../processors/cache/GridCacheMessage.java         |  6 ++---
 .../processors/cache/GridCacheMultiTxFuture.java   |  6 ++---
 .../internal/processors/cache/GridCacheMvcc.java   |  6 ++---
 .../processors/cache/GridCacheMvccCandidate.java   |  6 ++---
 .../processors/cache/GridCacheMvccEntryInfo.java   |  6 ++---
 .../processors/cache/GridCacheMvccManager.java     |  6 ++---
 .../processors/cache/GridCacheOperation.java       |  6 ++---
 .../cache/GridCachePartitionExchangeManager.java   |  6 ++---
 .../processors/cache/GridCachePreloader.java       |  6 ++---
 .../cache/GridCachePreloaderAdapter.java           |  6 ++---
 .../processors/cache/GridCacheProcessor.java       |  6 ++---
 .../processors/cache/GridCacheProxyImpl.java       |  6 ++---
 .../internal/processors/cache/GridCacheReturn.java |  6 ++---
 .../cache/GridCacheReturnCompletableWrapper.java   |  6 ++---
 .../processors/cache/GridCacheSharedContext.java   |  6 ++---
 .../processors/cache/GridCacheSharedManager.java   |  6 ++---
 .../cache/GridCacheSharedManagerAdapter.java       |  6 ++---
 .../cache/GridCacheSharedTtlCleanupManager.java    |  6 ++---
 .../processors/cache/GridCacheTtlManager.java      |  6 ++---
 .../cache/GridCacheUpdateAtomicResult.java         |  6 ++---
 .../processors/cache/GridCacheUpdateTxResult.java  |  6 ++---
 .../processors/cache/GridCacheUtilityKey.java      |  6 ++---
 .../internal/processors/cache/GridCacheUtils.java  |  6 ++---
 .../processors/cache/GridCacheValueCollection.java |  6 ++---
 .../processors/cache/GridCacheVersionedFuture.java |  6 ++---
 .../GridChangeGlobalStateMessageResponse.java      |  6 ++---
 .../cache/GridDeferredAckMessageSender.java        |  6 ++---
 .../processors/cache/GridNoStorageCacheMap.java    |  6 ++---
 .../processors/cache/IgniteCacheExpiryPolicy.java  |  6 ++---
 .../processors/cache/IgniteCacheFutureImpl.java    |  6 ++---
 .../cache/IgniteCacheOffheapManager.java           |  6 ++---
 .../cache/IgniteCacheOffheapManagerImpl.java       |  6 ++---
 .../processors/cache/IgniteCacheProxy.java         |  6 ++---
 .../processors/cache/IgniteCacheProxyImpl.java     |  6 ++---
 .../cache/IgniteFinishedCacheFutureImpl.java       |  6 ++---
 .../processors/cache/IgniteInternalCache.java      |  6 ++---
 .../processors/cache/IgniteRebalanceIterator.java  |  6 ++---
 .../processors/cache/IncompleteCacheObject.java    |  6 ++---
 .../processors/cache/IncompleteObject.java         |  6 ++---
 .../internal/processors/cache/KeyCacheObject.java  |  6 ++---
 .../processors/cache/KeyCacheObjectImpl.java       |  6 ++---
 .../processors/cache/LocalJoinCachesContext.java   |  6 ++---
 .../processors/cache/PartitionUpdateCounter.java   |  6 ++---
 .../processors/cache/PendingDiscoveryEvent.java    |  6 ++---
 .../internal/processors/cache/QueryCursorImpl.java |  6 ++---
 .../internal/processors/cache/ReaderArguments.java |  6 ++---
 .../internal/processors/cache/StartCacheInfo.java  |  6 ++---
 .../processors/cache/StateChangeRequest.java       |  6 ++---
 .../internal/processors/cache/StoredCacheData.java |  6 ++---
 .../TxOwnerDumpRequestAllowedSettingClosure.java   |  6 ++---
 ...TimeoutOnPartitionMapExchangeChangeMessage.java |  6 ++---
 .../TxTimeoutOnPartitionMapExchangeChangeTask.java |  6 ++---
 .../processors/cache/WalStateAbstractMessage.java  |  6 ++---
 .../processors/cache/WalStateAckMessage.java       |  6 ++---
 .../cache/WalStateDistributedProcess.java          |  6 ++---
 .../processors/cache/WalStateFinishMessage.java    |  6 ++---
 .../internal/processors/cache/WalStateManager.java |  6 ++---
 .../cache/WalStateNodeLeaveExchangeTask.java       |  6 ++---
 .../processors/cache/WalStateProposeMessage.java   |  6 ++---
 .../internal/processors/cache/WalStateResult.java  |  6 ++---
 .../cache/affinity/GridCacheAffinityImpl.java      |  6 ++---
 .../cache/affinity/GridCacheAffinityProxy.java     |  6 ++---
 .../cache/binary/BinaryMetadataFileStore.java      |  6 ++---
 .../cache/binary/BinaryMetadataHolder.java         |  6 ++---
 .../processors/cache/binary/BinaryMetadataKey.java |  6 ++---
 .../cache/binary/BinaryMetadataTransport.java      |  6 ++---
 .../binary/BinaryMetadataUpdatedListener.java      |  6 ++---
 .../binary/CacheObjectBinaryProcessorImpl.java     |  6 ++---
 .../cache/binary/ClientMetadataRequestFuture.java  |  6 ++---
 .../processors/cache/binary/IgniteBinaryImpl.java  |  6 ++---
 .../cache/binary/MetadataRequestMessage.java       |  6 ++---
 .../cache/binary/MetadataResponseMessage.java      |  6 ++---
 .../binary/MetadataUpdateAcceptedMessage.java      |  6 ++---
 .../binary/MetadataUpdateProposedMessage.java      |  6 ++---
 .../cache/binary/MetadataUpdateResult.java         |  6 ++---
 .../processors/cache/binary/package-info.java      |  6 ++---
 .../datastructures/CacheDataStructuresManager.java |  6 ++---
 .../cache/distributed/GridCacheMappedVersion.java  |  6 ++---
 .../distributed/GridCacheTtlUpdateRequest.java     |  6 ++---
 .../cache/distributed/GridCacheTxFinishSync.java   |  6 ++---
 .../distributed/GridCacheTxRecoveryFuture.java     |  6 ++---
 .../distributed/GridCacheTxRecoveryRequest.java    |  6 ++---
 .../distributed/GridCacheTxRecoveryResponse.java   |  6 ++---
 .../distributed/GridDistributedBaseMessage.java    |  6 ++---
 .../distributed/GridDistributedCacheAdapter.java   |  6 ++---
 .../distributed/GridDistributedCacheEntry.java     |  6 ++---
 .../GridDistributedLockCancelledException.java     |  6 ++---
 .../distributed/GridDistributedLockRequest.java    |  6 ++---
 .../distributed/GridDistributedLockResponse.java   |  6 ++---
 .../GridDistributedTxFinishRequest.java            |  6 ++---
 .../GridDistributedTxFinishResponse.java           |  6 ++---
 .../distributed/GridDistributedTxMapping.java      |  6 ++---
 .../GridDistributedTxPrepareRequest.java           |  6 ++---
 .../GridDistributedTxPrepareResponse.java          |  6 ++---
 .../GridDistributedTxRemoteAdapter.java            |  6 ++---
 .../distributed/GridDistributedUnlockRequest.java  |  6 ++---
 .../IgniteExternalizableExpiryPolicy.java          |  6 ++---
 .../dht/CacheDistributedGetFutureAdapter.java      |  6 ++---
 .../cache/distributed/dht/CacheGetFuture.java      |  6 ++---
 .../dht/ClientCacheDhtTopologyFuture.java          |  6 ++---
 .../cache/distributed/dht/DhtLockFuture.java       |  6 ++---
 .../cache/distributed/dht/ExceptionAware.java      |  6 ++---
 .../dht/GridCachePartitionedConcurrentMap.java     |  6 ++---
 .../dht/GridDhtAffinityAssignmentRequest.java      |  6 ++---
 .../dht/GridDhtAffinityAssignmentResponse.java     |  6 ++---
 .../dht/GridDhtAssignmentFetchFuture.java          |  6 ++---
 .../cache/distributed/dht/GridDhtCache.java        |  6 ++---
 .../cache/distributed/dht/GridDhtCacheAdapter.java |  6 ++---
 .../cache/distributed/dht/GridDhtCacheEntry.java   |  6 ++---
 .../distributed/dht/GridDhtEmbeddedFuture.java     |  6 ++---
 .../distributed/dht/GridDhtFinishedFuture.java     |  6 ++---
 .../cache/distributed/dht/GridDhtFuture.java       |  6 ++---
 .../cache/distributed/dht/GridDhtGetFuture.java    |  6 ++---
 .../distributed/dht/GridDhtGetSingleFuture.java    |  6 ++---
 .../cache/distributed/dht/GridDhtLockFuture.java   |  6 ++---
 .../cache/distributed/dht/GridDhtLockRequest.java  |  6 ++---
 .../cache/distributed/dht/GridDhtLockResponse.java |  6 ++---
 .../distributed/dht/GridDhtTopologyFuture.java     |  6 ++---
 .../dht/GridDhtTopologyFutureAdapter.java          |  6 ++---
 .../dht/GridDhtTransactionalCacheAdapter.java      |  6 ++---
 .../dht/GridDhtTxAbstractEnlistFuture.java         |  6 ++---
 .../distributed/dht/GridDhtTxEnlistFuture.java     |  6 ++---
 .../distributed/dht/GridDhtTxFinishFuture.java     |  6 ++---
 .../distributed/dht/GridDhtTxFinishRequest.java    |  6 ++---
 .../distributed/dht/GridDhtTxFinishResponse.java   |  6 ++---
 .../cache/distributed/dht/GridDhtTxLocal.java      |  6 ++---
 .../distributed/dht/GridDhtTxLocalAdapter.java     |  6 ++---
 .../cache/distributed/dht/GridDhtTxMapping.java    |  6 ++---
 .../dht/GridDhtTxOnePhaseCommitAckRequest.java     |  6 ++---
 .../distributed/dht/GridDhtTxPrepareFuture.java    |  6 ++---
 .../distributed/dht/GridDhtTxPrepareRequest.java   |  6 ++---
 .../distributed/dht/GridDhtTxPrepareResponse.java  |  6 ++---
 .../dht/GridDhtTxQueryAbstractEnlistFuture.java    |  6 ++---
 .../dht/GridDhtTxQueryEnlistFuture.java            |  6 ++---
 .../dht/GridDhtTxQueryEnlistRequest.java           |  6 ++---
 .../dht/GridDhtTxQueryEnlistResponse.java          |  6 ++---
 .../dht/GridDhtTxQueryFirstEnlistRequest.java      |  6 ++---
 .../dht/GridDhtTxQueryResultsEnlistFuture.java     |  6 ++---
 .../cache/distributed/dht/GridDhtTxRemote.java     |  6 ++---
 .../distributed/dht/GridDhtUnlockRequest.java      |  6 ++---
 .../dht/GridDhtUnreservedPartitionException.java   |  6 ++---
 .../cache/distributed/dht/GridInvokeValue.java     |  6 ++---
 .../distributed/dht/GridPartitionedGetFuture.java  |  6 ++---
 .../dht/GridPartitionedSingleGetFuture.java        |  6 ++---
 .../cache/distributed/dht/GridReservable.java      |  6 ++---
 .../dht/NearTxQueryEnlistResultHandler.java        |  6 ++---
 .../cache/distributed/dht/NearTxResultHandler.java |  6 ++---
 .../dht/PartitionUpdateCountersMessage.java        |  6 ++---
 .../dht/atomic/DhtAtomicUpdateResult.java          |  6 ++---
 .../atomic/GridDhtAtomicAbstractUpdateFuture.java  |  6 ++---
 .../atomic/GridDhtAtomicAbstractUpdateRequest.java |  6 ++---
 .../distributed/dht/atomic/GridDhtAtomicCache.java |  6 ++---
 .../GridDhtAtomicDeferredUpdateResponse.java       |  6 ++---
 .../dht/atomic/GridDhtAtomicNearResponse.java      |  6 ++---
 .../atomic/GridDhtAtomicSingleUpdateFuture.java    |  6 ++---
 .../atomic/GridDhtAtomicSingleUpdateRequest.java   |  6 ++---
 .../dht/atomic/GridDhtAtomicUpdateFuture.java      |  6 ++---
 .../dht/atomic/GridDhtAtomicUpdateRequest.java     |  6 ++---
 .../dht/atomic/GridDhtAtomicUpdateResponse.java    |  6 ++---
 .../GridNearAtomicAbstractSingleUpdateRequest.java |  6 ++---
 .../atomic/GridNearAtomicAbstractUpdateFuture.java |  6 ++---
 .../GridNearAtomicAbstractUpdateRequest.java       |  6 ++---
 .../atomic/GridNearAtomicCheckUpdateRequest.java   |  6 ++---
 .../atomic/GridNearAtomicFullUpdateRequest.java    |  6 ++---
 .../GridNearAtomicSingleUpdateFilterRequest.java   |  6 ++---
 .../atomic/GridNearAtomicSingleUpdateFuture.java   |  6 ++---
 .../GridNearAtomicSingleUpdateInvokeRequest.java   |  6 ++---
 .../atomic/GridNearAtomicSingleUpdateRequest.java  |  6 ++---
 .../dht/atomic/GridNearAtomicUpdateFuture.java     |  6 ++---
 .../dht/atomic/GridNearAtomicUpdateResponse.java   |  6 ++---
 .../distributed/dht/atomic/NearCacheUpdates.java   |  6 ++---
 .../cache/distributed/dht/atomic/UpdateErrors.java |  6 ++---
 .../dht/colocated/GridDhtColocatedCache.java       |  6 ++---
 .../dht/colocated/GridDhtColocatedLockFuture.java  |  6 ++---
 .../dht/colocated/GridDhtDetachedCacheEntry.java   |  6 ++---
 .../dht/preloader/CacheGroupAffinityMessage.java   |  6 ++---
 .../preloader/CachePartitionFullCountersMap.java   |  6 ++---
 .../CachePartitionPartialCountersMap.java          |  6 ++---
 .../dht/preloader/ForceRebalanceExchangeTask.java  |  6 ++---
 .../dht/preloader/GridDhtForceKeysFuture.java      |  6 ++---
 .../dht/preloader/GridDhtForceKeysRequest.java     |  6 ++---
 .../dht/preloader/GridDhtForceKeysResponse.java    |  6 ++---
 .../GridDhtPartitionDemandLegacyMessage.java       |  6 ++---
 .../preloader/GridDhtPartitionDemandMessage.java   |  6 ++---
 .../dht/preloader/GridDhtPartitionDemander.java    |  6 ++---
 .../dht/preloader/GridDhtPartitionExchangeId.java  |  6 ++---
 .../dht/preloader/GridDhtPartitionFullMap.java     |  6 ++---
 .../dht/preloader/GridDhtPartitionMap.java         |  6 ++---
 .../dht/preloader/GridDhtPartitionSupplier.java    |  6 ++---
 .../preloader/GridDhtPartitionSupplyMessage.java   |  6 ++---
 .../preloader/GridDhtPartitionSupplyMessageV2.java |  6 ++---
 .../GridDhtPartitionsAbstractMessage.java          |  6 ++---
 .../preloader/GridDhtPartitionsExchangeFuture.java |  6 ++---
 .../preloader/GridDhtPartitionsFullMessage.java    |  6 ++---
 .../preloader/GridDhtPartitionsSingleMessage.java  |  6 ++---
 .../preloader/GridDhtPartitionsSingleRequest.java  |  6 ++---
 .../dht/preloader/GridDhtPreloader.java            |  6 ++---
 .../dht/preloader/GridDhtPreloaderAssignments.java |  6 ++---
 .../preloader/IgniteDhtDemandedPartitionsMap.java  |  6 ++---
 .../preloader/IgniteDhtPartitionCountersMap.java   |  6 ++---
 .../preloader/IgniteDhtPartitionCountersMap2.java  |  6 ++---
 .../IgniteDhtPartitionHistorySuppliersMap.java     |  6 ++---
 .../preloader/IgniteDhtPartitionsToReloadMap.java  |  6 ++---
 .../dht/preloader/IgniteHistoricalIterator.java    |  6 ++---
 .../dht/preloader/IgniteRebalanceIteratorImpl.java |  6 ++---
 .../dht/preloader/InitNewCoordinatorFuture.java    |  6 ++---
 .../preloader/RebalanceReassignExchangeTask.java   |  6 ++---
 .../StopCachesOnClientReconnectExchangeTask.java   |  6 ++---
 .../dht/preloader/latch/ExchangeLatchManager.java  |  6 ++---
 .../distributed/dht/preloader/latch/Latch.java     |  6 ++---
 .../dht/preloader/latch/LatchAckMessage.java       |  6 ++---
 .../distributed/dht/topology/EvictionContext.java  |  6 ++---
 .../dht/topology/GridClientPartitionTopology.java  |  6 ++---
 .../topology/GridDhtInvalidPartitionException.java |  6 ++---
 .../dht/topology/GridDhtLocalPartition.java        |  6 ++---
 .../dht/topology/GridDhtPartitionState.java        |  6 ++---
 .../dht/topology/GridDhtPartitionTopology.java     |  6 ++---
 .../dht/topology/GridDhtPartitionTopologyImpl.java |  6 ++---
 .../dht/topology/GridDhtPartitionsReservation.java |  6 ++---
 .../topology/GridDhtPartitionsStateValidator.java  |  6 ++---
 .../dht/topology/PartitionsEvictManager.java       |  6 ++---
 .../distributed/near/CacheVersionedValue.java      |  6 ++---
 .../distributed/near/GridNearAtomicCache.java      |  6 ++---
 .../distributed/near/GridNearCacheAdapter.java     |  6 ++---
 .../near/GridNearCacheClearAllRunnable.java        |  6 ++---
 .../cache/distributed/near/GridNearCacheEntry.java |  6 ++---
 .../cache/distributed/near/GridNearGetFuture.java  |  6 ++---
 .../cache/distributed/near/GridNearGetRequest.java |  6 ++---
 .../distributed/near/GridNearGetResponse.java      |  6 ++---
 .../cache/distributed/near/GridNearLockFuture.java |  6 ++---
 .../distributed/near/GridNearLockMapping.java      |  6 ++---
 .../distributed/near/GridNearLockRequest.java      |  6 ++---
 .../distributed/near/GridNearLockResponse.java     |  6 ++---
 ...dNearOptimisticSerializableTxPrepareFuture.java |  6 ++---
 .../near/GridNearOptimisticTxPrepareFuture.java    |  6 ++---
 .../GridNearOptimisticTxPrepareFutureAdapter.java  |  6 ++---
 .../near/GridNearPessimisticTxPrepareFuture.java   |  6 ++---
 .../distributed/near/GridNearSingleGetRequest.java |  6 ++---
 .../near/GridNearSingleGetResponse.java            |  6 ++---
 .../near/GridNearTransactionalCache.java           |  6 ++---
 .../near/GridNearTxAbstractEnlistFuture.java       |  6 ++---
 .../distributed/near/GridNearTxEnlistFuture.java   |  6 ++---
 .../distributed/near/GridNearTxEnlistRequest.java  |  6 ++---
 .../distributed/near/GridNearTxEnlistResponse.java |  6 ++---
 .../near/GridNearTxFastFinishFuture.java           |  6 ++---
 .../near/GridNearTxFinishAndAckFuture.java         |  6 ++---
 .../distributed/near/GridNearTxFinishFuture.java   |  6 ++---
 .../distributed/near/GridNearTxFinishRequest.java  |  6 ++---
 .../distributed/near/GridNearTxFinishResponse.java |  6 ++---
 .../cache/distributed/near/GridNearTxLocal.java    |  6 ++---
 .../near/GridNearTxPrepareFutureAdapter.java       |  6 ++---
 .../distributed/near/GridNearTxPrepareRequest.java |  6 ++---
 .../near/GridNearTxPrepareResponse.java            |  6 ++---
 .../near/GridNearTxQueryAbstractEnlistFuture.java  |  6 ++---
 .../near/GridNearTxQueryEnlistFuture.java          |  6 ++---
 .../near/GridNearTxQueryEnlistRequest.java         |  6 ++---
 .../near/GridNearTxQueryEnlistResponse.java        |  6 ++---
 .../near/GridNearTxQueryResultsEnlistFuture.java   |  6 ++---
 .../near/GridNearTxQueryResultsEnlistRequest.java  |  6 ++---
 .../near/GridNearTxQueryResultsEnlistResponse.java |  6 ++---
 .../cache/distributed/near/GridNearTxRemote.java   |  6 ++---
 .../distributed/near/GridNearUnlockRequest.java    |  6 ++---
 .../cache/distributed/near/IgniteTxMappings.java   |  6 ++---
 .../distributed/near/IgniteTxMappingsImpl.java     |  6 ++---
 .../near/IgniteTxMappingsSingleImpl.java           |  6 ++---
 .../cache/distributed/near/NearTxFinishFuture.java |  6 ++---
 .../cache/dr/GridCacheDrExpirationInfo.java        |  6 ++---
 .../processors/cache/dr/GridCacheDrInfo.java       |  6 ++---
 .../processors/cache/dr/GridCacheDrManager.java    |  6 ++---
 .../processors/cache/dr/GridOsCacheDrManager.java  |  6 ++---
 .../extras/GridCacheAttributesEntryExtras.java     |  6 ++---
 .../extras/GridCacheAttributesMvccEntryExtras.java |  6 ++---
 ...GridCacheAttributesMvccObsoleteEntryExtras.java |  6 ++---
 ...dCacheAttributesMvccObsoleteTtlEntryExtras.java |  6 ++---
 .../GridCacheAttributesMvccTtlEntryExtras.java     |  6 ++---
 .../GridCacheAttributesObsoleteEntryExtras.java    |  6 ++---
 .../GridCacheAttributesObsoleteTtlEntryExtras.java |  6 ++---
 .../extras/GridCacheAttributesTtlEntryExtras.java  |  6 ++---
 .../cache/extras/GridCacheEntryExtras.java         |  6 ++---
 .../cache/extras/GridCacheEntryExtrasAdapter.java  |  6 ++---
 .../cache/extras/GridCacheMvccEntryExtras.java     |  6 ++---
 .../extras/GridCacheMvccObsoleteEntryExtras.java   |  6 ++---
 .../GridCacheMvccObsoleteTtlEntryExtras.java       |  6 ++---
 .../cache/extras/GridCacheMvccTtlEntryExtras.java  |  6 ++---
 .../cache/extras/GridCacheObsoleteEntryExtras.java |  6 ++---
 .../extras/GridCacheObsoleteTtlEntryExtras.java    |  6 ++---
 .../cache/extras/GridCacheTtlEntryExtras.java      |  6 ++---
 .../cache/jta/CacheJtaManagerAdapter.java          |  6 ++---
 .../processors/cache/jta/CacheNoopJtaManager.java  |  6 ++---
 .../processors/cache/local/GridLocalCache.java     |  6 ++---
 .../cache/local/GridLocalCacheEntry.java           |  6 ++---
 .../cache/local/GridLocalLockCallback.java         |  6 ++---
 .../cache/local/GridLocalLockFuture.java           |  6 ++---
 .../cache/local/atomic/GridLocalAtomicCache.java   |  6 ++---
 .../cache/mvcc/DeadlockDetectionManager.java       |  6 ++---
 .../processors/cache/mvcc/DeadlockProbe.java       |  6 ++---
 .../processors/cache/mvcc/MvccCachingManager.java  |  6 ++---
 .../processors/cache/mvcc/MvccCoordinator.java     |  6 ++---
 .../cache/mvcc/MvccCoordinatorChangeAware.java     |  6 ++---
 .../processors/cache/mvcc/MvccEmptyLongList.java   |  6 ++---
 .../internal/processors/cache/mvcc/MvccFuture.java |  6 ++---
 .../processors/cache/mvcc/MvccLongList.java        |  6 ++---
 .../processors/cache/mvcc/MvccProcessor.java       |  6 ++---
 .../processors/cache/mvcc/MvccProcessorImpl.java   |  6 ++---
 .../processors/cache/mvcc/MvccQueryTracker.java    |  6 ++---
 .../cache/mvcc/MvccQueryTrackerImpl.java           |  6 ++---
 .../processors/cache/mvcc/MvccSnapshot.java        |  6 ++---
 .../processors/cache/mvcc/MvccSnapshotFuture.java  |  6 ++---
 .../cache/mvcc/MvccSnapshotResponseListener.java   |  6 ++---
 .../cache/mvcc/MvccSnapshotWithoutTxs.java         |  6 ++---
 .../processors/cache/mvcc/MvccTxEntry.java         |  6 ++---
 .../cache/mvcc/MvccUpdateVersionAware.java         |  6 ++---
 .../internal/processors/cache/mvcc/MvccUtils.java  |  6 ++---
 .../processors/cache/mvcc/MvccVersion.java         |  6 ++---
 .../processors/cache/mvcc/MvccVersionAware.java    |  6 ++---
 .../processors/cache/mvcc/MvccVersionImpl.java     |  6 ++---
 .../processors/cache/mvcc/PreviousQueries.java     |  6 ++---
 .../internal/processors/cache/mvcc/ProbedTx.java   |  6 ++---
 .../cache/mvcc/StaticMvccQueryTracker.java         |  6 ++---
 .../processors/cache/mvcc/VacuumMetrics.java       |  6 ++---
 .../cache/mvcc/VacuumMetricsReducer.java           |  6 ++---
 .../internal/processors/cache/mvcc/VacuumTask.java |  6 ++---
 .../cache/mvcc/msg/MvccAckRequestQueryCntr.java    |  6 ++---
 .../cache/mvcc/msg/MvccAckRequestQueryId.java      |  6 ++---
 .../cache/mvcc/msg/MvccAckRequestTx.java           |  6 ++---
 .../mvcc/msg/MvccAckRequestTxAndQueryCntr.java     |  6 ++---
 .../cache/mvcc/msg/MvccAckRequestTxAndQueryId.java |  6 ++---
 .../cache/mvcc/msg/MvccActiveQueriesMessage.java   |  6 ++---
 .../cache/mvcc/msg/MvccFutureResponse.java         |  6 ++---
 .../processors/cache/mvcc/msg/MvccMessage.java     |  6 ++---
 .../cache/mvcc/msg/MvccQuerySnapshotRequest.java   |  6 ++---
 .../mvcc/msg/MvccRecoveryFinishedMessage.java      |  6 ++---
 .../cache/mvcc/msg/MvccSnapshotResponse.java       |  6 ++---
 .../cache/mvcc/msg/MvccTxSnapshotRequest.java      |  6 ++---
 .../msg/PartitionCountersNeighborcastRequest.java  |  6 ++---
 .../msg/PartitionCountersNeighborcastResponse.java |  6 ++---
 .../processors/cache/mvcc/txlog/TxKey.java         |  6 ++---
 .../processors/cache/mvcc/txlog/TxLog.java         |  6 ++---
 .../processors/cache/mvcc/txlog/TxLogIO.java       |  6 ++---
 .../processors/cache/mvcc/txlog/TxLogInnerIO.java  |  6 ++---
 .../processors/cache/mvcc/txlog/TxLogLeafIO.java   |  6 ++---
 .../processors/cache/mvcc/txlog/TxLogTree.java     |  6 ++---
 .../processors/cache/mvcc/txlog/TxRow.java         |  6 ++---
 .../processors/cache/mvcc/txlog/TxState.java       |  6 ++---
 .../internal/processors/cache/package-info.java    |  6 ++---
 .../cache/persistence/AllocatedPageTracker.java    |  6 ++---
 .../processors/cache/persistence/CacheDataRow.java |  6 ++---
 .../cache/persistence/CacheDataRowAdapter.java     |  6 ++---
 .../cache/persistence/CacheSearchRow.java          |  6 ++---
 .../cache/persistence/CheckpointFuture.java        |  6 ++---
 .../persistence/CheckpointLockStateChecker.java    |  6 ++---
 .../CheckpointWriteProgressSupplier.java           |  6 ++---
 .../persistence/CorruptedPersistenceException.java |  6 ++---
 .../processors/cache/persistence/DataRegion.java   |  6 ++---
 .../cache/persistence/DataRegionMetricsImpl.java   |  6 ++---
 .../persistence/DataRegionMetricsMXBeanImpl.java   |  6 ++---
 .../persistence/DataRegionMetricsSnapshot.java     |  6 ++---
 .../cache/persistence/DataStorageMXBeanImpl.java   |  6 ++---
 .../cache/persistence/DataStorageMetricsImpl.java  |  6 ++---
 .../persistence/DataStorageMetricsSnapshot.java    |  6 ++---
 .../cache/persistence/DataStructure.java           |  6 ++---
 .../persistence/DatabaseLifecycleListener.java     |  6 ++---
 .../cache/persistence/DbCheckpointListener.java    |  6 ++---
 .../GridCacheDatabaseSharedManager.java            |  6 ++---
 .../cache/persistence/GridCacheOffheapManager.java |  6 ++---
 .../IgniteCacheDatabaseSharedManager.java          |  6 ++---
 .../processors/cache/persistence/IndexStorage.java |  6 ++---
 .../cache/persistence/IndexStorageImpl.java        |  6 ++---
 .../cache/persistence/RecoveryDebug.java           |  6 ++---
 .../processors/cache/persistence/RootPage.java     |  6 ++---
 .../processors/cache/persistence/RowStore.java     |  6 ++---
 .../processors/cache/persistence/Storable.java     |  6 ++---
 .../cache/persistence/StorageException.java        |  6 ++---
 .../persistence/checkpoint/CheckpointEntry.java    |  6 ++---
 .../checkpoint/CheckpointEntryType.java            |  6 ++---
 .../persistence/checkpoint/CheckpointHistory.java  |  6 ++---
 .../evict/FairFifoPageEvictionTracker.java         |  6 ++---
 .../persistence/evict/NoOpPageEvictionTracker.java |  6 ++---
 .../evict/PageAbstractEvictionTracker.java         |  6 ++---
 .../persistence/evict/PageEvictionTracker.java     |  6 ++---
 .../evict/Random2LruPageEvictionTracker.java       |  6 ++---
 .../evict/RandomLruPageEvictionTracker.java        |  6 ++---
 .../cache/persistence/file/AbstractFileIO.java     |  6 ++---
 .../cache/persistence/file/AsyncFileIO.java        |  6 ++---
 .../cache/persistence/file/AsyncFileIOFactory.java |  6 ++---
 .../cache/persistence/file/EncryptedFileIO.java    |  6 ++---
 .../persistence/file/EncryptedFileIOFactory.java   |  6 ++---
 .../cache/persistence/file/FileDownloader.java     |  6 ++---
 .../processors/cache/persistence/file/FileIO.java  |  6 ++---
 .../cache/persistence/file/FileIODecorator.java    |  6 ++---
 .../cache/persistence/file/FileIOFactory.java      |  6 ++---
 .../cache/persistence/file/FilePageStore.java      |  6 ++---
 .../persistence/file/FilePageStoreFactory.java     |  6 ++---
 .../persistence/file/FilePageStoreManager.java     |  6 ++---
 .../cache/persistence/file/FilePageStoreV2.java    |  6 ++---
 .../cache/persistence/file/FileUploader.java       |  6 ++---
 .../file/FileVersionCheckingFactory.java           |  6 ++---
 .../cache/persistence/file/RandomAccessFileIO.java |  6 ++---
 .../file/RandomAccessFileIOFactory.java            |  6 ++---
 .../cache/persistence/file/UnzipFileIO.java        |  6 ++---
 .../filename/PdsConsistentIdProcessor.java         |  6 ++---
 .../persistence/filename/PdsFolderSettings.java    |  6 ++---
 .../persistence/filename/PdsFoldersResolver.java   |  6 ++---
 .../persistence/freelist/AbstractFreeList.java     |  6 ++---
 .../persistence/freelist/CacheFreeListImpl.java    |  6 ++---
 .../freelist/CorruptedFreeListException.java       |  6 ++---
 .../cache/persistence/freelist/FreeList.java       |  6 ++---
 .../cache/persistence/freelist/PagesList.java      |  6 ++---
 .../persistence/freelist/io/PagesListMetaIO.java   |  6 ++---
 .../persistence/freelist/io/PagesListNodeIO.java   |  6 ++---
 .../cache/persistence/metastorage/MetaStorage.java |  6 ++---
 .../metastorage/MetastorageDataRow.java            |  6 ++---
 .../metastorage/MetastorageLifecycleListener.java  |  6 ++---
 .../metastorage/MetastorageRowStore.java           |  6 ++---
 .../metastorage/MetastorageSearchRow.java          |  6 ++---
 .../persistence/metastorage/MetastorageTree.java   |  6 ++---
 .../metastorage/MetsatorageSearchRowImpl.java      |  6 ++---
 .../metastorage/ReadOnlyMetastorage.java           |  6 ++---
 .../metastorage/ReadWriteMetastorage.java          |  6 ++---
 .../UpgradePendingTreeToPerPartitionTask.java      |  6 ++---
 .../processors/cache/persistence/package-info.java |  6 ++---
 .../pagemem/CheckpointMetricsTracker.java          |  6 ++---
 .../persistence/pagemem/DelayedDirtyPageWrite.java |  6 ++---
 .../pagemem/DelayedPageReplacementTracker.java     |  6 ++---
 .../cache/persistence/pagemem/FullPageIdTable.java |  6 ++---
 .../pagemem/IntervalBasedMeasurement.java          |  6 ++---
 .../cache/persistence/pagemem/LoadedPagesMap.java  |  6 ++---
 .../cache/persistence/pagemem/PageMemoryEx.java    |  6 ++---
 .../cache/persistence/pagemem/PageMemoryImpl.java  |  6 ++---
 .../pagemem/PagesWriteSpeedBasedThrottle.java      |  6 ++---
 .../persistence/pagemem/PagesWriteThrottle.java    |  6 ++---
 .../pagemem/PagesWriteThrottlePolicy.java          |  6 ++---
 .../persistence/pagemem/ReplaceCandidate.java      |  6 ++---
 .../persistence/pagemem/ReplacedPageWriter.java    |  6 ++---
 .../pagemem/RobinHoodBackwardShiftHashMap.java     |  6 ++---
 .../cache/persistence/pagemem/package-info.java    |  6 ++---
 .../persistence/partstate/GroupPartitionId.java    |  6 ++---
 .../partstate/PagesAllocationRange.java            |  6 ++---
 .../partstate/PartitionAllocationMap.java          |  6 ++---
 .../partstate/PartitionRecoverState.java           |  6 ++---
 .../snapshot/IgniteCacheSnapshotManager.java       |  6 ++---
 .../snapshot/SnapshotDiscoveryMessage.java         |  6 ++---
 .../persistence/snapshot/SnapshotOperation.java    |  6 ++---
 .../snapshot/TrackingPageIsCorruptedException.java |  6 ++---
 .../cache/persistence/tree/BPlusTree.java          |  6 ++---
 .../persistence/tree/CorruptedTreeException.java   |  6 ++---
 .../persistence/tree/io/AbstractDataPageIO.java    |  6 ++---
 .../cache/persistence/tree/io/BPlusIO.java         |  6 ++---
 .../cache/persistence/tree/io/BPlusInnerIO.java    |  6 ++---
 .../cache/persistence/tree/io/BPlusLeafIO.java     |  6 ++---
 .../cache/persistence/tree/io/BPlusMetaIO.java     |  6 ++---
 .../cache/persistence/tree/io/CacheVersionIO.java  |  6 ++---
 .../persistence/tree/io/CompactablePageIO.java     |  6 ++---
 .../cache/persistence/tree/io/DataPageIO.java      |  6 ++---
 .../cache/persistence/tree/io/DataPagePayload.java |  6 ++---
 .../cache/persistence/tree/io/IOVersions.java      |  6 ++---
 .../cache/persistence/tree/io/PageIO.java          |  6 ++---
 .../cache/persistence/tree/io/PageMetaIO.java      |  6 ++---
 .../tree/io/PagePartitionCountersIO.java           |  6 ++---
 .../persistence/tree/io/PagePartitionMetaIO.java   |  6 ++---
 .../persistence/tree/io/PagePartitionMetaIOV2.java |  6 ++---
 .../persistence/tree/io/SimpleDataPageIO.java      |  6 ++---
 .../cache/persistence/tree/io/TrackingPageIO.java  |  6 ++---
 .../persistence/tree/reuse/LongListReuseBag.java   |  6 ++---
 .../cache/persistence/tree/reuse/ReuseBag.java     |  6 ++---
 .../cache/persistence/tree/reuse/ReuseList.java    |  6 ++---
 .../persistence/tree/reuse/ReuseListImpl.java      |  6 ++---
 .../cache/persistence/tree/util/PageHandler.java   |  6 ++---
 .../persistence/tree/util/PageHandlerWrapper.java  |  6 ++---
 .../persistence/tree/util/PageLockListener.java    |  6 ++---
 .../wal/AbstractWalRecordsIterator.java            |  6 ++---
 .../persistence/wal/ByteBufferBackedDataInput.java |  6 ++---
 .../wal/ByteBufferBackedDataInputImpl.java         |  6 ++---
 .../cache/persistence/wal/ByteBufferExpander.java  |  6 ++---
 .../cache/persistence/wal/FileDescriptor.java      |  6 ++---
 .../cache/persistence/wal/FileWALPointer.java      |  6 ++---
 .../persistence/wal/FileWriteAheadLogManager.java  |  6 ++---
 .../persistence/wal/SegmentArchiveResult.java      |  6 ++---
 .../cache/persistence/wal/SegmentEofException.java |  6 ++---
 .../cache/persistence/wal/SegmentRouter.java       |  6 ++---
 .../persistence/wal/SegmentedRingByteBuffer.java   |  6 ++---
 .../wal/SingleSegmentLogicalRecordsIterator.java   |  6 ++---
 .../wal/WalSegmentTailReachedException.java        |  6 ++---
 .../wal/aware/SegmentArchivedStorage.java          |  6 ++---
 .../cache/persistence/wal/aware/SegmentAware.java  |  6 ++---
 .../wal/aware/SegmentCompressStorage.java          |  6 ++---
 .../wal/aware/SegmentCurrentStateStorage.java      |  6 ++---
 .../persistence/wal/aware/SegmentLockStorage.java  |  6 ++---
 .../persistence/wal/aware/SegmentObservable.java   |  6 ++---
 .../wal/aware/SegmentReservationStorage.java       |  6 ++---
 .../cache/persistence/wal/crc/FastCrc.java         |  6 ++---
 .../crc/IgniteDataIntegrityViolationException.java |  6 ++---
 .../cache/persistence/wal/crc/PureJavaCrc32.java   |  6 ++---
 .../wal/filehandle/AbstractFileHandle.java         |  6 ++---
 .../wal/filehandle/FileHandleManager.java          |  6 ++---
 .../wal/filehandle/FileHandleManagerFactory.java   |  6 ++---
 .../wal/filehandle/FileHandleManagerImpl.java      |  6 ++---
 .../wal/filehandle/FileWriteHandle.java            |  6 ++---
 .../wal/filehandle/FileWriteHandleImpl.java        |  6 ++---
 .../wal/filehandle/FsyncFileHandleManagerImpl.java |  6 ++---
 .../wal/filehandle/FsyncFileWriteHandle.java       |  6 ++---
 .../cache/persistence/wal/io/FileInput.java        |  6 ++---
 .../persistence/wal/io/LockedReadFileInput.java    |  6 ++---
 .../wal/io/LockedSegmentFileInputFactory.java      |  6 ++---
 .../wal/io/SegmentFileInputFactory.java            |  6 ++---
 .../cache/persistence/wal/io/SegmentIO.java        |  6 ++---
 .../cache/persistence/wal/io/SimpleFileInput.java  |  6 ++---
 .../wal/io/SimpleSegmentFileInputFactory.java      |  6 ++---
 .../wal/reader/IgniteWalIteratorFactory.java       |  6 ++---
 .../wal/reader/StandaloneGridKernalContext.java    |  6 ++---
 ...StandaloneIgniteCacheDatabaseSharedManager.java |  6 ++---
 .../reader/StandaloneIgnitePluginProcessor.java    |  6 ++---
 .../wal/reader/StandaloneNoopCommunicationSpi.java |  6 ++---
 .../wal/reader/StandaloneNoopDiscoverySpi.java     |  6 ++---
 .../wal/reader/StandaloneWalRecordsIterator.java   |  6 ++---
 .../wal/reader/StrictBoundsCheckException.java     |  6 ++---
 .../cache/persistence/wal/record/HeaderRecord.java |  6 ++---
 .../cache/persistence/wal/record/RecordTypes.java  |  6 ++---
 .../wal/serializer/RecordDataSerializer.java       |  6 ++---
 .../wal/serializer/RecordDataV1Serializer.java     |  6 ++---
 .../wal/serializer/RecordDataV2Serializer.java     |  6 ++---
 .../wal/serializer/RecordSerializer.java           |  6 ++---
 .../wal/serializer/RecordSerializerFactory.java    |  6 ++---
 .../serializer/RecordSerializerFactoryImpl.java    |  6 ++---
 .../wal/serializer/RecordV1Serializer.java         |  6 ++---
 .../wal/serializer/RecordV2Serializer.java         |  6 ++---
 .../persistence/wal/serializer/SegmentHeader.java  |  6 ++---
 .../wal/serializer/TxRecordSerializer.java         |  6 ++---
 .../persistence/wal/serializer/io/RecordIO.java    |  6 ++---
 .../processors/cache/query/CacheQuery.java         |  6 ++---
 .../processors/cache/query/CacheQueryEntry.java    |  6 ++---
 .../processors/cache/query/CacheQueryFuture.java   |  6 ++---
 .../processors/cache/query/CacheQueryType.java     |  6 ++---
 .../GridCacheDistributedFieldsQueryFuture.java     |  6 ++---
 .../query/GridCacheDistributedQueryFuture.java     |  6 ++---
 .../query/GridCacheDistributedQueryManager.java    |  6 ++---
 .../query/GridCacheLocalFieldsQueryFuture.java     |  6 ++---
 .../cache/query/GridCacheLocalQueryFuture.java     |  6 ++---
 .../cache/query/GridCacheLocalQueryManager.java    |  6 ++---
 .../cache/query/GridCacheQueryAdapter.java         |  6 ++---
 .../processors/cache/query/GridCacheQueryBean.java |  6 ++---
 .../query/GridCacheQueryDetailMetricsAdapter.java  |  6 ++---
 .../query/GridCacheQueryDetailMetricsKey.java      |  6 ++---
 .../cache/query/GridCacheQueryErrorFuture.java     |  6 ++---
 .../cache/query/GridCacheQueryFutureAdapter.java   |  6 ++---
 .../processors/cache/query/GridCacheQueryInfo.java |  6 ++---
 .../cache/query/GridCacheQueryManager.java         |  6 ++---
 .../cache/query/GridCacheQueryMarshallable.java    |  6 ++---
 .../cache/query/GridCacheQueryMetadataAware.java   |  6 ++---
 .../cache/query/GridCacheQueryMetricsAdapter.java  |  6 ++---
 .../cache/query/GridCacheQueryMetricsKey.java      |  6 ++---
 .../cache/query/GridCacheQueryRequest.java         |  6 ++---
 .../cache/query/GridCacheQueryResponse.java        |  6 ++---
 .../cache/query/GridCacheQueryResponseEntry.java   |  6 ++---
 .../query/GridCacheQuerySqlMetadataJobV2.java      |  6 ++---
 .../cache/query/GridCacheQuerySqlMetadataV2.java   |  6 ++---
 .../processors/cache/query/GridCacheQueryType.java |  6 ++---
 .../cache/query/GridCacheSqlIndexMetadata.java     |  6 ++---
 .../cache/query/GridCacheSqlMetadata.java          |  6 ++---
 .../processors/cache/query/GridCacheSqlQuery.java  |  6 ++---
 .../cache/query/IgniteQueryErrorCode.java          |  6 ++---
 .../processors/cache/query/QueryCursorEx.java      |  6 ++---
 .../cache/query/QueryEntityClassProperty.java      |  6 ++---
 .../cache/query/QueryEntityIndexDescriptor.java    |  6 ++---
 .../cache/query/QueryEntityTypeDescriptor.java     |  6 ++---
 .../processors/cache/query/SqlFieldsQueryEx.java   |  6 ++---
 .../CacheContinuousQueryAcknowledgeBuffer.java     |  6 ++---
 .../continuous/CacheContinuousQueryBatchAck.java   |  6 ++---
 .../CacheContinuousQueryDeployableObject.java      |  6 ++---
 .../continuous/CacheContinuousQueryEntry.java      |  6 ++---
 .../continuous/CacheContinuousQueryEvent.java      |  6 ++---
 .../CacheContinuousQueryEventBuffer.java           |  6 ++---
 .../continuous/CacheContinuousQueryHandler.java    |  6 ++---
 .../continuous/CacheContinuousQueryHandlerV2.java  |  6 ++---
 .../continuous/CacheContinuousQueryHandlerV3.java  |  6 ++---
 .../continuous/CacheContinuousQueryListener.java   |  6 ++---
 .../continuous/CacheContinuousQueryManager.java    |  6 ++---
 .../CacheContinuousQueryPartitionRecovery.java     |  6 ++---
 .../cache/query/continuous/CounterSkipContext.java |  6 ++---
 .../query/jdbc/GridCacheQueryJdbcMetadataTask.java |  6 ++---
 .../cache/query/jdbc/GridCacheQueryJdbcTask.java   |  6 ++---
 .../jdbc/GridCacheQueryJdbcValidationTask.java     |  6 ++---
 .../cache/ratemetrics/HitRateMetrics.java          |  6 ++---
 .../cache/ratemetrics/HitRateMetricsSandbox.java   |  6 ++---
 .../processors/cache/store/CacheLocalStore.java    |  6 ++---
 .../cache/store/CacheOsStoreManager.java           |  6 ++---
 .../processors/cache/store/CacheStoreManager.java  |  6 ++---
 .../cache/store/GridCacheStoreManagerAdapter.java  |  6 ++---
 .../cache/store/GridCacheWriteBehindStore.java     |  6 ++---
 .../cache/transactions/IgniteInternalTx.java       |  6 ++---
 .../cache/transactions/IgniteTransactionsImpl.java |  6 ++---
 .../cache/transactions/IgniteTxAdapter.java        |  6 ++---
 .../cache/transactions/IgniteTxEntry.java          |  6 ++---
 .../cache/transactions/IgniteTxHandler.java        |  6 ++---
 .../IgniteTxImplicitSingleStateImpl.java           |  6 ++---
 .../processors/cache/transactions/IgniteTxKey.java |  6 ++---
 .../cache/transactions/IgniteTxLocalAdapter.java   |  6 ++---
 .../cache/transactions/IgniteTxLocalEx.java        |  6 ++---
 .../cache/transactions/IgniteTxLocalState.java     |  6 ++---
 .../transactions/IgniteTxLocalStateAdapter.java    |  6 ++---
 .../cache/transactions/IgniteTxManager.java        |  6 ++---
 .../processors/cache/transactions/IgniteTxMap.java |  6 ++---
 .../cache/transactions/IgniteTxRemoteEx.java       |  6 ++---
 .../IgniteTxRemoteSingleStateImpl.java             |  6 ++---
 .../cache/transactions/IgniteTxRemoteState.java    |  6 ++---
 .../transactions/IgniteTxRemoteStateAdapter.java   |  6 ++---
 .../transactions/IgniteTxRemoteStateImpl.java      |  6 ++---
 .../cache/transactions/IgniteTxState.java          |  6 ++---
 .../cache/transactions/IgniteTxStateAware.java     |  6 ++---
 .../cache/transactions/IgniteTxStateImpl.java      |  6 ++---
 .../PartitionCountersNeighborcastFuture.java       |  6 ++---
 .../transactions/TransactionEventProxyImpl.java    |  6 ++---
 .../transactions/TransactionMetricsAdapter.java    |  6 ++---
 .../cache/transactions/TransactionProxy.java       |  6 ++---
 .../cache/transactions/TransactionProxyImpl.java   |  6 ++---
 .../TransactionProxyRollbackOnlyImpl.java          |  6 ++---
 .../processors/cache/transactions/TxCounters.java  |  6 ++---
 .../processors/cache/transactions/TxDeadlock.java  |  6 ++---
 .../cache/transactions/TxDeadlockDetection.java    |  6 ++---
 .../cache/transactions/TxEntryValueHolder.java     |  6 ++---
 .../processors/cache/transactions/TxLock.java      |  6 ++---
 .../processors/cache/transactions/TxLockList.java  |  6 ++---
 .../cache/transactions/TxLocksRequest.java         |  6 ++---
 .../cache/transactions/TxLocksResponse.java        |  6 ++---
 .../processors/cache/tree/AbstractDataInnerIO.java |  6 ++---
 .../processors/cache/tree/AbstractDataLeafIO.java  |  6 ++---
 .../cache/tree/AbstractPendingEntryInnerIO.java    |  6 ++---
 .../cache/tree/AbstractPendingEntryLeafIO.java     |  6 ++---
 .../processors/cache/tree/CacheDataRowStore.java   |  6 ++---
 .../processors/cache/tree/CacheDataTree.java       |  6 ++---
 .../cache/tree/CacheIdAwareDataInnerIO.java        |  6 ++---
 .../cache/tree/CacheIdAwareDataLeafIO.java         |  6 ++---
 .../tree/CacheIdAwarePendingEntryInnerIO.java      |  6 ++---
 .../cache/tree/CacheIdAwarePendingEntryLeafIO.java |  6 ++---
 .../processors/cache/tree/DataInnerIO.java         |  6 ++---
 .../internal/processors/cache/tree/DataLeafIO.java |  6 ++---
 .../internal/processors/cache/tree/DataRow.java    |  6 ++---
 .../processors/cache/tree/PendingEntriesTree.java  |  6 ++---
 .../processors/cache/tree/PendingEntryInnerIO.java |  6 ++---
 .../processors/cache/tree/PendingEntryLeafIO.java  |  6 ++---
 .../internal/processors/cache/tree/PendingRow.java |  6 ++---
 .../processors/cache/tree/PendingRowIO.java        |  6 ++---
 .../internal/processors/cache/tree/RowLinkIO.java  |  6 ++---
 .../internal/processors/cache/tree/SearchRow.java  |  6 ++---
 .../mvcc/data/MvccCacheIdAwareDataInnerIO.java     |  6 ++---
 .../tree/mvcc/data/MvccCacheIdAwareDataLeafIO.java |  6 ++---
 .../cache/tree/mvcc/data/MvccDataInnerIO.java      |  6 ++---
 .../cache/tree/mvcc/data/MvccDataLeafIO.java       |  6 ++---
 .../cache/tree/mvcc/data/MvccDataRow.java          |  6 ++---
 .../cache/tree/mvcc/data/MvccUpdateDataRow.java    |  6 ++---
 .../cache/tree/mvcc/data/MvccUpdateResult.java     |  6 ++---
 .../cache/tree/mvcc/data/ResultType.java           |  6 ++---
 .../tree/mvcc/search/MvccDataPageClosure.java      |  6 ++---
 .../tree/mvcc/search/MvccFirstRowTreeClosure.java  |  6 ++---
 .../tree/mvcc/search/MvccLinkAwareSearchRow.java   |  6 ++---
 .../cache/tree/mvcc/search/MvccMaxSearchRow.java   |  6 ++---
 .../cache/tree/mvcc/search/MvccMinSearchRow.java   |  6 ++---
 .../cache/tree/mvcc/search/MvccSearchRow.java      |  6 ++---
 .../tree/mvcc/search/MvccSnapshotSearchRow.java    |  6 ++---
 .../cache/tree/mvcc/search/MvccTreeClosure.java    |  6 ++---
 .../processors/cache/verify/CacheInfo.java         |  6 ++---
 .../verify/CollectConflictPartitionKeysTask.java   |  6 ++---
 .../processors/cache/verify/ContentionClosure.java |  6 ++---
 .../processors/cache/verify/ContentionInfo.java    |  6 ++---
 .../cache/verify/GridNotIdleException.java         |  6 ++---
 .../cache/verify/IdleVerifyDumpResult.java         |  6 ++---
 .../cache/verify/IdleVerifyException.java          |  6 ++---
 .../cache/verify/IdleVerifyResultV2.java           |  6 ++---
 .../processors/cache/verify/IdleVerifyUtility.java |  6 ++---
 .../cache/verify/NoMatchingCachesException.java    |  6 ++---
 .../cache/verify/PartitionEntryHashRecord.java     |  6 ++---
 .../cache/verify/PartitionHashRecord.java          |  6 ++---
 .../cache/verify/PartitionHashRecordV2.java        |  6 ++---
 .../processors/cache/verify/PartitionKey.java      |  6 ++---
 .../processors/cache/verify/PartitionKeyV2.java    |  6 ++---
 .../RetrieveConflictPartitionValuesTask.java       |  6 ++---
 .../verify/VerifyBackupPartitionsDumpTask.java     |  6 ++---
 .../cache/verify/VerifyBackupPartitionsTask.java   |  6 ++---
 .../cache/verify/VerifyBackupPartitionsTaskV2.java |  6 ++---
 .../processors/cache/verify/ViewCacheClosure.java  |  6 ++---
 .../version/CacheVersionConflictResolver.java      |  6 ++---
 .../version/GridCacheLazyPlainVersionedEntry.java  |  6 ++---
 .../version/GridCachePlainVersionedEntry.java      |  6 ++---
 .../cache/version/GridCacheRawVersionedEntry.java  |  6 ++---
 .../processors/cache/version/GridCacheVersion.java |  6 ++---
 .../cache/version/GridCacheVersionAware.java       |  6 ++---
 .../version/GridCacheVersionConflictContext.java   |  6 ++---
 .../cache/version/GridCacheVersionEx.java          |  6 ++---
 .../cache/version/GridCacheVersionManager.java     |  6 ++---
 .../cache/version/GridCacheVersionable.java        |  6 ++---
 .../cache/version/GridCacheVersionedEntry.java     |  6 ++---
 .../cache/version/GridCacheVersionedEntryEx.java   |  6 ++---
 .../cacheobject/IgniteCacheObjectProcessor.java    |  6 ++---
 .../processors/cacheobject/NoOpBinary.java         |  6 ++---
 .../cacheobject/UserCacheObjectByteArrayImpl.java  |  6 ++---
 .../cacheobject/UserCacheObjectImpl.java           |  6 ++---
 .../cacheobject/UserKeyCacheObjectImpl.java        |  6 ++---
 .../processors/cacheobject/package-info.java       |  6 ++---
 .../internal/processors/closure/AffinityTask.java  |  6 ++---
 .../processors/closure/GridClosureProcessor.java   |  6 ++---
 .../closure/GridPeerDeployAwareTaskAdapter.java    |  6 ++---
 .../internal/processors/closure/package-info.java  |  6 ++---
 .../cluster/BaselineAdjustForbiddenException.java  |  6 ++---
 .../cluster/BaselineAutoAdjustMXBeanImpl.java      |  6 ++---
 .../processors/cluster/BaselineTopology.java       |  6 ++---
 .../cluster/BaselineTopologyHistory.java           |  6 ++---
 .../cluster/BaselineTopologyHistoryItem.java       |  6 ++---
 .../processors/cluster/BranchingPointType.java     |  6 ++---
 .../cluster/ChangeGlobalStateFinishMessage.java    |  6 ++---
 .../cluster/ChangeGlobalStateMessage.java          |  6 ++---
 .../cluster/ClusterMetricsUpdateMessage.java       |  6 ++---
 .../processors/cluster/ClusterNodeMetrics.java     |  6 ++---
 .../processors/cluster/ClusterProcessor.java       |  6 ++---
 .../cluster/DiscoveryDataClusterState.java         |  6 ++---
 .../processors/cluster/GridUpdateNotifier.java     |  6 ++---
 .../cluster/HttpIgniteUpdatesChecker.java          |  6 ++---
 .../cluster/IGridClusterStateProcessor.java        |  6 ++---
 .../cluster/IgniteChangeGlobalStateSupport.java    |  6 ++---
 .../autoadjust/BaselineAutoAdjustData.java         |  6 ++---
 .../autoadjust/BaselineAutoAdjustExecutor.java     |  6 ++---
 .../autoadjust/BaselineAutoAdjustScheduler.java    |  6 ++---
 .../autoadjust/BaselineAutoAdjustStatus.java       |  6 ++---
 .../baseline/autoadjust/ChangeTopologyWatcher.java |  6 ++---
 .../processors/compress/CompressionProcessor.java  |  6 ++---
 .../processors/compress/FileSystemUtils.java       |  6 ++---
 .../processors/compress/NativeFileSystem.java      |  6 ++---
 .../distributed/DetachedPropertyException.java     |  6 ++---
 .../distributed/DistributePropertyListener.java    |  6 ++---
 .../distributed/DistributedBooleanProperty.java    |  6 ++---
 .../distributed/DistributedComparableProperty.java |  6 ++---
 .../DistributedConfigurationLifecycleListener.java |  6 ++---
 .../DistributedConfigurationProcessor.java         |  6 ++---
 .../distributed/DistributedLongProperty.java       |  6 ++---
 .../distributed/DistributedProperty.java           |  6 ++---
 .../distributed/DistributedPropertyDispatcher.java |  6 ++---
 .../distributed/NotWritablePropertyException.java  |  6 ++---
 .../distributed/PropertyUpdateClosure.java         |  6 ++---
 .../continuous/AbstractContinuousMessage.java      |  6 ++---
 .../continuous/ContinuousRoutineInfo.java          |  6 ++---
 .../ContinuousRoutineStartResultMessage.java       |  6 ++---
 .../ContinuousRoutinesCommonDiscoveryData.java     |  6 ++---
 .../continuous/ContinuousRoutinesInfo.java         |  6 ++---
 ...ContinuousRoutinesJoiningNodeDiscoveryData.java |  6 ++---
 .../processors/continuous/GridContinuousBatch.java |  6 ++---
 .../continuous/GridContinuousBatchAdapter.java     |  6 ++---
 .../continuous/GridContinuousHandler.java          |  6 ++---
 .../continuous/GridContinuousMessage.java          |  6 ++---
 .../continuous/GridContinuousMessageType.java      |  6 ++---
 .../continuous/GridContinuousProcessor.java        |  6 ++---
 .../continuous/GridContinuousQueryBatch.java       |  6 ++---
 .../processors/continuous/StartRequestData.java    |  6 ++---
 .../processors/continuous/StartRequestDataV2.java  |  6 ++---
 .../StartRoutineAckDiscoveryMessage.java           |  6 ++---
 .../continuous/StartRoutineDiscoveryMessage.java   |  6 ++---
 .../continuous/StartRoutineDiscoveryMessageV2.java |  6 ++---
 .../continuous/StopRoutineAckDiscoveryMessage.java |  6 ++---
 .../continuous/StopRoutineDiscoveryMessage.java    |  6 ++---
 .../datastreamer/DataStreamProcessor.java          |  6 ++---
 .../datastreamer/DataStreamerCacheUpdaters.java    |  6 ++---
 .../processors/datastreamer/DataStreamerEntry.java |  6 ++---
 .../datastreamer/DataStreamerFuture.java           |  6 ++---
 .../processors/datastreamer/DataStreamerImpl.java  |  6 ++---
 .../datastreamer/DataStreamerRequest.java          |  6 ++---
 .../datastreamer/DataStreamerResponse.java         |  6 ++---
 .../datastreamer/DataStreamerUpdateJob.java        |  6 ++---
 .../processors/datastreamer/package-info.java      |  6 ++---
 .../datastructures/AtomicDataStructureProxy.java   |  6 ++---
 .../datastructures/AtomicDataStructureValue.java   |  6 ++---
 .../datastructures/CollocatedQueueItemKey.java     |  6 ++---
 .../datastructures/CollocatedSetItemKey.java       |  6 ++---
 .../datastructures/DataStructureInfoKey.java       |  6 ++---
 .../datastructures/DataStructureType.java          |  6 ++---
 .../datastructures/DataStructuresCacheKey.java     |  6 ++---
 .../datastructures/DataStructuresProcessor.java    |  6 ++---
 .../DistributedCollectionMetadata.java             |  6 ++---
 .../datastructures/GridAtomicCacheQueueImpl.java   |  6 ++---
 .../datastructures/GridCacheAnnotationHelper.java  |  6 ++---
 .../datastructures/GridCacheAtomicLongEx.java      |  6 ++---
 .../datastructures/GridCacheAtomicLongImpl.java    |  6 ++---
 .../datastructures/GridCacheAtomicLongValue.java   |  6 ++---
 .../datastructures/GridCacheAtomicReferenceEx.java |  6 ++---
 .../GridCacheAtomicReferenceImpl.java              |  6 ++---
 .../GridCacheAtomicReferenceValue.java             |  6 ++---
 .../datastructures/GridCacheAtomicSequenceEx.java  |  6 ++---
 .../GridCacheAtomicSequenceImpl.java               |  6 ++---
 .../GridCacheAtomicSequenceValue.java              |  6 ++---
 .../datastructures/GridCacheAtomicStampedEx.java   |  6 ++---
 .../datastructures/GridCacheAtomicStampedImpl.java |  6 ++---
 .../GridCacheAtomicStampedValue.java               |  6 ++---
 .../datastructures/GridCacheCountDownLatchEx.java  |  6 ++---
 .../GridCacheCountDownLatchImpl.java               |  6 ++---
 .../GridCacheCountDownLatchValue.java              |  6 ++---
 .../datastructures/GridCacheInternalKey.java       |  6 ++---
 .../datastructures/GridCacheInternalKeyImpl.java   |  6 ++---
 .../processors/datastructures/GridCacheLockEx.java |  6 ++---
 .../datastructures/GridCacheLockImpl.java          |  6 ++---
 .../datastructures/GridCacheLockState.java         |  6 ++---
 .../datastructures/GridCacheQueueAdapter.java      |  6 ++---
 .../datastructures/GridCacheQueueHeader.java       |  6 ++---
 .../datastructures/GridCacheQueueHeaderKey.java    |  6 ++---
 .../datastructures/GridCacheQueueItemKey.java      |  6 ++---
 .../datastructures/GridCacheQueueProxy.java        |  6 ++---
 .../datastructures/GridCacheRemovable.java         |  6 ++---
 .../datastructures/GridCacheSemaphoreEx.java       |  6 ++---
 .../datastructures/GridCacheSemaphoreImpl.java     |  6 ++---
 .../datastructures/GridCacheSemaphoreState.java    |  6 ++---
 .../datastructures/GridCacheSetHeader.java         |  6 ++---
 .../datastructures/GridCacheSetHeaderKey.java      |  6 ++---
 .../datastructures/GridCacheSetImpl.java           |  6 ++---
 .../datastructures/GridCacheSetItemKey.java        |  6 ++---
 .../datastructures/GridCacheSetProxy.java          |  6 ++---
 .../datastructures/GridSetQueryPredicate.java      |  6 ++---
 .../GridTransactionalCacheQueueImpl.java           |  6 ++---
 .../processors/datastructures/QueueItemKey.java    |  6 ++---
 .../processors/datastructures/SetItemKey.java      |  6 ++---
 .../VolatileAtomicDataStructureValue.java          |  6 ++---
 .../ignite/internal/processors/dr/GridDrType.java  |  6 ++---
 .../dr/IgniteDrDataStreamerCacheUpdater.java       |  6 ++---
 .../internal/processors/dr/package-info.java       |  6 ++---
 .../processors/failure/FailureProcessor.java       |  6 ++---
 .../internal/processors/failure/package-info.java  |  6 ++---
 .../ignite/internal/processors/hadoop/Hadoop.java  |  6 ++---
 .../processors/hadoop/HadoopClassLoader.java       |  6 ++---
 .../processors/hadoop/HadoopClasspathUtils.java    |  6 ++---
 .../processors/hadoop/HadoopDefaultJobInfo.java    |  6 ++---
 .../processors/hadoop/HadoopFileBlock.java         |  6 ++---
 .../internal/processors/hadoop/HadoopHelper.java   |  6 ++---
 .../internal/processors/hadoop/HadoopJobEx.java    |  6 ++---
 .../internal/processors/hadoop/HadoopJobId.java    |  6 ++---
 .../internal/processors/hadoop/HadoopJobInfo.java  |  6 ++---
 .../internal/processors/hadoop/HadoopJobPhase.java |  6 ++---
 .../processors/hadoop/HadoopJobProperty.java       |  6 ++---
 .../processors/hadoop/HadoopJobStatus.java         |  6 ++---
 .../processors/hadoop/HadoopLocations.java         |  6 ++---
 .../hadoop/HadoopMapperAwareTaskOutput.java        |  6 ++---
 .../processors/hadoop/HadoopNoopHelper.java        |  6 ++---
 .../processors/hadoop/HadoopNoopProcessor.java     |  6 ++---
 .../processors/hadoop/HadoopPartitioner.java       |  6 ++---
 .../processors/hadoop/HadoopProcessorAdapter.java  |  6 ++---
 .../processors/hadoop/HadoopSerialization.java     |  6 ++---
 .../internal/processors/hadoop/HadoopTask.java     |  6 ++---
 .../processors/hadoop/HadoopTaskContext.java       |  6 ++---
 .../internal/processors/hadoop/HadoopTaskInfo.java |  6 ++---
 .../processors/hadoop/HadoopTaskInput.java         |  6 ++---
 .../processors/hadoop/HadoopTaskOutput.java        |  6 ++---
 .../internal/processors/hadoop/HadoopTaskType.java |  6 ++---
 .../processors/hadoop/counter/HadoopCounter.java   |  6 ++---
 .../hadoop/counter/HadoopCounterWriter.java        |  6 ++---
 .../processors/hadoop/counter/HadoopCounters.java  |  6 ++---
 .../hadoop/io/PartiallyOffheapRawComparatorEx.java |  6 ++---
 .../processors/hadoop/message/HadoopMessage.java   |  6 ++---
 .../internal/processors/hadoop/package-info.java   |  6 ++---
 .../hadoop/shuffle/HadoopDirectShuffleMessage.java |  6 ++---
 .../hadoop/shuffle/HadoopShuffleAck.java           |  6 ++---
 .../hadoop/shuffle/HadoopShuffleFinishRequest.java |  6 ++---
 .../shuffle/HadoopShuffleFinishResponse.java       |  6 ++---
 .../hadoop/shuffle/HadoopShuffleMessage.java       |  6 ++---
 .../processors/igfs/IgfsAbstractOutputStream.java  |  6 ++---
 .../internal/processors/igfs/IgfsAckMessage.java   |  6 ++---
 .../internal/processors/igfs/IgfsAsyncImpl.java    |  6 ++---
 .../internal/processors/igfs/IgfsAttributes.java   |  6 ++---
 .../internal/processors/igfs/IgfsBaseBlockKey.java |  6 ++---
 .../internal/processors/igfs/IgfsBlockKey.java     |  6 ++---
 .../processors/igfs/IgfsBlockLocationImpl.java     |  6 ++---
 .../processors/igfs/IgfsBlocksMessage.java         |  6 ++---
 .../processors/igfs/IgfsClientSession.java         |  6 ++---
 .../IgfsColocatedMetadataAffinityKeyMapper.java    |  6 ++---
 .../processors/igfs/IgfsCommunicationMessage.java  |  6 ++---
 .../internal/processors/igfs/IgfsContext.java      |  6 ++---
 .../internal/processors/igfs/IgfsCreateResult.java |  6 ++---
 .../internal/processors/igfs/IgfsDataManager.java  |  6 ++---
 .../processors/igfs/IgfsDeleteMessage.java         |  6 ++---
 .../internal/processors/igfs/IgfsDeleteResult.java |  6 ++---
 .../internal/processors/igfs/IgfsDeleteWorker.java |  6 ++---
 .../processors/igfs/IgfsDirectoryInfo.java         |  6 ++---
 .../internal/processors/igfs/IgfsEntryInfo.java    |  6 ++---
 .../ignite/internal/processors/igfs/IgfsEx.java    |  6 ++---
 .../processors/igfs/IgfsFileAffinityRange.java     |  6 ++---
 .../internal/processors/igfs/IgfsFileImpl.java     |  6 ++---
 .../internal/processors/igfs/IgfsFileInfo.java     |  6 ++---
 .../internal/processors/igfs/IgfsFileMap.java      |  6 ++---
 .../processors/igfs/IgfsFileWorkerBatch.java       |  6 ++---
 .../IgfsFileWorkerBatchCancelledException.java     |  6 ++---
 .../processors/igfs/IgfsFragmentizerManager.java   |  6 ++---
 .../processors/igfs/IgfsFragmentizerRequest.java   |  6 ++---
 .../processors/igfs/IgfsFragmentizerResponse.java  |  6 ++---
 .../processors/igfs/IgfsHandshakeResponse.java     |  6 ++---
 .../internal/processors/igfs/IgfsHelper.java       |  6 ++---
 .../internal/processors/igfs/IgfsHelperImpl.java   |  6 ++---
 .../ignite/internal/processors/igfs/IgfsImpl.java  |  6 ++---
 .../processors/igfs/IgfsInputStreamDescriptor.java |  6 ++---
 .../processors/igfs/IgfsInputStreamImpl.java       |  6 ++---
 .../processors/igfs/IgfsInvalidRangeException.java |  6 ++---
 .../internal/processors/igfs/IgfsIpcHandler.java   |  6 ++---
 .../internal/processors/igfs/IgfsJobImpl.java      |  6 ++---
 ...sLazySecondaryFileSystemPositionedReadable.java |  6 ++---
 .../internal/processors/igfs/IgfsListingEntry.java |  6 ++---
 .../internal/processors/igfs/IgfsLocalMetrics.java |  6 ++---
 .../internal/processors/igfs/IgfsManager.java      |  6 ++---
 .../internal/processors/igfs/IgfsMetaManager.java  |  6 ++---
 .../processors/igfs/IgfsMetricsAdapter.java        |  6 ++---
 .../internal/processors/igfs/IgfsModeResolver.java |  6 ++---
 .../processors/igfs/IgfsNodePredicate.java         |  6 ++---
 .../internal/processors/igfs/IgfsNoopHelper.java   |  6 ++---
 .../processors/igfs/IgfsNoopProcessor.java         |  6 ++---
 .../processors/igfs/IgfsOutputStreamImpl.java      |  6 ++---
 .../processors/igfs/IgfsOutputStreamProxyImpl.java |  6 ++---
 .../internal/processors/igfs/IgfsPathIds.java      |  6 ++---
 .../processors/igfs/IgfsPathsCreateResult.java     |  6 ++---
 .../internal/processors/igfs/IgfsProcessor.java    |  6 ++---
 .../processors/igfs/IgfsProcessorAdapter.java      |  6 ++---
 .../internal/processors/igfs/IgfsSamplingKey.java  |  6 ++---
 .../igfs/IgfsSecondaryFileSystemCreateContext.java |  6 ++---
 .../igfs/IgfsSecondaryFileSystemImpl.java          |  6 ++---
 .../igfs/IgfsSecondaryInputStreamDescriptor.java   |  6 ++---
 .../internal/processors/igfs/IgfsServer.java       |  6 ++---
 .../processors/igfs/IgfsServerHandler.java         |  6 ++---
 .../processors/igfs/IgfsServerManager.java         |  6 ++---
 .../internal/processors/igfs/IgfsStatus.java       |  6 ++---
 .../internal/processors/igfs/IgfsSyncMessage.java  |  6 ++---
 .../internal/processors/igfs/IgfsTaskArgsImpl.java |  6 ++---
 .../internal/processors/igfs/IgfsThread.java       |  6 ++---
 .../processors/igfs/IgfsThreadFactory.java         |  6 ++---
 .../ignite/internal/processors/igfs/IgfsUtils.java |  6 ++---
 .../igfs/client/IgfsClientAbstractCallable.java    |  6 ++---
 .../igfs/client/IgfsClientAffinityCallable.java    |  6 ++---
 .../igfs/client/IgfsClientDeleteCallable.java      |  6 ++---
 .../igfs/client/IgfsClientExistsCallable.java      |  6 ++---
 .../igfs/client/IgfsClientInfoCallable.java        |  6 ++---
 .../igfs/client/IgfsClientListFilesCallable.java   |  6 ++---
 .../igfs/client/IgfsClientListPathsCallable.java   |  6 ++---
 .../igfs/client/IgfsClientMkdirsCallable.java      |  6 ++---
 .../igfs/client/IgfsClientRenameCallable.java      |  6 ++---
 .../igfs/client/IgfsClientSetTimesCallable.java    |  6 ++---
 .../igfs/client/IgfsClientSizeCallable.java        |  6 ++---
 .../igfs/client/IgfsClientSummaryCallable.java     |  6 ++---
 .../igfs/client/IgfsClientUpdateCallable.java      |  6 ++---
 .../meta/IgfsClientMetaIdsForPathCallable.java     |  6 ++---
 .../meta/IgfsClientMetaInfoForPathCallable.java    |  6 ++---
 .../client/meta/IgfsClientMetaUnlockCallable.java  |  6 ++---
 .../processors/igfs/data/IgfsDataPutProcessor.java |  6 ++---
 .../meta/IgfsMetaDirectoryCreateProcessor.java     |  6 ++---
 .../meta/IgfsMetaDirectoryListingAddProcessor.java |  6 ++---
 .../IgfsMetaDirectoryListingRemoveProcessor.java   |  6 ++---
 .../IgfsMetaDirectoryListingRenameProcessor.java   |  6 ++---
 .../IgfsMetaDirectoryListingReplaceProcessor.java  |  6 ++---
 .../igfs/meta/IgfsMetaFileCreateProcessor.java     |  6 ++---
 .../igfs/meta/IgfsMetaFileLockProcessor.java       |  6 ++---
 .../meta/IgfsMetaFileRangeDeleteProcessor.java     |  6 ++---
 .../meta/IgfsMetaFileRangeUpdateProcessor.java     |  6 ++---
 .../meta/IgfsMetaFileReserveSpaceProcessor.java    |  6 ++---
 .../igfs/meta/IgfsMetaFileUnlockProcessor.java     |  6 ++---
 .../meta/IgfsMetaUpdatePropertiesProcessor.java    |  6 ++---
 .../igfs/meta/IgfsMetaUpdateTimesProcessor.java    |  6 ++---
 .../internal/processors/igfs/package-info.java     |  6 ++---
 .../secondary/local/LocalFileSystemBlockKey.java   |  6 ++---
 .../secondary/local/LocalFileSystemIgfsFile.java   |  6 ++---
 .../local/LocalFileSystemPositionedReadable.java   |  6 ++---
 .../local/LocalFileSystemSizeVisitor.java          |  6 ++---
 .../igfs/secondary/local/LocalFileSystemUtils.java |  6 ++---
 .../processors/job/GridJobEventListener.java       |  6 ++---
 .../processors/job/GridJobHoldListener.java        |  6 ++---
 .../internal/processors/job/GridJobProcessor.java  |  6 ++---
 .../internal/processors/job/GridJobWorker.java     |  6 ++---
 .../internal/processors/job/package-info.java      |  6 ++---
 .../processors/jobmetrics/GridJobMetrics.java      |  6 ++---
 .../jobmetrics/GridJobMetricsProcessor.java        |  6 ++---
 .../jobmetrics/GridJobMetricsSnapshot.java         |  6 ++---
 .../processors/jobmetrics/package-info.java        |  6 ++---
 .../processors/marshaller/ClientRequestFuture.java |  6 ++---
 .../marshaller/GridMarshallerMappingProcessor.java |  6 ++---
 .../internal/processors/marshaller/MappedName.java |  6 ++---
 .../marshaller/MappingAcceptedMessage.java         |  6 ++---
 .../marshaller/MappingExchangeResult.java          |  6 ++---
 .../marshaller/MappingProposedMessage.java         |  6 ++---
 .../marshaller/MappingUpdatedListener.java         |  6 ++---
 .../marshaller/MarshallerMappingItem.java          |  6 ++---
 .../marshaller/MarshallerMappingTransport.java     |  6 ++---
 .../marshaller/MissingMappingRequestMessage.java   |  6 ++---
 .../marshaller/MissingMappingResponseMessage.java  |  6 ++---
 .../metastorage/DistributedMetaStorage.java        |  6 ++---
 .../DistributedMetaStorageListener.java            |  6 ++---
 .../DistributedMetastorageLifecycleListener.java   |  6 ++---
 .../ReadableDistributedMetaStorage.java            |  6 ++---
 .../persistence/DistributedMetaStorageBridge.java  |  6 ++---
 .../DistributedMetaStorageCasAckMessage.java       |  6 ++---
 .../DistributedMetaStorageCasMessage.java          |  6 ++---
 .../DistributedMetaStorageClusterNodeData.java     |  6 ++---
 .../DistributedMetaStorageHistoryCache.java        |  6 ++---
 .../DistributedMetaStorageHistoryItem.java         |  6 ++---
 .../persistence/DistributedMetaStorageImpl.java    |  6 ++---
 .../DistributedMetaStorageJoiningNodeData.java     |  6 ++---
 .../DistributedMetaStorageKeyValuePair.java        |  6 ++---
 .../DistributedMetaStorageUpdateAckMessage.java    |  6 ++---
 .../DistributedMetaStorageUpdateMessage.java       |  6 ++---
 .../persistence/DistributedMetaStorageUtil.java    |  6 ++---
 .../persistence/DistributedMetaStorageVersion.java |  6 ++---
 .../EmptyDistributedMetaStorageBridge.java         |  6 ++---
 ...InMemoryCachedDistributedMetaStorageBridge.java |  6 ++---
 .../NotAvailableDistributedMetaStorageBridge.java  |  6 ++---
 .../ReadOnlyDistributedMetaStorageBridge.java      |  6 ++---
 .../metastorage/persistence/StartupExtras.java     |  6 ++---
 .../WritableDistributedMetaStorageBridge.java      |  6 ++---
 .../DiscoveryNodeValidationProcessor.java          |  6 ++---
 .../OsDiscoveryNodeValidationProcessor.java        |  6 ++---
 .../odbc/ClientConnectorConfigurationEx.java       |  6 ++---
 .../ClientListenerAbstractConnectionContext.java   |  6 ++---
 .../odbc/ClientListenerBufferedParser.java         |  6 ++---
 .../odbc/ClientListenerConnectionContext.java      |  6 ++---
 .../odbc/ClientListenerMessageParser.java          |  6 ++---
 .../processors/odbc/ClientListenerNioListener.java |  6 ++---
 .../odbc/ClientListenerNioServerBuffer.java        |  6 ++---
 .../processors/odbc/ClientListenerProcessor.java   |  6 ++---
 .../odbc/ClientListenerProtocolVersion.java        |  6 ++---
 .../processors/odbc/ClientListenerRequest.java     |  6 ++---
 .../odbc/ClientListenerRequestHandler.java         |  6 ++---
 .../processors/odbc/ClientListenerRequestNoId.java |  6 ++---
 .../processors/odbc/ClientListenerResponse.java    |  6 ++---
 .../odbc/ClientListenerResponseSender.java         |  6 ++---
 .../processors/odbc/SqlListenerDataTypes.java      |  6 ++---
 .../internal/processors/odbc/SqlListenerUtils.java |  6 ++---
 .../internal/processors/odbc/SqlStateCode.java     |  6 ++---
 .../odbc/jdbc/JdbcBatchExecuteRequest.java         |  6 ++---
 .../odbc/jdbc/JdbcBatchExecuteResult.java          |  6 ++---
 .../odbc/jdbc/JdbcBulkLoadAckResult.java           |  6 ++---
 .../odbc/jdbc/JdbcBulkLoadBatchRequest.java        |  6 ++---
 .../odbc/jdbc/JdbcBulkLoadProcessor.java           |  6 ++---
 .../odbc/jdbc/JdbcCachePartitionsRequest.java      |  6 ++---
 .../odbc/jdbc/JdbcCachePartitionsResult.java       |  6 ++---
 .../processors/odbc/jdbc/JdbcColumnMeta.java       |  6 ++---
 .../processors/odbc/jdbc/JdbcColumnMetaV2.java     |  6 ++---
 .../processors/odbc/jdbc/JdbcColumnMetaV3.java     |  6 ++---
 .../processors/odbc/jdbc/JdbcColumnMetaV4.java     |  6 ++---
 .../odbc/jdbc/JdbcConnectionContext.java           |  6 ++---
 .../internal/processors/odbc/jdbc/JdbcCursor.java  |  6 ++---
 .../processors/odbc/jdbc/JdbcIndexMeta.java        |  6 ++---
 .../processors/odbc/jdbc/JdbcMessageParser.java    |  6 ++---
 .../odbc/jdbc/JdbcMetaColumnsRequest.java          |  6 ++---
 .../odbc/jdbc/JdbcMetaColumnsResult.java           |  6 ++---
 .../odbc/jdbc/JdbcMetaColumnsResultV2.java         |  6 ++---
 .../odbc/jdbc/JdbcMetaColumnsResultV3.java         |  6 ++---
 .../odbc/jdbc/JdbcMetaColumnsResultV4.java         |  6 ++---
 .../odbc/jdbc/JdbcMetaIndexesRequest.java          |  6 ++---
 .../odbc/jdbc/JdbcMetaIndexesResult.java           |  6 ++---
 .../odbc/jdbc/JdbcMetaParamsRequest.java           |  6 ++---
 .../processors/odbc/jdbc/JdbcMetaParamsResult.java |  6 ++---
 .../odbc/jdbc/JdbcMetaPrimaryKeysRequest.java      |  6 ++---
 .../odbc/jdbc/JdbcMetaPrimaryKeysResult.java       |  6 ++---
 .../odbc/jdbc/JdbcMetaSchemasRequest.java          |  6 ++---
 .../odbc/jdbc/JdbcMetaSchemasResult.java           |  6 ++---
 .../odbc/jdbc/JdbcMetaTablesRequest.java           |  6 ++---
 .../processors/odbc/jdbc/JdbcMetaTablesResult.java |  6 ++---
 .../processors/odbc/jdbc/JdbcMetadataInfo.java     |  6 ++---
 .../odbc/jdbc/JdbcOrderedBatchExecuteRequest.java  |  6 ++---
 .../odbc/jdbc/JdbcOrderedBatchExecuteResult.java   |  6 ++---
 .../processors/odbc/jdbc/JdbcParameterMeta.java    |  6 ++---
 .../processors/odbc/jdbc/JdbcPrimaryKeyMeta.java   |  6 ++---
 .../internal/processors/odbc/jdbc/JdbcQuery.java   |  6 ++---
 .../odbc/jdbc/JdbcQueryCancelRequest.java          |  6 ++---
 .../odbc/jdbc/JdbcQueryCloseRequest.java           |  6 ++---
 .../processors/odbc/jdbc/JdbcQueryCursor.java      |  6 ++---
 .../processors/odbc/jdbc/JdbcQueryDescriptor.java  |  6 ++---
 .../JdbcQueryExecuteMultipleStatementsResult.java  |  6 ++---
 .../odbc/jdbc/JdbcQueryExecuteRequest.java         |  6 ++---
 .../odbc/jdbc/JdbcQueryExecuteResult.java          |  6 ++---
 .../odbc/jdbc/JdbcQueryFetchRequest.java           |  6 ++---
 .../processors/odbc/jdbc/JdbcQueryFetchResult.java |  6 ++---
 .../odbc/jdbc/JdbcQueryMetadataRequest.java        |  6 ++---
 .../odbc/jdbc/JdbcQueryMetadataResult.java         |  6 ++---
 .../processors/odbc/jdbc/JdbcRawBinarylizable.java |  6 ++---
 .../internal/processors/odbc/jdbc/JdbcRequest.java |  6 ++---
 .../processors/odbc/jdbc/JdbcRequestHandler.java   |  6 ++---
 .../odbc/jdbc/JdbcRequestHandlerWorker.java        |  6 ++---
 .../processors/odbc/jdbc/JdbcResponse.java         |  6 ++---
 .../internal/processors/odbc/jdbc/JdbcResult.java  |  6 ++---
 .../processors/odbc/jdbc/JdbcResultInfo.java       |  6 ++---
 .../processors/odbc/jdbc/JdbcResultWithIo.java     |  6 ++---
 .../processors/odbc/jdbc/JdbcStatementType.java    |  6 ++---
 .../processors/odbc/jdbc/JdbcTableMeta.java        |  6 ++---
 .../internal/processors/odbc/jdbc/JdbcUtils.java   |  6 ++---
 .../processors/odbc/odbc/OdbcColumnMeta.java       |  6 ++---
 .../odbc/odbc/OdbcConnectionContext.java           |  6 ++---
 .../processors/odbc/odbc/OdbcMessageParser.java    |  6 ++---
 .../internal/processors/odbc/odbc/OdbcQuery.java   |  6 ++---
 .../odbc/odbc/OdbcQueryCloseRequest.java           |  6 ++---
 .../processors/odbc/odbc/OdbcQueryCloseResult.java |  6 ++---
 .../odbc/odbc/OdbcQueryExecuteBatchRequest.java    |  6 ++---
 .../odbc/odbc/OdbcQueryExecuteBatchResult.java     |  6 ++---
 .../odbc/odbc/OdbcQueryExecuteRequest.java         |  6 ++---
 .../odbc/odbc/OdbcQueryExecuteResult.java          |  6 ++---
 .../odbc/odbc/OdbcQueryFetchRequest.java           |  6 ++---
 .../processors/odbc/odbc/OdbcQueryFetchResult.java |  6 ++---
 .../odbc/odbc/OdbcQueryGetColumnsMetaRequest.java  |  6 ++---
 .../odbc/odbc/OdbcQueryGetColumnsMetaResult.java   |  6 ++---
 .../odbc/odbc/OdbcQueryGetParamsMetaRequest.java   |  6 ++---
 .../odbc/odbc/OdbcQueryGetParamsMetaResult.java    |  6 ++---
 .../odbc/odbc/OdbcQueryGetTablesMetaRequest.java   |  6 ++---
 .../odbc/odbc/OdbcQueryGetTablesMetaResult.java    |  6 ++---
 .../odbc/odbc/OdbcQueryMoreResultsRequest.java     |  6 ++---
 .../odbc/odbc/OdbcQueryMoreResultsResult.java      |  6 ++---
 .../processors/odbc/odbc/OdbcQueryResults.java     |  6 ++---
 .../internal/processors/odbc/odbc/OdbcRequest.java |  6 ++---
 .../processors/odbc/odbc/OdbcRequestHandler.java   |  6 ++---
 .../odbc/odbc/OdbcRequestHandlerWorker.java        |  6 ++---
 .../processors/odbc/odbc/OdbcResponse.java         |  6 ++---
 .../processors/odbc/odbc/OdbcResultSet.java        |  6 ++---
 .../odbc/odbc/OdbcStreamingBatchRequest.java       |  6 ++---
 .../odbc/odbc/OdbcStreamingBatchResult.java        |  6 ++---
 .../processors/odbc/odbc/OdbcTableMeta.java        |  6 ++---
 .../internal/processors/odbc/odbc/OdbcTypes.java   |  6 ++---
 .../internal/processors/odbc/odbc/OdbcUtils.java   |  6 ++---
 .../odbc/odbc/escape/OdbcEscapeParseResult.java    |  6 ++---
 .../odbc/odbc/escape/OdbcEscapeToken.java          |  6 ++---
 .../odbc/odbc/escape/OdbcEscapeType.java           |  6 ++---
 .../odbc/odbc/escape/OdbcEscapeUtils.java          |  6 ++---
 .../processors/offheap/GridOffHeapProcessor.java   |  6 ++---
 .../ignite/internal/processors/package-info.java   |  6 ++---
 .../platform/PlatformAbstractBootstrap.java        |  6 ++---
 .../PlatformAbstractConfigurationClosure.java      |  6 ++---
 .../platform/PlatformAbstractPredicate.java        |  6 ++---
 .../platform/PlatformAbstractTarget.java           |  6 ++---
 .../processors/platform/PlatformAsyncResult.java   |  6 ++---
 .../processors/platform/PlatformBootstrap.java     |  6 ++---
 .../platform/PlatformBootstrapFactory.java         |  6 ++---
 .../platform/PlatformConfigurationEx.java          |  6 ++---
 .../processors/platform/PlatformContext.java       |  6 ++---
 .../processors/platform/PlatformContextImpl.java   |  6 ++---
 .../platform/PlatformDefaultJavaObjectFactory.java |  6 ++---
 .../platform/PlatformEventFilterListener.java      |  6 ++---
 .../processors/platform/PlatformException.java     |  6 ++---
 .../platform/PlatformExtendedException.java        |  6 ++---
 .../processors/platform/PlatformIgnition.java      |  6 ++---
 .../platform/PlatformJavaObjectFactoryEx.java      |  6 ++---
 .../platform/PlatformJavaObjectFactoryProxy.java   |  6 ++---
 .../PlatformJavaObjectSingletonFactory.java        |  6 ++---
 .../platform/PlatformNativeException.java          |  6 ++---
 .../platform/PlatformNoCallbackException.java      |  6 ++---
 .../processors/platform/PlatformNoopProcessor.java |  6 ++---
 .../platform/PlatformPluginExtension.java          |  6 ++---
 .../processors/platform/PlatformProcessor.java     |  6 ++---
 .../processors/platform/PlatformProcessorImpl.java |  6 ++---
 .../processors/platform/PlatformTarget.java        |  6 ++---
 .../processors/platform/PlatformTargetProxy.java   |  6 ++---
 .../platform/PlatformTargetProxyImpl.java          |  6 ++---
 .../platform/binary/PlatformBinaryProcessor.java   |  6 ++---
 .../processors/platform/cache/PlatformCache.java   |  6 ++---
 .../platform/cache/PlatformCacheEntryFilter.java   |  6 ++---
 .../cache/PlatformCacheEntryFilterImpl.java        |  6 ++---
 .../cache/PlatformCacheEntryProcessor.java         |  6 ++---
 .../cache/PlatformCacheEntryProcessorImpl.java     |  6 ++---
 .../platform/cache/PlatformCacheExtension.java     |  6 ++---
 .../platform/cache/PlatformCacheIterator.java      |  6 ++---
 .../cache/PlatformCachePartialUpdateException.java |  6 ++---
 .../platform/cache/affinity/PlatformAffinity.java  |  6 ++---
 .../cache/affinity/PlatformAffinityFunction.java   |  6 ++---
 .../affinity/PlatformAffinityFunctionTarget.java   |  6 ++---
 .../cache/affinity/PlatformAffinityUtils.java      |  6 ++---
 .../cache/expiry/PlatformExpiryPolicy.java         |  6 ++---
 .../cache/expiry/PlatformExpiryPolicyFactory.java  |  6 ++---
 .../cache/query/PlatformAbstractQueryCursor.java   |  6 ++---
 .../cache/query/PlatformContinuousQuery.java       |  6 ++---
 .../cache/query/PlatformContinuousQueryFilter.java |  6 ++---
 .../cache/query/PlatformContinuousQueryImpl.java   |  6 ++---
 .../cache/query/PlatformContinuousQueryProxy.java  |  6 ++---
 .../query/PlatformContinuousQueryRemoteFilter.java |  6 ++---
 .../cache/query/PlatformFieldsQueryCursor.java     |  6 ++---
 .../platform/cache/query/PlatformQueryCursor.java  |  6 ++---
 .../platform/cache/store/PlatformCacheStore.java   |  6 ++---
 .../platform/callback/PlatformCallbackGateway.java |  6 ++---
 .../platform/callback/PlatformCallbackOp.java      |  6 ++---
 .../platform/callback/PlatformCallbackUtils.java   |  6 ++---
 .../client/ClientAffinityTopologyVersion.java      |  6 ++---
 .../platform/client/ClientBooleanResponse.java     |  6 ++---
 .../platform/client/ClientCloseableResource.java   |  6 ++---
 .../client/ClientConnectableNodePartitions.java    |  6 ++---
 .../platform/client/ClientConnectionContext.java   |  6 ++---
 .../processors/platform/client/ClientFlag.java     |  6 ++---
 .../platform/client/ClientIntResponse.java         |  6 ++---
 .../platform/client/ClientLongResponse.java        |  6 ++---
 .../platform/client/ClientMessageParser.java       |  6 ++---
 .../platform/client/ClientObjectResponse.java      |  6 ++---
 .../platform/client/ClientRawRequest.java          |  6 ++---
 .../processors/platform/client/ClientRequest.java  |  6 ++---
 .../platform/client/ClientRequestHandler.java      |  6 ++---
 .../client/ClientResourceCloseRequest.java         |  6 ++---
 .../platform/client/ClientResourceRegistry.java    |  6 ++---
 .../processors/platform/client/ClientResponse.java |  6 ++---
 .../processors/platform/client/ClientStatus.java   |  6 ++---
 .../platform/client/ClientStringResponse.java      |  6 ++---
 .../platform/client/IgniteClientException.java     |  6 ++---
 .../client/binary/ClientBinaryTypeGetRequest.java  |  6 ++---
 .../client/binary/ClientBinaryTypeGetResponse.java |  6 ++---
 .../binary/ClientBinaryTypeNameGetRequest.java     |  6 ++---
 .../binary/ClientBinaryTypeNamePutRequest.java     |  6 ++---
 .../client/binary/ClientBinaryTypePutRequest.java  |  6 ++---
 .../cache/ClientCacheAffinityAwarenessGroup.java   |  6 ++---
 .../client/cache/ClientCacheClearKeyRequest.java   |  6 ++---
 .../client/cache/ClientCacheClearKeysRequest.java  |  6 ++---
 .../client/cache/ClientCacheClearRequest.java      |  6 ++---
 .../cache/ClientCacheConfigurationSerializer.java  |  6 ++---
 .../cache/ClientCacheContainsKeyRequest.java       |  6 ++---
 .../cache/ClientCacheContainsKeysRequest.java      |  6 ++---
 .../ClientCacheCreateWithConfigurationRequest.java |  6 ++---
 .../cache/ClientCacheCreateWithNameRequest.java    |  6 ++---
 .../client/cache/ClientCacheDestroyRequest.java    |  6 ++---
 .../client/cache/ClientCacheEntryQueryCursor.java  |  6 ++---
 .../client/cache/ClientCacheFieldsQueryCursor.java |  6 ++---
 .../client/cache/ClientCacheGetAllRequest.java     |  6 ++---
 .../client/cache/ClientCacheGetAllResponse.java    |  6 ++---
 .../cache/ClientCacheGetAndPutIfAbsentRequest.java |  6 ++---
 .../client/cache/ClientCacheGetAndPutRequest.java  |  6 ++---
 .../cache/ClientCacheGetAndRemoveRequest.java      |  6 ++---
 .../cache/ClientCacheGetAndReplaceRequest.java     |  6 ++---
 .../cache/ClientCacheGetConfigurationRequest.java  |  6 ++---
 .../cache/ClientCacheGetConfigurationResponse.java |  6 ++---
 .../client/cache/ClientCacheGetNamesRequest.java   |  6 ++---
 .../client/cache/ClientCacheGetNamesResponse.java  |  6 ++---
 ...ntCacheGetOrCreateWithConfigurationRequest.java |  6 ++---
 .../ClientCacheGetOrCreateWithNameRequest.java     |  6 ++---
 .../client/cache/ClientCacheGetRequest.java        |  6 ++---
 .../client/cache/ClientCacheGetSizeRequest.java    |  6 ++---
 .../client/cache/ClientCacheKeyRequest.java        |  6 ++---
 .../client/cache/ClientCacheKeyValueRequest.java   |  6 ++---
 .../client/cache/ClientCacheKeysRequest.java       |  6 ++---
 .../client/cache/ClientCacheLocalPeekRequest.java  |  6 ++---
 .../cache/ClientCacheNodePartitionsRequest.java    |  6 ++---
 .../cache/ClientCacheNodePartitionsResponse.java   |  6 ++---
 .../client/cache/ClientCachePartitionMapping.java  |  6 ++---
 .../client/cache/ClientCachePartitionsRequest.java |  6 ++---
 .../cache/ClientCachePartitionsResponse.java       |  6 ++---
 .../client/cache/ClientCachePutAllRequest.java     |  6 ++---
 .../cache/ClientCachePutIfAbsentRequest.java       |  6 ++---
 .../client/cache/ClientCachePutRequest.java        |  6 ++---
 .../client/cache/ClientCacheQueryCursor.java       |  6 ++---
 .../cache/ClientCacheQueryNextPageRequest.java     |  6 ++---
 .../cache/ClientCacheQueryNextPageResponse.java    |  6 ++---
 .../client/cache/ClientCacheQueryResponse.java     |  6 ++---
 .../client/cache/ClientCacheRemoveAllRequest.java  |  6 ++---
 .../cache/ClientCacheRemoveIfEqualsRequest.java    |  6 ++---
 .../client/cache/ClientCacheRemoveKeyRequest.java  |  6 ++---
 .../client/cache/ClientCacheRemoveKeysRequest.java |  6 ++---
 .../cache/ClientCacheReplaceIfEqualsRequest.java   |  6 ++---
 .../client/cache/ClientCacheReplaceRequest.java    |  6 ++---
 .../platform/client/cache/ClientCacheRequest.java  |  6 ++---
 .../client/cache/ClientCacheScanQueryRequest.java  |  6 ++---
 .../cache/ClientCacheSqlFieldsQueryRequest.java    |  6 ++---
 .../cache/ClientCacheSqlFieldsQueryResponse.java   |  6 ++---
 .../client/cache/ClientCacheSqlQueryRequest.java   |  6 ++---
 .../platform/cluster/PlatformClusterGroup.java     |  6 ++---
 .../cluster/PlatformClusterNodeFilter.java         |  6 ++---
 .../cluster/PlatformClusterNodeFilterImpl.java     |  6 ++---
 .../platform/compute/PlatformAbstractJob.java      |  6 ++---
 .../platform/compute/PlatformAbstractTask.java     |  6 ++---
 .../compute/PlatformBalancingMultiClosureTask.java |  6 ++---
 ...PlatformBalancingSingleClosureAffinityTask.java |  6 ++---
 .../PlatformBalancingSingleClosureTask.java        |  6 ++---
 .../PlatformBroadcastingMultiClosureTask.java      |  6 ++---
 .../PlatformBroadcastingSingleClosureTask.java     |  6 ++---
 .../platform/compute/PlatformClosureJob.java       |  6 ++---
 .../platform/compute/PlatformCompute.java          |  6 ++---
 .../platform/compute/PlatformFullJob.java          |  6 ++---
 .../platform/compute/PlatformFullTask.java         |  6 ++---
 .../processors/platform/compute/PlatformJob.java   |  6 ++---
 .../platform/cpp/PlatformCppBootstrap.java         |  6 ++---
 .../platform/cpp/PlatformCppBootstrapFactory.java  |  6 ++---
 .../cpp/PlatformCppConfigurationClosure.java       |  6 ++---
 .../platform/cpp/PlatformCppConfigurationEx.java   |  6 ++---
 .../datastreamer/PlatformDataStreamer.java         |  6 ++---
 .../datastreamer/PlatformStreamReceiver.java       |  6 ++---
 .../datastreamer/PlatformStreamReceiverImpl.java   |  6 ++---
 .../datastructures/PlatformAtomicLong.java         |  6 ++---
 .../datastructures/PlatformAtomicReference.java    |  6 ++---
 .../datastructures/PlatformAtomicSequence.java     |  6 ++---
 .../platform/dotnet/PlatformDotNetBootstrap.java   |  6 ++---
 .../dotnet/PlatformDotNetBootstrapFactory.java     |  6 ++---
 .../platform/dotnet/PlatformDotNetCacheStore.java  |  6 ++---
 .../dotnet/PlatformDotNetConfigurationClosure.java |  6 ++---
 .../dotnet/PlatformDotNetConfigurationEx.java      |  6 ++---
 .../dotnet/PlatformDotNetConsoleStream.java        |  6 ++---
 .../platform/dotnet/PlatformDotNetService.java     |  6 ++---
 .../platform/dotnet/PlatformDotNetServiceImpl.java |  6 ++---
 .../PlatformDotNetEntityFrameworkCacheEntry.java   |  6 ++---
 ...latformDotNetEntityFrameworkCacheExtension.java |  6 ++---
 .../PlatformDotNetEntityFrameworkCacheKey.java     |  6 ++---
 ...NetEntityFrameworkIncreaseVersionProcessor.java |  6 ++---
 .../events/PlatformEventFilterListenerImpl.java    |  6 ++---
 .../processors/platform/events/PlatformEvents.java |  6 ++---
 .../events/PlatformLocalEventListener.java         |  6 ++---
 .../platform/lifecycle/PlatformLifecycleBean.java  |  6 ++---
 .../platform/memory/PlatformAbstractMemory.java    |  6 ++---
 .../memory/PlatformBigEndianInputStreamImpl.java   |  6 ++---
 .../memory/PlatformBigEndianOutputStreamImpl.java  |  6 ++---
 .../platform/memory/PlatformExternalMemory.java    |  6 ++---
 .../platform/memory/PlatformInputStream.java       |  6 ++---
 .../platform/memory/PlatformInputStreamImpl.java   |  6 ++---
 .../processors/platform/memory/PlatformMemory.java |  6 ++---
 .../platform/memory/PlatformMemoryManager.java     |  6 ++---
 .../platform/memory/PlatformMemoryManagerImpl.java |  6 ++---
 .../platform/memory/PlatformMemoryPool.java        |  6 ++---
 .../platform/memory/PlatformMemoryUtils.java       |  6 ++---
 .../platform/memory/PlatformOutputStream.java      |  6 ++---
 .../platform/memory/PlatformOutputStreamImpl.java  |  6 ++---
 .../platform/memory/PlatformPooledMemory.java      |  6 ++---
 .../platform/memory/PlatformUnpooledMemory.java    |  6 ++---
 .../platform/message/PlatformMessageFilter.java    |  6 ++---
 .../messaging/PlatformMessageFilterImpl.java       |  6 ++---
 .../messaging/PlatformMessageLocalFilter.java      |  6 ++---
 .../platform/messaging/PlatformMessaging.java      |  6 ++---
 .../platform/plugin/PlatformPluginProcessor.java   |  6 ++---
 .../cache/PlatformCachePluginConfiguration.java    |  6 ++---
 .../platform/services/PlatformAbstractService.java |  6 ++---
 .../platform/services/PlatformService.java         |  6 ++---
 .../platform/services/PlatformServices.java        |  6 ++---
 .../transactions/PlatformTransactions.java         |  6 ++---
 .../platform/utils/PlatformConfigurationUtils.java |  6 ++---
 .../platform/utils/PlatformFutureUtils.java        |  6 ++---
 .../platform/utils/PlatformListenable.java         |  6 ++---
 .../platform/utils/PlatformListenableTarget.java   |  6 ++---
 .../platform/utils/PlatformReaderBiClosure.java    |  6 ++---
 .../platform/utils/PlatformReaderClosure.java      |  6 ++---
 .../processors/platform/utils/PlatformUtils.java   |  6 ++---
 .../platform/utils/PlatformWriterBiClosure.java    |  6 ++---
 .../platform/utils/PlatformWriterClosure.java      |  6 ++---
 .../PlatformDotNetSessionCacheExtension.java       |  6 ++---
 .../websession/PlatformDotNetSessionData.java      |  6 ++---
 .../PlatformDotNetSessionLockProcessor.java        |  6 ++---
 .../PlatformDotNetSessionLockResult.java           |  6 ++---
 ...PlatformDotNetSessionSetAndUnlockProcessor.java |  6 ++---
 .../processors/plugin/CachePluginManager.java      |  6 ++---
 .../processors/plugin/IgnitePluginProcessor.java   |  6 ++---
 .../internal/processors/pool/PoolProcessor.java    |  6 ++---
 .../internal/processors/port/GridPortListener.java |  6 ++---
 .../processors/port/GridPortProcessor.java         |  6 ++---
 .../internal/processors/port/GridPortRecord.java   |  6 ++---
 .../internal/processors/port/package-info.java     |  6 ++---
 .../query/CacheQueryObjectValueContext.java        |  6 ++---
 .../internal/processors/query/EnlistOperation.java |  6 ++---
 .../query/GridQueryCacheObjectsIterator.java       |  6 ++---
 .../internal/processors/query/GridQueryCancel.java |  6 ++---
 .../processors/query/GridQueryFieldMetadata.java   |  6 ++---
 .../processors/query/GridQueryFieldsResult.java    |  6 ++---
 .../query/GridQueryFieldsResultAdapter.java        |  6 ++---
 .../processors/query/GridQueryIndexDescriptor.java |  6 ++---
 .../processors/query/GridQueryIndexing.java        |  6 ++---
 .../processors/query/GridQueryProcessor.java       |  6 ++---
 .../processors/query/GridQueryProperty.java        |  6 ++---
 .../processors/query/GridQueryRowCacheCleaner.java |  6 ++---
 .../processors/query/GridQueryTypeDescriptor.java  |  6 ++---
 .../processors/query/GridRunningQueryInfo.java     |  6 ++---
 .../processors/query/IgniteSQLException.java       |  6 ++---
 .../internal/processors/query/NestedTxMode.java    |  6 ++---
 .../processors/query/QueryCancellable.java         |  6 ++---
 .../internal/processors/query/QueryEntityEx.java   |  6 ++---
 .../internal/processors/query/QueryField.java      |  6 ++---
 .../processors/query/QueryHistoryMetrics.java      |  6 ++---
 .../processors/query/QueryHistoryMetricsKey.java   |  6 ++---
 .../processors/query/QueryHistoryMetricsValue.java |  6 ++---
 .../processors/query/QueryHistoryTracker.java      |  6 ++---
 .../processors/query/QueryIndexDescriptorImpl.java |  6 ++---
 .../internal/processors/query/QueryIndexKey.java   |  6 ++---
 .../processors/query/QueryKeyValueIterable.java    |  6 ++---
 .../processors/query/QueryKeyValueIterator.java    |  6 ++---
 .../processors/query/QueryRunningFuture.java       |  6 ++---
 .../internal/processors/query/QuerySchema.java     |  6 ++---
 .../processors/query/QuerySchemaPatch.java         |  6 ++---
 .../processors/query/QueryTypeCandidate.java       |  6 ++---
 .../processors/query/QueryTypeDescriptorImpl.java  |  6 ++---
 .../internal/processors/query/QueryTypeIdKey.java  |  6 ++---
 .../processors/query/QueryTypeNameKey.java         |  6 ++---
 .../internal/processors/query/QueryUtils.java      |  6 ++---
 .../processors/query/RunningQueryManager.java      |  6 ++---
 .../processors/query/SqlClientContext.java         |  6 ++---
 .../processors/query/UpdateSourceIterator.java     |  6 ++---
 .../twostep/messages/GridQueryCancelRequest.java   |  6 ++---
 .../h2/twostep/messages/GridQueryFailResponse.java |  6 ++---
 .../twostep/messages/GridQueryNextPageRequest.java |  6 ++---
 .../messages/GridQueryNextPageResponse.java        |  6 ++---
 .../query/messages/GridQueryKillRequest.java       |  6 ++---
 .../query/messages/GridQueryKillResponse.java      |  6 ++---
 .../query/property/QueryBinaryProperty.java        |  6 ++---
 .../query/property/QueryClassProperty.java         |  6 ++---
 .../query/property/QueryFieldAccessor.java         |  6 ++---
 .../query/property/QueryMethodsAccessor.java       |  6 ++---
 .../query/property/QueryPropertyAccessor.java      |  6 ++---
 .../property/QueryReadOnlyMethodsAccessor.java     |  6 ++---
 .../query/schema/SchemaExchangeWorkerTask.java     |  6 ++---
 .../query/schema/SchemaIndexCacheFilter.java       |  6 ++---
 .../query/schema/SchemaIndexCacheVisitor.java      |  6 ++---
 .../schema/SchemaIndexCacheVisitorClosure.java     |  6 ++---
 .../query/schema/SchemaIndexCacheVisitorImpl.java  |  6 ++---
 .../SchemaIndexOperationCancellationToken.java     |  6 ++---
 .../schema/SchemaNodeLeaveExchangeWorkerTask.java  |  6 ++---
 .../query/schema/SchemaOperationClientFuture.java  |  6 ++---
 .../query/schema/SchemaOperationException.java     |  6 ++---
 .../query/schema/SchemaOperationManager.java       |  6 ++---
 .../query/schema/SchemaOperationWorker.java        |  6 ++---
 .../message/SchemaAbstractDiscoveryMessage.java    |  6 ++---
 .../message/SchemaFinishDiscoveryMessage.java      |  6 ++---
 .../message/SchemaOperationStatusMessage.java      |  6 ++---
 .../message/SchemaProposeDiscoveryMessage.java     |  6 ++---
 .../SchemaAbstractAlterTableOperation.java         |  6 ++---
 .../schema/operation/SchemaAbstractOperation.java  |  6 ++---
 .../SchemaAlterTableAddColumnOperation.java        |  6 ++---
 .../SchemaAlterTableDropColumnOperation.java       |  6 ++---
 .../operation/SchemaIndexAbstractOperation.java    |  6 ++---
 .../operation/SchemaIndexCreateOperation.java      |  6 ++---
 .../schema/operation/SchemaIndexDropOperation.java |  6 ++---
 .../resource/GridNoImplicitInjection.java          |  6 ++---
 .../resource/GridResourceBasicInjector.java        |  6 ++---
 .../processors/resource/GridResourceField.java     |  6 ++---
 .../processors/resource/GridResourceInjector.java  |  6 ++---
 .../processors/resource/GridResourceIoc.java       |  6 ++---
 .../resource/GridResourceJobContextInjector.java   |  6 ++---
 .../resource/GridResourceLoggerInjector.java       |  6 ++---
 .../processors/resource/GridResourceMethod.java    |  6 ++---
 .../processors/resource/GridResourceProcessor.java |  6 ++---
 .../resource/GridResourceServiceInjector.java      |  6 ++---
 .../processors/resource/GridResourceUtils.java     |  6 ++---
 .../resource/GridSpringResourceContext.java        |  6 ++---
 .../internal/processors/resource/package-info.java |  6 ++---
 .../internal/processors/rest/GridRestCommand.java  |  6 ++---
 .../processors/rest/GridRestProcessor.java         |  6 ++---
 .../internal/processors/rest/GridRestProtocol.java |  6 ++---
 .../processors/rest/GridRestProtocolHandler.java   |  6 ++---
 .../internal/processors/rest/GridRestResponse.java |  6 ++---
 .../client/message/GridClientAbstractMessage.java  |  6 ++---
 .../message/GridClientAuthenticationRequest.java   |  6 ++---
 .../client/message/GridClientBinaryMetaData.java   |  6 ++---
 .../rest/client/message/GridClientCacheBean.java   |  6 ++---
 .../client/message/GridClientCacheRequest.java     |  6 ++---
 .../client/message/GridClientHandshakeRequest.java |  6 ++---
 .../message/GridClientHandshakeResponse.java       |  6 ++---
 .../rest/client/message/GridClientMessage.java     |  6 ++---
 .../rest/client/message/GridClientNodeBean.java    |  6 ++---
 .../client/message/GridClientNodeMetricsBean.java  |  6 ++---
 .../rest/client/message/GridClientPingPacket.java  |  6 ++---
 .../rest/client/message/GridClientResponse.java    |  6 ++---
 .../client/message/GridClientStateRequest.java     |  6 ++---
 .../rest/client/message/GridClientTaskRequest.java |  6 ++---
 .../client/message/GridClientTaskResultBean.java   |  6 ++---
 .../client/message/GridClientTopologyRequest.java  |  6 ++---
 .../rest/client/message/GridRouterRequest.java     |  6 ++---
 .../rest/client/message/GridRouterResponse.java    |  6 ++---
 .../rest/client/message/package-info.java          |  6 ++---
 .../rest/handlers/GridRestCommandHandler.java      |  6 ++---
 .../handlers/GridRestCommandHandlerAdapter.java    |  6 ++---
 .../auth/AuthenticationCommandHandler.java         |  6 ++---
 .../rest/handlers/auth/package-info.java           |  6 ++---
 .../handlers/cache/GridCacheCommandHandler.java    |  6 ++---
 .../rest/handlers/cache/GridCacheRestMetrics.java  |  6 ++---
 .../rest/handlers/cache/GridCacheRestResponse.java |  6 ++---
 .../rest/handlers/cache/package-info.java          |  6 ++---
 .../cluster/GridBaselineCommandHandler.java        |  6 ++---
 .../cluster/GridBaselineCommandResponse.java       |  6 ++---
 .../cluster/GridChangeStateCommandHandler.java     |  6 ++---
 .../DataStructuresCommandHandler.java              |  6 ++---
 .../rest/handlers/log/GridLogCommandHandler.java   |  6 ++---
 .../memory/MemoryMetricsCommandHandler.java        |  6 ++---
 .../processors/rest/handlers/package-info.java     |  6 ++---
 .../handlers/query/CacheQueryFieldsMetaResult.java |  6 ++---
 .../rest/handlers/query/CacheQueryResult.java      |  6 ++---
 .../rest/handlers/query/QueryCommandHandler.java   |  6 ++---
 .../handlers/redis/GridRedisCommandHandler.java    |  6 ++---
 .../redis/GridRedisConnectionCommandHandler.java   |  6 ++---
 .../redis/GridRedisRestCommandHandler.java         |  6 ++---
 .../redis/exception/GridRedisGenericException.java |  6 ++---
 .../redis/exception/GridRedisTypeException.java    |  6 ++---
 .../redis/key/GridRedisDelCommandHandler.java      |  6 ++---
 .../redis/key/GridRedisExistsCommandHandler.java   |  6 ++---
 .../redis/key/GridRedisExpireCommandHandler.java   |  6 ++---
 .../rest/handlers/redis/package-info.java          |  6 ++---
 .../server/GridRedisDbSizeCommandHandler.java      |  6 ++---
 .../redis/server/GridRedisFlushCommandHandler.java |  6 ++---
 .../string/GridRedisAppendCommandHandler.java      |  6 ++---
 .../redis/string/GridRedisGetCommandHandler.java   |  6 ++---
 .../string/GridRedisGetRangeCommandHandler.java    |  6 ++---
 .../string/GridRedisGetSetCommandHandler.java      |  6 ++---
 .../string/GridRedisIncrDecrCommandHandler.java    |  6 ++---
 .../redis/string/GridRedisMGetCommandHandler.java  |  6 ++---
 .../redis/string/GridRedisMSetCommandHandler.java  |  6 ++---
 .../redis/string/GridRedisSetCommandHandler.java   |  6 ++---
 .../string/GridRedisSetRangeCommandHandler.java    |  6 ++---
 .../string/GridRedisStrlenCommandHandler.java      |  6 ++---
 .../rest/handlers/task/GridTaskCommandHandler.java |  6 ++---
 .../rest/handlers/task/GridTaskResultRequest.java  |  6 ++---
 .../rest/handlers/task/GridTaskResultResponse.java |  6 ++---
 .../handlers/top/GridTopologyCommandHandler.java   |  6 ++---
 .../processors/rest/handlers/top/package-info.java |  6 ++---
 .../handlers/user/UserActionCommandHandler.java    |  6 ++---
 .../rest/handlers/user/package-info.java           |  6 ++---
 .../version/GridVersionCommandHandler.java         |  6 ++---
 .../rest/handlers/version/package-info.java        |  6 ++---
 .../internal/processors/rest/package-info.java     |  6 ++---
 .../rest/protocols/GridRestProtocolAdapter.java    |  6 ++---
 .../processors/rest/protocols/package-info.java    |  6 ++---
 .../rest/protocols/tcp/GridClientPacketType.java   |  6 ++---
 .../rest/protocols/tcp/GridMemcachedMessage.java   |  6 ++---
 .../protocols/tcp/GridTcpMemcachedNioListener.java |  6 ++---
 .../rest/protocols/tcp/GridTcpRestNioListener.java |  6 ++---
 .../rest/protocols/tcp/GridTcpRestParser.java      |  6 ++---
 .../rest/protocols/tcp/GridTcpRestProtocol.java    |  6 ++---
 .../rest/protocols/tcp/package-info.java           |  6 ++---
 .../rest/protocols/tcp/redis/GridRedisCommand.java |  6 ++---
 .../rest/protocols/tcp/redis/GridRedisMessage.java |  6 ++---
 .../protocols/tcp/redis/GridRedisNioListener.java  |  6 ++---
 .../tcp/redis/GridRedisProtocolParser.java         |  6 ++---
 .../rest/request/DataStructuresRequest.java        |  6 ++---
 .../rest/request/GridRestBaselineRequest.java      |  6 ++---
 .../rest/request/GridRestCacheRequest.java         |  6 ++---
 .../rest/request/GridRestChangeStateRequest.java   |  6 ++---
 .../rest/request/GridRestLogRequest.java           |  6 ++---
 .../processors/rest/request/GridRestRequest.java   |  6 ++---
 .../rest/request/GridRestTaskRequest.java          |  6 ++---
 .../rest/request/GridRestTopologyRequest.java      |  6 ++---
 .../processors/rest/request/RestQueryRequest.java  |  6 ++---
 .../rest/request/RestUserActionRequest.java        |  6 ++---
 .../processors/rest/request/package-info.java      |  6 ++---
 .../schedule/GridScheduleStatistics.java           |  6 ++---
 .../schedule/IgniteNoopScheduleProcessor.java      |  6 ++---
 .../schedule/IgniteScheduleProcessorAdapter.java   |  6 ++---
 .../internal/processors/schedule/package-info.java |  6 ++---
 .../processors/security/GridSecurityProcessor.java |  6 ++---
 .../processors/security/SecurityContext.java       |  6 ++---
 .../processors/security/SecurityContextHolder.java |  6 ++---
 .../processors/security/SecurityUtils.java         |  6 ++---
 .../security/os/GridOsSecurityProcessor.java       |  6 ++---
 .../segmentation/GridSegmentationProcessor.java    |  6 ++---
 .../os/GridOsSegmentationProcessor.java            |  6 ++---
 .../processors/segmentation/package-info.java      |  6 ++---
 .../processors/service/GridServiceAssignments.java |  6 ++---
 .../service/GridServiceAssignmentsKey.java         |  6 ++---
 .../processors/service/GridServiceDeployment.java  |  6 ++---
 .../GridServiceDeploymentCompoundFuture.java       |  6 ++---
 .../service/GridServiceDeploymentFuture.java       |  6 ++---
 .../service/GridServiceDeploymentKey.java          |  6 ++---
 .../GridServiceMethodNotFoundException.java        |  6 ++---
 .../service/GridServiceMethodReflectKey.java       |  6 ++---
 .../service/GridServiceNotFoundException.java      |  6 ++---
 .../processors/service/GridServiceProcessor.java   |  6 ++---
 .../processors/service/GridServiceProxy.java       |  6 ++---
 .../processors/service/IgniteServiceProcessor.java |  6 ++---
 .../service/LazyServiceConfiguration.java          |  6 ++---
 .../processors/service/PreparedConfigurations.java |  6 ++---
 .../service/ServiceChangeAbstractRequest.java      |  6 ++---
 .../service/ServiceChangeBatchRequest.java         |  6 ++---
 .../service/ServiceClusterDeploymentResult.java    |  6 ++---
 .../ServiceClusterDeploymentResultBatch.java       |  6 ++---
 .../processors/service/ServiceContextImpl.java     |  6 ++---
 .../service/ServiceDeploymentActions.java          |  6 ++---
 .../service/ServiceDeploymentManager.java          |  6 ++---
 .../service/ServiceDeploymentProcessId.java        |  6 ++---
 .../service/ServiceDeploymentRequest.java          |  6 ++---
 .../processors/service/ServiceDeploymentTask.java  |  6 ++---
 .../processors/service/ServiceDescriptorImpl.java  |  6 ++---
 .../internal/processors/service/ServiceInfo.java   |  6 ++---
 .../service/ServiceProcessorAdapter.java           |  6 ++---
 .../ServiceProcessorCommonDiscoveryData.java       |  6 ++---
 .../ServiceProcessorJoinNodeDiscoveryData.java     |  6 ++---
 .../service/ServiceSingleNodeDeploymentResult.java |  6 ++---
 .../ServiceSingleNodeDeploymentResultBatch.java    |  6 ++---
 .../service/ServiceUndeploymentRequest.java        |  6 ++---
 .../session/GridTaskSessionProcessor.java          |  6 ++---
 .../internal/processors/session/package-info.java  |  6 ++---
 .../GridInternalSubscriptionProcessor.java         |  6 ++---
 .../internal/processors/task/GridInternal.java     |  6 ++---
 .../processors/task/GridTaskEventListener.java     |  6 ++---
 .../processors/task/GridTaskProcessor.java         |  6 ++---
 .../processors/task/GridTaskThreadContextKey.java  |  6 ++---
 .../internal/processors/task/GridTaskWorker.java   |  6 ++---
 .../processors/task/GridVisorManagementTask.java   |  6 ++---
 .../internal/processors/task/package-info.java     |  6 ++---
 .../processors/timeout/GridSpiTimeoutObject.java   |  6 ++---
 .../processors/timeout/GridTimeoutObject.java      |  6 ++---
 .../timeout/GridTimeoutObjectAdapter.java          |  6 ++---
 .../processors/timeout/GridTimeoutProcessor.java   |  6 ++---
 .../internal/processors/timeout/package-info.java  |  6 ++---
 .../org/apache/ignite/internal/sql/SqlKeyword.java |  6 ++---
 .../org/apache/ignite/internal/sql/SqlLexer.java   |  6 ++---
 .../internal/sql/SqlLexerLookAheadToken.java       |  6 ++---
 .../apache/ignite/internal/sql/SqlLexerToken.java  |  6 ++---
 .../ignite/internal/sql/SqlLexerTokenType.java     |  6 ++---
 .../ignite/internal/sql/SqlParseException.java     |  6 ++---
 .../org/apache/ignite/internal/sql/SqlParser.java  |  6 ++---
 .../apache/ignite/internal/sql/SqlParserUtils.java |  6 ++---
 .../internal/sql/SqlStrictParseException.java      |  6 ++---
 .../internal/sql/command/SqlAlterTableCommand.java |  6 ++---
 .../internal/sql/command/SqlAlterUserCommand.java  |  6 ++---
 .../sql/command/SqlBeginTransactionCommand.java    |  6 ++---
 .../internal/sql/command/SqlBulkLoadCommand.java   |  6 ++---
 .../ignite/internal/sql/command/SqlCommand.java    |  6 ++---
 .../sql/command/SqlCommitTransactionCommand.java   |  6 ++---
 .../sql/command/SqlCreateIndexCommand.java         |  6 ++---
 .../internal/sql/command/SqlCreateUserCommand.java |  6 ++---
 .../internal/sql/command/SqlDropIndexCommand.java  |  6 ++---
 .../internal/sql/command/SqlDropUserCommand.java   |  6 ++---
 .../internal/sql/command/SqlIndexColumn.java       |  6 ++---
 .../internal/sql/command/SqlKillQueryCommand.java  |  6 ++---
 .../internal/sql/command/SqlQualifiedName.java     |  6 ++---
 .../sql/command/SqlRollbackTransactionCommand.java |  6 ++---
 .../sql/command/SqlSetStreamingCommand.java        |  6 ++---
 .../affinity/PartitionAffinityFunctionType.java    |  6 ++---
 .../sql/optimizer/affinity/PartitionAllNode.java   |  6 ++---
 .../optimizer/affinity/PartitionClientContext.java |  6 ++---
 .../optimizer/affinity/PartitionCompositeNode.java |  6 ++---
 .../affinity/PartitionCompositeNodeOperator.java   |  6 ++---
 .../optimizer/affinity/PartitionConstantNode.java  |  6 ++---
 .../optimizer/affinity/PartitionDataTypeUtils.java |  6 ++---
 .../sql/optimizer/affinity/PartitionGroupNode.java |  6 ++---
 .../optimizer/affinity/PartitionJoinCondition.java |  6 ++---
 .../sql/optimizer/affinity/PartitionJoinGroup.java |  6 ++---
 .../sql/optimizer/affinity/PartitionNode.java      |  6 ++---
 .../sql/optimizer/affinity/PartitionNoneNode.java  |  6 ++---
 .../optimizer/affinity/PartitionParameterNode.java |  6 ++---
 .../optimizer/affinity/PartitionParameterType.java |  6 ++---
 .../sql/optimizer/affinity/PartitionResolver.java  |  6 ++---
 .../sql/optimizer/affinity/PartitionResult.java    |  6 ++---
 .../affinity/PartitionResultMarshaler.java         |  6 ++---
 .../optimizer/affinity/PartitionSingleNode.java    |  6 ++---
 .../sql/optimizer/affinity/PartitionTable.java     |  6 ++---
 .../affinity/PartitionTableAffinityDescriptor.java |  6 ++---
 .../optimizer/affinity/PartitionTableModel.java    |  6 ++---
 .../apache/ignite/internal/stat/IndexPageType.java |  6 ++---
 .../ignite/internal/stat/IoStatisticsHolder.java   |  6 ++---
 .../internal/stat/IoStatisticsHolderCache.java     |  6 ++---
 .../internal/stat/IoStatisticsHolderIndex.java     |  6 ++---
 .../internal/stat/IoStatisticsHolderKey.java       |  6 ++---
 .../internal/stat/IoStatisticsHolderNoOp.java      |  6 ++---
 .../internal/stat/IoStatisticsHolderQuery.java     |  6 ++---
 .../ignite/internal/stat/IoStatisticsManager.java  |  6 ++---
 .../stat/IoStatisticsMetricsLocalMXBeanImpl.java   |  6 ++---
 .../internal/stat/IoStatisticsQueryHelper.java     |  6 ++---
 .../ignite/internal/stat/IoStatisticsType.java     |  6 ++---
 .../suggestions/GridPerformanceSuggestions.java    |  6 ++---
 .../suggestions/JvmConfigurationSuggestions.java   |  6 ++---
 .../suggestions/OsConfigurationSuggestions.java    |  6 ++---
 .../ignite/internal/suggestions/package-info.java  |  6 ++---
 .../ignite/internal/tck/TCKMBeanServerBuilder.java |  6 ++---
 .../IgniteTxAlreadyCompletedCheckedException.java  |  6 ++---
 .../IgniteTxDuplicateKeyCheckedException.java      |  6 ++---
 .../IgniteTxHeuristicCheckedException.java         |  6 ++---
 .../IgniteTxOptimisticCheckedException.java        |  6 ++---
 .../IgniteTxRollbackCheckedException.java          |  6 ++---
 .../IgniteTxSerializationCheckedException.java     |  6 ++---
 .../IgniteTxTimeoutCheckedException.java           |  6 ++---
 .../IgniteTxUnexpectedStateCheckedException.java   |  6 ++---
 .../transactions/TransactionCheckedException.java  |  6 ++---
 .../apache/ignite/internal/util/BitSetIntSet.java  |  6 ++---
 .../apache/ignite/internal/util/ClassCache.java    |  6 ++---
 .../ignite/internal/util/DirectBufferCleaner.java  |  6 ++---
 .../java/org/apache/ignite/internal/util/F0.java   |  6 ++---
 .../ignite/internal/util/FeatureChecker.java       |  6 ++---
 .../ignite/internal/util/GridAnnotationsCache.java |  6 ++---
 .../ignite/internal/util/GridArgumentCheck.java    |  6 ++---
 .../apache/ignite/internal/util/GridArrays.java    |  6 ++---
 .../internal/util/GridAtomicInitializer.java       |  6 ++---
 .../ignite/internal/util/GridAtomicInteger.java    |  6 ++---
 .../ignite/internal/util/GridAtomicLong.java       |  6 ++---
 .../util/GridBoundedConcurrentLinkedHashMap.java   |  6 ++---
 .../util/GridBoundedConcurrentLinkedHashSet.java   |  6 ++---
 .../util/GridBoundedConcurrentOrderedMap.java      |  6 ++---
 .../util/GridBoundedConcurrentOrderedSet.java      |  6 ++---
 .../internal/util/GridBoundedLinkedHashMap.java    |  6 ++---
 .../internal/util/GridBoundedLinkedHashSet.java    |  6 ++---
 .../internal/util/GridBoundedPriorityQueue.java    |  6 ++---
 .../apache/ignite/internal/util/GridBusyLock.java  |  6 ++---
 .../ignite/internal/util/GridByteArrayList.java    |  6 ++---
 .../ignite/internal/util/GridCircularBuffer.java   |  6 ++---
 .../ignite/internal/util/GridClassLoaderCache.java |  6 ++---
 .../apache/ignite/internal/util/GridCleaner.java   |  6 ++---
 .../ignite/internal/util/GridClientByteUtils.java  |  6 ++---
 .../util/GridCloseableIteratorAdapter.java         |  6 ++---
 .../util/GridCloseableIteratorAdapterEx.java       |  6 ++---
 .../ignite/internal/util/GridCollections.java      |  6 ++---
 .../internal/util/GridConcurrentFactory.java       |  6 ++---
 .../internal/util/GridConcurrentHashSet.java       |  6 ++---
 .../internal/util/GridConcurrentLinkedHashSet.java |  6 ++---
 .../util/GridConcurrentPhantomHashSet.java         |  6 ++---
 .../internal/util/GridConcurrentSkipListSet.java   |  6 ++---
 .../internal/util/GridConcurrentWeakHashSet.java   |  6 ++---
 .../internal/util/GridConfigurationFinder.java     |  6 ++---
 .../ignite/internal/util/GridConsistentHash.java   |  6 ++---
 .../internal/util/GridCursorIteratorWrapper.java   |  6 ++---
 .../org/apache/ignite/internal/util/GridDebug.java |  6 ++---
 .../internal/util/GridEmptyCloseableIterator.java  |  6 ++---
 .../ignite/internal/util/GridEmptyIterator.java    |  6 ++---
 .../internal/util/GridFixedSizeInputStream.java    |  6 ++---
 .../ignite/internal/util/GridHandleTable.java      |  6 ++---
 .../ignite/internal/util/GridIntIterator.java      |  6 ++---
 .../apache/ignite/internal/util/GridIntList.java   |  6 ++---
 .../ignite/internal/util/GridJavaProcess.java      |  6 ++---
 .../apache/ignite/internal/util/GridKeyLock.java   |  6 ++---
 .../ignite/internal/util/GridLeanIdentitySet.java  |  6 ++---
 .../apache/ignite/internal/util/GridLeanMap.java   |  6 ++---
 .../apache/ignite/internal/util/GridLeanSet.java   |  6 ++---
 .../apache/ignite/internal/util/GridListSet.java   |  6 ++---
 .../ignite/internal/util/GridLogThrottle.java      |  6 ++---
 .../apache/ignite/internal/util/GridLongList.java  |  6 ++---
 .../internal/util/GridMessageCollection.java       |  6 ++---
 .../internal/util/GridMultiCollectionWrapper.java  |  6 ++---
 .../org/apache/ignite/internal/util/GridMutex.java |  6 ++---
 .../internal/util/GridPartitionStateMap.java       |  6 ++---
 .../org/apache/ignite/internal/util/GridQueue.java |  6 ++---
 .../apache/ignite/internal/util/GridRandom.java    |  6 ++---
 .../internal/util/GridReadOnlyArrayView.java       |  6 ++---
 .../ignite/internal/util/GridReflectionCache.java  |  6 ++---
 .../internal/util/GridSerializableCollection.java  |  6 ++---
 .../internal/util/GridSerializableIterable.java    |  6 ++---
 .../internal/util/GridSerializableIterator.java    |  6 ++---
 .../ignite/internal/util/GridSerializableList.java |  6 ++---
 .../ignite/internal/util/GridSerializableMap.java  |  6 ++---
 .../ignite/internal/util/GridSerializableSet.java  |  6 ++---
 .../ignite/internal/util/GridSetWrapper.java       |  6 ++---
 .../ignite/internal/util/GridSnapshotLock.java     |  6 ++---
 .../util/GridSpiCloseableIteratorWrapper.java      |  6 ++---
 .../ignite/internal/util/GridSpinBusyLock.java     |  6 ++---
 .../internal/util/GridSpinReadWriteLock.java       |  6 ++---
 .../ignite/internal/util/GridStringBuilder.java    |  6 ++---
 .../internal/util/GridStringBuilderFactory.java    |  6 ++---
 .../ignite/internal/util/GridStripedLock.java      |  6 ++---
 .../internal/util/GridStripedReadWriteLock.java    |  6 ++---
 .../internal/util/GridStripedSpinBusyLock.java     |  6 ++---
 .../ignite/internal/util/GridSynchronizedMap.java  |  6 ++---
 .../org/apache/ignite/internal/util/GridTimer.java |  6 ++---
 .../apache/ignite/internal/util/GridTimerTask.java |  6 ++---
 .../apache/ignite/internal/util/GridUnsafe.java    |  6 ++---
 .../ignite/internal/util/GridWeakIterator.java     |  6 ++---
 .../ignite/internal/util/HostAndPortRange.java     |  6 ++---
 .../internal/util/IgniteExceptionRegistry.java     |  6 ++---
 .../ignite/internal/util/IgniteStopwatch.java      |  6 ++---
 .../apache/ignite/internal/util/IgniteTicker.java  |  6 ++---
 .../apache/ignite/internal/util/IgniteTree.java    |  6 ++---
 .../apache/ignite/internal/util/IgniteUtils.java   |  6 ++---
 .../ignite/internal/util/IgniteUuidCache.java      |  6 ++---
 .../internal/util/InitializationProtector.java     |  6 ++---
 .../ignite/internal/util/MutableSingletonList.java |  6 ++---
 .../ignite/internal/util/OffheapReadWriteLock.java |  6 ++---
 .../util/ReflectiveDirectBufferCleaner.java        |  6 ++---
 .../internal/util/SerializableTransient.java       |  6 ++---
 .../util/StripedCompositeReadWriteLock.java        |  6 ++---
 .../ignite/internal/util/StripedExecutor.java      |  6 ++---
 .../org/apache/ignite/internal/util/TimeBag.java   |  6 ++---
 .../internal/util/TransientSerializable.java       |  6 ++---
 .../internal/util/UUIDCollectionMessage.java       |  6 ++---
 .../internal/util/UnsafeDirectBufferCleaner.java   |  6 ++---
 .../internal/util/future/AsyncFutureListener.java  |  6 ++---
 .../internal/util/future/CountDownFuture.java      |  6 ++---
 .../internal/util/future/GridCompoundFuture.java   |  6 ++---
 .../util/future/GridCompoundIdentityFuture.java    |  6 ++---
 .../internal/util/future/GridEmbeddedFuture.java   |  6 ++---
 .../internal/util/future/GridFinishedFuture.java   |  6 ++---
 .../internal/util/future/GridFutureAdapter.java    |  6 ++---
 .../util/future/GridFutureChainListener.java       |  6 ++---
 .../util/future/IgniteFinishedFutureImpl.java      |  6 ++---
 .../internal/util/future/IgniteFutureImpl.java     |  6 ++---
 .../internal/util/future/IgniteRemoteMapTask.java  |  6 ++---
 .../ignite/internal/util/future/package-info.java  |  6 ++---
 .../util/gridify/GridifyArgumentBuilder.java       |  6 ++---
 .../internal/util/gridify/GridifyJobAdapter.java   |  6 ++---
 .../util/gridify/GridifyRangeArgument.java         |  6 ++---
 .../ignite/internal/util/gridify/GridifyUtils.java |  6 ++---
 .../ignite/internal/util/gridify/package-info.java |  6 ++---
 .../internal/util/io/GridByteArrayInputStream.java |  6 ++---
 .../util/io/GridByteArrayOutputStream.java         |  6 ++---
 .../ignite/internal/util/io/GridDataInput.java     |  6 ++---
 .../ignite/internal/util/io/GridDataOutput.java    |  6 ++---
 .../ignite/internal/util/io/GridFileUtils.java     |  6 ++---
 .../ignite/internal/util/io/GridFilenameUtils.java |  6 ++---
 .../util/io/GridReversedLinesFileReader.java       |  6 ++---
 .../internal/util/io/GridUnsafeDataInput.java      |  6 ++---
 .../internal/util/io/GridUnsafeDataOutput.java     |  6 ++---
 .../ignite/internal/util/ipc/IpcEndpoint.java      |  6 ++---
 .../util/ipc/IpcEndpointBindException.java         |  6 ++---
 .../internal/util/ipc/IpcEndpointFactory.java      |  6 ++---
 .../ignite/internal/util/ipc/IpcEndpointType.java  |  6 ++---
 .../internal/util/ipc/IpcServerEndpoint.java       |  6 ++---
 .../ignite/internal/util/ipc/IpcToNioAdapter.java  |  6 ++---
 .../util/ipc/loopback/IpcClientTcpEndpoint.java    |  6 ++---
 .../util/ipc/loopback/IpcServerTcpEndpoint.java    |  6 ++---
 .../internal/util/ipc/loopback/package-info.java   |  6 ++---
 .../ignite/internal/util/ipc/package-info.java     |  6 ++---
 .../shmem/IpcOutOfSystemResourcesException.java    |  6 ++---
 .../ipc/shmem/IpcSharedMemoryClientEndpoint.java   |  6 ++---
 .../util/ipc/shmem/IpcSharedMemoryInitRequest.java |  6 ++---
 .../ipc/shmem/IpcSharedMemoryInitResponse.java     |  6 ++---
 .../util/ipc/shmem/IpcSharedMemoryInputStream.java |  6 ++---
 .../ipc/shmem/IpcSharedMemoryNativeLoader.java     |  6 ++---
 .../IpcSharedMemoryOperationTimedoutException.java |  6 ++---
 .../ipc/shmem/IpcSharedMemoryOutputStream.java     |  6 ++---
 .../ipc/shmem/IpcSharedMemoryServerEndpoint.java   |  6 ++---
 .../util/ipc/shmem/IpcSharedMemorySpace.java       |  6 ++---
 .../util/ipc/shmem/IpcSharedMemoryUtils.java       |  6 ++---
 .../internal/util/ipc/shmem/package-info.java      |  6 ++---
 .../ignite/internal/util/lang/GridAbsClosure.java  |  6 ++---
 .../ignite/internal/util/lang/GridAbsClosureX.java |  6 ++---
 .../internal/util/lang/GridAbsPredicate.java       |  6 ++---
 .../internal/util/lang/GridAbsPredicateX.java      |  6 ++---
 .../internal/util/lang/GridCloseableIterator.java  |  6 ++---
 .../ignite/internal/util/lang/GridClosure3.java    |  6 ++---
 .../ignite/internal/util/lang/GridClosure3X.java   |  6 ++---
 .../internal/util/lang/GridClosureException.java   |  6 ++---
 .../ignite/internal/util/lang/GridCursor.java      |  6 ++---
 .../util/lang/GridFilteredClosableIterator.java    |  6 ++---
 .../internal/util/lang/GridFilteredIterator.java   |  6 ++---
 .../apache/ignite/internal/util/lang/GridFunc.java |  6 ++---
 .../ignite/internal/util/lang/GridInClosure3.java  |  6 ++---
 .../ignite/internal/util/lang/GridInClosure3X.java |  6 ++---
 .../ignite/internal/util/lang/GridIterable.java    |  6 ++---
 .../internal/util/lang/GridIterableAdapter.java    |  6 ++---
 .../ignite/internal/util/lang/GridIterator.java    |  6 ++---
 .../internal/util/lang/GridIteratorAdapter.java    |  6 ++---
 .../ignite/internal/util/lang/GridMapEntry.java    |  6 ++---
 .../util/lang/GridMetadataAwareAdapter.java        |  6 ++---
 .../internal/util/lang/GridNodePredicate.java      |  6 ++---
 .../internal/util/lang/GridPeerDeployAware.java    |  6 ++---
 .../util/lang/GridPeerDeployAwareAdapter.java      |  6 ++---
 .../internal/util/lang/GridPlainAbsClosure.java    |  6 ++---
 .../internal/util/lang/GridPlainCallable.java      |  6 ++---
 .../internal/util/lang/GridPlainClosure.java       |  6 ++---
 .../internal/util/lang/GridPlainClosure2.java      |  6 ++---
 .../internal/util/lang/GridPlainInClosure.java     |  6 ++---
 .../internal/util/lang/GridPlainOutClosure.java    |  6 ++---
 .../internal/util/lang/GridPlainRunnable.java      |  6 ++---
 .../ignite/internal/util/lang/GridPredicate3.java  |  6 ++---
 .../ignite/internal/util/lang/GridPredicate3X.java |  6 ++---
 .../ignite/internal/util/lang/GridTreePrinter.java |  6 ++---
 .../ignite/internal/util/lang/GridTriple.java      |  6 ++---
 .../ignite/internal/util/lang/GridTuple.java       |  6 ++---
 .../ignite/internal/util/lang/GridTuple3.java      |  6 ++---
 .../ignite/internal/util/lang/GridTuple4.java      |  6 ++---
 .../ignite/internal/util/lang/GridTuple5.java      |  6 ++---
 .../ignite/internal/util/lang/GridTuple6.java      |  6 ++---
 .../ignite/internal/util/lang/IgniteClosure2X.java |  6 ++---
 .../ignite/internal/util/lang/IgniteClosureX.java  |  6 ++---
 .../internal/util/lang/IgniteInClosure2X.java      |  6 ++---
 .../internal/util/lang/IgniteInClosureX.java       |  6 ++---
 .../internal/util/lang/IgniteOutClosureX.java      |  6 ++---
 .../ignite/internal/util/lang/IgnitePair.java      |  6 ++---
 .../internal/util/lang/IgnitePredicate2X.java      |  6 ++---
 .../internal/util/lang/IgnitePredicateX.java       |  6 ++---
 .../ignite/internal/util/lang/IgniteReducer2.java  |  6 ++---
 .../ignite/internal/util/lang/IgniteReducer2X.java |  6 ++---
 .../ignite/internal/util/lang/IgniteReducer3.java  |  6 ++---
 .../ignite/internal/util/lang/IgniteReducer3X.java |  6 ++---
 .../ignite/internal/util/lang/IgniteReducerX.java  |  6 ++---
 .../util/lang/IgniteSingletonIterator.java         |  6 ++---
 .../util/lang/IgniteThrowableConsumer.java         |  6 ++---
 .../util/lang/IgniteThrowableFunction.java         |  6 ++---
 .../internal/util/lang/IgniteThrowableRunner.java  |  6 ++---
 .../util/lang/gridfunc/AlwaysFalsePredicate.java   |  6 ++---
 .../util/lang/gridfunc/AlwaysTruePredicate.java    |  6 ++---
 .../util/lang/gridfunc/AlwaysTrueReducer.java      |  6 ++---
 .../gridfunc/AtomicIntegerFactoryCallable.java     |  6 ++---
 .../lang/gridfunc/CacheEntryGetValueClosure.java   |  6 ++---
 .../lang/gridfunc/CacheEntryHasPeekPredicate.java  |  6 ++---
 .../lang/gridfunc/ClusterNodeGetIdClosure.java     |  6 ++---
 .../gridfunc/ConcurrentHashSetFactoryCallable.java |  6 ++---
 .../gridfunc/ConcurrentMapFactoryCallable.java     |  6 ++---
 .../lang/gridfunc/ContainsNodeIdsPredicate.java    |  6 ++---
 .../util/lang/gridfunc/ContainsPredicate.java      |  6 ++---
 .../gridfunc/EntryByKeyEvaluationPredicate.java    |  6 ++---
 .../gridfunc/EqualsClusterNodeIdPredicate.java     |  6 ++---
 .../util/lang/gridfunc/EqualsUuidPredicate.java    |  6 ++---
 .../util/lang/gridfunc/FlatCollectionWrapper.java  |  6 ++---
 .../internal/util/lang/gridfunc/FlatIterator.java  |  6 ++---
 .../util/lang/gridfunc/HasEqualIdPredicate.java    |  6 ++---
 .../util/lang/gridfunc/HasNotEqualIdPredicate.java |  6 ++---
 .../util/lang/gridfunc/IdentityClosure.java        |  6 ++---
 .../internal/util/lang/gridfunc/IntSumReducer.java |  6 ++---
 .../util/lang/gridfunc/IsAllPredicate.java         |  6 ++---
 .../util/lang/gridfunc/IsNotAllPredicate.java      |  6 ++---
 .../util/lang/gridfunc/IsNotNullPredicate.java     |  6 ++---
 .../util/lang/gridfunc/LongSumReducer.java         |  6 ++---
 .../util/lang/gridfunc/MapFactoryCallable.java     |  6 ++---
 .../util/lang/gridfunc/MultipleIterator.java       |  6 ++---
 .../internal/util/lang/gridfunc/NoOpClosure.java   |  6 ++---
 .../util/lang/gridfunc/NotContainsPredicate.java   |  6 ++---
 .../util/lang/gridfunc/NotEqualPredicate.java      |  6 ++---
 .../lang/gridfunc/PredicateCollectionView.java     |  6 ++---
 .../util/lang/gridfunc/PredicateMapView.java       |  6 ++---
 .../util/lang/gridfunc/PredicateSetView.java       |  6 ++---
 .../util/lang/gridfunc/ReadOnlyCollectionView.java |  6 ++---
 .../lang/gridfunc/ReadOnlyCollectionView2X.java    |  6 ++---
 .../util/lang/gridfunc/RunnableWrapperClosure.java |  6 ++---
 .../util/lang/gridfunc/SetFactoryCallable.java     |  6 ++---
 .../util/lang/gridfunc/StringConcatReducer.java    |  6 ++---
 .../util/lang/gridfunc/ToStringClosure.java        |  6 ++---
 .../lang/gridfunc/TransformCollectionView.java     |  6 ++---
 .../lang/gridfunc/TransformFilteringIterator.java  |  6 ++---
 .../util/lang/gridfunc/TransformMapView.java       |  6 ++---
 .../util/lang/gridfunc/TransformMapView2.java      |  6 ++---
 .../internal/util/lang/gridfunc/package-info.java  |  6 ++---
 .../util/nio/GridAbstractCommunicationClient.java  |  6 ++---
 .../internal/util/nio/GridBufferedParser.java      |  6 ++---
 .../internal/util/nio/GridCommunicationClient.java |  6 ++---
 .../util/nio/GridConnectionBytesVerifyFilter.java  |  6 ++---
 .../internal/util/nio/GridDelimitedParser.java     |  6 ++---
 .../ignite/internal/util/nio/GridDirectParser.java |  6 ++---
 .../util/nio/GridNioAsyncNotifyFilter.java         |  6 ++---
 .../util/nio/GridNioBackPressureControl.java       |  6 ++---
 .../internal/util/nio/GridNioCodecFilter.java      |  6 ++---
 .../internal/util/nio/GridNioDelimitedBuffer.java  |  6 ++---
 .../internal/util/nio/GridNioEmbeddedFuture.java   |  6 ++---
 .../ignite/internal/util/nio/GridNioException.java |  6 ++---
 .../ignite/internal/util/nio/GridNioFilter.java    |  6 ++---
 .../internal/util/nio/GridNioFilterAdapter.java    |  6 ++---
 .../internal/util/nio/GridNioFilterChain.java      |  6 ++---
 .../internal/util/nio/GridNioFinishedFuture.java   |  6 ++---
 .../ignite/internal/util/nio/GridNioFuture.java    |  6 ++---
 .../internal/util/nio/GridNioFutureImpl.java       |  6 ++---
 .../internal/util/nio/GridNioKeyAttachment.java    |  6 ++---
 .../internal/util/nio/GridNioMessageReader.java    |  6 ++---
 .../util/nio/GridNioMessageReaderFactory.java      |  6 ++---
 .../internal/util/nio/GridNioMessageTracker.java   |  6 ++---
 .../internal/util/nio/GridNioMessageWriter.java    |  6 ++---
 .../util/nio/GridNioMessageWriterFactory.java      |  6 ++---
 .../internal/util/nio/GridNioMetricsListener.java  |  6 ++---
 .../ignite/internal/util/nio/GridNioParser.java    |  6 ++---
 .../util/nio/GridNioRecoveryDescriptor.java        |  6 ++---
 .../ignite/internal/util/nio/GridNioServer.java    |  6 ++---
 .../internal/util/nio/GridNioServerBuffer.java     |  6 ++---
 .../internal/util/nio/GridNioServerListener.java   |  6 ++---
 .../util/nio/GridNioServerListenerAdapter.java     |  6 ++---
 .../ignite/internal/util/nio/GridNioSession.java   |  6 ++---
 .../internal/util/nio/GridNioSessionImpl.java      |  6 ++---
 .../internal/util/nio/GridNioSessionMetaKey.java   |  6 ++---
 .../ignite/internal/util/nio/GridNioWorker.java    |  6 ++---
 .../util/nio/GridSelectorNioSessionImpl.java       |  6 ++---
 .../util/nio/GridShmemCommunicationClient.java     |  6 ++---
 .../util/nio/GridTcpNioCommunicationClient.java    |  6 ++---
 .../internal/util/nio/SessionWriteRequest.java     |  6 ++---
 .../ignite/internal/util/nio/package-info.java     |  6 ++---
 .../internal/util/nio/ssl/BlockingSslHandler.java  |  6 ++---
 .../internal/util/nio/ssl/GridNioSslFilter.java    |  6 ++---
 .../internal/util/nio/ssl/GridNioSslHandler.java   |  6 ++---
 .../ignite/internal/util/nio/ssl/GridSslMeta.java  |  6 ++---
 .../ignite/internal/util/nio/ssl/package-info.java |  6 ++---
 .../util/nodestart/IgniteNodeStartUtils.java       |  6 ++---
 .../nodestart/IgniteRemoteStartSpecification.java  |  6 ++---
 .../internal/util/nodestart/IgniteSshHelper.java   |  6 ++---
 .../internal/util/nodestart/StartNodeCallable.java |  6 ++---
 .../internal/util/offheap/GridOffHeapEvent.java    |  6 ++---
 .../util/offheap/GridOffHeapEventListener.java     |  6 ++---
 .../util/offheap/GridOffHeapEvictListener.java     |  6 ++---
 .../internal/util/offheap/GridOffHeapMap.java      |  6 ++---
 .../util/offheap/GridOffHeapMapFactory.java        |  6 ++---
 .../offheap/GridOffHeapOutOfMemoryException.java   |  6 ++---
 .../util/offheap/GridOffHeapPartitionedMap.java    |  6 ++---
 .../util/offheap/unsafe/GridUnsafeLru.java         |  6 ++---
 .../util/offheap/unsafe/GridUnsafeLruPoller.java   |  6 ++---
 .../util/offheap/unsafe/GridUnsafeMap.java         |  6 ++---
 .../util/offheap/unsafe/GridUnsafeMemory.java      |  6 ++---
 .../offheap/unsafe/GridUnsafePartitionedMap.java   |  6 ++---
 .../apache/ignite/internal/util/package-info.java  |  6 ++---
 .../util/portscanner/GridJmxPortFinder.java        |  6 ++---
 .../internal/util/portscanner/package-info.java    |  6 ++---
 .../apache/ignite/internal/util/scala/impl.java    |  6 ++---
 .../ignite/internal/util/scala/package-info.java   |  6 ++---
 .../internal/util/spring/IgniteSpringHelper.java   |  6 ++---
 .../internal/util/test/GridTestPrintStream.java    |  6 ++---
 .../util/test/GridTestPrintStreamFactory.java      |  6 ++---
 .../ignite/internal/util/test/package-info.java    |  6 ++---
 .../util/tostring/CircularStringBuilder.java       |  6 ++---
 .../util/tostring/GridToStringBuilder.java         |  6 ++---
 .../util/tostring/GridToStringClassDescriptor.java |  6 ++---
 .../util/tostring/GridToStringExclude.java         |  6 ++---
 .../util/tostring/GridToStringFieldDescriptor.java |  6 ++---
 .../util/tostring/GridToStringInclude.java         |  6 ++---
 .../internal/util/tostring/GridToStringOrder.java  |  6 ++---
 .../internal/util/tostring/SBLengthLimit.java      |  6 ++---
 .../internal/util/tostring/SBLimitedLength.java    |  6 ++---
 .../internal/util/tostring/package-info.java       |  6 ++---
 .../apache/ignite/internal/util/typedef/C1.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/C2.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/C3.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/CA.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/CAX.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/CI1.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/CI2.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/CI3.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/CIX1.java  |  6 ++---
 .../apache/ignite/internal/util/typedef/CIX2.java  |  6 ++---
 .../apache/ignite/internal/util/typedef/CIX3.java  |  6 ++---
 .../apache/ignite/internal/util/typedef/CO.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/COX.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/CX1.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/CX2.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/CX3.java   |  6 ++---
 .../org/apache/ignite/internal/util/typedef/F.java |  6 ++---
 .../org/apache/ignite/internal/util/typedef/G.java |  6 ++---
 .../apache/ignite/internal/util/typedef/P1.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/P2.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/P3.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/PA.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/PAX.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/PCE.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/PE.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/PKV.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/PN.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/PX1.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/PX2.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/PX3.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/R1.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/R2.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/R3.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/RX1.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/RX2.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/RX3.java   |  6 ++---
 .../apache/ignite/internal/util/typedef/T1.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/T2.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/T3.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/T4.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/T5.java    |  6 ++---
 .../apache/ignite/internal/util/typedef/T6.java    |  6 ++---
 .../org/apache/ignite/internal/util/typedef/X.java |  6 ++---
 .../ignite/internal/util/typedef/internal/A.java   |  6 ++---
 .../ignite/internal/util/typedef/internal/CU.java  |  6 ++---
 .../ignite/internal/util/typedef/internal/D.java   |  6 ++---
 .../ignite/internal/util/typedef/internal/GPC.java |  6 ++---
 .../ignite/internal/util/typedef/internal/GPR.java |  6 ++---
 .../ignite/internal/util/typedef/internal/LT.java  |  6 ++---
 .../ignite/internal/util/typedef/internal/S.java   |  6 ++---
 .../ignite/internal/util/typedef/internal/SB.java  |  6 ++---
 .../ignite/internal/util/typedef/internal/U.java   |  6 ++---
 .../util/typedef/internal/package-info.java        |  6 ++---
 .../ignite/internal/util/typedef/package-info.java |  6 ++---
 .../ignite/internal/util/worker/GridWorker.java    |  6 ++---
 .../internal/util/worker/GridWorkerFuture.java     |  6 ++---
 .../internal/util/worker/GridWorkerListener.java   |  6 ++---
 .../util/worker/GridWorkerListenerAdapter.java     |  6 ++---
 .../internal/util/worker/GridWorkerPool.java       |  6 ++---
 .../ignite/internal/util/worker/package-info.java  |  6 ++---
 .../internal/visor/VisorCoordinatorNodeTask.java   |  6 ++---
 .../internal/visor/VisorDataTransferObject.java    |  6 ++---
 .../visor/VisorDataTransferObjectInput.java        |  6 ++---
 .../visor/VisorDataTransferObjectOutput.java       |  6 ++---
 .../apache/ignite/internal/visor/VisorEither.java  |  6 ++---
 .../org/apache/ignite/internal/visor/VisorJob.java |  6 ++---
 .../ignite/internal/visor/VisorMultiNodeTask.java  |  6 ++---
 .../ignite/internal/visor/VisorOneNodeTask.java    |  6 ++---
 .../ignite/internal/visor/VisorTaskArgument.java   |  6 ++---
 .../baseline/VisorBaselineAutoAdjustSettings.java  |  6 ++---
 .../internal/visor/baseline/VisorBaselineNode.java |  6 ++---
 .../visor/baseline/VisorBaselineOperation.java     |  6 ++---
 .../internal/visor/baseline/VisorBaselineTask.java |  6 ++---
 .../visor/baseline/VisorBaselineTaskArg.java       |  6 ++---
 .../visor/baseline/VisorBaselineTaskResult.java    |  6 ++---
 .../visor/baseline/VisorBaselineViewTask.java      |  6 ++---
 .../internal/visor/binary/VisorBinaryMetadata.java |  6 ++---
 .../binary/VisorBinaryMetadataCollectorTask.java   |  6 ++---
 .../VisorBinaryMetadataCollectorTaskArg.java       |  6 ++---
 .../VisorBinaryMetadataCollectorTaskResult.java    |  6 ++---
 .../visor/binary/VisorBinaryMetadataField.java     |  6 ++---
 .../ignite/internal/visor/cache/VisorCache.java    |  6 ++---
 .../cache/VisorCacheAffinityConfiguration.java     |  6 ++---
 .../visor/cache/VisorCacheAffinityNodeTask.java    |  6 ++---
 .../visor/cache/VisorCacheAffinityNodeTaskArg.java |  6 ++---
 .../visor/cache/VisorCacheAggregatedMetrics.java   |  6 ++---
 .../internal/visor/cache/VisorCacheClearTask.java  |  6 ++---
 .../visor/cache/VisorCacheClearTaskArg.java        |  6 ++---
 .../visor/cache/VisorCacheClearTaskResult.java     |  6 ++---
 .../visor/cache/VisorCacheConfiguration.java       |  6 ++---
 .../cache/VisorCacheConfigurationCollectorJob.java |  6 ++---
 .../VisorCacheConfigurationCollectorTask.java      |  6 ++---
 .../VisorCacheConfigurationCollectorTaskArg.java   |  6 ++---
 .../cache/VisorCacheEvictionConfiguration.java     |  6 ++---
 .../internal/visor/cache/VisorCacheJdbcType.java   |  6 ++---
 .../visor/cache/VisorCacheJdbcTypeField.java       |  6 ++---
 .../internal/visor/cache/VisorCacheLoadTask.java   |  6 ++---
 .../visor/cache/VisorCacheLoadTaskArg.java         |  6 ++---
 .../visor/cache/VisorCacheLostPartitionsTask.java  |  6 ++---
 .../cache/VisorCacheLostPartitionsTaskArg.java     |  6 ++---
 .../cache/VisorCacheLostPartitionsTaskResult.java  |  6 ++---
 .../visor/cache/VisorCacheMetadataTask.java        |  6 ++---
 .../visor/cache/VisorCacheMetadataTaskArg.java     |  6 ++---
 .../internal/visor/cache/VisorCacheMetrics.java    |  6 ++---
 .../cache/VisorCacheMetricsCollectorTask.java      |  6 ++---
 .../cache/VisorCacheMetricsCollectorTaskArg.java   |  6 ++---
 .../internal/visor/cache/VisorCacheModifyTask.java |  6 ++---
 .../visor/cache/VisorCacheModifyTaskArg.java       |  6 ++---
 .../visor/cache/VisorCacheModifyTaskResult.java    |  6 ++---
 .../visor/cache/VisorCacheNamesCollectorTask.java  |  6 ++---
 .../cache/VisorCacheNamesCollectorTaskResult.java  |  6 ++---
 .../visor/cache/VisorCacheNearConfiguration.java   |  6 ++---
 .../internal/visor/cache/VisorCacheNodesTask.java  |  6 ++---
 .../visor/cache/VisorCacheNodesTaskArg.java        |  6 ++---
 .../internal/visor/cache/VisorCachePartitions.java |  6 ++---
 .../visor/cache/VisorCachePartitionsTask.java      |  6 ++---
 .../visor/cache/VisorCachePartitionsTaskArg.java   |  6 ++---
 .../cache/VisorCacheRebalanceConfiguration.java    |  6 ++---
 .../visor/cache/VisorCacheRebalanceTask.java       |  6 ++---
 .../visor/cache/VisorCacheRebalanceTaskArg.java    |  6 ++---
 .../cache/VisorCacheResetLostPartitionsTask.java   |  6 ++---
 .../VisorCacheResetLostPartitionsTaskArg.java      |  6 ++---
 .../visor/cache/VisorCacheResetMetricsTask.java    |  6 ++---
 .../visor/cache/VisorCacheResetMetricsTaskArg.java |  6 ++---
 .../visor/cache/VisorCacheSqlIndexMetadata.java    |  6 ++---
 .../visor/cache/VisorCacheSqlMetadata.java         |  6 ++---
 .../internal/visor/cache/VisorCacheStartTask.java  |  6 ++---
 .../visor/cache/VisorCacheStartTaskArg.java        |  6 ++---
 .../internal/visor/cache/VisorCacheStopTask.java   |  6 ++---
 .../visor/cache/VisorCacheStopTaskArg.java         |  6 ++---
 .../visor/cache/VisorCacheStoreConfiguration.java  |  6 ++---
 .../cache/VisorCacheToggleStatisticsTask.java      |  6 ++---
 .../cache/VisorCacheToggleStatisticsTaskArg.java   |  6 ++---
 .../internal/visor/cache/VisorMemoryMetrics.java   |  6 ++---
 .../internal/visor/cache/VisorModifyCacheMode.java |  6 ++---
 .../internal/visor/cache/VisorPartitionMap.java    |  6 ++---
 .../compute/VisorComputeCancelSessionsTask.java    |  6 ++---
 .../compute/VisorComputeCancelSessionsTaskArg.java |  6 ++---
 .../compute/VisorComputeMonitoringHolder.java      |  6 ++---
 .../compute/VisorComputeResetMetricsTask.java      |  6 ++---
 .../compute/VisorComputeToggleMonitoringTask.java  |  6 ++---
 .../VisorComputeToggleMonitoringTaskArg.java       |  6 ++---
 .../internal/visor/compute/VisorGatewayTask.java   |  6 ++---
 .../internal/visor/debug/VisorThreadDumpTask.java  |  6 ++---
 .../visor/debug/VisorThreadDumpTaskResult.java     |  6 ++---
 .../internal/visor/debug/VisorThreadInfo.java      |  6 ++---
 .../internal/visor/debug/VisorThreadLockInfo.java  |  6 ++---
 .../visor/debug/VisorThreadMonitorInfo.java        |  6 ++---
 .../visor/event/VisorGridDeploymentEvent.java      |  6 ++---
 .../visor/event/VisorGridDiscoveryEvent.java       |  6 ++---
 .../internal/visor/event/VisorGridEvent.java       |  6 ++---
 .../internal/visor/event/VisorGridEventsLost.java  |  6 ++---
 .../internal/visor/event/VisorGridJobEvent.java    |  6 ++---
 .../internal/visor/event/VisorGridTaskEvent.java   |  6 ++---
 .../ignite/internal/visor/file/VisorFileBlock.java |  6 ++---
 .../internal/visor/file/VisorFileBlockTask.java    |  6 ++---
 .../internal/visor/file/VisorFileBlockTaskArg.java |  6 ++---
 .../visor/file/VisorFileBlockTaskResult.java       |  6 ++---
 .../visor/file/VisorLatestTextFilesTask.java       |  6 ++---
 .../visor/file/VisorLatestTextFilesTaskArg.java    |  6 ++---
 .../ignite/internal/visor/igfs/VisorIgfs.java      |  6 ++---
 .../internal/visor/igfs/VisorIgfsEndpoint.java     |  6 ++---
 .../internal/visor/igfs/VisorIgfsFormatTask.java   |  6 ++---
 .../visor/igfs/VisorIgfsFormatTaskArg.java         |  6 ++---
 .../internal/visor/igfs/VisorIgfsMetrics.java      |  6 ++---
 .../internal/visor/igfs/VisorIgfsProfiler.java     |  6 ++---
 .../visor/igfs/VisorIgfsProfilerClearTask.java     |  6 ++---
 .../visor/igfs/VisorIgfsProfilerClearTaskArg.java  |  6 ++---
 .../igfs/VisorIgfsProfilerClearTaskResult.java     |  6 ++---
 .../visor/igfs/VisorIgfsProfilerEntry.java         |  6 ++---
 .../internal/visor/igfs/VisorIgfsProfilerTask.java |  6 ++---
 .../visor/igfs/VisorIgfsProfilerTaskArg.java       |  6 ++---
 .../igfs/VisorIgfsProfilerUniformityCounters.java  |  6 ++---
 .../visor/igfs/VisorIgfsResetMetricsTask.java      |  6 ++---
 .../visor/igfs/VisorIgfsResetMetricsTaskArg.java   |  6 ++---
 .../visor/igfs/VisorIgfsSamplingStateTask.java     |  6 ++---
 .../visor/igfs/VisorIgfsSamplingStateTaskArg.java  |  6 ++---
 .../ignite/internal/visor/log/VisorLogFile.java    |  6 ++---
 .../internal/visor/log/VisorLogSearchResult.java   |  6 ++---
 .../internal/visor/log/VisorLogSearchTask.java     |  6 ++---
 .../internal/visor/log/VisorLogSearchTaskArg.java  |  6 ++---
 .../visor/log/VisorLogSearchTaskResult.java        |  6 ++---
 .../ignite/internal/visor/misc/VisorAckTask.java   |  6 ++---
 .../internal/visor/misc/VisorAckTaskArg.java       |  6 ++---
 .../visor/misc/VisorChangeGridActiveStateTask.java |  6 ++---
 .../misc/VisorChangeGridActiveStateTaskArg.java    |  6 ++---
 .../internal/visor/misc/VisorClusterNode.java      |  6 ++---
 .../visor/misc/VisorLatestVersionTask.java         |  6 ++---
 .../ignite/internal/visor/misc/VisorNopTask.java   |  6 ++---
 .../visor/misc/VisorResolveHostNameTask.java       |  6 ++---
 .../ignite/internal/visor/misc/VisorWalTask.java   |  6 ++---
 .../internal/visor/misc/VisorWalTaskArg.java       |  6 ++---
 .../internal/visor/misc/VisorWalTaskOperation.java |  6 ++---
 .../internal/visor/misc/VisorWalTaskResult.java    |  6 ++---
 .../visor/node/VisorAffinityTopologyVersion.java   |  6 ++---
 .../visor/node/VisorAtomicConfiguration.java       |  6 ++---
 .../visor/node/VisorBasicConfiguration.java        |  6 ++---
 .../visor/node/VisorBinaryConfiguration.java       |  6 ++---
 .../visor/node/VisorBinaryTypeConfiguration.java   |  6 ++---
 .../visor/node/VisorCacheKeyConfiguration.java     |  6 ++---
 .../VisorCacheRebalanceCollectorJobResult.java     |  6 ++---
 .../node/VisorCacheRebalanceCollectorTask.java     |  6 ++---
 .../node/VisorCacheRebalanceCollectorTaskArg.java  |  6 ++---
 .../VisorCacheRebalanceCollectorTaskResult.java    |  6 ++---
 .../node/VisorClientConnectorConfiguration.java    |  6 ++---
 .../visor/node/VisorDataRegionConfiguration.java   |  6 ++---
 .../visor/node/VisorDataStorageConfiguration.java  |  6 ++---
 .../visor/node/VisorExecutorConfiguration.java     |  6 ++---
 .../node/VisorExecutorServiceConfiguration.java    |  6 ++---
 .../visor/node/VisorGridConfiguration.java         |  6 ++---
 .../visor/node/VisorHadoopConfiguration.java       |  6 ++---
 .../visor/node/VisorIgfsConfiguration.java         |  6 ++---
 .../visor/node/VisorLifecycleConfiguration.java    |  6 ++---
 .../visor/node/VisorMemoryConfiguration.java       |  6 ++---
 .../visor/node/VisorMemoryPolicyConfiguration.java |  6 ++---
 .../visor/node/VisorMetricsConfiguration.java      |  6 ++---
 .../visor/node/VisorMvccConfiguration.java         |  6 ++---
 .../visor/node/VisorNodeBaselineStatus.java        |  6 ++---
 .../node/VisorNodeConfigurationCollectorJob.java   |  6 ++---
 .../node/VisorNodeConfigurationCollectorTask.java  |  6 ++---
 .../visor/node/VisorNodeDataCollectorJob.java      |  6 ++---
 .../node/VisorNodeDataCollectorJobResult.java      |  6 ++---
 .../visor/node/VisorNodeDataCollectorTask.java     |  6 ++---
 .../visor/node/VisorNodeDataCollectorTaskArg.java  |  6 ++---
 .../node/VisorNodeDataCollectorTaskResult.java     |  6 ++---
 .../visor/node/VisorNodeEventsCollectorTask.java   |  6 ++---
 .../node/VisorNodeEventsCollectorTaskArg.java      |  6 ++---
 .../internal/visor/node/VisorNodeGcTask.java       |  6 ++---
 .../internal/visor/node/VisorNodeGcTaskResult.java |  6 ++---
 .../internal/visor/node/VisorNodePingTask.java     |  6 ++---
 .../internal/visor/node/VisorNodePingTaskArg.java  |  6 ++---
 .../visor/node/VisorNodePingTaskResult.java        |  6 ++---
 .../internal/visor/node/VisorNodeRestartTask.java  |  6 ++---
 .../internal/visor/node/VisorNodeStopTask.java     |  6 ++---
 .../visor/node/VisorNodeSuppressedErrors.java      |  6 ++---
 .../visor/node/VisorNodeSuppressedErrorsTask.java  |  6 ++---
 .../node/VisorNodeSuppressedErrorsTaskArg.java     |  6 ++---
 .../visor/node/VisorPeerToPeerConfiguration.java   |  6 ++---
 .../visor/node/VisorPersistenceMetrics.java        |  6 ++---
 .../node/VisorPersistentStoreConfiguration.java    |  6 ++---
 .../visor/node/VisorRestConfiguration.java         |  6 ++---
 .../visor/node/VisorSegmentationConfiguration.java |  6 ++---
 .../visor/node/VisorServiceConfiguration.java      |  6 ++---
 .../internal/visor/node/VisorSpiDescription.java   |  6 ++---
 .../visor/node/VisorSpisConfiguration.java         |  6 ++---
 .../visor/node/VisorSqlConnectorConfiguration.java |  6 ++---
 .../internal/visor/node/VisorSuppressedError.java  |  6 ++---
 .../visor/node/VisorTransactionConfiguration.java  |  6 ++---
 .../internal/visor/query/VisorQueryCancelTask.java |  6 ++---
 .../visor/query/VisorQueryCancelTaskArg.java       |  6 ++---
 .../visor/query/VisorQueryCleanupTask.java         |  6 ++---
 .../visor/query/VisorQueryCleanupTaskArg.java      |  6 ++---
 .../visor/query/VisorQueryConfiguration.java       |  6 ++---
 .../visor/query/VisorQueryDetailMetrics.java       |  6 ++---
 .../VisorQueryDetailMetricsCollectorTask.java      |  6 ++---
 .../VisorQueryDetailMetricsCollectorTaskArg.java   |  6 ++---
 .../internal/visor/query/VisorQueryEntity.java     |  6 ++---
 .../visor/query/VisorQueryFetchFirstPageTask.java  |  6 ++---
 .../internal/visor/query/VisorQueryField.java      |  6 ++---
 .../internal/visor/query/VisorQueryHolder.java     |  6 ++---
 .../internal/visor/query/VisorQueryIndex.java      |  6 ++---
 .../internal/visor/query/VisorQueryIndexField.java |  6 ++---
 .../internal/visor/query/VisorQueryMetrics.java    |  6 ++---
 .../visor/query/VisorQueryNextPageTask.java        |  6 ++---
 .../visor/query/VisorQueryNextPageTaskArg.java     |  6 ++---
 .../internal/visor/query/VisorQueryPingTask.java   |  6 ++---
 .../visor/query/VisorQueryPingTaskResult.java      |  6 ++---
 .../query/VisorQueryResetDetailMetricsTask.java    |  6 ++---
 .../visor/query/VisorQueryResetMetricsTask.java    |  6 ++---
 .../visor/query/VisorQueryResetMetricsTaskArg.java |  6 ++---
 .../internal/visor/query/VisorQueryResult.java     |  6 ++---
 .../visor/query/VisorQueryScanRegexFilter.java     |  6 ++---
 .../internal/visor/query/VisorQueryTask.java       |  6 ++---
 .../internal/visor/query/VisorQueryTaskArg.java    |  6 ++---
 .../internal/visor/query/VisorQueryUtils.java      |  6 ++---
 .../query/VisorRunningQueriesCollectorTask.java    |  6 ++---
 .../query/VisorRunningQueriesCollectorTaskArg.java |  6 ++---
 .../internal/visor/query/VisorRunningQuery.java    |  6 ++---
 .../internal/visor/query/VisorScanQueryTask.java   |  6 ++---
 .../visor/query/VisorScanQueryTaskArg.java         |  6 ++---
 .../visor/service/VisorCancelServiceTask.java      |  6 ++---
 .../visor/service/VisorCancelServiceTaskArg.java   |  6 ++---
 .../visor/service/VisorServiceDescriptor.java      |  6 ++---
 .../internal/visor/service/VisorServiceTask.java   |  6 ++---
 .../internal/visor/tx/FetchNearXidVersionTask.java |  6 ++---
 .../ignite/internal/visor/tx/TxKeyLockType.java    |  6 ++---
 .../ignite/internal/visor/tx/TxMappingType.java    |  6 ++---
 .../ignite/internal/visor/tx/TxVerboseId.java      |  6 ++---
 .../ignite/internal/visor/tx/TxVerboseInfo.java    |  6 ++---
 .../ignite/internal/visor/tx/TxVerboseKey.java     |  6 ++---
 .../ignite/internal/visor/tx/VisorTxInfo.java      |  6 ++---
 .../ignite/internal/visor/tx/VisorTxOperation.java |  6 ++---
 .../internal/visor/tx/VisorTxProjection.java       |  6 ++---
 .../ignite/internal/visor/tx/VisorTxSortOrder.java |  6 ++---
 .../ignite/internal/visor/tx/VisorTxTask.java      |  6 ++---
 .../ignite/internal/visor/tx/VisorTxTaskArg.java   |  6 ++---
 .../internal/visor/tx/VisorTxTaskResult.java       |  6 ++---
 .../util/VisorClusterGroupEmptyException.java      |  6 ++---
 .../internal/visor/util/VisorEventMapper.java      |  6 ++---
 .../internal/visor/util/VisorExceptionWrapper.java |  6 ++---
 .../ignite/internal/visor/util/VisorMimeTypes.java |  6 ++---
 .../ignite/internal/visor/util/VisorTaskUtils.java |  6 ++---
 .../internal/visor/verify/CacheFilterEnum.java     |  6 ++---
 .../visor/verify/IndexIntegrityCheckIssue.java     |  6 ++---
 .../visor/verify/IndexValidationIssue.java         |  6 ++---
 .../verify/ValidateIndexesPartitionResult.java     |  6 ++---
 .../visor/verify/VisorContentionJobResult.java     |  6 ++---
 .../internal/visor/verify/VisorContentionTask.java |  6 ++---
 .../visor/verify/VisorContentionTaskArg.java       |  6 ++---
 .../visor/verify/VisorContentionTaskResult.java    |  6 ++---
 .../visor/verify/VisorIdleAnalyzeTask.java         |  6 ++---
 .../visor/verify/VisorIdleAnalyzeTaskArg.java      |  6 ++---
 .../visor/verify/VisorIdleAnalyzeTaskResult.java   |  6 ++---
 .../visor/verify/VisorIdleVerifyDumpTask.java      |  6 ++---
 .../visor/verify/VisorIdleVerifyDumpTaskArg.java   |  6 ++---
 .../internal/visor/verify/VisorIdleVerifyJob.java  |  6 ++---
 .../internal/visor/verify/VisorIdleVerifyTask.java |  6 ++---
 .../visor/verify/VisorIdleVerifyTaskArg.java       |  6 ++---
 .../visor/verify/VisorIdleVerifyTaskResult.java    |  6 ++---
 .../visor/verify/VisorIdleVerifyTaskV2.java        |  6 ++---
 .../verify/VisorValidateIndexesJobResult.java      |  6 ++---
 .../visor/verify/VisorValidateIndexesTaskArg.java  |  6 ++---
 .../verify/VisorValidateIndexesTaskResult.java     |  6 ++---
 .../internal/visor/verify/VisorViewCacheCmd.java   |  6 ++---
 .../internal/visor/verify/VisorViewCacheTask.java  |  6 ++---
 .../visor/verify/VisorViewCacheTaskArg.java        |  6 ++---
 .../visor/verify/VisorViewCacheTaskResult.java     |  6 ++---
 .../websession/WebSessionAttributeProcessor.java   |  6 ++---
 .../internal/websession/WebSessionEntity.java      |  6 ++---
 .../internal/worker/FailureHandlingMxBeanImpl.java |  6 ++---
 .../internal/worker/WorkersControlMXBeanImpl.java  |  6 ++---
 .../ignite/internal/worker/WorkersRegistry.java    |  6 ++---
 .../ignite/internal/worker/package-info.java       |  6 ++---
 .../apache/ignite/lang/IgniteAsyncCallback.java    |  6 ++---
 .../org/apache/ignite/lang/IgniteAsyncSupport.java |  6 ++---
 .../apache/ignite/lang/IgniteAsyncSupported.java   |  6 ++---
 .../org/apache/ignite/lang/IgniteBiClosure.java    |  6 ++---
 .../org/apache/ignite/lang/IgniteBiInClosure.java  |  6 ++---
 .../org/apache/ignite/lang/IgniteBiPredicate.java  |  6 ++---
 .../java/org/apache/ignite/lang/IgniteBiTuple.java |  6 ++---
 .../org/apache/ignite/lang/IgniteCallable.java     |  6 ++---
 .../java/org/apache/ignite/lang/IgniteClosure.java |  6 ++---
 .../java/org/apache/ignite/lang/IgniteFuture.java  |  6 ++---
 .../lang/IgniteFutureCancelledException.java       |  6 ++---
 .../ignite/lang/IgniteFutureTimeoutException.java  |  6 ++---
 .../org/apache/ignite/lang/IgniteInClosure.java    |  6 ++---
 .../ignite/lang/IgniteNotPeerDeployable.java       |  6 ++---
 .../org/apache/ignite/lang/IgniteOutClosure.java   |  6 ++---
 .../org/apache/ignite/lang/IgnitePredicate.java    |  6 ++---
 .../apache/ignite/lang/IgniteProductVersion.java   |  6 ++---
 .../java/org/apache/ignite/lang/IgniteReducer.java |  6 ++---
 .../org/apache/ignite/lang/IgniteRunnable.java     |  6 ++---
 .../java/org/apache/ignite/lang/IgniteUuid.java    |  6 ++---
 .../java/org/apache/ignite/lang/package-info.java  |  6 ++---
 .../apache/ignite/lifecycle/LifecycleAware.java    |  6 ++---
 .../org/apache/ignite/lifecycle/LifecycleBean.java |  6 ++---
 .../ignite/lifecycle/LifecycleEventType.java       |  6 ++---
 .../org/apache/ignite/lifecycle/package-info.java  |  6 ++---
 .../apache/ignite/logger/LoggerNodeIdAware.java    |  6 ++---
 .../java/org/apache/ignite/logger/NullLogger.java  |  6 ++---
 .../org/apache/ignite/logger/java/JavaLogger.java  |  6 ++---
 .../ignite/logger/java/JavaLoggerFileHandler.java  |  6 ++---
 .../ignite/logger/java/JavaLoggerFormatter.java    |  6 ++---
 .../apache/ignite/logger/java/package-info.java    |  6 ++---
 .../org/apache/ignite/logger/package-info.java     |  6 ++---
 .../ignite/marshaller/AbstractMarshaller.java      |  6 ++---
 .../AbstractNodeNameAwareMarshaller.java           |  6 ++---
 .../org/apache/ignite/marshaller/Marshaller.java   |  6 ++---
 .../ignite/marshaller/MarshallerContext.java       |  6 ++---
 .../ignite/marshaller/MarshallerExclusions.java    |  6 ++---
 .../apache/ignite/marshaller/MarshallerUtils.java  |  6 ++---
 .../ignite/marshaller/jdk/JdkMarshaller.java       |  6 ++---
 .../jdk/JdkMarshallerDummySerializable.java        |  6 ++---
 .../jdk/JdkMarshallerInputStreamWrapper.java       |  6 ++---
 .../jdk/JdkMarshallerObjectInputStream.java        |  6 ++---
 .../jdk/JdkMarshallerObjectOutputStream.java       |  6 ++---
 .../jdk/JdkMarshallerOutputStreamWrapper.java      |  6 ++---
 .../apache/ignite/marshaller/jdk/package-info.java |  6 ++---
 .../org/apache/ignite/marshaller/package-info.java |  6 ++---
 .../ignite/messaging/MessagingListenActor.java     |  6 ++---
 .../org/apache/ignite/messaging/package-info.java  |  6 ++---
 .../ignite/mxbean/BaselineAutoAdjustMXBean.java    |  6 ++---
 .../ignite/mxbean/CacheGroupMetricsMXBean.java     |  6 ++---
 .../apache/ignite/mxbean/CacheMetricsMXBean.java   |  6 ++---
 .../ignite/mxbean/ClientProcessorMXBean.java       |  6 ++---
 .../apache/ignite/mxbean/ClusterMetricsMXBean.java |  6 ++---
 .../ignite/mxbean/DataRegionMetricsMXBean.java     |  6 ++---
 .../apache/ignite/mxbean/DataStorageMXBean.java    |  6 ++---
 .../ignite/mxbean/DataStorageMetricsMXBean.java    |  6 ++---
 .../ignite/mxbean/FailureHandlingMxBean.java       |  6 ++---
 .../org/apache/ignite/mxbean/IgniteMBeanAware.java |  6 ++---
 .../org/apache/ignite/mxbean/IgniteMXBean.java     |  6 ++---
 .../org/apache/ignite/mxbean/IgnitionMXBean.java   |  6 ++---
 .../ignite/mxbean/IoStatisticsMetricsMXBean.java   |  6 ++---
 .../apache/ignite/mxbean/MXBeanDescription.java    |  6 ++---
 .../mxbean/MXBeanParametersDescriptions.java       |  6 ++---
 .../ignite/mxbean/MXBeanParametersNames.java       |  6 ++---
 .../apache/ignite/mxbean/MemoryMetricsMXBean.java  |  6 ++---
 .../ignite/mxbean/PersistenceMetricsMXBean.java    |  6 ++---
 .../ignite/mxbean/StripedExecutorMXBean.java       |  6 ++---
 .../org/apache/ignite/mxbean/ThreadPoolMXBean.java |  6 ++---
 .../ignite/mxbean/TransactionMetricsMxBean.java    |  6 ++---
 .../apache/ignite/mxbean/TransactionsMXBean.java   |  6 ++---
 .../apache/ignite/mxbean/WorkersControlMXBean.java |  6 ++---
 .../org/apache/ignite/mxbean/package-info.java     |  6 ++---
 .../main/java/org/apache/ignite/package-info.java  |  6 ++---
 .../ignite/platform/PlatformJavaObjectFactory.java |  6 ++---
 .../platform/cpp/PlatformCppConfiguration.java     |  6 ++---
 .../apache/ignite/platform/cpp/package-info.java   |  6 ++---
 .../dotnet/PlatformDotNetAffinityFunction.java     |  6 ++---
 .../dotnet/PlatformDotNetBinaryConfiguration.java  |  6 ++---
 .../PlatformDotNetBinaryTypeConfiguration.java     |  6 ++---
 .../dotnet/PlatformDotNetCacheStoreFactory.java    |  6 ++---
 .../PlatformDotNetCacheStoreFactoryNative.java     |  6 ++---
 .../dotnet/PlatformDotNetConfiguration.java        |  6 ++---
 .../dotnet/PlatformDotNetLifecycleBean.java        |  6 ++---
 .../ignite/platform/dotnet/package-info.java       |  6 ++---
 .../org/apache/ignite/platform/package-info.java   |  6 ++---
 .../ignite/plugin/CachePluginConfiguration.java    |  6 ++---
 .../apache/ignite/plugin/CachePluginContext.java   |  6 ++---
 .../apache/ignite/plugin/CachePluginProvider.java  |  6 ++---
 .../java/org/apache/ignite/plugin/Extension.java   |  6 ++---
 .../apache/ignite/plugin/ExtensionRegistry.java    |  6 ++---
 .../org/apache/ignite/plugin/IgnitePlugin.java     |  6 ++---
 .../apache/ignite/plugin/PluginConfiguration.java  |  6 ++---
 .../org/apache/ignite/plugin/PluginContext.java    |  6 ++---
 .../ignite/plugin/PluginNotFoundException.java     |  6 ++---
 .../org/apache/ignite/plugin/PluginProvider.java   |  6 ++---
 .../ignite/plugin/PluginValidationException.java   |  6 ++---
 .../plugin/extensions/communication/IoPool.java    |  6 ++---
 .../plugin/extensions/communication/Message.java   |  6 ++---
 .../communication/MessageCollectionItemType.java   |  6 ++---
 .../extensions/communication/MessageFactory.java   |  6 ++---
 .../extensions/communication/MessageFormatter.java |  6 ++---
 .../extensions/communication/MessageReader.java    |  6 ++---
 .../extensions/communication/MessageWriter.java    |  6 ++---
 .../extensions/communication/package-info.java     |  6 ++---
 .../org/apache/ignite/plugin/package-info.java     |  6 ++---
 .../PlatformCachePluginConfigurationClosure.java   |  6 ++---
 ...formCachePluginConfigurationClosureFactory.java |  6 ++---
 .../PlatformPluginConfigurationClosure.java        |  6 ++---
 .../PlatformPluginConfigurationClosureFactory.java |  6 ++---
 .../ignite/plugin/platform/package-info.java       |  6 ++---
 .../plugin/security/AuthenticationContext.java     |  6 ++---
 .../security/SecurityBasicPermissionSet.java       |  6 ++---
 .../plugin/security/SecurityCredentials.java       |  6 ++---
 .../security/SecurityCredentialsBasicProvider.java |  6 ++---
 .../security/SecurityCredentialsProvider.java      |  6 ++---
 .../ignite/plugin/security/SecurityException.java  |  6 ++---
 .../ignite/plugin/security/SecurityPermission.java |  6 ++---
 .../plugin/security/SecurityPermissionSet.java     |  6 ++---
 .../security/SecurityPermissionSetBuilder.java     |  6 ++---
 .../ignite/plugin/security/SecuritySubject.java    |  6 ++---
 .../plugin/security/SecuritySubjectType.java       |  6 ++---
 .../ignite/plugin/security/package-info.java       |  6 ++---
 .../plugin/segmentation/SegmentationPolicy.java    |  6 ++---
 .../plugin/segmentation/SegmentationResolver.java  |  6 ++---
 .../ignite/plugin/segmentation/package-info.java   |  6 ++---
 .../apache/ignite/resources/CacheNameResource.java |  6 ++---
 .../resources/CacheStoreSessionResource.java       |  6 ++---
 .../ignite/resources/FileSystemResource.java       |  6 ++---
 .../ignite/resources/IgniteInstanceResource.java   |  6 ++---
 .../ignite/resources/JobContextResource.java       |  6 ++---
 .../ignite/resources/LoadBalancerResource.java     |  6 ++---
 .../apache/ignite/resources/LoggerResource.java    |  6 ++---
 .../apache/ignite/resources/ServiceResource.java   |  6 ++---
 .../SpringApplicationContextResource.java          |  6 ++---
 .../apache/ignite/resources/SpringResource.java    |  6 ++---
 .../resources/TaskContinuousMapperResource.java    |  6 ++---
 .../ignite/resources/TaskSessionResource.java      |  6 ++---
 .../org/apache/ignite/resources/package-info.java  |  6 ++---
 .../apache/ignite/scheduler/SchedulerFuture.java   |  6 ++---
 .../org/apache/ignite/scheduler/package-info.java  |  6 ++---
 .../java/org/apache/ignite/services/Service.java   |  6 ++---
 .../ignite/services/ServiceConfiguration.java      |  6 ++---
 .../org/apache/ignite/services/ServiceContext.java |  6 ++---
 .../services/ServiceDeploymentException.java       |  6 ++---
 .../apache/ignite/services/ServiceDescriptor.java  |  6 ++---
 .../org/apache/ignite/services/package-info.java   |  6 ++---
 .../spi/ExponentialBackoffTimeoutStrategy.java     |  6 ++---
 .../ignite/spi/IgniteNodeValidationResult.java     |  6 ++---
 .../org/apache/ignite/spi/IgnitePortProtocol.java  |  6 ++---
 .../main/java/org/apache/ignite/spi/IgniteSpi.java |  6 ++---
 .../org/apache/ignite/spi/IgniteSpiAdapter.java    |  6 ++---
 .../ignite/spi/IgniteSpiCloseableIterator.java     |  6 ++---
 .../apache/ignite/spi/IgniteSpiConfiguration.java  |  6 ++---
 .../ignite/spi/IgniteSpiConsistencyChecked.java    |  6 ++---
 .../org/apache/ignite/spi/IgniteSpiContext.java    |  6 ++---
 .../org/apache/ignite/spi/IgniteSpiException.java  |  6 ++---
 .../apache/ignite/spi/IgniteSpiMBeanAdapter.java   |  6 ++---
 .../ignite/spi/IgniteSpiManagementMBean.java       |  6 ++---
 .../apache/ignite/spi/IgniteSpiMultiException.java |  6 ++---
 .../spi/IgniteSpiMultipleInstancesSupport.java     |  6 ++---
 .../java/org/apache/ignite/spi/IgniteSpiNoop.java  |  6 ++---
 .../spi/IgniteSpiOperationTimeoutException.java    |  6 ++---
 .../spi/IgniteSpiOperationTimeoutHelper.java       |  6 ++---
 .../org/apache/ignite/spi/IgniteSpiThread.java     |  6 ++---
 .../apache/ignite/spi/IgniteSpiThreadFactory.java  |  6 ++---
 .../apache/ignite/spi/IgniteSpiTimeoutObject.java  |  6 ++---
 .../ignite/spi/IgniteSpiVersionCheckException.java |  6 ++---
 .../org/apache/ignite/spi/TimeoutStrategy.java     |  6 ++---
 .../ignite/spi/checkpoint/CheckpointListener.java  |  6 ++---
 .../ignite/spi/checkpoint/CheckpointSpi.java       |  6 ++---
 .../spi/checkpoint/cache/CacheCheckpointSpi.java   |  6 ++---
 .../checkpoint/cache/CacheCheckpointSpiMBean.java  |  6 ++---
 .../ignite/spi/checkpoint/cache/package-info.java  |  6 ++---
 .../spi/checkpoint/jdbc/JdbcCheckpointSpi.java     |  6 ++---
 .../checkpoint/jdbc/JdbcCheckpointSpiMBean.java    |  6 ++---
 .../ignite/spi/checkpoint/jdbc/package-info.java   |  6 ++---
 .../spi/checkpoint/noop/NoopCheckpointSpi.java     |  6 ++---
 .../ignite/spi/checkpoint/noop/package-info.java   |  6 ++---
 .../apache/ignite/spi/checkpoint/package-info.java |  6 ++---
 .../sharedfs/SharedFsCheckpointData.java           |  6 ++---
 .../checkpoint/sharedfs/SharedFsCheckpointSpi.java |  6 ++---
 .../sharedfs/SharedFsCheckpointSpiMBean.java       |  6 ++---
 .../spi/checkpoint/sharedfs/SharedFsTimeData.java  |  6 ++---
 .../checkpoint/sharedfs/SharedFsTimeoutTask.java   |  6 ++---
 .../spi/checkpoint/sharedfs/SharedFsUtils.java     |  6 ++---
 .../spi/checkpoint/sharedfs/package-info.java      |  6 ++---
 .../ignite/spi/collision/CollisionContext.java     |  6 ++---
 .../spi/collision/CollisionExternalListener.java   |  6 ++---
 .../ignite/spi/collision/CollisionJobContext.java  |  6 ++---
 .../apache/ignite/spi/collision/CollisionSpi.java  |  6 ++---
 .../collision/fifoqueue/FifoQueueCollisionSpi.java |  6 ++---
 .../fifoqueue/FifoQueueCollisionSpiMBean.java      |  6 ++---
 .../spi/collision/fifoqueue/package-info.java      |  6 ++---
 .../jobstealing/JobStealingCollisionSpi.java       |  6 ++---
 .../jobstealing/JobStealingCollisionSpiMBean.java  |  6 ++---
 .../collision/jobstealing/JobStealingDisabled.java |  6 ++---
 .../collision/jobstealing/JobStealingRequest.java  |  6 ++---
 .../spi/collision/jobstealing/package-info.java    |  6 ++---
 .../spi/collision/noop/NoopCollisionSpi.java       |  6 ++---
 .../ignite/spi/collision/noop/package-info.java    |  6 ++---
 .../apache/ignite/spi/collision/package-info.java  |  6 ++---
 .../priorityqueue/PriorityQueueCollisionSpi.java   |  6 ++---
 .../PriorityQueueCollisionSpiMBean.java            |  6 ++---
 .../spi/collision/priorityqueue/package-info.java  |  6 ++---
 .../spi/communication/CommunicationListener.java   |  6 ++---
 .../ignite/spi/communication/CommunicationSpi.java |  6 ++---
 .../ignite/spi/communication/package-info.java     |  6 ++---
 .../tcp/TcpCommunicationMetricsListener.java       |  6 ++---
 .../spi/communication/tcp/TcpCommunicationSpi.java |  6 ++---
 .../tcp/TcpCommunicationSpiMBean.java              |  6 ++---
 .../communication/tcp/internal/ConnectionKey.java  |  6 ++---
 .../tcp/internal/HandshakeException.java           |  6 ++---
 .../TcpCommunicationConnectionCheckFuture.java     |  6 ++---
 .../TcpCommunicationNodeConnectionCheckFuture.java |  6 ++---
 .../communication/tcp/internal/package-info.java   |  6 ++---
 .../tcp/messages/HandshakeMessage.java             |  6 ++---
 .../tcp/messages/HandshakeMessage2.java            |  6 ++---
 .../tcp/messages/HandshakeWaitMessage.java         |  6 ++---
 .../communication/tcp/messages/NodeIdMessage.java  |  6 ++---
 .../tcp/messages/RecoveryLastReceivedMessage.java  |  6 ++---
 .../communication/tcp/messages/package-info.java   |  6 ++---
 .../ignite/spi/communication/tcp/package-info.java |  6 ++---
 .../ignite/spi/deployment/DeploymentListener.java  |  6 ++---
 .../ignite/spi/deployment/DeploymentResource.java  |  6 ++---
 .../spi/deployment/DeploymentResourceAdapter.java  |  6 ++---
 .../ignite/spi/deployment/DeploymentSpi.java       |  6 ++---
 .../IgnoreIfPeerClassLoadingDisabled.java          |  6 ++---
 .../spi/deployment/local/LocalDeploymentSpi.java   |  6 ++---
 .../deployment/local/LocalDeploymentSpiMBean.java  |  6 ++---
 .../ignite/spi/deployment/local/package-info.java  |  6 ++---
 .../apache/ignite/spi/deployment/package-info.java |  6 ++---
 .../ignite/spi/discovery/DiscoveryDataBag.java     |  6 ++---
 .../spi/discovery/DiscoveryMetricsProvider.java    |  6 ++---
 .../apache/ignite/spi/discovery/DiscoverySpi.java  |  6 ++---
 .../spi/discovery/DiscoverySpiCustomMessage.java   |  6 ++---
 .../spi/discovery/DiscoverySpiDataExchange.java    |  6 ++---
 .../spi/discovery/DiscoverySpiHistorySupport.java  |  6 ++---
 .../ignite/spi/discovery/DiscoverySpiListener.java |  6 ++---
 .../ignite/spi/discovery/DiscoverySpiMBean.java    |  6 ++---
 .../DiscoverySpiMutableCustomMessageSupport.java   |  6 ++---
 .../discovery/DiscoverySpiNodeAuthenticator.java   |  6 ++---
 .../spi/discovery/DiscoverySpiOrderSupport.java    |  6 ++---
 .../spi/discovery/IgniteDiscoveryThread.java       |  6 ++---
 .../apache/ignite/spi/discovery/package-info.java  |  6 ++---
 .../ignite/spi/discovery/tcp/ClientImpl.java       |  6 ++---
 .../ignite/spi/discovery/tcp/ServerImpl.java       |  6 ++---
 .../ignite/spi/discovery/tcp/TcpDiscoveryImpl.java |  6 ++---
 .../ignite/spi/discovery/tcp/TcpDiscoverySpi.java  |  6 ++---
 .../spi/discovery/tcp/TcpDiscoverySpiMBean.java    |  6 ++---
 .../tcp/internal/DiscoveryDataPacket.java          |  6 ++---
 .../spi/discovery/tcp/internal/FutureTask.java     |  6 ++---
 .../discovery/tcp/internal/TcpDiscoveryNode.java   |  6 ++---
 .../tcp/internal/TcpDiscoveryNodesRing.java        |  6 ++---
 .../tcp/internal/TcpDiscoverySpiState.java         |  6 ++---
 .../tcp/internal/TcpDiscoveryStatistics.java       |  6 ++---
 .../spi/discovery/tcp/internal/package-info.java   |  6 ++---
 .../tcp/ipfinder/TcpDiscoveryIpFinder.java         |  6 ++---
 .../tcp/ipfinder/TcpDiscoveryIpFinderAdapter.java  |  6 ++---
 .../ipfinder/jdbc/BasicJdbcIpFinderDialect.java    |  6 ++---
 .../tcp/ipfinder/jdbc/JdbcIpFinderDialect.java     |  6 ++---
 .../ipfinder/jdbc/OracleJdbcIpFinderDialect.java   |  6 ++---
 .../ipfinder/jdbc/TcpDiscoveryJdbcIpFinder.java    |  6 ++---
 .../discovery/tcp/ipfinder/jdbc/package-info.java  |  6 ++---
 .../multicast/TcpDiscoveryMulticastIpFinder.java   |  6 ++---
 .../tcp/ipfinder/multicast/package-info.java       |  6 ++---
 .../spi/discovery/tcp/ipfinder/package-info.java   |  6 ++---
 .../sharedfs/TcpDiscoverySharedFsIpFinder.java     |  6 ++---
 .../tcp/ipfinder/sharedfs/package-info.java        |  6 ++---
 .../tcp/ipfinder/vm/TcpDiscoveryVmIpFinder.java    |  6 ++---
 .../discovery/tcp/ipfinder/vm/package-info.java    |  6 ++---
 .../tcp/messages/TcpDiscoveryAbstractMessage.java  |  6 ++---
 .../messages/TcpDiscoveryAuthFailedMessage.java    |  6 ++---
 .../messages/TcpDiscoveryCheckFailedMessage.java   |  6 ++---
 .../messages/TcpDiscoveryClientAckResponse.java    |  6 ++---
 .../TcpDiscoveryClientMetricsUpdateMessage.java    |  6 ++---
 .../messages/TcpDiscoveryClientPingRequest.java    |  6 ++---
 .../messages/TcpDiscoveryClientPingResponse.java   |  6 ++---
 .../TcpDiscoveryClientReconnectMessage.java        |  6 ++---
 .../TcpDiscoveryConnectionCheckMessage.java        |  6 ++---
 .../messages/TcpDiscoveryCustomEventMessage.java   |  6 ++---
 .../tcp/messages/TcpDiscoveryDiscardMessage.java   |  6 ++---
 .../messages/TcpDiscoveryDummyWakeupMessage.java   |  6 ++---
 .../messages/TcpDiscoveryDuplicateIdMessage.java   |  6 ++---
 .../tcp/messages/TcpDiscoveryEnsureDelivery.java   |  6 ++---
 .../tcp/messages/TcpDiscoveryHandshakeRequest.java |  6 ++---
 .../messages/TcpDiscoveryHandshakeResponse.java    |  6 ++---
 .../messages/TcpDiscoveryJoinRequestMessage.java   |  6 ++---
 .../TcpDiscoveryLoopbackProblemMessage.java        |  6 ++---
 .../messages/TcpDiscoveryMetricsUpdateMessage.java |  6 ++---
 .../TcpDiscoveryNodeAddFinishedMessage.java        |  6 ++---
 .../tcp/messages/TcpDiscoveryNodeAddedMessage.java |  6 ++---
 .../messages/TcpDiscoveryNodeFailedMessage.java    |  6 ++---
 .../tcp/messages/TcpDiscoveryNodeLeftMessage.java  |  6 ++---
 .../tcp/messages/TcpDiscoveryPingRequest.java      |  6 ++---
 .../tcp/messages/TcpDiscoveryPingResponse.java     |  6 ++---
 .../tcp/messages/TcpDiscoveryRedirectToClient.java |  6 ++---
 .../TcpDiscoveryRingLatencyCheckMessage.java       |  6 ++---
 .../TcpDiscoveryServerOnlyCustomEventMessage.java  |  6 ++---
 .../messages/TcpDiscoveryStatusCheckMessage.java   |  6 ++---
 .../spi/discovery/tcp/messages/package-info.java   |  6 ++---
 .../ignite/spi/discovery/tcp/package-info.java     |  6 ++---
 .../ignite/spi/encryption/EncryptionSpi.java       |  6 ++---
 .../encryption/keystore/KeystoreEncryptionKey.java |  6 ++---
 .../encryption/keystore/KeystoreEncryptionSpi.java |  6 ++---
 .../spi/encryption/keystore/package-info.java      |  6 ++---
 .../spi/encryption/noop/NoopEncryptionSpi.java     |  6 ++---
 .../ignite/spi/encryption/noop/package-info.java   |  6 ++---
 .../apache/ignite/spi/encryption/package-info.java |  6 ++---
 .../ignite/spi/eventstorage/EventStorageSpi.java   |  6 ++---
 .../spi/eventstorage/NoopEventStorageSpi.java      |  6 ++---
 .../eventstorage/memory/MemoryEventStorageSpi.java |  6 ++---
 .../memory/MemoryEventStorageSpiMBean.java         |  6 ++---
 .../spi/eventstorage/memory/package-info.java      |  6 ++---
 .../ignite/spi/eventstorage/package-info.java      |  6 ++---
 .../ignite/spi/failover/FailoverContext.java       |  6 ++---
 .../apache/ignite/spi/failover/FailoverSpi.java    |  6 ++---
 .../spi/failover/always/AlwaysFailoverSpi.java     |  6 ++---
 .../failover/always/AlwaysFailoverSpiMBean.java    |  6 ++---
 .../ignite/spi/failover/always/package-info.java   |  6 ++---
 .../jobstealing/JobStealingFailoverSpi.java        |  6 ++---
 .../jobstealing/JobStealingFailoverSpiMBean.java   |  6 ++---
 .../spi/failover/jobstealing/package-info.java     |  6 ++---
 .../spi/failover/never/NeverFailoverSpi.java       |  6 ++---
 .../spi/failover/never/NeverFailoverSpiMBean.java  |  6 ++---
 .../ignite/spi/failover/never/package-info.java    |  6 ++---
 .../apache/ignite/spi/failover/package-info.java   |  6 ++---
 .../spi/indexing/IndexingQueryCacheFilter.java     |  6 ++---
 .../ignite/spi/indexing/IndexingQueryFilter.java   |  6 ++---
 .../spi/indexing/IndexingQueryFilterImpl.java      |  6 ++---
 .../apache/ignite/spi/indexing/IndexingSpi.java    |  6 ++---
 .../ignite/spi/indexing/noop/NoopIndexingSpi.java  |  6 ++---
 .../ignite/spi/indexing/noop/package-info.java     |  6 ++---
 .../apache/ignite/spi/indexing/package-info.java   |  6 ++---
 .../ignite/spi/loadbalancing/LoadBalancingSpi.java |  6 ++---
 .../adaptive/AdaptiveCpuLoadProbe.java             |  6 ++---
 .../adaptive/AdaptiveJobCountLoadProbe.java        |  6 ++---
 .../adaptive/AdaptiveLoadBalancingSpi.java         |  6 ++---
 .../adaptive/AdaptiveLoadBalancingSpiMBean.java    |  6 ++---
 .../loadbalancing/adaptive/AdaptiveLoadProbe.java  |  6 ++---
 .../adaptive/AdaptiveProcessingTimeLoadProbe.java  |  6 ++---
 .../spi/loadbalancing/adaptive/package-info.java   |  6 ++---
 .../ignite/spi/loadbalancing/package-info.java     |  6 ++---
 .../roundrobin/RoundRobinGlobalLoadBalancer.java   |  6 ++---
 .../roundrobin/RoundRobinLoadBalancingSpi.java     |  6 ++---
 .../RoundRobinLoadBalancingSpiMBean.java           |  6 ++---
 .../roundrobin/RoundRobinPerTaskLoadBalancer.java  |  6 ++---
 .../spi/loadbalancing/roundrobin/package-info.java |  6 ++---
 .../WeightedRandomLoadBalancingSpi.java            |  6 ++---
 .../WeightedRandomLoadBalancingSpiMBean.java       |  6 ++---
 .../loadbalancing/weightedrandom/package-info.java |  6 ++---
 .../java/org/apache/ignite/spi/package-info.java   |  6 ++---
 .../apache/ignite/ssl/DelegatingSSLContextSpi.java |  6 ++---
 .../org/apache/ignite/ssl/SSLContextWrapper.java   |  6 ++---
 .../ignite/ssl/SSLServerSocketFactoryWrapper.java  |  6 ++---
 .../apache/ignite/ssl/SSLSocketFactoryWrapper.java |  6 ++---
 .../org/apache/ignite/ssl/SslContextFactory.java   |  6 ++---
 .../java/org/apache/ignite/ssl/package-info.java   |  6 ++---
 .../apache/ignite/startup/BasicWarmupClosure.java  |  6 ++---
 .../apache/ignite/startup/cmdline/AboutDialog.java |  6 ++---
 .../cmdline/CommandLineRandomNumberGenerator.java  |  6 ++---
 .../ignite/startup/cmdline/CommandLineStartup.java |  6 ++---
 .../startup/cmdline/CommandLineTransformer.java    |  6 ++---
 .../ignite/startup/cmdline/package-info.java       |  6 ++---
 .../org/apache/ignite/startup/package-info.java    |  6 ++---
 .../org/apache/ignite/stream/StreamAdapter.java    |  6 ++---
 .../stream/StreamMultipleTupleExtractor.java       |  6 ++---
 .../org/apache/ignite/stream/StreamReceiver.java   |  6 ++---
 .../ignite/stream/StreamSingleTupleExtractor.java  |  6 ++---
 .../apache/ignite/stream/StreamTransformer.java    |  6 ++---
 .../apache/ignite/stream/StreamTupleExtractor.java |  6 ++---
 .../org/apache/ignite/stream/StreamVisitor.java    |  6 ++---
 .../org/apache/ignite/stream/package-info.java     |  6 ++---
 .../stream/socket/SocketMessageConverter.java      |  6 ++---
 .../ignite/stream/socket/SocketStreamer.java       |  6 ++---
 .../apache/ignite/stream/socket/package-info.java  |  6 ++---
 .../thread/IgniteStripedThreadPoolExecutor.java    |  6 ++---
 .../org/apache/ignite/thread/IgniteThread.java     |  6 ++---
 .../apache/ignite/thread/IgniteThreadFactory.java  |  6 ++---
 .../ignite/thread/IgniteThreadPoolExecutor.java    |  6 ++---
 .../apache/ignite/thread/OomExceptionHandler.java  |  6 ++---
 .../org/apache/ignite/thread/package-info.java     |  6 ++---
 .../apache/ignite/transactions/Transaction.java    |  6 ++---
 .../TransactionAlreadyCompletedException.java      |  6 ++---
 .../transactions/TransactionConcurrency.java       |  6 ++---
 .../transactions/TransactionDeadlockException.java |  6 ++---
 .../TransactionDuplicateKeyException.java          |  6 ++---
 .../ignite/transactions/TransactionException.java  |  6 ++---
 .../TransactionHeuristicException.java             |  6 ++---
 .../ignite/transactions/TransactionIsolation.java  |  6 ++---
 .../ignite/transactions/TransactionMetrics.java    |  6 ++---
 .../TransactionMixedModeException.java             |  6 ++---
 .../TransactionOptimisticException.java            |  6 ++---
 .../transactions/TransactionRollbackException.java |  6 ++---
 .../TransactionSerializationException.java         |  6 ++---
 .../ignite/transactions/TransactionState.java      |  6 ++---
 .../transactions/TransactionTimeoutException.java  |  6 ++---
 ...TransactionUnsupportedConcurrencyException.java |  6 ++---
 .../apache/ignite/transactions/package-info.java   |  6 ++---
 .../apache/ignite/util/AttributeNodeFilter.java    |  6 ++---
 .../apache/ignite/util/deque/FastSizeDeque.java    |  6 ++---
 .../resources/META-INF/classnames-jdk.properties   |  6 ++---
 .../main/resources/META-INF/classnames.properties  |  6 ++---
 modules/core/src/main/resources/ignite.properties  |  6 ++---
 modules/core/src/test/bin/start-nodes-custom.sh    |  6 ++---
 .../benchmark/spring-cache-client-benchmark-1.xml  |  6 ++---
 .../benchmark/spring-cache-client-benchmark-2.xml  |  6 ++---
 .../benchmark/spring-cache-client-benchmark-3.xml  |  6 ++---
 modules/core/src/test/config/cache-load.properties |  6 ++---
 .../test/config/class_list_exploit_excluded.txt    |  6 ++---
 .../test/config/class_list_exploit_included.txt    |  6 ++---
 .../src/test/config/default-spring-url-testing.xml |  6 ++---
 modules/core/src/test/config/discovery-stress.xml  |  6 ++---
 modules/core/src/test/config/example-cache.xml     |  6 ++---
 modules/core/src/test/config/examples.properties   |  6 ++---
 .../config/hadoop/core-site-loopback-secondary.xml |  6 ++---
 .../src/test/config/hadoop/core-site-loopback.xml  |  6 ++---
 .../src/test/config/hadoop/core-site-secondary.xml |  6 ++---
 modules/core/src/test/config/hadoop/core-site.xml  |  6 ++---
 modules/core/src/test/config/igfs-loopback.xml     |  6 ++---
 modules/core/src/test/config/igfs-shmem.xml        |  6 ++---
 .../core/src/test/config/io-manager-benchmark.xml  |  6 ++---
 .../core/src/test/config/job-loadtest/client.xml   |  6 ++---
 .../config/job-loadtest/job-loadtest.properties    |  6 ++---
 .../core/src/test/config/job-loadtest/server.xml   |  6 ++---
 modules/core/src/test/config/jobs-load-base.xml    |  6 ++---
 modules/core/src/test/config/jobs-load-client.xml  |  6 ++---
 modules/core/src/test/config/jobs-load-server.xml  |  6 ++---
 .../core/src/test/config/load/cache-benchmark.xml  |  6 ++---
 .../test/config/load/cache-client-benchmark.xml    |  6 ++---
 .../test/config/load/dsi-49-server-production.xml  |  6 ++---
 .../core/src/test/config/load/dsi-load-base.xml    |  6 ++---
 .../core/src/test/config/load/dsi-load-client.xml  |  6 ++---
 .../core/src/test/config/load/dsi-load-server.xml  |  6 ++---
 .../core/src/test/config/load/merge-sort-base.xml  |  6 ++---
 .../src/test/config/loaders/grid-cfg-2-grids.xml   |  6 ++---
 modules/core/src/test/config/loaders/grid-cfg.xml  |  6 ++---
 modules/core/src/test/config/log4j-tc-test.xml     |  6 ++---
 modules/core/src/test/config/log4j-test.xml        |  6 ++---
 modules/core/src/test/config/log4j2-test.xml       |  6 ++---
 .../core/src/test/config/log4j2-verbose-test.xml   |  6 ++---
 .../core/src/test/config/spark/spark-config.xml    |  6 ++---
 modules/core/src/test/config/spring-cache-load.xml |  6 ++---
 .../test/config/spring-cache-put-remove-load.xml   |  6 ++---
 modules/core/src/test/config/spring-cache-swap.xml |  6 ++---
 .../src/test/config/spring-cache-teststore.xml     |  6 ++---
 modules/core/src/test/config/spring-multicache.xml |  6 ++---
 .../src/test/config/spring-start-nodes-attr.xml    |  6 ++---
 .../core/src/test/config/spring-start-nodes.xml    |  6 ++---
 .../test/config/store/jdbc/ignite-jdbc-type.xml    |  6 ++---
 .../average/spring-streamer-average-base.xml       |  6 ++---
 .../average/spring-streamer-average-local.xml      |  6 ++---
 .../average/spring-streamer-average-random.xml     |  6 ++---
 .../test/config/streamer/spring-streamer-base.xml  |  6 ++---
 modules/core/src/test/config/tests.properties      |  6 ++---
 .../test/config/websession/example-cache-base.xml  |  6 ++---
 .../config/websession/example-cache-client.xml     |  6 ++---
 .../src/test/config/websession/example-cache.xml   |  6 ++---
 .../src/test/config/websession/example-cache2.xml  |  6 ++---
 .../src/test/config/websession/spring-cache-1.xml  |  6 ++---
 .../src/test/config/websession/spring-cache-2.xml  |  6 ++---
 .../src/test/config/websession/spring-cache-3.xml  |  6 ++---
 modules/core/src/test/java/ExcludeList             |  6 ++---
 .../ignite/GridCacheAffinityBackupsSelfTest.java   |  6 ++---
 .../ignite/GridSuppressedExceptionSelfTest.java    |  6 ++---
 .../java/org/apache/ignite/GridTestIoUtils.java    |  6 ++---
 .../test/java/org/apache/ignite/GridTestJob.java   |  6 ++---
 .../java/org/apache/ignite/GridTestJobContext.java |  6 ++---
 .../java/org/apache/ignite/GridTestJobResult.java  |  6 ++---
 .../org/apache/ignite/GridTestNodeStartup.java     |  6 ++---
 .../apache/ignite/GridTestStoreNodeStartup.java    |  6 ++---
 .../test/java/org/apache/ignite/GridTestTask.java  |  6 ++---
 .../org/apache/ignite/GridTestTaskSession.java     |  6 ++---
 .../apache/ignite/IgniteCacheAffinitySelfTest.java |  6 ++---
 .../ignite/IgniteExternalizableAbstractTest.java   |  6 ++---
 ...gniteCacheEntryProcessorSequentialCallTest.java |  6 ++---
 .../ignite/cache/IgniteWarmupClosureSelfTest.java  |  6 ++---
 .../apache/ignite/cache/LargeEntryUpdateTest.java  |  6 ++---
 .../ignite/cache/NodeWithFilterRestartTest.java    |  6 ++---
 .../ignite/cache/ResetLostPartitionTest.java       |  6 ++---
 .../affinity/AbstractAffinityFunctionSelfTest.java |  6 ++---
 .../cache/affinity/AffinityClientNodeSelfTest.java |  6 ++---
 .../affinity/AffinityDistributionLoggingTest.java  |  6 ++---
 ...finityFunctionBackupFilterAbstractSelfTest.java |  6 ++---
 ...tyFunctionExcludeNeighborsAbstractSelfTest.java |  6 ++---
 .../cache/affinity/AffinityHistoryCleanupTest.java |  6 ++---
 .../affinity/local/LocalAffinityFunctionTest.java  |  6 ++---
 ...rNodeAttributeAffinityBackupFilterSelfTest.java |  6 ++---
 ...ezvousAffinityFunctionBackupFilterSelfTest.java |  6 ++---
 ...usAffinityFunctionExcludeNeighborsSelfTest.java |  6 ++---
 ...AffinityFunctionFastPowerOfTwoHashSelfTest.java |  6 ++---
 .../RendezvousAffinityFunctionSelfTest.java        |  6 ++---
 .../RendezvousAffinityFunctionSimpleBenchmark.java |  6 ++---
 ...ezvousAffinityFunctionStandardHashSelfTest.java |  6 ++---
 ...reListenerRWThroughDisabledAtomicCacheTest.java |  6 ++---
 ...nerRWThroughDisabledTransactionalCacheTest.java |  6 ++---
 .../cache/store/CacheStoreReadFromBackupTest.java  |  6 ++---
 .../CacheStoreSessionListenerAbstractSelfTest.java |  6 ++---
 ...CacheStoreSessionListenerLifecycleSelfTest.java |  6 ++---
 ...stenerReadWriteThroughDisabledAbstractTest.java |  6 ++---
 ...StoreSessionListenerWriteBehindEnabledTest.java |  6 ++---
 .../cache/store/CacheStoreWriteErrorTest.java      |  6 ++---
 .../CacheTransactionalStoreReadFromBackupTest.java |  6 ++---
 .../store/GridCacheBalancingStoreSelfTest.java     |  6 ++---
 .../GridCacheLoadOnlyStoreAdapterSelfTest.java     |  6 ++---
 .../cache/store/GridGeneratingTestStore.java       |  6 ++---
 .../ignite/cache/store/GridStoreLoadCacheTest.java |  6 ++---
 .../store/IgniteCacheExpiryStoreLoadSelfTest.java  |  6 ++---
 .../store/StoreResourceInjectionSelfTest.java      |  6 ++---
 .../jdbc/CacheJdbcPojoStoreAbstractSelfTest.java   |  6 ++---
 ...CacheJdbcPojoStoreBinaryMarshallerSelfTest.java |  6 ++---
 ...oreBinaryMarshallerStoreKeepBinarySelfTest.java |  6 ++---
 ...hallerStoreKeepBinaryWithSqlEscapeSelfTest.java |  6 ++---
 ...StoreBinaryMarshallerWithSqlEscapeSelfTest.java |  6 ++---
 .../CacheJdbcPojoStoreMultitreadedSelfTest.java    |  6 ++---
 .../cache/store/jdbc/CacheJdbcPojoStoreTest.java   |  6 ++---
 ...JdbcPojoWriteBehindStoreWithCoalescingTest.java |  6 ++---
 ...acheJdbcStoreAbstractMultithreadedSelfTest.java |  6 ++---
 .../CacheJdbcStoreSessionListenerSelfTest.java     |  6 ++---
 ...ridCacheJdbcBlobStoreMultithreadedSelfTest.java |  6 ++---
 .../store/jdbc/GridCacheJdbcBlobStoreSelfTest.java |  6 ++---
 .../cache/store/jdbc/H2DataSourceFactory.java      |  6 ++---
 .../jdbc/JdbcTypesDefaultTransformerTest.java      |  6 ++---
 .../ignite/cache/store/jdbc/model/BinaryTest.java  |  6 ++---
 .../cache/store/jdbc/model/BinaryTestKey.java      |  6 ++---
 .../ignite/cache/store/jdbc/model/Gender.java      |  6 ++---
 .../cache/store/jdbc/model/Organization.java       |  6 ++---
 .../cache/store/jdbc/model/OrganizationKey.java    |  6 ++---
 .../ignite/cache/store/jdbc/model/Person.java      |  6 ++---
 .../cache/store/jdbc/model/PersonComplexKey.java   |  6 ++---
 .../ignite/cache/store/jdbc/model/PersonKey.java   |  6 ++---
 .../store/jdbc/model/TestJdbcPojoDataSource.java   |  6 ++---
 .../jdbc/model/TestJdbcPojoDataSourceFactory.java  |  6 ++---
 .../TestJdbcPojoStoreFactoryWithHangWriteAll.java  |  6 ++---
 .../ignite/cache/store/jdbc/model/TestPojo.java    |  6 ++---
 .../cache/store/jdbc/model/package-info.java       |  6 ++---
 .../ignite/cache/store/jdbc/package-info.java      |  6 ++---
 .../apache/ignite/cache/store/package-info.java    |  6 ++---
 .../client/ClientCacheConfigurationTest.java       |  6 ++---
 .../ignite/client/ClientConfigurationTest.java     |  6 ++---
 .../java/org/apache/ignite/client/Comparers.java   |  6 ++---
 .../test/java/org/apache/ignite/client/Config.java |  6 ++---
 .../org/apache/ignite/client/ConnectionTest.java   |  6 ++---
 .../org/apache/ignite/client/FunctionalTest.java   |  6 ++---
 .../org/apache/ignite/client/IgniteBinaryTest.java |  6 ++---
 .../java/org/apache/ignite/client/LoadTest.java    |  6 ++---
 .../apache/ignite/client/LocalIgniteCluster.java   |  6 ++---
 .../test/java/org/apache/ignite/client/Person.java |  6 ++---
 .../org/apache/ignite/client/ReliabilityTest.java  |  6 ++---
 .../apache/ignite/client/SslParametersTest.java    |  6 ++---
 .../ignite/custom/DummyEventFilterFactory.java     |  6 ++---
 .../ignite/failure/AbstractFailureHandlerTest.java |  6 ++---
 .../failure/FailureHandlerTriggeredTest.java       |  6 ++---
 .../failure/FailureHandlingConfigurationTest.java  |  6 ++---
 .../ignite/failure/IoomFailureHandlerTest.java     |  6 ++---
 .../ignite/failure/OomFailureHandlerTest.java      |  6 ++---
 .../ignite/failure/StopNodeFailureHandlerTest.java |  6 ++---
 .../failure/StopNodeOrHaltFailureHandlerTest.java  |  6 ++---
 .../ignite/failure/SystemWorkersBlockingTest.java  |  6 ++---
 .../failure/SystemWorkersTerminationTest.java      |  6 ++---
 .../apache/ignite/failure/TestFailureHandler.java  |  6 ++---
 .../ignite/igfs/IgfsEventsAbstractSelfTest.java    |  6 ++---
 .../igfs/IgfsFragmentizerAbstractSelfTest.java     |  6 ++---
 .../ignite/igfs/IgfsFragmentizerSelfTest.java      |  6 ++---
 .../igfs/IgfsFragmentizerTopologySelfTest.java     |  6 ++---
 .../org/apache/ignite/igfs/IgfsPathSelfTest.java   |  6 ++---
 .../apache/ignite/igfs/IgfsTestInputGenerator.java |  6 ++---
 .../org/apache/ignite/internal/ClassSetTest.java   |  6 ++---
 .../ClusterBaselineNodesMetricsSelfTest.java       |  6 ++---
 .../ignite/internal/ClusterGroupAbstractTest.java  |  6 ++---
 .../ignite/internal/ClusterGroupHostsSelfTest.java |  6 ++---
 .../ignite/internal/ClusterGroupSelfTest.java      |  6 ++---
 .../ignite/internal/ClusterMetricsSelfTest.java    |  6 ++---
 .../internal/ClusterNodeMetricsSelfTest.java       |  6 ++---
 .../internal/ClusterNodeMetricsUpdateTest.java     |  6 ++---
 .../ComputeJobCancelWithServiceSelfTest.java       |  6 ++---
 .../ConsistentIdImplicitlyExplicitlyTest.java      |  6 ++---
 .../ignite/internal/DiscoverySpiTestListener.java  |  6 ++---
 .../ignite/internal/GridAffinityMappedTest.java    |  6 ++---
 .../internal/GridAffinityNoCacheSelfTest.java      |  6 ++---
 .../ignite/internal/GridAffinityP2PSelfTest.java   |  6 ++---
 .../ignite/internal/GridAffinitySelfTest.java      |  6 ++---
 .../GridAlwaysFailoverSpiFailSelfTest.java         |  6 ++---
 ...dCachePartitionExchangeManagerHistSizeTest.java |  6 ++---
 ...dCachePartitionExchangeManagerWarningsTest.java |  6 ++---
 .../internal/GridCancelOnGridStopSelfTest.java     |  6 ++---
 .../internal/GridCancelUnusedJobSelfTest.java      |  6 ++---
 .../internal/GridCancelledJobsMetricsSelfTest.java |  6 ++---
 .../internal/GridCollisionJobsContextSelfTest.java |  6 ++---
 .../ignite/internal/GridCommunicationSelfTest.java |  6 ++---
 ...idComputationBinarylizableClosuresSelfTest.java |  6 ++---
 .../GridContinuousJobAnnotationSelfTest.java       |  6 ++---
 .../GridContinuousJobSiblingsSelfTest.java         |  6 ++---
 .../internal/GridContinuousTaskSelfTest.java       |  6 ++---
 .../GridDeploymentMultiThreadedSelfTest.java       |  6 ++---
 .../ignite/internal/GridDeploymentSelfTest.java    |  6 ++---
 .../internal/GridDiscoveryEventSelfTest.java       |  6 ++---
 .../ignite/internal/GridDiscoverySelfTest.java     |  6 ++---
 .../GridEventStorageCheckAllEventsSelfTest.java    |  6 ++---
 .../GridEventStorageDefaultExceptionTest.java      |  6 ++---
 ...idEventStorageRuntimeConfigurationSelfTest.java |  6 ++---
 .../ignite/internal/GridEventStorageSelfTest.java  |  6 ++---
 .../ignite/internal/GridFactoryVmShutdownTest.java |  6 ++---
 .../GridFailFastNodeFailureDetectionSelfTest.java  |  6 ++---
 .../GridFailedInputParametersSelfTest.java         |  6 ++---
 .../GridFailoverCustomTopologySelfTest.java        |  6 ++---
 .../ignite/internal/GridFailoverSelfTest.java      |  6 ++---
 .../GridFailoverTaskWithPredicateSelfTest.java     |  6 ++---
 .../internal/GridFailoverTopologySelfTest.java     |  6 ++---
 .../ignite/internal/GridGetOrStartSelfTest.java    |  6 ++---
 .../ignite/internal/GridHomePathSelfTest.java      |  6 ++---
 .../internal/GridJobCheckpointCleanupSelfTest.java |  6 ++---
 .../internal/GridJobCollisionCancelSelfTest.java   |  6 ++---
 .../ignite/internal/GridJobContextSelfTest.java    |  6 ++---
 .../internal/GridJobMasterLeaveAwareSelfTest.java  |  6 ++---
 .../internal/GridJobServicesAddNodeTest.java       |  6 ++---
 .../ignite/internal/GridJobStealingSelfTest.java   |  6 ++---
 .../GridJobStealingZeroActiveJobsSelfTest.java     |  6 ++---
 .../ignite/internal/GridJobSubjectIdSelfTest.java  |  6 ++---
 .../GridKernalConcurrentAccessStopSelfTest.java    |  6 ++---
 .../ignite/internal/GridKernalTestUtils.java       |  6 ++---
 .../internal/GridLifecycleAwareSelfTest.java       |  6 ++---
 .../ignite/internal/GridLifecycleBeanSelfTest.java |  6 ++---
 .../ignite/internal/GridListenActorSelfTest.java   |  6 ++---
 .../internal/GridLocalEventListenerSelfTest.java   |  6 ++---
 .../org/apache/ignite/internal/GridMBeansTest.java |  6 ++---
 .../ignite/internal/GridMultipleJobsSelfTest.java  |  6 ++---
 .../ignite/internal/GridMultipleSpisSelfTest.java  |  6 ++---
 .../GridMultipleVersionsDeploymentSelfTest.java    |  6 ++---
 .../GridMultithreadedJobStealingSelfTest.java      |  6 ++---
 .../ignite/internal/GridNodeFilterSelfTest.java    |  6 ++---
 .../ignite/internal/GridNodeLocalSelfTest.java     |  6 ++---
 .../internal/GridNodeMetricsLogPdsSelfTest.java    |  6 ++---
 .../internal/GridNodeMetricsLogSelfTest.java       |  6 ++---
 .../internal/GridNodeVisorAttributesSelfTest.java  |  6 ++---
 .../internal/GridNonHistoryMetricsSelfTest.java    |  6 ++---
 .../internal/GridProjectionForCachesSelfTest.java  |  6 ++---
 ...rojectionLocalJobMultipleArgumentsSelfTest.java |  6 ++---
 .../apache/ignite/internal/GridReduceSelfTest.java |  6 ++---
 .../ignite/internal/GridReleaseTypeSelfTest.java   |  6 ++---
 .../internal/GridRuntimeExceptionSelfTest.java     |  6 ++---
 .../ignite/internal/GridSameVmStartupSelfTest.java |  6 ++---
 .../org/apache/ignite/internal/GridSelfTest.java   |  6 ++---
 .../ignite/internal/GridSpiExceptionSelfTest.java  |  6 ++---
 .../ignite/internal/GridStartStopSelfTest.java     |  6 ++---
 .../internal/GridStopWithCancelSelfTest.java       |  6 ++---
 .../ignite/internal/GridStopWithWaitSelfTest.java  |  6 ++---
 .../internal/GridTaskCancelSingleNodeSelfTest.java |  6 ++---
 .../internal/GridTaskContinuousMapperSelfTest.java |  6 ++---
 .../internal/GridTaskExecutionContextSelfTest.java |  6 ++---
 .../ignite/internal/GridTaskExecutionSelfTest.java |  6 ++---
 ...skExecutionWithoutPeerClassLoadingSelfTest.java |  6 ++---
 .../internal/GridTaskFailoverAffinityRunTest.java  |  6 ++---
 .../ignite/internal/GridTaskFailoverSelfTest.java  |  6 ++---
 .../GridTaskFutureImplStopGridSelfTest.java        |  6 ++---
 .../GridTaskInstanceExecutionSelfTest.java         |  6 ++---
 .../internal/GridTaskInstantiationSelfTest.java    |  6 ++---
 .../ignite/internal/GridTaskJobRejectSelfTest.java |  6 ++---
 .../ignite/internal/GridTaskListenerSelfTest.java  |  6 ++---
 .../ignite/internal/GridTaskMapAsyncSelfTest.java  |  6 ++---
 .../internal/GridTaskNameAnnotationSelfTest.java   |  6 ++---
 .../internal/GridTaskResultCacheSelfTest.java      |  6 ++---
 .../ignite/internal/GridTaskTimeoutSelfTest.java   |  6 ++---
 .../internal/GridTopicExternalizableSelfTest.java  |  6 ++---
 .../ignite/internal/GridVersionSelfTest.java       |  6 ++---
 ...ClientConnectAfterCommunicationFailureTest.java |  6 ++---
 .../IgniteClientReconnectAbstractTest.java         |  6 ++---
 .../IgniteClientReconnectApiExceptionTest.java     |  6 ++---
 .../internal/IgniteClientReconnectAtomicsTest.java |  6 ++---
 ...ientReconnectAtomicsWithLostPartitionsTest.java | 28 +++++++++++-----------
 .../IgniteClientReconnectBinaryContexTest.java     |  6 ++---
 .../internal/IgniteClientReconnectCacheTest.java   |  6 ++---
 .../IgniteClientReconnectCollectionsTest.java      |  6 ++---
 .../internal/IgniteClientReconnectComputeTest.java |  6 ++---
 ...niteClientReconnectContinuousProcessorTest.java |  6 ++---
 .../IgniteClientReconnectDelayedSpiTest.java       |  6 ++---
 .../IgniteClientReconnectDiscoveryStateTest.java   |  6 ++---
 .../IgniteClientReconnectFailoverAbstractTest.java |  6 ++---
 .../IgniteClientReconnectFailoverTest.java         |  6 ++---
 .../IgniteClientReconnectServicesTest.java         |  6 ++---
 .../internal/IgniteClientReconnectStopTest.java    |  6 ++---
 .../IgniteClientReconnectStreamerTest.java         |  6 ++---
 .../ignite/internal/IgniteClientRejoinTest.java    |  6 ++---
 .../IgniteComputeEmptyClusterGroupTest.java        |  6 ++---
 .../internal/IgniteComputeJobOneThreadTest.java    |  6 ++---
 .../internal/IgniteComputeResultExceptionTest.java |  6 ++---
 .../IgniteComputeTopologyExceptionTest.java        |  6 ++---
 ...niteConcurrentEntryProcessorAccessStopTest.java |  6 ++---
 ...teConnectionConcurrentReserveAndRemoveTest.java |  6 ++---
 .../IgniteDiscoveryMassiveNodeFailTest.java        |  6 ++---
 .../ignite/internal/IgniteExecutorServiceTest.java |  6 ++---
 .../IgniteExplicitImplicitDeploymentSelfTest.java  |  6 ++---
 .../internal/IgniteInternalCacheRemoveTest.java    |  6 ++---
 .../IgniteLocalNodeMapBeforeStartTest.java         |  6 ++---
 .../internal/IgniteReflectionFactorySelfTest.java  |  6 ++---
 ...iteRoundRobinErrorAfterClientReconnectTest.java |  6 ++---
 .../IgniteSlowClientDetectionSelfTest.java         |  6 ++---
 ...iteUpdateNotifierPerClusterSettingSelfTest.java |  6 ++---
 .../internal/IgniteVersionUtilsSelfTest.java       |  6 ++---
 .../ignite/internal/LongJVMPauseDetectorTest.java  |  6 ++---
 .../internal/MarshallerContextLockingSelfTest.java |  6 ++---
 .../internal/MemoryLeaksOnRestartNodeTest.java     |  6 ++---
 .../internal/SensitiveInfoTestLoggerProxy.java     |  6 ++---
 .../SensitiveInfoTestLoggerProxy_Exclude.txt       |  6 ++---
 .../SensitiveInfoTestLoggerProxy_Include.txt       |  6 ++---
 .../ignite/internal/TaskNodeRestartTest.java       |  6 ++---
 .../internal/TestDelayingCommunicationSpi.java     |  6 ++---
 .../internal/TestManagementVisorMultiNodeTask.java |  6 ++---
 .../internal/TestManagementVisorOneNodeTask.java   |  6 ++---
 .../TestNotManagementVisorMultiNodeTask.java       |  6 ++---
 .../TestNotManagementVisorOneNodeTask.java         |  6 ++---
 .../internal/TestRecordingCommunicationSpi.java    |  6 ++---
 .../internal/TransactionMetricsMxBeanImplTest.java |  6 ++---
 .../internal/TransactionsMXBeanImplTest.java       |  6 ++---
 .../internal/VisorManagementEventSelfTest.java     |  6 ++---
 .../apache/ignite/internal/binary/AffinityKey.java |  6 ++---
 .../BinaryArrayIdentityResolverSelfTest.java       |  6 ++---
 .../binary/BinaryBasicIdMapperSelfTest.java        |  6 ++---
 .../binary/BinaryBasicNameMapperSelfTest.java      |  6 ++---
 .../BinaryConfigurationConsistencySelfTest.java    |  6 ++---
 ...inaryConfigurationCustomSerializerSelfTest.java |  6 ++---
 .../internal/binary/BinaryEnumsSelfTest.java       |  6 ++---
 .../binary/BinaryFieldExtractionSelfTest.java      |  6 ++---
 .../binary/BinaryFieldsAbstractSelfTest.java       |  6 ++---
 .../internal/binary/BinaryFieldsHeapSelfTest.java  |  6 ++---
 .../binary/BinaryFieldsOffheapSelfTest.java        |  6 ++---
 .../BinaryFooterOffsetsAbstractSelfTest.java       |  6 ++---
 .../binary/BinaryFooterOffsetsHeapSelfTest.java    |  6 ++---
 .../binary/BinaryFooterOffsetsOffheapSelfTest.java |  6 ++---
 .../internal/binary/BinaryMarshallerSelfTest.java  |  6 ++---
 .../BinaryObjectBuilderAdditionalSelfTest.java     |  6 ++---
 .../BinaryObjectBuilderDefaultMappersSelfTest.java |  6 ++---
 ...tBuilderSimpleNameLowerCaseMappersSelfTest.java |  6 ++---
 .../binary/BinaryObjectExceptionSelfTest.java      |  6 ++---
 .../binary/BinaryObjectToStringSelfTest.java       |  6 ++---
 .../binary/BinaryObjectTypeCompatibilityTest.java  |  6 ++---
 .../BinarySerialiedFieldComparatorSelfTest.java    |  6 ++---
 .../BinarySimpleNameTestPropertySelfTest.java      |  6 ++---
 .../ignite/internal/binary/BinaryTreeSelfTest.java |  6 ++---
 .../binary/GridBinaryAffinityKeySelfTest.java      |  6 ++---
 .../GridBinaryMarshallerCtxDisabledSelfTest.java   |  6 ++---
 .../binary/GridBinaryWildcardsSelfTest.java        |  6 ++---
 ...DefaultBinaryMappersBinaryMetaDataSelfTest.java |  6 ++---
 ...werCaseBinaryMappersBinaryMetaDataSelfTest.java |  6 ++---
 .../binary/TestCachingMetadataHandler.java         |  6 ++---
 .../ignite/internal/binary/TestMappedObject.java   |  6 ++---
 .../GridBinaryMarshalerAwareTestClass.java         |  6 ++---
 .../binary/mutabletest/GridBinaryTestClasses.java  |  6 ++---
 .../internal/binary/mutabletest/package-info.java  |  6 ++---
 .../BinaryFieldsHeapNonCompactSelfTest.java        |  6 ++---
 .../BinaryFieldsOffheapNonCompactSelfTest.java     |  6 ++---
 .../BinaryFooterOffsetsHeapNonCompactSelfTest.java |  6 ++---
 ...naryFooterOffsetsOffheapNonCompactSelfTest.java |  6 ++---
 .../BinaryMarshallerNonCompactSelfTest.java        |  6 ++---
 ...yObjectBuilderAdditionalNonCompactSelfTest.java |  6 ++---
 ...ectBuilderNonCompactDefaultMappersSelfTest.java |  6 ++---
 ...nCompactSimpleNameLowerCaseMappersSelfTest.java |  6 ++---
 .../ignite/internal/binary/package-info.java       |  6 ++---
 .../AbstractBinaryStreamByteOrderSelfTest.java     |  6 ++---
 .../streams/BinaryAbstractOutputStreamTest.java    |  6 ++---
 .../streams/BinaryHeapStreamByteOrderSelfTest.java |  6 ++---
 .../BinaryOffheapStreamByteOrderSelfTest.java      |  6 ++---
 .../internal/binary/test/GridBinaryTestClass1.java |  6 ++---
 .../internal/binary/test/GridBinaryTestClass2.java |  6 ++---
 .../ignite/internal/binary/test/package-info.java  |  6 ++---
 .../test/subpackage/GridBinaryTestClass3.java      |  6 ++---
 .../binary/test/subpackage/package-info.java       |  6 ++---
 .../FullyConnectedComponentSearcherTest.java       |  6 ++---
 .../internal/commandline/CommandArgFactory.java    |  6 ++---
 .../commandline/CommandHandlerParsingTest.java     |  6 ++---
 ...ectByteBufferStreamImplV2ByteOrderSelfTest.java |  6 ++---
 .../encryption/AbstractEncryptionTest.java         |  6 ++---
 .../encryption/EncryptedCacheBigEntryTest.java     |  6 ++---
 .../encryption/EncryptedCacheCreateTest.java       |  6 ++---
 .../encryption/EncryptedCacheDestroyTest.java      |  6 ++---
 .../encryption/EncryptedCacheGroupCreateTest.java  |  6 ++---
 .../encryption/EncryptedCacheNodeJoinTest.java     |  6 ++---
 .../EncryptedCachePreconfiguredRestartTest.java    |  6 ++---
 .../encryption/EncryptedCacheRestartTest.java      |  6 ++---
 .../GridManagerLocalMessageListenerSelfTest.java   |  6 ++---
 ...GridManagerMxBeanIllegalArgumentHandleTest.java |  6 ++---
 .../internal/managers/GridManagerStopSelfTest.java |  6 ++---
 .../internal/managers/GridNoopManagerSelfTest.java |  6 ++---
 ...eDiagnosticMessagesMultipleConnectionsTest.java |  6 ++---
 .../managers/IgniteDiagnosticMessagesTest.java     |  6 ++---
 .../GridCheckpointManagerAbstractSelfTest.java     |  6 ++---
 .../checkpoint/GridCheckpointManagerSelfTest.java  |  6 ++---
 .../checkpoint/GridCheckpointTaskSelfTest.java     |  6 ++---
 .../internal/managers/checkpoint/package-info.java |  6 ++---
 .../GridCommunicationManagerListenersSelfTest.java |  6 ++---
 .../GridCommunicationSendMessageSelfTest.java      |  6 ++---
 .../communication/GridIoManagerSelfTest.java       |  6 ++---
 ...ommunicationBalanceMultipleConnectionsTest.java |  6 ++---
 ...eCommunicationBalancePairedConnectionsTest.java |  6 ++---
 .../IgniteCommunicationBalanceTest.java            |  6 ++---
 .../IgniteCommunicationSslBalanceTest.java         |  6 ++---
 .../communication/IgniteIoTestMessagesTest.java    |  6 ++---
 .../IgniteVariousConnectionNumberTest.java         |  6 ++---
 .../managers/communication/package-info.java       |  6 ++---
 ...loymentRequestOfUnknownClassProcessingTest.java |  6 ++---
 .../GridDeploymentManagerStopSelfTest.java         |  6 ++---
 .../GridDeploymentMessageCountSelfTest.java        |  6 ++---
 .../managers/deployment/GridTestDeployment.java    |  6 ++---
 .../internal/managers/deployment/package-info.java |  6 ++---
 .../GridDiscoveryManagerAliveCacheSelfTest.java    |  6 ++---
 .../GridDiscoveryManagerAttributesSelfTest.java    |  6 ++---
 .../IgniteTopologyPrintFormatSelfTest.java         |  6 ++---
 .../events/GridEventStorageManagerSelfTest.java    |  6 ++---
 .../ignite/internal/managers/package-info.java     |  6 ++---
 .../optimized/OptimizedMarshallerEnumSelfTest.java |  6 ++---
 .../OptimizedMarshallerNodeFailoverTest.java       |  6 ++---
 .../OptimizedMarshallerPooledSelfTest.java         |  6 ++---
 .../optimized/OptimizedMarshallerSelfTest.java     |  6 ++---
 ...edMarshallerSerialPersistentFieldsSelfTest.java |  6 ++---
 .../optimized/OptimizedMarshallerTest.java         |  6 ++---
 .../optimized/OptimizedObjectStreamSelfTest.java   |  6 ++---
 .../optimized/TestTcpDiscoveryIpFinderAdapter.java |  6 ++---
 .../marshaller/optimized/package-info.java         |  6 ++---
 .../org/apache/ignite/internal/package-info.java   |  6 ++---
 .../internal/pagemem/impl/PageIdUtilsSelfTest.java |  6 ++---
 .../pagemem/impl/PageMemoryNoLoadSelfTest.java     |  6 ++---
 .../processors/DeadLockOnNodeLeftExchangeTest.java |  6 ++---
 .../GridCacheTxLoadFromStoreOnLockSelfTest.java    |  6 ++---
 .../affinity/GridAffinityAssignmentV2Test.java     |  6 ++---
 ...ridAffinityAssignmentV2TestNoOptimizations.java |  6 ++---
 .../GridAffinityProcessorAbstractSelfTest.java     |  6 ++---
 .../GridAffinityProcessorMemoryLeakTest.java       |  6 ++---
 .../GridAffinityProcessorRendezvousSelfTest.java   |  6 ++---
 .../GridHistoryAffinityAssignmentTest.java         |  6 ++---
 ...istoryAffinityAssignmentTestNoOptimization.java |  6 ++---
 .../affinity/SerializableMetricsProvider.java      |  6 ++---
 .../Authentication1kUsersNodeRestartTest.java      |  6 ++---
 .../AuthenticationConfigurationClusterTest.java    |  6 ++---
 .../AuthenticationOnNotActiveClusterTest.java      |  6 ++---
 .../AuthenticationProcessorNPEOnStartTest.java     |  6 ++---
 .../AuthenticationProcessorNodeRestartTest.java    |  6 ++---
 .../AuthenticationProcessorSelfTest.java           |  6 ++---
 .../AtomicCacheAffinityConfigurationTest.java      |  6 ++---
 ...tadataRegistrationInsideEntryProcessorTest.java |  6 ++---
 .../cache/CacheAffinityCallSelfTest.java           |  6 ++---
 .../CacheAtomicSingleMessageCountSelfTest.java     |  6 ++---
 .../processors/cache/CacheClientStoreSelfTest.java |  6 ++---
 .../processors/cache/CacheComparatorTest.java      |  6 ++---
 .../cache/CacheConcurrentReadThroughTest.java      |  6 ++---
 .../cache/CacheConfigurationLeakTest.java          |  6 ++---
 ...eConfigurationSerializationOnDiscoveryTest.java |  6 ++---
 ...heConfigurationSerializationOnExchangeTest.java |  6 ++---
 .../cache/CacheConnectionLeakStoreTxTest.java      |  6 ++---
 .../cache/CacheDataRegionConfigurationTest.java    |  6 ++---
 .../cache/CacheDeferredDeleteQueueTest.java        |  6 ++---
 .../cache/CacheDeferredDeleteSanitySelfTest.java   |  6 ++---
 .../CacheDhtLocalPartitionAfterRemoveSelfTest.java |  6 ++---
 .../cache/CacheEntryProcessorCopySelfTest.java     |  6 ++---
 .../cache/CacheEnumOperationsAbstractTest.java     |  6 ++---
 .../cache/CacheEnumOperationsSingleNodeTest.java   |  6 ++---
 .../processors/cache/CacheEnumOperationsTest.java  |  6 ++---
 .../cache/CacheEventWithTxLabelTest.java           |  6 ++---
 .../CacheExchangeMessageDuplicatedStateTest.java   |  6 ++---
 .../cache/CacheFutureExceptionSelfTest.java        |  6 ++---
 .../cache/CacheGetEntryAbstractTest.java           |  6 ++---
 ...cheGetEntryOptimisticReadCommittedSelfTest.java |  6 ++---
 ...heGetEntryOptimisticRepeatableReadSelfTest.java |  6 ++---
 ...acheGetEntryOptimisticSerializableSelfTest.java |  6 ++---
 ...heGetEntryPessimisticReadCommittedSelfTest.java |  6 ++---
 ...eGetEntryPessimisticRepeatableReadSelfTest.java |  6 ++---
 ...cheGetEntryPessimisticSerializableSelfTest.java |  6 ++---
 .../processors/cache/CacheGetFromJobTest.java      |  6 ++---
 .../cache/CacheGetRemoveSkipStoreTest.java         |  6 ++---
 .../cache/CacheGetsDistributionAbstractTest.java   |  6 ++---
 .../CacheGroupLocalConfigurationSelfTest.java      |  6 ++---
 .../cache/CacheGroupMetricsMBeanTest.java          |  6 ++---
 .../cache/CacheGroupsMetricsRebalanceTest.java     |  6 ++---
 ...InterceptorPartitionCounterLocalSanityTest.java |  6 ++---
 ...ceptorPartitionCounterRandomOperationsTest.java |  6 ++---
 .../cache/CacheKeepBinaryTransactionTest.java      |  6 ++---
 .../cache/CacheLocalGetSerializationTest.java      |  6 ++---
 .../cache/CacheMetricsCacheSizeTest.java           |  6 ++---
 .../cache/CacheMetricsEntitiesCountTest.java       |  6 ++---
 .../cache/CacheMetricsForClusterGroupSelfTest.java |  6 ++---
 .../processors/cache/CacheMetricsManageTest.java   |  6 ++---
 .../cache/CacheMvccTxFastFinishTest.java           |  6 ++---
 .../cache/CacheNearReaderUpdateTest.java           |  6 ++---
 .../CacheNearUpdateTopologyChangeAbstractTest.java |  6 ++---
 .../cache/CacheNoAffinityExchangeTest.java         |  6 ++---
 .../cache/CacheOffheapMapEntrySelfTest.java        |  6 ++---
 ...sticTransactionsWithFilterSingleServerTest.java |  6 ++---
 .../CacheOptimisticTransactionsWithFilterTest.java |  6 ++---
 .../cache/CachePutEventListenerErrorSelfTest.java  |  6 ++---
 .../processors/cache/CachePutIfAbsentTest.java     |  6 ++---
 .../CacheReadThroughAtomicRestartSelfTest.java     |  6 ++---
 ...CacheReadThroughLocalAtomicRestartSelfTest.java |  6 ++---
 .../CacheReadThroughLocalRestartSelfTest.java      |  6 ++---
 ...ReadThroughReplicatedAtomicRestartSelfTest.java |  6 ++---
 .../CacheReadThroughReplicatedRestartSelfTest.java |  6 ++---
 .../cache/CacheReadThroughRestartSelfTest.java     |  6 ++---
 .../processors/cache/CacheRebalancingSelfTest.java |  6 ++---
 .../processors/cache/CacheRemoveAllSelfTest.java   |  6 ++---
 .../cache/CacheSerializableTransactionsTest.java   |  6 ++---
 .../cache/CacheStartupInDeploymentModesTest.java   |  6 ++---
 .../cache/CacheStopAndDestroySelfTest.java         |  6 ++---
 .../cache/CacheStoreTxPutAllMultiNodeTest.java     |  6 ++---
 .../CacheStoreUsageMultinodeAbstractTest.java      |  6 ++---
 ...toreUsageMultinodeDynamicStartAbstractTest.java |  6 ++---
 ...eStoreUsageMultinodeDynamicStartAtomicTest.java |  6 ++---
 ...CacheStoreUsageMultinodeDynamicStartTxTest.java |  6 ++---
 ...StoreUsageMultinodeStaticStartAbstractTest.java |  6 ++---
 ...heStoreUsageMultinodeStaticStartAtomicTest.java |  6 ++---
 .../CacheStoreUsageMultinodeStaticStartTxTest.java |  6 ++---
 .../processors/cache/CacheTxFastFinishTest.java    |  6 ++---
 .../cache/CacheTxNotAllowReadFromBackupTest.java   |  6 ++---
 .../cache/CacheValidatorMetricsTest.java           |  6 ++---
 .../ClientFastReplyCoordinatorFailureTest.java     |  6 ++---
 .../cache/ClusterReadOnlyModeAbstractTest.java     |  6 ++---
 .../processors/cache/ClusterReadOnlyModeTest.java  |  6 ++---
 .../processors/cache/ClusterStateAbstractTest.java |  6 ++---
 .../cache/ClusterStatePartitionedSelfTest.java     |  6 ++---
 .../cache/ClusterStateReplicatedSelfTest.java      |  6 ++---
 .../processors/cache/ConcurrentCacheStartTest.java |  6 ++---
 .../processors/cache/CrossCacheLockTest.java       |  6 ++---
 ...rossCacheTxNearEnabledRandomOperationsTest.java |  6 ++---
 .../cache/CrossCacheTxRandomOperationsTest.java    |  6 ++---
 .../DataStorageConfigurationValidationTest.java    |  6 ++---
 .../EntryVersionConsistencyReadThroughTest.java    |  6 ++---
 .../GridAbstractCacheInterceptorRebalanceTest.java |  6 ++---
 .../GridCacheAbstractByteArrayValuesSelfTest.java  |  6 ++---
 .../cache/GridCacheAbstractFailoverSelfTest.java   |  6 ++---
 .../cache/GridCacheAbstractFailoverTxSelfTest.java |  6 ++---
 ...dCacheAbstractFullApiMultithreadedSelfTest.java |  6 ++---
 .../cache/GridCacheAbstractFullApiSelfTest.java    |  6 ++---
 .../cache/GridCacheAbstractIteratorsSelfTest.java  |  6 ++---
 .../cache/GridCacheAbstractLocalStoreSelfTest.java |  6 ++---
 .../cache/GridCacheAbstractMetricsSelfTest.java    |  6 ++---
 .../cache/GridCacheAbstractRemoveFailureTest.java  |  6 ++---
 .../cache/GridCacheAbstractSelfTest.java           |  6 ++---
 .../cache/GridCacheAbstractTxReadTest.java         |  6 ++---
 ...idCacheAbstractUsersAffinityMapperSelfTest.java |  6 ++---
 .../cache/GridCacheAffinityApiSelfTest.java        |  6 ++---
 .../cache/GridCacheAffinityMapperSelfTest.java     |  6 ++---
 .../cache/GridCacheAffinityRoutingSelfTest.java    |  6 ++---
 .../cache/GridCacheAlwaysEvictionPolicy.java       |  6 ++---
 .../GridCacheAsyncOperationsLimitSelfTest.java     |  6 ++---
 ...acheAtomicEntryProcessorDeploymentSelfTest.java |  6 ++---
 .../cache/GridCacheAtomicMessageCountSelfTest.java |  6 ++---
 ...GridCacheAtomicUsersAffinityMapperSelfTest.java |  6 ++---
 .../cache/GridCacheBasicApiAbstractTest.java       |  6 ++---
 .../cache/GridCacheBasicStoreAbstractTest.java     |  6 ++---
 ...idCacheBasicStoreMultithreadedAbstractTest.java |  6 ++---
 .../cache/GridCacheClearAllSelfTest.java           |  6 ++---
 .../cache/GridCacheClearLocallySelfTest.java       |  6 ++---
 .../processors/cache/GridCacheClearSelfTest.java   |  6 ++---
 ...GridCacheColocatedTxStoreExceptionSelfTest.java |  6 ++---
 .../GridCacheConcurrentGetCacheOnClientTest.java   |  6 ++---
 .../cache/GridCacheConcurrentMapSelfTest.java      |  6 ++---
 .../GridCacheConcurrentTxMultiNodeLoadTest.java    |  6 ++---
 .../GridCacheConditionalDeploymentSelfTest.java    |  6 ++---
 .../GridCacheConfigurationConsistencySelfTest.java |  6 ++---
 .../GridCacheConfigurationValidationSelfTest.java  |  6 ++---
 .../cache/GridCacheDaemonNodeAbstractSelfTest.java |  6 ++---
 .../cache/GridCacheEntryMemorySizeSelfTest.java    |  6 ++---
 .../cache/GridCacheEntryVersionSelfTest.java       |  6 ++---
 .../cache/GridCacheEvictionEventAbstractTest.java  |  6 ++---
 .../cache/GridCacheFinishPartitionsSelfTest.java   |  6 ++---
 ...ridCacheFullTextQueryMultithreadedSelfTest.java |  6 ++---
 .../cache/GridCacheGenericTestStore.java           |  6 ++---
 .../GridCacheGetAndTransformStoreAbstractTest.java |  6 ++---
 .../cache/GridCacheIncrementTransformTest.java     |  6 ++---
 .../GridCacheInterceptorAbstractSelfTest.java      |  6 ++---
 ...dCacheInterceptorAtomicNearEnabledSelfTest.java |  6 ++---
 .../GridCacheInterceptorAtomicRebalanceTest.java   |  6 ++---
 ...idCacheInterceptorAtomicReplicatedSelfTest.java |  6 ++---
 .../cache/GridCacheInterceptorAtomicSelfTest.java  |  6 ++---
 ...terceptorAtomicWithStoreReplicatedSelfTest.java |  6 ++---
 ...ridCacheInterceptorAtomicWithStoreSelfTest.java |  6 ++---
 .../GridCacheInterceptorLocalAtomicSelfTest.java   |  6 ++---
 ...cheInterceptorLocalAtomicWithStoreSelfTest.java |  6 ++---
 .../cache/GridCacheInterceptorLocalSelfTest.java   |  6 ++---
 ...GridCacheInterceptorLocalWithStoreSelfTest.java |  6 ++---
 .../GridCacheInterceptorNearEnabledSelfTest.java   |  6 ++---
 .../GridCacheInterceptorReplicatedSelfTest.java    |  6 ++---
 ...acheInterceptorReplicatedWithStoreSelfTest.java |  6 ++---
 .../cache/GridCacheInterceptorSelfTest.java        |  6 ++---
 ...CacheInterceptorTransactionalRebalanceTest.java |  6 ++---
 .../GridCacheInterceptorWithStoreSelfTest.java     |  6 ++---
 .../cache/GridCacheIteratorPerformanceTest.java    |  6 ++---
 .../GridCacheKeyCheckNearEnabledSelfTest.java      |  6 ++---
 .../cache/GridCacheKeyCheckSelfTest.java           |  6 ++---
 .../processors/cache/GridCacheLeakTest.java        |  6 ++---
 .../cache/GridCacheLifecycleAwareSelfTest.java     |  6 ++---
 .../GridCacheLocalTxStoreExceptionSelfTest.java    |  6 ++---
 ...CacheLongRunningTransactionDiagnosticsTest.java |  6 ++---
 .../cache/GridCacheMarshallerTxAbstractTest.java   |  6 ++---
 .../GridCacheMarshallingNodeJoinSelfTest.java      |  6 ++---
 .../GridCacheMissingCommitVersionSelfTest.java     |  6 ++---
 .../GridCacheMixedPartitionExchangeSelfTest.java   |  6 ++---
 .../cache/GridCacheMultiUpdateLockSelfTest.java    |  6 ++---
 .../GridCacheMultinodeUpdateAbstractSelfTest.java  |  6 ++---
 ...heMultinodeUpdateAtomicNearEnabledSelfTest.java |  6 ++---
 .../GridCacheMultinodeUpdateAtomicSelfTest.java    |  6 ++---
 ...ultinodeUpdateNearEnabledNoBackupsSelfTest.java |  6 ++---
 ...ridCacheMultinodeUpdateNearEnabledSelfTest.java |  6 ++---
 .../cache/GridCacheMultinodeUpdateSelfTest.java    |  6 ++---
 .../processors/cache/GridCacheMvccFlagsTest.java   |  6 ++---
 .../cache/GridCacheMvccManagerSelfTest.java        |  6 ++---
 .../GridCacheMvccMultiThreadedUpdateSelfTest.java  |  6 ++---
 .../cache/GridCacheMvccPartitionedSelfTest.java    |  6 ++---
 .../processors/cache/GridCacheMvccSelfTest.java    |  6 ++---
 .../GridCacheNearTxStoreExceptionSelfTest.java     |  6 ++---
 .../cache/GridCacheNestedTxAbstractTest.java       |  6 ++---
 .../cache/GridCacheObjectToStringSelfTest.java     |  6 ++---
 ...heOffHeapAtomicMultiThreadedUpdateSelfTest.java |  6 ++---
 ...OffHeapMultiThreadedUpdateAbstractSelfTest.java |  6 ++---
 ...ridCacheOffHeapMultiThreadedUpdateSelfTest.java |  6 ++---
 .../cache/GridCacheOffheapUpdateSelfTest.java      |  6 ++---
 .../cache/GridCacheOnCopyFlagAbstractSelfTest.java |  6 ++---
 .../cache/GridCacheOnCopyFlagAtomicSelfTest.java   |  6 ++---
 .../cache/GridCacheOnCopyFlagLocalSelfTest.java    |  6 ++---
 .../GridCacheOnCopyFlagReplicatedSelfTest.java     |  6 ++---
 .../GridCacheOnCopyFlagTxPartitionedSelfTest.java  |  6 ++---
 .../cache/GridCacheOrderedPreloadingSelfTest.java  |  6 ++---
 .../cache/GridCacheP2PUndeploySelfTest.java        |  6 ++---
 .../cache/GridCachePartitionedGetSelfTest.java     |  6 ++---
 .../GridCachePartitionedLocalStoreSelfTest.java    |  6 ++---
 ...CachePartitionedProjectionAffinitySelfTest.java |  6 ++---
 .../cache/GridCachePartitionedWritesTest.java      |  6 ++---
 .../GridCachePreloadingEvictionsSelfTest.java      |  6 ++---
 .../cache/GridCachePutAllFailoverSelfTest.java     |  6 ++---
 .../processors/cache/GridCachePutAllTask.java      |  6 ++---
 .../cache/GridCacheQueryEmbeddedValue.java         |  6 ++---
 .../GridCacheQueryIndexingDisabledSelfTest.java    |  6 ++---
 .../cache/GridCacheQueryInternalKeysSelfTest.java  |  6 ++---
 .../GridCacheQuerySqlFieldInlineSizeSelfTest.java  |  6 ++---
 .../cache/GridCacheReferenceCleanupSelfTest.java   |  6 ++---
 .../processors/cache/GridCacheReloadSelfTest.java  |  6 ++---
 .../GridCacheReplicatedLocalStoreSelfTest.java     |  6 ++---
 .../GridCacheReplicatedSynchronousCommitTest.java  |  6 ++---
 ...ridCacheReplicatedTxStoreExceptionSelfTest.java |  6 ++---
 ...CacheReplicatedUsersAffinityMapperSelfTest.java |  6 ++---
 .../GridCacheReturnValueTransferSelfTest.java      |  6 ++---
 .../processors/cache/GridCacheSlowTxWarnTest.java  |  6 ++---
 .../processors/cache/GridCacheStopSelfTest.java    |  6 ++---
 .../GridCacheStoreManagerDeserializationTest.java  |  6 ++---
 .../cache/GridCacheStoreValueBytesSelfTest.java    |  6 ++---
 ...idCacheTcpClientDiscoveryMultiThreadedTest.java |  6 ++---
 .../processors/cache/GridCacheTestEntryEx.java     |  6 ++---
 .../processors/cache/GridCacheTestKey.java         |  6 ++---
 .../processors/cache/GridCacheTestStore.java       |  6 ++---
 .../processors/cache/GridCacheTestValue.java       |  6 ++---
 .../processors/cache/GridCacheTestValue2.java      |  6 ++---
 ...dCacheTransactionalAbstractMetricsSelfTest.java |  6 ++---
 ...nsactionalEntryProcessorDeploymentSelfTest.java |  6 ++---
 .../cache/GridCacheTtlManagerEvictionSelfTest.java |  6 ++---
 .../cache/GridCacheTtlManagerLoadTest.java         |  6 ++---
 .../cache/GridCacheTtlManagerNotificationTest.java |  6 ++---
 .../cache/GridCacheTtlManagerSelfTest.java         |  6 ++---
 .../GridCacheTxPartitionedLocalStoreSelfTest.java  |  6 ++---
 .../GridCacheTxUsersAffinityMapperSelfTest.java    |  6 ++---
 .../processors/cache/GridCacheUtilsSelfTest.java   |  6 ++---
 .../GridCacheValueBytesPreloadingSelfTest.java     |  6 ++---
 .../GridCacheValueConsistencyAbstractSelfTest.java |  6 ++---
 ...onsistencyTransactionalNearEnabledSelfTest.java |  6 ++---
 ...CacheValueConsistencyTransactionalSelfTest.java |  6 ++---
 .../cache/GridCacheVariableTopologySelfTest.java   |  6 ++---
 .../cache/GridCacheVersionMultinodeTest.java       |  6 ++---
 .../processors/cache/GridCacheVersionSelfTest.java |  6 ++---
 .../cache/GridCacheVersionTopologyChangeTest.java  |  6 ++---
 ...ataStorageConfigurationConsistencySelfTest.java |  6 ++---
 .../cache/GridEvictionPolicyMBeansTest.java        |  6 ++---
 ...dLocalCacheStoreManagerDeserializationTest.java |  6 ++---
 .../cache/GridLocalIgniteSerializationTest.java    |  6 ++---
 ...ridProjectionForCachesOnDaemonNodeSelfTest.java |  6 ++---
 .../processors/cache/H2CacheStoreStrategy.java     |  6 ++---
 .../IgniteAbstractDynamicCacheStartFailTest.java   |  6 ++---
 ...gniteAtomicCacheEntryProcessorNodeJoinTest.java |  6 ++---
 .../cache/IgniteCacheAbstractStopBusySelfTest.java |  6 ++---
 .../processors/cache/IgniteCacheAbstractTest.java  |  6 ++---
 .../IgniteCacheAtomicCopyOnReadDisabledTest.java   |  6 ++---
 .../cache/IgniteCacheAtomicInvokeTest.java         |  6 ++---
 .../cache/IgniteCacheAtomicLocalInvokeTest.java    |  6 ++---
 .../cache/IgniteCacheAtomicLocalPeekModesTest.java |  6 ++---
 .../IgniteCacheAtomicLocalStoreValueTest.java      |  6 ++---
 .../IgniteCacheAtomicLocalWithStoreInvokeTest.java |  6 ++---
 .../IgniteCacheAtomicNearEnabledInvokeTest.java    |  6 ++---
 ...IgniteCacheAtomicNearEnabledStoreValueTest.java |  6 ++---
 .../cache/IgniteCacheAtomicNearPeekModesTest.java  |  6 ++---
 .../cache/IgniteCacheAtomicPeekModesTest.java      |  6 ++---
 .../IgniteCacheAtomicPutAllFailoverSelfTest.java   |  6 ++---
 .../IgniteCacheAtomicReplicatedPeekModesTest.java  |  6 ++---
 .../cache/IgniteCacheAtomicStopBusySelfTest.java   |  6 ++---
 .../cache/IgniteCacheAtomicStoreValueTest.java     |  6 ++---
 .../IgniteCacheAtomicWithStoreInvokeTest.java      |  6 ++---
 .../IgniteCacheBinaryEntryProcessorSelfTest.java   |  6 ++---
 .../IgniteCacheBinaryObjectsScanSelfTest.java      |  6 ++---
 ...teCacheBinaryObjectsScanWithEventsSelfTest.java |  6 ++---
 .../IgniteCacheConfigVariationsFullApiTest.java    |  6 ++---
 ...gniteCacheConfigurationDefaultTemplateTest.java |  6 ++---
 .../IgniteCacheConfigurationTemplateTest.java      |  6 ++---
 .../IgniteCacheContainsKeyAbstractSelfTest.java    |  6 ++---
 .../cache/IgniteCacheContainsKeyAtomicTest.java    |  6 ++---
 .../IgniteCacheCopyOnReadDisabledAbstractTest.java |  6 ++---
 .../cache/IgniteCacheCreateRestartSelfTest.java    |  6 ++---
 .../cache/IgniteCacheDynamicStopSelfTest.java      |  6 ++---
 .../IgniteCacheEntryListenerAbstractTest.java      |  6 ++---
 .../IgniteCacheEntryListenerAtomicLocalTest.java   |  6 ++---
 ...niteCacheEntryListenerAtomicReplicatedTest.java |  6 ++---
 .../cache/IgniteCacheEntryListenerAtomicTest.java  |  6 ++---
 ...niteCacheEntryListenerEagerTtlDisabledTest.java |  6 ++---
 .../IgniteCacheEntryListenerExpiredEventsTest.java |  6 ++---
 .../cache/IgniteCacheEntryListenerTxLocalTest.java |  6 ++---
 .../IgniteCacheEntryListenerTxReplicatedTest.java  |  6 ++---
 .../cache/IgniteCacheEntryListenerTxTest.java      |  6 ++---
 .../cache/IgniteCacheEntryProcessorCallTest.java   |  6 ++---
 .../IgniteCacheEntryProcessorNodeJoinTest.java     |  6 ++---
 .../IgniteCacheExpireAndUpdateConsistencyTest.java |  6 ++---
 .../IgniteCacheGetCustomCollectionsSelfTest.java   |  6 ++---
 .../processors/cache/IgniteCacheGroupsTest.java    |  6 ++---
 .../cache/IgniteCacheIncrementTxTest.java          |  6 ++---
 .../cache/IgniteCacheInterceptorSelfTestSuite.java |  6 ++---
 .../cache/IgniteCacheInvokeAbstractTest.java       |  6 ++---
 .../IgniteCacheInvokeReadThroughAbstractTest.java  |  6 ++---
 ...IgniteCacheInvokeReadThroughSingleNodeTest.java |  6 ++---
 .../cache/IgniteCacheInvokeReadThroughTest.java    |  6 ++---
 .../IgniteCacheLoadRebalanceEvictionSelfTest.java  |  6 ++---
 .../cache/IgniteCacheManyAsyncOperationsTest.java  |  6 ++---
 .../cache/IgniteCacheMvccTxInvokeTest.java         |  6 ++---
 .../IgniteCacheMvccTxNearEnabledInvokeTest.java    |  6 ++---
 .../cache/IgniteCacheNearLockValueSelfTest.java    |  6 ++---
 .../cache/IgniteCacheNoSyncForGetTest.java         |  6 ++---
 .../cache/IgniteCacheObjectPutSelfTest.java        |  6 ++---
 .../IgniteCacheP2pUnmarshallingErrorTest.java      |  6 ++---
 .../IgniteCacheP2pUnmarshallingNearErrorTest.java  |  6 ++---
 ...iteCacheP2pUnmarshallingRebalanceErrorTest.java |  6 ++---
 .../IgniteCacheP2pUnmarshallingTxErrorTest.java    |  6 ++---
 .../cache/IgniteCachePartitionMapUpdateTest.java   |  6 ++---
 .../cache/IgniteCachePeekModesAbstractTest.java    |  6 ++---
 .../cache/IgniteCachePutAllRestartTest.java        |  6 ++---
 .../cache/IgniteCachePutStackOverflowSelfTest.java |  6 ++---
 .../IgniteCacheReadThroughEvictionSelfTest.java    |  6 ++---
 ...teCacheReadThroughEvictionsVariationsSuite.java |  6 ++---
 .../cache/IgniteCacheReadThroughStoreCallTest.java |  6 ++---
 ...IgniteCacheScanPredicateDeploymentSelfTest.java |  6 ++---
 .../cache/IgniteCacheSerializationSelfTest.java    |  6 ++---
 .../cache/IgniteCacheStartStopLoadTest.java        |  6 ++---
 .../processors/cache/IgniteCacheStartTest.java     |  6 ++---
 .../cache/IgniteCacheStoreCollectionTest.java      |  6 ++---
 .../cache/IgniteCacheStoreValueAbstractTest.java   |  6 ++---
 .../IgniteCacheTransactionalStopBusySelfTest.java  |  6 ++---
 .../cache/IgniteCacheTxCopyOnReadDisabledTest.java |  6 ++---
 .../processors/cache/IgniteCacheTxInvokeTest.java  |  6 ++---
 .../cache/IgniteCacheTxLocalInvokeTest.java        |  6 ++---
 .../cache/IgniteCacheTxLocalPeekModesTest.java     |  6 ++---
 .../cache/IgniteCacheTxLocalStoreValueTest.java    |  6 ++---
 .../cache/IgniteCacheTxNearEnabledInvokeTest.java  |  6 ++---
 .../IgniteCacheTxNearEnabledStoreValueTest.java    |  6 ++---
 .../cache/IgniteCacheTxNearPeekModesTest.java      |  6 ++---
 .../cache/IgniteCacheTxPeekModesTest.java          |  6 ++---
 .../cache/IgniteCacheTxPreloadNoWriteTest.java     |  6 ++---
 .../IgniteCacheTxReplicatedPeekModesTest.java      |  6 ++---
 .../cache/IgniteCacheTxStoreValueTest.java         |  6 ++---
 .../cache/IgniteCachingProviderSelfTest.java       |  6 ++---
 .../IgniteClientAffinityAssignmentSelfTest.java    |  6 ++---
 .../IgniteClientCacheInitializationFailTest.java   |  6 ++---
 .../cache/IgniteClientCacheStartFailoverTest.java  |  6 ++---
 .../cache/IgniteClusterActivateDeactivateTest.java |  6 ++---
 ...usterActivateDeactivateTestWithPersistence.java |  6 ++---
 ...eactivateTestWithPersistenceAndMemoryReuse.java |  6 ++---
 .../cache/IgniteDaemonNodeMarshallerCacheTest.java |  6 ++---
 .../IgniteDiscoDataHandlingInNewClusterTest.java   |  6 ++---
 .../cache/IgniteDynamicCacheAndNodeStop.java       |  6 ++---
 .../cache/IgniteDynamicCacheFilterTest.java        |  6 ++---
 .../cache/IgniteDynamicCacheMultinodeTest.java     |  6 ++---
 ...teDynamicCacheStartCoordinatorFailoverTest.java |  6 ++---
 .../cache/IgniteDynamicCacheStartFailTest.java     |  6 ++---
 ...teDynamicCacheStartFailWithPersistenceTest.java |  6 ++---
 ...niteDynamicCacheStartNoExchangeTimeoutTest.java |  6 ++---
 .../cache/IgniteDynamicCacheStartSelfTest.java     |  6 ++---
 .../IgniteDynamicCacheStartStopConcurrentTest.java |  6 ++---
 .../IgniteDynamicCacheWithConfigStartSelfTest.java |  6 ++---
 .../IgniteDynamicClientCacheStartSelfTest.java     |  6 ++---
 .../cache/IgniteExchangeFutureHistoryTest.java     |  6 ++---
 .../IgniteGetNonPlainKeyReadThroughSelfTest.java   |  6 ++---
 .../cache/IgniteIncompleteCacheObjectSelfTest.java |  6 ++---
 .../cache/IgniteInternalCacheTypesTest.java        |  6 ++---
 ...IgniteMarshallerCacheClassNameConflictTest.java |  6 ++---
 ...hallerCacheClientRequestsMappingOnMissTest.java |  6 ++---
 ...niteMarshallerCacheConcurrentReadWriteTest.java |  6 ++---
 .../cache/IgniteMarshallerCacheFSRestoreTest.java  |  6 ++---
 .../IgniteMvccTxMultiThreadedAbstractTest.java     |  6 ++---
 .../IgniteMvccTxSingleThreadedAbstractTest.java    |  6 ++---
 .../cache/IgniteNearClientCacheCloseTest.java      |  6 ++---
 .../cache/IgniteOnePhaseCommitInvokeTest.java      |  6 ++---
 .../cache/IgniteOnePhaseCommitNearReadersTest.java |  6 ++---
 .../cache/IgniteOnePhaseCommitNearSelfTest.java    |  6 ++---
 .../cache/IgniteOutOfMemoryPropagationTest.java    |  6 ++---
 .../cache/IgnitePdsDataRegionMetricsTxTest.java    |  6 ++---
 .../cache/IgnitePutAllLargeBatchSelfTest.java      |  6 ++---
 ...ePutAllUpdateNonPreloadedPartitionSelfTest.java |  6 ++---
 ...gniteStartCacheInTransactionAtomicSelfTest.java |  6 ++---
 .../IgniteStartCacheInTransactionSelfTest.java     |  6 ++---
 .../cache/IgniteStaticCacheStartSelfTest.java      |  6 ++---
 .../cache/IgniteSystemCacheOnClientTest.java       |  6 ++---
 .../IgniteTopologyValidatorAbstractCacheTest.java  |  6 ++---
 ...TopologyValidatorAbstractTxCacheGroupsTest.java |  6 ++---
 ...IgniteTopologyValidatorAbstractTxCacheTest.java |  6 ++---
 ...teTopologyValidatorCacheGroupsAbstractTest.java |  6 ++---
 .../IgniteTopologyValidatorGridSplitCacheTest.java |  6 ++---
 ...idatorNearPartitionedAtomicCacheGroupsTest.java |  6 ++---
 ...ogyValidatorNearPartitionedAtomicCacheTest.java |  6 ++---
 ...yValidatorNearPartitionedTxCacheGroupsTest.java |  6 ++---
 ...opologyValidatorNearPartitionedTxCacheTest.java |  6 ++---
 ...yValidatorPartitionedAtomicCacheGroupsTest.java |  6 ++---
 ...opologyValidatorPartitionedAtomicCacheTest.java |  6 ++---
 ...ologyValidatorPartitionedTxCacheGroupsTest.java |  6 ++---
 ...iteTopologyValidatorPartitionedTxCacheTest.java |  6 ++---
 ...gyValidatorReplicatedAtomicCacheGroupsTest.java |  6 ++---
 ...TopologyValidatorReplicatedAtomicCacheTest.java |  6 ++---
 ...pologyValidatorReplicatedTxCacheGroupsTest.java |  6 ++---
 ...niteTopologyValidatorReplicatedTxCacheTest.java |  6 ++---
 .../processors/cache/IgniteTxAbstractTest.java     |  6 ++---
 .../cache/IgniteTxConcurrentGetAbstractTest.java   |  6 ++---
 .../cache/IgniteTxConfigCacheSelfTest.java         |  6 ++---
 .../cache/IgniteTxExceptionAbstractSelfTest.java   |  6 ++---
 .../cache/IgniteTxMultiNodeAbstractTest.java       |  6 ++---
 .../cache/IgniteTxMultiThreadedAbstractTest.java   |  6 ++---
 .../cache/IgniteTxReentryAbstractSelfTest.java     |  6 ++---
 .../cache/IgniteTxSingleThreadedAbstractTest.java  |  6 ++---
 .../IgniteTxStoreExceptionAbstractSelfTest.java    |  6 ++---
 ...nterceptorCacheConfigVariationsFullApiTest.java |  6 ++---
 .../InterceptorWithKeepBinaryCacheFullApiTest.java |  6 ++---
 .../processors/cache/MapCacheStoreStrategy.java    |  6 ++---
 .../MarshallerCacheJobRunNodeRestartTest.java      |  6 ++---
 .../cache/MemoryPolicyConfigValidationTest.java    |  6 ++---
 .../cache/MvccCacheGroupMetricsMBeanTest.java      |  6 ++---
 ...NonAffinityCoordinatorDynamicStartStopTest.java |  6 ++---
 ...OffheapCacheMetricsForClusterGroupSelfTest.java |  6 ++---
 ...PartitionedAtomicCacheGetsDistributionTest.java |  6 ++---
 ...MvccTxPessimisticCacheGetsDistributionTest.java |  6 ++---
 ...ctionalOptimisticCacheGetsDistributionTest.java |  6 ++---
 ...tionalPessimisticCacheGetsDistributionTest.java |  6 ++---
 .../PartitionsExchangeCoordinatorFailoverTest.java |  6 ++---
 ...ionsExchangeOnDiscoveryHistoryOverflowTest.java |  6 ++---
 .../RebalanceWithDifferentThreadPoolSizeTest.java  |  6 ++---
 .../ReplicatedAtomicCacheGetsDistributionTest.java |  6 ++---
 ...MvccTxPessimisticCacheGetsDistributionTest.java |  6 ++---
 ...ctionalOptimisticCacheGetsDistributionTest.java |  6 ++---
 ...tionalPessimisticCacheGetsDistributionTest.java |  6 ++---
 .../SetTxTimeoutOnPartitionMapExchangeTest.java    |  6 ++---
 .../processors/cache/TestCacheStoreStrategy.java   |  6 ++---
 .../cache/WalModeChangeAbstractSelfTest.java       |  6 ++---
 .../cache/WalModeChangeAdvancedSelfTest.java       |  6 ++---
 .../cache/WalModeChangeCommonAbstractSelfTest.java |  6 ++---
 ...deChangeCoordinatorNotAffinityNodeSelfTest.java |  6 ++---
 .../processors/cache/WalModeChangeSelfTest.java    |  6 ++---
 .../cache/WithKeepBinaryCacheFullApiTest.java      |  6 ++---
 .../BinaryAtomicCacheLocalEntriesSelfTest.java     |  6 ++---
 .../binary/BinaryMetadataUpdatesFlowTest.java      |  6 ++---
 .../binary/BinaryTxCacheLocalEntriesSelfTest.java  |  6 ++---
 .../binary/CacheKeepBinaryWithInterceptorTest.java |  6 ++---
 .../GridBinaryCacheEntryMemorySizeSelfTest.java    |  6 ++---
 ...naryAtomicEntryProcessorDeploymentSelfTest.java |  6 ++---
 ...eBinaryObjectMetadataExchangeMultinodeTest.java |  6 ++---
 ...idCacheBinaryObjectUserClassloaderSelfTest.java |  6 ++---
 ...eBinaryObjectsAbstractDataStreamerSelfTest.java |  6 ++---
 ...BinaryObjectsAbstractMultiThreadedSelfTest.java |  6 ++---
 .../GridCacheBinaryObjectsAbstractSelfTest.java    |  6 ++---
 .../GridCacheBinaryStoreAbstractSelfTest.java      |  6 ++---
 ...eBinaryStoreBinariesDefaultMappersSelfTest.java |  6 ++---
 ...naryStoreBinariesSimpleNameMappersSelfTest.java |  6 ++---
 .../GridCacheBinaryStoreObjectsSelfTest.java       |  6 ++---
 ...nsactionalEntryProcessorDeploymentSelfTest.java |  6 ++---
 ...lientNodeBinaryObjectMetadataMultinodeTest.java |  6 ++---
 ...ridCacheClientNodeBinaryObjectMetadataTest.java |  6 ++---
 .../DataStreamProcessorBinarySelfTest.java         |  6 ++---
 ...taStreamProcessorPersistenceBinarySelfTest.java |  6 ++---
 .../GridDataStreamerImplSelfTest.java              |  6 ++---
 .../GridCacheAffinityRoutingBinarySelfTest.java    |  6 ++---
 ...nedOnlyBinaryDataStreamerMultiNodeSelfTest.java |  6 ++---
 ...nlyBinaryDataStreamerMultithreadedSelfTest.java |  6 ++---
 ...omicPartitionedOnlyBinaryMultiNodeSelfTest.java |  6 ++---
 ...PartitionedOnlyBinaryMultithreadedSelfTest.java |  6 ++---
 ...riesNearPartitionedByteArrayValuesSelfTest.java |  6 ++---
 ...riesPartitionedOnlyByteArrayValuesSelfTest.java |  6 ++---
 ...aryObjectsAtomicNearDisabledOnheapSelfTest.java |  6 ++---
 ...cheBinaryObjectsAtomicNearDisabledSelfTest.java |  6 ++---
 ...GridCacheBinaryObjectsAtomicOnheapSelfTest.java |  6 ++---
 .../dht/GridCacheBinaryObjectsAtomicSelfTest.java  |  6 ++---
 ...jectsPartitionedNearDisabledOnheapSelfTest.java |  6 ++---
 ...naryObjectsPartitionedNearDisabledSelfTest.java |  6 ++---
 ...acheBinaryObjectsPartitionedOnheapSelfTest.java |  6 ++---
 .../GridCacheBinaryObjectsPartitionedSelfTest.java |  6 ++---
 .../GridCacheBinaryObjectsReplicatedSelfTest.java  |  6 ++---
 .../GridCacheBinaryObjectsAtomicLocalSelfTest.java |  6 ++---
 .../GridCacheBinaryObjectsLocalOnheapSelfTest.java |  6 ++---
 .../local/GridCacheBinaryObjectsLocalSelfTest.java |  6 ++---
 .../IgniteCacheAbstractExecutionContextTest.java   |  6 ++---
 .../IgniteCacheAtomicExecutionContextTest.java     |  6 ++---
 .../IgniteCacheContinuousExecutionContextTest.java |  6 ++---
 .../IgniteCacheIsolatedExecutionContextTest.java   |  6 ++---
 .../IgniteCacheP2PDisableExecutionContextTest.java |  6 ++---
 .../IgniteCachePrivateExecutionContextTest.java    |  6 ++---
 .../IgniteCacheReplicatedExecutionContextTest.java |  6 ++---
 .../IgniteCacheSharedExecutionContextTest.java     |  6 ++---
 .../context/IgniteCacheTxExecutionContextTest.java |  6 ++---
 ...acheAbstractDataStructuresFailoverSelfTest.java |  6 ++---
 ...stractQueueFailoverDataConsistencySelfTest.java |  6 ++---
 ...ridCacheAtomicReferenceApiSelfAbstractTest.java |  6 ++---
 ...dCacheAtomicReferenceMultiNodeAbstractTest.java |  6 ++---
 .../GridCacheAtomicStampedApiSelfAbstractTest.java |  6 ++---
 .../GridCacheMultiNodeDataStructureTest.java       |  6 ++---
 .../GridCacheQueueApiSelfAbstractTest.java         |  6 ++---
 .../GridCacheQueueCleanupSelfTest.java             |  6 ++---
 .../GridCacheQueueClientDisconnectTest.java        |  6 ++---
 .../GridCacheQueueJoinedNodeSelfAbstractTest.java  |  6 ++---
 .../GridCacheQueueMultiNodeAbstractSelfTest.java   |  6 ++---
 ...GridCacheQueueMultiNodeConsistencySelfTest.java |  6 ++---
 ...ridCacheQueueRotativeMultiNodeAbstractTest.java |  6 ++---
 .../GridCacheSequenceApiSelfAbstractTest.java      |  6 ++---
 ...GridCacheSequenceMultiNodeAbstractSelfTest.java |  6 ++---
 .../GridCacheSetAbstractSelfTest.java              |  6 ++---
 .../GridCacheSetFailoverAbstractSelfTest.java      |  6 ++---
 .../IgniteAtomicLongApiAbstractSelfTest.java       |  6 ++---
 .../datastructures/IgniteAtomicsAbstractTest.java  |  6 ++---
 .../IgniteClientDataStructuresAbstractTest.java    |  6 ++---
 .../IgniteClientDataStructuresTest.java            |  6 ++---
 .../IgniteClientDiscoveryDataStructuresTest.java   |  6 ++---
 .../IgniteCollectionAbstractTest.java              |  6 ++---
 .../IgniteCountDownLatchAbstractSelfTest.java      |  6 ++---
 .../IgniteDataStructureUniqueNameTest.java         |  6 ++---
 .../IgniteDataStructureWithJobTest.java            |  6 ++---
 .../IgniteDataStructuresNoClassOnServerTest.java   |  6 ++---
 ...iteExchangeLatchManagerCoordinatorFailTest.java |  6 ++---
 .../datastructures/IgniteLockAbstractSelfTest.java |  6 ++---
 .../IgniteSemaphoreAbstractSelfTest.java           |  6 ++---
 .../IgniteSequenceInternalCleanupTest.java         |  6 ++---
 .../SemaphoreFailoverNoWaitingAcquirerTest.java    |  6 ++---
 .../SemaphoreFailoverSafeReleasePermitsTest.java   |  6 ++---
 .../GridCacheLocalAtomicQueueApiSelfTest.java      |  6 ++---
 .../local/GridCacheLocalAtomicSetSelfTest.java     |  6 ++---
 .../local/GridCacheLocalQueueApiSelfTest.java      |  6 ++---
 .../local/GridCacheLocalSequenceApiSelfTest.java   |  6 ++---
 .../local/GridCacheLocalSetSelfTest.java           |  6 ++---
 .../local/IgniteLocalAtomicLongApiSelfTest.java    |  6 ++---
 .../local/IgniteLocalCountDownLatchSelfTest.java   |  6 ++---
 .../local/IgniteLocalLockSelfTest.java             |  6 ++---
 .../local/IgniteLocalSemaphoreSelfTest.java        |  6 ++---
 ...GridCachePartitionedAtomicQueueApiSelfTest.java |  6 ++---
 ...titionedAtomicQueueCreateMultiNodeSelfTest.java |  6 ++---
 ...AtomicQueueFailoverDataConsistencySelfTest.java |  6 ++---
 ...chePartitionedAtomicQueueMultiNodeSelfTest.java |  6 ++---
 ...artitionedAtomicQueueRotativeMultiNodeTest.java |  6 ++---
 ...CachePartitionedAtomicReferenceApiSelfTest.java |  6 ++---
 ...chePartitionedAtomicReferenceMultiNodeTest.java |  6 ++---
 ...PartitionedAtomicSequenceMultiThreadedTest.java |  6 ++---
 ...idCachePartitionedAtomicSequenceTxSelfTest.java |  6 ++---
 ...dCachePartitionedAtomicSetFailoverSelfTest.java |  6 ++---
 .../GridCachePartitionedAtomicSetSelfTest.java     |  6 ++---
 ...idCachePartitionedAtomicStampedApiSelfTest.java |  6 ++---
 ...ePartitionedDataStructuresFailoverSelfTest.java |  6 ++---
 .../GridCachePartitionedNodeRestartTxSelfTest.java |  6 ++---
 .../GridCachePartitionedQueueApiSelfTest.java      |  6 ++---
 ...chePartitionedQueueCreateMultiNodeSelfTest.java |  6 ++---
 ...GridCachePartitionedQueueEntryMoveSelfTest.java |  6 ++---
 ...tionedQueueFailoverDataConsistencySelfTest.java |  6 ++---
 ...ridCachePartitionedQueueJoinedNodeSelfTest.java |  6 ++---
 ...GridCachePartitionedQueueMultiNodeSelfTest.java |  6 ++---
 ...CachePartitionedQueueRotativeMultiNodeTest.java |  6 ++---
 .../GridCachePartitionedSequenceApiSelfTest.java   |  6 ++---
 ...dCachePartitionedSequenceMultiNodeSelfTest.java |  6 ++---
 .../GridCachePartitionedSetFailoverSelfTest.java   |  6 ++---
 .../GridCachePartitionedSetSelfTest.java           |  6 ++---
 .../GridCachePartitionedSetWithClientSelfTest.java |  6 ++---
 ...dCachePartitionedSetWithNodeFilterSelfTest.java |  6 ++---
 .../IgnitePartitionedAtomicLongApiSelfTest.java    |  6 ++---
 .../IgnitePartitionedCountDownLatchSelfTest.java   |  6 ++---
 .../partitioned/IgnitePartitionedLockSelfTest.java |  6 ++---
 .../IgnitePartitionedQueueNoBackupsTest.java       |  6 ++---
 .../IgnitePartitionedSemaphoreSelfTest.java        |  6 ++---
 .../IgnitePartitionedSetNoBackupsSelfTest.java     |  6 ++---
 ...dCacheReplicatedAtomicReferenceApiSelfTest.java |  6 ++---
 ...acheReplicatedAtomicReferenceMultiNodeTest.java |  6 ++---
 ...ridCacheReplicatedAtomicStampedApiSelfTest.java |  6 ++---
 ...heReplicatedDataStructuresFailoverSelfTest.java |  6 ++---
 .../GridCacheReplicatedQueueApiSelfTest.java       |  6 ++---
 .../GridCacheReplicatedQueueMultiNodeSelfTest.java |  6 ++---
 ...dCacheReplicatedQueueRotativeMultiNodeTest.java |  6 ++---
 .../GridCacheReplicatedSequenceApiSelfTest.java    |  6 ++---
 ...idCacheReplicatedSequenceMultiNodeSelfTest.java |  6 ++---
 .../replicated/GridCacheReplicatedSetSelfTest.java |  6 ++---
 .../GridCacheReplicatedSetWithClientSelfTest.java  |  6 ++---
 ...idCacheReplicatedSetWithNodeFilterSelfTest.java |  6 ++---
 .../IgniteReplicatedAtomicLongApiSelfTest.java     |  6 ++---
 .../IgniteReplicatedCountDownLatchSelfTest.java    |  6 ++---
 .../replicated/IgniteReplicatedLockSelfTest.java   |  6 ++---
 .../IgniteReplicatedSemaphoreSelfTest.java         |  6 ++---
 .../cache/distributed/Cache64kPartitionsTest.java  |  6 ++---
 .../distributed/CacheAbstractRestartSelfTest.java  |  6 ++---
 .../cache/distributed/CacheAffinityEarlyTest.java  |  6 ++---
 .../CacheAsyncOperationsFailoverAbstractTest.java  |  6 ++---
 .../CacheAsyncOperationsFailoverAtomicTest.java    |  6 ++---
 .../CacheAsyncOperationsFailoverTxTest.java        |  6 ++---
 .../distributed/CacheAsyncOperationsTest.java      |  6 ++---
 .../CacheAtomicNearUpdateTopologyChangeTest.java   |  6 ++---
 .../CacheAtomicPrimarySyncBackPressureTest.java    |  6 ++---
 .../distributed/CacheBaselineTopologyTest.java     |  6 ++---
 .../cache/distributed/CacheBlockOnGetAllTest.java  |  6 ++---
 .../distributed/CacheBlockOnReadAbstractTest.java  |  6 ++---
 .../cache/distributed/CacheBlockOnScanTest.java    |  6 ++---
 .../distributed/CacheBlockOnSingleGetTest.java     |  6 ++---
 .../CacheClientsConcurrentStartTest.java           |  6 ++---
 .../CacheDataLossOnPartitionMoveTest.java          |  6 ++---
 .../CacheDiscoveryDataConcurrentJoinTest.java      |  6 ++---
 .../cache/distributed/CacheExchangeMergeTest.java  |  6 ++---
 .../distributed/CacheGetFutureHangsSelfTest.java   |  6 ++---
 .../CacheGetInsideLockChangingTopologyTest.java    |  6 ++---
 .../cache/distributed/CacheGroupsPreloadTest.java  |  6 ++---
 ...teAffinityAssignmentNodeJoinValidationTest.java |  6 ++---
 .../CacheLateAffinityAssignmentTest.java           |  6 ++---
 .../CacheLoadingConcurrentGridStartSelfTest.java   |  6 ++---
 ...gConcurrentGridStartSelfTestAllowOverwrite.java |  6 ++---
 .../distributed/CacheLockChangingTopologyTest.java |  6 ++---
 .../distributed/CacheLockReleaseNodeLeaveTest.java |  6 ++---
 ...cheNearDisabledAtomicInvokeRestartSelfTest.java |  6 ++---
 ...DisabledTransactionalInvokeRestartSelfTest.java |  6 ++---
 ...abledTransactionalWriteReadRestartSelfTest.java |  6 ++---
 .../CacheNoValueClassOnServerNodeTest.java         |  6 ++---
 .../distributed/CacheOperationsInterruptTest.java  |  6 ++---
 .../distributed/CachePageWriteLockUnlockTest.java  |  6 ++---
 .../cache/distributed/CacheParallelStartTest.java  |  6 ++---
 .../cache/distributed/CachePartitionStateTest.java |  6 ++---
 .../CachePutAllFailoverAbstractTest.java           |  6 ++---
 .../distributed/CachePutAllFailoverAtomicTest.java |  6 ++---
 .../distributed/CachePutAllFailoverTxTest.java     |  6 ++---
 .../distributed/CacheRentingStateRepairTest.java   |  6 ++---
 .../CacheResultIsNotNullOnPartitionLossTest.java   |  6 ++---
 .../cache/distributed/CacheStartOnJoinTest.java    |  6 ++---
 .../distributed/CacheTryLockMultithreadedTest.java |  6 ++---
 ...gConcurrentGridStartSelfTestAllowOverwrite.java |  6 ++---
 .../CacheTxNearUpdateTopologyChangeTest.java       |  6 ++---
 .../ExchangeMergeStaleServerNodesTest.java         |  6 ++---
 ...AbstractDistributedByteArrayValuesSelfTest.java |  6 ++---
 .../GridCacheAbstractJobExecutionTest.java         |  6 ++---
 .../GridCacheAbstractNodeRestartSelfTest.java      |  6 ++---
 ...AbstractPartitionedByteArrayValuesSelfTest.java |  6 ++---
 .../GridCacheAbstractPrimarySyncSelfTest.java      |  6 ++---
 .../distributed/GridCacheBasicOpAbstractTest.java  |  6 ++---
 .../GridCacheClientModesAbstractSelfTest.java      |  6 ++---
 ...eClientModesTcpClientDiscoveryAbstractTest.java |  6 ++---
 .../GridCacheEntrySetAbstractSelfTest.java         |  6 ++---
 ...idCacheEntrySetIterationPreloadingSelfTest.java |  6 ++---
 .../distributed/GridCacheEventAbstractTest.java    |  6 ++---
 .../distributed/GridCacheLockAbstractTest.java     |  6 ++---
 .../distributed/GridCacheMixedModeSelfTest.java    |  6 ++---
 .../GridCacheModuloAffinityFunction.java           |  6 ++---
 .../GridCacheMultiNodeAbstractTest.java            |  6 ++---
 .../GridCacheMultiNodeLockAbstractTest.java        |  6 ++---
 ...GridCacheMultithreadedFailoverAbstractTest.java |  6 ++---
 .../GridCacheNodeFailureAbstractTest.java          |  6 ++---
 ...PartitionEvictionDuringReadThroughSelfTest.java |  6 ++---
 .../GridCachePartitionNotLoadedEventSelfTest.java  |  6 ++---
 ...nedNearDisabledMvccTxMultiThreadedSelfTest.java |  6 ++---
 ...itionedNearDisabledTxMultiThreadedSelfTest.java |  6 ++---
 ...dCachePartitionedReloadAllAbstractSelfTest.java |  6 ++---
 .../GridCachePreloadEventsAbstractSelfTest.java    |  6 ++---
 .../GridCachePreloadLifecycleAbstractTest.java     |  6 ++---
 .../GridCachePreloadRestartAbstractSelfTest.java   |  6 ++---
 .../GridCacheTransformEventSelfTest.java           |  6 ++---
 ...naryMetadataUpdateChangingTopologySelfTest.java |  6 ++---
 .../IgniteBinaryMetadataUpdateNodeRestartTest.java |  6 ++---
 .../distributed/IgniteCache150ClientsTest.java     |  6 ++---
 ...acheAtomicMessageRecovery10ConnectionsTest.java |  6 ++---
 ...AtomicMessageRecoveryPairedConnectionsTest.java |  6 ++---
 .../IgniteCacheAtomicMessageRecoveryTest.java      |  6 ++---
 .../distributed/IgniteCacheAtomicNodeJoinTest.java |  6 ++---
 .../IgniteCacheAtomicNodeRestartTest.java          |  6 ++---
 ...CacheClientMultiNodeUpdateTopologyLockTest.java |  6 ++---
 .../IgniteCacheClientNodeChangingTopologyTest.java |  6 ++---
 .../IgniteCacheClientNodeConcurrentStart.java      |  6 ++---
 ...gniteCacheClientNodePartitionsExchangeTest.java |  6 ++---
 .../IgniteCacheClientReconnectTest.java            |  6 ++---
 ...teCacheConnectionRecovery10ConnectionsTest.java |  6 ++---
 .../IgniteCacheConnectionRecoveryTest.java         |  6 ++---
 .../IgniteCacheCreatePutMultiNodeSelfTest.java     |  6 ++---
 .../distributed/IgniteCacheCreatePutTest.java      |  6 ++---
 .../IgniteCacheFailedUpdateResponseTest.java       |  6 ++---
 .../distributed/IgniteCacheGetRestartTest.java     |  6 ++---
 ...niteCacheGroupsPartitionLossPolicySelfTest.java |  6 ++---
 .../distributed/IgniteCacheManyClientsTest.java    |  6 ++---
 .../IgniteCacheMessageRecoveryAbstractTest.java    |  6 ++---
 ...niteCacheMessageRecoveryIdleConnectionTest.java |  6 ++---
 .../IgniteCacheMessageWriteTimeoutTest.java        |  6 ++---
 .../IgniteCacheNearRestartRollbackSelfTest.java    |  6 ++---
 .../IgniteCacheNodeJoinAbstractTest.java           |  6 ++---
 .../IgniteCachePartitionLossPolicySelfTest.java    |  6 ++---
 .../distributed/IgniteCachePrimarySyncTest.java    |  6 ++---
 .../IgniteCachePutGetRestartAbstractTest.java      |  6 ++---
 .../distributed/IgniteCacheReadFromBackupTest.java |  6 ++---
 .../IgniteCacheServerNodeConcurrentStart.java      |  6 ++---
 .../IgniteCacheSingleGetMessageTest.java           |  6 ++---
 .../distributed/IgniteCacheSizeFailoverTest.java   |  6 ++---
 .../IgniteCacheSystemTransactionsSelfTest.java     |  6 ++---
 .../distributed/IgniteCacheThreadLocalTxTest.java  |  6 ++---
 .../distributed/IgniteCacheTxIteratorSelfTest.java |  6 ++---
 .../IgniteCacheTxMessageRecoveryTest.java          |  6 ++---
 ...IgniteCacheTxNearDisabledPutGetRestartTest.java |  6 ++---
 .../distributed/IgniteCacheTxNodeJoinTest.java     |  6 ++---
 .../IgniteCrossCacheTxStoreSelfTest.java           |  6 ++---
 .../IgniteMvccTxTimeoutAbstractTest.java           |  6 ++---
 .../IgniteNoClassOnServerAbstractTest.java         |  6 ++---
 .../IgniteOptimisticTxSuspendResumeTest.java       |  6 ++---
 .../IgnitePessimisticTxSuspendResumeTest.java      |  6 ++---
 .../IgniteRejectConnectOnNodeStopTest.java         |  6 ++---
 .../distributed/IgniteTxCachePrimarySyncTest.java  |  6 ++---
 ...WriteSynchronizationModesMultithreadedTest.java |  6 ++---
 .../IgniteTxConcurrentRemoveObjectsTest.java       |  6 ++---
 ...IgniteTxConsistencyRestartAbstractSelfTest.java |  6 ++---
 .../distributed/IgniteTxGetAfterStopTest.java      |  6 ++---
 ...teTxOriginatingNodeFailureAbstractSelfTest.java |  6 ++---
 ...sticOriginatingNodeFailureAbstractSelfTest.java |  6 ++---
 .../distributed/IgniteTxPreloadAbstractTest.java   |  6 ++---
 .../IgniteTxRemoveTimeoutObjectsNearTest.java      |  6 ++---
 .../IgniteTxRemoveTimeoutObjectsTest.java          |  6 ++---
 .../distributed/IgniteTxTimeoutAbstractTest.java   |  6 ++---
 .../distributed/TestCacheNodeExcludingFilter.java  |  6 ++---
 .../dht/CacheGetReadFromBackupFailoverTest.java    |  6 ++---
 .../CachePartitionPartialCountersMapSelfTest.java  |  6 ++---
 ...ractPartitionedOnlyByteArrayValuesSelfTest.java |  6 ++---
 ...CacheAbstractTransformWriteThroughSelfTest.java |  6 ++---
 .../dht/GridCacheAtomicFullApiSelfTest.java        |  6 ++---
 .../dht/GridCacheAtomicNearCacheSelfTest.java      |  6 ++---
 .../GridCacheAtomicNearEnabledFullApiSelfTest.java |  6 ++---
 .../dht/GridCacheAtomicReloadAllSelfTest.java      |  6 ++---
 .../dht/GridCacheClientOnlySelfTest.java           |  6 ++---
 .../dht/GridCacheColocatedDebugTest.java           |  6 ++---
 .../dht/GridCacheColocatedFailoverSelfTest.java    |  6 ++---
 ...CacheColocatedMvccTxSingleThreadedSelfTest.java |  6 ++---
 ...acheColocatedOptimisticTransactionSelfTest.java |  6 ++---
 .../GridCacheColocatedPreloadRestartSelfTest.java  |  6 ++---
 .../dht/GridCacheColocatedPrimarySyncSelfTest.java |  6 ++---
 .../dht/GridCacheColocatedReloadAllSelfTest.java   |  6 ++---
 .../dht/GridCacheColocatedTxExceptionSelfTest.java |  6 ++---
 ...xPessimisticOriginatingNodeFailureSelfTest.java |  6 ++---
 ...GridCacheColocatedTxSingleThreadedSelfTest.java |  6 ++---
 .../GridCacheDaemonNodePartitionedSelfTest.java    |  6 ++---
 ...dCacheDhtAtomicEvictionNearReadersSelfTest.java |  6 ++---
 .../dht/GridCacheDhtAtomicRemoveFailureTest.java   |  6 ++---
 .../dht/GridCacheDhtClientRemoveFailureTest.java   |  6 ++---
 .../distributed/dht/GridCacheDhtEntrySelfTest.java |  6 ++---
 .../dht/GridCacheDhtEntrySetSelfTest.java          |  6 ++---
 .../GridCacheDhtEvictionNearReadersSelfTest.java   |  6 ++---
 .../dht/GridCacheDhtEvictionsDisabledSelfTest.java |  6 ++---
 .../dht/GridCacheDhtMappingSelfTest.java           |  6 ++---
 .../dht/GridCacheDhtMultiBackupTest.java           |  6 ++---
 .../dht/GridCacheDhtPreloadBigDataSelfTest.java    |  6 ++---
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java    |  6 ++---
 .../dht/GridCacheDhtPreloadDisabledSelfTest.java   |  6 ++---
 .../dht/GridCacheDhtPreloadMessageCountTest.java   |  6 ++---
 .../GridCacheDhtPreloadMultiThreadedSelfTest.java  |  6 ++---
 .../dht/GridCacheDhtPreloadOnheapSelfTest.java     |  6 ++---
 .../dht/GridCacheDhtPreloadPerformanceTest.java    |  6 ++---
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java     |  6 ++---
 .../dht/GridCacheDhtPreloadSelfTest.java           |  6 ++---
 .../dht/GridCacheDhtPreloadStartStopSelfTest.java  |  6 ++---
 .../dht/GridCacheDhtPreloadUnloadSelfTest.java     |  6 ++---
 .../dht/GridCacheDhtRemoveFailureTest.java         |  6 ++---
 .../dht/GridCacheDhtTxPreloadSelfTest.java         |  6 ++---
 .../distributed/dht/GridCacheGlobalLoadTest.java   |  6 ++---
 ...nedNearDisabledAtomicOnheapFullApiSelfTest.java |  6 ++---
 ...sabledAtomicOnheapMultiNodeFullApiSelfTest.java |  6 ++---
 ...achePartitionedNearDisabledFullApiSelfTest.java |  6 ++---
 ...idCachePartitionedNearDisabledLockSelfTest.java |  6 ++---
 ...achePartitionedNearDisabledMetricsSelfTest.java |  6 ++---
 ...tionedNearDisabledMultiNodeFullApiSelfTest.java |  6 ++---
 ...isabledMultiNodeP2PDisabledFullApiSelfTest.java |  6 ++---
 ...rDisabledMultiNodeWithGroupFullApiSelfTest.java |  6 ++---
 ...rtitionedNearDisabledOnheapFullApiSelfTest.java |  6 ++---
 ...NearDisabledOnheapMultiNodeFullApiSelfTest.java |  6 ++---
 ...nedNearDisabledOptimisticTxNodeRestartTest.java |  6 ++---
 ...arDisabledTxOriginatingNodeFailureSelfTest.java |  6 ++---
 ...onedOnlyP2PDisabledByteArrayValuesSelfTest.java |  6 ++---
 ...ionedOnlyP2PEnabledByteArrayValuesSelfTest.java |  6 ++---
 .../GridCachePartitionedSupplyEventsSelfTest.java  |  6 ++---
 ...GridCachePartitionedTopologyChangeSelfTest.java |  6 ++---
 ...edTransformWriteThroughBatchUpdateSelfTest.java |  6 ++---
 ...artitionedTxOriginatingNodeFailureSelfTest.java |  6 ++---
 .../GridCachePartitionedUnloadEventsSelfTest.java  |  6 ++---
 .../GridCachePartitionsStateValidationTest.java    |  6 ++---
 .../GridCachePartitionsStateValidatorSelfTest.java |  6 ++---
 .../dht/GridCacheTxNodeFailureSelfTest.java        |  6 ++---
 .../IgniteAtomicLongChangingTopologySelfTest.java  |  6 ++---
 .../dht/IgniteCacheClearDuringRebalanceTest.java   |  6 ++---
 .../dht/IgniteCacheCommitDelayTxRecoveryTest.java  |  6 ++---
 .../dht/IgniteCacheConcurrentPutGetRemove.java     |  6 ++---
 .../IgniteCacheContainsKeyColocatedSelfTest.java   |  6 ++---
 .../dht/IgniteCacheCrossCacheTxFailoverTest.java   |  6 ++---
 .../dht/IgniteCacheLockFailoverSelfTest.java       |  6 ++---
 .../dht/IgniteCacheMultiTxLockSelfTest.java        |  6 ++---
 ...hePartitionedBackupNodeFailureRecoveryTest.java |  6 ++---
 ...NearDisabledPrimaryNodeFailureRecoveryTest.java |  6 ++---
 ...ePartitionedPrimaryNodeFailureRecoveryTest.java |  6 ++---
 ...edTwoBackupsPrimaryNodeFailureRecoveryTest.java |  6 ++---
 ...achePrimaryNodeFailureRecoveryAbstractTest.java |  6 ++---
 .../dht/IgniteCachePutRetryAbstractSelfTest.java   |  6 ++---
 .../dht/IgniteCachePutRetryAtomicSelfTest.java     |  6 ++---
 .../IgniteCachePutRetryTransactionalSelfTest.java  |  6 ++---
 .../dht/IgniteCacheStartWithLoadTest.java          |  6 ++---
 .../dht/IgniteCacheTopologySplitAbstractTest.java  |  6 ++---
 .../dht/IgniteCacheTxRecoveryRollbackTest.java     |  6 ++---
 .../dht/IgniteCrossCacheMvccTxSelfTest.java        |  6 ++---
 .../dht/IgniteCrossCacheTxAbstractSelfTest.java    |  6 ++---
 .../dht/IgniteCrossCacheTxNearEnabledSelfTest.java |  6 ++---
 .../dht/IgniteCrossCacheTxSelfTest.java            |  6 ++---
 ...gniteTxConsistencyColocatedRestartSelfTest.java |  6 ++---
 .../dht/IgniteTxReentryColocatedSelfTest.java      |  6 ++---
 .../dht/NotMappedPartitionInTxTest.java            |  6 ++---
 .../dht/TxRecoveryStoreEnabledTest.java            |  6 ++---
 .../atomic/AtomicPutAllChangingTopologyTest.java   |  6 ++---
 ...omicClientInvalidPartitionHandlingSelfTest.java |  6 ++---
 .../GridCacheAtomicClientRemoveFailureTest.java    |  6 ++---
 .../atomic/GridCacheAtomicFailoverSelfTest.java    |  6 ++---
 ...acheAtomicInvalidPartitionHandlingSelfTest.java |  6 ++---
 .../dht/atomic/GridCacheAtomicPreloadSelfTest.java |  6 ++---
 .../atomic/GridCacheAtomicRemoveFailureTest.java   |  6 ++---
 .../GridCacheAtomicReplicatedFailoverSelfTest.java |  6 ++---
 ...eValueConsistencyAtomicNearEnabledSelfTest.java |  6 ++---
 .../GridCacheValueConsistencyAtomicSelfTest.java   |  6 ++---
 .../dht/atomic/IgniteCacheAtomicProtocolTest.java  |  6 ++---
 ...iteCacheContainsKeyColocatedAtomicSelfTest.java |  6 ++---
 .../IgniteCacheContainsKeyNearAtomicSelfTest.java  |  6 ++---
 ...titionedMultiNodeLongTxTimeout2FullApiTest.java |  6 ++---
 ...rtitionedMultiNodeLongTxTimeoutFullApiTest.java |  6 ++---
 ...arEnabledMultiNodeLongTxTimeoutFullApiTest.java |  6 ++---
 ...ractNearPartitionedByteArrayValuesSelfTest.java |  6 ++---
 ...heAtomicClientOnlyMultiNodeFullApiSelfTest.java |  6 ++---
 ...entOnlyMultiNodeP2PDisabledFullApiSelfTest.java |  6 ++---
 ...CopyOnReadDisabledMultiNodeFullApiSelfTest.java |  6 ++---
 .../GridCacheAtomicMultiNodeFullApiSelfTest.java   |  6 ++---
 ...eAtomicMultiNodeP2PDisabledFullApiSelfTest.java |  6 ++---
 ...cheAtomicMultiNodeWithGroupFullApiSelfTest.java |  6 ++---
 ...eAtomicNearEnabledMultiNodeFullApiSelfTest.java |  6 ++---
 ...arEnabledMultiNodeWithGroupFullApiSelfTest.java |  6 ++---
 .../GridCacheAtomicNearEvictionEventSelfTest.java  |  6 ++---
 .../near/GridCacheAtomicNearEvictionSelfTest.java  |  6 ++---
 .../near/GridCacheAtomicNearMultiNodeSelfTest.java |  6 ++---
 ...acheAtomicNearOnlyMultiNodeFullApiSelfTest.java |  6 ++---
 ...earOnlyMultiNodeP2PDisabledFullApiSelfTest.java |  6 ++---
 .../near/GridCacheAtomicNearReadersSelfTest.java   |  6 ++---
 .../near/GridCacheAtomicNearRemoveFailureTest.java |  6 ++---
 .../near/GridCacheAtomicOnheapFullApiSelfTest.java |  6 ++---
 ...dCacheAtomicOnheapMultiNodeFullApiSelfTest.java |  6 ++---
 .../GridCacheAtomicPartitionedMetricsSelfTest.java |  6 ++---
 ...cheAtomicPartitionedTckMetricsSelfTestImpl.java |  6 ++---
 .../near/GridCacheGetStoreErrorSelfTest.java       |  6 ++---
 .../near/GridCacheMvccNearEvictionSelfTest.java    |  6 ++---
 .../near/GridCacheNearAtomicMetricsSelfTest.java   |  6 ++---
 .../near/GridCacheNearClientHitTest.java           |  6 ++---
 .../near/GridCacheNearEvictionEventSelfTest.java   |  6 ++---
 .../near/GridCacheNearEvictionSelfTest.java        |  6 ++---
 .../near/GridCacheNearJobExecutionSelfTest.java    |  6 ++---
 .../near/GridCacheNearMetricsSelfTest.java         |  6 ++---
 .../near/GridCacheNearMultiGetSelfTest.java        |  6 ++---
 .../near/GridCacheNearMultiNodeSelfTest.java       |  6 ++---
 .../near/GridCacheNearOneNodeSelfTest.java         |  6 ++---
 .../GridCacheNearOnlyMultiNodeFullApiSelfTest.java |  6 ++---
 ...earOnlyMultiNodeP2PDisabledFullApiSelfTest.java |  6 ++---
 .../near/GridCacheNearOnlySelfTest.java            |  6 ++---
 .../near/GridCacheNearOnlyTopologySelfTest.java    |  6 ++---
 .../GridCacheNearPartitionedClearSelfTest.java     |  6 ++---
 ...titionedP2PDisabledByteArrayValuesSelfTest.java |  6 ++---
 ...rtitionedP2PEnabledByteArrayValuesSelfTest.java |  6 ++---
 .../near/GridCacheNearPreloadRestartSelfTest.java  |  6 ++---
 .../near/GridCacheNearPrimarySyncSelfTest.java     |  6 ++---
 .../near/GridCacheNearReaderPreloadSelfTest.java   |  6 ++---
 .../near/GridCacheNearReadersSelfTest.java         |  6 ++---
 .../near/GridCacheNearReloadAllSelfTest.java       |  6 ++---
 .../near/GridCacheNearRemoveFailureTest.java       |  6 ++---
 .../near/GridCacheNearTxExceptionSelfTest.java     |  6 ++---
 .../near/GridCacheNearTxForceKeyTest.java          |  6 ++---
 .../near/GridCacheNearTxMultiNodeSelfTest.java     |  6 ++---
 ...xPessimisticOriginatingNodeFailureSelfTest.java |  6 ++---
 .../near/GridCacheNearTxPreloadSelfTest.java       |  6 ++---
 ...nedAffinityExcludeNeighborsPerformanceTest.java |  6 ++---
 .../near/GridCachePartitionedAffinitySelfTest.java |  6 ++---
 ...titionedAtomicGetAndTransformStoreSelfTest.java |  6 ++---
 ...achePartitionedAtomicOnheapFullApiSelfTest.java |  6 ++---
 ...tionedAtomicOnheapMultiNodeFullApiSelfTest.java |  6 ++---
 .../near/GridCachePartitionedBasicApiTest.java     |  6 ++---
 .../near/GridCachePartitionedBasicOpSelfTest.java  |  6 ++---
 ...achePartitionedBasicStoreMultiNodeSelfTest.java |  6 ++---
 .../GridCachePartitionedBasicStoreSelfTest.java    |  6 ++---
 ...titionedClientOnlyNoPrimaryFullApiSelfTest.java |  6 ++---
 ...CopyOnReadDisabledMultiNodeFullApiSelfTest.java |  6 ++---
 .../GridCachePartitionedEntryLockSelfTest.java     |  6 ++---
 .../near/GridCachePartitionedEventSelfTest.java    |  6 ++---
 .../near/GridCachePartitionedEvictionSelfTest.java |  6 ++---
 ...PartitionedExplicitLockNodeFailureSelfTest.java |  6 ++---
 .../near/GridCachePartitionedFailoverSelfTest.java |  6 ++---
 .../GridCachePartitionedFilteredPutSelfTest.java   |  6 ++---
 ...chePartitionedFullApiMultithreadedSelfTest.java |  6 ++---
 .../near/GridCachePartitionedFullApiSelfTest.java  |  6 ++---
 ...chePartitionedGetAndTransformStoreSelfTest.java |  6 ++---
 .../GridCachePartitionedHitsAndMissesSelfTest.java |  6 ++---
 .../GridCachePartitionedIteratorsSelfTest.java     |  6 ++---
 .../GridCachePartitionedLoadCacheSelfTest.java     |  6 ++---
 .../near/GridCachePartitionedLockSelfTest.java     |  6 ++---
 .../near/GridCachePartitionedMetricsSelfTest.java  |  6 ++---
 ...idCachePartitionedMultiNodeCounterSelfTest.java |  6 ++---
 ...idCachePartitionedMultiNodeFullApiSelfTest.java |  6 ++---
 .../GridCachePartitionedMultiNodeLockSelfTest.java |  6 ++---
 ...itionedMultiNodeP2PDisabledFullApiSelfTest.java |  6 ++---
 .../GridCachePartitionedMultiNodeSelfTest.java     |  6 ++---
 ...rtitionedMultiNodeWithGroupFullApiSelfTest.java |  6 ++---
 ...achePartitionedMultiThreadedPutGetSelfTest.java |  6 ++---
 ...achePartitionedMvccTxMultiThreadedSelfTest.java |  6 ++---
 ...chePartitionedMvccTxSingleThreadedSelfTest.java |  6 ++---
 .../GridCachePartitionedMvccTxTimeoutSelfTest.java |  6 ++---
 ...nedNearDisabledBasicStoreMultiNodeSelfTest.java |  6 ++---
 ...artitionedNearOnlyNoPrimaryFullApiSelfTest.java |  6 ++---
 .../near/GridCachePartitionedNestedTxTest.java     |  6 ++---
 .../GridCachePartitionedNodeFailureSelfTest.java   |  6 ++---
 .../near/GridCachePartitionedNodeRestartTest.java  |  6 ++---
 .../GridCachePartitionedOnheapFullApiSelfTest.java |  6 ++---
 ...ePartitionedOnheapMultiNodeFullApiSelfTest.java |  6 ++---
 ...achePartitionedOptimisticTxNodeRestartTest.java |  6 ++---
 ...idCachePartitionedPreloadLifecycleSelfTest.java |  6 ++---
 .../near/GridCachePartitionedStorePutSelfTest.java |  6 ++---
 .../GridCachePartitionedTxConcurrentGetTest.java   |  6 ++---
 .../GridCachePartitionedTxMultiNodeSelfTest.java   |  6 ++---
 ...ridCachePartitionedTxMultiThreadedSelfTest.java |  6 ++---
 .../near/GridCachePartitionedTxReadTest.java       |  6 ++---
 .../GridCachePartitionedTxSalvageSelfTest.java     |  6 ++---
 ...idCachePartitionedTxSingleThreadedSelfTest.java |  6 ++---
 .../GridCachePartitionedTxTimeoutSelfTest.java     |  6 ++---
 .../near/GridCachePutArrayValueSelfTest.java       |  6 ++---
 .../GridCacheRendezvousAffinityClientSelfTest.java |  6 ++---
 .../near/GridNearCacheStoreUpdateTest.java         |  6 ++---
 .../near/GridPartitionedBackupLoadSelfTest.java    |  6 ++---
 .../near/IgniteCacheContainsKeyNearSelfTest.java   |  6 ++---
 .../near/IgniteCacheNearOnlyTxTest.java            |  6 ++---
 .../near/IgniteCacheNearReadCommittedTest.java     |  6 ++---
 .../near/IgniteCacheNearTxRollbackTest.java        |  6 ++---
 .../near/IgniteTxReentryNearSelfTest.java          |  6 ++---
 .../near/NearCacheMultithreadedUpdateTest.java     |  6 ++---
 .../near/NearCachePutAllMultinodeTest.java         |  6 ++---
 .../distributed/near/NearCacheSyncUpdateTest.java  |  6 ++---
 .../near/NoneRebalanceModeSelfTest.java            |  6 ++---
 .../rebalancing/CacheManualRebalancingTest.java    |  6 ++---
 .../rebalancing/CacheNodeSafeAssertion.java        |  6 ++---
 ...lancingDelayedPartitionMapExchangeSelfTest.java |  6 ++---
 .../GridCacheRebalancingAsyncSelfTest.java         |  6 ++---
 .../GridCacheRebalancingCancelTest.java            |  6 ++---
 .../GridCacheRebalancingOrderingTest.java          |  6 ++---
 ...dCacheRebalancingPartitionCountersMvccTest.java |  6 ++---
 .../GridCacheRebalancingPartitionCountersTest.java |  6 ++---
 ...dCacheRebalancingPartitionDistributionTest.java |  6 ++---
 .../GridCacheRebalancingSyncCheckDataTest.java     |  6 ++---
 .../GridCacheRebalancingSyncSelfTest.java          |  6 ++---
 ...acheRebalancingUnmarshallingFailedSelfTest.java |  6 ++---
 ...dCacheRebalancingWithAsyncClearingMvccTest.java |  6 ++---
 .../GridCacheRebalancingWithAsyncClearingTest.java |  6 ++---
 ...eRebalanceOnCachesStoppingOrDestroyingTest.java |  6 ++---
 ...tyExcludeNeighborsMultiNodeFullApiSelfTest.java |  6 ++---
 ...RendezvousAffinityMultiNodeFullApiSelfTest.java |  6 ++---
 ...eAbstractReplicatedByteArrayValuesSelfTest.java |  6 ++---
 .../GridCacheAtomicReplicatedMetricsSelfTest.java  |  6 ++---
 .../GridCacheDaemonNodeReplicatedSelfTest.java     |  6 ++---
 .../GridCacheReplicatedAtomicFullApiSelfTest.java  |  6 ++---
 ...plicatedAtomicGetAndTransformStoreSelfTest.java |  6 ++---
 ...heReplicatedAtomicMultiNodeFullApiSelfTest.java |  6 ++---
 .../GridCacheReplicatedBasicApiTest.java           |  6 ++---
 .../GridCacheReplicatedBasicOpSelfTest.java        |  6 ++---
 .../GridCacheReplicatedBasicStoreSelfTest.java     |  6 ++---
 .../GridCacheReplicatedEntrySetSelfTest.java       |  6 ++---
 .../GridCacheReplicatedEventDisabledSelfTest.java  |  6 ++---
 .../GridCacheReplicatedEventSelfTest.java          |  6 ++---
 .../GridCacheReplicatedEvictionEventSelfTest.java  |  6 ++---
 .../GridCacheReplicatedFailoverSelfTest.java       |  6 ++---
 ...acheReplicatedFullApiMultithreadedSelfTest.java |  6 ++---
 .../GridCacheReplicatedFullApiSelfTest.java        |  6 ++---
 ...acheReplicatedGetAndTransformStoreSelfTest.java |  6 ++---
 .../GridCacheReplicatedIteratorsSelfTest.java      |  6 ++---
 .../GridCacheReplicatedJobExecutionTest.java       |  6 ++---
 .../GridCacheReplicatedLockSelfTest.java           |  6 ++---
 .../GridCacheReplicatedMarshallerTxTest.java       |  6 ++---
 .../GridCacheReplicatedMetricsSelfTest.java        |  6 ++---
 ...ridCacheReplicatedMultiNodeFullApiSelfTest.java |  6 ++---
 .../GridCacheReplicatedMultiNodeLockSelfTest.java  |  6 ++---
 ...licatedMultiNodeP2PDisabledFullApiSelfTest.java |  6 ++---
 .../GridCacheReplicatedMultiNodeSelfTest.java      |  6 ++---
 ...CacheReplicatedMvccTxMultiThreadedSelfTest.java |  6 ++---
 ...acheReplicatedMvccTxSingleThreadedSelfTest.java |  6 ++---
 .../GridCacheReplicatedMvccTxTimeoutSelfTest.java  |  6 ++---
 ...ReplicatedNearOnlyMultiNodeFullApiSelfTest.java |  6 ++---
 .../GridCacheReplicatedNodeFailureSelfTest.java    |  6 ++---
 .../GridCacheReplicatedNodeRestartSelfTest.java    |  6 ++---
 .../GridCacheReplicatedOnheapFullApiSelfTest.java  |  6 ++---
 ...heReplicatedOnheapMultiNodeFullApiSelfTest.java |  6 ++---
 ...plicatedP2PDisabledByteArrayValuesSelfTest.java |  6 ++---
 ...eplicatedP2PEnabledByteArrayValuesSelfTest.java |  6 ++---
 .../GridCacheReplicatedPreloadEventsSelfTest.java  |  6 ++---
 .../GridCacheReplicatedTxConcurrentGetTest.java    |  6 ++---
 .../GridCacheReplicatedTxExceptionSelfTest.java    |  6 ++---
 .../GridCacheReplicatedTxMultiNodeBasicTest.java   |  6 ++---
 ...GridCacheReplicatedTxMultiThreadedSelfTest.java |  6 ++---
 ...ReplicatedTxOriginatingNodeFailureSelfTest.java |  6 ++---
 ...xPessimisticOriginatingNodeFailureSelfTest.java |  6 ++---
 .../replicated/GridCacheReplicatedTxReadTest.java  |  6 ++---
 ...ridCacheReplicatedTxSingleThreadedSelfTest.java |  6 ++---
 .../GridCacheReplicatedTxTimeoutSelfTest.java      |  6 ++---
 .../GridCacheSyncReplicatedPreloadSelfTest.java    |  6 ++---
 .../replicated/GridReplicatedTxPreloadTest.java    |  6 ++---
 ...teCacheAtomicReplicatedNodeRestartSelfTest.java |  6 ++---
 .../IgniteCacheSyncRebalanceModeSelfTest.java      |  6 ++---
 ...ridCacheReplicatedPreloadLifecycleSelfTest.java |  6 ++---
 .../GridCacheReplicatedPreloadSelfTest.java        |  6 ++---
 ...heReplicatedPreloadStartStopEventsSelfTest.java |  6 ++---
 .../GridCacheReplicatedPreloadUndeploysTest.java   |  6 ++---
 .../cache/eviction/DhtAndNearEvictionTest.java     |  6 ++---
 .../cache/eviction/EvictionAbstractTest.java       |  6 ++---
 .../EvictionPolicyFactoryAbstractTest.java         |  6 ++---
 ...CacheConcurrentEvictionConsistencySelfTest.java |  6 ++---
 .../GridCacheConcurrentEvictionsSelfTest.java      |  6 ++---
 .../GridCacheEmptyEntriesAbstractSelfTest.java     |  6 ++---
 .../GridCacheEmptyEntriesLocalSelfTest.java        |  6 ++---
 .../GridCacheEmptyEntriesPartitionedSelfTest.java  |  6 ++---
 .../GridCacheEvictableEntryEqualsSelfTest.java     |  6 ++---
 .../eviction/GridCacheEvictionFilterSelfTest.java  |  6 ++---
 .../GridCacheEvictionLockUnlockSelfTest.java       |  6 ++---
 .../eviction/GridCacheEvictionTouchSelfTest.java   |  6 ++---
 .../cache/eviction/GridCacheMockEntry.java         |  6 ++---
 .../fifo/FifoEvictionPolicyFactorySelfTest.java    |  6 ++---
 .../eviction/fifo/FifoEvictionPolicySelfTest.java  |  6 ++---
 .../lru/LruEvictionPolicyFactorySelfTest.java      |  6 ++---
 .../eviction/lru/LruEvictionPolicySelfTest.java    |  6 ++---
 .../lru/LruNearEvictionPolicySelfTest.java         |  6 ++---
 .../lru/LruNearOnlyNearEvictionPolicySelfTest.java |  6 ++---
 .../eviction/paged/PageEvictionAbstractTest.java   |  6 ++---
 .../paged/PageEvictionDataStreamerTest.java        |  6 ++---
 .../eviction/paged/PageEvictionMetricTest.java     |  6 ++---
 .../paged/PageEvictionMultinodeAbstractTest.java   |  6 ++---
 .../PageEvictionMultinodeMixedRegionsTest.java     |  6 ++---
 .../PageEvictionPagesRecyclingAndReusingTest.java  |  6 ++---
 .../paged/PageEvictionReadThroughTest.java         |  6 ++---
 .../eviction/paged/PageEvictionTouchOrderTest.java |  6 ++---
 .../PageEvictionWithRebalanceAbstractTest.java     |  6 ++---
 ...om2LruNearEnabledPageEvictionMultinodeTest.java |  6 ++---
 .../paged/Random2LruPageEvictionMultinodeTest.java |  6 ++---
 .../Random2LruPageEvictionWithRebalanceTest.java   |  6 ++---
 ...domLruNearEnabledPageEvictionMultinodeTest.java |  6 ++---
 .../paged/RandomLruPageEvictionMultinodeTest.java  |  6 ++---
 .../RandomLruPageEvictionWithRebalanceTest.java    |  6 ++---
 .../cache/eviction/paged/TestObject.java           |  6 ++---
 .../SortedEvictionPolicyFactorySelfTest.java       |  6 ++---
 .../SortedEvictionPolicyPerformanceTest.java       |  6 ++---
 .../sorted/SortedEvictionPolicySelfTest.java       |  6 ++---
 .../expiry/IgniteCacheAtomicExpiryPolicyTest.java  |  6 ++---
 ...IgniteCacheAtomicExpiryPolicyWithStoreTest.java |  6 ++---
 .../IgniteCacheAtomicLocalExpiryPolicyTest.java    |  6 ++---
 ...niteCacheAtomicLocalOnheapExpiryPolicyTest.java |  6 ++---
 .../IgniteCacheAtomicOnheapExpiryPolicyTest.java   |  6 ++---
 ...gniteCacheAtomicReplicatedExpiryPolicyTest.java |  6 ++---
 ...IgniteCacheAtomicWithStoreExpiryPolicyTest.java |  6 ++---
 .../IgniteCacheClientNearCacheExpiryTest.java      |  6 ++---
 .../IgniteCacheExpireWhileRebalanceTest.java       |  6 ++---
 .../IgniteCacheExpiryPolicyAbstractTest.java       |  6 ++---
 .../expiry/IgniteCacheExpiryPolicyTestSuite.java   |  6 ++---
 ...niteCacheExpiryPolicyWithStoreAbstractTest.java |  6 ++---
 .../expiry/IgniteCacheLargeValueExpireTest.java    |  6 ++---
 ...niteCacheOnlyOneTtlCleanupThreadExistsTest.java |  6 ++---
 .../expiry/IgniteCacheTxExpiryPolicyTest.java      |  6 ++---
 .../IgniteCacheTxExpiryPolicyWithStoreTest.java    |  6 ++---
 .../expiry/IgniteCacheTxLocalExpiryPolicyTest.java |  6 ++---
 .../IgniteCacheTxReplicatedExpiryPolicyTest.java   |  6 ++---
 .../IgniteCacheTxWithStoreExpiryPolicyTest.java    |  6 ++---
 .../integration/IgniteCacheAtomicLoadAllTest.java  |  6 ++---
 .../IgniteCacheAtomicLoaderWriterTest.java         |  6 ++---
 .../IgniteCacheAtomicLocalLoadAllTest.java         |  6 ++---
 ...iteCacheAtomicLocalNoLoadPreviousValueTest.java |  6 ++---
 .../IgniteCacheAtomicLocalNoReadThroughTest.java   |  6 ++---
 .../IgniteCacheAtomicLocalNoWriteThroughTest.java  |  6 ++---
 ...heAtomicNearEnabledNoLoadPreviousValueTest.java |  6 ++---
 ...iteCacheAtomicNearEnabledNoReadThroughTest.java |  6 ++---
 ...teCacheAtomicNearEnabledNoWriteThroughTest.java |  6 ++---
 .../IgniteCacheAtomicNoLoadPreviousValueTest.java  |  6 ++---
 .../IgniteCacheAtomicNoReadThroughTest.java        |  6 ++---
 .../IgniteCacheAtomicNoWriteThroughTest.java       |  6 ++---
 .../IgniteCacheAtomicStoreSessionTest.java         |  6 ++---
 ...niteCacheAtomicStoreSessionWriteBehindTest.java |  6 ++---
 .../IgniteCacheJdbcBlobStoreNodeRestartTest.java   |  6 ++---
 .../IgniteCacheLoadAllAbstractTest.java            |  6 ++---
 .../IgniteCacheLoaderWriterAbstractTest.java       |  6 ++---
 ...IgniteCacheNoLoadPreviousValueAbstractTest.java |  6 ++---
 .../IgniteCacheNoReadThroughAbstractTest.java      |  6 ++---
 .../IgniteCacheNoWriteThroughAbstractTest.java     |  6 ++---
 .../IgniteCacheStoreNodeRestartAbstractTest.java   |  6 ++---
 .../IgniteCacheStoreSessionAbstractTest.java       |  6 ++---
 ...teCacheStoreSessionWriteBehindAbstractTest.java |  6 ++---
 .../integration/IgniteCacheTxLoadAllTest.java      |  6 ++---
 .../integration/IgniteCacheTxLoaderWriterTest.java |  6 ++---
 .../integration/IgniteCacheTxLocalLoadAllTest.java |  6 ++---
 .../IgniteCacheTxLocalNoLoadPreviousValueTest.java |  6 ++---
 .../IgniteCacheTxLocalNoReadThroughTest.java       |  6 ++---
 .../IgniteCacheTxLocalNoWriteThroughTest.java      |  6 ++---
 ...eCacheTxNearEnabledNoLoadPreviousValueTest.java |  6 ++---
 .../IgniteCacheTxNearEnabledNoReadThroughTest.java |  6 ++---
 ...IgniteCacheTxNearEnabledNoWriteThroughTest.java |  6 ++---
 .../IgniteCacheTxNoLoadPreviousValueTest.java      |  6 ++---
 .../IgniteCacheTxNoReadThroughTest.java            |  6 ++---
 .../IgniteCacheTxNoWriteThroughTest.java           |  6 ++---
 .../integration/IgniteCacheTxStoreSessionTest.java |  6 ++---
 ...cheTxStoreSessionWriteBehindCoalescingTest.java |  6 ++---
 .../IgniteCacheTxStoreSessionWriteBehindTest.java  |  6 ++---
 ...GridCacheAtomicLocalMetricsNoStoreSelfTest.java |  6 ++---
 .../local/GridCacheAtomicLocalMetricsSelfTest.java |  6 ++---
 ...GridCacheAtomicLocalTckMetricsSelfTestImpl.java |  6 ++---
 .../local/GridCacheDaemonNodeLocalSelfTest.java    |  6 ++---
 .../GridCacheLocalAtomicBasicStoreSelfTest.java    |  6 ++---
 .../local/GridCacheLocalAtomicFullApiSelfTest.java |  6 ++---
 ...cheLocalAtomicGetAndTransformStoreSelfTest.java |  6 ++---
 ...cheLocalAtomicMetricsNoReadThroughSelfTest.java |  6 ++---
 ...idCacheLocalAtomicWithGroupFullApiSelfTest.java |  6 ++---
 .../local/GridCacheLocalBasicApiSelfTest.java      |  6 ++---
 ...dCacheLocalBasicStoreMultithreadedSelfTest.java |  6 ++---
 .../local/GridCacheLocalBasicStoreSelfTest.java    |  6 ++---
 .../GridCacheLocalByteArrayValuesSelfTest.java     |  6 ++---
 .../cache/local/GridCacheLocalEventSelfTest.java   |  6 ++---
 .../local/GridCacheLocalEvictionEventSelfTest.java |  6 ++---
 ...GridCacheLocalFullApiMultithreadedSelfTest.java |  6 ++---
 .../cache/local/GridCacheLocalFullApiSelfTest.java |  6 ++---
 ...GridCacheLocalGetAndTransformStoreSelfTest.java |  6 ++---
 .../local/GridCacheLocalIsolatedNodesSelfTest.java |  6 ++---
 .../local/GridCacheLocalIteratorsSelfTest.java     |  6 ++---
 .../cache/local/GridCacheLocalLoadAllSelfTest.java |  6 ++---
 .../cache/local/GridCacheLocalLockSelfTest.java    |  6 ++---
 .../cache/local/GridCacheLocalMetricsSelfTest.java |  6 ++---
 .../local/GridCacheLocalMultithreadedSelfTest.java |  6 ++---
 .../local/GridCacheLocalTxExceptionSelfTest.java   |  6 ++---
 .../GridCacheLocalTxMultiThreadedSelfTest.java     |  6 ++---
 .../cache/local/GridCacheLocalTxReadTest.java      |  6 ++---
 .../GridCacheLocalTxSingleThreadedSelfTest.java    |  6 ++---
 .../local/GridCacheLocalTxTimeoutSelfTest.java     |  6 ++---
 .../GridCacheLocalWithGroupFullApiSelfTest.java    |  6 ++---
 ...cheAtomicClientOnlyMultiJvmFullApiSelfTest.java |  6 ++---
 ...ientOnlyMultiJvmP2PDisabledFullApiSelfTest.java |  6 ++---
 ...cCopyOnReadDisabledMultiJvmFullApiSelfTest.java |  6 ++---
 .../GridCacheAtomicMultiJvmFullApiSelfTest.java    |  6 ++---
 ...heAtomicMultiJvmP2PDisabledFullApiSelfTest.java |  6 ++---
 ...heAtomicNearEnabledMultiJvmFullApiSelfTest.java |  6 ++---
 ...CacheAtomicNearOnlyMultiJvmFullApiSelfTest.java |  6 ++---
 ...NearOnlyMultiJvmP2PDisabledFullApiSelfTest.java |  6 ++---
 ...idCacheAtomicOnheapMultiJvmFullApiSelfTest.java |  6 ++---
 .../GridCacheNearOnlyMultiJvmFullApiSelfTest.java  |  6 ++---
 ...NearOnlyMultiJvmP2PDisabledFullApiSelfTest.java |  6 ++---
 ...dCopyOnReadDisabledMultiJvmFullApiSelfTest.java |  6 ++---
 ...ridCachePartitionedMultiJvmFullApiSelfTest.java |  6 ++---
 ...titionedMultiJvmP2PDisabledFullApiSelfTest.java |  6 ++---
 ...isabledAtomicOnheapMultiJvmFullApiSelfTest.java |  6 ++---
 ...itionedNearDisabledMultiJvmFullApiSelfTest.java |  6 ++---
 ...DisabledMultiJvmP2PDisabledFullApiSelfTest.java |  6 ++---
 ...dNearDisabledOnheapMultiJvmFullApiSelfTest.java |  6 ++---
 ...hePartitionedOnheapMultiJvmFullApiSelfTest.java |  6 ++---
 ...cheReplicatedAtomicMultiJvmFullApiSelfTest.java |  6 ++---
 ...GridCacheReplicatedMultiJvmFullApiSelfTest.java |  6 ++---
 ...plicatedMultiJvmP2PDisabledFullApiSelfTest.java |  6 ++---
 ...eReplicatedNearOnlyMultiJvmFullApiSelfTest.java |  6 ++---
 ...cheReplicatedOnheapMultiJvmFullApiSelfTest.java |  6 ++---
 ...heMvccAbstractBasicCoordinatorFailoverTest.java |  6 ++---
 .../CacheMvccAbstractCoordinatorFailoverTest.java  |  6 ++---
 .../cache/mvcc/CacheMvccAbstractFeatureTest.java   |  6 ++---
 .../cache/mvcc/CacheMvccAbstractTest.java          |  6 ++---
 .../cache/mvcc/CacheMvccClientReconnectTest.java   |  6 ++---
 .../cache/mvcc/CacheMvccClusterRestartTest.java    |  6 ++---
 .../mvcc/CacheMvccConfigurationValidationTest.java |  6 ++---
 ...eMvccIteratorWithConcurrentTransactionTest.java |  6 ++---
 ...cLocalEntriesWithConcurrentTransactionTest.java |  6 ++---
 .../cache/mvcc/CacheMvccOperationChecksTest.java   |  6 ++---
 ...acheMvccPartitionedCoordinatorFailoverTest.java |  6 ++---
 .../mvcc/CacheMvccProcessorLazyStartTest.java      |  6 ++---
 .../cache/mvcc/CacheMvccProcessorTest.java         |  6 ++---
 .../mvcc/CacheMvccRemoteTxOnNearNodeStartTest.java |  6 ++---
 ...CacheMvccReplicatedCoordinatorFailoverTest.java |  6 ++---
 ...MvccScanQueryWithConcurrentTransactionTest.java |  6 ++---
 ...CacheMvccSizeWithConcurrentTransactionTest.java |  6 ++---
 .../cache/mvcc/CacheMvccTransactionsTest.java      |  6 ++---
 .../cache/mvcc/CacheMvccTxFailoverTest.java        |  6 ++---
 .../processors/cache/mvcc/CacheMvccVacuumTest.java |  6 ++---
 .../processors/cache/mvcc/MvccCachePeekTest.java   |  6 ++---
 .../cache/mvcc/MvccUnsupportedTxModesTest.java     |  6 ++---
 .../persistence/CheckpointReadLockFailureTest.java |  6 ++---
 .../persistence/CleanupRestoredCachesSlowTest.java |  6 ++---
 .../CommonPoolStarvationCheckpointTest.java        |  6 ++---
 .../processors/cache/persistence/DummyPageIO.java  |  6 ++---
 ...niteBaselineAffinityTopologyActivationTest.java |  6 ++---
 .../IgniteDataStorageMetricsSelfTest.java          |  6 ++---
 ...itePdsAtomicCacheHistoricalRebalancingTest.java |  6 ++---
 .../IgnitePdsAtomicCacheRebalancingTest.java       |  6 ++---
 ...gnitePdsBinaryMetadataOnClusterRestartTest.java |  6 ++---
 .../IgnitePdsBinarySortObjectFieldsTest.java       |  6 ++---
 .../IgnitePdsCacheAssignmentNodeRestartsTest.java  |  6 ++---
 ...CacheConfigurationFileConsistencyCheckTest.java |  6 ++---
 ...sCacheObjectBinaryProcessorOnDiscoveryTest.java |  6 ++---
 .../IgnitePdsCacheRebalancingAbstractTest.java     |  6 ++---
 ...itePdsCacheStartStopWithFreqCheckpointTest.java |  6 ++---
 .../IgnitePdsClientNearCachePutGetTest.java        |  6 ++---
 .../IgnitePdsContinuousRestartTest.java            |  6 ++---
 ...tePdsContinuousRestartTestWithExpiryPolicy.java |  6 ++---
 ...inuousRestartTestWithSharedGroupAndIndexes.java |  6 ++---
 .../persistence/IgnitePdsCorruptedIndexTest.java   |  6 ++---
 .../persistence/IgnitePdsCorruptedStoreTest.java   |  6 ++---
 .../IgnitePdsDestroyCacheAbstractTest.java         |  6 ++---
 .../persistence/IgnitePdsDestroyCacheTest.java     |  6 ++---
 ...gnitePdsDestroyCacheWithoutCheckpointsTest.java |  6 ++---
 ...IgnitePdsDiscoDataHandlingInNewClusterTest.java |  6 ++---
 .../persistence/IgnitePdsDynamicCacheTest.java     |  6 ++---
 .../IgnitePdsExchangeDuringCheckpointTest.java     |  6 ++---
 ...PdsMarshallerMappingRestoreOnNodeStartTest.java |  6 ++---
 .../IgnitePdsNoSpaceLeftOnDeviceTest.java          |  6 ++---
 .../IgnitePdsNodeJoinWithCachesStopping.java       |  6 ++---
 .../cache/persistence/IgnitePdsPageSizesTest.java  |  6 ++---
 .../IgnitePdsPartitionFilesDestroyTest.java        |  6 ++---
 .../IgnitePdsPartitionsStateRecoveryTest.java      |  6 ++---
 .../IgnitePdsRecoveryAfterFileCorruptionTest.java  |  6 ++---
 .../IgnitePdsRemoveDuringRebalancingTest.java      |  6 ++---
 .../IgnitePdsSingleNodePutGetPersistenceTest.java  |  6 ++---
 .../IgnitePdsSporadicDataRecordsOnBackupTest.java  |  6 ++---
 .../persistence/IgnitePdsTaskCancelingTest.java    |  6 ++---
 .../IgnitePdsTxCacheRebalancingTest.java           |  6 ++---
 .../IgnitePdsTxHistoricalRebalancingTest.java      |  6 ++---
 .../IgnitePersistenceSequentialCheckpointTest.java |  6 ++---
 .../IgnitePersistentStoreCacheGroupsTest.java      |  6 ++---
 .../IgnitePersistentStoreDataStructuresTest.java   |  6 ++---
 ...gniteRebalanceScheduleResendPartitionsTest.java |  6 ++---
 ...ocalWalModeChangeDuringRebalancingSelfTest.java |  6 ++---
 ...NoChangeDuringRebalanceOnNonNodeAssignTest.java |  6 ++---
 .../MemoryPolicyInitializationTest.java            |  6 ++---
 .../PersistenceDirectoryWarningLoggingTest.java    |  6 ++---
 .../persistence/SingleNodePersistenceSslTest.java  |  6 ++---
 .../ClientAffinityAssignmentWithBaselineTest.java  |  6 ++---
 .../baseline/ClusterActivationEventTest.java       |  6 ++---
 .../IgniteAbsentEvictionNodeOutOfBaselineTest.java |  6 ++---
 ...gniteAllBaselineNodesOnlineFullApiSelfTest.java |  6 ++---
 .../IgniteBaselineAbstractFullApiSelfTest.java     |  6 ++---
 ...hangingBaselineDownCachePutAllFailoverTest.java |  6 ++---
 ...hangingBaselineDownCacheRemoveFailoverTest.java |  6 ++---
 ...eChangingBaselineUpCachePutAllFailoverTest.java |  6 ++---
 ...eChangingBaselineUpCacheRemoveFailoverTest.java |  6 ++---
 .../IgniteOfflineBaselineNodeFullApiSelfTest.java  |  6 ++---
 ...niteOnlineNodeOutOfBaselineFullApiSelfTest.java |  6 ++---
 ...gniteStableBaselineCachePutAllFailoverTest.java |  6 ++---
 ...gniteStableBaselineCacheRemoveFailoverTest.java |  6 ++---
 .../db/CheckpointBufferDeadlockTest.java           |  6 ++---
 .../persistence/db/CheckpointFailingIoFactory.java |  6 ++---
 .../persistence/db/IgniteLogicalRecoveryTest.java  |  6 ++---
 .../persistence/db/IgnitePdsCacheRestoreTest.java  |  6 ++---
 ...IgnitePdsCacheWalDisabledOnRebalancingTest.java |  6 ++---
 .../db/IgnitePdsDataRegionMetricsTest.java         |  6 ++---
 .../db/IgnitePdsMultiNodePutGetRestartTest.java    |  6 ++---
 ...itePdsPageEvictionDuringPartitionClearTest.java |  6 ++---
 .../persistence/db/IgnitePdsPageEvictionTest.java  |  6 ++---
 .../db/IgnitePdsPartitionPreloadTest.java          |  6 ++---
 ...gnitePdsRebalancingOnNotStableTopologyTest.java |  6 ++---
 .../db/IgnitePdsReserveWalSegmentsTest.java        |  6 ++---
 ...itePdsReserveWalSegmentsWithCompactionTest.java |  6 ++---
 .../db/IgnitePdsStartWIthEmptyArchive.java         |  6 ++---
 .../db/IgnitePdsTransactionsHangTest.java          |  6 ++---
 .../db/IgnitePdsWholeClusterRestartTest.java       |  6 ++---
 .../cache/persistence/db/IgnitePdsWithTtlTest.java |  6 ++---
 .../persistence/db/IgnitePdsWithTtlTest2.java      |  6 ++---
 .../db/IgniteSequentialNodeCrashRecoveryTest.java  |  6 ++---
 .../IgniteShutdownOnSupplyMessageFailureTest.java  |  6 ++---
 .../SlowHistoricalRebalanceSmallHistoryTest.java   |  6 ++---
 .../db/checkpoint/CheckpointFreeListTest.java      |  6 ++---
 .../IgniteCheckpointDirtyPagesForLowLoadTest.java  |  6 ++---
 .../db/checkpoint/IgniteMassLoadSandboxTest.java   |  6 ++---
 .../db/checkpoint/ProgressWatchdog.java            |  6 ++---
 .../DefaultPageSizeBackwardsCompatibilityTest.java |  6 ++---
 .../IgnitePdsCacheDestroyDuringCheckpointTest.java |  6 ++---
 .../db/file/IgnitePdsCacheIntegrationTest.java     |  6 ++---
 .../db/file/IgnitePdsCheckpointSimpleTest.java     |  6 ++---
 ...CheckpointSimulationWithRealCpDisabledTest.java |  6 ++---
 .../db/file/IgnitePdsDiskErrorsRecoveringTest.java |  6 ++---
 .../db/file/IgnitePdsNoActualWalHistoryTest.java   |  6 ++---
 .../db/file/IgnitePdsPageReplacementTest.java      |  6 ++---
 .../db/file/IgnitePdsThreadInterruptionTest.java   |  6 ++---
 .../IgniteUidAsConsistentIdMigrationTest.java      |  6 ++---
 .../db/wal/FsyncWalRolloverDoesNotBlockTest.java   |  6 ++---
 .../wal/IgniteNodeStoppedDuringDisableWALTest.java |  6 ++---
 ...ailIsReachedDuringIterationOverArchiveTest.java |  6 ++---
 .../db/wal/IgniteWalFlushBackgroundSelfTest.java   |  6 ++---
 ...teWalFlushBackgroundWithMmapBufferSelfTest.java |  6 ++---
 .../db/wal/IgniteWalFlushFailoverTest.java         |  6 ++---
 .../db/wal/IgniteWalFlushFsyncSelfTest.java        |  6 ++---
 ...teWalFlushFsyncWithDedicatedWorkerSelfTest.java |  6 ++---
 .../IgniteWalFlushFsyncWithMmapBufferSelfTest.java |  6 ++---
 .../db/wal/IgniteWalFlushLogOnlySelfTest.java      |  6 ++---
 ...gniteWalFlushLogOnlyWithMmapBufferSelfTest.java |  6 ++---
 ...eWalFlushMultiNodeFailoverAbstractSelfTest.java |  6 ++---
 .../db/wal/IgniteWalFormatFileFailoverTest.java    |  6 ++---
 .../db/wal/IgniteWalHistoryReservationsTest.java   |  6 ++---
 .../IgniteWalIteratorExceptionDuringReadTest.java  |  6 ++---
 .../db/wal/IgniteWalIteratorSwitchSegmentTest.java |  6 ++---
 .../persistence/db/wal/IgniteWalRebalanceTest.java |  6 ++---
 .../db/wal/IgniteWalRecoveryPPCTest.java           |  6 ++---
 .../wal/IgniteWalRecoverySeveralRestartsTest.java  |  6 ++---
 .../db/wal/IgniteWalSerializerVersionTest.java     |  6 ++---
 .../db/wal/WalCompactionAfterRestartTest.java      |  6 ++---
 .../db/wal/WalCompactionSwitchOnTest.java          |  6 ++---
 .../persistence/db/wal/WalCompactionTest.java      |  6 ++---
 .../db/wal/WalDeletionArchiveAbstractTest.java     |  6 ++---
 .../db/wal/WalDeletionArchiveFsyncTest.java        |  6 ++---
 .../db/wal/WalDeletionArchiveLogOnlyTest.java      |  6 ++---
 .../cache/persistence/db/wal/WalPathsTest.java     |  6 ++---
 .../db/wal/WalRecoveryTxLogicalRecordsTest.java    |  6 ++---
 .../db/wal/WalRolloverRecordLoggingFsyncTest.java  |  6 ++---
 .../wal/WalRolloverRecordLoggingLogOnlyTest.java   |  6 ++---
 .../db/wal/WalRolloverRecordLoggingTest.java       |  6 ++---
 .../persistence/db/wal/WalRolloverTypesTest.java   |  6 ++---
 .../IgniteAbstractWalIteratorInvalidCrcTest.java   |  6 ++---
 .../db/wal/crc/IgniteDataIntegrityTests.java       |  6 ++---
 ...IgniteFsyncReplayWalIteratorInvalidCrcTest.java |  6 ++---
 .../db/wal/crc/IgnitePureJavaCrcCompatibility.java |  6 ++---
 .../crc/IgniteReplayWalIteratorInvalidCrcTest.java |  6 ++---
 .../IgniteStandaloneWalIteratorInvalidCrcTest.java |  6 ++---
 ...teWithoutArchiverWalIteratorInvalidCrcTest.java |  6 ++---
 .../cache/persistence/db/wal/crc/WalTestUtils.java |  6 ++---
 .../db/wal/reader/IgniteWalReaderTest.java         |  6 ++---
 .../persistence/db/wal/reader/IndexedObject.java   |  6 ++---
 .../db/wal/reader/MockWalIteratorFactory.java      |  6 ++---
 .../cache/persistence/file/FileDownloaderTest.java |  6 ++---
 .../metastorage/IgniteMetaStorageBasicTest.java    |  6 ++---
 .../pagemem/BPlusTreePageMemoryImplTest.java       |  6 ++---
 .../BPlusTreeReuseListPageMemoryImplTest.java      |  6 ++---
 .../persistence/pagemem/FillFactorMetricTest.java  |  6 ++---
 .../persistence/pagemem/FullPageIdTableTest.java   |  6 ++---
 .../IgnitePageMemReplaceDelayedWriteUnitTest.java  |  6 ++---
 .../pagemem/IgniteThrottlingUnitTest.java          |  6 ++---
 .../pagemem/IndexStoragePageMemoryImplTest.java    |  6 ++---
 .../persistence/pagemem/NoOpPageStoreManager.java  |  6 ++---
 .../cache/persistence/pagemem/NoOpWALManager.java  |  6 ++---
 .../pagemem/PageIdDistributionTest.java            |  6 ++---
 .../pagemem/PageMemoryImplNoLoadTest.java          |  6 ++---
 .../persistence/pagemem/PageMemoryImplTest.java    |  6 ++---
 .../pagemem/PageMemoryLazyAllocationTest.java      |  6 ++---
 .../PageMemoryLazyAllocationWithPDSTest.java       |  6 ++---
 .../pagemem/PageMemoryNoStoreLeakTest.java         |  6 ++---
 .../pagemem/PagesWriteThrottleSandboxTest.java     |  6 ++---
 .../pagemem/PagesWriteThrottleSmokeTest.java       |  6 ++---
 .../pagemem/RobinHoodBackwardShiftHashMapTest.java |  6 ++---
 .../pagemem/UsedPagesMetricAbstractTest.java       |  6 ++---
 .../persistence/pagemem/UsedPagesMetricTest.java   |  6 ++---
 .../pagemem/UsedPagesMetricTestPersistence.java    |  6 ++---
 .../standbycluster/AbstractNodeJoinTemplate.java   |  6 ++---
 .../IgniteChangeGlobalStateAbstractTest.java       |  6 ++---
 .../IgniteChangeGlobalStateCacheTest.java          |  6 ++---
 .../IgniteChangeGlobalStateDataStreamerTest.java   |  6 ++---
 .../IgniteChangeGlobalStateDataStructureTest.java  |  6 ++---
 .../IgniteChangeGlobalStateFailOverTest.java       |  6 ++---
 .../IgniteChangeGlobalStateServiceTest.java        |  6 ++---
 .../IgniteChangeGlobalStateTest.java               |  6 ++---
 .../IgniteNoParrallelClusterIsAllowedTest.java     |  6 ++---
 .../standbycluster/IgniteStandByClusterTest.java   |  6 ++---
 .../extended/GridActivateExtensionTest.java        |  6 ++---
 .../join/JoinActiveNodeToActiveCluster.java        |  6 ++---
 .../join/JoinActiveNodeToInActiveCluster.java      |  6 ++---
 .../join/JoinInActiveNodeToActiveCluster.java      |  6 ++---
 .../join/JoinInActiveNodeToInActiveCluster.java    |  6 ++---
 ...inActiveNodeToActiveClusterWithPersistence.java |  6 ++---
 ...ActiveNodeToInActiveClusterWithPersistence.java |  6 ++---
 ...InActiveNodeToActiveClusterWithPersistence.java |  6 ++---
 ...ActiveNodeToInActiveClusterWithPersistence.java |  6 ++---
 .../IgniteAbstractStandByClientReconnectTest.java  |  6 ++---
 .../IgniteStandByClientReconnectTest.java          |  6 ++---
 ...niteStandByClientReconnectToNewClusterTest.java |  6 ++---
 .../persistence/tree/io/TrackingPageIOTest.java    |  6 ++---
 .../wal/AbstractWalDeltaConsistencyTest.java       |  6 ++---
 .../wal/CpTriggeredWalDeltaConsistencyTest.java    |  6 ++---
 .../wal/ExplicitWalDeltaConsistencyTest.java       |  6 ++---
 .../wal/SegmentedRingByteBufferTest.java           |  6 ++---
 .../wal/SysPropWalDeltaConsistencyTest.java        |  6 ++---
 .../persistence/wal/aware/SegmentAwareTest.java    |  6 ++---
 .../wal/memtracker/PageMemoryTracker.java          |  6 ++---
 .../memtracker/PageMemoryTrackerConfiguration.java |  6 ++---
 .../PageMemoryTrackerPluginProvider.java           |  6 ++---
 .../reader/StandaloneWalRecordsIteratorTest.java   |  6 ++---
 .../cache/query/CacheDataPageScanQueryTest.java    |  6 ++---
 .../cache/query/CacheScanQueryFailoverTest.java    |  6 ++---
 .../query/GridCacheQueryTransformerSelfTest.java   |  6 ++---
 .../cache/query/GridCircularQueueTest.java         |  6 ++---
 .../IgniteCacheQueryCacheDestroySelfTest.java      |  6 ++---
 .../cache/query/IndexingSpiQuerySelfTest.java      |  6 ++---
 .../cache/query/IndexingSpiQueryTxSelfTest.java    |  6 ++---
 .../IndexingSpiQueryWithH2IndexingSelfTest.java    |  6 ++---
 .../ScanQueryOffheapExpiryPolicySelfTest.java      |  6 ++---
 .../continuous/CacheContinuousBatchAckTest.java    |  6 ++---
 ...CacheContinuousBatchForceServerModeAckTest.java |  6 ++---
 ...ContinuousQueryAsyncFailoverAtomicSelfTest.java |  6 ++---
 ...ContinuousQueryAsyncFailoverMvccTxSelfTest.java |  6 ++---
 ...uousQueryAsyncFailoverTxReplicatedSelfTest.java |  6 ++---
 ...acheContinuousQueryAsyncFailoverTxSelfTest.java |  6 ++---
 ...acheContinuousQueryAsyncFilterListenerTest.java |  6 ++---
 ...ntinuousQueryConcurrentPartitionUpdateTest.java |  6 ++---
 .../CacheContinuousQueryCounterAbstractTest.java   |  6 ++---
 ...ontinuousQueryCounterPartitionedAtomicTest.java |  6 ++---
 ...cheContinuousQueryCounterPartitionedTxTest.java |  6 ++---
 ...ContinuousQueryCounterReplicatedAtomicTest.java |  6 ++---
 ...acheContinuousQueryCounterReplicatedTxTest.java |  6 ++---
 .../CacheContinuousQueryEventBufferTest.java       |  6 ++---
 .../CacheContinuousQueryExecuteInPrimaryTest.java  |  6 ++---
 ...QueryFactoryAsyncFilterRandomOperationTest.java |  6 ++---
 ...nuousQueryFactoryFilterRandomOperationTest.java |  6 ++---
 ...cheContinuousQueryFailoverAbstractSelfTest.java |  6 ++---
 ...QueryFailoverAtomicNearEnabledSelfSelfTest.java |  6 ++---
 ...nuousQueryFailoverAtomicReplicatedSelfTest.java |  6 ++---
 ...CacheContinuousQueryFailoverAtomicSelfTest.java |  6 ++---
 ...nuousQueryFailoverMvccTxReplicatedSelfTest.java |  6 ++---
 ...CacheContinuousQueryFailoverMvccTxSelfTest.java |  6 ++---
 ...ontinuousQueryFailoverTxReplicatedSelfTest.java |  6 ++---
 .../CacheContinuousQueryFailoverTxSelfTest.java    |  6 ++---
 .../CacheContinuousQueryLostPartitionTest.java     |  6 ++---
 ...heContinuousQueryOperationFromCallbackTest.java |  6 ++---
 .../CacheContinuousQueryOperationP2PTest.java      |  6 ++---
 .../CacheContinuousQueryOrderingEventTest.java     |  6 ++---
 .../CacheContinuousQueryRandomOperationsTest.java  |  6 ++---
 ...ontinuousQueryRandomOperationsTwoNodesTest.java |  6 ++---
 .../CacheContinuousQueryVariationsTest.java        |  6 ++---
 ...cheContinuousWithTransformerClientSelfTest.java |  6 ++---
 ...CacheContinuousWithTransformerFailoverTest.java |  6 ++---
 ...acheContinuousWithTransformerLocalSelfTest.java |  6 ++---
 ...ntinuousWithTransformerPartitionedSelfTest.java |  6 ++---
 ...tinuousWithTransformerRandomOperationsTest.java |  6 ++---
 ...ontinuousWithTransformerReplicatedSelfTest.java |  6 ++---
 ...acheEntryProcessorExternalizableFailedTest.java |  6 ++---
 .../CacheEntryProcessorNonSerializableTest.java    |  6 ++---
 .../CacheKeepBinaryIterationNearEnabledTest.java   |  6 ++---
 .../CacheKeepBinaryIterationStoreEnabledTest.java  |  6 ++---
 .../continuous/CacheKeepBinaryIterationTest.java   |  6 ++---
 .../ClientReconnectContinuousQueryTest.java        |  6 ++---
 .../continuous/ContinuousQueryMarshallerTest.java  |  6 ++---
 .../ContinuousQueryPeerClassLoadingTest.java       |  6 ++---
 .../ContinuousQueryReassignmentTest.java           |  6 ++---
 ...ueryRemoteFilterMissingInClassPathSelfTest.java |  6 ++---
 .../GridCacheContinuousQueryAbstractSelfTest.java  |  6 ++---
 ...heContinuousQueryAtomicNearEnabledSelfTest.java |  6 ++---
 ...heContinuousQueryAtomicP2PDisabledSelfTest.java |  6 ++---
 .../GridCacheContinuousQueryAtomicSelfTest.java    |  6 ++---
 .../GridCacheContinuousQueryConcurrentTest.java    |  6 ++---
 ...ridCacheContinuousQueryLocalAtomicSelfTest.java |  6 ++---
 .../GridCacheContinuousQueryLocalSelfTest.java     |  6 ++---
 ...acheContinuousQueryMultiNodesFilteringTest.java |  6 ++---
 ...GridCacheContinuousQueryNodesFilteringTest.java |  6 ++---
 ...eContinuousQueryPartitionAtomicOneNodeTest.java |  6 ++---
 ...CacheContinuousQueryPartitionTxOneNodeTest.java |  6 ++---
 ...acheContinuousQueryPartitionedOnlySelfTest.java |  6 ++---
 ...tinuousQueryPartitionedP2PDisabledSelfTest.java |  6 ++---
 ...ridCacheContinuousQueryPartitionedSelfTest.java |  6 ++---
 ...ContinuousQueryReplicatedAtomicOneNodeTest.java |  6 ++---
 ...cheContinuousQueryReplicatedAtomicSelfTest.java |  6 ++---
 ...ntinuousQueryReplicatedP2PDisabledSelfTest.java |  6 ++---
 ...GridCacheContinuousQueryReplicatedSelfTest.java |  6 ++---
 ...acheContinuousQueryReplicatedTxOneNodeTest.java |  6 ++---
 .../GridCacheContinuousQueryTxSelfTest.java        |  6 ++---
 .../IgniteCacheContinuousQueryBackupQueueTest.java |  6 ++---
 ...iteCacheContinuousQueryClientReconnectTest.java |  6 ++---
 .../IgniteCacheContinuousQueryClientTest.java      |  6 ++---
 ...eCacheContinuousQueryClientTxReconnectTest.java |  6 ++---
 ...niteCacheContinuousQueryImmutableEntryTest.java |  6 ++---
 ...gniteCacheContinuousQueryNoUnsubscribeTest.java |  6 ++---
 .../IgniteCacheContinuousQueryReconnectTest.java   |  6 ++---
 .../GridCacheWriteBehindStoreAbstractSelfTest.java |  6 ++---
 .../GridCacheWriteBehindStoreAbstractTest.java     |  6 ++---
 .../store/GridCacheWriteBehindStoreLocalTest.java  |  6 ++---
 ...CacheWriteBehindStoreMultithreadedSelfTest.java |  6 ++---
 ...iteBehindStorePartitionedMultiNodeSelfTest.java |  6 ++---
 .../GridCacheWriteBehindStorePartitionedTest.java  |  6 ++---
 .../GridCacheWriteBehindStoreReplicatedTest.java   |  6 ++---
 .../store/GridCacheWriteBehindStoreSelfTest.java   |  6 ++---
 .../IgniteCacheWriteBehindNoUpdateSelfTest.java    |  6 ++---
 ...nteCacheClientWriteBehindStoreAbstractTest.java |  6 ++---
 ...IgnteCacheClientWriteBehindStoreAtomicTest.java |  6 ++---
 ...cheClientWriteBehindStoreNonCoalescingTest.java |  6 ++---
 .../IgnteCacheClientWriteBehindStoreTxTest.java    |  6 ++---
 .../AbstractDeadlockDetectionTest.java             |  6 ++---
 .../AbstractTransactionIntergrityTest.java         |  6 ++---
 .../transactions/AtomicOperationsInTxTest.java     |  6 ++---
 .../cache/transactions/DepthFirstSearchTest.java   |  6 ++---
 ...ionIntegrityWithPrimaryIndexCorruptionTest.java |  6 ++---
 ...nsactionIntegrityWithSystemWorkerDeathTest.java |  6 ++---
 .../TxDataConsistencyOnCommitFailureTest.java      |  6 ++---
 .../cache/transactions/TxDeadlockCauseTest.java    |  6 ++---
 .../TxDeadlockDetectionMessageMarshallingTest.java |  6 ++---
 .../TxDeadlockDetectionNoHangsTest.java            |  6 ++---
 .../transactions/TxDeadlockDetectionTest.java      |  6 ++---
 .../TxDeadlockDetectionUnmasrhalErrorsTest.java    |  6 ++---
 .../processors/cache/transactions/TxLabelTest.java |  6 ++---
 .../transactions/TxMultiCacheAsyncOpsTest.java     |  6 ++---
 .../cache/transactions/TxOnCachesStartTest.java    |  6 ++---
 ...xOptimisticDeadlockDetectionCrossCacheTest.java |  6 ++---
 .../TxOptimisticDeadlockDetectionTest.java         |  6 ++---
 .../TxOptimisticOnPartitionExchangeTest.java       |  6 ++---
 .../TxOptimisticPrepareOnUnstableTopologyTest.java |  6 ++---
 ...PessimisticDeadlockDetectionCrossCacheTest.java |  6 ++---
 .../TxPessimisticDeadlockDetectionTest.java        |  6 ++---
 .../transactions/TxRollbackAsyncNearCacheTest.java |  6 ++---
 .../cache/transactions/TxRollbackAsyncTest.java    |  6 ++---
 .../TxRollbackAsyncWithPersistenceTest.java        |  6 ++---
 .../TxRollbackOnIncorrectParamsTest.java           |  6 ++---
 .../TxRollbackOnTimeoutNearCacheTest.java          |  6 ++---
 ...TxRollbackOnTimeoutNoDeadlockDetectionTest.java |  6 ++---
 .../TxRollbackOnTimeoutOnePhaseCommitTest.java     |  6 ++---
 .../transactions/TxRollbackOnTimeoutTest.java      |  6 ++---
 .../TxRollbackOnTopologyChangeTest.java            |  6 ++---
 .../cache/transactions/TxStateChangeEventTest.java |  6 ++---
 .../TxWithSmallTimeoutAndContentionOneKeyTest.java |  6 ++---
 .../version/CacheVersionedEntryAbstractTest.java   |  6 ++---
 ...sionedEntryLocalAtomicSwapDisabledSelfTest.java |  6 ++---
 ...heVersionedEntryLocalTransactionalSelfTest.java |  6 ++---
 ...cheVersionedEntryPartitionedAtomicSelfTest.java |  6 ++---
 ...ionedEntryPartitionedTransactionalSelfTest.java |  6 ++---
 ...acheVersionedEntryReplicatedAtomicSelfTest.java |  6 ++---
 ...sionedEntryReplicatedTransactionalSelfTest.java |  6 ++---
 .../closure/GridClosureProcessorRemoteTest.java    |  6 ++---
 .../closure/GridClosureProcessorSelfTest.java      |  6 ++---
 .../closure/GridClosureSerializationTest.java      |  6 ++---
 .../internal/processors/closure/package-info.java  |  6 ++---
 .../cluster/BaselineAutoAdjustInMemoryTest.java    |  6 ++---
 .../cluster/BaselineAutoAdjustMXBeanTest.java      |  6 ++---
 .../processors/cluster/BaselineAutoAdjustTest.java |  6 ++---
 .../cluster/GridAddressResolverSelfTest.java       |  6 ++---
 .../cluster/GridUpdateNotifierSelfTest.java        |  6 ++---
 ...ridComputeJobExecutionErrorToLogManualTest.java |  6 ++---
 .../IgniteComputeConfigVariationsFullApiTest.java  |  6 ++---
 ...ComputeCustomExecutorConfigurationSelfTest.java |  6 ++---
 .../IgniteComputeCustomExecutorSelfTest.java       |  6 ++---
 .../compute/PublicThreadpoolStarvationTest.java    |  6 ++---
 .../DistributedConfigurationAbstractTest.java      |  6 ++---
 .../DistributedConfigurationInMemoryTest.java      |  6 ++---
 .../DistributedConfigurationPersistentTest.java    |  6 ++---
 .../TestDistibutedConfigurationPlugin.java         |  6 ++---
 .../continuous/GridEventConsumeSelfTest.java       |  6 ++---
 .../continuous/GridMessageListenSelfTest.java      |  6 ++---
 .../IgniteContinuousQueryMetadataUpdateTest.java   |  6 ++---
 .../IgniteNoCustomEventsOnNodeStart.java           |  6 ++---
 .../database/BPlusTreeFakeReuseSelfTest.java       |  6 ++---
 .../database/BPlusTreeReuseSelfTest.java           |  6 ++---
 .../processors/database/BPlusTreeSelfTest.java     |  6 ++---
 .../database/CacheFreeListImplSelfTest.java        |  6 ++---
 .../database/DataRegionMetricsSelfTest.java        |  6 ++---
 .../processors/database/IgniteDbAbstractTest.java  |  6 ++---
 .../database/IgniteDbDynamicCacheSelfTest.java     |  6 ++---
 .../database/IgniteDbMemoryLeakAbstractTest.java   |  6 ++---
 .../IgniteDbMemoryLeakLargeObjectsTest.java        |  6 ++---
 .../database/IgniteDbMemoryLeakLargePagesTest.java |  6 ++---
 .../IgniteDbMemoryLeakNonTransactionalTest.java    |  6 ++---
 .../database/IgniteDbMemoryLeakTest.java           |  6 ++---
 .../IgniteDbMemoryLeakWithExpirationTest.java      |  6 ++---
 .../database/IgniteDbMultiNodePutGetTest.java      |  6 ++---
 .../database/IgniteDbPutGetAbstractTest.java       |  6 ++---
 .../database/IgniteDbPutGetWithCacheStoreTest.java |  6 ++---
 .../database/IgniteDbSingleNodePutGetTest.java     |  6 ++---
 .../database/IgniteDbSingleNodeTinyPutGetTest.java |  6 ++---
 .../processors/database/IndexStorageSelfTest.java  |  6 ++---
 .../database/SwapPathConstructionSelfTest.java     |  6 ++---
 ...DataStreamProcessorMvccPersistenceSelfTest.java |  6 ++---
 .../DataStreamProcessorMvccSelfTest.java           |  6 ++---
 .../DataStreamProcessorPersistenceSelfTest.java    |  6 ++---
 .../datastreamer/DataStreamProcessorSelfTest.java  |  6 ++---
 ...amerClientReconnectAfterClusterRestartTest.java |  6 ++---
 .../datastreamer/DataStreamerImplSelfTest.java     |  6 ++---
 .../DataStreamerMultiThreadedSelfTest.java         |  6 ++---
 .../DataStreamerMultinodeCreateCacheTest.java      |  6 ++---
 .../datastreamer/DataStreamerTimeoutTest.java      |  6 ++---
 .../DataStreamerUpdateAfterLoadTest.java           |  6 ++---
 .../IgniteDataStreamerPerformanceTest.java         |  6 ++---
 .../DefaultIgfsSecondaryFileSystemTestAdapter.java |  6 ++---
 .../processors/igfs/IgfsAbstractBaseSelfTest.java  |  6 ++---
 .../processors/igfs/IgfsAbstractSelfTest.java      |  6 ++---
 .../igfs/IgfsAtomicPrimaryMultiNodeSelfTest.java   |  6 ++---
 .../processors/igfs/IgfsAtomicPrimarySelfTest.java |  6 ++---
 .../processors/igfs/IgfsAttributesSelfTest.java    |  6 ++---
 .../igfs/IgfsBackupFailoverSelfTest.java           |  6 ++---
 .../igfs/IgfsBackupsDualAsyncSelfTest.java         |  6 ++---
 .../igfs/IgfsBackupsDualSyncSelfTest.java          |  6 ++---
 .../igfs/IgfsBackupsPrimarySelfTest.java           |  6 ++---
 ...fsBlockMessageSystemPoolStarvationSelfTest.java |  6 ++---
 ...IgfsCachePerBlockLruEvictionPolicySelfTest.java |  6 ++---
 .../processors/igfs/IgfsCacheSelfTest.java         |  6 ++---
 .../processors/igfs/IgfsCommonAbstractTest.java    |  6 ++---
 .../processors/igfs/IgfsDataManagerSelfTest.java   |  6 ++---
 .../processors/igfs/IgfsDualAbstractSelfTest.java  |  6 ++---
 .../igfs/IgfsDualAsyncClientSelfTest.java          |  6 ++---
 .../processors/igfs/IgfsDualAsyncSelfTest.java     |  6 ++---
 .../igfs/IgfsDualSyncClientSelfTest.java           |  6 ++---
 .../processors/igfs/IgfsDualSyncSelfTest.java      |  6 ++---
 .../processors/igfs/IgfsFileInfoSelfTest.java      |  6 ++---
 .../processors/igfs/IgfsFileMapSelfTest.java       |  6 ++---
 .../IgfsGroupDataBlockKeyMapperHashSelfTest.java   |  6 ++---
 .../internal/processors/igfs/IgfsIgniteMock.java   |  6 ++---
 ...calSecondaryFileSystemDualAbstractSelfTest.java |  6 ++---
 ...SecondaryFileSystemDualAsyncClientSelfTest.java |  6 ++---
 ...sLocalSecondaryFileSystemDualAsyncSelfTest.java |  6 ++---
 ...lSecondaryFileSystemDualSyncClientSelfTest.java |  6 ++---
 ...fsLocalSecondaryFileSystemDualSyncSelfTest.java |  6 ++---
 ...ocalSecondaryFileSystemProxyClientSelfTest.java |  6 ++---
 .../IgfsLocalSecondaryFileSystemProxySelfTest.java |  6 ++---
 .../IgfsLocalSecondaryFileSystemTestAdapter.java   |  6 ++---
 .../processors/igfs/IgfsMetaManagerSelfTest.java   |  6 ++---
 .../processors/igfs/IgfsMetricsSelfTest.java       |  6 ++---
 .../ignite/internal/processors/igfs/IgfsMock.java  |  6 ++---
 .../processors/igfs/IgfsModeResolverSelfTest.java  |  6 ++---
 .../processors/igfs/IgfsModesSelfTest.java         |  6 ++---
 .../processors/igfs/IgfsOneClientNodeTest.java     |  6 ++---
 .../processors/igfs/IgfsPrimaryClientSelfTest.java |  6 ++---
 .../igfs/IgfsPrimaryMultiNodeSelfTest.java         |  6 ++---
 ...gfsPrimaryRelaxedConsistencyClientSelfTest.java |  6 ++---
 ...PrimaryRelaxedConsistencyMultiNodeSelfTest.java |  6 ++---
 .../IgfsPrimaryRelaxedConsistencySelfTest.java     |  6 ++---
 .../processors/igfs/IgfsPrimarySelfTest.java       |  6 ++---
 .../processors/igfs/IgfsProcessorSelfTest.java     |  6 ++---
 .../igfs/IgfsProcessorValidationSelfTest.java      |  6 ++---
 .../processors/igfs/IgfsProxySelfTest.java         |  6 ++---
 .../IgfsSecondaryFileSystemInjectionSelfTest.java  |  6 ++---
 .../igfs/IgfsSecondaryFileSystemTestAdapter.java   |  6 ++---
 ...gerIpcEndpointRegistrationAbstractSelfTest.java |  6 ++---
 ...cEndpointRegistrationOnLinuxAndMacSelfTest.java |  6 ++---
 ...erIpcEndpointRegistrationOnWindowsSelfTest.java |  6 ++---
 .../internal/processors/igfs/IgfsSizeSelfTest.java |  6 ++---
 .../processors/igfs/IgfsStartCacheTest.java        |  6 ++---
 .../processors/igfs/IgfsStreamsSelfTest.java       |  6 ++---
 .../internal/processors/igfs/IgfsTaskSelfTest.java |  6 ++---
 .../processors/igfs/IgfsTestInputStream.java       |  6 ++---
 .../processors/igfs/benchmark/IgfsBenchmark.java   |  6 ++---
 .../internal/processors/igfs/package-info.java     |  6 ++---
 .../split/IgfsAbstractRecordResolverSelfTest.java  |  6 ++---
 .../IgfsByteDelimiterRecordResolverSelfTest.java   |  6 ++---
 .../IgfsFixedLengthRecordResolverSelfTest.java     |  6 ++---
 ...IgfsNewLineDelimiterRecordResolverSelfTest.java |  6 ++---
 .../IgfsStringDelimiterRecordResolverSelfTest.java |  6 ++---
 .../GridJobMetricsProcessorLoadTest.java           |  6 ++---
 .../IgniteMessagingConfigVariationFullApiTest.java |  6 ++---
 .../DistributedMetaStoragePersistentTest.java      |  6 ++---
 .../metastorage/DistributedMetaStorageTest.java    |  6 ++---
 .../DistributedMetaStorageHistoryCacheTest.java    |  6 ++---
 .../odbc/OdbcConfigurationValidationSelfTest.java  |  6 ++---
 .../odbc/OdbcEscapeSequenceSelfTest.java           |  6 ++---
 .../processors/port/GridPortProcessorSelfTest.java |  6 ++---
 .../processors/rest/RestProtocolStartTest.java     |  6 ++---
 .../GridCacheAtomicCommandHandlerSelfTest.java     |  6 ++---
 .../cache/GridCacheCommandHandlerSelfTest.java     |  6 ++---
 .../handlers/log/GridLogCommandHandlerTest.java    |  6 ++---
 .../query/GridQueryCommandHandlerTest.java         |  6 ++---
 .../top/CacheTopologyCommandHandlerTest.java       |  6 ++---
 .../service/ClosureServiceClientsNodesTest.java    |  6 ++---
 .../internal/processors/service/DummyService.java  |  6 ++---
 .../service/GridServiceClientNodeTest.java         |  6 ++---
 .../GridServiceContinuousQueryRedeployTest.java    |  6 ++---
 ...ridServiceDeploymentCompoundFutureSelfTest.java |  6 ++---
 ...dServiceDeploymentExceptionPropagationTest.java |  6 ++---
 .../service/GridServicePackagePrivateSelfTest.java |  6 ++---
 .../GridServiceProcessorAbstractSelfTest.java      |  6 ++---
 .../GridServiceProcessorBatchDeploySelfTest.java   |  6 ++---
 ...ridServiceProcessorMultiNodeConfigSelfTest.java |  6 ++---
 .../GridServiceProcessorMultiNodeSelfTest.java     |  6 ++---
 .../service/GridServiceProcessorProxySelfTest.java |  6 ++---
 .../GridServiceProcessorSingleNodeSelfTest.java    |  6 ++---
 .../service/GridServiceProcessorStopSelfTest.java  |  6 ++---
 .../GridServiceProxyClientReconnectSelfTest.java   |  6 ++---
 .../service/GridServiceProxyNodeStopSelfTest.java  |  6 ++---
 .../service/GridServiceReassignmentSelfTest.java   |  6 ++---
 .../service/GridServiceSerializationSelfTest.java  |  6 ++---
 .../IgniteServiceConfigVariationsFullApiTest.java  |  6 ++---
 ...ployment2ClassLoadersDefaultMarshallerTest.java |  6 ++---
 ...ceDeployment2ClassLoadersJdkMarshallerTest.java |  6 ++---
 ...oyment2ClassLoadersOptimizedMarshallerTest.java |  6 ++---
 ...eploymentClassLoadingDefaultMarshallerTest.java |  6 ++---
 ...iceDeploymentClassLoadingJdkMarshallerTest.java |  6 ++---
 ...loymentClassLoadingOptimizedMarshallerTest.java |  6 ++---
 .../IgniteServiceDynamicCachesSelfTest.java        |  6 ++---
 .../IgniteServiceProxyTimeoutInitializedTest.java  |  6 ++---
 .../service/IgniteServiceReassignmentTest.java     |  6 ++---
 ...mentDiscoveryListenerNotificationOrderTest.java |  6 ++---
 ...mentNonSerializableStaticConfigurationTest.java |  6 ++---
 .../service/ServiceDeploymentOnActivationTest.java |  6 ++---
 .../ServiceDeploymentOnClientDisconnectTest.java   |  6 ++---
 .../ServiceDeploymentOutsideBaselineTest.java      |  6 ++---
 .../ServiceDeploymentProcessAbstractTest.java      |  6 ++---
 .../ServiceDeploymentProcessIdSelfTest.java        |  6 ++---
 ...eDeploymentProcessingOnCoordinatorFailTest.java |  6 ++---
 ...eDeploymentProcessingOnCoordinatorLeftTest.java |  6 ++---
 ...ServiceDeploymentProcessingOnNodesFailTest.java |  6 ++---
 ...ServiceDeploymentProcessingOnNodesLeftTest.java |  6 ++---
 ...ServiceHotRedeploymentViaDeploymentSpiTest.java |  6 ++---
 .../processors/service/ServiceInfoSelfTest.java    |  6 ++---
 .../service/ServicePredicateAccessCacheTest.java   |  6 ++---
 .../ServiceReassignmentFunctionSelfTest.java       |  6 ++---
 .../service/SystemCacheNotConfiguredTest.java      |  6 ++---
 .../service/inner/LongInitializedTestService.java  |  6 ++---
 .../processors/service/inner/MyService.java        |  6 ++---
 .../processors/service/inner/MyServiceFactory.java |  6 ++---
 .../processors/service/inner/MyServiceImpl.java    |  6 ++---
 .../timeout/GridTimeoutProcessorSelfTest.java      |  6 ++---
 .../product/GridProductVersionSelfTest.java        |  6 ++---
 .../internal/sql/SqlParserAbstractSelfTest.java    |  6 ++---
 .../internal/sql/SqlParserBulkLoadSelfTest.java    |  6 ++---
 .../internal/sql/SqlParserCreateIndexSelfTest.java |  6 ++---
 .../internal/sql/SqlParserDropIndexSelfTest.java   |  6 ++---
 .../internal/sql/SqlParserKillQuerySelfTest.java   |  6 ++---
 .../sql/SqlParserMultiStatementSelfTest.java       |  6 ++---
 .../sql/SqlParserSetStreamingSelfTest.java         |  6 ++---
 .../SqlParserTransactionalKeywordsSelfTest.java    |  6 ++---
 .../ignite/internal/sql/SqlParserUserSelfTest.java |  6 ++---
 .../stat/IoStatisticsCachePersistenceSelfTest.java |  6 ++---
 .../internal/stat/IoStatisticsCacheSelfTest.java   |  6 ++---
 .../internal/stat/IoStatisticsManagerSelfTest.java |  6 ++---
 ...IoStatisticsMetricsLocalMXBeanImplSelfTest.java |  6 ++---
 .../org/apache/ignite/internal/updatestatus.html   |  6 ++---
 .../ignite/internal/util/BitSetIntSetTest.java     |  6 ++---
 .../ignite/internal/util/GridArraysSelfTest.java   |  6 ++---
 .../ignite/internal/util/GridCleanerTest.java      |  6 ++---
 .../internal/util/GridHandleTableSelfTest.java     |  6 ++---
 ...GridStartupWithUndefinedIgniteHomeSelfTest.java |  6 ++---
 .../ignite/internal/util/GridTestClockTimer.java   |  6 ++---
 .../ignite/internal/util/IgniteDevOnlyLogTest.java |  6 ++---
 .../util/IgniteExceptionRegistrySelfTest.java      |  6 ++---
 .../ignite/internal/util/IgniteUtilsSelfTest.java  |  6 ++---
 .../ignite/internal/util/StripedExecutorTest.java  |  6 ++---
 .../util/future/GridCompoundFutureSelfTest.java    |  6 ++---
 .../util/future/GridEmbeddedFutureSelfTest.java    |  6 ++---
 .../util/future/GridFutureAdapterSelfTest.java     |  6 ++---
 .../internal/util/future/GridFutureQueueTest.java  |  6 ++---
 .../util/future/IgniteCacheFutureImplTest.java     |  6 ++---
 .../internal/util/future/IgniteFutureImplTest.java |  6 ++---
 .../future/nio/GridNioEmbeddedFutureSelfTest.java  |  6 ++---
 .../util/future/nio/GridNioFutureSelfTest.java     |  6 ++---
 ...GridUnsafeDataInputOutputByteOrderSelfTest.java |  6 ++---
 .../GridUnsafeDataOutputArraySizingSelfTest.java   |  6 ++---
 .../util/ipc/shmem/IgfsSharedMemoryTestClient.java |  6 ++---
 .../util/ipc/shmem/IgfsSharedMemoryTestServer.java |  6 ++---
 .../IpcSharedMemoryCrashDetectionSelfTest.java     |  6 ++---
 .../util/ipc/shmem/IpcSharedMemoryFakeClient.java  |  6 ++---
 .../shmem/IpcSharedMemoryNativeLoaderSelfTest.java |  6 ++---
 .../util/ipc/shmem/IpcSharedMemoryNodeStartup.java |  6 ++---
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java    |  6 ++---
 .../ipc/shmem/IpcSharedMemoryUtilsSelfTest.java    |  6 ++---
 .../shmem/LoadWithCorruptedLibFileTestRunner.java  |  6 ++---
 .../benchmark/IpcSharedMemoryBenchmarkParty.java   |  6 ++---
 .../benchmark/IpcSharedMemoryBenchmarkReader.java  |  6 ++---
 .../benchmark/IpcSharedMemoryBenchmarkWriter.java  |  6 ++---
 .../util/nio/GridNioDelimitedBufferSelfTest.java   |  6 ++---
 .../ignite/internal/util/nio/GridNioSelfTest.java  |  6 ++---
 .../util/nio/GridNioSessionMetaKeySelfTest.java    |  6 ++---
 .../internal/util/nio/GridNioSslSelfTest.java      |  6 ++---
 .../internal/util/nio/GridRoundTripTest.java       |  6 ++---
 .../nio/IgniteExceptionInNioWorkerSelfTest.java    |  6 ++---
 .../util/nio/impl/GridNioFilterChainSelfTest.java  |  6 ++---
 .../ignite/internal/util/nio/package-info.java     |  6 ++---
 .../util/offheap/GridByteArrayWrapper.java         |  6 ++---
 .../offheap/GridOffHeapMapAbstractSelfTest.java    |  6 ++---
 .../GridOffHeapMapPerformanceAbstractTest.java     |  6 ++---
 .../GridOffHeapPartitionedMapAbstractSelfTest.java |  6 ++---
 ...fHeapPartitionedMapPerformanceAbstractTest.java |  6 ++---
 .../unsafe/GridUnsafeMapPerformanceTest.java       |  6 ++---
 .../util/offheap/unsafe/GridUnsafeMapSelfTest.java |  6 ++---
 .../offheap/unsafe/GridUnsafeMemorySelfTest.java   |  6 ++---
 .../GridUnsafePartitionedMapPerformanceTest.java   |  6 ++---
 .../unsafe/GridUnsafePartitionedMapSelfTest.java   |  6 ++---
 .../unsafe/GridUnsafeStripedLruSefTest.java        |  6 ++---
 .../tostring/CircularStringBuilderSelfTest.java    |  6 ++---
 .../util/tostring/GridToStringBuilderSelfTest.java |  6 ++---
 .../tostring/IncludeSensitiveAbstractTest.java     |  6 ++---
 .../util/tostring/IncludeSensitiveAtomicTest.java  |  6 ++---
 .../IncludeSensitiveTransactionalTest.java         |  6 ++---
 .../internal/util/tostring/package-info.java       |  6 ++---
 .../apache/ignite/jvmtest/BlockingQueueTest.java   |  6 ++---
 .../java/org/apache/ignite/jvmtest/FileIOTest.java |  6 ++---
 .../org/apache/ignite/jvmtest/FileLocksTest.java   |  6 ++---
 .../apache/ignite/jvmtest/LinkedHashMapTest.java   |  6 ++---
 .../apache/ignite/jvmtest/MultipleFileIOTest.java  |  6 ++---
 .../apache/ignite/jvmtest/NetworkFailureTest.java  |  6 ++---
 .../jvmtest/QueueSizeCounterMultiThreadedTest.java |  6 ++---
 .../jvmtest/ReadWriteLockMultiThreadedTest.java    |  6 ++---
 .../java/org/apache/ignite/jvmtest/RegExpTest.java |  6 ++---
 .../jvmtest/ServerSocketMultiThreadedTest.java     |  6 ++---
 .../ignite/lang/GridBasicPerformanceTest.java      |  6 ++---
 .../ignite/lang/GridByteArrayListSelfTest.java     |  6 ++---
 .../ignite/lang/GridFuncPerformanceTest.java       |  6 ++---
 .../lang/GridFutureListenPerformanceTest.java      |  6 ++---
 .../lang/GridMetadataAwareAdapterLoadTest.java     |  6 ++---
 .../lang/GridMetadataAwareAdapterSelfTest.java     |  6 ++---
 .../apache/ignite/lang/GridSetWrapperSelfTest.java |  6 ++---
 .../lang/GridSystemCurrentTimeMillisTest.java      |  6 ++---
 .../apache/ignite/lang/GridThreadPriorityTest.java |  6 ++---
 .../org/apache/ignite/lang/GridTupleSelfTest.java  |  6 ++---
 .../java/org/apache/ignite/lang/GridXSelfTest.java |  6 ++---
 .../org/apache/ignite/lang/IgniteUuidSelfTest.java |  6 ++---
 .../java/org/apache/ignite/lang/package-info.java  |  6 ++---
 ...GridBoundedConcurrentLinkedHashMapSelfTest.java |  6 ++---
 .../GridBoundedConcurrentOrderedMapSelfTest.java   |  6 ++---
 .../utils/GridBoundedPriorityQueueSelfTest.java    |  6 ++---
 .../utils/GridCircularBufferPerformanceTest.java   |  6 ++---
 .../lang/utils/GridCircularBufferSelfTest.java     |  6 ++---
 .../utils/GridConcurrentLinkedHashMapSelfTest.java |  6 ++---
 .../utils/GridConcurrentWeakHashSetSelfTest.java   |  6 ++---
 .../lang/utils/GridConsistentHashSelfTest.java     |  6 ++---
 .../lang/utils/GridLeanIdentitySetSelfTest.java    |  6 ++---
 .../lang/utils/GridLeanMapPerformanceTest.java     |  6 ++---
 .../ignite/lang/utils/GridLeanMapSelfTest.java     |  6 ++---
 .../ignite/lang/utils/GridListSetSelfTest.java     |  6 ++---
 .../ignite/lang/utils/GridStripedLockSelfTest.java |  6 ++---
 .../utils/IgniteOffheapReadWriteLockSelfTest.java  |  6 ++---
 .../org/apache/ignite/lang/utils/package-info.java |  6 ++---
 .../loadtests/GridCacheLoadPopulationTask.java     |  6 ++---
 .../loadtests/GridCacheMultiNodeLoadTest.java      |  6 ++---
 .../ignite/loadtests/GridLoadTestStatistics.java   |  6 ++---
 .../ignite/loadtests/GridSingleExecutionTest.java  |  6 ++---
 .../loadtests/cache/GridCacheAbstractLoadTest.java |  6 ++---
 .../ignite/loadtests/cache/GridCacheBenchmark.java |  6 ++---
 .../cache/GridCacheDataStructuresLoadTest.java     |  6 ++---
 .../ignite/loadtests/cache/GridCacheLoadTest.java  |  6 ++---
 .../cache/GridCacheWriteBehindStoreLoadTest.java   |  6 ++---
 .../loadtests/capacity/GridCapacityLoadTest.java   |  6 ++---
 .../loadtests/capacity/spring-capacity-cache.xml   |  6 ++---
 .../loadtests/colocation/GridTestCacheStore.java   |  6 ++---
 .../loadtests/colocation/GridTestConstants.java    |  6 ++---
 .../ignite/loadtests/colocation/GridTestKey.java   |  6 ++---
 .../colocation/GridTestLifecycleBean.java          |  6 ++---
 .../ignite/loadtests/colocation/GridTestMain.java  |  6 ++---
 .../loadtests/colocation/spring-colocation.xml     |  6 ++---
 .../communication/GridIoManagerBenchmark.java      |  6 ++---
 .../communication/GridIoManagerBenchmark0.java     |  6 ++---
 .../GridTcpCommunicationBenchmark.java             |  6 ++---
 .../loadtests/communication/GridTestMessage.java   |  6 ++---
 .../GridContinuousOperationsLoadTest.java          |  6 ++---
 .../GridCachePartitionedAtomicLongLoadTest.java    |  6 ++---
 .../direct/multisplit/GridLoadTestJob.java         |  6 ++---
 .../direct/multisplit/GridLoadTestJobTarget.java   |  6 ++---
 .../direct/multisplit/GridLoadTestTask.java        |  6 ++---
 .../direct/multisplit/GridMultiSplitsLoadTest.java |  6 ++---
 .../GridMultiSplitsRedeployLoadTest.java           |  6 ++---
 .../loadtests/direct/multisplit/package-info.java  |  6 ++---
 .../GridSingleSplitNewNodesTestJobTarget.java      |  6 ++---
 .../newnodes/GridSingleSplitNewNodesTestTask.java  |  6 ++---
 .../GridSingleSplitsNewNodesAbstractLoadTest.java  |  6 ++---
 .../GridSingleSplitsNewNodesMulticastLoadTest.java |  6 ++---
 .../loadtests/direct/newnodes/package-info.java    |  6 ++---
 .../redeploy/GridSingleSplitsRedeployLoadTest.java |  6 ++---
 .../loadtests/direct/redeploy/package-info.java    |  6 ++---
 .../direct/session/GridSessionLoadTest.java        |  6 ++---
 .../direct/session/GridSessionLoadTestJob.java     |  6 ++---
 .../direct/session/GridSessionLoadTestTask.java    |  6 ++---
 .../loadtests/direct/session/package-info.java     |  6 ++---
 .../direct/stealing/GridStealingLoadTest.java      |  6 ++---
 .../direct/stealing/GridStealingLoadTestJob.java   |  6 ++---
 .../direct/stealing/GridStealingLoadTestTask.java  |  6 ++---
 .../loadtests/direct/stealing/package-info.java    |  6 ++---
 .../loadtests/discovery/GridGcTimeoutTest.java     |  6 ++---
 .../apache/ignite/loadtests/dsi/GridDsiClient.java |  6 ++---
 .../ignite/loadtests/dsi/GridDsiLifecycleBean.java |  6 ++---
 .../ignite/loadtests/dsi/GridDsiMessage.java       |  6 ++---
 .../ignite/loadtests/dsi/GridDsiPerfJob.java       |  6 ++---
 .../ignite/loadtests/dsi/GridDsiRequest.java       |  6 ++---
 .../ignite/loadtests/dsi/GridDsiRequestTask.java   |  6 ++---
 .../ignite/loadtests/dsi/GridDsiResponse.java      |  6 ++---
 .../ignite/loadtests/dsi/GridDsiResponseTask.java  |  6 ++---
 .../ignite/loadtests/dsi/GridDsiSession.java       |  6 ++---
 .../cacheget/GridBenchmarkCacheGetLoadTest.java    |  6 ++---
 .../apache/ignite/loadtests/dsi/package-info.java  |  6 ++---
 ...GridBoundedConcurrentLinkedHashSetLoadTest.java |  6 ++---
 .../loadtests/hashmap/GridCacheTestContext.java    |  6 ++---
 .../loadtests/hashmap/GridHashMapLoadTest.java     |  6 ++---
 .../job/GridJobExecutionLoadTestClient.java        |  6 ++---
 .../GridJobExecutionLoadTestClientSemaphore.java   |  6 ++---
 .../loadtests/job/GridJobExecutionLoadTestJob.java |  6 ++---
 .../job/GridJobExecutionLoadTestServer.java        |  6 ++---
 .../job/GridJobExecutionLoadTestTask.java          |  6 ++---
 .../job/GridJobExecutionSingleNodeLoadTest.java    |  6 ++---
 ...ridJobExecutionSingleNodeSemaphoreLoadTest.java |  6 ++---
 .../ignite/loadtests/job/GridJobLoadTest.java      |  6 ++---
 .../ignite/loadtests/job/GridJobLoadTestJob.java   |  6 ++---
 .../loadtests/job/GridJobLoadTestParams.java       |  6 ++---
 .../loadtests/job/GridJobLoadTestSubmitter.java    |  6 ++---
 .../ignite/loadtests/job/GridJobLoadTestTask.java  |  6 ++---
 .../apache/ignite/loadtests/job/package-info.java  |  6 ++---
 .../lang/GridConcurrentLinkedHashMapBenchmark.java |  6 ++---
 .../ignite/loadtests/mapper/GridNodeStartup.java   |  6 ++---
 .../loadtests/mergesort/GridMergeSortLoadTask.java |  6 ++---
 .../loadtests/mergesort/GridMergeSortLoadTest.java |  6 ++---
 .../loadtests/nio/GridNioBenchmarkClient.java      |  6 ++---
 .../ignite/loadtests/nio/GridNioBenchmarkTest.java |  6 ++---
 .../loadtests/util/GridCumulativeAverage.java      |  6 ++---
 .../ignite/loadtests/util/GridLoadTestArgs.java    |  6 ++---
 .../apache/ignite/logger/java/JavaLoggerTest.java  |  6 ++---
 .../apache/ignite/logger/java/package-info.java    |  6 ++---
 .../DynamicProxySerializationMultiJvmSelfTest.java |  6 ++---
 .../marshaller/GridMarshallerAbstractTest.java     |  6 ++---
 .../GridMarshallerExternalizableBean.java          |  6 ++---
 .../GridMarshallerMappingConsistencyTest.java      |  6 ++---
 .../marshaller/GridMarshallerPerformanceTest.java  |  6 ++---
 .../marshaller/GridMarshallerResourceBean.java     |  6 ++---
 .../marshaller/GridMarshallerTestAbstractBean.java |  6 ++---
 .../ignite/marshaller/GridMarshallerTestBean.java  |  6 ++---
 .../GridMarshallerTestInheritedBean.java           |  6 ++---
 .../marshaller/MarshallerContextSelfTest.java      |  6 ++---
 .../marshaller/MarshallerContextTestImpl.java      |  6 ++---
 .../MarshallerEnumDeadlockMultiJvmTest.java        |  6 ++---
 .../marshaller/jdk/GridJdkMarshallerSelfTest.java  |  6 ++---
 .../apache/ignite/marshaller/jdk/package-info.java |  6 ++---
 .../org/apache/ignite/marshaller/package-info.java |  6 ++---
 .../GridMessagingNoPeerClassLoadingSelfTest.java   |  6 ++---
 .../ignite/messaging/GridMessagingSelfTest.java    |  6 ++---
 .../messaging/IgniteMessagingSendAsyncTest.java    |  6 ++---
 .../messaging/IgniteMessagingWithClientTest.java   |  6 ++---
 .../p2p/DeploymentClassLoaderCallableTest.java     |  6 ++---
 .../p2p/GridAbstractMultinodeRedeployTest.java     |  6 ++---
 ...ridMultinodeRedeployContinuousModeSelfTest.java |  6 ++---
 .../GridMultinodeRedeployIsolatedModeSelfTest.java |  6 ++---
 .../GridMultinodeRedeployPrivateModeSelfTest.java  |  6 ++---
 .../GridMultinodeRedeploySharedModeSelfTest.java   |  6 ++---
 .../ignite/p2p/GridP2PClassLoadingSelfTest.java    |  6 ++---
 ...GridP2PComputeWithNestedEntryProcessorTest.java |  6 ++---
 .../p2p/GridP2PContinuousDeploymentSelfTest.java   |  6 ++---
 .../p2p/GridP2PDifferentClassLoaderSelfTest.java   |  6 ++---
 .../p2p/GridP2PDoubleDeploymentSelfTest.java       |  6 ++---
 .../ignite/p2p/GridP2PHotRedeploymentSelfTest.java |  6 ++---
 .../ignite/p2p/GridP2PJobClassLoaderSelfTest.java  |  6 ++---
 .../ignite/p2p/GridP2PLocalDeploymentSelfTest.java |  6 ++---
 .../GridP2PMissedResourceCacheSizeSelfTest.java    |  6 ++---
 .../apache/ignite/p2p/GridP2PNodeLeftSelfTest.java |  6 ++---
 .../ignite/p2p/GridP2PRecursionTaskSelfTest.java   |  6 ++---
 .../p2p/GridP2PRemoteClassLoadersSelfTest.java     |  6 ++---
 .../ignite/p2p/GridP2PSameClassLoaderSelfTest.java |  6 ++---
 .../java/org/apache/ignite/p2p/GridP2PTestJob.java |  6 ++---
 .../org/apache/ignite/p2p/GridP2PTestTask.java     |  6 ++---
 .../ignite/p2p/GridP2PTestTaskExecutionTest.java   |  6 ++---
 .../apache/ignite/p2p/GridP2PTimeoutSelfTest.java  |  6 ++---
 .../apache/ignite/p2p/GridP2PUndeploySelfTest.java |  6 ++---
 .../apache/ignite/p2p/GridSwapSpaceCustomKey.java  |  6 ++---
 .../ignite/p2p/GridSwapSpaceCustomValue.java       |  6 ++---
 .../ignite/p2p/P2PScanQueryUndeployTest.java       |  6 ++---
 .../ignite/p2p/P2PStreamingClassLoaderTest.java    |  6 ++---
 .../apache/ignite/p2p/SharedDeploymentTest.java    |  6 ++---
 .../java/org/apache/ignite/p2p/package-info.java   |  6 ++---
 .../test/java/org/apache/ignite/package-info.java  |  6 ++---
 .../platform/PlatformAttributeNodeFilter.java      |  6 ++---
 .../platform/PlatformCacheEntryEventFilter.java    |  6 ++---
 .../PlatformCacheEntryEventFilterFactory.java      |  6 ++---
 .../platform/PlatformCacheWriteMetricsTask.java    |  6 ++---
 .../platform/PlatformComputeBinarizable.java       |  6 ++---
 .../PlatformComputeBinarizableArgTask.java         |  6 ++---
 .../platform/PlatformComputeBroadcastTask.java     |  6 ++---
 .../platform/PlatformComputeDecimalTask.java       |  6 ++---
 .../ignite/platform/PlatformComputeEchoTask.java   |  6 ++---
 .../ignite/platform/PlatformComputeEnum.java       |  6 ++---
 .../platform/PlatformComputeJavaBinarizable.java   |  6 ++---
 .../PlatformDefaultJavaObjectFactorySelfTest.java  |  6 ++---
 .../ignite/platform/PlatformDeployServiceTask.java |  6 ++---
 .../platform/PlatformEventsWriteEventTask.java     |  6 ++---
 .../ignite/platform/PlatformExceptionTask.java     |  6 ++---
 .../PlatformJavaObjectFactoryProxySelfTest.java    |  6 ++---
 .../ignite/platform/PlatformMaxMemoryTask.java     |  6 ++---
 .../ignite/platform/PlatformMinMemoryTask.java     |  6 ++---
 .../ignite/platform/PlatformSqlQueryTask.java      |  6 ++---
 .../ignite/platform/PlatformStartIgniteTask.java   |  6 ++---
 .../ignite/platform/PlatformStopIgniteTask.java    |  6 ++---
 .../ignite/platform/PlatformStringTestTask.java    |  6 ++---
 .../ignite/platform/javaobject/TestJavaObject.java |  6 ++---
 .../javaobject/TestJavaObjectNoDefaultCtor.java    |  6 ++---
 .../TestJavaObjectNoDefaultCtorFactory.java        |  6 ++---
 .../lifecycle/PlatformJavaLifecycleBean.java       |  6 ++---
 .../lifecycle/PlatformJavaLifecycleTask.java       |  6 ++---
 .../plugin/NodeValidationPluginProvider.java       |  6 ++---
 .../ignite/plugin/PluginNodeValidationTest.java    |  6 ++---
 .../security/SecurityPermissionSetBuilderTest.java |  6 ++---
 .../ignite/services/ServiceThreadPoolSelfTest.java |  6 ++---
 ...ridSessionCancelSiblingsFromFutureSelfTest.java |  6 ++---
 .../GridSessionCancelSiblingsFromJobSelfTest.java  |  6 ++---
 .../GridSessionCancelSiblingsFromTaskSelfTest.java |  6 ++---
 .../GridSessionCheckpointAbstractSelfTest.java     |  6 ++---
 .../session/GridSessionCheckpointSelfTest.java     |  6 ++---
 .../session/GridSessionCollisionSpiSelfTest.java   |  6 ++---
 .../GridSessionFutureWaitJobAttributeSelfTest.java |  6 ++---
 ...GridSessionFutureWaitTaskAttributeSelfTest.java |  6 ++---
 .../session/GridSessionJobFailoverSelfTest.java    |  6 ++---
 .../GridSessionJobWaitTaskAttributeSelfTest.java   |  6 ++---
 .../ignite/session/GridSessionLoadSelfTest.java    |  6 ++---
 .../GridSessionSetFutureAttributeSelfTest.java     |  6 ++---
 ...sionSetFutureAttributeWaitListenerSelfTest.java |  6 ++---
 .../GridSessionSetJobAttribute2SelfTest.java       |  6 ++---
 .../GridSessionSetJobAttributeOrderSelfTest.java   |  6 ++---
 .../GridSessionSetJobAttributeSelfTest.java        |  6 ++---
 ...SessionSetJobAttributeWaitListenerSelfTest.java |  6 ++---
 .../GridSessionSetTaskAttributeSelfTest.java       |  6 ++---
 .../GridSessionTaskWaitJobAttributeSelfTest.java   |  6 ++---
 .../session/GridSessionWaitAttributeSelfTest.java  |  6 ++---
 .../ignite/session/GridThreadSerialNumber.java     |  6 ++---
 .../org/apache/ignite/session/package-info.java    |  6 ++---
 .../spi/ExponentialBackoffTimeoutStrategyTest.java |  6 ++---
 .../ignite/spi/GridSpiLocalHostInjectionTest.java  |  6 ++---
 .../ignite/spi/GridSpiStartStopAbstractTest.java   |  6 ++---
 .../org/apache/ignite/spi/GridTcpForwarder.java    |  6 ++---
 .../ignite/spi/GridTcpSpiForwardingSelfTest.java   |  6 ++---
 .../checkpoint/GridCheckpointSpiAbstractTest.java  |  6 ++---
 .../spi/checkpoint/GridCheckpointTestState.java    |  6 ++---
 .../cache/CacheCheckpointSpiConfigSelfTest.java    |  6 ++---
 .../CacheCheckpointSpiSecondCacheSelfTest.java     |  6 ++---
 .../cache/CacheCheckpointSpiSelfTest.java          |  6 ++---
 .../cache/CacheCheckpointSpiStartStopSelfTest.java |  6 ++---
 .../ignite/spi/checkpoint/cache/package-info.java  |  6 ++---
 .../jdbc/JdbcCheckpointSpiConfigSelfTest.java      |  6 ++---
 .../JdbcCheckpointSpiCustomConfigSelfTest.java     |  6 ++---
 .../JdbcCheckpointSpiDefaultConfigSelfTest.java    |  6 ++---
 .../jdbc/JdbcCheckpointSpiStartStopSelfTest.java   |  6 ++---
 .../ignite/spi/checkpoint/jdbc/package-info.java   |  6 ++---
 .../apache/ignite/spi/checkpoint/package-info.java |  6 ++---
 .../GridSharedFsCheckpointSpiConfigSelfTest.java   |  6 ++---
 ...SharedFsCheckpointSpiMultiThreadedSelfTest.java |  6 ++---
 ...FsCheckpointSpiMultipleDirectoriesSelfTest.java |  6 ++---
 .../GridSharedFsCheckpointSpiSelfTest.java         |  6 ++---
 ...GridSharedFsCheckpointSpiStartStopSelfTest.java |  6 ++---
 .../spi/checkpoint/sharedfs/package-info.java      |  6 ++---
 .../spi/collision/GridCollisionTestContext.java    |  6 ++---
 .../spi/collision/GridTestCollisionJobContext.java |  6 ++---
 .../collision/GridTestCollisionTaskSession.java    |  6 ++---
 .../GridFifoQueueCollisionSpiConfigSelfTest.java   |  6 ++---
 .../GridFifoQueueCollisionSpiSelfTest.java         |  6 ++---
 ...GridFifoQueueCollisionSpiStartStopSelfTest.java |  6 ++---
 .../spi/collision/fifoqueue/package-info.java      |  6 ++---
 ...dJobStealingCollisionSpiAttributesSelfTest.java |  6 ++---
 .../GridJobStealingCollisionSpiConfigSelfTest.java |  6 ++---
 ...StealingCollisionSpiCustomTopologySelfTest.java |  6 ++---
 .../GridJobStealingCollisionSpiSelfTest.java       |  6 ++---
 ...idJobStealingCollisionSpiStartStopSelfTest.java |  6 ++---
 .../spi/collision/jobstealing/package-info.java    |  6 ++---
 .../apache/ignite/spi/collision/package-info.java  |  6 ++---
 ...ridPriorityQueueCollisionSpiConfigSelfTest.java |  6 ++---
 .../GridPriorityQueueCollisionSpiSelfTest.java     |  6 ++---
 ...PriorityQueueCollisionSpiStartStopSelfTest.java |  6 ++---
 .../spi/collision/priorityqueue/package-info.java  |  6 ++---
 .../GridAbstractCommunicationSelfTest.java         |  6 ++---
 .../communication/GridCacheMessageSelfTest.java    |  6 ++---
 .../ignite/spi/communication/GridTestMessage.java  |  6 ++---
 .../ignite/spi/communication/package-info.java     |  6 ++---
 .../tcp/GridCacheDhtLockBackupSelfTest.java        |  6 ++---
 .../tcp/GridTcpCommunicationSpiAbstractTest.java   |  6 ++---
 ...pCommunicationSpiConcurrentConnectSelfTest.java |  6 ++---
 ...mmunicationSpiConcurrentConnectSslSelfTest.java |  6 ++---
 .../tcp/GridTcpCommunicationSpiConfigSelfTest.java |  6 ++---
 .../tcp/GridTcpCommunicationSpiLanLoadTest.java    |  6 ++---
 ...idTcpCommunicationSpiMultithreadedSelfTest.java |  6 ++---
 ...dTcpCommunicationSpiMultithreadedShmemTest.java |  6 ++---
 ...GridTcpCommunicationSpiRecoveryAckSelfTest.java |  6 ++---
 ...icationSpiRecoveryFailureDetectionSelfTest.java |  6 ++---
 ...nicationSpiRecoveryNoPairedConnectionsTest.java |  6 ++---
 .../GridTcpCommunicationSpiRecoverySelfTest.java   |  6 ++---
 ...GridTcpCommunicationSpiRecoverySslSelfTest.java |  6 ++---
 .../tcp/GridTcpCommunicationSpiShmemSelfTest.java  |  6 ++---
 .../tcp/GridTcpCommunicationSpiSslSelfTest.java    |  6 ++---
 ...TcpCommunicationSpiSslSmallBuffersSelfTest.java |  6 ++---
 .../GridTcpCommunicationSpiStartStopSelfTest.java  |  6 ++---
 ...ommunicationSpiTcpFailureDetectionSelfTest.java |  6 ++---
 ...idTcpCommunicationSpiTcpNoDelayOffSelfTest.java |  6 ++---
 .../tcp/GridTcpCommunicationSpiTcpSelfTest.java    |  6 ++---
 .../tcp/IgniteCacheSslStartStopSelfTest.java       |  6 ++---
 .../IgniteTcpCommunicationConnectOnInitTest.java   |  6 ++---
 ...IgniteTcpCommunicationHandshakeWaitSslTest.java |  6 ++---
 .../IgniteTcpCommunicationHandshakeWaitTest.java   |  6 ++---
 ...TcpCommunicationRecoveryAckClosureSelfTest.java |  6 ++---
 .../tcp/TcpCommunicationSpiDropNodesTest.java      |  6 ++---
 .../TcpCommunicationSpiFaultyClientSslTest.java    |  6 ++---
 .../tcp/TcpCommunicationSpiFaultyClientTest.java   |  6 ++---
 .../tcp/TcpCommunicationSpiFreezingClientTest.java |  6 ++---
 ...cpCommunicationSpiHalfOpenedConnectionTest.java |  6 ++---
 .../TcpCommunicationSpiSkipMessageSendTest.java    |  6 ++---
 .../tcp/TcpCommunicationStatisticsTest.java        |  6 ++---
 .../ignite/spi/communication/tcp/package-info.java |  6 ++---
 .../local/GridLocalDeploymentSpiSelfTest.java      |  6 ++---
 .../GridLocalDeploymentSpiStartStopSelfTest.java   |  6 ++---
 .../ignite/spi/deployment/local/package-info.java  |  6 ++---
 .../AbstractDiscoveryRandomStartStopTest.java      |  6 ++---
 .../spi/discovery/AbstractDiscoverySelfTest.java   |  6 ++---
 .../spi/discovery/AbstractDiscoveryTest.java       |  6 ++---
 .../spi/discovery/AuthenticationRestartTest.java   |  6 ++---
 ...rMetricsSnapshotSerializeCompatibilityTest.java |  6 ++---
 .../ClusterMetricsSnapshotSerializeSelfTest.java   |  6 ++---
 .../FilterDataForClientNodeDiscoveryTest.java      |  6 ++---
 .../IgniteDiscoveryCacheReuseSelfTest.java         |  6 ++---
 .../discovery/LongClientConnectToClusterTest.java  |  6 ++---
 .../apache/ignite/spi/discovery/package-info.java  |  6 ++---
 .../tcp/DiscoveryUnmarshalVulnerabilityTest.java   |  6 ++---
 .../discovery/tcp/IgniteClientConnectSslTest.java  |  6 ++---
 .../spi/discovery/tcp/IgniteClientConnectTest.java |  6 ++---
 ...gniteClientReconnectMassiveShutdownSslTest.java |  6 ++---
 .../IgniteClientReconnectMassiveShutdownTest.java  |  6 ++---
 .../TcpClientDiscoveryMarshallerCheckSelfTest.java |  6 ++---
 ...TcpClientDiscoverySpiCoordinatorChangeTest.java |  6 ++---
 ...cpClientDiscoverySpiFailureTimeoutSelfTest.java |  6 ++---
 .../tcp/TcpClientDiscoverySpiMulticastTest.java    |  6 ++---
 .../tcp/TcpClientDiscoverySpiSelfTest.java         |  6 ++---
 .../tcp/TcpClientDiscoveryUnresolvedHostTest.java  |  6 ++---
 .../tcp/TcpDiscoveryClientSuspensionSelfTest.java  |  6 ++---
 .../tcp/TcpDiscoveryConcurrentStartTest.java       |  6 ++---
 .../tcp/TcpDiscoveryCoordinatorFailureTest.java    |  6 ++---
 .../discovery/tcp/TcpDiscoveryFailedJoinTest.java  |  6 ++---
 .../tcp/TcpDiscoveryIpFinderCleanerTest.java       |  6 ++---
 .../tcp/TcpDiscoveryMarshallerCheckSelfTest.java   |  6 ++---
 .../tcp/TcpDiscoveryMultiThreadedTest.java         |  6 ++---
 .../tcp/TcpDiscoveryNetworkIssuesTest.java         |  6 ++---
 ...scoveryNodeAttributesUpdateOnReconnectTest.java |  6 ++---
 ...TcpDiscoveryNodeConfigConsistentIdSelfTest.java |  6 ++---
 .../tcp/TcpDiscoveryNodeConsistentIdSelfTest.java  |  6 ++---
 .../tcp/TcpDiscoveryNodeJoinAndFailureTest.java    |  6 ++---
 .../TcpDiscoveryPendingMessageDeliveryTest.java    |  6 ++---
 .../TcpDiscoveryReconnectUnstableTopologyTest.java |  6 ++---
 .../spi/discovery/tcp/TcpDiscoveryRestartTest.java |  6 ++---
 .../tcp/TcpDiscoverySegmentationPolicyTest.java    |  6 ++---
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java    |  6 ++---
 .../tcp/TcpDiscoverySnapshotHistoryTest.java       |  6 ++---
 .../tcp/TcpDiscoverySpiConfigSelfTest.java         |  6 ++---
 .../tcp/TcpDiscoverySpiFailureTimeoutSelfTest.java |  6 ++---
 .../discovery/tcp/TcpDiscoverySpiMBeanTest.java    |  6 ++---
 .../tcp/TcpDiscoverySpiRandomStartStopTest.java    |  6 ++---
 .../tcp/TcpDiscoverySpiReconnectDelayTest.java     |  6 ++---
 .../spi/discovery/tcp/TcpDiscoverySpiSelfTest.java |  6 ++---
 .../discovery/tcp/TcpDiscoverySpiSslSelfTest.java  |  6 ++---
 .../tcp/TcpDiscoverySpiStartStopSelfTest.java      |  6 ++---
 .../tcp/TcpDiscoverySpiWildcardSelfTest.java       |  6 ++---
 .../tcp/TcpDiscoverySslParametersTest.java         |  6 ++---
 .../tcp/TcpDiscoverySslSecuredUnsecuredTest.java   |  6 ++---
 .../spi/discovery/tcp/TcpDiscoverySslSelfTest.java |  6 ++---
 .../tcp/TcpDiscoverySslTrustedSelfTest.java        |  6 ++---
 .../tcp/TcpDiscoverySslTrustedUntrustedTest.java   |  6 ++---
 .../tcp/TcpDiscoveryWithWrongServerTest.java       |  6 ++---
 .../discovery/tcp/TestReconnectPluginProvider.java |  6 ++---
 .../spi/discovery/tcp/TestReconnectProcessor.java  |  6 ++---
 .../spi/discovery/tcp/TestTcpDiscoverySpi.java     |  6 ++---
 .../TcpDiscoveryIpFinderAbstractSelfTest.java      |  6 ++---
 .../jdbc/TcpDiscoveryJdbcIpFinderSelfTest.java     |  6 ++---
 .../discovery/tcp/ipfinder/jdbc/package-info.java  |  6 ++---
 .../TcpDiscoveryMulticastIpFinderSelfTest.java     |  6 ++---
 .../spi/discovery/tcp/ipfinder/package-info.java   |  6 ++---
 .../TcpDiscoverySharedFsIpFinderSelfTest.java      |  6 ++---
 .../tcp/ipfinder/sharedfs/package-info.java        |  6 ++---
 .../vm/TcpDiscoveryVmIpFinderSelfTest.java         |  6 ++---
 .../discovery/tcp/ipfinder/vm/package-info.java    |  6 ++---
 .../ignite/spi/discovery/tcp/package-info.java     |  6 ++---
 .../encryption/KeystoreEncryptionSpiSelfTest.java  |  6 ++---
 ...ridMemoryEventStorageMultiThreadedSelfTest.java |  6 ++---
 .../GridMemoryEventStorageSpiConfigSelfTest.java   |  6 ++---
 .../memory/GridMemoryEventStorageSpiSelfTest.java  |  6 ++---
 ...GridMemoryEventStorageSpiStartStopSelfTest.java |  6 ++---
 .../spi/eventstorage/memory/package-info.java      |  6 ++---
 .../spi/failover/GridFailoverTestContext.java      |  6 ++---
 .../GridAlwaysFailoverSpiConfigSelfTest.java       |  6 ++---
 .../always/GridAlwaysFailoverSpiSelfTest.java      |  6 ++---
 .../GridAlwaysFailoverSpiStartStopSelfTest.java    |  6 ++---
 .../ignite/spi/failover/always/package-info.java   |  6 ++---
 .../GridJobStealingFailoverSpiConfigSelfTest.java  |  6 ++---
 .../GridJobStealingFailoverSpiOneNodeSelfTest.java |  6 ++---
 .../GridJobStealingFailoverSpiSelfTest.java        |  6 ++---
 ...ridJobStealingFailoverSpiStartStopSelfTest.java |  6 ++---
 .../spi/failover/jobstealing/package-info.java     |  6 ++---
 .../never/GridNeverFailoverSpiSelfTest.java        |  6 ++---
 .../GridNeverFailoverSpiStartStopSelfTest.java     |  6 ++---
 .../ignite/spi/failover/never/package-info.java    |  6 ++---
 .../apache/ignite/spi/failover/package-info.java   |  6 ++---
 ...GridAdaptiveLoadBalancingSpiConfigSelfTest.java |  6 ++---
 ...aptiveLoadBalancingSpiMultipleNodeSelfTest.java |  6 ++---
 .../GridAdaptiveLoadBalancingSpiSelfTest.java      |  6 ++---
 ...dAdaptiveLoadBalancingSpiStartStopSelfTest.java |  6 ++---
 .../spi/loadbalancing/adaptive/package-info.java   |  6 ++---
 .../GridInternalTasksLoadBalancingSelfTest.java    |  6 ++---
 .../ignite/spi/loadbalancing/package-info.java     |  6 ++---
 ...adBalancingNotPerTaskMultithreadedSelfTest.java |  6 ++---
 ...oundRobinLoadBalancingSpiLocalNodeSelfTest.java |  6 ++---
 ...RobinLoadBalancingSpiMultipleNodesSelfTest.java |  6 ++---
 ...undRobinLoadBalancingSpiNotPerTaskSelfTest.java |  6 ++---
 ...oundRobinLoadBalancingSpiStartStopSelfTest.java |  6 ++---
 ...obinLoadBalancingSpiTopologyChangeSelfTest.java |  6 ++---
 .../roundrobin/GridRoundRobinTestUtils.java        |  6 ++---
 .../spi/loadbalancing/roundrobin/package-info.java |  6 ++---
 ...ightedRandomLoadBalancingSpiConfigSelfTest.java |  6 ++---
 ...GridWeightedRandomLoadBalancingSpiSelfTest.java |  6 ++---
 ...tedRandomLoadBalancingSpiStartStopSelfTest.java |  6 ++---
 ...htedRandomLoadBalancingSpiWeightedSelfTest.java |  6 ++---
 .../loadbalancing/weightedrandom/package-info.java |  6 ++---
 .../java/org/apache/ignite/spi/package-info.java   |  6 ++---
 .../startup/GridRandomCommandLineLoader.java       |  6 ++---
 .../apache/ignite/startup/GridVmNodesStarter.java  |  6 ++---
 .../startup/cmdline/GridCommandLineLoaderTest.java |  6 ++---
 .../GridCommandLineTransformerSelfTest.java        |  6 ++---
 .../ignite/startup/cmdline/package-info.java       |  6 ++---
 .../org/apache/ignite/startup/package-info.java    |  6 ++---
 .../properties/NotStringSystemPropertyTest.java    |  6 ++---
 .../startup/servlet/GridServletLoaderTest.java     |  6 ++---
 .../ignite/startup/servlet/package-info.java       |  6 ++---
 .../stream/socket/SocketStreamerSelfTest.java      |  6 ++---
 .../SocketStreamerUnmarshalVulnerabilityTest.java  |  6 ++---
 .../apache/ignite/stream/socket/package-info.java  |  6 ++---
 .../apache/ignite/testframework/GridFileLock.java  |  6 ++---
 .../ignite/testframework/GridJarClassLoader.java   |  6 ++---
 .../ignite/testframework/GridLoadTestUtils.java    |  6 ++---
 .../ignite/testframework/GridSpiTestContext.java   |  6 ++---
 .../ignite/testframework/GridStringLogger.java     |  6 ++---
 .../ignite/testframework/GridTestClassLoader.java  |  6 ++---
 .../testframework/GridTestExternalClassLoader.java |  6 ++---
 .../apache/ignite/testframework/GridTestNode.java  |  6 ++---
 .../testframework/GridTestSafeThreadFactory.java   |  6 ++---
 .../ignite/testframework/GridTestThread.java       |  6 ++---
 .../apache/ignite/testframework/GridTestUtils.java |  6 ++---
 .../ignite/testframework/ListeningTestLogger.java  |  6 ++---
 .../apache/ignite/testframework/LogListener.java   |  6 ++---
 .../ignite/testframework/MvccFeatureChecker.java   |  6 ++---
 .../testframework/assertions/AlwaysAssertion.java  |  6 ++---
 .../ignite/testframework/assertions/Assertion.java |  6 ++---
 .../testframework/assertions/package-info.java     |  6 ++---
 .../testframework/config/GridTestProperties.java   |  6 ++---
 .../ignite/testframework/config/package-info.java  |  6 ++---
 .../configvariations/CacheStartMode.java           |  6 ++---
 .../configvariations/ConfigFactory.java            |  6 ++---
 .../configvariations/ConfigParameter.java          |  6 ++---
 .../configvariations/ConfigVariations.java         |  6 ++---
 .../configvariations/ConfigVariationsFactory.java  |  6 ++---
 .../ConfigVariationsTestSuiteBuilder.java          |  6 ++---
 .../testframework/configvariations/Parameters.java |  6 ++---
 .../configvariations/VariationsIterator.java       |  6 ++---
 .../configvariations/VariationsTestsConfig.java    |  6 ++---
 .../testframework/http/GridEmbeddedHttpServer.java |  6 ++---
 .../ignite/testframework/http/package-info.java    |  6 ++---
 .../ignite/testframework/junits/DynamicSuite.java  |  6 ++---
 .../testframework/junits/GridAbstractTest.java     |  6 ++---
 .../junits/GridTestKernalContext.java              |  6 ++---
 .../IgniteCacheConfigVariationsAbstractTest.java   |  6 ++---
 .../junits/IgniteConfigVariationsAbstractTest.java |  6 ++---
 .../ignite/testframework/junits/IgniteMock.java    |  6 ++---
 .../testframework/junits/IgniteTestResources.java  |  6 ++---
 .../junits/JUnit3TestLegacySupport.java            |  6 ++---
 .../testframework/junits/JUnitAssertAware.java     |  6 ++---
 .../testframework/junits/SystemPropertiesList.java |  6 ++---
 .../testframework/junits/WithSystemProperty.java   |  6 ++---
 .../cache/GridAbstractCacheStoreSelfTest.java      |  6 ++---
 .../junits/cache/TestCacheSession.java             |  6 ++---
 .../junits/cache/TestThreadLocalCacheSession.java  |  6 ++---
 .../junits/common/GridAbstractExamplesTest.java    |  6 ++---
 .../common/GridAbstractLifecycleAwareSelfTest.java |  6 ++---
 .../junits/common/GridCommonAbstractTest.java      |  6 ++---
 .../junits/common/GridCommonTest.java              |  6 ++---
 .../common/GridRollingRestartAbstractTest.java     |  6 ++---
 .../testframework/junits/common/package-info.java  |  6 ++---
 .../logger/GridLog4jRollingFileAppender.java       |  6 ++---
 .../junits/logger/GridTestLog4jLogger.java         |  6 ++---
 .../junits/multijvm/AffinityProcessProxy.java      |  6 ++---
 .../junits/multijvm/IgniteCacheProcessProxy.java   |  6 ++---
 .../junits/multijvm/IgniteClusterProcessProxy.java |  6 ++---
 .../junits/multijvm/IgniteEventsProcessProxy.java  |  6 ++---
 .../junits/multijvm/IgniteNodeRunner.java          |  6 ++---
 .../junits/multijvm/IgniteProcessProxy.java        |  6 ++---
 .../ignite/testframework/junits/package-info.java  |  6 ++---
 .../junits/spi/GridSpiAbstractConfigTest.java      |  6 ++---
 .../junits/spi/GridSpiAbstractTest.java            |  6 ++---
 .../testframework/junits/spi/GridSpiTest.java      |  6 ++---
 .../junits/spi/GridSpiTestConfig.java              |  6 ++---
 .../testframework/junits/spi/package-info.java     |  6 ++---
 .../apache/ignite/testframework/package-info.java  |  6 ++---
 .../test/ConfigVariationsTestSuiteBuilderTest.java |  6 ++---
 .../test/ListeningTestLoggerTest.java              |  6 ++---
 .../ignite/testframework/test/ParametersTest.java  |  6 ++---
 .../testframework/test/VariationsIteratorTest.java |  6 ++---
 .../ignite/testsuites/IgniteBasicTestSuite.java    |  6 ++---
 .../IgniteBasicWithPersistenceTestSuite.java       |  6 ++---
 .../testsuites/IgniteBinaryCacheTestSuite.java     |  6 ++---
 .../IgniteBinaryObjectsCacheTestSuite3.java        |  6 ++---
 .../IgniteBinaryObjectsComputeGridTestSuite.java   |  6 ++---
 ...bjectsSimpleNameMapperComputeGridTestSuite.java |  6 ++---
 .../testsuites/IgniteBinaryObjectsTestSuite.java   |  6 ++---
 ...IgniteBinarySimpleNameMapperBasicTestSuite.java |  6 ++---
 ...inarySimpleNameMapperCacheFullApiTestSuite.java |  6 ++---
 ...CacheBasicConfigVariationsFullApiTestSuite.java |  6 ++---
 ...acheBlockExchangeOnReadOperationsTestSuite.java |  6 ++---
 ...niteCacheDataStructuresBinarySelfTestSuite.java |  6 ++---
 .../IgniteCacheDataStructuresSelfTestSuite.java    |  6 ++---
 .../IgniteCacheEvictionSelfTestSuite.java          |  6 ++---
 .../testsuites/IgniteCacheFailoverTestSuite.java   |  6 ++---
 .../testsuites/IgniteCacheFailoverTestSuite2.java  |  6 ++---
 .../testsuites/IgniteCacheFailoverTestSuite3.java  |  6 ++---
 .../IgniteCacheFailoverTestSuiteSsl.java           |  6 ++---
 .../IgniteCacheFullApiMultiJvmSelfTestSuite.java   |  6 ++---
 .../IgniteCacheFullApiSelfTestSuite.java           |  6 ++---
 .../IgniteCacheIteratorsSelfTestSuite.java         |  6 ++---
 .../IgniteCacheLoadConsistencyTestSuite.java       |  6 ++---
 .../IgniteCacheMetricsSelfTestSuite.java           |  6 ++---
 .../testsuites/IgniteCacheMvccTestSuite.java       |  6 ++---
 .../testsuites/IgniteCacheMvccTestSuite1.java      |  6 ++---
 .../testsuites/IgniteCacheMvccTestSuite2.java      |  6 ++---
 .../testsuites/IgniteCacheMvccTestSuite3.java      |  6 ++---
 .../testsuites/IgniteCacheMvccTestSuite4.java      |  6 ++---
 .../testsuites/IgniteCacheMvccTestSuite5.java      |  6 ++---
 .../testsuites/IgniteCacheMvccTestSuite6.java      |  6 ++---
 .../testsuites/IgniteCacheMvccTestSuite7.java      |  6 ++---
 .../testsuites/IgniteCacheMvccTestSuite8.java      |  6 ++---
 .../testsuites/IgniteCacheMvccTestSuite9.java      |  6 ++---
 .../IgniteCacheNearOnlySelfTestSuite.java          |  6 ++---
 .../IgniteCacheP2pUnmarshallingErrorTestSuite.java |  6 ++---
 .../testsuites/IgniteCacheRestartTestSuite.java    |  6 ++---
 .../testsuites/IgniteCacheRestartTestSuite2.java   |  6 ++---
 .../IgniteCacheTcpClientDiscoveryTestSuite.java    |  6 ++---
 .../ignite/testsuites/IgniteCacheTestSuite.java    |  6 ++---
 .../ignite/testsuites/IgniteCacheTestSuite2.java   |  6 ++---
 .../ignite/testsuites/IgniteCacheTestSuite3.java   |  6 ++---
 .../ignite/testsuites/IgniteCacheTestSuite4.java   |  6 ++---
 .../ignite/testsuites/IgniteCacheTestSuite5.java   |  6 ++---
 .../ignite/testsuites/IgniteCacheTestSuite6.java   |  6 ++---
 .../ignite/testsuites/IgniteCacheTestSuite7.java   |  6 ++---
 .../ignite/testsuites/IgniteCacheTestSuite8.java   |  6 ++---
 .../ignite/testsuites/IgniteCacheTestSuite9.java   |  6 ++---
 .../IgniteCacheTxRecoverySelfTestSuite.java        |  6 ++---
 .../IgniteCacheWriteBehindTestSuite.java           |  6 ++---
 .../testsuites/IgniteClientNodesTestSuite.java     |  6 ++---
 .../testsuites/IgniteClientReconnectTestSuite.java |  6 ++---
 ...mputeBasicConfigVariationsFullApiTestSuite.java |  6 ++---
 .../testsuites/IgniteComputeGridTestSuite.java     |  6 ++---
 ...IgniteContinuousQueryConfigVariationsSuite.java |  6 ++---
 .../IgniteContinuousTaskSelfTestSuite.java         |  6 ++---
 .../ignite/testsuites/IgniteDatabaseTestSuite.java |  6 ++---
 .../testsuites/IgniteDbMemoryLeakTestSuite.java    |  6 ++---
 .../IgniteExternalizableSelfTestSuite.java         |  6 ++---
 .../ignite/testsuites/IgniteIgfsTestSuite.java     |  6 ++---
 .../IgniteIpcSharedMemorySelfTestSuite.java        |  6 ++---
 .../ignite/testsuites/IgniteIpcTestSuite.java      |  6 ++---
 .../testsuites/IgniteJobMetricsSelfTestSuite.java  |  6 ++---
 .../testsuites/IgniteKernalSelfTestSuite.java      |  6 ++---
 .../ignite/testsuites/IgniteLangSelfTestSuite.java |  6 ++---
 .../testsuites/IgniteLoggingSelfTestSuite.java     |  6 ++---
 .../testsuites/IgniteLostAndFoundTestSuite.java    |  6 ++---
 .../testsuites/IgniteMarshallerSelfTestSuite.java  |  6 ++---
 ...teMessagingConfigVariationFullApiTestSuite.java |  6 ++---
 .../ignite/testsuites/IgniteP2PSelfTestSuite.java  |  6 ++---
 .../ignite/testsuites/IgnitePdsMvccTestSuite.java  |  6 ++---
 .../ignite/testsuites/IgnitePdsMvccTestSuite2.java |  6 ++---
 .../ignite/testsuites/IgnitePdsMvccTestSuite3.java |  6 ++---
 .../ignite/testsuites/IgnitePdsMvccTestSuite4.java |  6 ++---
 .../ignite/testsuites/IgnitePdsTestSuite.java      |  6 ++---
 .../ignite/testsuites/IgnitePdsTestSuite2.java     |  6 ++---
 .../ignite/testsuites/IgnitePdsTestSuite3.java     |  6 ++---
 .../ignite/testsuites/IgnitePdsTestSuite4.java     |  6 ++---
 .../ignite/testsuites/IgnitePdsUnitTestSuite.java  |  6 ++---
 .../testsuites/IgnitePerformanceTestSuite.java     |  6 ++---
 .../testsuites/IgnitePlatformsTestSuite.java       |  6 ++---
 .../ignite/testsuites/IgniteReproducingSuite.java  |  6 ++---
 .../testsuites/IgniteRestHandlerTestSuite.java     |  6 ++---
 ...iteServiceConfigVariationsFullApiTestSuite.java |  6 ++---
 .../testsuites/IgniteServiceGridTestSuite.java     |  6 ++---
 .../IgniteSpiCheckpointSelfTestSuite.java          |  6 ++---
 .../IgniteSpiCollisionSelfTestSuite.java           |  6 ++---
 .../IgniteSpiCommunicationSelfTestSuite.java       |  6 ++---
 .../IgniteSpiDeploymentSelfTestSuite.java          |  6 ++---
 .../IgniteSpiDiscoverySelfTestSuite.java           |  6 ++---
 .../IgniteSpiEventStorageSelfTestSuite.java        |  6 ++---
 .../testsuites/IgniteSpiFailoverSelfTestSuite.java |  6 ++---
 .../IgniteSpiLoadBalancingSelfTestSuite.java       |  6 ++---
 .../ignite/testsuites/IgniteSpiTestSuite.java      |  6 ++---
 .../testsuites/IgniteStandByClusterSuite.java      |  6 ++---
 .../ignite/testsuites/IgniteStartUpTestSuite.java  |  6 ++---
 .../testsuites/IgniteStreamSelfTestSuite.java      |  6 ++---
 .../testsuites/IgniteTaskSessionSelfTestSuite.java |  6 ++---
 .../IgniteTimeoutProcessorSelfTestSuite.java       |  6 ++---
 .../IgniteTopologyValidatorTestSuite.java          |  6 ++---
 .../ignite/testsuites/IgniteUtilSelfTestSuite.java |  6 ++---
 ...eptorCacheConfigVariationsFullApiTestSuite.java |  6 ++---
 .../testsuites/TxDeadlockDetectionTestSuite.java   |  6 ++---
 ...inaryCacheConfigVariationsFullApiTestSuite.java |  6 ++---
 .../org/apache/ignite/testsuites/package-info.java |  6 ++---
 .../GridThreadPoolExecutorServiceSelfTest.java     |  6 ++---
 .../org/apache/ignite/thread/GridThreadTest.java   |  6 ++---
 .../ignite/thread/IgniteThreadPoolSizeTest.java    |  6 ++---
 .../ignite/util/AttributeNodeFilterSelfTest.java   |  6 ++---
 .../ignite/util/GridCommandHandlerSslTest.java     |  6 ++---
 .../apache/ignite/util/GridCommandHandlerTest.java |  6 ++---
 ...GridConcurrentLinkedDequeMultiThreadedTest.java |  6 ++---
 .../util/GridConcurrentLinkedDequeSelfTest.java    |  6 ++---
 ...ncurrentLinkedHashMapMultiThreadedSelfTest.java |  6 ++---
 .../apache/ignite/util/GridIntListSelfTest.java    |  6 ++---
 .../GridInternalTaskUnusedWalSegmentsTest.java     |  6 ++---
 .../apache/ignite/util/GridLogThrottleTest.java    |  6 ++---
 .../apache/ignite/util/GridLongListSelfTest.java   |  6 ++---
 .../ignite/util/GridMessageCollectionTest.java     |  6 ++---
 .../ignite/util/GridPartitionMapSelfTest.java      |  6 ++---
 .../org/apache/ignite/util/GridQueueSelfTest.java  |  6 ++---
 .../org/apache/ignite/util/GridRandomSelfTest.java |  6 ++---
 .../ignite/util/GridSnapshotLockSelfTest.java      |  6 ++---
 .../ignite/util/GridSpinReadWriteLockSelfTest.java |  6 ++---
 .../util/GridStringBuilderFactorySelfTest.java     |  6 ++---
 .../ignite/util/GridTopologyHeapSizeSelfTest.java  |  6 ++---
 .../org/apache/ignite/util/GridTransientTest.java  |  6 ++---
 .../ignite/util/TestTcpCommunicationSpi.java       |  6 ++---
 .../ignite/util/mbeans/GridMBeanBaselineTest.java  |  6 ++---
 .../util/mbeans/GridMBeanDisableSelfTest.java      |  6 ++---
 .../util/mbeans/GridMBeanExoticNamesSelfTest.java  |  6 ++---
 .../ignite/util/mbeans/GridMBeanSelfTest.java      |  6 ++---
 .../util/mbeans/WorkersControlMXBeanTest.java      |  6 ++---
 .../java/org/apache/ignite/util/package-info.java  |  6 ++---
 .../test/webapp/META-INF/ignite-webapp-config.xml  |  6 ++---
 modules/core/src/test/webapp/WEB-INF/web.xml       |  6 ++---
 modules/dev-utils/ignite-modules-test/build.gradle |  6 ++---
 .../src/test/java/module-info.java                 |  6 ++---
 .../modulestest/IgniteLaunchInModularEnvTest.java  |  6 ++---
 modules/dev-utils/pom.xml                          |  6 ++---
 .../development/utils/IgniteWalConverter.java      |  6 ++---
 .../development/utils/RecordSizeCountStat.java     |  6 ++---
 .../apache/ignite/development/utils/TxWalStat.java |  6 ++---
 .../apache/ignite/development/utils/WalStat.java   |  6 ++---
 .../ignite/development/utils/package-info.java     |  6 ++---
 modules/direct-io/pom.xml                          |  6 ++---
 .../cache/persistence/file/AlignedBuffers.java     |  6 ++---
 .../file/AlignedBuffersDirectFileIO.java           |  6 ++---
 .../file/AlignedBuffersDirectFileIOFactory.java    |  6 ++---
 .../cache/persistence/file/IgniteNativeIoLib.java  |  6 ++---
 .../persistence/file/LinuxNativeIoPlugin.java      |  6 ++---
 .../file/LinuxNativeIoPluginProvider.java          |  6 ++---
 ...DiskPageCompressionIntegrationDirectIOTest.java |  6 ++---
 ...ocalWalModeChangeDuringRebalancingSelfTest.java |  6 ++---
 ...NativeIoPdsRecoveryAfterFileCorruptionTest.java |  6 ++---
 .../wal/IgniteNativeIoWalFlushFsyncSelfTest.java   |  6 ++---
 .../cache/persistence/file/IgniteFileIOTest.java   |  6 ++---
 .../file/IgniteNativeIoWithNoPersistenceTest.java  |  6 ++---
 .../testsuites/IgnitePdsNativeIoTestSuite.java     |  6 ++---
 .../testsuites/IgnitePdsNativeIoTestSuite2.java    |  6 ++---
 .../IgnitePdsReplacementNativeIoTest.java          |  6 ++---
 modules/extdata/p2p/META-INF/ignite.xml            |  6 ++---
 modules/extdata/p2p/pom.xml                        |  6 ++---
 .../ignite/tests/p2p/AlwaysTruePredicate.java      |  6 ++---
 ...heDeploymenComputeWithNestedEntryProcessor.java |  6 ++---
 .../p2p/CacheDeploymentAffinityKeyMapper.java      |  6 ++---
 .../p2p/CacheDeploymentAlwaysTruePredicate.java    |  6 ++---
 .../p2p/CacheDeploymentAlwaysTruePredicate2.java   |  6 ++---
 .../p2p/CacheDeploymentBinaryEntryProcessor.java   |  6 ++---
 .../CacheDeploymentBinaryObjectEntryProcessor.java |  6 ++---
 ...eploymentCacheEntryEventSerializableFilter.java |  6 ++---
 .../p2p/CacheDeploymentCacheEntryListener.java     |  6 ++---
 .../CacheDeploymentCachePluginConfiguration.java   |  6 ++---
 .../tests/p2p/CacheDeploymentEntryEventFilter.java |  6 ++---
 .../CacheDeploymentEntryEventFilterFactory.java    |  6 ++---
 .../tests/p2p/CacheDeploymentEntryProcessor.java   |  6 ++---
 .../CacheDeploymentExternalizableTestValue.java    |  6 ++---
 ...CacheDeploymentStoreSessionListenerFactory.java |  6 ++---
 .../tests/p2p/CacheDeploymentTestEnumValue.java    |  6 ++---
 .../ignite/tests/p2p/CacheDeploymentTestKey.java   |  6 ++---
 .../tests/p2p/CacheDeploymentTestStoreFactory.java |  6 ++---
 .../ignite/tests/p2p/CacheDeploymentTestTask1.java |  6 ++---
 .../ignite/tests/p2p/CacheDeploymentTestTask2.java |  6 ++---
 .../ignite/tests/p2p/CacheDeploymentTestTask3.java |  6 ++---
 .../ignite/tests/p2p/CacheDeploymentTestValue.java |  6 ++---
 .../tests/p2p/CacheDeploymentTestValue2.java       |  6 ++---
 .../tests/p2p/CacheDeploymentTestValue3.java       |  6 ++---
 .../apache/ignite/tests/p2p/ExcludeNodeFilter.java |  6 ++---
 .../tests/p2p/GridCacheDeploymentTestValue3.java   |  6 ++---
 .../ignite/tests/p2p/GridEventConsumeFilter.java   |  6 ++---
 .../p2p/GridEventConsumeProjectionPredicate.java   |  6 ++---
 .../tests/p2p/GridExternalAffinityFunction.java    |  6 ++---
 .../tests/p2p/GridExternalAffinityKeyMapper.java   |  6 ++---
 .../tests/p2p/GridP2PAwareTestUserResource.java    |  6 ++---
 .../p2p/GridP2PContinuousDeploymentTask1.java      |  6 ++---
 .../p2p/GridP2PContinuousDeploymentTask2.java      |  6 ++---
 .../tests/p2p/GridP2PEventFilterExternalPath1.java |  6 ++---
 .../tests/p2p/GridP2PEventFilterExternalPath2.java |  6 ++---
 .../tests/p2p/GridSingleSplitTestJobTarget.java    |  6 ++---
 .../ignite/tests/p2p/GridTestMessageListener.java  |  6 ++---
 .../ignite/tests/p2p/GridTestMessageTopic.java     |  6 ++---
 .../apache/ignite/tests/p2p/JobStealingTask.java   |  6 ++---
 .../p2p/NoValueClassOnServerAbstractClient.java    |  6 ++---
 .../org/apache/ignite/tests/p2p/NodeFilter.java    |  6 ++---
 .../ignite/tests/p2p/NoopCacheEntryProcessor.java  |  6 ++---
 .../org/apache/ignite/tests/p2p/NoopService.java   |  6 ++---
 .../org/apache/ignite/tests/p2p/NoopService2.java  |  6 ++---
 .../ignite/tests/p2p/P2PTestTaskExternalPath1.java |  6 ++---
 .../ignite/tests/p2p/P2PTestTaskExternalPath2.java |  6 ++---
 .../ignite/tests/p2p/SingleSplitTestTask.java      |  6 ++---
 .../apache/ignite/tests/p2p/TestUserResource.java  |  6 ++---
 .../cache/CacheNoValueClassOnServerTestClient.java |  6 ++---
 .../org/apache/ignite/tests/p2p/cache/Person.java  |  6 ++---
 .../apache/ignite/tests/p2p/cache/PersonKey.java   |  6 ++---
 .../ignite/tests/p2p/cache/PersonWrapper.java      |  6 ++---
 .../ignite/tests/p2p/compute/ExternalCallable.java |  6 ++---
 .../tests/p2p/compute/ExternalCallable1.java       |  6 ++---
 .../tests/p2p/compute/ExternalCallable2.java       |  6 ++---
 .../DataStructuresNoClassOnServerTestClient.java   |  6 ++---
 .../org/apache/ignite/tests/p2p/package-info.java  |  6 ++---
 .../tests/p2p/pedicates/BinaryPredicate.java       |  6 ++---
 .../tests/p2p/pedicates/CompositePredicate.java    |  6 ++---
 .../p2p/pedicates/FirstConsideredPredicate.java    |  6 ++---
 .../p2p/pedicates/SecondConsideredPredicate.java   |  6 ++---
 .../tests/p2p/startcache/CacheAllNodesFilter.java  |  6 ++---
 .../CacheConfigurationP2PTestClient.java           |  6 ++---
 .../ignite/tests/p2p/startcache/Organization1.java |  6 ++---
 .../ignite/tests/p2p/startcache/Organization2.java |  6 ++---
 modules/extdata/platform/pom.xml                   |  6 ++---
 .../ignite/platform/plugin/PlatformTestPlugin.java |  6 ++---
 .../plugin/PlatformTestPluginConfiguration.java    |  6 ++---
 ...tformTestPluginConfigurationClosureFactory.java |  6 ++---
 .../plugin/PlatformTestPluginException.java        |  6 ++---
 .../plugin/PlatformTestPluginExtension.java        |  6 ++---
 .../plugin/PlatformTestPluginProvider.java         |  6 ++---
 .../platform/plugin/PlatformTestPluginTarget.java  |  6 ++---
 .../plugin/cache/PlatformGetCachePluginsTask.java  |  6 ++---
 .../PlatformTestCachePluginConfiguration.java      |  6 ++---
 ...latformTestCachePluginConfigurationClosure.java |  6 ++---
 ...TestCachePluginConfigurationClosureFactory.java |  6 ++---
 .../cache/PlatformTestCachePluginProvider.java     |  6 ++---
 .../ignite/platform/plugin/cache/package-info.java |  6 ++---
 .../ignite/platform/plugin/package-info.java       |  6 ++---
 .../extdata/uri/META-INF/bad-classes-ignite.xml    |  6 ++---
 .../uri/META-INF/bad-signed-deployfile-ignite.xml  |  6 ++---
 .../extdata/uri/META-INF/deploydepend-ignite.xml   |  6 ++---
 modules/extdata/uri/META-INF/deploydir-ignite.xml  |  6 ++---
 modules/extdata/uri/META-INF/deployfile-ignite.xml |  6 ++---
 modules/extdata/uri/META-INF/ignite.xml            |  6 ++---
 .../uri/META-INF/well-signed-deployfile-ignite.xml |  6 ++---
 modules/extdata/uri/modules/uri-dependency/pom.xml |  6 ++---
 .../deployment/uri/tasks/GarHelloWorldBean.java    |  6 ++---
 .../src/main/resources/gar-example.properties      |  6 ++---
 modules/extdata/uri/pom.xml                        |  6 ++---
 .../deployment/uri/tasks/GarHelloWorldTask.java    |  6 ++---
 .../tasks/GridUriDeploymentAbstractTestTask.java   |  6 ++---
 .../uri/tasks/GridUriDeploymentDependency1.java    |  6 ++---
 .../uri/tasks/GridUriDeploymentDependency2.java    |  6 ++---
 .../uri/tasks/GridUriDeploymentDependency9.java    |  6 ++---
 .../uri/tasks/GridUriDeploymentInnerTestTask.java  |  6 ++---
 .../tasks/GridUriDeploymentInterfaceTestTask.java  |  6 ++---
 .../tasks/GridUriDeploymentNonePublicTestTask.java |  6 ++---
 .../uri/tasks/GridUriDeploymentTestTask0.java      |  6 ++---
 .../uri/tasks/GridUriDeploymentTestTask1.java      |  6 ++---
 .../uri/tasks/GridUriDeploymentTestTask10.java     |  6 ++---
 .../uri/tasks/GridUriDeploymentTestTask11.java     |  6 ++---
 .../uri/tasks/GridUriDeploymentTestTask2.java      |  6 ++---
 .../uri/tasks/GridUriDeploymentTestTask3.java      |  6 ++---
 .../uri/tasks/GridUriDeploymentTestTask4.java      |  6 ++---
 .../uri/tasks/GridUriDeploymentTestTask5.java      |  6 ++---
 .../uri/tasks/GridUriDeploymentTestTask6.java      |  6 ++---
 .../uri/tasks/GridUriDeploymentTestTask8.java      |  6 ++---
 .../uri/tasks/GridUriDeploymentTestTask9.java      |  6 ++---
 .../tasks/GridUriDeploymentTestWithNameTask0.java  |  6 ++---
 .../tasks/GridUriDeploymentTestWithNameTask10.java |  6 ++---
 .../tasks/GridUriDeploymentTestWithNameTask11.java |  6 ++---
 .../tasks/GridUriDeploymentTestWithNameTask3.java  |  6 ++---
 .../tasks/GridUriDeploymentTestWithNameTask4.java  |  6 ++---
 .../tasks/GridUriDeploymentTestWithNameTask5.java  |  6 ++---
 .../tasks/GridUriDeploymentTestWithNameTask6.java  |  6 ++---
 .../tasks/GridUriDeploymentTestWithNameTask7.java  |  6 ++---
 .../tasks/GridUriDeploymentTestWithNameTask8.java  |  6 ++---
 .../spi/deployment/uri/tasks/gar-spring-bean.xml   |  6 ++---
 .../spi/deployment/uri/tasks/package-info.java     |  6 ++---
 .../ignite/spi/deployment/uri/tasks/spring1.xml    |  6 ++---
 .../ignite/spi/deployment/uri/tasks/spring2.xml    |  6 ++---
 .../ignite/spi/deployment/uri/tasks/spring9.xml    |  6 ++---
 .../spi/deployment/uri/tasks/test1.properties      |  6 ++---
 .../spi/deployment/uri/tasks/test2.properties      |  6 ++---
 .../spi/deployment/uri/tasks/test9.properties      |  6 ++---
 .../java/org/apache/ignite/test/test.properties    |  6 ++---
 .../ignite/tests/p2p/compute/ExternalCallable.java |  6 ++---
 .../tests/p2p/compute/ExternalCallable1.java       |  6 ++---
 .../tests/p2p/compute/ExternalCallable2.java       |  6 ++---
 modules/flink/pom.xml                              |  6 ++---
 .../org/apache/ignite/sink/flink/IgniteSink.java   |  6 ++---
 .../org/apache/ignite/sink/flink/package-info.java |  6 ++---
 .../apache/ignite/source/flink/IgniteSource.java   |  6 ++---
 .../ignite/source/flink/TaskRemoteFilter.java      |  6 ++---
 .../apache/ignite/source/flink/package-info.java   |  6 ++---
 .../ignite/sink/flink/FlinkIgniteSinkSelfTest.java |  6 ++---
 .../sink/flink/FlinkIgniteSinkSelfTestSuite.java   |  6 ++---
 .../source/flink/FlinkIgniteSourceSelfTest.java    |  6 ++---
 .../flink/FlinkIgniteSourceSelfTestSuite.java      |  6 ++---
 .../flink/src/test/resources/example-ignite.xml    |  6 ++---
 modules/flume/pom.xml                              |  6 ++---
 .../ignite/stream/flume/EventTransformer.java      |  6 ++---
 .../org/apache/ignite/stream/flume/IgniteSink.java |  6 ++---
 .../ignite/stream/flume/IgniteSinkConstants.java   |  6 ++---
 .../apache/ignite/stream/flume/package-info.java   |  6 ++---
 .../apache/ignite/stream/flume/IgniteSinkTest.java |  6 ++---
 .../ignite/stream/flume/IgniteSinkTestSuite.java   |  6 ++---
 .../ignite/stream/flume/TestEventTransformer.java  |  6 ++---
 .../apache/ignite/stream/flume/package-info.java   |  6 ++---
 .../flume/src/test/resources/example-ignite.xml    |  6 ++---
 modules/gce/pom.xml                                |  6 ++---
 .../gce/TcpDiscoveryGoogleStorageIpFinder.java     |  6 ++---
 .../discovery/tcp/ipfinder/gce/package-info.java   |  6 ++---
 .../TcpDiscoveryGoogleStorageIpFinderSelfTest.java |  6 ++---
 .../discovery/tcp/ipfinder/gce/package-info.java   |  6 ++---
 .../ignite/testsuites/IgniteGCETestSuite.java      |  6 ++---
 modules/geospatial/pom.xml                         |  6 ++---
 .../query/h2/opt/GridH2SpatialIndex.java           |  6 ++---
 .../query/h2/H2IndexesSystemViewTest.java          |  6 ++---
 .../query/h2/H2IndexingAbstractGeoSelfTest.java    |  6 ++---
 .../processors/query/h2/H2IndexingGeoSelfTest.java |  6 ++---
 .../query/h2/H2IndexingSegmentedGeoSelfTest.java   |  6 ++---
 .../testsuites/GeoSpatialIndexingTestSuite.java    |  6 ++---
 modules/hadoop/config/core-site.ignite.xml         |  6 ++---
 modules/hadoop/config/hive-site.ignite.xml         |  6 ++---
 modules/hadoop/config/mapred-site.ignite.xml       |  6 ++---
 modules/hadoop/pom.xml                             | 12 +++++-----
 .../hadoop/fs/BasicHadoopFileSystemFactory.java    |  6 ++---
 .../hadoop/fs/CachingHadoopFileSystemFactory.java  |  6 ++---
 .../ignite/hadoop/fs/HadoopFileSystemFactory.java  |  6 ++---
 .../fs/IgniteHadoopFileSystemCounterWriter.java    |  6 ++---
 .../fs/IgniteHadoopIgfsSecondaryFileSystem.java    |  6 ++---
 .../hadoop/fs/KerberosHadoopFileSystemFactory.java |  6 ++---
 .../org/apache/ignite/hadoop/fs/package-info.java  |  6 ++---
 .../hadoop/fs/v1/IgniteHadoopFileSystem.java       |  6 ++---
 .../apache/ignite/hadoop/fs/v1/package-info.java   |  6 ++---
 .../hadoop/fs/v2/IgniteHadoopFileSystem.java       |  6 ++---
 .../apache/ignite/hadoop/fs/v2/package-info.java   |  6 ++---
 .../io/BytesWritablePartiallyRawComparator.java    |  6 ++---
 .../ignite/hadoop/io/PartiallyRawComparator.java   |  6 ++---
 .../org/apache/ignite/hadoop/io/RawMemory.java     |  6 ++---
 .../hadoop/io/TextPartiallyRawComparator.java      |  6 ++---
 .../org/apache/ignite/hadoop/io/package-info.java  |  6 ++---
 .../IgniteHadoopClientProtocolProvider.java        |  6 ++---
 .../IgniteHadoopWeightedMapReducePlanner.java      |  6 ++---
 .../ignite/hadoop/mapreduce/package-info.java      |  6 ++---
 .../planner/HadoopAbstractMapReducePlanner.java    |  6 ++---
 .../planner/HadoopTestRoundRobinMrPlanner.java     |  6 ++---
 .../apache/ignite/hadoop/planner/package-info.java |  6 ++---
 .../ignite/hadoop/util/BasicUserNameMapper.java    |  6 ++---
 .../ignite/hadoop/util/ChainedUserNameMapper.java  |  6 ++---
 .../ignite/hadoop/util/KerberosUserNameMapper.java |  6 ++---
 .../apache/ignite/hadoop/util/UserNameMapper.java  |  6 ++---
 .../apache/ignite/hadoop/util/package-info.java    |  6 ++---
 .../processors/hadoop/HadoopAttributes.java        |  6 ++---
 .../processors/hadoop/HadoopCommonUtils.java       |  6 ++---
 .../processors/hadoop/HadoopComponent.java         |  6 ++---
 .../internal/processors/hadoop/HadoopContext.java  |  6 ++---
 .../processors/hadoop/HadoopExternalSplit.java     |  6 ++---
 .../processors/hadoop/HadoopHelperImpl.java        |  6 ++---
 .../internal/processors/hadoop/HadoopImpl.java     |  6 ++---
 .../processors/hadoop/HadoopMapperUtils.java       |  6 ++---
 .../processors/hadoop/HadoopProcessor.java         |  6 ++---
 .../internal/processors/hadoop/HadoopSetup.java    |  6 ++---
 .../processors/hadoop/HadoopSplitWrapper.java      |  6 ++---
 .../hadoop/HadoopTaskCancelledException.java       |  6 ++---
 .../hadoop/counter/HadoopCounterAdapter.java       |  6 ++---
 .../hadoop/counter/HadoopCountersImpl.java         |  6 ++---
 .../hadoop/counter/HadoopLongCounter.java          |  6 ++---
 .../hadoop/counter/HadoopPerformanceCounter.java   |  6 ++---
 .../hadoop/delegate/HadoopDelegateUtils.java       |  6 ++---
 .../HadoopFileSystemCounterWriterDelegate.java     |  6 ++---
 .../delegate/HadoopFileSystemFactoryDelegate.java  |  6 ++---
 .../HadoopIgfsSecondaryFileSystemDelegate.java     |  6 ++---
 .../processors/hadoop/igfs/HadoopIgfsEndpoint.java |  6 ++---
 .../hadoop/impl/HadoopMapReduceCounterGroup.java   |  6 ++---
 .../hadoop/impl/HadoopMapReduceCounters.java       |  6 ++---
 .../processors/hadoop/impl/HadoopUtils.java        |  6 ++---
 .../HadoopBasicFileSystemFactoryDelegate.java      |  6 ++---
 .../HadoopCachingFileSystemFactoryDelegate.java    |  6 ++---
 .../HadoopDefaultFileSystemFactoryDelegate.java    |  6 ++---
 .../HadoopFileSystemCounterWriterDelegateImpl.java |  6 ++---
 .../HadoopIgfsSecondaryFileSystemDelegateImpl.java |  6 ++---
 .../HadoopKerberosFileSystemFactoryDelegate.java   |  6 ++---
 .../hadoop/impl/fs/HadoopFileSystemCacheUtils.java |  6 ++---
 .../hadoop/impl/fs/HadoopFileSystemsUtils.java     |  6 ++---
 .../hadoop/impl/fs/HadoopLazyConcurrentMap.java    |  6 ++---
 .../hadoop/impl/fs/HadoopLocalFileSystemV1.java    |  6 ++---
 .../hadoop/impl/fs/HadoopLocalFileSystemV2.java    |  6 ++---
 .../hadoop/impl/fs/HadoopParameters.java           |  6 ++---
 .../hadoop/impl/fs/HadoopRawLocalFileSystem.java   |  6 ++---
 .../processors/hadoop/impl/igfs/HadoopIgfs.java    |  6 ++---
 .../igfs/HadoopIgfsCommunicationException.java     |  6 ++---
 .../processors/hadoop/impl/igfs/HadoopIgfsEx.java  |  6 ++---
 .../hadoop/impl/igfs/HadoopIgfsFuture.java         |  6 ++---
 .../hadoop/impl/igfs/HadoopIgfsInProc.java         |  6 ++---
 .../hadoop/impl/igfs/HadoopIgfsInputStream.java    |  6 ++---
 .../processors/hadoop/impl/igfs/HadoopIgfsIo.java  |  6 ++---
 .../hadoop/impl/igfs/HadoopIgfsIpcIo.java          |  6 ++---
 .../hadoop/impl/igfs/HadoopIgfsIpcIoListener.java  |  6 ++---
 .../hadoop/impl/igfs/HadoopIgfsJclLogger.java      |  6 ++---
 .../hadoop/impl/igfs/HadoopIgfsOutProc.java        |  6 ++---
 .../hadoop/impl/igfs/HadoopIgfsOutputStream.java   |  6 ++---
 .../hadoop/impl/igfs/HadoopIgfsProperties.java     |  6 ++---
 .../impl/igfs/HadoopIgfsProxyInputStream.java      |  6 ++---
 .../impl/igfs/HadoopIgfsProxyOutputStream.java     |  6 ++---
 ...pIgfsSecondaryFileSystemPositionedReadable.java |  6 ++---
 .../hadoop/impl/igfs/HadoopIgfsStreamDelegate.java |  6 ++---
 .../impl/igfs/HadoopIgfsStreamEventListener.java   |  6 ++---
 .../hadoop/impl/igfs/HadoopIgfsUtils.java          |  6 ++---
 .../hadoop/impl/igfs/HadoopIgfsWrapper.java        |  6 ++---
 .../hadoop/impl/proto/HadoopClientProtocol.java    |  6 ++---
 .../hadoop/impl/v1/HadoopV1CleanupTask.java        |  6 ++---
 .../processors/hadoop/impl/v1/HadoopV1Counter.java |  6 ++---
 .../processors/hadoop/impl/v1/HadoopV1MapTask.java |  6 ++---
 .../hadoop/impl/v1/HadoopV1OutputCollector.java    |  6 ++---
 .../hadoop/impl/v1/HadoopV1Partitioner.java        |  6 ++---
 .../hadoop/impl/v1/HadoopV1ReduceTask.java         |  6 ++---
 .../hadoop/impl/v1/HadoopV1Reporter.java           |  6 ++---
 .../hadoop/impl/v1/HadoopV1SetupTask.java          |  6 ++---
 .../hadoop/impl/v1/HadoopV1Splitter.java           |  6 ++---
 .../processors/hadoop/impl/v1/HadoopV1Task.java    |  6 ++---
 .../processors/hadoop/impl/v2/HadoopDaemon.java    |  6 ++---
 .../hadoop/impl/v2/HadoopSerializationWrapper.java |  6 ++---
 .../hadoop/impl/v2/HadoopShutdownHookManager.java  |  6 ++---
 .../hadoop/impl/v2/HadoopV2CleanupTask.java        |  6 ++---
 .../processors/hadoop/impl/v2/HadoopV2Context.java |  6 ++---
 .../processors/hadoop/impl/v2/HadoopV2Counter.java |  6 ++---
 ...pV2DelegatingPartiallyOffheapRawComparator.java |  6 ++---
 .../processors/hadoop/impl/v2/HadoopV2Job.java     |  6 ++---
 .../hadoop/impl/v2/HadoopV2JobResourceManager.java |  6 ++---
 .../processors/hadoop/impl/v2/HadoopV2MapTask.java |  6 ++---
 .../hadoop/impl/v2/HadoopV2Partitioner.java        |  6 ++---
 .../hadoop/impl/v2/HadoopV2ReduceTask.java         |  6 ++---
 .../hadoop/impl/v2/HadoopV2SetupTask.java          |  6 ++---
 .../hadoop/impl/v2/HadoopV2Splitter.java           |  6 ++---
 .../processors/hadoop/impl/v2/HadoopV2Task.java    |  6 ++---
 .../hadoop/impl/v2/HadoopV2TaskContext.java        |  6 ++---
 .../impl/v2/HadoopWritableSerialization.java       |  6 ++---
 .../processors/hadoop/io/OffheapRawMemory.java     |  6 ++---
 .../hadoop/jobtracker/HadoopJobMetadata.java       |  6 ++---
 .../hadoop/jobtracker/HadoopJobTracker.java        |  6 ++---
 .../hadoop/mapreduce/MapReduceClient.java          |  6 ++---
 .../hadoop/planner/HadoopDefaultMapReducePlan.java |  6 ++---
 .../hadoop/planner/HadoopMapReducePlanGroup.java   |  6 ++---
 .../planner/HadoopMapReducePlanTopology.java       |  6 ++---
 .../proto/HadoopProtocolJobCountersTask.java       |  6 ++---
 .../hadoop/proto/HadoopProtocolJobStatusTask.java  |  6 ++---
 .../hadoop/proto/HadoopProtocolKillJobTask.java    |  6 ++---
 .../hadoop/proto/HadoopProtocolNextTaskIdTask.java |  6 ++---
 .../hadoop/proto/HadoopProtocolSubmitJobTask.java  |  6 ++---
 .../hadoop/proto/HadoopProtocolTaskAdapter.java    |  6 ++---
 .../hadoop/proto/HadoopProtocolTaskArguments.java  |  6 ++---
 .../processors/hadoop/shuffle/HadoopShuffle.java   |  6 ++---
 .../hadoop/shuffle/HadoopShuffleJob.java           |  6 ++---
 .../hadoop/shuffle/HadoopShuffleLocalState.java    |  6 ++---
 .../hadoop/shuffle/HadoopShuffleRemoteState.java   |  6 ++---
 .../collections/HadoopConcurrentHashMultimap.java  |  6 ++---
 .../shuffle/collections/HadoopHashMultimap.java    |  6 ++---
 .../collections/HadoopHashMultimapBase.java        |  6 ++---
 .../hadoop/shuffle/collections/HadoopMultimap.java |  6 ++---
 .../shuffle/collections/HadoopMultimapBase.java    |  6 ++---
 .../hadoop/shuffle/collections/HadoopSkipList.java |  6 ++---
 .../shuffle/direct/HadoopDirectDataInput.java      |  6 ++---
 .../shuffle/direct/HadoopDirectDataOutput.java     |  6 ++---
 .../direct/HadoopDirectDataOutputContext.java      |  6 ++---
 .../direct/HadoopDirectDataOutputState.java        |  6 ++---
 .../hadoop/shuffle/streams/HadoopDataInStream.java |  6 ++---
 .../shuffle/streams/HadoopDataOutStream.java       |  6 ++---
 .../shuffle/streams/HadoopOffheapBuffer.java       |  6 ++---
 .../taskexecutor/HadoopEmbeddedTaskExecutor.java   |  6 ++---
 .../hadoop/taskexecutor/HadoopExecutorService.java |  6 ++---
 .../hadoop/taskexecutor/HadoopRunnableTask.java    |  6 ++---
 .../taskexecutor/HadoopTaskExecutorAdapter.java    |  6 ++---
 .../hadoop/taskexecutor/HadoopTaskState.java       |  6 ++---
 .../hadoop/taskexecutor/HadoopTaskStatus.java      |  6 ++---
 .../external/HadoopExternalTaskExecutor.java       |  6 ++---
 .../external/HadoopExternalTaskMetadata.java       |  6 ++---
 .../external/HadoopJobInfoUpdateRequest.java       |  6 ++---
 .../external/HadoopPrepareForJobRequest.java       |  6 ++---
 .../external/HadoopProcessDescriptor.java          |  6 ++---
 .../external/HadoopProcessStartedAck.java          |  6 ++---
 .../external/HadoopTaskExecutionRequest.java       |  6 ++---
 .../external/HadoopTaskFinishedMessage.java        |  6 ++---
 .../external/child/HadoopChildProcessRunner.java   |  6 ++---
 .../child/HadoopExternalProcessStarter.java        |  6 ++---
 .../HadoopAbstractCommunicationClient.java         |  6 ++---
 .../communication/HadoopCommunicationClient.java   |  6 ++---
 .../communication/HadoopExternalCommunication.java |  6 ++---
 .../HadoopHandshakeTimeoutException.java           |  6 ++---
 .../communication/HadoopIpcToNioAdapter.java       |  6 ++---
 .../communication/HadoopMarshallerFilter.java      |  6 ++---
 .../communication/HadoopMessageListener.java       |  6 ++---
 .../HadoopTcpNioCommunicationClient.java           |  6 ++---
 .../main/resources/META-INF/classnames.properties  |  6 ++---
 .../src/test/config/hadoop-fs-open-test/grid-0.xml |  6 ++---
 .../src/test/config/hadoop-fs-open-test/grid-1.xml |  6 ++---
 .../src/test/config/hadoop-fs-open-test/grid-2.xml |  6 ++---
 .../src/test/config/igfs-cli-config-dual-async.xml |  6 ++---
 .../src/test/config/igfs-cli-config-dual-sync.xml  |  6 ++---
 .../src/test/config/igfs-cli-config-primary.xml    |  6 ++---
 .../src/test/config/igfs-cli-config-proxy.xml      |  6 ++---
 .../processors/hadoop/HadoopSharedMap.java         |  6 ++---
 .../processors/hadoop/HadoopTestClassLoader.java   |  6 ++---
 .../hadoop/impl/HadoopAbstractMapReduceTest.java   |  6 ++---
 .../hadoop/impl/HadoopAbstractSelfTest.java        |  6 ++---
 .../hadoop/impl/HadoopAbstractWordCountTest.java   |  6 ++---
 .../hadoop/impl/HadoopCommandLineTest.java         |  6 ++---
 .../hadoop/impl/HadoopErrorSimulator.java          |  6 ++---
 .../hadoop/impl/HadoopFileSystemsTest.java         |  6 ++---
 .../processors/hadoop/impl/HadoopGroupingTest.java |  6 ++---
 .../hadoop/impl/HadoopJobTrackerSelfTest.java      |  6 ++---
 .../impl/HadoopMapReduceEmbeddedSelfTest.java      |  6 ++---
 .../impl/HadoopMapReduceErrorResilienceTest.java   |  6 ++---
 .../hadoop/impl/HadoopMapReduceTest.java           |  6 ++---
 .../hadoop/impl/HadoopNoHadoopMapReduceTest.java   |  6 ++---
 .../hadoop/impl/HadoopPlannerMockJob.java          |  6 ++---
 .../impl/HadoopSerializationWrapperSelfTest.java   |  6 ++---
 .../hadoop/impl/HadoopSnappyFullMapReduceTest.java |  6 ++---
 .../processors/hadoop/impl/HadoopSnappyTest.java   |  6 ++---
 .../hadoop/impl/HadoopSortingExternalTest.java     |  6 ++---
 .../processors/hadoop/impl/HadoopSortingTest.java  |  6 ++---
 .../hadoop/impl/HadoopSplitWrapperSelfTest.java    |  6 ++---
 .../processors/hadoop/impl/HadoopStartup.java      |  6 ++---
 .../hadoop/impl/HadoopTaskExecutionSelfTest.java   |  6 ++---
 .../processors/hadoop/impl/HadoopTasksV1Test.java  |  6 ++---
 .../processors/hadoop/impl/HadoopTasksV2Test.java  |  6 ++---
 .../impl/HadoopTasksVersionsAbstractTest.java      |  6 ++---
 .../processors/hadoop/impl/HadoopTeraSortTest.java |  6 ++---
 .../hadoop/impl/HadoopTestTaskContext.java         |  6 ++---
 .../processors/hadoop/impl/HadoopTestUtils.java    |  6 ++---
 .../hadoop/impl/HadoopTxConfigCacheTest.java       |  6 ++---
 .../hadoop/impl/HadoopUserLibsSelfTest.java        |  6 ++---
 .../hadoop/impl/HadoopV2JobSelfTest.java           |  6 ++---
 .../hadoop/impl/HadoopValidationSelfTest.java      |  6 ++---
 .../impl/HadoopWeightedMapReducePlannerTest.java   |  6 ++---
 .../impl/HadoopWeightedPlannerMapReduceTest.java   |  6 ++---
 .../HadoopClientProtocolEmbeddedSelfTest.java      |  6 ++---
 ...adoopClientProtocolMultipleServersSelfTest.java |  6 ++---
 .../impl/client/HadoopClientProtocolSelfTest.java  |  6 ++---
 .../hadoop/impl/examples/HadoopPopularWords.java   |  6 ++---
 .../hadoop/impl/examples/HadoopWordCount1.java     |  6 ++---
 .../hadoop/impl/examples/HadoopWordCount1Map.java  |  6 ++---
 .../impl/examples/HadoopWordCount1Reduce.java      |  6 ++---
 .../hadoop/impl/examples/HadoopWordCount2.java     |  6 ++---
 .../impl/examples/HadoopWordCount2Combiner.java    |  6 ++---
 .../impl/examples/HadoopWordCount2Mapper.java      |  6 ++---
 .../impl/examples/HadoopWordCount2Reducer.java     |  6 ++---
 .../KerberosHadoopFileSystemFactorySelfTest.java   |  6 ++---
 .../hadoop/impl/igfs/Hadoop1DualAbstractTest.java  |  6 ++---
 .../impl/igfs/Hadoop1OverIgfsDualAsyncTest.java    |  6 ++---
 .../impl/igfs/Hadoop1OverIgfsDualSyncTest.java     |  6 ++---
 .../hadoop/impl/igfs/Hadoop1OverIgfsProxyTest.java |  6 ++---
 .../impl/igfs/HadoopFIleSystemFactorySelfTest.java |  6 ++---
 .../HadoopIgfs20FileSystemAbstractSelfTest.java    |  6 ++---
 ...oopIgfs20FileSystemLoopbackPrimarySelfTest.java |  6 ++---
 ...HadoopIgfs20FileSystemShmemPrimarySelfTest.java |  6 ++---
 .../impl/igfs/HadoopIgfsDualAbstractSelfTest.java  |  6 ++---
 .../impl/igfs/HadoopIgfsDualAsyncSelfTest.java     |  6 ++---
 .../impl/igfs/HadoopIgfsDualSyncSelfTest.java      |  6 ++---
 .../HadoopIgfsSecondaryFileSystemTestAdapter.java  |  6 ++---
 ...HadoopSecondaryFileSystemConfigurationTest.java |  6 ++---
 .../hadoop/impl/igfs/IgfsEventsTestSuite.java      |  6 ++---
 .../impl/igfs/IgfsNearOnlyMultiNodeSelfTest.java   |  6 ++---
 .../IgniteHadoopFileSystemAbstractSelfTest.java    |  6 ++---
 ...adoopFileSystemClientBasedAbstractSelfTest.java |  6 ++---
 ...doopFileSystemClientBasedDualAsyncSelfTest.java |  6 ++---
 ...adoopFileSystemClientBasedDualSyncSelfTest.java |  6 ++---
 .../IgniteHadoopFileSystemClientBasedOpenTest.java |  6 ++---
 ...HadoopFileSystemClientBasedPrimarySelfTest.java |  6 ++---
 ...teHadoopFileSystemClientBasedProxySelfTest.java |  6 ++---
 .../igfs/IgniteHadoopFileSystemClientSelfTest.java |  6 ++---
 .../IgniteHadoopFileSystemHandshakeSelfTest.java   |  6 ++---
 .../IgniteHadoopFileSystemIpcCacheSelfTest.java    |  6 ++---
 .../igfs/IgniteHadoopFileSystemLoggerSelfTest.java |  6 ++---
 .../IgniteHadoopFileSystemLoggerStateSelfTest.java |  6 ++---
 ...teHadoopFileSystemLoopbackAbstractSelfTest.java |  6 ++---
 ...ileSystemLoopbackEmbeddedDualAsyncSelfTest.java |  6 ++---
 ...FileSystemLoopbackEmbeddedDualSyncSelfTest.java |  6 ++---
 ...pFileSystemLoopbackEmbeddedPrimarySelfTest.java |  6 ++---
 ...ileSystemLoopbackEmbeddedSecondarySelfTest.java |  6 ++---
 ...ileSystemLoopbackExternalDualAsyncSelfTest.java |  6 ++---
 ...FileSystemLoopbackExternalDualSyncSelfTest.java |  6 ++---
 ...pFileSystemLoopbackExternalPrimarySelfTest.java |  6 ++---
 ...ileSystemLoopbackExternalSecondarySelfTest.java |  6 ++---
 ...emLoopbackExternalToClientAbstractSelfTest.java |  6 ++---
 ...mLoopbackExternalToClientDualAsyncSelfTest.java |  6 ++---
 ...emLoopbackExternalToClientDualSyncSelfTest.java |  6 ++---
 ...temLoopbackExternalToClientPrimarySelfTest.java |  6 ++---
 ...ystemLoopbackExternalToClientProxySelfTest.java |  6 ++---
 ...gniteHadoopFileSystemShmemAbstractSelfTest.java |  6 ++---
 ...opFileSystemShmemExternalDualAsyncSelfTest.java |  6 ++---
 ...oopFileSystemShmemExternalDualSyncSelfTest.java |  6 ++---
 ...doopFileSystemShmemExternalPrimarySelfTest.java |  6 ++---
 ...opFileSystemShmemExternalSecondarySelfTest.java |  6 ++---
 ...ystemShmemExternalToClientAbstractSelfTest.java |  6 ++---
 ...stemShmemExternalToClientDualAsyncSelfTest.java |  6 ++---
 ...ystemShmemExternalToClientDualSyncSelfTest.java |  6 ++---
 ...SystemShmemExternalToClientPrimarySelfTest.java |  6 ++---
 ...leSystemShmemExternalToClientProxySelfTest.java |  6 ++---
 .../shuffle/collections/HadoopAbstractMapTest.java |  6 ++---
 .../HadoopConcurrentHashMultimapSelftest.java      |  6 ++---
 .../shuffle/collections/HadoopHashMapSelfTest.java |  6 ++---
 .../collections/HadoopSkipListSelfTest.java        |  6 ++---
 .../shuffle/streams/HadoopDataStreamSelfTest.java  |  6 ++---
 .../taskexecutor/HadoopExecutorServiceTest.java    |  6 ++---
 .../HadoopExternalTaskExecutionSelfTest.java       |  6 ++---
 .../HadoopExternalCommunicationSelfTest.java       |  6 ++---
 .../impl/util/BasicUserNameMapperSelfTest.java     |  6 ++---
 .../impl/util/ChainedUserNameMapperSelfTest.java   |  6 ++---
 .../impl/util/KerberosUserNameMapperSelfTest.java  |  6 ++---
 .../hadoop/state/HadoopGroupingTestState.java      |  6 ++---
 .../state/HadoopJobTrackerSelfTestState.java       |  6 ++---
 .../HadoopMapReduceEmbeddedSelfTestState.java      |  6 ++---
 .../state/HadoopTaskExecutionSelfTestValues.java   |  6 ++---
 .../ignite/testsuites/IgniteHadoopTestSuite.java   |  6 ++---
 .../IgniteIgfsLinuxAndMacOSTestSuite.java          |  6 ++---
 modules/hibernate-4.2/pom.xml                      |  6 ++---
 .../HibernateAbstractRegionAccessStrategy.java     |  6 ++---
 .../cache/hibernate/HibernateCollectionRegion.java |  6 ++---
 .../cache/hibernate/HibernateEntityRegion.java     |  6 ++---
 .../hibernate/HibernateGeneralDataRegion.java      |  6 ++---
 .../cache/hibernate/HibernateKeyWrapper.java       |  6 ++---
 .../cache/hibernate/HibernateNaturalIdRegion.java  |  6 ++---
 .../hibernate/HibernateQueryResultsRegion.java     |  6 ++---
 .../ignite/cache/hibernate/HibernateRegion.java    |  6 ++---
 .../cache/hibernate/HibernateRegionFactory.java    |  6 ++---
 .../cache/hibernate/HibernateTimestampsRegion.java |  6 ++---
 .../HibernateTransactionalDataRegion.java          |  6 ++---
 .../ignite/cache/hibernate/package-info.java       |  6 ++---
 .../store/hibernate/CacheHibernateBlobStore.java   |  6 ++---
 .../hibernate/CacheHibernateBlobStoreEntry.hbm.xml |  6 ++---
 .../hibernate/CacheHibernateBlobStoreEntry.java    |  6 ++---
 .../hibernate/CacheHibernateBlobStoreFactory.java  |  6 ++---
 .../CacheHibernateStoreSessionListener.java        |  6 ++---
 .../ignite/cache/store/hibernate/package-info.java |  6 ++---
 .../src/test/config/factory-cache.xml              |  6 ++---
 .../src/test/config/factory-cache1.xml             |  6 ++---
 .../test/config/factory-incorrect-store-cache.xml  |  6 ++---
 .../HibernateL2CacheConfigurationSelfTest.java     |  6 ++---
 .../hibernate/HibernateL2CacheMultiJvmTest.java    |  6 ++---
 .../cache/hibernate/HibernateL2CacheSelfTest.java  |  6 ++---
 .../HibernateL2CacheStrategySelfTest.java          |  6 ++---
 .../HibernateL2CacheTransactionalSelfTest.java     |  6 ++---
 ...bernateL2CacheTransactionalUseSyncSelfTest.java |  6 ++---
 .../CacheHibernateBlobStoreNodeRestartTest.java    |  6 ++---
 .../hibernate/CacheHibernateBlobStoreSelfTest.java |  6 ++---
 .../CacheHibernateStoreFactorySelfTest.java        |  6 ++---
 ...CacheHibernateStoreSessionListenerSelfTest.java |  6 ++---
 .../ignite/cache/store/hibernate/hibernate.cfg.xml |  6 ++---
 .../ignite/cache/store/hibernate/package-info.java |  6 ++---
 .../testsuites/IgniteHibernateTestSuite.java       |  6 ++---
 modules/hibernate-5.1/pom.xml                      |  6 ++---
 .../HibernateAbstractRegionAccessStrategy.java     |  6 ++---
 .../cache/hibernate/HibernateCollectionRegion.java |  6 ++---
 .../cache/hibernate/HibernateEntityRegion.java     |  6 ++---
 .../hibernate/HibernateGeneralDataRegion.java      |  6 ++---
 .../cache/hibernate/HibernateKeyWrapper.java       |  6 ++---
 .../cache/hibernate/HibernateNaturalIdRegion.java  |  6 ++---
 .../hibernate/HibernateQueryResultsRegion.java     |  6 ++---
 .../ignite/cache/hibernate/HibernateRegion.java    |  6 ++---
 .../cache/hibernate/HibernateRegionFactory.java    |  6 ++---
 .../cache/hibernate/HibernateTimestampsRegion.java |  6 ++---
 .../HibernateTransactionalDataRegion.java          |  6 ++---
 .../ignite/cache/hibernate/package-info.java       |  6 ++---
 .../store/hibernate/CacheHibernateBlobStore.java   |  6 ++---
 .../hibernate/CacheHibernateBlobStoreEntry.hbm.xml |  6 ++---
 .../hibernate/CacheHibernateBlobStoreEntry.java    |  6 ++---
 .../hibernate/CacheHibernateBlobStoreFactory.java  |  6 ++---
 .../CacheHibernateStoreSessionListener.java        |  6 ++---
 .../ignite/cache/store/hibernate/package-info.java |  6 ++---
 .../src/test/config/factory-cache.xml              |  6 ++---
 .../src/test/config/factory-cache1.xml             |  6 ++---
 .../test/config/factory-incorrect-store-cache.xml  |  6 ++---
 .../HibernateL2CacheConfigurationSelfTest.java     |  6 ++---
 .../hibernate/HibernateL2CacheMultiJvmTest.java    |  6 ++---
 .../cache/hibernate/HibernateL2CacheSelfTest.java  |  6 ++---
 .../HibernateL2CacheStrategySelfTest.java          |  6 ++---
 .../HibernateL2CacheTransactionalSelfTest.java     |  6 ++---
 ...bernateL2CacheTransactionalUseSyncSelfTest.java |  6 ++---
 .../CacheHibernateBlobStoreNodeRestartTest.java    |  6 ++---
 .../hibernate/CacheHibernateBlobStoreSelfTest.java |  6 ++---
 .../CacheHibernateStoreFactorySelfTest.java        |  6 ++---
 ...CacheHibernateStoreSessionListenerSelfTest.java |  6 ++---
 .../ignite/cache/store/hibernate/hibernate.cfg.xml |  6 ++---
 .../ignite/cache/store/hibernate/package-info.java |  6 ++---
 .../testsuites/IgniteHibernate5TestSuite.java      |  6 ++---
 modules/hibernate-5.3/pom.xml                      |  6 ++---
 .../cache/hibernate/HibernateKeyWrapper.java       |  6 ++---
 .../ignite/cache/hibernate/HibernateRegion.java    |  6 ++---
 .../cache/hibernate/HibernateRegionFactory.java    |  6 ++---
 .../hibernate/IgniteCachedDomainDataAccess.java    |  6 ++---
 .../hibernate/IgniteCollectionDataAccess.java      |  6 ++---
 .../cache/hibernate/IgniteDomainDataRegion.java    |  6 ++---
 .../cache/hibernate/IgniteEntityDataAccess.java    |  6 ++---
 .../cache/hibernate/IgniteGeneralDataRegion.java   |  6 ++---
 .../cache/hibernate/IgniteNaturalIdDataAccess.java |  6 ++---
 .../cache/hibernate/IgniteQueryResultsRegion.java  |  6 ++---
 .../cache/hibernate/IgniteTimestampsRegion.java    |  6 ++---
 .../ignite/cache/hibernate/package-info.java       |  6 ++---
 .../store/hibernate/CacheHibernateBlobStore.java   |  6 ++---
 .../hibernate/CacheHibernateBlobStoreEntry.java    |  6 ++---
 .../hibernate/CacheHibernateBlobStoreFactory.java  |  6 ++---
 .../CacheHibernateStoreSessionListener.java        |  6 ++---
 .../ignite/cache/store/hibernate/package-info.java |  6 ++---
 .../hibernate/CacheHibernateBlobStoreEntry.hbm.xml |  6 ++---
 .../src/test/config/factory-cache.xml              |  6 ++---
 .../src/test/config/factory-cache1.xml             |  6 ++---
 .../test/config/factory-incorrect-store-cache.xml  |  6 ++---
 .../HibernateL2CacheConfigurationSelfTest.java     |  6 ++---
 .../hibernate/HibernateL2CacheMultiJvmTest.java    |  6 ++---
 .../cache/hibernate/HibernateL2CacheSelfTest.java  |  6 ++---
 .../HibernateL2CacheStrategySelfTest.java          |  6 ++---
 .../HibernateL2CacheTransactionalSelfTest.java     |  6 ++---
 ...bernateL2CacheTransactionalUseSyncSelfTest.java |  6 ++---
 .../CacheHibernateBlobStoreNodeRestartTest.java    |  6 ++---
 .../hibernate/CacheHibernateBlobStoreSelfTest.java |  6 ++---
 .../CacheHibernateStoreFactorySelfTest.java        |  6 ++---
 ...CacheHibernateStoreSessionListenerSelfTest.java |  6 ++---
 .../ignite/cache/store/hibernate/hibernate.cfg.xml |  6 ++---
 .../ignite/cache/store/hibernate/package-info.java |  6 ++---
 .../testsuites/IgniteHibernate53TestSuite.java     |  6 ++---
 .../ignite/cache/store/hibernate/hibernate.cfg.xml |  6 ++---
 modules/hibernate-core/pom.xml                     |  6 ++---
 .../hibernate/HibernateAccessStrategyAdapter.java  |  6 ++---
 .../hibernate/HibernateAccessStrategyFactory.java  |  6 ++---
 .../cache/hibernate/HibernateCacheProxy.java       |  6 ++---
 .../hibernate/HibernateExceptionConverter.java     |  6 ++---
 .../cache/hibernate/HibernateKeyTransformer.java   |  6 ++---
 .../HibernateNonStrictAccessStrategy.java          |  6 ++---
 .../hibernate/HibernateReadOnlyAccessStrategy.java |  6 ++---
 .../HibernateReadWriteAccessStrategy.java          |  6 ++---
 .../HibernateTransactionalAccessStrategy.java      |  6 ++---
 .../ignite/cache/hibernate/package-info.java       |  6 ++---
 modules/ignored-tests/pom.xml                      |  6 ++---
 .../testsuites/IgniteIgnoredBinaryTestSuite.java   |  6 ++---
 .../ignite/testsuites/IgniteIgnoredTestSuite.java  |  6 ++---
 .../org/apache/ignite/testsuites/package-info.java |  6 ++---
 modules/indexing/pom.xml                           |  6 ++---
 .../ignite/internal/mxbean/SqlQueryMXBean.java     |  6 ++---
 .../ignite/internal/mxbean/SqlQueryMXBeanImpl.java |  6 ++---
 .../cache/query/GridCacheTwoStepQuery.java         |  6 ++---
 .../processors/cache/query/QueryTable.java         |  6 ++---
 .../cache/query/RegisteredQueryCursor.java         |  6 ++---
 .../processors/query/h2/CommandProcessor.java      |  6 ++---
 .../processors/query/h2/CommandResult.java         |  6 ++---
 .../processors/query/h2/ConnectionManager.java     |  6 ++---
 .../query/h2/DmlStatementsProcessor.java           |  6 ++---
 .../processors/query/h2/H2CachedStatementKey.java  |  6 ++---
 .../processors/query/h2/H2ConnectionWrapper.java   |  6 ++---
 .../internal/processors/query/h2/H2Cursor.java     |  6 ++---
 .../processors/query/h2/H2DatabaseType.java        |  6 ++---
 .../processors/query/h2/H2FieldsIterator.java      |  6 ++---
 .../processors/query/h2/H2KeyValueIterator.java    |  6 ++---
 .../internal/processors/query/h2/H2QueryInfo.java  |  6 ++---
 .../processors/query/h2/H2ResultSetIterator.java   |  6 ++---
 .../internal/processors/query/h2/H2RowCache.java   |  6 ++---
 .../processors/query/h2/H2RowCacheRegistry.java    |  6 ++---
 .../internal/processors/query/h2/H2Schema.java     |  6 ++---
 .../processors/query/h2/H2SqlFieldMetadata.java    |  6 ++---
 .../processors/query/h2/H2StatementCache.java      |  6 ++---
 .../processors/query/h2/H2TableDescriptor.java     |  6 ++---
 .../processors/query/h2/H2TableEngine.java         |  6 ++---
 .../internal/processors/query/h2/H2TypeKey.java    |  6 ++---
 .../internal/processors/query/h2/H2Utils.java      |  6 ++---
 .../processors/query/h2/IgniteH2Indexing.java      |  6 ++---
 .../processors/query/h2/IndexBuildClosure.java     |  6 ++---
 .../query/h2/IndexRebuildFullClosure.java          |  6 ++---
 .../query/h2/IndexRebuildPartialClosure.java       |  6 ++---
 .../internal/processors/query/h2/KillQueryRun.java |  6 ++---
 .../query/h2/LongRunningQueryManager.java          |  6 ++---
 .../processors/query/h2/MapH2QueryInfo.java        |  6 ++---
 .../processors/query/h2/QueryDescriptor.java       |  6 ++---
 .../processors/query/h2/QueryParameters.java       |  6 ++---
 .../internal/processors/query/h2/QueryParser.java  |  6 ++---
 .../processors/query/h2/QueryParserCacheEntry.java |  6 ++---
 .../processors/query/h2/QueryParserResult.java     |  6 ++---
 .../query/h2/QueryParserResultCommand.java         |  6 ++---
 .../processors/query/h2/QueryParserResultDml.java  |  6 ++---
 .../query/h2/QueryParserResultSelect.java          |  6 ++---
 .../processors/query/h2/ReduceH2QueryInfo.java     |  6 ++---
 .../processors/query/h2/SchemaManager.java         |  6 ++---
 .../processors/query/h2/ThreadLocalObjectPool.java |  6 ++---
 .../internal/processors/query/h2/UpdateResult.java |  6 ++---
 .../query/h2/affinity/H2PartitionResolver.java     |  6 ++---
 .../query/h2/affinity/PartitionExtractor.java      |  6 ++---
 .../processors/query/h2/database/H2IndexType.java  |  6 ++---
 .../query/h2/database/H2PkHashIndex.java           |  6 ++---
 .../processors/query/h2/database/H2Tree.java       |  6 ++---
 .../query/h2/database/H2TreeClientIndex.java       |  6 ++---
 .../query/h2/database/H2TreeFilterClosure.java     |  6 ++---
 .../processors/query/h2/database/H2TreeIndex.java  |  6 ++---
 .../query/h2/database/H2TreeIndexBase.java         |  6 ++---
 .../query/h2/database/IndexInformation.java        |  6 ++---
 .../query/h2/database/InlineIndexHelper.java       |  6 ++---
 .../h2/database/io/AbstractH2ExtrasInnerIO.java    |  6 ++---
 .../h2/database/io/AbstractH2ExtrasLeafIO.java     |  6 ++---
 .../query/h2/database/io/AbstractH2InnerIO.java    |  6 ++---
 .../query/h2/database/io/AbstractH2LeafIO.java     |  6 ++---
 .../query/h2/database/io/H2ExtrasInnerIO.java      |  6 ++---
 .../query/h2/database/io/H2ExtrasLeafIO.java       |  6 ++---
 .../processors/query/h2/database/io/H2IOUtils.java |  6 ++---
 .../processors/query/h2/database/io/H2InnerIO.java |  6 ++---
 .../processors/query/h2/database/io/H2LeafIO.java  |  6 ++---
 .../query/h2/database/io/H2MvccExtrasInnerIO.java  |  6 ++---
 .../query/h2/database/io/H2MvccExtrasLeafIO.java   |  6 ++---
 .../query/h2/database/io/H2MvccInnerIO.java        |  6 ++---
 .../query/h2/database/io/H2MvccLeafIO.java         |  6 ++---
 .../query/h2/database/io/H2RowLinkIO.java          |  6 ++---
 .../processors/query/h2/dml/DmlArgument.java       |  6 ++---
 .../processors/query/h2/dml/DmlArguments.java      |  6 ++---
 .../processors/query/h2/dml/DmlAstUtils.java       |  6 ++---
 .../processors/query/h2/dml/DmlBatchSender.java    |  6 ++---
 .../query/h2/dml/DmlBulkLoadDataConverter.java     |  6 ++---
 .../query/h2/dml/DmlDistributedPlanInfo.java       |  6 ++---
 .../query/h2/dml/DmlDistributedUpdateRun.java      |  6 ++---
 .../query/h2/dml/DmlPageProcessingErrorResult.java |  6 ++---
 .../query/h2/dml/DmlPageProcessingResult.java      |  6 ++---
 .../query/h2/dml/DmlUpdateResultsIterator.java     |  6 ++---
 .../query/h2/dml/DmlUpdateSingleEntryIterator.java |  6 ++---
 .../internal/processors/query/h2/dml/DmlUtils.java |  6 ++---
 .../processors/query/h2/dml/FastUpdate.java        |  6 ++---
 .../processors/query/h2/dml/KeyValueSupplier.java  |  6 ++---
 .../processors/query/h2/dml/UpdateMode.java        |  6 ++---
 .../processors/query/h2/dml/UpdatePlan.java        |  6 ++---
 .../processors/query/h2/dml/UpdatePlanBuilder.java |  6 ++---
 .../processors/query/h2/dml/package-info.java      |  6 ++---
 .../processors/query/h2/opt/GridH2Cursor.java      |  6 ++---
 .../query/h2/opt/GridH2DefaultTableEngine.java     |  6 ++---
 .../processors/query/h2/opt/GridH2IndexBase.java   |  6 ++---
 .../processors/query/h2/opt/GridH2MetaTable.java   |  6 ++---
 .../processors/query/h2/opt/GridH2ProxyIndex.java  |  6 ++---
 .../query/h2/opt/GridH2ProxySpatialIndex.java      |  6 ++---
 .../query/h2/opt/GridH2RetryException.java         |  6 ++---
 .../query/h2/opt/GridH2RowDescriptor.java          |  6 ++---
 .../processors/query/h2/opt/GridH2Table.java       |  6 ++---
 .../query/h2/opt/GridH2ValueCacheObject.java       |  6 ++---
 .../query/h2/opt/GridLuceneDirectory.java          |  6 ++---
 .../processors/query/h2/opt/GridLuceneFile.java    |  6 ++---
 .../processors/query/h2/opt/GridLuceneIndex.java   |  6 ++---
 .../query/h2/opt/GridLuceneInputStream.java        |  6 ++---
 .../query/h2/opt/GridLuceneLockFactory.java        |  6 ++---
 .../query/h2/opt/GridLuceneOutputStream.java       |  6 ++---
 .../processors/query/h2/opt/H2CacheRow.java        |  6 ++---
 .../processors/query/h2/opt/H2PlainRow.java        |  6 ++---
 .../processors/query/h2/opt/H2PlainRowFactory.java |  6 ++---
 .../processors/query/h2/opt/H2PlainRowPair.java    |  6 ++---
 .../processors/query/h2/opt/H2PlainRowSingle.java  |  6 ++---
 .../internal/processors/query/h2/opt/H2Row.java    |  6 ++---
 .../processors/query/h2/opt/H2ScanIndex.java       |  6 ++---
 .../processors/query/h2/opt/H2TableScanIndex.java  |  6 ++---
 .../processors/query/h2/opt/QueryContext.java      |  6 ++---
 .../processors/query/h2/opt/QueryContextKey.java   |  6 ++---
 .../query/h2/opt/QueryContextRegistry.java         |  6 ++---
 .../query/h2/opt/join/BroadcastCursor.java         |  6 ++---
 .../query/h2/opt/join/CollocationModel.java        |  6 ++---
 .../h2/opt/join/CollocationModelAffinity.java      |  6 ++---
 .../h2/opt/join/CollocationModelMultiplier.java    |  6 ++---
 .../query/h2/opt/join/CollocationModelType.java    |  6 ++---
 .../query/h2/opt/join/CursorIteratorWrapper.java   |  6 ++---
 .../query/h2/opt/join/DistributedJoinContext.java  |  6 ++---
 .../query/h2/opt/join/DistributedLookupBatch.java  |  6 ++---
 .../h2/opt/join/ProxyDistributedLookupBatch.java   |  6 ++---
 .../processors/query/h2/opt/join/RangeSource.java  |  6 ++---
 .../processors/query/h2/opt/join/RangeStream.java  |  6 ++---
 .../processors/query/h2/opt/join/SegmentKey.java   |  6 ++---
 .../processors/query/h2/opt/join/SourceKey.java    |  6 ++---
 .../query/h2/opt/join/UnicastCursor.java           |  6 ++---
 .../internal/processors/query/h2/package-info.java |  6 ++---
 .../query/h2/sql/GridSqlAggregateFunction.java     |  6 ++---
 .../processors/query/h2/sql/GridSqlAlias.java      |  6 ++---
 .../query/h2/sql/GridSqlAlterTableAddColumn.java   |  6 ++---
 .../query/h2/sql/GridSqlAlterTableDropColumn.java  |  6 ++---
 .../processors/query/h2/sql/GridSqlArray.java      |  6 ++---
 .../processors/query/h2/sql/GridSqlAst.java        |  6 ++---
 .../processors/query/h2/sql/GridSqlColumn.java     |  6 ++---
 .../processors/query/h2/sql/GridSqlConst.java      |  6 ++---
 .../query/h2/sql/GridSqlCreateIndex.java           |  6 ++---
 .../query/h2/sql/GridSqlCreateTable.java           |  6 ++---
 .../processors/query/h2/sql/GridSqlDelete.java     |  6 ++---
 .../processors/query/h2/sql/GridSqlDropIndex.java  |  6 ++---
 .../processors/query/h2/sql/GridSqlDropTable.java  |  6 ++---
 .../processors/query/h2/sql/GridSqlElement.java    |  6 ++---
 .../processors/query/h2/sql/GridSqlFunction.java   |  6 ++---
 .../query/h2/sql/GridSqlFunctionType.java          |  6 ++---
 .../processors/query/h2/sql/GridSqlInsert.java     |  6 ++---
 .../processors/query/h2/sql/GridSqlJoin.java       |  6 ++---
 .../processors/query/h2/sql/GridSqlKeyword.java    |  6 ++---
 .../processors/query/h2/sql/GridSqlMerge.java      |  6 ++---
 .../processors/query/h2/sql/GridSqlOperation.java  |  6 ++---
 .../query/h2/sql/GridSqlOperationType.java         |  6 ++---
 .../processors/query/h2/sql/GridSqlParameter.java  |  6 ++---
 .../query/h2/sql/GridSqlPlaceholder.java           |  6 ++---
 .../processors/query/h2/sql/GridSqlQuery.java      |  6 ++---
 .../query/h2/sql/GridSqlQueryParser.java           |  6 ++---
 .../query/h2/sql/GridSqlQuerySplitter.java         |  6 ++---
 .../processors/query/h2/sql/GridSqlSelect.java     |  6 ++---
 .../processors/query/h2/sql/GridSqlSortColumn.java |  6 ++---
 .../processors/query/h2/sql/GridSqlStatement.java  |  6 ++---
 .../processors/query/h2/sql/GridSqlSubquery.java   |  6 ++---
 .../processors/query/h2/sql/GridSqlTable.java      |  6 ++---
 .../processors/query/h2/sql/GridSqlType.java       |  6 ++---
 .../processors/query/h2/sql/GridSqlUnion.java      |  6 ++---
 .../processors/query/h2/sql/GridSqlUpdate.java     |  6 ++---
 .../query/h2/sql/SplitterAndCondition.java         |  6 ++---
 .../processors/query/h2/sql/SplitterContext.java   |  6 ++---
 .../query/h2/sql/SplitterQueryModel.java           |  6 ++---
 .../query/h2/sql/SplitterQueryModelType.java       |  6 ++---
 .../processors/query/h2/sql/SplitterUtils.java     |  6 ++---
 .../processors/query/h2/sys/SqlSystemIndex.java    |  6 ++---
 .../processors/query/h2/sys/SqlSystemTable.java    |  6 ++---
 .../query/h2/sys/SqlSystemTableEngine.java         |  6 ++---
 .../h2/sys/view/SqlAbstractLocalSystemView.java    |  6 ++---
 .../query/h2/sys/view/SqlAbstractSystemView.java   |  6 ++---
 .../query/h2/sys/view/SqlSystemView.java           |  6 ++---
 .../h2/sys/view/SqlSystemViewBaselineNodes.java    |  6 ++---
 .../h2/sys/view/SqlSystemViewCacheGroups.java      |  6 ++---
 .../view/SqlSystemViewCacheGroupsIOStatistics.java |  6 ++---
 .../query/h2/sys/view/SqlSystemViewCaches.java     |  6 ++---
 .../h2/sys/view/SqlSystemViewColumnCondition.java  |  6 ++---
 .../query/h2/sys/view/SqlSystemViewIndexes.java    |  6 ++---
 .../h2/sys/view/SqlSystemViewNodeAttributes.java   |  6 ++---
 .../h2/sys/view/SqlSystemViewNodeMetrics.java      |  6 ++---
 .../query/h2/sys/view/SqlSystemViewNodes.java      |  6 ++---
 .../sys/view/SqlSystemViewQueryHistoryMetrics.java |  6 ++---
 .../h2/sys/view/SqlSystemViewRunningQueries.java   |  6 ++---
 .../query/h2/sys/view/SqlSystemViewSchemas.java    |  6 ++---
 .../query/h2/sys/view/SqlSystemViewTables.java     |  6 ++---
 .../query/h2/twostep/GridMapQueryExecutor.java     |  6 ++---
 .../query/h2/twostep/GridReduceQueryExecutor.java  |  6 ++---
 .../query/h2/twostep/MapNodeResults.java           |  6 ++---
 .../query/h2/twostep/MapQueryResult.java           |  6 ++---
 .../query/h2/twostep/MapQueryResults.java          |  6 ++---
 .../processors/query/h2/twostep/MapRequestKey.java |  6 ++---
 .../query/h2/twostep/PartitionReservation.java     |  6 ++---
 .../query/h2/twostep/PartitionReservationKey.java  |  6 ++---
 .../h2/twostep/PartitionReservationManager.java    |  6 ++---
 .../query/h2/twostep/ReduceBlockList.java          |  6 ++---
 .../processors/query/h2/twostep/ReduceIndex.java   |  6 ++---
 .../query/h2/twostep/ReduceIndexIterator.java      |  6 ++---
 .../query/h2/twostep/ReduceIndexSorted.java        |  6 ++---
 .../query/h2/twostep/ReduceIndexUnsorted.java      |  6 ++---
 .../query/h2/twostep/ReducePartitionMapResult.java |  6 ++---
 .../query/h2/twostep/ReducePartitionMapper.java    |  6 ++---
 .../h2/twostep/ReducePartitionsSpecializer.java    |  6 ++---
 .../query/h2/twostep/ReduceQueryRun.java           |  6 ++---
 .../query/h2/twostep/ReduceResultPage.java         |  6 ++---
 .../query/h2/twostep/ReduceSourceKey.java          |  6 ++---
 .../processors/query/h2/twostep/ReduceTable.java   |  6 ++---
 .../query/h2/twostep/ReduceTableEngine.java        |  6 ++---
 .../query/h2/twostep/ReduceTableWrapper.java       |  6 ++---
 .../query/h2/twostep/msg/GridH2Array.java          |  6 ++---
 .../query/h2/twostep/msg/GridH2Boolean.java        |  6 ++---
 .../query/h2/twostep/msg/GridH2Byte.java           |  6 ++---
 .../query/h2/twostep/msg/GridH2Bytes.java          |  6 ++---
 .../query/h2/twostep/msg/GridH2CacheObject.java    |  6 ++---
 .../query/h2/twostep/msg/GridH2Date.java           |  6 ++---
 .../query/h2/twostep/msg/GridH2Decimal.java        |  6 ++---
 .../query/h2/twostep/msg/GridH2DmlRequest.java     |  6 ++---
 .../query/h2/twostep/msg/GridH2DmlResponse.java    |  6 ++---
 .../query/h2/twostep/msg/GridH2Double.java         |  6 ++---
 .../query/h2/twostep/msg/GridH2Float.java          |  6 ++---
 .../query/h2/twostep/msg/GridH2Geometry.java       |  6 ++---
 .../h2/twostep/msg/GridH2IndexRangeRequest.java    |  6 ++---
 .../h2/twostep/msg/GridH2IndexRangeResponse.java   |  6 ++---
 .../query/h2/twostep/msg/GridH2Integer.java        |  6 ++---
 .../query/h2/twostep/msg/GridH2JavaObject.java     |  6 ++---
 .../query/h2/twostep/msg/GridH2Long.java           |  6 ++---
 .../query/h2/twostep/msg/GridH2Null.java           |  6 ++---
 .../query/h2/twostep/msg/GridH2QueryRequest.java   |  6 ++---
 .../query/h2/twostep/msg/GridH2RowMessage.java     |  6 ++---
 .../query/h2/twostep/msg/GridH2RowRange.java       |  6 ++---
 .../query/h2/twostep/msg/GridH2RowRangeBounds.java |  6 ++---
 .../msg/GridH2SelectForUpdateTxDetails.java        |  6 ++---
 .../query/h2/twostep/msg/GridH2Short.java          |  6 ++---
 .../query/h2/twostep/msg/GridH2String.java         |  6 ++---
 .../query/h2/twostep/msg/GridH2Time.java           |  6 ++---
 .../query/h2/twostep/msg/GridH2Timestamp.java      |  6 ++---
 .../query/h2/twostep/msg/GridH2Uuid.java           |  6 ++---
 .../query/h2/twostep/msg/GridH2ValueMessage.java   |  6 ++---
 .../h2/twostep/msg/GridH2ValueMessageFactory.java  |  6 ++---
 .../visor/verify/ValidateIndexesClosure.java       |  6 ++---
 .../visor/verify/VisorValidateIndexesTask.java     |  6 ++---
 .../org/apache/ignite/client/ClientTestSuite.java  |  6 ++---
 .../apache/ignite/client/FunctionalQueryTest.java  |  6 ++---
 .../ignite/client/IgniteBinaryQueryTest.java       |  6 ++---
 .../org/apache/ignite/client/SecurityTest.java     |  6 ++---
 ...finityKeyNameAndValueFieldNameConflictTest.java |  6 ++---
 .../processors/cache/BigEntryQueryTest.java        |  6 ++---
 ...aryMetadataConcurrentUpdateWithIndexesTest.java |  6 ++---
 .../cache/BinarySerializationQuerySelfTest.java    |  6 ++---
 ...ationQueryWithReflectiveSerializerSelfTest.java |  6 ++---
 .../cache/BinaryTypeMismatchLoggingTest.java       |  6 ++---
 .../cache/BinaryTypeRegistrationTest.java          |  6 ++---
 .../CacheAbstractQueryDetailMetricsSelfTest.java   |  6 ++---
 .../cache/CacheAbstractQueryMetricsSelfTest.java   |  6 ++---
 .../cache/CacheBinaryKeyConcurrentQueryTest.java   |  6 ++---
 .../cache/CacheConfigurationP2PTest.java           |  6 ++---
 .../cache/CacheConfigurationP2PTestServer.java     |  6 ++---
 .../processors/cache/CacheIndexStreamerTest.java   |  6 ++---
 .../cache/CacheIteratorScanQueryTest.java          |  6 ++---
 .../CacheLocalQueryDetailMetricsSelfTest.java      |  6 ++---
 .../cache/CacheLocalQueryMetricsSelfTest.java      |  6 ++---
 .../cache/CacheOffheapBatchIndexingBaseTest.java   |  6 ++---
 .../CacheOffheapBatchIndexingMultiTypeTest.java    |  6 ++---
 .../CacheOffheapBatchIndexingSingleTypeTest.java   |  6 ++---
 .../cache/CacheOperationsWithExpirationTest.java   |  6 ++---
 ...ionedQueryDetailMetricsDistributedSelfTest.java |  6 ++---
 ...PartitionedQueryDetailMetricsLocalSelfTest.java |  6 ++---
 ...PartitionedQueryMetricsDistributedSelfTest.java |  6 ++---
 .../CachePartitionedQueryMetricsLocalSelfTest.java |  6 ++---
 ...acheQueryAfterDynamicCacheStartFailureTest.java | 28 +++++++++++-----------
 .../processors/cache/CacheQueryBuildValueTest.java |  6 ++---
 .../cache/CacheQueryEvictDataLostTest.java         |  6 ++---
 .../cache/CacheQueryFilterExpiredTest.java         |  6 ++---
 .../cache/CacheQueryNewClientSelfTest.java         |  6 ++---
 .../CacheRandomOperationsMultithreadedTest.java    |  6 ++---
 ...catedQueryDetailMetricsDistributedSelfTest.java |  6 ++---
 ...eReplicatedQueryDetailMetricsLocalSelfTest.java |  6 ++---
 ...eReplicatedQueryMetricsDistributedSelfTest.java |  6 ++---
 .../CacheReplicatedQueryMetricsLocalSelfTest.java  |  6 ++---
 .../CacheScanPartitionQueryFallbackSelfTest.java   |  6 ++---
 .../cache/CacheSqlQueryValueCopySelfTest.java      |  6 ++---
 .../ClientReconnectAfterClusterRestartTest.java    |  6 ++---
 .../cache/ClusterReadOnlyModeSqlTest.java          |  6 ++---
 .../processors/cache/DdlTransactionSelfTest.java   |  6 ++---
 .../cache/GridCacheCrossCacheQuerySelfTest.java    |  6 ++---
 ...GridCacheDynamicLoadOnClientPersistentTest.java |  6 ++---
 .../cache/GridCacheDynamicLoadOnClientTest.java    |  6 ++---
 .../cache/GridCacheFullTextQuerySelfTest.java      |  6 ++---
 .../GridCacheLazyQueryPartitionsReleaseTest.java   |  6 ++---
 .../processors/cache/GridCacheOffHeapSelfTest.java |  6 ++---
 .../cache/GridCacheOffheapIndexEntryEvictTest.java |  6 ++---
 .../cache/GridCacheOffheapIndexGetSelfTest.java    |  6 ++---
 .../cache/GridCacheQueryIndexDisabledSelfTest.java |  6 ++---
 .../cache/GridCacheQuerySerializationSelfTest.java |  6 ++---
 .../cache/GridCacheQuerySimpleBenchmark.java       |  6 ++---
 .../processors/cache/GridCacheQueryTestValue.java  |  6 ++---
 .../cache/GridIndexingWithNoopSwapSelfTest.java    |  6 ++---
 .../IgniteBinaryObjectFieldsQuerySelfTest.java     |  6 ++---
 .../IgniteBinaryObjectLocalQueryArgumentsTest.java |  6 ++---
 .../IgniteBinaryObjectQueryArgumentsTest.java      |  6 ++---
 ...niteBinaryWrappedObjectFieldsQuerySelfTest.java |  6 ++---
 .../IgniteCacheAbstractFieldsQuerySelfTest.java    |  6 ++---
 .../IgniteCacheAbstractInsertSqlQuerySelfTest.java |  6 ++---
 .../cache/IgniteCacheAbstractQuerySelfTest.java    |  6 ++---
 .../IgniteCacheAbstractSqlDmlQuerySelfTest.java    |  6 ++---
 .../cache/IgniteCacheCollocatedQuerySelfTest.java  |  6 ++---
 .../IgniteCacheConfigVariationsQueryTest.java      |  6 ++---
 ...teCacheConfigurationPrimitiveTypesSelfTest.java |  6 ++---
 .../cache/IgniteCacheCrossCacheJoinRandomTest.java |  6 ++---
 .../cache/IgniteCacheDeleteSqlQuerySelfTest.java   |  6 ++---
 ...teCacheDistributedJoinCollocatedAndNotTest.java |  6 ++---
 ...teCacheDistributedJoinCustomAffinityMapper.java |  6 ++---
 .../IgniteCacheDistributedJoinNoIndexTest.java     |  6 ++---
 ...istributedJoinPartitionedAndReplicatedTest.java |  6 ++---
 ...iteCacheDistributedJoinQueryConditionsTest.java |  6 ++---
 .../cache/IgniteCacheDistributedJoinTest.java      |  6 ++---
 ...eCacheDuplicateEntityConfigurationSelfTest.java |  6 ++---
 .../IgniteCacheFieldsQueryNoDataSelfTest.java      |  6 ++---
 ...gniteCacheFullTextQueryNodeJoiningSelfTest.java |  6 ++---
 .../processors/cache/IgniteCacheGroupsSqlTest.java |  6 ++---
 .../cache/IgniteCacheInsertSqlQuerySelfTest.java   |  6 ++---
 ...oinPartitionedAndReplicatedCollocationTest.java |  6 ++---
 ...gniteCacheJoinPartitionedAndReplicatedTest.java |  6 ++---
 .../IgniteCacheJoinQueryWithAffinityKeyTest.java   |  6 ++---
 .../cache/IgniteCacheLargeResultSelfTest.java      |  6 ++---
 ...acheLockPartitionOnAffinityRunAbstractTest.java |  6 ++---
 ...ockPartitionOnAffinityRunAtomicCacheOpTest.java |  6 ++---
 .../IgniteCacheLockPartitionOnAffinityRunTest.java |  6 ++---
 ...cheLockPartitionOnAffinityRunTxCacheOpTest.java |  6 ++---
 ...PartitionOnAffinityRunWithCollisionSpiTest.java |  6 ++---
 .../cache/IgniteCacheMergeSqlQuerySelfTest.java    |  6 ++---
 .../cache/IgniteCacheMultipleIndexedTypesTest.java |  6 ++---
 .../cache/IgniteCacheNoClassQuerySelfTest.java     |  6 ++---
 .../IgniteCacheObjectKeyIndexingSelfTest.java      |  6 ++---
 .../cache/IgniteCacheOffheapEvictQueryTest.java    |  6 ++---
 .../cache/IgniteCacheOffheapIndexScanTest.java     |  6 ++---
 .../IgniteCacheP2pUnmarshallingQueryErrorTest.java |  6 ++---
 ...CachePartitionedQueryMultiThreadedSelfTest.java |  6 ++---
 .../IgniteCachePrimitiveFieldsQuerySelfTest.java   |  6 ++---
 .../cache/IgniteCacheQueriesLoadTest1.java         |  6 ++---
 ...gniteCacheQueryEvictsMultiThreadedSelfTest.java |  6 ++---
 .../cache/IgniteCacheQueryH2IndexingLeakTest.java  |  6 ++---
 .../cache/IgniteCacheQueryIndexSelfTest.java       |  6 ++---
 .../cache/IgniteCacheQueryLoadSelfTest.java        |  6 ++---
 .../IgniteCacheQueryMultiThreadedSelfTest.java     |  6 ++---
 .../cache/IgniteCacheSqlDmlErrorSelfTest.java      |  6 ++---
 .../IgniteCacheSqlInsertValidationSelfTest.java    |  6 ++---
 .../cache/IgniteCacheSqlQueryErrorSelfTest.java    |  6 ++---
 .../IgniteCacheSqlQueryMultiThreadedSelfTest.java  |  6 ++---
 .../IgniteCacheStarvationOnRebalanceTest.java      |  6 ++---
 .../cache/IgniteCacheUnionDuplicatesTest.java      |  6 ++---
 .../cache/IgniteCacheUpdateSqlQuerySelfTest.java   |  6 ++---
 ...iteCheckClusterStateBeforeExecuteQueryTest.java |  6 ++---
 ...iteClientReconnectCacheQueriesFailoverTest.java |  6 ++---
 .../cache/IgniteClientReconnectQueriesTest.java    |  6 ++---
 .../cache/IgniteCrossCachesJoinsQueryTest.java     |  6 ++---
 .../cache/IgniteDynamicSqlRestoreTest.java         |  6 ++---
 .../cache/IgniteErrorOnRebalanceTest.java          |  6 ++---
 ...hIndexingAndGroupPutGetPersistenceSelfTest.java |  6 ++---
 ...ingleNodeWithIndexingPutGetPersistenceTest.java |  6 ++---
 .../processors/cache/IncorrectQueryEntityTest.java |  6 ++---
 .../IndexingCachePartitionLossPolicySelfTest.java  |  6 ++---
 .../cache/QueryEntityCaseMismatchTest.java         |  6 ++---
 .../QueryJoinWithDifferentNodeFiltersTest.java     |  6 ++---
 .../processors/cache/SqlFieldsQuerySelfTest.java   |  6 ++---
 .../cache/StartCachesInParallelTest.java           |  6 ++---
 .../authentication/SqlUserCommandSelfTest.java     |  6 ++---
 .../CacheBlockOnCreateDestoryIndexTest.java        |  6 ++---
 .../distributed/CacheBlockOnSqlQueryTest.java      |  6 ++---
 .../near/IgniteCacheAtomicFieldsQuerySelfTest.java |  6 ++---
 ...eCacheAtomicNearEnabledFieldsQuerySelfTest.java |  6 ++---
 .../IgniteCacheAtomicNearEnabledQuerySelfTest.java |  6 ++---
 .../near/IgniteCacheAtomicQuerySelfTest.java       |  6 ++---
 ...heClientQueryReplicatedNodeRestartSelfTest.java |  6 ++---
 ...eDistributedPartitionQueryAbstractSelfTest.java |  6 ++---
 ...ributedPartitionQueryConfigurationSelfTest.java |  6 ++---
 ...tributedPartitionQueryNodeRestartsSelfTest.java |  6 ++---
 ...niteCacheDistributedPartitionQuerySelfTest.java |  6 ++---
 .../IgniteCacheDistributedQueryCancelSelfTest.java |  6 ++---
 ...tributedQueryStopOnCancelOrTimeoutSelfTest.java |  6 ++---
 ...hePartitionedFieldsQueryP2PEnabledSelfTest.java |  6 ++---
 .../IgniteCachePartitionedFieldsQuerySelfTest.java |  6 ++---
 ...eCachePartitionedQueryEvtsDisabledSelfTest.java |  6 ++---
 ...teCachePartitionedQueryP2PDisabledSelfTest.java |  6 ++---
 .../near/IgniteCachePartitionedQuerySelfTest.java  |  6 ++---
 ...chePartitionedSnapshotEnabledQuerySelfTest.java |  6 ++---
 ...eCacheQueryAbstractDistributedJoinSelfTest.java |  6 ++---
 .../near/IgniteCacheQueryNoRebalanceSelfTest.java  |  6 ++---
 .../near/IgniteCacheQueryNodeFailTest.java         |  6 ++---
 ...cheQueryNodeRestartDistributedJoinSelfTest.java |  6 ++---
 .../near/IgniteCacheQueryNodeRestartSelfTest.java  |  6 ++---
 .../near/IgniteCacheQueryNodeRestartSelfTest2.java |  6 ++---
 .../IgniteCacheQueryNodeRestartTxSelfTest.java     |  6 ++---
 ...opOnCancelOrTimeoutDistributedJoinSelfTest.java |  6 ++---
 .../near/IgniteSqlQueryWithBaselineTest.java       |  6 ++---
 ...FieldsQueryJoinNoPrimaryPartitionsSelfTest.java |  6 ++---
 ...cheReplicatedFieldsQueryP2PEnabledSelfTest.java |  6 ++---
 ...IgniteCacheReplicatedFieldsQueryROSelfTest.java |  6 ++---
 .../IgniteCacheReplicatedFieldsQuerySelfTest.java  |  6 ++---
 ...teCacheReplicatedQueryEvtsDisabledSelfTest.java |  6 ++---
 ...iteCacheReplicatedQueryP2PDisabledSelfTest.java |  6 ++---
 .../IgniteCacheReplicatedQuerySelfTest.java        |  6 ++---
 .../cache/encryption/EncryptedSqlTableTest.java    |  6 ++---
 .../cache/index/AbstractIndexingCommonTest.java    |  6 ++---
 .../cache/index/AbstractSchemaSelfTest.java        |  6 ++---
 .../cache/index/BasicIndexMultinodeTest.java       |  6 ++---
 .../processors/cache/index/BasicIndexTest.java     |  6 ++---
 .../index/ComplexPrimaryKeyUnwrapSelfTest.java     |  6 ++---
 .../index/ComplexSecondaryKeyUnwrapSelfTest.java   |  6 ++---
 .../index/DuplicateKeyValueClassesSelfTest.java    |  6 ++---
 .../DynamicColumnsAbstractConcurrentSelfTest.java  |  6 ++---
 .../cache/index/DynamicColumnsAbstractTest.java    |  6 ++---
 ...ColumnsConcurrentAtomicPartitionedSelfTest.java |  6 ++---
 ...cColumnsConcurrentAtomicReplicatedSelfTest.java |  6 ++---
 ...ConcurrentTransactionalPartitionedSelfTest.java |  6 ++---
 ...sConcurrentTransactionalReplicatedSelfTest.java |  6 ++---
 .../index/DynamicIndexAbstractBasicSelfTest.java   |  6 ++---
 .../DynamicIndexAbstractConcurrentSelfTest.java    |  6 ++---
 .../cache/index/DynamicIndexAbstractSelfTest.java  |  6 ++---
 .../index/DynamicIndexClientBasicSelfTest.java     |  6 ++---
 ...icIndexPartitionedAtomicConcurrentSelfTest.java |  6 ++---
 ...PartitionedTransactionalConcurrentSelfTest.java |  6 ++---
 ...micIndexReplicatedAtomicConcurrentSelfTest.java |  6 ++---
 ...xReplicatedTransactionalConcurrentSelfTest.java |  6 ++---
 .../index/DynamicIndexServerBasicSelfTest.java     |  6 ++---
 ...DynamicIndexServerCoordinatorBasicSelfTest.java |  6 ++---
 .../DynamicIndexServerNodeFIlterBasicSelfTest.java |  6 ++---
 ...exServerNodeFilterCoordinatorBasicSelfTest.java |  6 ++---
 .../cache/index/H2ConnectionLeaksSelfTest.java     |  6 ++---
 .../H2DynamicColumnsAbstractBasicSelfTest.java     |  6 ++---
 .../index/H2DynamicColumnsClientBasicSelfTest.java |  6 ++---
 .../index/H2DynamicColumnsServerBasicSelfTest.java |  6 ++---
 ...namicColumnsServerCoordinatorBasicSelfTest.java |  6 ++---
 .../index/H2DynamicIndexAbstractSelfTest.java      |  6 ++---
 ...2DynamicIndexAtomicPartitionedNearSelfTest.java |  6 ++---
 .../H2DynamicIndexAtomicPartitionedSelfTest.java   |  6 ++---
 .../H2DynamicIndexAtomicReplicatedSelfTest.java    |  6 ++---
 ...cIndexTransactionalPartitionedNearSelfTest.java |  6 ++---
 ...namicIndexTransactionalPartitionedSelfTest.java |  6 ++---
 ...ynamicIndexTransactionalReplicatedSelfTest.java |  6 ++---
 .../H2DynamicIndexingComplexAbstractTest.java      |  6 ++---
 ...omplexClientAtomicPartitionedNoBackupsTest.java |  6 ++---
 ...IndexingComplexClientAtomicPartitionedTest.java |  6 ++---
 ...cIndexingComplexClientAtomicReplicatedTest.java |  6 ++---
 ...lientTransactionalPartitionedNoBackupsTest.java |  6 ++---
 ...gComplexClientTransactionalPartitionedTest.java |  6 ++---
 ...ngComplexClientTransactionalReplicatedTest.java |  6 ++---
 ...omplexServerAtomicPartitionedNoBackupsTest.java |  6 ++---
 ...IndexingComplexServerAtomicPartitionedTest.java |  6 ++---
 ...cIndexingComplexServerAtomicReplicatedTest.java |  6 ++---
 ...erverTransactionalPartitionedNoBackupsTest.java |  6 ++---
 ...gComplexServerTransactionalPartitionedTest.java |  6 ++---
 ...ngComplexServerTransactionalReplicatedTest.java |  6 ++---
 .../cache/index/H2DynamicTableSelfTest.java        |  6 ++---
 .../cache/index/H2RowCachePageEvictionTest.java    |  6 ++---
 .../processors/cache/index/H2RowCacheSelfTest.java |  6 ++---
 .../cache/index/H2RowExpireTimeIndexSelfTest.java  |  6 ++---
 .../cache/index/IgniteDecimalSelfTest.java         |  6 ++---
 .../index/IoStatisticsBasicIndexSelfTest.java      |  6 ++---
 .../processors/cache/index/LongIndexNameTest.java  |  6 ++---
 .../cache/index/MvccEmptyTransactionSelfTest.java  |  6 ++---
 .../index/OptimizedMarshallerIndexNameTest.java    |  6 ++---
 .../cache/index/QueryEntityValidationSelfTest.java |  6 ++---
 .../cache/index/SchemaExchangeSelfTest.java        |  6 ++---
 ...ransactionCommandsWithMvccDisabledSelfTest.java |  6 ++---
 ...ransactionsCommandsWithMvccEnabledSelfTest.java |  6 ++---
 .../cache/index/SqlTransactionsSelfTest.java       |  6 ++---
 .../StaticCacheDdlKeepStaticConfigurationTest.java |  6 ++---
 .../processors/cache/index/StaticCacheDdlTest.java |  6 ++---
 .../local/IgniteCacheLocalAtomicQuerySelfTest.java |  6 ++---
 .../local/IgniteCacheLocalFieldsQuerySelfTest.java |  6 ++---
 ...niteCacheLocalQueryCancelOrTimeoutSelfTest.java |  6 ++---
 .../cache/local/IgniteCacheLocalQuerySelfTest.java |  6 ++---
 .../CacheMvccAbstractContinuousQuerySelfTest.java  |  6 ++---
 ...acheMvccAbstractSqlContinuousQuerySelfTest.java |  6 ++---
 ...acheMvccAbstractSqlCoordinatorFailoverTest.java |  6 ++---
 .../cache/mvcc/CacheMvccBackupsAbstractTest.java   |  6 ++---
 .../mvcc/CacheMvccBasicContinuousQueryTest.java    |  6 ++---
 .../cache/mvcc/CacheMvccBulkLoadTest.java          |  6 ++---
 ...acheMvccClientReconnectContinuousQueryTest.java |  6 ++---
 .../CacheMvccContinuousQueryBackupQueueTest.java   |  6 ++---
 ...acheMvccContinuousQueryClientReconnectTest.java |  6 ++---
 .../mvcc/CacheMvccContinuousQueryClientTest.java   |  6 ++---
 ...CacheMvccContinuousQueryImmutableEntryTest.java |  6 ++---
 ...MvccContinuousQueryMultiNodesFilteringTest.java |  6 ++---
 ...acheMvccContinuousQueryPartitionedSelfTest.java |  6 ++---
 ...vccContinuousQueryPartitionedTxOneNodeTest.java |  6 ++---
 ...CacheMvccContinuousQueryReplicatedSelfTest.java |  6 ++---
 ...MvccContinuousQueryReplicatedTxOneNodeTest.java |  6 ++---
 ...vccContinuousWithTransformerClientSelfTest.java |  6 ++---
 ...ntinuousWithTransformerPartitionedSelfTest.java |  6 ++---
 ...ontinuousWithTransformerReplicatedSelfTest.java |  6 ++---
 .../cache/mvcc/CacheMvccDmlSimpleTest.java         |  6 ++---
 ...cIteratorWithConcurrentJdbcTransactionTest.java |  6 ++---
 ...alEntriesWithConcurrentJdbcTransactionTest.java |  6 ++---
 .../mvcc/CacheMvccPartitionedBackupsTest.java      |  6 ++---
 ...eMvccPartitionedSqlCoordinatorFailoverTest.java |  6 ++---
 .../mvcc/CacheMvccPartitionedSqlQueriesTest.java   |  6 ++---
 .../mvcc/CacheMvccPartitionedSqlTxQueriesTest.java |  6 ++---
 ...MvccPartitionedSqlTxQueriesWithReducerTest.java |  6 ++---
 .../cache/mvcc/CacheMvccReplicatedBackupsTest.java |  6 ++---
 ...heMvccReplicatedSqlCoordinatorFailoverTest.java |  6 ++---
 .../mvcc/CacheMvccReplicatedSqlQueriesTest.java    |  6 ++---
 .../mvcc/CacheMvccReplicatedSqlTxQueriesTest.java  |  6 ++---
 ...eMvccReplicatedSqlTxQueriesWithReducerTest.java |  6 ++---
 ...ScanQueryWithConcurrentJdbcTransactionTest.java |  6 ++---
 .../CacheMvccSelectForUpdateQueryBasicTest.java    |  6 ++---
 .../mvcc/CacheMvccSelectForUpdateQueryTest.java    |  6 ++---
 .../processors/cache/mvcc/CacheMvccSizeTest.java   |  6 ++---
 ...eMvccSizeWithConcurrentJdbcTransactionTest.java |  6 ++---
 .../CacheMvccSqlConfigurationValidationTest.java   |  6 ++---
 ...eMvccSqlContinuousQueryPartitionedSelfTest.java |  6 ++---
 ...heMvccSqlContinuousQueryReplicatedSelfTest.java |  6 ++---
 .../cache/mvcc/CacheMvccSqlLockTimeoutTest.java    |  6 ++---
 .../mvcc/CacheMvccSqlQueriesAbstractTest.java      |  6 ++---
 .../cache/mvcc/CacheMvccSqlTxModesTest.java        |  6 ++---
 .../mvcc/CacheMvccSqlTxQueriesAbstractTest.java    |  6 ++---
 ...cheMvccSqlTxQueriesWithReducerAbstractTest.java |  6 ++---
 .../cache/mvcc/CacheMvccSqlUpdateCountersTest.java |  6 ++---
 .../cache/mvcc/CacheMvccStreamingInsertTest.java   |  6 ++---
 .../cache/mvcc/CacheMvccTxNodeMappingTest.java     |  6 ++---
 .../cache/mvcc/CacheMvccTxRecoveryTest.java        |  6 ++---
 .../mvcc/MvccDeadlockDetectionConfigTest.java      |  6 ++---
 .../cache/mvcc/MvccDeadlockDetectionTest.java      |  6 ++---
 .../cache/mvcc/MvccRepeatableReadBulkOpsTest.java  |  6 ++---
 .../mvcc/MvccRepeatableReadOperationsTest.java     |  6 ++---
 .../persistence/db/IgniteTcBotInitNewPageTest.java |  6 ++---
 ...xingMultithreadedLoadContinuousRestartTest.java |  6 ++---
 .../persistence/db/wal/IgniteWalRecoveryTest.java  |  6 ++---
 .../wal/IgniteWalRecoveryWithCompactionTest.java   |  6 ++---
 .../transaction/DmlInsideTransactionTest.java      |  6 ++---
 .../cache/ttl/CacheTtlAbstractSelfTest.java        |  6 ++---
 .../cache/ttl/CacheTtlAtomicAbstractSelfTest.java  |  6 ++---
 .../cache/ttl/CacheTtlAtomicLocalSelfTest.java     |  6 ++---
 .../ttl/CacheTtlAtomicPartitionedSelfTest.java     |  6 ++---
 .../ttl/CacheTtlTransactionalAbstractSelfTest.java |  6 ++---
 .../ttl/CacheTtlTransactionalLocalSelfTest.java    |  6 ++---
 .../CacheTtlTransactionalPartitionedSelfTest.java  |  6 ++---
 ...ntConnectorConfigurationValidationSelfTest.java |  6 ++---
 .../processors/client/IgniteDataStreamerTest.java  |  6 ++---
 .../database/IgniteDbMemoryLeakIndexedTest.java    |  6 ++---
 .../database/IgniteDbMemoryLeakSqlQueryTest.java   |  6 ++---
 .../IgniteDbMultiNodeWithIndexingPutGetTest.java   |  6 ++---
 .../IgniteDbSingleNodeWithIndexingPutGetTest.java  |  6 ++---
 ...niteDbSingleNodeWithIndexingWalRestoreTest.java |  6 ++---
 ...tStoreQueryWithMultipleClassesPerCacheTest.java |  6 ++---
 .../IgnitePersistentStoreSchemaLoadTest.java       |  6 ++---
 .../database/IgniteTwoRegionsRebuildIndexTest.java |  6 ++---
 ...eLockPartitionOnAffinityRunAtomicCacheTest.java |  6 ++---
 ...elineLockPartitionOnAffinityRunTxCacheTest.java |  6 ++---
 ...ngingBaselineCacheQueryNodeRestartSelfTest.java |  6 ++---
 ...iteStableBaselineBinObjFieldsQuerySelfTest.java |  6 ++---
 ...ableBaselineCacheQueryNodeRestartsSelfTest.java |  6 ++---
 ...actQueryTableLockAndConnectionPoolSelfTest.java |  6 ++---
 .../query/IgniteCacheGroupsCompareQueryTest.java   |  6 ++---
 ...gniteCacheGroupsSqlDistributedJoinSelfTest.java |  6 ++---
 ...heGroupsSqlSegmentedIndexMultiNodeSelfTest.java |  6 ++---
 ...IgniteCacheGroupsSqlSegmentedIndexSelfTest.java |  6 ++---
 .../query/IgniteCachelessQueriesSelfTest.java      |  6 ++---
 .../query/IgniteQueryDedicatedPoolTest.java        |  6 ++---
 ...yTableLockAndConnectionPoolLazyModeOffTest.java |  6 ++---
 ...ryTableLockAndConnectionPoolLazyModeOnTest.java |  6 ++---
 .../query/IgniteSqlCreateTableTemplateTest.java    |  6 ++---
 .../query/IgniteSqlDefaultValueTest.java           |  6 ++---
 .../query/IgniteSqlDistributedJoinSelfTest.java    |  6 ++---
 .../query/IgniteSqlEntryCacheModeAgnosticTest.java |  6 ++---
 .../query/IgniteSqlGroupConcatCollocatedTest.java  |  6 ++---
 .../IgniteSqlGroupConcatNotCollocatedTest.java     |  6 ++---
 .../query/IgniteSqlKeyValueFieldsTest.java         |  6 ++---
 .../query/IgniteSqlNotNullConstraintTest.java      |  6 ++---
 .../query/IgniteSqlParameterizedQueryTest.java     |  6 ++---
 .../query/IgniteSqlQueryParallelismTest.java       |  6 ++---
 .../processors/query/IgniteSqlRoutingTest.java     |  6 ++---
 .../query/IgniteSqlSchemaIndexingTest.java         |  6 ++---
 .../IgniteSqlSegmentedIndexMultiNodeSelfTest.java  |  6 ++---
 .../query/IgniteSqlSegmentedIndexSelfTest.java     |  6 ++---
 ...gniteSqlSkipReducerOnUpdateDmlFlagSelfTest.java |  6 ++---
 .../IgniteSqlSkipReducerOnUpdateDmlSelfTest.java   |  6 ++---
 .../query/IgniteSqlSplitterSelfTest.java           |  6 ++---
 .../processors/query/KillQueryFromClientTest.java  |  6 ++---
 .../query/KillQueryFromNeighbourTest.java          |  6 ++---
 .../query/KillQueryOnClientDisconnectTest.java     |  6 ++---
 .../internal/processors/query/KillQueryTest.java   |  6 ++---
 .../processors/query/LocalQueryLazyTest.java       |  6 ++---
 .../processors/query/LongRunningQueryTest.java     |  6 ++---
 .../query/MultipleStatementsSqlQuerySelfTest.java  |  6 ++---
 .../processors/query/RunningQueriesTest.java       |  6 ++---
 .../processors/query/SqlIllegalSchemaSelfTest.java |  6 ++---
 .../SqlIncompatibleDataTypeExceptionTest.java      |  6 ++---
 .../SqlLocalQueryConnectionAndStatementTest.java   |  6 ++---
 .../processors/query/SqlNestedQuerySelfTest.java   |  6 ++---
 .../processors/query/SqlPushDownFunctionTest.java  |  6 ++---
 .../query/SqlQueryHistoryFromClientSelfTest.java   |  6 ++---
 .../processors/query/SqlQueryHistorySelfTest.java  |  6 ++---
 .../processors/query/SqlSchemaSelfTest.java        |  6 ++---
 .../processors/query/SqlSystemViewsSelfTest.java   |  6 ++---
 .../CacheQueryEntityWithDateTimeApiFieldsTest.java |  6 ++---
 .../query/h2/DmlStatementsProcessorTest.java       |  6 ++---
 .../query/h2/GridIndexFullRebuildTest.java         |  6 ++---
 .../query/h2/GridIndexRebuildSelfTest.java         |  6 ++---
 .../GridIndexRebuildWithMvccEnabledSelfTest.java   |  6 ++---
 .../H2ResultSetIteratorNullifyOnEndSelfTest.java   |  6 ++---
 .../query/h2/IgniteSqlBigIntegerKeyTest.java       |  6 ++---
 .../query/h2/IgniteSqlQueryMinMaxTest.java         |  6 ++---
 .../processors/query/h2/QueryDataPageScanTest.java |  6 ++---
 .../query/h2/ThreadLocalObjectPoolSelfTest.java    |  6 ++---
 .../query/h2/database/InlineIndexHelperTest.java   |  6 ++---
 .../query/h2/sql/AbstractH2CompareQueryTest.java   |  6 ++---
 .../query/h2/sql/BaseH2CompareQueryTest.java       |  6 ++---
 .../processors/query/h2/sql/ExplainSelfTest.java   |  6 ++---
 .../query/h2/sql/GridQueryParsingTest.java         |  6 ++---
 .../sql/H2CompareBigQueryDistributedJoinsTest.java |  6 ++---
 .../query/h2/sql/H2CompareBigQueryTest.java        |  6 ++---
 .../query/h2/sql/ParameterTypeInferenceTest.java   |  6 ++---
 .../query/h2/sql/SqlUnsupportedSelfTest.java       |  6 ++---
 .../twostep/AbstractPartitionPruningBaseTest.java  |  6 ++---
 .../AndOperationExtractPartitionSelfTest.java      |  6 ++---
 .../BetweenOperationExtractPartitionSelfTest.java  |  6 ++---
 .../query/h2/twostep/CacheQueryMemoryLeakTest.java |  6 ++---
 .../h2/twostep/CreateTableWithDateKeySelfTest.java |  6 ++---
 .../DisappearedCacheCauseRetryMessageSelfTest.java |  6 ++---
 ...DisappearedCacheWasNotFoundMessageSelfTest.java |  6 ++---
 .../twostep/DmlSelectPartitionPruningSelfTest.java |  6 ++---
 .../InOperationExtractPartitionSelfTest.java       |  6 ++---
 .../h2/twostep/JoinPartitionPruningSelfTest.java   |  6 ++---
 .../query/h2/twostep/JoinSqlTestHelper.java        |  6 ++---
 .../twostep/MvccDmlPartitionPruningSelfTest.java   |  6 ++---
 .../twostep/NonCollocatedRetryMessageSelfTest.java |  6 ++---
 ...neOrSinglePartitionsQueryOptimizationsTest.java |  6 ++---
 .../h2/twostep/RetryCauseMessageSelfTest.java      |  6 ++---
 .../h2/twostep/SqlDataTypeConversionTest.java      |  6 ++---
 .../h2/twostep/TableViewSubquerySelfTest.java      |  6 ++---
 .../processors/query/oom/AbstractQueryOOMTest.java |  6 ++---
 .../query/oom/IgniteQueryOOMTestSuite.java         |  6 ++---
 .../oom/QueryOOMWithQueryParallelismTest.java      |  6 ++---
 .../oom/QueryOOMWithoutQueryParallelismTest.java   |  6 ++---
 ...achePartitionedAtomicColumnConstraintsTest.java |  6 ++---
 ...titionedTransactionalColumnConstraintsTest.java |  6 ++---
 ...dTransactionalSnapshotColumnConstraintTest.java |  6 ++---
 ...CacheReplicatedAtomicColumnConstraintsTest.java |  6 ++---
 ...plicatedTransactionalColumnConstraintsTest.java |  6 ++---
 ...dTransactionalSnapshotColumnConstraintTest.java |  6 ++---
 .../sql/IgniteSQLColumnConstraintsTest.java        |  6 ++---
 .../IgniteTransactionSQLColumnConstraintTest.java  |  6 ++---
 ...qlConnectorConfigurationValidationSelfTest.java |  6 ++---
 .../h2indexing/FetchingQueryCursorStressTest.java  |  6 ++---
 .../tcp/GridOrderedMessageCancelSelfTest.java      |  6 ++---
 .../org/apache/ignite/sqltests/BaseSqlTest.java    |  6 ++---
 .../apache/ignite/sqltests/PartitionedSqlTest.java |  6 ++---
 .../apache/ignite/sqltests/ReplicatedSqlTest.java  |  6 ++---
 .../IgniteBinaryCacheQueryTestSuite.java           |  6 ++---
 .../IgniteBinaryCacheQueryTestSuite2.java          |  6 ++---
 ...eBinarySimpleNameMapperCacheQueryTestSuite.java |  6 ++---
 .../IgniteCacheAffinityRunTestSuite.java           |  6 ++---
 ...eBlockExchangeOnSqlReadOperationsTestSuite.java |  6 ++---
 .../IgniteCacheConfigVariationQueryTestSuite.java  |  6 ++---
 .../testsuites/IgniteCacheMvccSqlTestSuite.java    |  6 ++---
 .../testsuites/IgniteCacheQuerySelfTestSuite3.java |  6 ++---
 .../testsuites/IgniteCacheQuerySelfTestSuite4.java |  6 ++---
 .../testsuites/IgniteCacheQuerySelfTestSuite5.java |  6 ++---
 .../testsuites/IgniteCacheQuerySelfTestSuite6.java |  6 ++---
 ...teCacheWithIndexingAndPersistenceTestSuite.java |  6 ++---
 .../IgniteCacheWithIndexingTestSuite.java          |  6 ++---
 .../IgniteDbMemoryLeakWithIndexingTestSuite.java   |  6 ++---
 .../IgnitePdsWithIndexingCoreTestSuite.java        |  6 ++---
 .../testsuites/IgnitePdsWithIndexingTestSuite.java |  6 ++---
 .../IgniteBinaryCacheQueryLazyTestSuite.java       |  6 ++---
 .../IgniteBinaryCacheQueryLazyTestSuite2.java      |  6 ++---
 .../util/GridCommandHandlerIndexingTest.java       |  6 ++---
 modules/jcl/pom.xml                                |  6 ++---
 .../org/apache/ignite/logger/jcl/JclLogger.java    |  6 ++---
 .../org/apache/ignite/logger/jcl/package-info.java |  6 ++---
 .../apache/ignite/logger/jcl/JclLoggerTest.java    |  6 ++---
 .../org/apache/ignite/logger/jcl/package-info.java |  6 ++---
 .../ignite/testsuites/IgniteJclTestSuite.java      |  6 ++---
 modules/jms11/pom.xml                              |  6 ++---
 .../apache/ignite/stream/jms11/JmsStreamer.java    |  6 ++---
 .../ignite/stream/jms11/MessageTransformer.java    |  6 ++---
 .../apache/ignite/stream/jms11/package-info.java   |  6 ++---
 .../ignite/stream/jms11/IgniteJmsStreamerTest.java |  6 ++---
 .../stream/jms11/IgniteJmsStreamerTestSuite.java   |  6 ++---
 .../ignite/stream/jms11/TestTransformers.java      |  6 ++---
 .../apache/ignite/stream/jms11/package-info.java   |  6 ++---
 modules/jta/pom.xml                                |  6 ++---
 .../org/apache/ignite/cache/jta/CacheTmLookup.java |  6 ++---
 .../ignite/cache/jta/jndi/CacheJndiTmFactory.java  |  6 ++---
 .../ignite/cache/jta/jndi/CacheJndiTmLookup.java   |  6 ++---
 .../apache/ignite/cache/jta/jndi/package-info.java |  6 ++---
 .../org/apache/ignite/cache/jta/package-info.java  |  6 ++---
 .../cache/jta/reflect/CacheReflectionTmLookup.java |  6 ++---
 .../ignite/cache/jta/reflect/package-info.java     |  6 ++---
 .../jta/websphere/WebSphereLibertyTmFactory.java   |  6 ++---
 .../cache/jta/websphere/WebSphereTmFactory.java    |  6 ++---
 .../ignite/cache/jta/websphere/package-info.java   |  6 ++---
 .../processors/cache/jta/CacheJtaManager.java      |  6 ++---
 .../processors/cache/jta/CacheJtaResource.java     |  6 ++---
 .../cache/CacheJndiTmFactorySelfTest.java          |  6 ++---
 ...ridCacheJtaConfigurationValidationSelfTest.java |  6 ++---
 ...ridCacheJtaFactoryConfigValidationSelfTest.java |  6 ++---
 .../cache/GridJtaLifecycleAwareSelfTest.java       |  6 ++---
 .../cache/GridJtaTransactionManagerSelfTest.java   |  6 ++---
 .../cache/jta/AbstractCacheJtaSelfTest.java        |  6 ++---
 .../GridPartitionedCacheJtaFactorySelfTest.java    |  6 ++---
 ...dPartitionedCacheJtaFactoryUseSyncSelfTest.java |  6 ++---
 ...PartitionedCacheJtaLookupClassNameSelfTest.java |  6 ++---
 .../jta/GridReplicatedCacheJtaFactorySelfTest.java |  6 ++---
 ...idReplicatedCacheJtaFactoryUseSyncSelfTest.java |  6 ++---
 ...dReplicatedCacheJtaLookupClassNameSelfTest.java |  6 ++---
 .../processors/cache/jta/package-info.java         |  6 ++---
 .../ignite/testsuites/IgniteJtaTestSuite.java      |  6 ++---
 modules/kafka/pom.xml                              |  6 ++---
 .../apache/ignite/stream/kafka/KafkaStreamer.java  |  6 ++---
 .../stream/kafka/connect/IgniteSinkConnector.java  |  6 ++---
 .../stream/kafka/connect/IgniteSinkConstants.java  |  6 ++---
 .../stream/kafka/connect/IgniteSinkTask.java       |  6 ++---
 .../kafka/connect/IgniteSourceConnector.java       |  6 ++---
 .../kafka/connect/IgniteSourceConstants.java       |  6 ++---
 .../stream/kafka/connect/IgniteSourceTask.java     |  6 ++---
 .../ignite/stream/kafka/connect/package-info.java  |  6 ++---
 .../connect/serialization/CacheEventConverter.java |  6 ++---
 .../serialization/CacheEventDeserializer.java      |  6 ++---
 .../serialization/CacheEventSerializer.java        |  6 ++---
 .../kafka/connect/serialization/package-info.java  |  6 ++---
 .../apache/ignite/stream/kafka/package-info.java   |  6 ++---
 .../kafka/IgniteKafkaStreamerSelfTestSuite.java    |  6 ++---
 .../stream/kafka/KafkaIgniteStreamerSelfTest.java  |  6 ++---
 .../ignite/stream/kafka/TestKafkaBroker.java       |  6 ++---
 .../kafka/connect/IgniteSinkConnectorMock.java     |  6 ++---
 .../kafka/connect/IgniteSinkConnectorTest.java     |  6 ++---
 .../stream/kafka/connect/IgniteSinkTaskMock.java   |  6 ++---
 .../kafka/connect/IgniteSourceConnectorMock.java   |  6 ++---
 .../kafka/connect/IgniteSourceConnectorTest.java   |  6 ++---
 .../stream/kafka/connect/IgniteSourceTaskMock.java |  6 ++---
 .../stream/kafka/connect/TestCacheEventFilter.java |  6 ++---
 .../apache/ignite/stream/kafka/package-info.java   |  6 ++---
 .../kafka/src/test/resources/example-ignite.xml    |  6 ++---
 modules/kubernetes/config/Dockerfile               |  6 ++---
 .../kubernetes/config/az/ignite-account-role.yaml  |  6 ++---
 .../kubernetes/config/az/ignite-deployment.yaml    |  6 ++---
 modules/kubernetes/config/az/ignite-namespace.yaml |  6 ++---
 .../az/ignite-persistence-storage-class.yaml       |  6 ++---
 .../kubernetes/config/az/ignite-role-binding.yaml  |  6 ++---
 .../config/az/ignite-service-account.yaml          |  6 ++---
 modules/kubernetes/config/az/ignite-service.yaml   |  6 ++---
 .../kubernetes/config/az/ignite-stateful-set.yaml  |  6 ++---
 .../config/az/ignite-wal-storage-class.yaml        |  6 ++---
 .../kubernetes/config/eks/ignite-account-role.yaml |  6 ++---
 .../kubernetes/config/eks/ignite-namespace.yaml    |  6 ++---
 .../eks/ignite-persistence-storage-class.yaml      |  6 ++---
 .../kubernetes/config/eks/ignite-role-binding.yaml |  6 ++---
 .../config/eks/ignite-service-account.yaml         |  6 ++---
 modules/kubernetes/config/eks/ignite-service.yaml  |  6 ++---
 .../kubernetes/config/eks/ignite-stateful-set.yaml |  6 ++---
 .../config/eks/ignite-wal-storage-class.yaml       |  6 ++---
 .../config/example-kube-persistence-and-wal.xml    |  6 ++---
 .../kubernetes/config/example-kube-persistence.xml |  6 ++---
 modules/kubernetes/config/example-kube-rbac.xml    |  6 ++---
 modules/kubernetes/config/example-kube.xml         |  6 ++---
 .../kubernetes/config/gce/ignite-account-role.yaml |  6 ++---
 .../kubernetes/config/gce/ignite-deployment.yaml   |  6 ++---
 .../kubernetes/config/gce/ignite-namespace.yaml    |  6 ++---
 .../gce/ignite-persistence-storage-class.yaml      |  6 ++---
 .../kubernetes/config/gce/ignite-role-binding.yaml |  6 ++---
 .../config/gce/ignite-service-account.yaml         |  6 ++---
 modules/kubernetes/config/gce/ignite-service.yaml  |  6 ++---
 .../kubernetes/config/gce/ignite-stateful-set.yaml |  6 ++---
 .../config/gce/ignite-wal-storage-class.yaml       |  6 ++---
 modules/kubernetes/config/ignite-deployment.yaml   |  6 ++---
 modules/kubernetes/config/ignite-service.yaml      |  6 ++---
 modules/kubernetes/config/run.sh                   |  6 ++---
 modules/kubernetes/pom.xml                         |  6 ++---
 .../kubernetes/TcpDiscoveryKubernetesIpFinder.java |  6 ++---
 .../tcp/ipfinder/kubernetes/package-info.java      |  6 ++---
 .../TcpDiscoveryKubernetesIpFinderSelfTest.java    |  6 ++---
 .../tcp/ipfinder/kubernetes/package-info.java      |  6 ++---
 .../testsuites/IgniteKubernetesTestSuite.java      |  6 ++---
 modules/log4j/pom.xml                              |  6 ++---
 .../log4j/Log4JDailyRollingFileAppender.java       |  6 ++---
 .../log4j/Log4JExternallyRolledFileAppender.java   |  6 ++---
 .../ignite/logger/log4j/Log4JFileAppender.java     |  6 ++---
 .../apache/ignite/logger/log4j/Log4JLogger.java    |  6 ++---
 .../apache/ignite/logger/log4j/Log4jFileAware.java |  6 ++---
 .../ignite/logger/log4j/Log4jNodeIdFilePath.java   |  6 ++---
 .../logger/log4j/Log4jRollingFileAppender.java     |  6 ++---
 .../apache/ignite/logger/log4j/package-info.java   |  6 ++---
 modules/log4j/src/test/config/log4j-debug.xml      |  6 ++---
 modules/log4j/src/test/config/log4j-info.xml       |  6 ++---
 .../logger/log4j/GridLog4jConfigUpdateTest.java    |  6 ++---
 .../logger/log4j/GridLog4jCorrectFileNameTest.java |  6 ++---
 .../logger/log4j/GridLog4jInitializedTest.java     |  6 ++---
 .../logger/log4j/GridLog4jLoggingFileTest.java     |  6 ++---
 .../logger/log4j/GridLog4jLoggingPathTest.java     |  6 ++---
 .../logger/log4j/GridLog4jLoggingUrlTest.java      |  6 ++---
 .../logger/log4j/GridLog4jNotInitializedTest.java  |  6 ++---
 .../logger/log4j/GridLog4jWatchDelayTest.java      |  6 ++---
 .../apache/ignite/logger/log4j/package-info.java   |  6 ++---
 .../ignite/testsuites/IgniteLog4jTestSuite.java    |  6 ++---
 modules/log4j2/pom.xml                             |  6 ++---
 .../apache/ignite/logger/log4j2/Log4J2Logger.java  |  6 ++---
 .../apache/ignite/logger/log4j2/package-info.java  |  6 ++---
 modules/log4j2/src/test/config/log4j2-debug.xml    |  6 ++---
 modules/log4j2/src/test/config/log4j2-info.xml     |  6 ++---
 modules/log4j2/src/test/config/log4j2-markers.xml  |  6 ++---
 .../logger/log4j2/Log4j2ConfigUpdateTest.java      |  6 ++---
 .../logger/log4j2/Log4j2LoggerMarkerTest.java      |  6 ++---
 .../ignite/logger/log4j2/Log4j2LoggerSelfTest.java |  6 ++---
 .../log4j2/Log4j2LoggerVerboseModeSelfTest.java    |  6 ++---
 .../apache/ignite/logger/log4j2/package-info.java  |  6 ++---
 .../ignite/testsuites/IgniteLog4j2TestSuite.java   |  6 ++---
 modules/mesos/pom.xml                              |  6 ++---
 .../org/apache/ignite/mesos/ClusterProperties.java |  6 ++---
 .../org/apache/ignite/mesos/IgniteFramework.java   |  6 ++---
 .../org/apache/ignite/mesos/IgniteScheduler.java   |  6 ++---
 .../java/org/apache/ignite/mesos/IgniteTask.java   |  6 ++---
 .../java/org/apache/ignite/mesos/package-info.java |  6 ++---
 .../ignite/mesos/resource/IgniteProvider.java      |  6 ++---
 .../apache/ignite/mesos/resource/JettyServer.java  |  6 ++---
 .../ignite/mesos/resource/ResourceHandler.java     |  6 ++---
 .../ignite/mesos/resource/ResourceProvider.java    |  6 ++---
 .../apache/ignite/mesos/resource/package-info.java |  6 ++---
 .../src/main/resources/ignite-default-config.xml   |  6 ++---
 .../org/apache/ignite/IgniteMesosTestSuite.java    |  6 ++---
 .../ignite/mesos/IgniteSchedulerSelfTest.java      |  6 ++---
 modules/ml/mleap-model-parser/pom.xml              |  6 ++---
 .../org/apache/ignite/ml/mleap/MLeapModel.java     |  6 ++---
 .../apache/ignite/ml/mleap/MLeapModelParser.java   |  6 ++---
 .../org/apache/ignite/ml/mleap/package-info.java   |  6 ++---
 .../ignite/ml/mleap/IgniteMLeapTestSuite.java      |  6 ++---
 .../ignite/ml/mleap/MLeapModelParserTest.java      |  6 ++---
 modules/ml/pom.xml                                 |  6 ++---
 modules/ml/spark-model-parser/pom.xml              |  6 ++---
 .../ml/sparkmodelparser/SparkModelParser.java      |  6 ++---
 .../ml/sparkmodelparser/SupportedSparkModels.java  |  6 ++---
 .../UnsupportedSparkModelException.java            |  6 ++---
 .../ignite/ml/sparkmodelparser/package-info.java   |  6 ++---
 .../IgniteMLSparkModelParserTestSuite.java         |  6 ++---
 .../ml/sparkmodelparser/SparkModelParserTest.java  |  6 ++---
 .../main/java/org/apache/ignite/ml/Exportable.java |  6 ++---
 .../main/java/org/apache/ignite/ml/Exporter.java   |  6 ++---
 .../java/org/apache/ignite/ml/FileExporter.java    |  6 ++---
 .../java/org/apache/ignite/ml/IgniteModel.java     |  6 ++---
 .../gmm/CovarianceMatricesAggregator.java          |  6 ++---
 .../apache/ignite/ml/clustering/gmm/GmmModel.java  |  6 ++---
 .../ignite/ml/clustering/gmm/GmmPartitionData.java |  6 ++---
 .../ignite/ml/clustering/gmm/GmmTrainer.java       |  6 ++---
 .../gmm/MeanWithClusterProbAggregator.java         |  6 ++---
 .../gmm/NewComponentStatisticsAggregator.java      |  6 ++---
 .../ignite/ml/clustering/gmm/package-info.java     |  6 ++---
 .../ignite/ml/clustering/kmeans/Clusterer.java     |  6 ++---
 .../ml/clustering/kmeans/ClusterizationModel.java  |  6 ++---
 .../ignite/ml/clustering/kmeans/KMeansModel.java   |  6 ++---
 .../ml/clustering/kmeans/KMeansModelFormat.java    |  6 ++---
 .../ignite/ml/clustering/kmeans/KMeansTrainer.java |  6 ++---
 .../ignite/ml/clustering/kmeans/package-info.java  |  6 ++---
 .../apache/ignite/ml/clustering/package-info.java  |  6 ++---
 .../ignite/ml/composition/CompositionUtils.java    |  6 ++---
 .../ignite/ml/composition/DatasetMapping.java      |  6 ++---
 .../ml/composition/ModelOnFeaturesSubspace.java    |  6 ++---
 .../ignite/ml/composition/ModelsComposition.java   |  6 ++---
 .../ml/composition/ModelsCompositionFormat.java    |  6 ++---
 .../ignite/ml/composition/bagging/BaggedModel.java |  6 ++---
 .../ml/composition/bagging/BaggedTrainer.java      |  6 ++---
 .../boosting/GDBBinaryClassifierTrainer.java       |  6 ++---
 .../composition/boosting/GDBLearningStrategy.java  |  6 ++---
 .../composition/boosting/GDBRegressionTrainer.java |  6 ++---
 .../ignite/ml/composition/boosting/GDBTrainer.java |  6 ++---
 .../boosting/convergence/ConvergenceChecker.java   |  6 ++---
 .../convergence/ConvergenceCheckerFactory.java     |  6 ++---
 .../mean/MeanAbsValueConvergenceChecker.java       |  6 ++---
 .../MeanAbsValueConvergenceCheckerFactory.java     |  6 ++---
 .../boosting/convergence/mean/package-info.java    |  6 ++---
 .../median/MedianOfMedianConvergenceChecker.java   |  6 ++---
 .../MedianOfMedianConvergenceCheckerFactory.java   |  6 ++---
 .../boosting/convergence/median/package-info.java  |  6 ++---
 .../boosting/convergence/package-info.java         |  6 ++---
 .../convergence/simple/ConvergenceCheckerStub.java |  6 ++---
 .../simple/ConvergenceCheckerStubFactory.java      |  6 ++---
 .../boosting/convergence/simple/package-info.java  |  6 ++---
 .../ml/composition/boosting/loss/LogLoss.java      |  6 ++---
 .../ignite/ml/composition/boosting/loss/Loss.java  |  6 ++---
 .../ml/composition/boosting/loss/SquaredError.java |  6 ++---
 .../ml/composition/boosting/loss/package-info.java |  6 ++---
 .../ml/composition/boosting/package-info.java      |  6 ++---
 .../ml/composition/combinators/package-info.java   |  6 ++---
 .../parallel/ModelsParallelComposition.java        |  6 ++---
 .../parallel/TrainersParallelComposition.java      |  6 ++---
 .../combinators/parallel/package-info.java         |  6 ++---
 .../sequential/ModelsSequentialComposition.java    |  6 ++---
 .../sequential/TrainersSequentialComposition.java  |  6 ++---
 .../combinators/sequential/package-info.java       |  6 ++---
 .../apache/ignite/ml/composition/package-info.java |  6 ++---
 .../MeanValuePredictionsAggregator.java            |  6 ++---
 .../OnMajorityPredictionsAggregator.java           |  6 ++---
 .../PredictionsAggregator.java                     |  6 ++---
 .../WeightedPredictionsAggregator.java             |  6 ++---
 .../predictionsaggregator/package-info.java        |  6 ++---
 .../stacking/SimpleStackedDatasetTrainer.java      |  6 ++---
 .../stacking/StackedDatasetTrainer.java            |  6 ++---
 .../ml/composition/stacking/StackedModel.java      |  6 ++---
 .../stacking/StackedVectorDatasetTrainer.java      |  6 ++---
 .../ml/composition/stacking/package-info.java      |  6 ++---
 .../java/org/apache/ignite/ml/dataset/Dataset.java |  6 ++---
 .../apache/ignite/ml/dataset/DatasetBuilder.java   |  6 ++---
 .../apache/ignite/ml/dataset/DatasetFactory.java   |  6 ++---
 .../ignite/ml/dataset/PartitionContextBuilder.java |  6 ++---
 .../ignite/ml/dataset/PartitionDataBuilder.java    |  6 ++---
 .../apache/ignite/ml/dataset/UpstreamEntry.java    |  6 ++---
 .../ignite/ml/dataset/UpstreamTransformer.java     |  6 ++---
 .../ml/dataset/UpstreamTransformerBuilder.java     |  6 ++---
 .../ignite/ml/dataset/feature/BucketMeta.java      |  6 ++---
 .../ml/dataset/feature/DistributionComputer.java   |  6 ++---
 .../ignite/ml/dataset/feature/FeatureMeta.java     |  6 ++---
 .../ignite/ml/dataset/feature/Histogram.java       |  6 ++---
 .../ignite/ml/dataset/feature/ObjectHistogram.java |  6 ++---
 .../dataset/feature/extractor/ExtractionUtils.java |  6 ++---
 .../ml/dataset/feature/extractor/Vectorizer.java   |  6 ++---
 .../extractor/impl/BinaryObjectVectorizer.java     |  6 ++---
 .../extractor/impl/DoubleArrayVectorizer.java      |  6 ++---
 .../feature/extractor/impl/DummyVectorizer.java    |  6 ++---
 .../extractor/impl/LabeledDummyVectorizer.java     |  6 ++---
 .../feature/extractor/impl/package-info.java       |  6 ++---
 .../ml/dataset/feature/extractor/package-info.java |  6 ++---
 .../ignite/ml/dataset/feature/package-info.java    |  6 ++---
 .../bootstrapping/BootstrappedDatasetBuilder.java  |  6 ++---
 .../BootstrappedDatasetPartition.java              |  6 ++---
 .../impl/bootstrapping/BootstrappedVector.java     |  6 ++---
 .../dataset/impl/bootstrapping/package-info.java   |  6 ++---
 .../ml/dataset/impl/cache/CacheBasedDataset.java   |  6 ++---
 .../impl/cache/CacheBasedDatasetBuilder.java       |  6 ++---
 .../ignite/ml/dataset/impl/cache/package-info.java |  6 ++---
 .../ml/dataset/impl/cache/util/ComputeUtils.java   |  6 ++---
 .../cache/util/DatasetAffinityFunctionWrapper.java |  6 ++---
 .../IteratorWithConcurrentModificationChecker.java |  6 ++---
 .../impl/cache/util/PartitionDataStorage.java      |  6 ++---
 .../ml/dataset/impl/cache/util/package-info.java   |  6 ++---
 .../ignite/ml/dataset/impl/local/LocalDataset.java |  6 ++---
 .../ml/dataset/impl/local/LocalDatasetBuilder.java |  6 ++---
 .../ignite/ml/dataset/impl/local/package-info.java |  6 ++---
 .../ignite/ml/dataset/impl/package-info.java       |  6 ++---
 .../org/apache/ignite/ml/dataset/package-info.java |  6 ++---
 .../ml/dataset/primitive/DatasetWrapper.java       |  6 ++---
 .../FeatureMatrixWithLabelsOnHeapData.java         |  6 ++---
 .../FeatureMatrixWithLabelsOnHeapDataBuilder.java  |  6 ++---
 .../ignite/ml/dataset/primitive/SimpleDataset.java |  6 ++---
 .../ml/dataset/primitive/SimpleLabeledDataset.java |  6 ++---
 .../builder/context/EmptyContextBuilder.java       |  6 ++---
 .../primitive/builder/context/package-info.java    |  6 ++---
 .../builder/data/SimpleDatasetDataBuilder.java     |  6 ++---
 .../data/SimpleLabeledDatasetDataBuilder.java      |  6 ++---
 .../primitive/builder/data/package-info.java       |  6 ++---
 .../ml/dataset/primitive/builder/package-info.java |  6 ++---
 .../ml/dataset/primitive/context/EmptyContext.java |  6 ++---
 .../ml/dataset/primitive/context/package-info.java |  6 ++---
 .../dataset/primitive/data/SimpleDatasetData.java  |  6 ++---
 .../primitive/data/SimpleLabeledDatasetData.java   |  6 ++---
 .../ml/dataset/primitive/data/package-info.java    |  6 ++---
 .../ignite/ml/dataset/primitive/package-info.java  |  6 ++---
 .../DefaultLearningEnvironmentBuilder.java         |  6 ++---
 .../ignite/ml/environment/LearningEnvironment.java |  6 ++---
 .../ml/environment/LearningEnvironmentBuilder.java |  6 ++---
 .../ml/environment/logging/ConsoleLogger.java      |  6 ++---
 .../ml/environment/logging/CustomMLLogger.java     |  6 ++---
 .../ignite/ml/environment/logging/MLLogger.java    |  6 ++---
 .../ignite/ml/environment/logging/NoOpLogger.java  |  6 ++---
 .../ml/environment/logging/package-info.java       |  6 ++---
 .../apache/ignite/ml/environment/package-info.java |  6 ++---
 .../parallelism/DefaultParallelismStrategy.java    |  6 ++---
 .../parallelism/NoParallelismStrategy.java         |  6 ++---
 .../parallelism/ParallelismStrategy.java           |  6 ++---
 .../ignite/ml/environment/parallelism/Promise.java |  6 ++---
 .../ml/environment/parallelism/package-info.java   |  6 ++---
 .../org/apache/ignite/ml/genetic/Chromosome.java   |  6 ++---
 .../org/apache/ignite/ml/genetic/CrossOverJob.java |  6 ++---
 .../apache/ignite/ml/genetic/CrossOverTask.java    |  6 ++---
 .../org/apache/ignite/ml/genetic/FitnessJob.java   |  6 ++---
 .../org/apache/ignite/ml/genetic/FitnessTask.java  |  6 ++---
 .../java/org/apache/ignite/ml/genetic/GAGrid.java  |  6 ++---
 .../java/org/apache/ignite/ml/genetic/Gene.java    |  6 ++---
 .../apache/ignite/ml/genetic/IFitnessFunction.java |  6 ++---
 .../org/apache/ignite/ml/genetic/MutateJob.java    |  6 ++---
 .../org/apache/ignite/ml/genetic/MutateTask.java   |  6 ++---
 .../ml/genetic/RouletteWheelSelectionJob.java      |  6 ++---
 .../ml/genetic/RouletteWheelSelectionTask.java     |  6 ++---
 .../ignite/ml/genetic/TruncateSelectionJob.java    |  6 ++---
 .../ignite/ml/genetic/TruncateSelectionTask.java   |  6 ++---
 .../ignite/ml/genetic/cache/GeneCacheConfig.java   |  6 ++---
 .../ml/genetic/cache/PopulationCacheConfig.java    |  6 ++---
 .../ignite/ml/genetic/cache/package-info.java      |  6 ++---
 .../ml/genetic/functions/GAGridFunction.java       |  6 ++---
 .../ignite/ml/genetic/functions/package-info.java  |  6 ++---
 .../org/apache/ignite/ml/genetic/package-info.java |  6 ++---
 .../ml/genetic/parameter/ChromosomeCriteria.java   |  6 ++---
 .../ml/genetic/parameter/GAConfiguration.java      |  6 ++---
 .../ml/genetic/parameter/GAGridConstants.java      |  6 ++---
 .../ml/genetic/parameter/ITerminateCriteria.java   |  6 ++---
 .../ignite/ml/genetic/parameter/package-info.java  |  6 ++---
 .../ignite/ml/genetic/utils/GAGridUtils.java       |  6 ++---
 .../ignite/ml/genetic/utils/package-info.java      |  6 ++---
 .../ml/inference/IgniteModelStorageUtil.java       |  6 ++---
 .../java/org/apache/ignite/ml/inference/Model.java |  6 ++---
 .../ignite/ml/inference/ModelDescriptor.java       |  6 ++---
 .../apache/ignite/ml/inference/ModelSignature.java |  6 ++---
 .../ml/inference/builder/AsyncModelBuilder.java    |  6 ++---
 .../builder/IgniteDistributedModelBuilder.java     |  6 ++---
 .../ml/inference/builder/SingleModelBuilder.java   |  6 ++---
 .../ml/inference/builder/SyncModelBuilder.java     |  6 ++---
 .../ml/inference/builder/ThreadedModelBuilder.java |  6 ++---
 .../ignite/ml/inference/builder/package-info.java  |  6 ++---
 .../apache/ignite/ml/inference/package-info.java   |  6 ++---
 .../ml/inference/parser/IgniteModelParser.java     |  6 ++---
 .../ignite/ml/inference/parser/ModelParser.java    |  6 ++---
 .../ignite/ml/inference/parser/package-info.java   |  6 ++---
 .../ml/inference/reader/FileSystemModelReader.java |  6 ++---
 .../ml/inference/reader/InMemoryModelReader.java   |  6 ++---
 .../ignite/ml/inference/reader/ModelReader.java    |  6 ++---
 .../inference/reader/ModelStorageModelReader.java  |  6 ++---
 .../ignite/ml/inference/reader/package-info.java   |  6 ++---
 .../descriptor/IgniteModelDescriptorStorage.java   |  6 ++---
 .../descriptor/LocalModelDescriptorStorage.java    |  6 ++---
 .../storage/descriptor/ModelDescriptorStorage.java |  6 ++---
 .../descriptor/ModelDescriptorStorageFactory.java  |  6 ++---
 .../inference/storage/descriptor/package-info.java |  6 ++---
 .../storage/model/DefaultModelStorage.java         |  6 ++---
 .../ml/inference/storage/model/Directory.java      |  6 ++---
 .../ignite/ml/inference/storage/model/File.java    |  6 ++---
 .../inference/storage/model/FileOrDirectory.java   |  6 ++---
 .../storage/model/IgniteModelStorageProvider.java  |  6 ++---
 .../storage/model/LocalModelStorageProvider.java   |  6 ++---
 .../ml/inference/storage/model/ModelStorage.java   |  6 ++---
 .../storage/model/ModelStorageFactory.java         |  6 ++---
 .../storage/model/ModelStorageProvider.java        |  6 ++---
 .../ml/inference/storage/model/package-info.java   |  6 ++---
 .../ignite/ml/inference/storage/package-info.java  |  6 ++---
 .../ml/inference/util/DirectorySerializer.java     |  6 ++---
 .../ignite/ml/inference/util/package-info.java     |  6 ++---
 .../java/org/apache/ignite/ml/knn/KNNUtils.java    |  6 ++---
 .../ignite/ml/knn/NNClassificationModel.java       |  6 ++---
 .../ignite/ml/knn/ann/ANNClassificationModel.java  |  6 ++---
 .../ml/knn/ann/ANNClassificationTrainer.java       |  6 ++---
 .../apache/ignite/ml/knn/ann/ANNModelFormat.java   |  6 ++---
 .../apache/ignite/ml/knn/ann/ProbableLabel.java    |  6 ++---
 .../org/apache/ignite/ml/knn/ann/package-info.java |  6 ++---
 .../knn/classification/KNNClassificationModel.java |  6 ++---
 .../classification/KNNClassificationTrainer.java   |  6 ++---
 .../ml/knn/classification/KNNModelFormat.java      |  6 ++---
 .../ignite/ml/knn/classification/NNStrategy.java   |  6 ++---
 .../ignite/ml/knn/classification/package-info.java |  6 ++---
 .../org/apache/ignite/ml/knn/package-info.java     |  6 ++---
 .../ml/knn/regression/KNNRegressionModel.java      |  6 ++---
 .../ml/knn/regression/KNNRegressionTrainer.java    |  6 ++---
 .../ignite/ml/knn/regression/package-info.java     |  6 ++---
 .../main/java/org/apache/ignite/ml/math/Blas.java  |  6 ++---
 .../org/apache/ignite/ml/math/Destroyable.java     |  6 ++---
 .../org/apache/ignite/ml/math/MetaAttributes.java  |  6 ++---
 .../apache/ignite/ml/math/StorageConstants.java    |  6 ++---
 .../apache/ignite/ml/math/StorageOpsMetrics.java   |  6 ++---
 .../java/org/apache/ignite/ml/math/Tracer.java     |  6 ++---
 .../ignite/ml/math/distances/DistanceMeasure.java  |  6 ++---
 .../ml/math/distances/EuclideanDistance.java       |  6 ++---
 .../ignite/ml/math/distances/HammingDistance.java  |  6 ++---
 .../ml/math/distances/ManhattanDistance.java       |  6 ++---
 .../ignite/ml/math/distances/package-info.java     |  6 ++---
 .../ml/math/exceptions/CardinalityException.java   |  6 ++---
 .../ml/math/exceptions/ColumnIndexException.java   |  6 ++---
 .../ignite/ml/math/exceptions/IndexException.java  |  6 ++---
 .../exceptions/MathIllegalArgumentException.java   |  6 ++---
 .../ml/math/exceptions/MathRuntimeException.java   |  6 ++---
 .../ignite/ml/math/exceptions/NoDataException.java |  6 ++---
 .../math/exceptions/NonSquareMatrixException.java  |  6 ++---
 .../ml/math/exceptions/RowIndexException.java      |  6 ++---
 .../math/exceptions/SingularMatrixException.java   |  6 ++---
 .../exceptions/UnsupportedOperationException.java  |  6 ++---
 .../ml/math/exceptions/knn/EmptyFileException.java |  6 ++---
 .../math/exceptions/knn/FileParsingException.java  |  6 ++---
 .../exceptions/knn/NoLabelVectorException.java     |  6 ++---
 .../ml/math/exceptions/knn/package-info.java       |  6 ++---
 .../ignite/ml/math/exceptions/package-info.java    |  6 ++---
 .../UnknownCategorialFeatureValue.java             |  6 ++---
 .../exceptions/preprocessing/package-info.java     |  6 ++---
 .../apache/ignite/ml/math/functions/Functions.java |  6 ++---
 .../ignite/ml/math/functions/IgniteBiConsumer.java |  6 ++---
 .../ignite/ml/math/functions/IgniteBiFunction.java |  6 ++---
 .../ml/math/functions/IgniteBinaryOperator.java    |  6 ++---
 .../ignite/ml/math/functions/IgniteConsumer.java   |  6 ++---
 .../ml/math/functions/IgniteCurriedBiFunction.java |  6 ++---
 .../math/functions/IgniteCurriedTriFunction.java   |  6 ++---
 ...IgniteDifferentiableDoubleToDoubleFunction.java |  6 ++---
 ...IgniteDifferentiableVectorToDoubleFunction.java |  6 ++---
 .../ml/math/functions/IgniteDoubleFunction.java    |  6 ++---
 .../ignite/ml/math/functions/IgniteFunction.java   |  6 ++---
 .../IgniteIntDoubleToDoubleBiFunction.java         |  6 ++---
 .../functions/IgniteIntIntToIntBiFunction.java     |  6 ++---
 .../ignite/ml/math/functions/IgniteSupplier.java   |  6 ++---
 .../ml/math/functions/IgniteToDoubleFunction.java  |  6 ++---
 .../ml/math/functions/IgniteTriConsumer.java       |  6 ++---
 .../ml/math/functions/IgniteTriFunction.java       |  6 ++---
 .../ml/math/functions/IntDoubleToVoidFunction.java |  6 ++---
 .../math/functions/IntIntDoubleToVoidFunction.java |  6 ++---
 .../ml/math/functions/IntIntToDoubleFunction.java  |  6 ++---
 .../ignite/ml/math/functions/package-info.java     |  6 ++---
 .../ml/math/isolve/IterativeSolverResult.java      |  6 ++---
 .../ignite/ml/math/isolve/lsqr/AbstractLSQR.java   |  6 ++---
 .../ignite/ml/math/isolve/lsqr/LSQROnHeap.java     |  6 ++---
 .../ml/math/isolve/lsqr/LSQRPartitionContext.java  |  6 ++---
 .../ignite/ml/math/isolve/lsqr/LSQRResult.java     |  6 ++---
 .../ignite/ml/math/isolve/lsqr/package-info.java   |  6 ++---
 .../apache/ignite/ml/math/isolve/package-info.java |  6 ++---
 .../org/apache/ignite/ml/math/package-info.java    |  6 ++---
 .../ml/math/primitives/matrix/AbstractMatrix.java  |  6 ++---
 .../ml/math/primitives/matrix/LUDecomposition.java |  6 ++---
 .../ignite/ml/math/primitives/matrix/Matrix.java   |  6 ++---
 .../ml/math/primitives/matrix/MatrixStorage.java   |  6 ++---
 .../ml/math/primitives/matrix/OrderedMatrix.java   |  6 ++---
 .../math/primitives/matrix/impl/DenseMatrix.java   |  6 ++---
 .../math/primitives/matrix/impl/SparseMatrix.java  |  6 ++---
 .../ml/math/primitives/matrix/impl/ViewMatrix.java |  6 ++---
 .../math/primitives/matrix/impl/package-info.java  |  6 ++---
 .../ml/math/primitives/matrix/package-info.java    |  6 ++---
 .../matrix/storage/DenseMatrixStorage.java         |  6 ++---
 .../matrix/storage/SparseMatrixStorage.java        |  6 ++---
 .../matrix/storage/ViewMatrixStorage.java          |  6 ++---
 .../primitives/matrix/storage/package-info.java    |  6 ++---
 .../ignite/ml/math/primitives/package-info.java    |  6 ++---
 .../ml/math/primitives/vector/AbstractVector.java  |  6 ++---
 .../ml/math/primitives/vector/NamedVector.java     |  6 ++---
 .../ignite/ml/math/primitives/vector/Vector.java   |  6 ++---
 .../ml/math/primitives/vector/VectorStorage.java   |  6 ++---
 .../ml/math/primitives/vector/VectorUtils.java     |  6 ++---
 .../vector/impl/DelegatingNamedVector.java         |  6 ++---
 .../primitives/vector/impl/DelegatingVector.java   |  6 ++---
 .../math/primitives/vector/impl/DenseVector.java   |  6 ++---
 .../math/primitives/vector/impl/SparseVector.java  |  6 ++---
 .../ml/math/primitives/vector/impl/VectorView.java |  6 ++---
 .../vector/impl/VectorizedViewMatrix.java          |  6 ++---
 .../math/primitives/vector/impl/package-info.java  |  6 ++---
 .../ml/math/primitives/vector/package-info.java    |  6 ++---
 .../vector/storage/DenseVectorStorage.java         |  6 ++---
 .../vector/storage/SparseVectorStorage.java        |  6 ++---
 .../vector/storage/VectorViewStorage.java          |  6 ++---
 .../storage/VectorizedViewMatrixStorage.java       |  6 ++---
 .../primitives/vector/storage/package-info.java    |  6 ++---
 .../apache/ignite/ml/math/stat/Distribution.java   |  6 ++---
 .../ignite/ml/math/stat/DistributionMixture.java   |  6 ++---
 .../stat/MultivariateGaussianDistribution.java     |  6 ++---
 .../apache/ignite/ml/math/stat/package-info.java   |  6 ++---
 .../org/apache/ignite/ml/math/util/MapUtil.java    |  6 ++---
 .../org/apache/ignite/ml/math/util/MatrixUtil.java |  6 ++---
 .../apache/ignite/ml/math/util/package-info.java   |  6 ++---
 .../ignite/ml/multiclass/MultiClassModel.java      |  6 ++---
 .../ignite/ml/multiclass/OneVsRestTrainer.java     |  6 ++---
 .../apache/ignite/ml/multiclass/package-info.java  |  6 ++---
 .../discrete/DiscreteNaiveBayesModel.java          |  6 ++---
 .../discrete/DiscreteNaiveBayesSumsHolder.java     |  6 ++---
 .../discrete/DiscreteNaiveBayesTrainer.java        |  6 ++---
 .../ml/naivebayes/discrete/package-info.java       |  6 ++---
 .../gaussian/GaussianNaiveBayesModel.java          |  6 ++---
 .../gaussian/GaussianNaiveBayesSumsHolder.java     |  6 ++---
 .../gaussian/GaussianNaiveBayesTrainer.java        |  6 ++---
 .../ml/naivebayes/gaussian/package-info.java       |  6 ++---
 .../apache/ignite/ml/naivebayes/package-info.java  |  6 ++---
 .../java/org/apache/ignite/ml/nn/Activators.java   |  6 ++---
 .../java/org/apache/ignite/ml/nn/MLPLayer.java     |  6 ++---
 .../java/org/apache/ignite/ml/nn/MLPState.java     |  6 ++---
 .../java/org/apache/ignite/ml/nn/MLPTrainer.java   |  6 ++---
 .../apache/ignite/ml/nn/MultilayerPerceptron.java  |  6 ++---
 .../ignite/ml/nn/ReplicatedVectorMatrix.java       |  6 ++---
 .../org/apache/ignite/ml/nn/UpdatesStrategy.java   |  6 ++---
 .../ml/nn/architecture/LayerArchitecture.java      |  6 ++---
 .../ignite/ml/nn/architecture/MLPArchitecture.java |  6 ++---
 .../TransformationLayerArchitecture.java           |  6 ++---
 .../ignite/ml/nn/architecture/package-info.java    |  6 ++---
 .../ignite/ml/nn/initializers/MLPInitializer.java  |  6 ++---
 .../ml/nn/initializers/RandomInitializer.java      |  6 ++---
 .../ignite/ml/nn/initializers/package-info.java    |  6 ++---
 .../java/org/apache/ignite/ml/nn/package-info.java |  6 ++---
 .../ignite/ml/optimization/BaseParametrized.java   |  6 ++---
 .../ignite/ml/optimization/LossFunctions.java      |  6 ++---
 .../ignite/ml/optimization/Parametrized.java       |  6 ++---
 .../ignite/ml/optimization/SmoothParametrized.java |  6 ++---
 .../ignite/ml/optimization/package-info.java       |  6 ++---
 .../updatecalculators/NesterovParameterUpdate.java |  6 ++---
 .../NesterovUpdateCalculator.java                  |  6 ++---
 .../ParameterUpdateCalculator.java                 |  6 ++---
 .../updatecalculators/RPropParameterUpdate.java    |  6 ++---
 .../updatecalculators/RPropUpdateCalculator.java   |  6 ++---
 .../updatecalculators/SimpleGDParameterUpdate.java |  6 ++---
 .../SimpleGDUpdateCalculator.java                  |  6 ++---
 .../updatecalculators/package-info.java            |  6 ++---
 .../java/org/apache/ignite/ml/package-info.java    |  6 ++---
 .../org/apache/ignite/ml/pipeline/Pipeline.java    |  6 ++---
 .../org/apache/ignite/ml/pipeline/PipelineMdl.java |  6 ++---
 .../apache/ignite/ml/pipeline/package-info.java    |  6 ++---
 .../ml/preprocessing/PreprocessingTrainer.java     |  6 ++---
 .../ignite/ml/preprocessing/Preprocessor.java      |  6 ++---
 .../binarization/BinarizationPreprocessor.java     |  6 ++---
 .../binarization/BinarizationTrainer.java          |  6 ++---
 .../preprocessing/binarization/package-info.java   |  6 ++---
 .../developer/MappedPreprocessor.java              |  6 ++---
 .../developer/PatchedPreprocessor.java             |  6 ++---
 .../ml/preprocessing/developer/package-info.java   |  6 ++---
 .../encoding/EncoderPartitionData.java             |  6 ++---
 .../encoding/EncoderPreprocessor.java              |  6 ++---
 .../encoding/EncoderSortingStrategy.java           |  6 ++---
 .../ml/preprocessing/encoding/EncoderTrainer.java  |  6 ++---
 .../ml/preprocessing/encoding/EncoderType.java     |  6 ++---
 .../onehotencoder/OneHotEncoderPreprocessor.java   |  6 ++---
 .../encoding/onehotencoder/package-info.java       |  6 ++---
 .../ml/preprocessing/encoding/package-info.java    |  6 ++---
 .../stringencoder/StringEncoderPreprocessor.java   |  6 ++---
 .../encoding/stringencoder/package-info.java       |  6 ++---
 .../imputing/ImputerPartitionData.java             |  6 ++---
 .../imputing/ImputerPreprocessor.java              |  6 ++---
 .../ml/preprocessing/imputing/ImputerTrainer.java  |  6 ++---
 .../preprocessing/imputing/ImputingStrategy.java   |  6 ++---
 .../ml/preprocessing/imputing/package-info.java    |  6 ++---
 .../maxabsscaling/MaxAbsScalerPartitionData.java   |  6 ++---
 .../maxabsscaling/MaxAbsScalerPreprocessor.java    |  6 ++---
 .../maxabsscaling/MaxAbsScalerTrainer.java         |  6 ++---
 .../preprocessing/maxabsscaling/package-info.java  |  6 ++---
 .../minmaxscaling/MinMaxScalerPartitionData.java   |  6 ++---
 .../minmaxscaling/MinMaxScalerPreprocessor.java    |  6 ++---
 .../minmaxscaling/MinMaxScalerTrainer.java         |  6 ++---
 .../preprocessing/minmaxscaling/package-info.java  |  6 ++---
 .../normalization/NormalizationPreprocessor.java   |  6 ++---
 .../normalization/NormalizationTrainer.java        |  6 ++---
 .../preprocessing/normalization/package-info.java  |  6 ++---
 .../ignite/ml/preprocessing/package-info.java      |  6 ++---
 .../standardscaling/StandardScalerData.java        |  6 ++---
 .../StandardScalerPreprocessor.java                |  6 ++---
 .../standardscaling/StandardScalerTrainer.java     |  6 ++---
 .../standardscaling/package-info.java              |  6 ++---
 .../linear/LinearRegressionLSQRTrainer.java        |  6 ++---
 .../regressions/linear/LinearRegressionModel.java  |  6 ++---
 .../linear/LinearRegressionSGDTrainer.java         |  6 ++---
 .../ignite/ml/regressions/linear/package-info.java |  6 ++---
 .../logistic/LogisticRegressionModel.java          |  6 ++---
 .../logistic/LogisticRegressionSGDTrainer.java     |  6 ++---
 .../ml/regressions/logistic/package-info.java      |  6 ++---
 .../apache/ignite/ml/regressions/package-info.java |  6 ++---
 .../ignite/ml/selection/cv/CrossValidation.java    |  6 ++---
 .../ml/selection/cv/CrossValidationResult.java     |  6 ++---
 .../ignite/ml/selection/cv/package-info.java       |  6 ++---
 .../apache/ignite/ml/selection/package-info.java   |  6 ++---
 .../ignite/ml/selection/paramgrid/ParamGrid.java   |  6 ++---
 .../selection/paramgrid/ParameterSetGenerator.java |  6 ++---
 .../ml/selection/paramgrid/package-info.java       |  6 ++---
 .../ignite/ml/selection/scoring/LabelPair.java     |  6 ++---
 .../scoring/cursor/CacheBasedLabelPairCursor.java  |  6 ++---
 .../selection/scoring/cursor/LabelPairCursor.java  |  6 ++---
 .../scoring/cursor/LocalLabelPairCursor.java       |  6 ++---
 .../ml/selection/scoring/cursor/package-info.java  |  6 ++---
 .../ml/selection/scoring/evaluator/Evaluator.java  |  6 ++---
 .../selection/scoring/evaluator/package-info.java  |  6 ++---
 .../selection/scoring/metric/AbstractMetrics.java  |  6 ++---
 .../ignite/ml/selection/scoring/metric/Metric.java |  6 ++---
 .../ml/selection/scoring/metric/MetricValues.java  |  6 ++---
 .../scoring/metric/classification/Accuracy.java    |  6 ++---
 .../BinaryClassificationMetricValues.java          |  6 ++---
 .../BinaryClassificationMetrics.java               |  6 ++---
 .../scoring/metric/classification/ClassMetric.java |  6 ++---
 .../scoring/metric/classification/Fmeasure.java    |  6 ++---
 .../scoring/metric/classification/Precision.java   |  6 ++---
 .../scoring/metric/classification/ROCAUC.java      |  6 ++---
 .../scoring/metric/classification/Recall.java      |  6 ++---
 .../metric/classification/package-info.java        |  6 ++---
 .../exceptions/UnknownClassLabelException.java     |  6 ++---
 .../scoring/metric/exceptions/package-info.java    |  6 ++---
 .../ml/selection/scoring/metric/package-info.java  |  6 ++---
 .../metric/regression/RegressionMetricValues.java  |  6 ++---
 .../metric/regression/RegressionMetrics.java       |  6 ++---
 .../scoring/metric/regression/package-info.java    |  6 ++---
 .../ignite/ml/selection/scoring/package-info.java  |  6 ++---
 .../selection/split/TrainTestDatasetSplitter.java  |  6 ++---
 .../ignite/ml/selection/split/TrainTestSplit.java  |  6 ++---
 .../split/mapper/SHA256UniformMapper.java          |  6 ++---
 .../ml/selection/split/mapper/UniformMapper.java   |  6 ++---
 .../ml/selection/split/mapper/package-info.java    |  6 ++---
 .../ignite/ml/selection/split/package-info.java    |  6 ++---
 .../org/apache/ignite/ml/sql/SQLFunctions.java     |  6 ++---
 .../apache/ignite/ml/sql/SqlDatasetBuilder.java    |  6 ++---
 .../org/apache/ignite/ml/sql/package-info.java     |  6 ++---
 .../org/apache/ignite/ml/structures/Dataset.java   |  6 ++---
 .../apache/ignite/ml/structures/DatasetRow.java    |  6 ++---
 .../ignite/ml/structures/FeatureMetadata.java      |  6 ++---
 .../apache/ignite/ml/structures/LabeledVector.java |  6 ++---
 .../ignite/ml/structures/LabeledVectorSet.java     |  6 ++---
 .../structures/LabeledVectorSetTestTrainPair.java  |  6 ++---
 .../apache/ignite/ml/structures/package-info.java  |  6 ++---
 .../partition/LabelPartitionDataBuilderOnHeap.java |  6 ++---
 .../partition/LabelPartitionDataOnHeap.java        |  6 ++---
 .../LabeledDatasetPartitionDataBuilderOnHeap.java  |  6 ++---
 .../ml/structures/partition/package-info.java      |  6 ++---
 .../preprocessing/LabeledDatasetLoader.java        |  6 ++---
 .../ml/structures/preprocessing/package-info.java  |  6 ++---
 .../ml/svm/SVMLinearClassificationModel.java       |  6 ++---
 .../ml/svm/SVMLinearClassificationTrainer.java     |  6 ++---
 .../org/apache/ignite/ml/svm/package-info.java     |  6 ++---
 .../ignite/ml/trainers/AdaptableDatasetModel.java  |  6 ++---
 .../ml/trainers/AdaptableDatasetTrainer.java       |  6 ++---
 .../apache/ignite/ml/trainers/DatasetTrainer.java  |  6 ++---
 .../ignite/ml/trainers/FeatureLabelExtractor.java  |  6 ++---
 .../ml/trainers/MultiLabelDatasetTrainer.java      |  6 ++---
 .../ml/trainers/SingleLabelDatasetTrainer.java     |  6 ++---
 .../ignite/ml/trainers/TrainerTransformers.java    |  6 ++---
 .../apache/ignite/ml/trainers/package-info.java    |  6 ++---
 .../transformers/BaggingUpstreamTransformer.java   |  6 ++---
 .../ml/trainers/transformers/package-info.java     |  6 ++---
 .../org/apache/ignite/ml/tree/DecisionTree.java    |  6 ++---
 .../ml/tree/DecisionTreeClassificationTrainer.java |  6 ++---
 .../ml/tree/DecisionTreeConditionalNode.java       |  6 ++---
 .../ignite/ml/tree/DecisionTreeLeafNode.java       |  6 ++---
 .../apache/ignite/ml/tree/DecisionTreeNode.java    |  6 ++---
 .../ml/tree/DecisionTreeRegressionTrainer.java     |  6 ++---
 .../java/org/apache/ignite/ml/tree/TreeFilter.java |  6 ++---
 .../GDBBinaryClassifierOnTreesTrainer.java         |  6 ++---
 .../tree/boosting/GDBOnTreesLearningStrategy.java  |  6 ++---
 .../tree/boosting/GDBRegressionOnTreesTrainer.java |  6 ++---
 .../ignite/ml/tree/boosting/package-info.java      |  6 ++---
 .../ignite/ml/tree/data/DecisionTreeData.java      |  6 ++---
 .../ml/tree/data/DecisionTreeDataBuilder.java      |  6 ++---
 .../apache/ignite/ml/tree/data/TreeDataIndex.java  |  6 ++---
 .../apache/ignite/ml/tree/data/package-info.java   |  6 ++---
 .../ignite/ml/tree/impurity/ImpurityMeasure.java   |  6 ++---
 .../tree/impurity/ImpurityMeasureCalculator.java   |  6 ++---
 .../ml/tree/impurity/gini/GiniImpurityMeasure.java |  6 ++---
 .../gini/GiniImpurityMeasureCalculator.java        |  6 ++---
 .../ignite/ml/tree/impurity/gini/package-info.java |  6 ++---
 .../ml/tree/impurity/mse/MSEImpurityMeasure.java   |  6 ++---
 .../impurity/mse/MSEImpurityMeasureCalculator.java |  6 ++---
 .../ignite/ml/tree/impurity/mse/package-info.java  |  6 ++---
 .../ignite/ml/tree/impurity/package-info.java      |  6 ++---
 .../util/SimpleStepFunctionCompressor.java         |  6 ++---
 .../ignite/ml/tree/impurity/util/StepFunction.java |  6 ++---
 .../tree/impurity/util/StepFunctionCompressor.java |  6 ++---
 .../ignite/ml/tree/impurity/util/package-info.java |  6 ++---
 .../ml/tree/leaf/DecisionTreeLeafBuilder.java      |  6 ++---
 .../ml/tree/leaf/MeanDecisionTreeLeafBuilder.java  |  6 ++---
 .../leaf/MostCommonDecisionTreeLeafBuilder.java    |  6 ++---
 .../apache/ignite/ml/tree/leaf/package-info.java   |  6 ++---
 .../org/apache/ignite/ml/tree/package-info.java    |  6 ++---
 .../RandomForestClassifierTrainer.java             |  6 ++---
 .../RandomForestRegressionTrainer.java             |  6 ++---
 .../ml/tree/randomforest/RandomForestTrainer.java  |  6 ++---
 .../data/FeaturesCountSelectionStrategies.java     |  6 ++---
 .../ignite/ml/tree/randomforest/data/NodeId.java   |  6 ++---
 .../ml/tree/randomforest/data/NodeSplit.java       |  6 ++---
 .../ignite/ml/tree/randomforest/data/TreeNode.java |  6 ++---
 .../ignite/ml/tree/randomforest/data/TreeRoot.java |  6 ++---
 .../randomforest/data/impurity/GiniHistogram.java  |  6 ++---
 .../data/impurity/GiniHistogramsComputer.java      |  6 ++---
 .../data/impurity/ImpurityComputer.java            |  6 ++---
 .../data/impurity/ImpurityHistogram.java           |  6 ++---
 .../data/impurity/ImpurityHistogramsComputer.java  |  6 ++---
 .../randomforest/data/impurity/MSEHistogram.java   |  6 ++---
 .../data/impurity/MSEHistogramComputer.java        |  6 ++---
 .../basic/BootstrappedVectorsHistogram.java        |  6 ++---
 .../data/impurity/basic/CountersHistogram.java     |  6 ++---
 .../data/impurity/basic/package-info.java          |  6 ++---
 .../randomforest/data/impurity/package-info.java   |  6 ++---
 .../ml/tree/randomforest/data/package-info.java    |  6 ++---
 .../statistics/ClassifierLeafValuesComputer.java   |  6 ++---
 .../data/statistics/LeafValuesComputer.java        |  6 ++---
 .../data/statistics/MeanValueStatistic.java        |  6 ++---
 .../statistics/NormalDistributionStatistics.java   |  6 ++---
 .../NormalDistributionStatisticsComputer.java      |  6 ++---
 .../statistics/RegressionLeafValuesComputer.java   |  6 ++---
 .../randomforest/data/statistics/package-info.java |  6 ++---
 .../ignite/ml/tree/randomforest/package-info.java  |  6 ++---
 .../java/org/apache/ignite/ml/util/LRUCache.java   |  6 ++---
 .../ignite/ml/util/LRUCacheExpirationListener.java |  6 ++---
 .../apache/ignite/ml/util/MLSandboxDatasets.java   |  6 ++---
 .../java/org/apache/ignite/ml/util/MnistUtils.java |  6 ++---
 .../java/org/apache/ignite/ml/util/ModelTrace.java |  6 ++---
 .../org/apache/ignite/ml/util/SandboxMLCache.java  |  6 ++---
 .../main/java/org/apache/ignite/ml/util/Utils.java |  6 ++---
 .../ml/util/generators/DataStreamGenerator.java    |  6 ++---
 .../ml/util/generators/DatasetBuilderAdapter.java  |  6 ++---
 .../ignite/ml/util/generators/package-info.java    |  6 ++---
 .../util/generators/primitives/package-info.java   |  6 ++---
 .../primitives/scalar/DiscreteRandomProducer.java  |  6 ++---
 .../primitives/scalar/GaussRandomProducer.java     |  6 ++---
 .../primitives/scalar/RandomProducer.java          |  6 ++---
 .../scalar/RandomProducerWithGenerator.java        |  6 ++---
 .../primitives/scalar/UniformRandomProducer.java   |  6 ++---
 .../generators/primitives/scalar/package-info.java |  6 ++---
 .../vector/ParametricVectorGenerator.java          |  6 ++---
 .../primitives/vector/VectorGenerator.java         |  6 ++---
 .../vector/VectorGeneratorPrimitives.java          |  6 ++---
 .../primitives/vector/VectorGeneratorsFamily.java  |  6 ++---
 .../generators/primitives/vector/package-info.java |  6 ++---
 .../standard/GaussianMixtureDataStream.java        |  6 ++---
 .../generators/standard/RegressionDataStream.java  |  6 ++---
 .../util/generators/standard/RingsDataStream.java  |  6 ++---
 .../standard/TwoSeparableClassesDataStream.java    |  6 ++---
 .../ml/util/generators/standard/package-info.java  |  6 ++---
 .../org/apache/ignite/ml/util/package-info.java    |  6 ++---
 .../org/apache/ignite/ml/util/plugin/MLPlugin.java |  6 ++---
 .../ml/util/plugin/MLPluginConfiguration.java      |  6 ++---
 .../ignite/ml/util/plugin/MLPluginProvider.java    |  6 ++---
 .../apache/ignite/ml/math/d3-dataset-template.html |  6 ++---
 .../apache/ignite/ml/math/d3-matrix-template.html  |  6 ++---
 .../apache/ignite/ml/math/d3-vector-template.html  |  6 ++---
 .../org/apache/ignite/ml/IgniteMLTestSuite.java    |  6 ++---
 .../test/java/org/apache/ignite/ml/TestUtils.java  |  6 ++---
 .../ignite/ml/clustering/ClusteringTestSuite.java  |  6 ++---
 .../ignite/ml/clustering/KMeansModelTest.java      |  6 ++---
 .../ignite/ml/clustering/KMeansTrainerTest.java    |  6 ++---
 .../gmm/CovarianceMatricesAggregatorTest.java      |  6 ++---
 .../ignite/ml/clustering/gmm/GmmModelTest.java     |  6 ++---
 .../ml/clustering/gmm/GmmPartitionDataTest.java    |  6 ++---
 .../clustering/gmm/GmmTrainerIntegrationTest.java  |  6 ++---
 .../ignite/ml/clustering/gmm/GmmTrainerTest.java   |  6 ++---
 .../gmm/MeanWithClusterProbAggregatorTest.java     |  6 ++---
 .../gmm/NewComponentStatisticsAggregatorTest.java  |  6 ++---
 .../apache/ignite/ml/common/CollectionsTest.java   |  6 ++---
 .../apache/ignite/ml/common/CommonTestSuite.java   |  6 ++---
 .../apache/ignite/ml/common/ExternalizeTest.java   |  6 ++---
 .../apache/ignite/ml/common/KeepBinaryTest.java    |  6 ++---
 .../apache/ignite/ml/common/LocalModelsTest.java   |  6 ++---
 .../org/apache/ignite/ml/common/ModelTest.java     |  6 ++---
 .../org/apache/ignite/ml/common/TrainerTest.java   |  6 ++---
 .../ml/composition/CompositionTestSuite.java       |  6 ++---
 .../apache/ignite/ml/composition/StackingTest.java |  6 ++---
 .../ignite/ml/composition/bagging/BaggingTest.java |  6 ++---
 .../ml/composition/boosting/GDBTrainerTest.java    |  6 ++---
 .../convergence/ConvergenceCheckerTest.java        |  6 ++---
 .../mean/MeanAbsValueConvergenceCheckerTest.java   |  6 ++---
 .../MedianOfMedianConvergenceCheckerTest.java      |  6 ++---
 .../MeanValuePredictionsAggregatorTest.java        |  6 ++---
 .../OnMajorityPredictionsAggregatorTest.java       |  6 ++---
 .../WeightedPredictionsAggregatorTest.java         |  6 ++---
 .../apache/ignite/ml/dataset/DatasetTestSuite.java |  6 ++---
 .../ml/dataset/feature/ObjectHistogramTest.java    |  6 ++---
 .../dataset/feature/extractor/VectorizerTest.java  |  6 ++---
 .../impl/cache/CacheBasedDatasetBuilderTest.java   |  6 ++---
 .../dataset/impl/cache/CacheBasedDatasetTest.java  |  6 ++---
 .../dataset/impl/cache/util/ComputeUtilsTest.java  |  6 ++---
 .../util/DatasetAffinityFunctionWrapperTest.java   |  6 ++---
 ...ratorWithConcurrentModificationCheckerTest.java |  6 ++---
 .../impl/cache/util/PartitionDataStorageTest.java  |  6 ++---
 .../impl/local/LocalDatasetBuilderTest.java        |  6 ++---
 .../ml/dataset/primitive/DatasetWrapperTest.java   |  6 ++---
 .../ml/dataset/primitive/SimpleDatasetTest.java    |  6 ++---
 .../primitive/SimpleLabeledDatasetTest.java        |  6 ++---
 .../ml/environment/EnvironmentTestSuite.java       |  6 ++---
 .../LearningEnvironmentBuilderTest.java            |  6 ++---
 .../ml/environment/LearningEnvironmentTest.java    |  6 ++---
 .../apache/ignite/ml/environment/PromiseTest.java  |  6 ++---
 .../ml/genetic/GAGridCalculateFitnessTest.java     |  6 ++---
 .../ml/genetic/GAGridInitializePopulationTest.java |  6 ++---
 .../apache/ignite/ml/genetic/GAGridTestSuite.java  |  6 ++---
 .../ignite/ml/genetic/PasswordFitnessFunction.java |  6 ++---
 .../ml/inference/IgniteModelStorageUtilTest.java   |  6 ++---
 .../ignite/ml/inference/InferenceTestSuite.java    |  6 ++---
 .../builder/IgniteDistributedModelBuilderTest.java |  6 ++---
 .../ml/inference/builder/ModelBuilderTestUtil.java |  6 ++---
 .../inference/builder/SingleModelBuilderTest.java  |  6 ++---
 .../builder/ThreadedModelBuilderTest.java          |  6 ++---
 .../storage/model/AbstractModelStorageTest.java    |  6 ++---
 .../storage/model/DefaultModelStorageTest.java     |  6 ++---
 .../ml/inference/util/DirectorySerializerTest.java |  6 ++---
 .../ignite/ml/knn/ANNClassificationTest.java       |  6 ++---
 .../ignite/ml/knn/KNNClassificationTest.java       |  6 ++---
 .../apache/ignite/ml/knn/KNNRegressionTest.java    |  6 ++---
 .../org/apache/ignite/ml/knn/KNNTestSuite.java     |  6 ++---
 .../apache/ignite/ml/knn/LabeledDatasetHelper.java |  6 ++---
 .../apache/ignite/ml/knn/LabeledVectorSetTest.java |  6 ++---
 .../java/org/apache/ignite/ml/math/BlasTest.java   |  6 ++---
 .../apache/ignite/ml/math/ExternalizableTest.java  |  6 ++---
 .../org/apache/ignite/ml/math/ExternalizeTest.java |  6 ++---
 .../ignite/ml/math/MathImplLocalTestSuite.java     |  6 ++---
 .../ignite/ml/math/MathImplMainTestSuite.java      |  6 ++---
 .../java/org/apache/ignite/ml/math/TracerTest.java |  6 ++---
 .../org/apache/ignite/ml/math/VectorUtilsTest.java |  6 ++---
 .../ignite/ml/math/distances/DistanceTest.java     |  6 ++---
 .../ignite/ml/math/isolve/lsqr/LSQROnHeapTest.java |  6 ++---
 .../ml/math/primitives/MathTestConstants.java      |  6 ++---
 .../matrix/DenseMatrixConstructorTest.java         |  6 ++---
 .../primitives/matrix/LUDecompositionTest.java     |  6 ++---
 .../primitives/matrix/MatrixArrayStorageTest.java  |  6 ++---
 .../primitives/matrix/MatrixAttributeTest.java     |  6 ++---
 .../primitives/matrix/MatrixBaseStorageTest.java   |  6 ++---
 .../primitives/matrix/MatrixStorageFixtures.java   |  6 ++---
 .../matrix/MatrixStorageImplementationTest.java    |  6 ++---
 .../matrix/MatrixViewConstructorTest.java          |  6 ++---
 .../matrix/SparseMatrixConstructorTest.java        |  6 ++---
 .../math/primitives/vector/AbstractVectorTest.java |  6 ++---
 .../vector/DelegatingVectorConstructorTest.java    |  6 ++---
 .../vector/DenseVectorConstructorTest.java         |  6 ++---
 .../primitives/vector/MatrixVectorViewTest.java    |  6 ++---
 .../vector/SparseVectorConstructorTest.java        |  6 ++---
 .../primitives/vector/VectorArrayStorageTest.java  |  6 ++---
 .../primitives/vector/VectorAttributesTest.java    |  6 ++---
 .../primitives/vector/VectorBaseStorageTest.java   |  6 ++---
 .../math/primitives/vector/VectorFoldMapTest.java  |  6 ++---
 .../vector/VectorImplementationsFixtures.java      |  6 ++---
 .../vector/VectorImplementationsTest.java          |  6 ++---
 .../ml/math/primitives/vector/VectorNormTest.java  |  6 ++---
 .../math/primitives/vector/VectorToMatrixTest.java |  6 ++---
 .../ml/math/primitives/vector/VectorViewTest.java  |  6 ++---
 .../vector/storage/AbstractStorageTest.java        |  6 ++---
 .../vector/storage/DenseVectorStorageTest.java     |  6 ++---
 .../vector/storage/SparseVectorStorageTest.java    |  6 ++---
 .../ml/math/stat/DistributionMixtureTest.java      |  6 ++---
 .../stat/MultivariateGaussianDistributionTest.java |  6 ++---
 .../apache/ignite/ml/math/stat/StatsTestSuite.java |  6 ++---
 .../ignite/ml/multiclass/MultiClassTestSuite.java  |  6 ++---
 .../ignite/ml/multiclass/OneVsRestTrainerTest.java |  6 ++---
 .../discrete/DiscreteNaiveBayesModelTest.java      |  6 ++---
 .../discrete/DiscreteNaiveBayesTest.java           |  6 ++---
 .../discrete/DiscreteNaiveBayesTrainerTest.java    |  6 ++---
 .../gaussian/GaussianNaiveBayesModelTest.java      |  6 ++---
 .../gaussian/GaussianNaiveBayesTest.java           |  6 ++---
 .../gaussian/GaussianNaiveBayesTrainerTest.java    |  6 ++---
 .../org/apache/ignite/ml/nn/LossFunctionsTest.java |  6 ++---
 .../apache/ignite/ml/nn/MLPConstInitializer.java   |  6 ++---
 .../test/java/org/apache/ignite/ml/nn/MLPTest.java |  6 ++---
 .../java/org/apache/ignite/ml/nn/MLPTestSuite.java |  6 ++---
 .../ignite/ml/nn/MLPTrainerIntegrationTest.java    |  6 ++---
 .../org/apache/ignite/ml/nn/MLPTrainerTest.java    |  6 ++---
 .../MLPTrainerMnistIntegrationTest.java            |  6 ++---
 .../ml/nn/performance/MLPTrainerMnistTest.java     |  6 ++---
 .../ignite/ml/nn/performance/MnistMLPTestUtil.java |  6 ++---
 .../apache/ignite/ml/pipeline/PipelineMdlTest.java |  6 ++---
 .../apache/ignite/ml/pipeline/PipelineTest.java    |  6 ++---
 .../ignite/ml/pipeline/PipelineTestSuite.java      |  6 ++---
 .../ml/preprocessing/PreprocessingTestSuite.java   |  6 ++---
 .../binarization/BinarizationPreprocessorTest.java |  6 ++---
 .../binarization/BinarizationTrainerTest.java      |  6 ++---
 .../preprocessing/encoding/EncoderTrainerTest.java |  6 ++---
 .../encoding/OneHotEncoderPreprocessorTest.java    |  6 ++---
 .../encoding/StringEncoderPreprocessorTest.java    |  6 ++---
 .../imputing/ImputerPreprocessorTest.java          |  6 ++---
 .../preprocessing/imputing/ImputerTrainerTest.java |  6 ++---
 .../MaxAbsScalerPreprocessorTest.java              |  6 ++---
 .../maxabsscaling/MaxAbsScalerTrainerTest.java     |  6 ++---
 .../MinMaxScalerPreprocessorTest.java              |  6 ++---
 .../minmaxscaling/MinMaxScalerTrainerTest.java     |  6 ++---
 .../NormalizationPreprocessorTest.java             |  6 ++---
 .../normalization/NormalizationTrainerTest.java    |  6 ++---
 .../StandardScalerPreprocessorTest.java            |  6 ++---
 .../standardscaling/StandardScalerTrainerTest.java |  6 ++---
 .../ml/regressions/RegressionsTestSuite.java       |  6 ++---
 .../linear/LinearRegressionLSQRTrainerTest.java    |  6 ++---
 .../linear/LinearRegressionModelTest.java          |  6 ++---
 .../linear/LinearRegressionSGDTrainerTest.java     |  6 ++---
 .../logistic/LogisticRegressionModelTest.java      |  6 ++---
 .../logistic/LogisticRegressionSGDTrainerTest.java |  6 ++---
 .../ignite/ml/selection/SelectionTestSuite.java    |  6 ++---
 .../ml/selection/cv/CrossValidationTest.java       |  6 ++---
 .../paramgrid/ParameterSetGeneratorTest.java       |  6 ++---
 .../ml/selection/scoring/TestLabelPairCursor.java  |  6 ++---
 .../cursor/CacheBasedLabelPairCursorTest.java      |  6 ++---
 .../scoring/cursor/LocalLabelPairCursorTest.java   |  6 ++---
 .../BinaryClassificationEvaluatorTest.java         |  6 ++---
 .../scoring/evaluator/RegressionEvaluatorTest.java |  6 ++---
 .../metric/classification/AccuracyTest.java        |  6 ++---
 .../BinaryClassificationMetricsTest.java           |  6 ++---
 .../BinaryClassificationMetricsValuesTest.java     |  6 ++---
 .../metric/classification/FmeasureTest.java        |  6 ++---
 .../metric/classification/PrecisionTest.java       |  6 ++---
 .../scoring/metric/classification/ROCAUCTest.java  |  6 ++---
 .../scoring/metric/classification/RecallTest.java  |  6 ++---
 .../metric/regression/RegressionMetricsTest.java   |  6 ++---
 .../split/TrainTestDatasetSplitterTest.java        |  6 ++---
 .../split/mapper/SHA256UniformMapperTest.java      |  6 ++---
 .../ignite/ml/structures/DatasetStructureTest.java |  6 ++---
 .../ignite/ml/structures/StructuresTestSuite.java  |  6 ++---
 .../apache/ignite/ml/svm/SVMBinaryTrainerTest.java |  6 ++---
 .../org/apache/ignite/ml/svm/SVMModelTest.java     |  6 ++---
 .../org/apache/ignite/ml/svm/SVMTestSuite.java     |  6 ++---
 ...onTreeClassificationTrainerIntegrationTest.java |  6 ++---
 .../DecisionTreeClassificationTrainerTest.java     |  6 ++---
 ...cisionTreeRegressionTrainerIntegrationTest.java |  6 ++---
 .../ml/tree/DecisionTreeRegressionTrainerTest.java |  6 ++---
 .../ignite/ml/tree/DecisionTreeTestSuite.java      |  6 ++---
 .../ignite/ml/tree/data/DecisionTreeDataTest.java  |  6 ++---
 .../ignite/ml/tree/data/TreeDataIndexTest.java     |  6 ++---
 .../gini/GiniImpurityMeasureCalculatorTest.java    |  6 ++---
 .../impurity/gini/GiniImpurityMeasureTest.java     |  6 ++---
 .../mse/MSEImpurityMeasureCalculatorTest.java      |  6 ++---
 .../tree/impurity/mse/MSEImpurityMeasureTest.java  |  6 ++---
 .../util/SimpleStepFunctionCompressorTest.java     |  6 ++---
 .../ml/tree/impurity/util/StepFunctionTest.java    |  6 ++---
 .../ml/tree/impurity/util/TestImpurityMeasure.java |  6 ++---
 .../DecisionTreeMNISTIntegrationTest.java          |  6 ++---
 .../ml/tree/performance/DecisionTreeMNISTTest.java |  6 ++---
 .../RandomForestClassifierTrainerTest.java         |  6 ++---
 .../randomforest/RandomForestIntegrationTest.java  |  6 ++---
 .../RandomForestRegressionTrainerTest.java         |  6 ++---
 .../ml/tree/randomforest/RandomForestTest.java     |  6 ++---
 .../randomforest/RandomForestTreeTestSuite.java    |  6 ++---
 .../ml/tree/randomforest/data/TreeNodeTest.java    |  6 ++---
 .../data/impurity/GiniFeatureHistogramTest.java    |  6 ++---
 .../data/impurity/ImpurityHistogramTest.java       |  6 ++---
 .../data/impurity/MSEHistogramTest.java            |  6 ++---
 .../NormalDistributionStatisticsComputerTest.java  |  6 ++---
 .../org/apache/ignite/ml/util/LRUCacheTest.java    |  6 ++---
 .../org/apache/ignite/ml/util/UtilTestSuite.java   |  6 ++---
 .../DataStreamGeneratorFillCacheTest.java          |  6 ++---
 .../util/generators/DataStreamGeneratorTest.java   |  6 ++---
 .../generators/DataStreamGeneratorTestSuite.java   |  6 ++---
 .../scalar/DiscreteRandomProducerTest.java         |  6 ++---
 .../primitives/scalar/GaussRandomProducerTest.java |  6 ++---
 .../primitives/scalar/RandomProducerTest.java      |  6 ++---
 .../scalar/UniformRandomProducerTest.java          |  6 ++---
 .../vector/ParametricVectorGeneratorTest.java      |  6 ++---
 .../vector/VectorGeneratorPrimitivesTest.java      |  6 ++---
 .../primitives/vector/VectorGeneratorTest.java     |  6 ++---
 .../vector/VectorGeneratorsFamilyTest.java         |  6 ++---
 .../trees/columntrees.manualrun.properties         |  6 ++---
 modules/ml/tensorflow-model-parser/pom.xml         |  6 ++---
 .../parser/TensorFlowBaseModelParser.java          |  6 ++---
 .../parser/TensorFlowGraphModelParser.java         |  6 ++---
 .../parser/TensorFlowSavedModelModelParser.java    |  6 ++---
 modules/ml/xgboost-model-parser/pom.xml            |  6 ++---
 .../ignite/ml/xgboost/XGModelComposition.java      |  6 ++---
 .../org/apache/ignite/ml/xgboost/package-info.java |  6 ++---
 .../ml/xgboost/parser/XGBoostModelBaseVisitor.java |  6 ++---
 .../ml/xgboost/parser/XGBoostModelLexer.java       |  6 ++---
 .../ml/xgboost/parser/XGBoostModelListener.java    |  6 ++---
 .../ml/xgboost/parser/XGBoostModelParser.java      |  6 ++---
 .../ml/xgboost/parser/XGBoostModelVisitor.java     |  6 ++---
 .../ignite/ml/xgboost/parser/XGModelParser.java    |  6 ++---
 .../ignite/ml/xgboost/parser/package-info.java     |  6 ++---
 .../ml/xgboost/parser/visitor/XGModelVisitor.java  |  6 ++---
 .../parser/visitor/XGTreeDictionaryVisitor.java    |  6 ++---
 .../ml/xgboost/parser/visitor/XGTreeVisitor.java   |  6 ++---
 .../ml/xgboost/parser/visitor/package-info.java    |  6 ++---
 .../ml/xgboost/IgniteMLXGBoostTestSuite.java       |  6 ++---
 .../ml/xgboost/parser/XGBoostModelParserTest.java  |  6 ++---
 modules/mqtt/pom.xml                               |  6 ++---
 .../apache/ignite/stream/mqtt/MqttStreamer.java    |  6 ++---
 .../apache/ignite/stream/mqtt/package-info.java    |  6 ++---
 .../ignite/stream/mqtt/IgniteMqttStreamerTest.java |  6 ++---
 .../stream/mqtt/IgniteMqttStreamerTestSuite.java   |  6 ++---
 .../apache/ignite/stream/mqtt/package-info.java    |  6 ++---
 modules/osgi-karaf/pom.xml                         |  6 ++---
 modules/osgi-karaf/src/main/resources/features.xml |  6 ++---
 modules/osgi-paxlogging/pom.xml                    |  6 ++---
 modules/osgi/pom.xml                               |  6 ++---
 .../osgi/IgniteAbstractOsgiContextActivator.java   |  6 ++---
 .../org/apache/ignite/osgi/IgniteOsgiUtils.java    |  6 ++---
 .../classloaders/BundleDelegatingClassLoader.java  |  6 ++---
 .../classloaders/ContainerSweepClassLoader.java    |  6 ++---
 .../classloaders/OsgiClassLoadingStrategyType.java |  6 ++---
 .../ignite/osgi/classloaders/package-info.java     |  6 ++---
 .../java/org/apache/ignite/osgi/package-info.java  |  6 ++---
 .../ignite/osgi/AbstractIgniteKarafTest.java       |  6 ++---
 .../osgi/IgniteKarafFeaturesInstallationTest.java  |  6 ++---
 .../apache/ignite/osgi/IgniteOsgiServiceTest.java  |  6 ++---
 .../apache/ignite/osgi/IgniteOsgiTestSuite.java    |  6 ++---
 .../osgi/activators/BasicIgniteTestActivator.java  |  6 ++---
 .../ignite/osgi/activators/TestOsgiFlags.java      |  6 ++---
 .../ignite/osgi/activators/TestOsgiFlagsImpl.java  |  6 ++---
 modules/platforms/cpp/Makefile.am                  |  6 ++---
 modules/platforms/cpp/binary/Makefile.am           |  6 ++---
 modules/platforms/cpp/binary/configure.ac          |  6 ++---
 modules/platforms/cpp/binary/include/Makefile.am   |  6 ++---
 .../cpp/binary/include/ignite/binary/binary.h      |  6 ++---
 .../binary/include/ignite/binary/binary_consts.h   |  6 ++---
 .../include/ignite/binary/binary_containers.h      |  6 ++---
 .../binary/include/ignite/binary/binary_object.h   |  6 ++---
 .../include/ignite/binary/binary_raw_reader.h      |  6 ++---
 .../include/ignite/binary/binary_raw_writer.h      |  6 ++---
 .../binary/include/ignite/binary/binary_reader.h   |  6 ++---
 .../cpp/binary/include/ignite/binary/binary_type.h |  6 ++---
 .../binary/include/ignite/binary/binary_writer.h   |  6 ++---
 .../include/ignite/impl/binary/binary_common.h     |  6 ++---
 .../include/ignite/impl/binary/binary_field_meta.h |  6 ++---
 .../ignite/impl/binary/binary_id_resolver.h        |  6 ++---
 .../ignite/impl/binary/binary_object_header.h      |  6 ++---
 .../ignite/impl/binary/binary_object_impl.h        |  6 ++---
 .../ignite/impl/binary/binary_reader_impl.h        |  6 ++---
 .../include/ignite/impl/binary/binary_schema.h     |  6 ++---
 .../ignite/impl/binary/binary_type_handler.h       |  6 ++---
 .../include/ignite/impl/binary/binary_type_impl.h  |  6 ++---
 .../ignite/impl/binary/binary_type_manager.h       |  6 ++---
 .../ignite/impl/binary/binary_type_snapshot.h      |  6 ++---
 .../ignite/impl/binary/binary_type_updater.h       |  6 ++---
 .../include/ignite/impl/binary/binary_utils.h      |  6 ++---
 .../ignite/impl/binary/binary_writer_impl.h        |  6 ++---
 .../binary/include/ignite/impl/interop/interop.h   |  6 ++---
 .../ignite/impl/interop/interop_input_stream.h     |  6 ++---
 .../include/ignite/impl/interop/interop_memory.h   |  6 ++---
 .../ignite/impl/interop/interop_output_stream.h    |  6 ++---
 .../impl/interop/interop_stream_position_guard.h   |  6 ++---
 .../cpp/binary/src/binary/binary_containers.cpp    |  6 ++---
 .../cpp/binary/src/binary/binary_raw_reader.cpp    |  6 ++---
 .../cpp/binary/src/binary/binary_raw_writer.cpp    |  6 ++---
 .../cpp/binary/src/binary/binary_reader.cpp        |  6 ++---
 .../cpp/binary/src/binary/binary_type.cpp          |  6 ++---
 .../cpp/binary/src/binary/binary_writer.cpp        |  6 ++---
 .../binary/src/impl/binary/binary_field_meta.cpp   |  6 ++---
 .../src/impl/binary/binary_object_header.cpp       |  6 ++---
 .../binary/src/impl/binary/binary_object_impl.cpp  |  6 ++---
 .../binary/src/impl/binary/binary_reader_impl.cpp  |  6 ++---
 .../cpp/binary/src/impl/binary/binary_schema.cpp   |  6 ++---
 .../binary/src/impl/binary/binary_type_handler.cpp |  6 ++---
 .../binary/src/impl/binary/binary_type_impl.cpp    |  6 ++---
 .../binary/src/impl/binary/binary_type_manager.cpp |  6 ++---
 .../src/impl/binary/binary_type_snapshot.cpp       |  6 ++---
 .../cpp/binary/src/impl/binary/binary_utils.cpp    |  6 ++---
 .../binary/src/impl/binary/binary_writer_impl.cpp  |  6 ++---
 .../src/impl/interop/interop_input_stream.cpp      |  6 ++---
 .../cpp/binary/src/impl/interop/interop_memory.cpp |  6 ++---
 .../src/impl/interop/interop_output_stream.cpp     |  6 ++---
 modules/platforms/cpp/common/Makefile.am           |  6 ++---
 modules/platforms/cpp/common/configure.ac          |  6 ++---
 modules/platforms/cpp/common/include/Makefile.am   |  6 ++---
 .../cpp/common/include/ignite/common/big_integer.h |  6 ++---
 .../cpp/common/include/ignite/common/bits.h        |  6 ++---
 .../cpp/common/include/ignite/common/cancelable.h  |  6 ++---
 .../cpp/common/include/ignite/common/concurrent.h  |  6 ++---
 .../cpp/common/include/ignite/common/decimal.h     |  6 ++---
 .../include/ignite/common/default_allocator.h      |  6 ++---
 .../include/ignite/common/dynamic_size_array.h     |  6 ++---
 .../cpp/common/include/ignite/common/expected.h    |  6 ++---
 .../include/ignite/common/fixed_size_array.h       |  6 ++---
 .../cpp/common/include/ignite/common/lazy.h        |  6 ++---
 .../common/include/ignite/common/platform_utils.h  |  6 ++---
 .../cpp/common/include/ignite/common/promise.h     |  6 ++---
 .../common/include/ignite/common/reference_impl.h  |  6 ++---
 .../common/include/ignite/common/shared_state.h    |  6 ++---
 .../cpp/common/include/ignite/common/utils.h       |  6 ++---
 modules/platforms/cpp/common/include/ignite/date.h |  6 ++---
 .../platforms/cpp/common/include/ignite/future.h   |  6 ++---
 modules/platforms/cpp/common/include/ignite/guid.h |  6 ++---
 .../cpp/common/include/ignite/ignite_error.h       |  6 ++---
 .../cpp/common/include/ignite/reference.h          |  6 ++---
 modules/platforms/cpp/common/include/ignite/time.h |  6 ++---
 .../cpp/common/include/ignite/timestamp.h          |  6 ++---
 .../cpp/common/os/linux/include/Makefile.am        |  6 ++---
 .../common/os/linux/include/ignite/common/common.h |  6 ++---
 .../os/linux/include/ignite/common/concurrent_os.h |  6 ++---
 .../linux/include/ignite/common/dynamic_load_os.h  |  6 ++---
 .../common/os/linux/src/common/concurrent_os.cpp   |  6 ++---
 .../common/os/linux/src/common/dynamic_load_os.cpp |  6 ++---
 .../common/os/linux/src/common/platform_utils.cpp  |  6 ++---
 .../common/os/win/include/ignite/common/common.h   |  6 ++---
 .../os/win/include/ignite/common/concurrent_os.h   |  6 ++---
 .../os/win/include/ignite/common/dynamic_load_os.h |  6 ++---
 .../cpp/common/os/win/src/common/concurrent_os.cpp |  6 ++---
 .../common/os/win/src/common/dynamic_load_os.cpp   |  6 ++---
 .../common/os/win/src/common/platform_utils.cpp    |  6 ++---
 .../cpp/common/src/common/big_integer.cpp          |  6 ++---
 modules/platforms/cpp/common/src/common/bits.cpp   |  6 ++---
 .../platforms/cpp/common/src/common/concurrent.cpp |  6 ++---
 .../platforms/cpp/common/src/common/decimal.cpp    |  6 ++---
 modules/platforms/cpp/common/src/common/utils.cpp  |  6 ++---
 modules/platforms/cpp/common/src/date.cpp          |  6 ++---
 modules/platforms/cpp/common/src/guid.cpp          |  6 ++---
 modules/platforms/cpp/common/src/ignite_error.cpp  |  6 ++---
 modules/platforms/cpp/common/src/time.cpp          |  6 ++---
 modules/platforms/cpp/common/src/timestamp.cpp     |  6 ++---
 modules/platforms/cpp/configure.ac                 |  6 ++---
 modules/platforms/cpp/configure.acrel              |  6 ++---
 modules/platforms/cpp/core-test/Makefile.am        |  6 ++---
 .../cpp/core-test/config/cache-identity-32.xml     |  6 ++---
 .../core-test/config/cache-identity-default.xml    |  6 ++---
 .../cpp/core-test/config/cache-identity.xml        |  6 ++---
 .../cpp/core-test/config/cache-query-32.xml        |  6 ++---
 .../core-test/config/cache-query-continuous-32.xml |  6 ++---
 .../config/cache-query-continuous-default.xml      |  6 ++---
 .../core-test/config/cache-query-continuous.xml    |  6 ++---
 .../cpp/core-test/config/cache-query-default.xml   |  6 ++---
 .../platforms/cpp/core-test/config/cache-query.xml |  6 ++---
 .../cpp/core-test/config/cache-store-32.xml        |  6 ++---
 .../cpp/core-test/config/cache-store-default.xml   |  6 ++---
 .../platforms/cpp/core-test/config/cache-store.xml |  6 ++---
 .../cpp/core-test/config/cache-test-32.xml         |  6 ++---
 .../cpp/core-test/config/cache-test-default.xml    |  6 ++---
 .../platforms/cpp/core-test/config/cache-test.xml  |  6 ++---
 modules/platforms/cpp/core-test/config/invalid.xml |  6 ++---
 .../platforms/cpp/core-test/config/isolated-32.xml |  6 ++---
 .../cpp/core-test/config/isolated-default.xml      |  6 ++---
 .../platforms/cpp/core-test/config/isolated.xml    |  6 ++---
 .../cpp/core-test/config/persistence-store-32.xml  |  6 ++---
 .../core-test/config/persistence-store-default.xml |  6 ++---
 .../cpp/core-test/config/persistence-store.xml     |  6 ++---
 modules/platforms/cpp/core-test/configure.ac       |  6 ++---
 .../platforms/cpp/core-test/include/Makefile.am    |  6 ++---
 .../core-test/include/ignite/binary_test_defs.h    |  6 ++---
 .../core-test/include/ignite/binary_test_utils.h   |  6 ++---
 .../cpp/core-test/include/ignite/complex_type.h    |  6 ++---
 .../cpp/core-test/include/ignite/test_type.h       |  6 ++---
 .../cpp/core-test/include/ignite/test_utils.h      |  6 ++---
 .../src/binary_identity_resolver_test.cpp          |  6 ++---
 .../cpp/core-test/src/binary_object_test.cpp       |  6 ++---
 .../src/binary_reader_writer_raw_test.cpp          |  6 ++---
 .../core-test/src/binary_reader_writer_test.cpp    |  6 ++---
 .../cpp/core-test/src/binary_session_test.cpp      |  6 ++---
 .../cpp/core-test/src/binary_test_defs.cpp         |  6 ++---
 modules/platforms/cpp/core-test/src/bits_test.cpp  |  6 ++---
 .../cpp/core-test/src/cache_invoke_test.cpp        |  6 ++---
 .../cpp/core-test/src/cache_query_test.cpp         |  6 ++---
 .../cpp/core-test/src/cache_store_test.cpp         |  6 ++---
 modules/platforms/cpp/core-test/src/cache_test.cpp |  6 ++---
 .../platforms/cpp/core-test/src/cluster_test.cpp   |  6 ++---
 .../platforms/cpp/core-test/src/compute_test.cpp   |  6 ++---
 .../cpp/core-test/src/concurrent_test.cpp          |  6 ++---
 .../cpp/core-test/src/continuous_query_test.cpp    |  6 ++---
 .../platforms/cpp/core-test/src/date_time_test.cpp |  6 ++---
 .../platforms/cpp/core-test/src/decimal_test.cpp   |  6 ++---
 .../cpp/core-test/src/dynamic_size_array_test.cpp  |  6 ++---
 .../cpp/core-test/src/fixed_size_array_test.cpp    |  6 ++---
 .../platforms/cpp/core-test/src/future_test.cpp    |  6 ++---
 .../cpp/core-test/src/handle_registry_test.cpp     |  6 ++---
 .../cpp/core-test/src/ignite_error_test.cpp        |  6 ++---
 .../platforms/cpp/core-test/src/ignition_test.cpp  |  6 ++---
 .../cpp/core-test/src/interop_memory_test.cpp      |  6 ++---
 .../platforms/cpp/core-test/src/interop_test.cpp   |  6 ++---
 .../platforms/cpp/core-test/src/reference_test.cpp |  6 ++---
 modules/platforms/cpp/core-test/src/test_utils.cpp |  6 ++---
 .../cpp/core-test/src/transactions_test.cpp        |  6 ++---
 modules/platforms/cpp/core/Makefile.am             |  6 ++---
 modules/platforms/cpp/core/configure.ac            |  6 ++---
 modules/platforms/cpp/core/include/Makefile.am     |  6 ++---
 .../cpp/core/include/ignite/cache/cache.h          |  6 ++---
 .../cpp/core/include/ignite/cache/cache_entry.h    |  6 ++---
 .../include/ignite/cache/cache_entry_processor.h   |  6 ++---
 .../core/include/ignite/cache/cache_peek_mode.h    |  6 ++---
 .../include/ignite/cache/event/cache_entry_event.h |  6 ++---
 .../ignite/cache/event/cache_entry_event_filter.h  |  6 ++---
 .../cache/event/cache_entry_event_listener.h       |  6 ++---
 .../include/ignite/cache/mutable_cache_entry.h     |  6 ++---
 .../cache/query/continuous/continuous_query.h      |  6 ++---
 .../query/continuous/continuous_query_handle.h     |  6 ++---
 .../cpp/core/include/ignite/cache/query/query.h    |  6 ++---
 .../core/include/ignite/cache/query/query_cursor.h |  6 ++---
 .../ignite/cache/query/query_fields_cursor.h       |  6 ++---
 .../include/ignite/cache/query/query_fields_row.h  |  6 ++---
 .../core/include/ignite/cache/query/query_scan.h   |  6 ++---
 .../core/include/ignite/cache/query/query_sql.h    |  6 ++---
 .../include/ignite/cache/query/query_sql_fields.h  |  6 ++---
 .../core/include/ignite/cache/query/query_text.h   |  6 ++---
 .../cpp/core/include/ignite/compute/compute.h      |  6 ++---
 .../cpp/core/include/ignite/compute/compute_func.h |  6 ++---
 modules/platforms/cpp/core/include/ignite/ignite.h |  6 ++---
 .../cpp/core/include/ignite/ignite_binding.h       |  6 ++---
 .../core/include/ignite/ignite_binding_context.h   |  6 ++---
... 274975 lines suppressed ...