You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by ag...@apache.org on 2018/11/20 18:04:39 UTC

[46/50] [abbrv] ignite git commit: Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/ignite into ignite-9720

Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/ignite into ignite-9720


Project: http://git-wip-us.apache.org/repos/asf/ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/45a4a6f5
Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/45a4a6f5
Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/45a4a6f5

Branch: refs/heads/ignite-9720
Commit: 45a4a6f57216dedc70023c17b550f7c8a0f2efe7
Parents: 36d3169 d6d4965
Author: Alexey Goncharuk <al...@gmail.com>
Authored: Tue Nov 20 19:30:29 2018 +0300
Committer: Alexey Goncharuk <al...@gmail.com>
Committed: Tue Nov 20 19:30:29 2018 +0300

----------------------------------------------------------------------
 RELEASE_NOTES.txt                               |  152 +
 bin/ignite-tf.sh                                |    0
 ...ggedLogisticRegressionSGDTrainerExample.java |  108 +
 .../logistic/bagged/package-info.java           |   22 +
 .../examples/ml/util/MLSandboxDatasets.java     |   16 +-
 .../ignite/examples/ml/util/SandboxMLCache.java |    3 +-
 .../ignite/examples/ml/util/datasets/README.md  |    2 +
 .../ml/util/datasets/boston_housing_dataset.txt |  505 +++
 .../ml/util/datasets/cleared_machines.csv       |  209 ++
 .../ml/util/datasets/glass_identification.csv   |  116 +
 .../ignite/examples/ml/util/datasets/iris.txt   |  150 +
 .../examples/ml/util/datasets/mortalitydata.csv |   53 +
 .../examples/ml/util/datasets/titanic.csv       | 1310 +++++++
 .../ml/util/datasets/titanic_10_rows.csv        |   11 +
 .../ml/util/datasets/two_classed_iris.csv       |  100 +
 .../ignite/examples/ml/util/datasets/wine.txt   |  178 +
 examples/src/main/resources/datasets/README.md  |    2 -
 .../datasets/boston_housing_dataset.txt         |  505 ---
 .../resources/datasets/cleared_machines.csv     |  209 --
 .../resources/datasets/glass_identification.csv |  116 -
 examples/src/main/resources/datasets/iris.txt   |  150 -
 .../main/resources/datasets/mortalitydata.csv   |   53 -
 .../src/main/resources/datasets/titanic.csv     | 1310 -------
 .../main/resources/datasets/titanic_10_rows.csv |   11 -
 .../resources/datasets/two_classed_iris.csv     |  100 -
 examples/src/main/resources/datasets/wine.txt   |  178 -
 idea/ignite_inspections_teamcity.xml            |    4 +-
 .../aop/aspectj/GridifyAspectJAspect.java       |    2 +-
 .../aspectj/GridifySetToSetAspectJAspect.java   |    2 +-
 .../aspectj/GridifySetToValueAspectJAspect.java |    2 +-
 .../aop/spring/GridifySetToSetSpringAspect.java |    2 +-
 .../spring/GridifySetToValueSpringAspect.java   |    2 +-
 .../gridify/aop/spring/GridifySpringAspect.java |    2 +-
 .../aop/spring/GridifySpringPointcut.java       |    8 +-
 .../apache/ignite/gridify/AbstractAopTest.java  |    3 +-
 .../singlesplit/SingleSplitsLoadTest.java       |    1 -
 .../gridify/GridifySingleSplitLoadTest.java     |    3 -
 .../gridify/ExternalNonSpringAopSelfTest.java   |    2 -
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |    1 -
 .../tcp/ipfinder/s3/TcpDiscoveryS3IpFinder.java |    1 -
 .../cassandra/CassandraCacheStoreFactory.java   |    2 -
 .../store/cassandra/common/CassandraHelper.java |    1 -
 .../store/cassandra/datasource/DataSource.java  |   20 -
 .../KeyValuePersistenceSettings.java            |    5 -
 .../persistence/PersistenceController.java      |    1 -
 .../apache/ignite/tests/DDLGeneratorTest.java   |    1 -
 .../org/apache/ignite/tests/pojos/Person.java   |   20 -
 .../org/apache/ignite/tests/pojos/PersonId.java |    7 -
 .../apache/ignite/tests/pojos/SimplePerson.java |    1 -
 .../ignite/tests/pojos/SimplePersonId.java      |    1 -
 .../ignite/tests/utils/CassandraHelper.java     |    4 -
 .../ignite/tests/utils/TestCacheSession.java    |    1 -
 .../ClientAbstractMultiNodeSelfTest.java        |    3 -
 .../integration/ClientAbstractSelfTest.java     |    2 -
 .../util/ClientConsistentHashSelfTest.java      |    1 -
 .../jdbc2/JdbcAbstractDmlStatementSelfTest.java |    1 -
 .../internal/jdbc2/JdbcBulkLoadSelfTest.java    |    1 -
 .../jdbc2/JdbcComplexQuerySelfTest.java         |    2 -
 .../jdbc2/JdbcDistributedJoinsQueryTest.java    |    2 -
 .../internal/jdbc2/JdbcMetadataSelfTest.java    |   76 +-
 .../jdbc2/JdbcPreparedStatementSelfTest.java    |    1 -
 .../internal/jdbc2/JdbcResultSetSelfTest.java   |    2 -
 .../internal/jdbc2/JdbcStatementSelfTest.java   |    1 -
 .../rest/RestMemcacheProtocolSelfTest.java      |    1 -
 .../processors/rest/TestBinaryClient.java       |    1 -
 .../processors/rest/TestMemcacheClient.java     |    1 -
 .../ignite/jdbc/JdbcComplexQuerySelfTest.java   |    2 -
 .../ignite/jdbc/JdbcErrorsAbstractSelfTest.java |    3 -
 .../ignite/jdbc/JdbcMetadataSelfTest.java       |    2 -
 .../jdbc/JdbcPreparedStatementSelfTest.java     |    1 -
 .../ignite/jdbc/JdbcResultSetSelfTest.java      |    1 -
 .../ignite/jdbc/JdbcStatementSelfTest.java      |    1 -
 .../JdbcThinAbstractDmlStatementSelfTest.java   |    1 -
 .../thin/JdbcThinAutoCloseServerCursorTest.java |    2 -
 .../thin/JdbcThinComplexDmlDdlSelfTest.java     |    1 -
 .../jdbc/thin/JdbcThinComplexQuerySelfTest.java |    2 -
 .../jdbc/thin/JdbcThinConnectionSelfTest.java   |    2 -
 .../jdbc/thin/JdbcThinErrorsSelfTest.java       |   15 +-
 .../jdbc/thin/JdbcThinMetadataSelfTest.java     |   88 +-
 .../JdbcThinMissingLongArrayResultsTest.java    |    2 +-
 .../thin/JdbcThinPreparedStatementSelfTest.java |    1 -
 .../jdbc/thin/JdbcThinResultSetSelfTest.java    |    1 -
 .../jdbc/thin/JdbcThinSchemaCaseTest.java       |    2 +-
 .../thin/JdbcThinSelectAfterAlterTable.java     |    2 -
 .../jdbc/thin/JdbcThinStatementSelfTest.java    |    3 +-
 .../ignite/jdbc/thin/JdbcThinTcpIoTest.java     |    1 -
 ...ThinTransactionsAbstractComplexSelfTest.java |    2 -
 .../jdbc/thin/JdbcThinTransactionsSelfTest.java |   14 -
 ...ThinTransactionsWithMvccEnabledSelfTest.java |   13 -
 .../loadtests/client/ClientCacheBenchmark.java  |    1 -
 .../loadtests/client/ClientTcpSslLoadTest.java  |    1 -
 .../ignite/codegen/MessageCodeGenerator.java    |   11 +-
 modules/compatibility/pom.xml                   |    7 +
 .../IgnitePKIndexesMigrationToUnwrapPkTest.java |  249 ++
 .../testframework/junits/Dependency.java        |   28 +-
 .../junits/IgniteCompatibilityAbstractTest.java |   10 +-
 .../java/org/apache/ignite/IgniteCache.java     |    4 +-
 .../org/apache/ignite/IgniteJdbcDriver.java     |    1 -
 .../org/apache/ignite/IgniteJdbcThinDriver.java |    1 -
 .../apache/ignite/IgniteSystemProperties.java   |   15 +
 .../ignite/cache/query/SqlFieldsQuery.java      |    4 +
 .../org/apache/ignite/cache/query/SqlQuery.java |    4 +
 .../cache/store/jdbc/CacheJdbcBlobStore.java    |    1 -
 .../store/jdbc/CacheJdbcPojoStoreFactory.java   |    2 -
 .../apache/ignite/compute/ComputeTaskName.java  |    2 +-
 .../apache/ignite/compute/ComputeTaskSpis.java  |    1 -
 .../apache/ignite/compute/gridify/Gridify.java  |    6 -
 .../ignite/compute/gridify/GridifySetToSet.java |    1 -
 .../compute/gridify/GridifySetToValue.java      |    1 -
 .../gridify/aop/GridifyDefaultRangeTask.java    |    1 -
 .../aop/GridifySetToSetAbstractAspect.java      |    1 -
 .../configuration/CacheConfiguration.java       |   10 +-
 .../configuration/DataStorageConfiguration.java |    1 -
 .../configuration/IgniteConfiguration.java      |   33 +-
 .../configuration/MemoryConfiguration.java      |    1 -
 .../SqlConnectorConfiguration.java              |    1 -
 .../org/apache/ignite/events/CacheEvent.java    |   24 +-
 .../ignite/failure/AbstractFailureHandler.java  |   16 +-
 .../apache/ignite/failure/FailureHandler.java   |    6 -
 .../java/org/apache/ignite/igfs/IgfsPath.java   |    1 -
 .../records/IgfsNewLineRecordResolver.java      |    1 -
 .../ignite/internal/AsyncSupportAdapter.java    |    1 -
 .../internal/GridEventConsumeHandler.java       |    1 -
 .../ignite/internal/GridJobCancelRequest.java   |    2 +-
 .../ignite/internal/GridJobExecuteRequest.java  |    4 +-
 .../ignite/internal/GridJobExecuteResponse.java |    4 +-
 .../ignite/internal/GridJobSessionImpl.java     |    3 -
 .../ignite/internal/GridJobSiblingsRequest.java |    2 +-
 .../internal/GridJobSiblingsResponse.java       |    2 +-
 .../ignite/internal/GridKernalContext.java      |    5 +
 .../ignite/internal/GridKernalContextImpl.java  |   15 +
 .../ignite/internal/GridKernalGatewayImpl.java  |    2 +-
 .../apache/ignite/internal/GridLoggerProxy.java |    2 -
 .../ignite/internal/GridPluginComponent.java    |    1 -
 .../ignite/internal/GridTaskCancelRequest.java  |    2 +-
 .../ignite/internal/GridTaskSessionRequest.java |    2 +-
 .../IgniteInterruptedCheckedException.java      |    1 -
 .../apache/ignite/internal/IgniteKernal.java    |   10 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |   11 +-
 .../internal/binary/BinaryClassDescriptor.java  |    1 -
 .../internal/binary/BinaryMarshaller.java       |    1 -
 .../internal/binary/BinaryObjectExImpl.java     |    6 +
 .../binary/BinaryObjectOffheapImpl.java         |    1 -
 .../ignite/internal/binary/BinaryTreeSet.java   |    1 -
 .../binary/builder/BinaryObjectBuilderImpl.java |    5 +-
 .../client/GridClientPartitionAffinity.java     |    1 -
 .../connection/GridClientNioTcpConnection.java  |    2 +-
 .../router/GridTcpRouterConfiguration.java      |    1 -
 .../impl/GridRouterCommandLineStartup.java      |    1 -
 .../client/util/GridClientConsistentHash.java   |    1 -
 .../client/util/GridConcurrentHashSet.java      |    2 -
 .../internal/commandline/CommandHandler.java    |   72 +-
 .../internal/direct/DirectMessageReader.java    |   30 +
 .../internal/direct/DirectMessageWriter.java    |   26 +
 .../direct/stream/DirectByteBufferStream.java   |   11 +
 .../stream/v1/DirectByteBufferStreamImplV1.java |   13 +
 .../stream/v2/DirectByteBufferStreamImplV2.java |   19 +-
 .../stream/v3/DirectByteBufferStreamImplV3.java |  298 ++
 .../internal/executor/GridExecutorService.java  |    3 -
 .../igfs/common/IgfsControlResponse.java        |    1 -
 .../apache/ignite/internal/jdbc/JdbcUtils.java  |    2 -
 .../jdbc/thin/JdbcThinDatabaseMetadata.java     |   38 +-
 .../internal/jdbc/thin/JdbcThinResultSet.java   |    3 -
 .../internal/jdbc/thin/JdbcThinTcpIo.java       |    2 -
 .../internal/jdbc/thin/JdbcThinUtils.java       |    2 -
 .../ignite/internal/jdbc2/JdbcConnection.java   |    2 -
 .../internal/jdbc2/JdbcDatabaseMetadata.java    |   38 +-
 .../ignite/internal/jdbc2/JdbcResultSet.java    |    1 -
 .../ignite/internal/jdbc2/JdbcStatement.java    |    1 -
 .../internal/managers/GridManagerAdapter.java   |    2 -
 .../checkpoint/GridCheckpointManager.java       |    3 +-
 .../checkpoint/GridCheckpointRequest.java       |    2 +-
 .../managers/communication/GridIoManager.java   |   11 +-
 .../communication/GridIoUserMessage.java        |    2 +-
 .../communication/IgniteIoTestMessage.java      |    2 +
 .../managers/deployment/GridDeployment.java     |    2 +-
 .../deployment/GridDeploymentCommunication.java |    1 -
 .../deployment/GridDeploymentInfoBean.java      |    2 +-
 .../GridDeploymentPerVersionStore.java          |    1 -
 .../deployment/GridDeploymentRequest.java       |    2 +-
 .../deployment/GridDeploymentResponse.java      |    2 +-
 .../discovery/GridDiscoveryManager.java         |    1 -
 .../encryption/GridEncryptionManager.java       |    3 +-
 .../eventstorage/GridEventStorageManager.java   |    6 +-
 .../eventstorage/GridEventStorageMessage.java   |    2 +-
 .../managers/indexing/GridIndexingManager.java  |    3 -
 .../optimized/OptimizedClassDescriptor.java     |    2 -
 .../optimized/OptimizedObjectInputStream.java   |    3 -
 .../optimized/OptimizedObjectOutputStream.java  |    2 -
 .../OptimizedObjectStreamRegistry.java          |    1 -
 .../internal/pagemem/PageIdAllocator.java       |    3 +
 .../ignite/internal/pagemem/PageUtils.java      |    1 -
 .../pagemem/impl/PageMemoryNoStoreImpl.java     |    2 -
 .../internal/pagemem/wal/record/DataEntry.java  |    1 +
 .../internal/pagemem/wal/record/DataRecord.java |    7 +
 .../pagemem/wal/record/LazyDataEntry.java       |    1 -
 .../pagemem/wal/record/LazyMvccDataEntry.java   |  149 +
 .../wal/record/MemoryRecoveryRecord.java        |    9 +-
 .../pagemem/wal/record/MetastoreDataRecord.java |    8 +-
 .../pagemem/wal/record/MvccDataEntry.java       |   75 +
 .../pagemem/wal/record/MvccDataRecord.java      |   69 +
 .../pagemem/wal/record/MvccTxRecord.java        |   92 +
 .../internal/pagemem/wal/record/TxRecord.java   |   34 +-
 .../pagemem/wal/record/UnwrapMvccDataEntry.java |  130 +
 .../internal/pagemem/wal/record/WALRecord.java  |   10 +-
 .../MetaPageUpdatePartitionDataRecord.java      |    3 +-
 .../affinity/AffinityTopologyVersion.java       |    2 +-
 .../affinity/GridAffinityAssignmentCache.java   |   39 +-
 .../affinity/GridAffinityProcessor.java         |    1 -
 .../processors/authentication/User.java         |    7 +-
 .../UserAuthenticateResponseMessage.java        |    2 +-
 .../cache/CacheAffinitySharedManager.java       |   23 +-
 .../cache/CacheEntryInfoCollection.java         |    2 +-
 .../processors/cache/CacheEntryPredicate.java   |    2 +-
 .../cache/CacheEntryPredicateAdapter.java       |    2 +-
 .../cache/CacheEntryPredicateContainsValue.java |    2 +-
 .../cache/CacheEntryPredicateHasValue.java      |    2 +-
 .../cache/CacheEntryPredicateNoValue.java       |    2 +-
 .../cache/CacheEntrySerializablePredicate.java  |    2 +-
 .../cache/CacheEvictableEntryImpl.java          |    2 -
 .../processors/cache/CacheEvictionEntry.java    |    2 +-
 .../processors/cache/CacheGroupContext.java     |  243 +-
 .../cache/CacheInvokeDirectResult.java          |    2 +-
 .../internal/processors/cache/CacheObject.java  |    2 +-
 .../processors/cache/CacheObjectAdapter.java    |    2 +-
 .../cache/CacheObjectByteArrayImpl.java         |    2 +-
 .../processors/cache/CacheObjectContext.java    |    1 -
 .../processors/cache/CacheObjectImpl.java       |    2 +-
 .../processors/cache/CachesRegistry.java        |    2 +-
 .../processors/cache/ClusterCachesInfo.java     |    8 -
 .../cache/ExchangeDiscoveryEvents.java          |    1 +
 .../processors/cache/GridCacheAdapter.java      |   17 +-
 .../cache/GridCacheAffinityManager.java         |   14 +-
 .../cache/GridCacheConcurrentMapImpl.java       |   10 +-
 .../processors/cache/GridCacheContext.java      |   80 +-
 .../cache/GridCacheDeploymentManager.java       |    1 -
 .../processors/cache/GridCacheEntryEx.java      |   10 +
 .../processors/cache/GridCacheEventManager.java |   33 +-
 .../cache/GridCacheEvictionManager.java         |    6 +-
 .../cache/GridCacheFilterFailedException.java   |    1 -
 .../cache/GridCacheGroupIdMessage.java          |    6 +-
 .../processors/cache/GridCacheIdMessage.java    |    6 +-
 .../processors/cache/GridCacheIoManager.java    |   24 +-
 .../processors/cache/GridCacheMapEntry.java     |  209 +-
 .../processors/cache/GridCacheMessage.java      |   41 +-
 .../cache/GridCacheMvccCandidate.java           |    2 -
 .../GridCachePartitionExchangeManager.java      |  214 +-
 .../processors/cache/GridCacheProcessor.java    |  444 ++-
 .../processors/cache/GridCacheReturn.java       |    1 -
 .../cache/GridCacheSharedTtlCleanupManager.java |   15 +-
 .../processors/cache/GridCacheUtils.java        |    2 +-
 .../cache/GridCacheValueCollection.java         |    1 -
 .../GridChangeGlobalStateMessageResponse.java   |   10 +-
 .../cache/IgniteCacheOffheapManager.java        |   54 +-
 .../cache/IgniteCacheOffheapManagerImpl.java    |  118 +-
 .../processors/cache/IgniteCacheProxyImpl.java  |    2 -
 .../processors/cache/IgniteInternalCache.java   |    1 -
 .../processors/cache/KeyCacheObject.java        |    2 +-
 .../cache/PartitionUpdateCounter.java           |   28 +-
 .../processors/cache/WalStateAckMessage.java    |    2 +
 .../binary/CacheObjectBinaryProcessorImpl.java  |   49 +-
 .../distributed/GridCacheTtlUpdateRequest.java  |   30 +-
 .../distributed/GridCacheTxRecoveryFuture.java  |    2 -
 .../distributed/GridCacheTxRecoveryRequest.java |   26 +-
 .../GridCacheTxRecoveryResponse.java            |   14 +-
 .../distributed/GridDistributedBaseMessage.java |   16 +-
 .../distributed/GridDistributedCacheEntry.java  |   18 +-
 .../distributed/GridDistributedLockRequest.java |   54 +-
 .../GridDistributedLockResponse.java            |   14 +-
 .../GridDistributedTxFinishRequest.java         |   62 +-
 .../GridDistributedTxFinishResponse.java        |   18 +-
 .../GridDistributedTxPrepareRequest.java        |   54 +-
 .../GridDistributedTxPrepareResponse.java       |   14 +-
 .../GridDistributedTxRemoteAdapter.java         |   18 +-
 .../GridDistributedUnlockRequest.java           |    6 +-
 .../dht/CacheDistributedGetFutureAdapter.java   |    6 +-
 .../dht/ClientCacheDhtTopologyFuture.java       |    5 +
 .../dht/GridDhtAffinityAssignmentRequest.java   |   18 +-
 .../dht/GridDhtAffinityAssignmentResponse.java  |   26 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |   22 +-
 .../distributed/dht/GridDhtCacheEntry.java      |    1 -
 .../cache/distributed/dht/GridDhtGetFuture.java |   49 +-
 .../distributed/dht/GridDhtGetSingleFuture.java |   50 +-
 .../distributed/dht/GridDhtLockFuture.java      |    9 +-
 .../distributed/dht/GridDhtLockRequest.java     |   76 +-
 .../distributed/dht/GridDhtLockResponse.java    |   18 +-
 .../distributed/dht/GridDhtTopologyFuture.java  |    6 +
 .../dht/GridDhtTopologyFutureAdapter.java       |  233 +-
 .../dht/GridDhtTransactionalCacheAdapter.java   |   76 +-
 .../dht/GridDhtTxAbstractEnlistFuture.java      |   25 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |    3 +-
 .../distributed/dht/GridDhtTxFinishRequest.java |   54 +-
 .../dht/GridDhtTxFinishResponse.java            |   14 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |   16 +-
 .../distributed/dht/GridDhtTxLocalAdapter.java  |    3 -
 .../cache/distributed/dht/GridDhtTxMapping.java |    1 -
 .../dht/GridDhtTxOnePhaseCommitAckRequest.java  |    6 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |   10 +-
 .../dht/GridDhtTxPrepareRequest.java            |  111 +-
 .../dht/GridDhtTxPrepareResponse.java           |   22 +-
 .../dht/GridDhtTxQueryEnlistRequest.java        |   30 +-
 .../dht/GridDhtTxQueryEnlistResponse.java       |   14 +-
 .../dht/GridDhtTxQueryFirstEnlistRequest.java   |   42 +-
 .../cache/distributed/dht/GridDhtTxRemote.java  |   14 +-
 .../distributed/dht/GridDhtUnlockRequest.java   |    6 +-
 .../dht/GridPartitionedGetFuture.java           |   20 +-
 .../dht/GridPartitionedSingleGetFuture.java     |   28 +-
 .../dht/PartitionUpdateCountersMessage.java     |    2 +
 .../GridDhtAtomicAbstractUpdateRequest.java     |   42 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   12 +-
 .../GridDhtAtomicDeferredUpdateResponse.java    |    6 +-
 .../dht/atomic/GridDhtAtomicNearResponse.java   |   22 +-
 .../GridDhtAtomicSingleUpdateRequest.java       |   18 +-
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |   66 +-
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |   18 +-
 .../GridNearAtomicAbstractUpdateFuture.java     |    1 -
 .../GridNearAtomicAbstractUpdateRequest.java    |   34 +-
 .../GridNearAtomicCheckUpdateRequest.java       |   10 +-
 .../atomic/GridNearAtomicFullUpdateRequest.java |   38 +-
 ...GridNearAtomicSingleUpdateFilterRequest.java |    6 +-
 .../GridNearAtomicSingleUpdateFuture.java       |    2 +-
 ...GridNearAtomicSingleUpdateInvokeRequest.java |   10 +-
 .../GridNearAtomicSingleUpdateRequest.java      |   10 +-
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |    2 +-
 .../atomic/GridNearAtomicUpdateResponse.java    |   36 +-
 .../dht/atomic/NearCacheUpdates.java            |    1 -
 .../dht/colocated/GridDhtColocatedCache.java    |   55 +-
 .../colocated/GridDhtColocatedLockFuture.java   |    6 +-
 .../CachePartitionPartialCountersMap.java       |    2 +-
 .../dht/preloader/GridDhtForceKeysFuture.java   |    4 +-
 .../dht/preloader/GridDhtForceKeysRequest.java  |   22 +-
 .../dht/preloader/GridDhtForceKeysResponse.java |   22 +-
 .../GridDhtPartitionDemandLegacyMessage.java    |   40 +-
 .../GridDhtPartitionDemandMessage.java          |   32 +-
 .../dht/preloader/GridDhtPartitionDemander.java |    6 +-
 .../preloader/GridDhtPartitionExchangeId.java   |    6 +-
 .../GridDhtPartitionSupplyMessage.java          |   44 +-
 .../GridDhtPartitionSupplyMessageV2.java        |    6 +-
 .../GridDhtPartitionsAbstractMessage.java       |   14 +-
 .../GridDhtPartitionsExchangeFuture.java        |  138 +-
 .../preloader/GridDhtPartitionsFullMessage.java |  272 +-
 .../GridDhtPartitionsSingleMessage.java         |   93 +-
 .../GridDhtPartitionsSingleRequest.java         |    6 +-
 .../dht/preloader/GridDhtPreloader.java         |    5 +-
 .../dht/preloader/latch/LatchAckMessage.java    |    6 +-
 .../topology/GridClientPartitionTopology.java   |   10 +-
 .../dht/topology/GridDhtLocalPartition.java     |   23 +-
 .../dht/topology/GridDhtPartitionTopology.java  |   14 +-
 .../topology/GridDhtPartitionTopologyImpl.java  |  292 +-
 .../GridDhtPartitionsStateValidator.java        |    4 +-
 .../distributed/near/CacheVersionedValue.java   |    2 +-
 .../distributed/near/GridNearCacheEntry.java    |    4 +-
 .../distributed/near/GridNearGetFuture.java     |    9 +-
 .../distributed/near/GridNearGetRequest.java    |   91 +-
 .../distributed/near/GridNearGetResponse.java   |   34 +-
 .../distributed/near/GridNearLockFuture.java    |    9 +-
 .../distributed/near/GridNearLockRequest.java   |   71 +-
 .../distributed/near/GridNearLockResponse.java  |   30 +-
 ...arOptimisticSerializableTxPrepareFuture.java |    4 +-
 .../near/GridNearOptimisticTxPrepareFuture.java |    5 -
 .../GridNearPessimisticTxPrepareFuture.java     |    1 -
 .../near/GridNearSingleGetRequest.java          |   75 +-
 .../near/GridNearSingleGetResponse.java         |   26 +-
 .../near/GridNearTransactionalCache.java        |    6 +-
 .../near/GridNearTxEnlistFuture.java            |    4 +-
 .../near/GridNearTxEnlistRequest.java           |   70 +-
 .../near/GridNearTxEnlistResponse.java          |   34 +-
 .../near/GridNearTxFinishFuture.java            |    1 -
 .../near/GridNearTxFinishRequest.java           |   10 +-
 .../near/GridNearTxFinishResponse.java          |   14 +-
 .../cache/distributed/near/GridNearTxLocal.java |   15 +-
 .../near/GridNearTxPrepareFutureAdapter.java    |    1 -
 .../near/GridNearTxPrepareRequest.java          |   58 +-
 .../near/GridNearTxPrepareResponse.java         |   70 +-
 .../near/GridNearTxQueryEnlistRequest.java      |   78 +-
 .../near/GridNearTxQueryEnlistResponse.java     |   44 +-
 .../GridNearTxQueryResultsEnlistFuture.java     |    3 +-
 .../GridNearTxQueryResultsEnlistRequest.java    |   62 +-
 .../GridNearTxQueryResultsEnlistResponse.java   |   12 +-
 .../distributed/near/GridNearTxRemote.java      |   40 +-
 .../distributed/near/GridNearUnlockRequest.java |    2 +-
 .../cache/local/GridLocalCacheEntry.java        |   22 +-
 .../cache/local/GridLocalLockFuture.java        |    4 +-
 .../local/atomic/GridLocalAtomicCache.java      |    3 +-
 .../cache/mvcc/MvccCachingManager.java          |   30 +-
 .../cache/mvcc/MvccProcessorImpl.java           |   80 +-
 .../processors/cache/mvcc/MvccUtils.java        |   17 +-
 .../mvcc/msg/MvccAckRequestTxAndQueryId.java    |    1 +
 .../cache/mvcc/msg/MvccSnapshotResponse.java    |    2 +
 .../cache/mvcc/msg/MvccTxSnapshotRequest.java   |    2 +
 .../PartitionCountersNeighborcastRequest.java   |   10 +-
 .../PartitionCountersNeighborcastResponse.java  |    6 +-
 .../processors/cache/mvcc/txlog/TxLog.java      |   37 +-
 .../persistence/DatabaseLifecycleListener.java  |   48 +-
 .../GridCacheDatabaseSharedManager.java         | 1278 ++++---
 .../persistence/GridCacheOffheapManager.java    |  153 +-
 .../IgniteCacheDatabaseSharedManager.java       |  110 +-
 .../persistence/file/AsyncFileIOFactory.java    |    9 -
 .../file/EncryptedFileIOFactory.java            |    7 -
 .../cache/persistence/file/FileIOFactory.java   |   10 +-
 .../cache/persistence/file/FilePageStore.java   |    7 +-
 .../persistence/file/FilePageStoreManager.java  |   41 +-
 .../file/RandomAccessFileIOFactory.java         |    9 -
 .../cache/persistence/freelist/PagesList.java   |    1 -
 .../persistence/metastorage/MetaStorage.java    |    7 +
 .../MetastorageLifecycleListener.java           |    4 +-
 .../metastorage/MetastorageTree.java            |    8 +
 .../persistence/pagemem/PageMemoryImpl.java     |   13 +-
 .../partstate/PartitionRecoverState.java        |   52 +
 .../snapshot/IgniteCacheSnapshotManager.java    |    4 -
 .../cache/persistence/tree/BPlusTree.java       |    2 +-
 .../cache/persistence/tree/io/BPlusMetaIO.java  |   20 +-
 .../cache/persistence/wal/FileWALPointer.java   |    2 +-
 .../wal/FileWriteAheadLogManager.java           | 1077 +-----
 .../wal/FsyncModeFileWriteAheadLogManager.java  | 3464 ------------------
 .../wal/aware/SegmentLockStorage.java           |    2 -
 .../wal/filehandle/AbstractFileHandle.java      |   47 +
 .../wal/filehandle/FileHandleManager.java       |   81 +
 .../filehandle/FileHandleManagerFactory.java    |   90 +
 .../wal/filehandle/FileHandleManagerImpl.java   |  603 +++
 .../wal/filehandle/FileWriteHandle.java         |  113 +
 .../wal/filehandle/FileWriteHandleImpl.java     |  600 +++
 .../filehandle/FsyncFileHandleManagerImpl.java  |  157 +
 .../wal/filehandle/FsyncFileWriteHandle.java    |  844 +++++
 .../wal/reader/IgniteWalIteratorFactory.java    |   19 +-
 .../wal/reader/StandaloneGridKernalContext.java |    5 +
 .../reader/StandaloneWalRecordsIterator.java    |  126 +-
 .../wal/reader/StrictBoundsCheckException.java  |   35 +
 .../wal/serializer/RecordDataV1Serializer.java  |   49 +-
 .../wal/serializer/RecordDataV2Serializer.java  |  141 +-
 .../wal/serializer/RecordSerializerFactory.java |    2 +
 .../wal/serializer/RecordV1Serializer.java      |    2 -
 .../wal/serializer/TxRecordSerializer.java      |  132 +-
 .../cache/query/GridCacheQueryAdapter.java      |    2 +-
 .../query/GridCacheQueryFutureAdapter.java      |    4 +-
 .../cache/query/GridCacheQueryManager.java      |    5 +-
 .../cache/query/GridCacheQueryRequest.java      |  112 +-
 .../cache/query/GridCacheQueryResponse.java     |   26 +-
 .../cache/query/IgniteQueryErrorCode.java       |    8 +
 .../CacheContinuousQueryBatchAck.java           |   16 +-
 .../continuous/CacheContinuousQueryEntry.java   |    4 +-
 .../CacheContinuousQueryListener.java           |    1 -
 .../continuous/CacheContinuousQueryManager.java |   33 +
 .../store/GridCacheStoreManagerAdapter.java     |    1 -
 .../cache/transactions/IgniteInternalTx.java    |    7 +
 .../transactions/IgniteTransactionsImpl.java    |    1 -
 .../cache/transactions/IgniteTxAdapter.java     |   41 +-
 .../cache/transactions/IgniteTxEntry.java       |    1 -
 .../cache/transactions/IgniteTxHandler.java     |   30 +-
 .../cache/transactions/IgniteTxKey.java         |    2 +-
 .../transactions/IgniteTxLocalAdapter.java      |    4 -
 .../cache/transactions/IgniteTxManager.java     |   82 +-
 .../TransactionProxyRollbackOnlyImpl.java       |    1 -
 .../cache/transactions/TxLocksRequest.java      |   10 +-
 .../cache/transactions/TxLocksResponse.java     |   18 +-
 .../cache/tree/mvcc/data/MvccUpdateDataRow.java |    2 +-
 .../version/GridCacheRawVersionedEntry.java     |    4 +-
 .../cache/version/GridCacheVersion.java         |    1 -
 .../cache/version/GridCacheVersionManager.java  |    1 -
 .../IgniteCacheObjectProcessorImpl.java         |    2 -
 .../continuous/GridContinuousMessage.java       |    2 +-
 .../continuous/GridContinuousProcessor.java     |    6 +-
 .../datastreamer/DataStreamerRequest.java       |    4 +-
 .../datastreamer/DataStreamerResponse.java      |    2 +-
 .../GridCacheAtomicReferenceImpl.java           |    1 -
 .../GridCacheAtomicSequenceImpl.java            |    1 -
 .../GridCacheAtomicStampedImpl.java             |    1 -
 .../datastructures/GridCacheLockImpl.java       |    1 -
 .../datastructures/GridCacheQueueAdapter.java   |    2 -
 .../datastructures/GridCacheQueueProxy.java     |    2 -
 .../datastructures/GridCacheSetImpl.java        |    2 -
 .../datastructures/GridSetQueryPredicate.java   |    1 -
 .../processors/failure/FailureProcessor.java    |    9 +-
 .../processors/hadoop/HadoopClassLoader.java    |    2 -
 .../processors/hadoop/HadoopNoopHelper.java     |    1 -
 .../shuffle/HadoopDirectShuffleMessage.java     |    4 +-
 .../hadoop/shuffle/HadoopShuffleMessage.java    |    2 +
 .../processors/igfs/IgfsAckMessage.java         |    2 +-
 .../internal/processors/igfs/IgfsBlockKey.java  |    2 +-
 .../processors/igfs/IgfsBlocksMessage.java      |    2 +-
 .../igfs/IgfsCommunicationMessage.java          |    2 +-
 .../processors/igfs/IgfsDataManager.java        |    2 -
 .../processors/igfs/IgfsDeleteMessage.java      |    2 +-
 .../processors/igfs/IgfsDirectoryInfo.java      |    1 -
 .../processors/igfs/IgfsFileAffinityRange.java  |    1 -
 .../internal/processors/igfs/IgfsFileInfo.java  |    1 -
 .../igfs/IgfsFragmentizerRequest.java           |    2 +-
 .../igfs/IgfsFragmentizerResponse.java          |    2 +-
 .../processors/igfs/IgfsInputStreamImpl.java    |    1 -
 .../processors/igfs/IgfsIpcHandler.java         |    1 -
 .../processors/igfs/IgfsMetaManager.java        |    2 +-
 .../internal/processors/igfs/IgfsProcessor.java |    1 -
 .../processors/igfs/IgfsSyncMessage.java        |    2 +-
 .../internal/processors/igfs/IgfsUtils.java     |    2 -
 .../igfs/client/IgfsClientAbstractCallable.java |    1 -
 .../processors/job/GridJobProcessor.java        |    3 +-
 ...ClientListenerAbstractConnectionContext.java |    6 +-
 .../odbc/ClientListenerConnectionContext.java   |    6 +
 .../odbc/ClientListenerNioListener.java         |   21 +-
 .../processors/odbc/SqlListenerUtils.java       |    1 -
 .../odbc/jdbc/JdbcBatchExecuteRequest.java      |    1 -
 .../odbc/jdbc/JdbcBulkLoadBatchRequest.java     |    2 -
 .../odbc/jdbc/JdbcQueryExecuteRequest.java      |    1 -
 .../odbc/jdbc/JdbcRequestHandler.java           |   50 +-
 .../odbc/odbc/OdbcRequestHandler.java           |   12 +-
 .../processors/odbc/odbc/OdbcUtils.java         |   23 +
 .../offheap/GridOffHeapProcessor.java           |    1 -
 .../platform/PlatformContextImpl.java           |    1 -
 .../processors/platform/PlatformIgnition.java   |    1 -
 .../platform/PlatformNativeException.java       |    1 -
 .../platform/PlatformNoCallbackException.java   |    1 -
 .../processors/platform/PlatformProcessor.java  |    2 +-
 .../platform/PlatformProcessorImpl.java         |    2 +-
 .../processors/platform/PlatformTarget.java     |    1 -
 .../platform/PlatformTargetProxy.java           |    1 -
 .../platform/cache/PlatformCache.java           |    2 +-
 .../cache/affinity/PlatformAffinity.java        |    3 +-
 .../cache/query/PlatformContinuousQuery.java    |    1 -
 .../query/PlatformContinuousQueryImpl.java      |    1 -
 .../callback/PlatformCallbackGateway.java       |    1 -
 .../platform/client/ClientRequest.java          |    9 +-
 .../platform/client/ClientRequestHandler.java   |   18 +-
 .../binary/ClientBinaryTypePutRequest.java      |    1 -
 .../client/cache/ClientCacheClearRequest.java   |    1 -
 .../client/cache/ClientCacheGetSizeRequest.java |    1 -
 .../cache/ClientCacheNodePartitionsRequest.java |    4 +-
 .../cache/ClientCacheRemoveAllRequest.java      |    1 -
 .../platform/cluster/PlatformClusterGroup.java  |    3 +-
 .../cluster/PlatformClusterNodeFilterImpl.java  |    1 -
 .../platform/compute/PlatformAbstractTask.java  |    2 -
 .../PlatformBalancingMultiClosureTask.java      |    1 -
 .../PlatformBalancingSingleClosureTask.java     |    1 -
 .../platform/compute/PlatformCompute.java       |    2 +-
 .../platform/compute/PlatformFullJob.java       |    2 -
 .../datastreamer/PlatformDataStreamer.java      |    2 +-
 .../PlatformStreamReceiverImpl.java             |    1 -
 .../dotnet/PlatformDotNetCacheStore.java        |    2 +-
 .../PlatformDotNetConfigurationClosure.java     |    2 -
 .../platform/events/PlatformEvents.java         |    2 +-
 .../platform/messaging/PlatformMessaging.java   |    1 -
 .../services/PlatformAbstractService.java       |    1 -
 .../platform/services/PlatformServices.java     |    2 -
 .../transactions/PlatformTransactions.java      |    2 +-
 .../utils/PlatformConfigurationUtils.java       |   14 +-
 .../platform/utils/PlatformFutureUtils.java     |    1 -
 .../platform/utils/PlatformUtils.java           |    5 +-
 .../websession/PlatformDotNetSessionData.java   |    1 -
 .../PlatformDotNetSessionLockProcessor.java     |    1 -
 .../PlatformDotNetSessionLockResult.java        |    1 -
 .../processors/plugin/CachePluginManager.java   |    1 -
 .../processors/query/GridQueryIndexing.java     |   30 +-
 .../processors/query/GridQueryProcessor.java    |  325 +-
 .../processors/query/QueryKeyValueIterable.java |   53 +
 .../processors/query/QueryKeyValueIterator.java |   68 +
 .../query/QueryTypeDescriptorImpl.java          |   26 +-
 .../internal/processors/query/QueryUtils.java   |   39 +-
 .../messages/GridQueryNextPageResponse.java     |    4 +-
 .../query/property/QueryBinaryProperty.java     |    8 +-
 .../schema/SchemaIndexCacheVisitorImpl.java     |    1 -
 .../query/schema/SchemaOperationManager.java    |    1 -
 .../message/SchemaOperationStatusMessage.java   |    2 +
 .../processors/resource/GridResourceIoc.java    |    1 -
 .../resource/GridResourceLoggerInjector.java    |    1 -
 .../processors/rest/GridRestResponse.java       |    1 -
 .../client/message/GridClientCacheRequest.java  |    2 -
 .../handlers/cache/GridCacheCommandHandler.java |    1 -
 .../handlers/query/QueryCommandHandler.java     |    1 -
 .../handlers/task/GridTaskResultRequest.java    |    2 +-
 .../handlers/task/GridTaskResultResponse.java   |    2 +-
 .../rest/protocols/GridRestProtocolAdapter.java |    1 -
 .../tcp/GridTcpMemcachedNioListener.java        |    1 -
 .../protocols/tcp/GridTcpRestNioListener.java   |    1 -
 .../rest/protocols/tcp/GridTcpRestProtocol.java |    1 -
 .../security/SecurityContextHolder.java         |   15 +-
 .../processors/service/GridServiceProxy.java    |    1 -
 .../processors/task/GridTaskProcessor.java      |    1 -
 .../processors/task/GridTaskWorker.java         |    1 -
 .../sql/command/SqlBulkLoadCommand.java         |    1 -
 .../org/apache/ignite/internal/util/F0.java     |    4 +-
 .../util/GridBoundedConcurrentOrderedMap.java   |    1 -
 .../util/GridBoundedConcurrentOrderedSet.java   |    1 -
 .../internal/util/GridBoundedLinkedHashSet.java |    2 +-
 .../ignite/internal/util/GridByteArrayList.java |    2 +-
 .../internal/util/GridCircularBuffer.java       |    1 -
 .../util/GridConcurrentPhantomHashSet.java      |    2 -
 .../util/GridConcurrentSkipListSet.java         |    2 +-
 .../util/GridConcurrentWeakHashSet.java         |    2 -
 .../ignite/internal/util/GridIntList.java       |    2 +-
 .../ignite/internal/util/GridLeanMap.java       |    1 -
 .../ignite/internal/util/GridLeanSet.java       |    2 +-
 .../ignite/internal/util/GridListSet.java       |    3 +-
 .../ignite/internal/util/GridLongList.java      |    2 +
 .../apache/ignite/internal/util/GridMutex.java  |    1 -
 .../ignite/internal/util/GridSetWrapper.java    |    2 -
 .../ignite/internal/util/GridSnapshotLock.java  |    1 -
 .../internal/util/GridSpinReadWriteLock.java    |    2 -
 .../ignite/internal/util/IgniteUtils.java       |  420 ++-
 .../internal/util/OffheapReadWriteLock.java     |    1 -
 .../util/future/GridCompoundFuture.java         |    1 -
 .../util/future/GridEmbeddedFuture.java         |    2 -
 .../internal/util/gridify/GridifyUtils.java     |    1 -
 .../internal/util/io/GridUnsafeDataOutput.java  |   76 +-
 .../ipc/shmem/IpcSharedMemoryNativeLoader.java  |    2 -
 .../util/ipc/shmem/IpcSharedMemorySpace.java    |    1 -
 .../ignite/internal/util/lang/GridFunc.java     |    9 +-
 .../util/lang/GridMetadataAwareAdapter.java     |    3 -
 .../ignite/internal/util/lang/GridTriple.java   |    1 -
 .../ignite/internal/util/lang/GridTuple.java    |    1 -
 .../ignite/internal/util/lang/GridTuple3.java   |    1 -
 .../ignite/internal/util/lang/GridTuple4.java   |    1 -
 .../ignite/internal/util/lang/GridTuple5.java   |    1 -
 .../ignite/internal/util/lang/GridTuple6.java   |    1 -
 .../ignite/internal/util/lang/IgnitePair.java   |    1 -
 .../util/lang/IgniteThrowableConsumer.java      |    6 +-
 .../gridfunc/CacheEntryGetValueClosure.java     |    1 -
 .../gridfunc/CacheEntryHasPeekPredicate.java    |    1 -
 .../ignite/internal/util/nio/GridNioServer.java |    2 -
 .../util/offheap/unsafe/GridUnsafeMap.java      |    8 +-
 .../unsafe/GridUnsafePartitionedMap.java        |    1 -
 .../util/tostring/GridToStringBuilder.java      |    2 -
 .../util/tostring/GridToStringOrder.java        |    2 +-
 .../internal/util/typedef/internal/U.java       |    1 -
 .../internal/util/worker/GridWorkerPool.java    |    2 +-
 .../ignite/internal/visor/cache/VisorCache.java |   20 +-
 .../VisorCacheConfigurationCollectorTask.java   |   40 +
 .../cache/VisorCacheToggleStatisticsTask.java   |   72 +
 .../VisorCacheToggleStatisticsTaskArg.java      |   87 +
 .../visor/node/VisorNodeDataCollectorJob.java   |    3 +-
 .../ignite/internal/worker/WorkersRegistry.java |    2 +-
 .../org/apache/ignite/lang/IgniteBiTuple.java   |    2 -
 .../ignite/lang/IgniteProductVersion.java       |    1 -
 .../logger/java/JavaLoggerFileHandler.java      |    1 -
 .../ignite/logger/java/JavaLoggerFormatter.java |    1 -
 .../AbstractNodeNameAwareMarshaller.java        |    1 -
 .../apache/ignite/mxbean/MXBeanDescription.java |    2 +-
 .../mxbean/MXBeanParametersDescriptions.java    |    2 +-
 .../ignite/mxbean/MXBeanParametersNames.java    |    2 +-
 .../dotnet/PlatformDotNetConfiguration.java     |    1 -
 .../MessageCollectionItemType.java              |    5 +-
 .../extensions/communication/MessageReader.java |    9 +
 .../extensions/communication/MessageWriter.java |   10 +
 .../ignite/services/ServiceConfiguration.java   |    1 -
 .../ignite/spi/IgniteSpiConfiguration.java      |    1 -
 .../ignite/spi/IgniteSpiConsistencyChecked.java |    2 -
 .../spi/IgniteSpiMultipleInstancesSupport.java  |    2 +-
 .../org/apache/ignite/spi/IgniteSpiThread.java  |    1 -
 .../jobstealing/JobStealingCollisionSpi.java    |    2 -
 .../jobstealing/JobStealingRequest.java         |    2 +-
 .../communication/tcp/TcpCommunicationSpi.java  |   23 +-
 .../tcp/messages/HandshakeMessage.java          |    2 +
 .../tcp/messages/HandshakeMessage2.java         |    2 +
 .../tcp/messages/NodeIdMessage.java             |    2 +
 .../messages/RecoveryLastReceivedMessage.java   |    2 +
 .../deployment/local/LocalDeploymentSpi.java    |    1 -
 .../discovery/DiscoverySpiHistorySupport.java   |    1 -
 .../spi/discovery/DiscoverySpiOrderSupport.java |    1 -
 .../ignite/spi/discovery/tcp/ClientImpl.java    |    1 -
 .../ignite/spi/discovery/tcp/ServerImpl.java    |    6 +-
 .../spi/discovery/tcp/TcpDiscoveryImpl.java     |    2 -
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |    5 -
 .../spi/failover/always/AlwaysFailoverSpi.java  |    1 -
 .../jobstealing/JobStealingFailoverSpi.java     |    1 -
 .../ignite/startup/cmdline/AboutDialog.java     |    1 -
 .../startup/cmdline/CommandLineStartup.java     |    1 -
 .../startup/cmdline/CommandLineTransformer.java |    1 -
 .../org/apache/ignite/thread/IgniteThread.java  |   44 +-
 .../resources/META-INF/classnames.properties    |    5 -
 .../ignite/cache/ResetLostPartitionTest.java    |  260 ++
 ...ityFunctionBackupFilterAbstractSelfTest.java |    1 -
 ...unctionExcludeNeighborsAbstractSelfTest.java |    1 -
 .../ignite/failure/IoomFailureHandlerTest.java  |   28 +-
 .../internal/ClusterNodeMetricsSelfTest.java    |    1 -
 .../internal/GridAffinityP2PSelfTest.java       |    1 -
 .../GridAlwaysFailoverSpiFailSelfTest.java      |    2 -
 .../internal/GridCancelUnusedJobSelfTest.java   |    1 -
 .../ignite/internal/GridDeploymentSelfTest.java |    2 -
 .../ignite/internal/GridDiscoverySelfTest.java  |    2 -
 ...ventStorageRuntimeConfigurationSelfTest.java |    1 -
 .../GridFailoverCustomTopologySelfTest.java     |    2 +-
 .../internal/GridFailoverTopologySelfTest.java  |    1 -
 .../internal/GridJobStealingSelfTest.java       |    7 -
 .../internal/GridListenActorSelfTest.java       |    1 -
 .../internal/GridMultipleSpisSelfTest.java      |    1 -
 .../GridMultithreadedJobStealingSelfTest.java   |    1 -
 .../internal/GridNodeMetricsLogSelfTest.java    |    1 -
 .../apache/ignite/internal/GridSelfTest.java    |    1 -
 .../ignite/internal/GridStartStopSelfTest.java  |    2 +-
 .../GridTaskContinuousMapperSelfTest.java       |    2 -
 .../internal/GridTaskFailoverSelfTest.java      |    1 -
 .../GridTaskFutureImplStopGridSelfTest.java     |    4 +-
 .../internal/GridTaskListenerSelfTest.java      |    3 +-
 .../internal/GridTaskTimeoutSelfTest.java       |    1 -
 .../internal/IgniteExecutorServiceTest.java     |    2 -
 ...gniteExplicitImplicitDeploymentSelfTest.java |    1 -
 .../internal/SensitiveInfoTestLoggerProxy.java  |    2 -
 .../internal/binary/BinaryEnumsSelfTest.java    |    1 -
 .../binary/BinaryFieldExtractionSelfTest.java   |    2 -
 .../binary/BinaryFieldsAbstractSelfTest.java    |    3 -
 .../binary/BinaryMarshallerSelfTest.java        |   23 +-
 .../BinaryObjectBuilderAdditionalSelfTest.java  |    2 -
 ...naryObjectBuilderDefaultMappersSelfTest.java |    4 -
 ...ilderSimpleNameLowerCaseMappersSelfTest.java |    1 -
 .../binary/BinaryObjectExceptionSelfTest.java   |    1 -
 .../binary/GridBinaryAffinityKeySelfTest.java   |    1 -
 .../binary/GridBinaryWildcardsSelfTest.java     |    6 -
 ...aultBinaryMappersBinaryMetaDataSelfTest.java |    2 -
 .../GridBinaryMarshalerAwareTestClass.java      |    1 -
 .../mutabletest/GridBinaryTestClasses.java      |    1 -
 .../commandline/CommandHandlerParsingTest.java  |    1 -
 .../managers/IgniteDiagnosticMessagesTest.java  |   53 +-
 ...idCommunicationManagerListenersSelfTest.java |    2 -
 ...unicationBalanceMultipleConnectionsTest.java |    5 -
 .../GridDeploymentMessageCountSelfTest.java     |    1 -
 .../optimized/OptimizedMarshallerSelfTest.java  |    1 -
 .../optimized/OptimizedMarshallerTest.java      |   63 +-
 .../OptimizedObjectStreamSelfTest.java          |    6 -
 .../GridAffinityProcessorAbstractSelfTest.java  |    1 -
 .../Authentication1kUsersNodeRestartTest.java   |   77 +-
 .../AuthenticationConfigurationClusterTest.java |   14 +
 .../AuthenticationOnNotActiveClusterTest.java   |   15 +
 .../AuthenticationProcessorNodeRestartTest.java |   14 +
 .../AuthenticationProcessorSelfTest.java        |   14 +
 .../cache/CacheNoAffinityExchangeTest.java      |  218 ++
 .../cache/CashEventWithTxLabelTest.java         |  487 +++
 .../cache/ClusterStateAbstractTest.java         |    1 -
 ...idAbstractCacheInterceptorRebalanceTest.java |    7 +-
 .../GridCacheAbstractRemoveFailureTest.java     |    1 -
 .../cache/GridCacheAbstractSelfTest.java        |    2 -
 .../cache/GridCacheAbstractTxReadTest.java      |    1 -
 .../cache/GridCacheBasicStoreAbstractTest.java  |    1 -
 .../cache/GridCacheConcurrentMapSelfTest.java   |    1 -
 .../GridCacheConcurrentTxMultiNodeLoadTest.java |    3 -
 .../cache/GridCacheEntryMemorySizeSelfTest.java |    1 -
 .../cache/GridCacheGenericTestStore.java        |    1 -
 .../GridCacheInterceptorLocalSelfTest.java      |    1 -
 .../GridCacheInterceptorReplicatedSelfTest.java |    1 -
 .../cache/GridCacheInterceptorSelfTest.java     |    1 -
 ...ultinodeUpdateAtomicNearEnabledSelfTest.java |    1 -
 ...CacheMultinodeUpdateNearEnabledSelfTest.java |    2 -
 .../cache/GridCacheMultinodeUpdateSelfTest.java |    1 -
 .../cache/GridCachePartitionedGetSelfTest.java  |    1 -
 ...hePartitionedProjectionAffinitySelfTest.java |    3 -
 ...ridCacheQuerySqlFieldInlineSizeSelfTest.java |    2 +-
 .../GridCacheReferenceCleanupSelfTest.java      |    1 -
 ...ridCacheStoreManagerDeserializationTest.java |    1 -
 .../processors/cache/GridCacheTestEntryEx.java  |    8 +-
 .../cache/GridCacheUtilsSelfTest.java           |    2 -
 ...idCacheValueConsistencyAbstractSelfTest.java |    5 +-
 ...heValueConsistencyTransactionalSelfTest.java |    5 +-
 .../GridCacheVersionTopologyChangeTest.java     |    3 +-
 .../IgniteCacheConfigVariationsFullApiTest.java |    3 +-
 .../IgniteCacheEntryProcessorNodeJoinTest.java  |   20 +-
 .../processors/cache/IgniteCacheGroupsTest.java |   10 +-
 ...IgniteClientCacheInitializationFailTest.java |   25 +-
 .../IgniteClusterActivateDeactivateTest.java    |    5 +-
 .../cache/IgniteTxMultiNodeAbstractTest.java    |    9 -
 .../IgniteTxMultiThreadedAbstractTest.java      |    1 -
 .../IgniteTxSingleThreadedAbstractTest.java     |    1 -
 ...rceptorCacheConfigVariationsFullApiTest.java |    2 +-
 .../SetTxTimeoutOnPartitionMapExchangeTest.java |    1 -
 .../cache/WalModeChangeAdvancedSelfTest.java    |   11 +-
 .../cache/WithKeepBinaryCacheFullApiTest.java   |    1 -
 .../binary/BinaryMetadataUpdatesFlowTest.java   |  531 ++-
 .../GridCacheQueueCleanupSelfTest.java          |    1 -
 ...GridCacheQueueMultiNodeAbstractSelfTest.java |    1 -
 .../GridCacheSetAbstractSelfTest.java           |    2 -
 .../IgniteAtomicLongApiAbstractSelfTest.java    |    1 -
 ...titionedAtomicSequenceMultiThreadedTest.java |    1 -
 .../CacheDiscoveryDataConcurrentJoinTest.java   |    1 -
 .../distributed/CacheExchangeMergeTest.java     |    2 +
 ...CacheLoadingConcurrentGridStartSelfTest.java |   61 +-
 .../distributed/CacheParallelStartTest.java     |  202 +
 ...CacheResultIsNotNullOnPartitionLossTest.java |   23 +-
 .../GridCacheAbstractNodeRestartSelfTest.java   |    1 -
 .../distributed/GridCacheLockAbstractTest.java  |    2 -
 .../GridCacheModuloAffinityFunction.java        |    1 -
 ...dCacheMultithreadedFailoverAbstractTest.java |    2 +-
 ...ridCachePartitionNotLoadedEventSelfTest.java |   11 +-
 .../GridCachePreloadLifecycleAbstractTest.java  |    1 -
 .../GridCacheTransformEventSelfTest.java        |    1 -
 .../IgniteCacheNearRestartRollbackSelfTest.java |    1 -
 .../IgniteCachePartitionLossPolicySelfTest.java |  535 ++-
 .../IgniteTxConcurrentRemoveObjectsTest.java    |  165 +
 .../dht/GridCacheAtomicNearCacheSelfTest.java   |    2 -
 .../dht/GridCacheColocatedDebugTest.java        |    3 -
 ...dCacheColocatedTxSingleThreadedSelfTest.java |    1 -
 .../dht/GridCacheDhtEntrySelfTest.java          |    4 +-
 ...GridCacheDhtEvictionNearReadersSelfTest.java |    3 +-
 .../dht/GridCacheDhtPreloadSelfTest.java        |    1 -
 .../dht/IgniteCacheMultiTxLockSelfTest.java     |    1 -
 .../dht/IgniteCacheStartWithLoadTest.java       |   12 +-
 .../near/GridCacheNearMultiGetSelfTest.java     |    1 -
 .../near/GridCacheNearMultiNodeSelfTest.java    |    1 -
 .../near/GridCacheNearOneNodeSelfTest.java      |    1 -
 .../near/GridCacheNearReadersSelfTest.java      |    1 -
 ...AffinityExcludeNeighborsPerformanceTest.java |    1 -
 .../GridCachePartitionedAffinitySelfTest.java   |    2 -
 ...achePartitionedMultiNodeCounterSelfTest.java |    2 +-
 ...achePartitionedMultiNodeFullApiSelfTest.java |    1 -
 ...ePartitionedMultiThreadedPutGetSelfTest.java |    2 -
 ...achePartitionedPreloadLifecycleSelfTest.java |    1 -
 ...CachePartitionedTxMultiThreadedSelfTest.java |    1 -
 ...achePartitionedTxSingleThreadedSelfTest.java |    1 -
 .../near/NoneRebalanceModeSelfTest.java         |    1 -
 .../GridCacheRebalancingSyncSelfTest.java       |   80 +-
 ...idCacheRebalancingWithAsyncClearingTest.java |   49 +-
 ...dCacheReplicatedTxMultiThreadedSelfTest.java |    1 -
 ...CacheReplicatedTxSingleThreadedSelfTest.java |    1 -
 ...CacheReplicatedPreloadLifecycleSelfTest.java |    1 -
 .../GridCacheReplicatedPreloadSelfTest.java     |    1 -
 .../cache/eviction/EvictionAbstractTest.java    |    1 -
 .../EvictionPolicyFactoryAbstractTest.java      |    1 -
 .../GridCacheConcurrentEvictionsSelfTest.java   |   21 +-
 ...acheStoreSessionWriteBehindAbstractTest.java |    1 -
 .../cache/local/GridCacheLocalLockSelfTest.java |    3 -
 .../GridCacheLocalTxMultiThreadedSelfTest.java  |    1 -
 .../GridCacheLocalTxSingleThreadedSelfTest.java |    1 -
 .../cache/mvcc/CacheMvccAbstractTest.java       |    7 +-
 .../mvcc/CacheMvccOperationChecksTest.java      |   10 -
 .../cache/mvcc/CacheMvccProcessorTest.java      |   20 +-
 .../cache/mvcc/CacheMvccTxFailoverTest.java     |  272 ++
 .../cache/mvcc/CacheMvccVacuumTest.java         |    6 +
 .../cache/mvcc/MvccCachePeekTest.java           |  161 +
 ...tePdsBinaryMetadataOnClusterRestartTest.java |    6 +-
 .../IgnitePdsCorruptedIndexTest.java            |   10 -
 .../IgnitePdsCorruptedStoreTest.java            |   11 +-
 .../IgnitePdsPartitionFilesDestroyTest.java     |   10 -
 .../persistence/IgnitePdsTaskCancelingTest.java |    9 -
 ...IgnitePersistentStoreDataStructuresTest.java |   18 +-
 ...lWalModeChangeDuringRebalancingSelfTest.java |    5 -
 .../db/CheckpointBufferDeadlockTest.java        |    9 -
 .../db/IgniteLogicalRecoveryTest.java           |  636 ++++
 .../db/IgnitePdsDataRegionMetricsTest.java      |    3 +-
 .../file/IgnitePdsDiskErrorsRecoveringTest.java |  123 +-
 .../IgniteNodeStoppedDuringDisableWALTest.java  |   14 +-
 .../db/wal/IgniteWalFlushFailoverTest.java      |    9 -
 ...lFlushMultiNodeFailoverAbstractSelfTest.java |   18 +-
 .../db/wal/IgniteWalFormatFileFailoverTest.java |   13 +-
 .../wal/IgniteWalHistoryReservationsTest.java   |   16 +-
 .../wal/IgniteWalIteratorSwitchSegmentTest.java |   65 +-
 .../db/wal/IgniteWalRebalanceTest.java          |    8 -
 .../persistence/db/wal/WalCompactionTest.java   |   13 +-
 .../db/wal/WalRecoveryTxLogicalRecordsTest.java |    6 +-
 .../metastorage/IgniteMetaStorageBasicTest.java |   77 +
 ...gnitePageMemReplaceDelayedWriteUnitTest.java |    3 +-
 .../pagemem/PagesWriteThrottleSmokeTest.java    |    9 -
 .../AbstractNodeJoinTemplate.java               |    4 +-
 .../wal/AbstractWalDeltaConsistencyTest.java    |    2 +
 .../wal/ExplicitWalDeltaConsistencyTest.java    |    2 +
 .../wal/memtracker/PageMemoryTracker.java       |   58 +-
 .../PageMemoryTrackerPluginProvider.java        |   19 +-
 .../StandaloneWalRecordsIteratorTest.java       |  121 +-
 .../cache/query/IndexingSpiQuerySelfTest.java   |    1 -
 .../cache/query/IndexingSpiQueryTxSelfTest.java |    1 -
 ...heContinuousBatchForceServerModeAckTest.java |    1 -
 ...tinuousQueryAsyncFailoverMvccTxSelfTest.java |   53 +
 ...acheContinuousQueryExecuteInPrimaryTest.java |    1 -
 ...ContinuousQueryFailoverAbstractSelfTest.java |   90 +-
 ...usQueryFailoverMvccTxReplicatedSelfTest.java |   31 +
 ...heContinuousQueryFailoverMvccTxSelfTest.java |   48 +
 ...inuousWithTransformerReplicatedSelfTest.java |    4 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |    1 -
 ...dCacheContinuousQueryNodesFilteringTest.java |    1 -
 ...eContinuousQueryReplicatedTxOneNodeTest.java |    1 -
 ...idCacheWriteBehindStoreAbstractSelfTest.java |    1 -
 .../GridCacheWriteBehindStoreAbstractTest.java  |    1 -
 .../GridCacheWriteBehindStoreSelfTest.java      |    3 -
 .../AbstractDeadlockDetectionTest.java          |    1 -
 ...IntegrityWithPrimaryIndexCorruptionTest.java |    3 -
 ...DeadlockDetectionMessageMarshallingTest.java |    1 -
 .../TxOptimisticDeadlockDetectionTest.java      |    1 -
 ...OptimisticPrepareOnUnstableTopologyTest.java |    1 -
 .../TxPessimisticDeadlockDetectionTest.java     |    1 -
 .../cache/transactions/TxRollbackAsyncTest.java |   28 +-
 .../closure/GridClosureProcessorRemoteTest.java |    1 -
 .../closure/GridClosureSerializationTest.java   |    6 +-
 .../database/IgniteDbPutGetAbstractTest.java    |   28 +-
 .../IgniteDbSingleNodeTinyPutGetTest.java       |   42 +-
 .../DataStreamProcessorSelfTest.java            |    3 +-
 .../igfs/IgfsAbstractBaseSelfTest.java          |    3 +-
 .../processors/igfs/IgfsAbstractSelfTest.java   |    6 +-
 ...sCachePerBlockLruEvictionPolicySelfTest.java |    2 +-
 .../processors/igfs/IgfsFileInfoSelfTest.java   |    1 -
 ...IgfsGroupDataBlockKeyMapperHashSelfTest.java |    1 -
 .../igfs/IgfsMetaManagerSelfTest.java           |    1 -
 .../processors/igfs/IgfsModesSelfTest.java      |    1 -
 .../igfs/IgfsProcessorValidationSelfTest.java   |    1 -
 ...gfsSecondaryFileSystemInjectionSelfTest.java |    2 -
 .../OdbcConfigurationValidationSelfTest.java    |    1 -
 .../odbc/OdbcEscapeSequenceSelfTest.java        |    1 -
 .../cache/GridCacheCommandHandlerSelfTest.java  |    1 -
 .../service/ClosureServiceClientsNodesTest.java |    1 -
 .../GridServiceProcessorAbstractSelfTest.java   |    1 -
 ...gniteServiceConfigVariationsFullApiTest.java |    1 -
 ...gniteServiceProxyTimeoutInitializedTest.java |    4 +-
 .../sql/SqlParserCreateIndexSelfTest.java       |    2 +-
 .../internal/sql/SqlParserUserSelfTest.java     |    2 +-
 .../internal/util/IgniteUtilsSelfTest.java      |  275 +-
 .../util/future/GridFutureQueueTest.java        |    1 -
 .../util/future/IgniteFutureImplTest.java       |    1 -
 ...GridUnsafeDataOutputArraySizingSelfTest.java |    2 -
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java |    2 +-
 ...idOffHeapPartitionedMapAbstractSelfTest.java |    1 -
 .../QueueSizeCounterMultiThreadedTest.java      |    2 -
 .../ignite/lang/GridBasicPerformanceTest.java   |    3 -
 .../ignite/lang/GridFuncPerformanceTest.java    |    1 -
 .../GridConcurrentWeakHashSetSelfTest.java      |    1 -
 .../lang/utils/GridConsistentHashSelfTest.java  |    1 -
 .../lang/utils/GridLeanMapPerformanceTest.java  |    2 +-
 .../ignite/lang/utils/GridLeanMapSelfTest.java  |    1 -
 .../loadtests/GridCacheLoadPopulationTask.java  |    1 -
 .../cache/GridCacheAbstractLoadTest.java        |    1 -
 .../loadtests/cache/GridCacheBenchmark.java     |    1 -
 .../GridCacheWriteBehindStoreLoadTest.java      |    1 -
 .../communication/GridIoManagerBenchmark.java   |    2 -
 .../communication/GridIoManagerBenchmark0.java  |    3 -
 .../direct/multisplit/GridLoadTestJob.java      |    1 -
 .../multisplit/GridMultiSplitsLoadTest.java     |    2 -
 .../GridMultiSplitsRedeployLoadTest.java        |    2 -
 ...ridSingleSplitsNewNodesAbstractLoadTest.java |    1 -
 .../direct/session/GridSessionLoadTest.java     |    1 -
 .../direct/stealing/GridStealingLoadTest.java   |    1 -
 .../ignite/loadtests/dsi/GridDsiClient.java     |    3 +-
 .../loadtests/dsi/GridDsiLifecycleBean.java     |    1 -
 .../ignite/loadtests/dsi/GridDsiRequest.java    |    4 +-
 .../ignite/loadtests/dsi/GridDsiResponse.java   |    3 -
 .../ignite/loadtests/dsi/GridDsiSession.java    |    1 -
 .../cacheget/GridBenchmarkCacheGetLoadTest.java |    2 +-
 ...dBoundedConcurrentLinkedHashSetLoadTest.java |    3 +-
 .../loadtests/hashmap/GridCacheTestContext.java |    2 +-
 .../job/GridJobExecutionLoadTestClient.java     |    1 -
 ...GridJobExecutionLoadTestClientSemaphore.java |    1 -
 .../job/GridJobExecutionSingleNodeLoadTest.java |    3 +-
 .../loadtests/nio/GridNioBenchmarkTest.java     |    1 -
 .../ignite/loadtests/util/GridLoadTestArgs.java |    2 -
 .../jdk/GridJdkMarshallerSelfTest.java          |    1 -
 .../ignite/messaging/GridMessagingSelfTest.java |    2 -
 .../ignite/p2p/GridP2PClassLoadingSelfTest.java |    3 +-
 .../GridP2PDifferentClassLoaderSelfTest.java    |    2 +-
 .../p2p/GridP2PHotRedeploymentSelfTest.java     |    2 +-
 .../GridP2PMissedResourceCacheSizeSelfTest.java |    2 +-
 .../platform/PlatformCacheEntryEventFilter.java |    4 +-
 .../PlatformCacheEntryEventFilterFactory.java   |    1 -
 .../platform/PlatformCacheWriteMetricsTask.java |    1 -
 .../PlatformComputeBinarizableArgTask.java      |    1 -
 .../platform/PlatformComputeDecimalTask.java    |    3 +-
 ...latformDefaultJavaObjectFactorySelfTest.java |    1 -
 .../platform/PlatformDeployServiceTask.java     |    2 -
 .../platform/PlatformEventsWriteEventTask.java  |    4 +-
 .../PlatformJavaObjectFactoryProxySelfTest.java |    1 -
 .../SecurityPermissionSetBuilderTest.java       |    2 +-
 ...SessionCancelSiblingsFromFutureSelfTest.java |    1 -
 ...ridSessionCancelSiblingsFromJobSelfTest.java |    2 -
 ...idSessionCancelSiblingsFromTaskSelfTest.java |    3 -
 ...idSessionFutureWaitJobAttributeSelfTest.java |    1 -
 ...dSessionFutureWaitTaskAttributeSelfTest.java |    1 -
 .../session/GridSessionJobFailoverSelfTest.java |    1 -
 ...GridSessionJobWaitTaskAttributeSelfTest.java |    1 -
 .../GridSessionSetFutureAttributeSelfTest.java  |    1 -
 .../GridSessionSetJobAttributeSelfTest.java     |    1 -
 .../GridSessionSetTaskAttributeSelfTest.java    |    1 -
 ...GridSessionTaskWaitJobAttributeSelfTest.java |    1 -
 .../GridSessionWaitAttributeSelfTest.java       |    1 -
 .../spi/GridTcpSpiForwardingSelfTest.java       |    2 -
 .../GridCheckpointSpiAbstractTest.java          |    1 -
 .../GridPriorityQueueCollisionSpiSelfTest.java  |    3 +-
 .../GridAbstractCommunicationSelfTest.java      |    3 -
 .../tcp/GridCacheDhtLockBackupSelfTest.java     |    1 -
 .../tcp/GridTcpCommunicationSpiLanLoadTest.java |    3 -
 ...cpCommunicationSpiMultithreadedSelfTest.java |    2 -
 ...dTcpCommunicationSpiRecoveryAckSelfTest.java |    1 -
 ...GridTcpCommunicationSpiRecoverySelfTest.java |    2 -
 ...CommunicationRecoveryAckClosureSelfTest.java |    1 -
 .../AbstractDiscoveryRandomStartStopTest.java   |    1 -
 .../discovery/AbstractDiscoverySelfTest.java    |    1 -
 .../spi/discovery/AbstractDiscoveryTest.java    |    2 -
 .../tcp/TcpDiscoveryMultiThreadedTest.java      |    1 -
 .../discovery/tcp/TcpDiscoverySpiSelfTest.java  |    1 -
 .../TcpDiscoveryIpFinderAbstractSelfTest.java   |    1 -
 .../TcpDiscoveryMulticastIpFinderSelfTest.java  |    2 +-
 .../GridMemoryEventStorageSpiSelfTest.java      |    1 -
 .../always/GridAlwaysFailoverSpiSelfTest.java   |    1 -
 ...aptiveLoadBalancingSpiStartStopSelfTest.java |    1 -
 ...dRobinLoadBalancingSpiStartStopSelfTest.java |    1 -
 ...RandomLoadBalancingSpiStartStopSelfTest.java |    1 -
 .../startup/GridRandomCommandLineLoader.java    |    1 -
 .../startup/servlet/GridServletLoaderTest.java  |    1 -
 .../testframework/GridSpiTestContext.java       |   12 +-
 .../GridTestExternalClassLoader.java            |    1 -
 .../ignite/testframework/GridTestNode.java      |    1 -
 .../ignite/testframework/GridTestThread.java    |    4 +-
 .../ignite/testframework/GridTestUtils.java     |  203 +-
 .../ConfigVariationsFactory.java                |    1 -
 .../testframework/junits/GridAbstractTest.java  |   90 +-
 .../junits/common/GridCommonAbstractTest.java   |    2 -
 .../junits/spi/GridSpiAbstractTest.java         |    2 +-
 .../testframework/junits/spi/GridSpiTest.java   |    1 -
 .../junits/spi/GridSpiTestConfig.java           |    3 +-
 .../testframework/test/ParametersTest.java      |    1 -
 .../test/VariationsIteratorTest.java            |    3 -
 .../ignite/testsuites/IgniteBasicTestSuite.java |    3 -
 ...IgniteBinaryObjectsComputeGridTestSuite.java |    3 -
 .../IgniteCacheFullApiSelfTestSuite.java        |    3 -
 .../testsuites/IgniteCacheMvccTestSuite.java    |   43 +
 .../ignite/testsuites/IgniteCacheTestSuite.java |    6 +-
 .../testsuites/IgniteCacheTestSuite2.java       |    4 -
 .../testsuites/IgniteCacheTestSuite3.java       |    3 -
 .../testsuites/IgniteCacheTestSuite4.java       |    8 +-
 .../testsuites/IgniteCacheTestSuite5.java       |    4 -
 .../testsuites/IgniteCacheTestSuite6.java       |    9 +-
 .../testsuites/IgniteCacheTestSuite8.java       |    3 -
 .../testsuites/IgniteCacheTestSuite9.java       |    6 +-
 .../ignite/testsuites/IgnitePdsTestSuite4.java  |    3 +
 .../util/AttributeNodeFilterSelfTest.java       |    1 -
 .../ignite/util/GridCommandHandlerTest.java     |   72 +-
 ...dConcurrentLinkedDequeMultiThreadedTest.java |    1 -
 .../ignite/development/utils/WalStat.java       |    4 +-
 .../file/AlignedBuffersDirectFileIOFactory.java |    9 -
 .../tests/p2p/GridExternalAffinityFunction.java |    1 -
 .../ignite/tests/p2p/JobStealingTask.java       |    2 -
 .../uri/tasks/GridUriDeploymentTestTask1.java   |    1 -
 .../uri/tasks/GridUriDeploymentTestTask2.java   |    1 -
 .../apache/ignite/sink/flink/IgniteSink.java    |    1 -
 .../hadoop/fs/v1/IgniteHadoopFileSystem.java    |    7 -
 .../hadoop/fs/v2/IgniteHadoopFileSystem.java    |    2 -
 .../IgniteHadoopClientProtocolProvider.java     |    1 -
 .../planner/HadoopAbstractMapReducePlanner.java |    1 -
 .../processors/hadoop/HadoopSplitWrapper.java   |    1 -
 .../hadoop/delegate/HadoopDelegateUtils.java    |    1 -
 .../hadoop/impl/igfs/HadoopIgfsUtils.java       |    1 -
 .../processors/hadoop/impl/v2/HadoopDaemon.java |    1 -
 .../hadoop/impl/v2/HadoopV2CleanupTask.java     |    1 -
 .../processors/hadoop/impl/v2/HadoopV2Job.java  |    2 +-
 .../hadoop/impl/v2/HadoopV2MapTask.java         |    2 +-
 .../hadoop/impl/v2/HadoopV2ReduceTask.java      |    2 +-
 .../hadoop/impl/v2/HadoopV2SetupTask.java       |    1 -
 .../hadoop/impl/v2/HadoopV2TaskContext.java     |    1 -
 .../hadoop/jobtracker/HadoopJobTracker.java     |    5 +-
 .../hadoop/proto/HadoopProtocolTaskAdapter.java |    1 -
 .../hadoop/shuffle/HadoopShuffleJob.java        |    3 -
 .../shuffle/collections/HadoopSkipList.java     |    1 -
 .../hadoop/taskexecutor/HadoopRunnableTask.java |    1 -
 .../child/HadoopChildProcessRunner.java         |    1 -
 .../HadoopExternalCommunication.java            |    1 -
 .../processors/hadoop/impl/HadoopStartup.java   |    1 -
 ...opClientProtocolMultipleServersSelfTest.java |    4 -
 .../client/HadoopClientProtocolSelfTest.java    |    2 -
 ...KerberosHadoopFileSystemFactorySelfTest.java |    1 -
 .../igfs/HadoopFIleSystemFactorySelfTest.java   |    1 -
 ...oopSecondaryFileSystemConfigurationTest.java |    1 -
 .../IgniteHadoopFileSystemClientSelfTest.java   |    2 -
 ...IgniteHadoopFileSystemHandshakeSelfTest.java |    1 -
 ...teHadoopFileSystemShmemAbstractSelfTest.java |    1 -
 ...emShmemExternalToClientAbstractSelfTest.java |    1 -
 .../util/ChainedUserNameMapperSelfTest.java     |    2 -
 .../cache/query/CacheQueryPartitionInfo.java    |  143 -
 .../cache/query/GridCacheTwoStepQuery.java      |    8 +-
 .../processors/cache/query/QueryTable.java      |    2 +
 .../processors/query/h2/ConnectionManager.java  |  444 +++
 .../query/h2/DmlStatementsProcessor.java        |   23 +-
 .../query/h2/H2ResultSetIterator.java           |    1 -
 .../processors/query/h2/H2TableDescriptor.java  |  139 +-
 .../internal/processors/query/h2/H2Utils.java   |   13 +
 .../processors/query/h2/IgniteH2Indexing.java   |  800 +---
 .../processors/query/h2/UpdateResult.java       |    1 -
 .../query/h2/affinity/PartitionExtractor.java   |  384 ++
 .../query/h2/affinity/PartitionInfo.java        |  143 +
 .../query/h2/database/H2PkHashIndex.java        |    1 -
 .../processors/query/h2/database/H2Tree.java    |   69 +-
 .../query/h2/database/H2TreeIndex.java          |   87 +-
 .../query/h2/ddl/DdlStatementsProcessor.java    |    8 +-
 .../processors/query/h2/dml/DmlBatchSender.java |    2 +-
 .../h2/dml/DmlPageProcessingErrorResult.java    |    1 -
 .../query/h2/dml/DmlPageProcessingResult.java   |    1 -
 .../processors/query/h2/dml/FastUpdate.java     |    2 +-
 .../processors/query/h2/dml/UpdatePlan.java     |    2 +-
 .../query/h2/dml/UpdatePlanBuilder.java         |   31 +-
 .../query/h2/opt/GridH2DefaultTableEngine.java  |    4 +-
 .../query/h2/opt/GridH2PrimaryScanIndex.java    |    1 -
 .../processors/query/h2/opt/GridH2Table.java    |    1 -
 .../query/h2/opt/GridLuceneLockFactory.java     |    1 -
 .../query/h2/sql/GridSqlQueryParser.java        |   65 +-
 .../query/h2/sql/GridSqlQuerySplitter.java      |  327 +-
 .../query/h2/twostep/GridMapQueryExecutor.java  |    3 +-
 .../query/h2/twostep/GridMergeIndex.java        |    1 -
 .../h2/twostep/GridReduceQueryExecutor.java     |   23 +-
 .../query/h2/twostep/MapQueryResults.java       |    1 -
 .../h2/twostep/msg/GridH2IndexRangeRequest.java |    2 +
 .../twostep/msg/GridH2IndexRangeResponse.java   |    2 +
 .../h2/twostep/msg/GridH2QueryRequest.java      |    6 +-
 .../h2/twostep/msg/GridH2ValueMessage.java      |    2 +
 ...ityKeyNameAndValueFieldNameConflictTest.java |  261 ++
 ...CacheAbstractQueryDetailMetricsSelfTest.java |   15 +-
 .../CacheAbstractQueryMetricsSelfTest.java      |   13 -
 .../GridCacheQueryIndexDisabledSelfTest.java    |    1 -
 .../IgniteCacheAbstractFieldsQuerySelfTest.java |    5 +-
 .../cache/IgniteCacheAbstractQuerySelfTest.java |   53 +-
 .../IgniteCacheConfigVariationsQueryTest.java   |    4 -
 ...acheConfigurationPrimitiveTypesSelfTest.java |    1 -
 .../IgniteCacheInsertSqlQuerySelfTest.java      |    1 -
 ...niteCacheLockPartitionOnAffinityRunTest.java |    2 +
 .../cache/IgniteCacheNoClassQuerySelfTest.java  |    2 +-
 .../IgniteCacheQueryH2IndexingLeakTest.java     |   11 +-
 .../IgniteCacheQueryMultiThreadedSelfTest.java  |    1 -
 .../cache/IgniteCrossCachesJoinsQueryTest.java  |    1 -
 ...ndexingCachePartitionLossPolicySelfTest.java |   89 +-
 .../cache/QueryEntityCaseMismatchTest.java      |    1 -
 .../cache/StartCachesInParallelTest.java        |  148 +
 ...butedQueryStopOnCancelOrTimeoutSelfTest.java |    1 -
 ...nCancelOrTimeoutDistributedJoinSelfTest.java |    1 -
 .../IgniteCacheReplicatedQuerySelfTest.java     |   17 +-
 .../index/ComplexPrimaryKeyUnwrapSelfTest.java  |  339 ++
 .../ComplexSecondaryKeyUnwrapSelfTest.java      |  249 ++
 ...ynamicColumnsAbstractConcurrentSelfTest.java |    1 -
 .../cache/index/DynamicColumnsAbstractTest.java |    2 -
 .../DynamicIndexAbstractBasicSelfTest.java      |    2 +-
 .../DynamicIndexAbstractConcurrentSelfTest.java |    1 -
 .../index/DynamicIndexAbstractSelfTest.java     |    2 +-
 .../cache/index/H2ConnectionLeaksSelfTest.java  |    4 +-
 .../H2DynamicColumnsAbstractBasicSelfTest.java  |    5 +-
 .../H2DynamicIndexingComplexAbstractTest.java   |    1 -
 .../cache/index/H2DynamicTableSelfTest.java     |   28 +-
 .../cache/index/IgniteDecimalSelfTest.java      |    7 +-
 .../index/QueryEntityValidationSelfTest.java    |    1 -
 ...sactionsCommandsWithMvccEnabledSelfTest.java |    1 -
 .../cache/index/SqlTransactionsSelfTest.java    |    2 -
 ...eMvccAbstractSqlCoordinatorFailoverTest.java |    1 -
 .../mvcc/CacheMvccBasicContinuousQueryTest.java |  363 ++
 ...cheMvccSelectForUpdateQueryAbstractTest.java |    2 +-
 .../db/wal/IgniteWalRecoveryTest.java           |    1 -
 .../transaction/DmlInsideTransactionTest.java   |  239 ++
 ...onnectorConfigurationValidationSelfTest.java |    4 -
 .../IgnitePersistentStoreSchemaLoadTest.java    |    1 -
 .../query/IgniteCachelessQueriesSelfTest.java   |    2 +-
 .../query/IgniteSqlSchemaIndexingTest.java      |    1 -
 ...IgniteSqlSkipReducerOnUpdateDmlSelfTest.java |    2 +-
 .../processors/query/LazyQuerySelfTest.java     |    1 -
 .../processors/query/RunningQueriesTest.java    |   93 +
 .../query/SqlNestedQuerySelfTest.java           |   75 +
 .../h2/GridIndexingSpiAbstractSelfTest.java     |  639 +---
 ...H2ResultSetIteratorNullifyOnEndSelfTest.java |  186 -
 .../h2/sql/AbstractH2CompareQueryTest.java      |    2 -
 .../query/h2/sql/ExplainSelfTest.java           |  150 +
 .../query/h2/sql/GridQueryParsingTest.java      |    4 +-
 .../query/h2/sql/H2CompareBigQueryTest.java     |    2 -
 .../h2/twostep/RetryCauseMessageSelfTest.java   |    3 +
 ...ePartitionedAtomicColumnConstraintsTest.java |  407 +-
 ...ansactionalSnapshotColumnConstraintTest.java |  120 +
 ...ansactionalSnapshotColumnConstraintTest.java |  120 +
 .../sql/IgniteSQLColumnConstraintsTest.java     |  288 +-
 ...gniteTransactionSQLColumnConstraintTest.java |   71 +
 ...onnectorConfigurationValidationSelfTest.java |    2 +-
 .../FetchingQueryCursorStressTest.java          |    2 -
 .../org/apache/ignite/sqltests/BaseSqlTest.java |    1 -
 .../IgniteBinaryCacheQueryTestSuite.java        |   29 +-
 .../IgniteCacheQuerySelfTestSuite3.java         |   98 +-
 .../IgniteCacheQuerySelfTestSuite4.java         |    6 +
 .../IgniteCacheQuerySelfTestSuite5.java         |   73 +
 .../IgniteCacheQuerySelfTestSuite6.java         |   73 +
 ...acheWithIndexingAndPersistenceTestSuite.java |    2 +
 .../IgniteCacheWithIndexingTestSuite.java       |    3 -
 .../IgnitePdsWithIndexingCoreTestSuite.java     |    3 +
 .../cache/jta/websphere/WebSphereTmFactory.java |    1 -
 .../cache/jta/AbstractCacheJtaSelfTest.java     |    1 -
 modules/kafka/pom.xml                           |    1 +
 .../kafka/connect/IgniteSinkConnectorTest.java  |    2 -
 .../connect/IgniteSourceConnectorTest.java      |    1 -
 .../logger/log4j/GridLog4jConfigUpdateTest.java |    4 -
 .../logger/log4j2/Log4j2ConfigUpdateTest.java   |    3 -
 .../ml/composition/BaggingModelTrainer.java     |  200 -
 .../ignite/ml/dataset/DatasetBuilder.java       |   11 +
 .../ml/dataset/PartitionContextBuilder.java     |   21 +
 .../ignite/ml/dataset/PartitionDataBuilder.java |   11 +-
 .../ignite/ml/dataset/UpstreamTransformer.java  |   42 +
 .../ml/dataset/UpstreamTransformerChain.java    |  154 +
 .../dataset/impl/cache/CacheBasedDataset.java   |   15 +-
 .../impl/cache/CacheBasedDatasetBuilder.java    |   15 +-
 .../dataset/impl/cache/util/ComputeUtils.java   |   95 +-
 .../ml/dataset/impl/local/LocalDataset.java     |    2 +-
 .../dataset/impl/local/LocalDatasetBuilder.java |   96 +-
 .../environment/LearningEnvironmentBuilder.java |    2 +-
 .../binomial/LogisticRegressionSGDTrainer.java  |    9 +-
 .../ignite/ml/trainers/DatasetTrainer.java      |    1 +
 .../ignite/ml/trainers/TrainerTransformers.java |  376 ++
 .../BaggingUpstreamTransformer.java             |   58 +
 .../ml/trainers/transformers/package-info.java  |   22 +
 .../impurity/ImpurityHistogramsComputer.java    |    2 +-
 .../java/org/apache/ignite/ml/util/Utils.java   |   32 +
 .../org/apache/ignite/ml/IgniteMLTestSuite.java |    4 +-
 .../impl/cache/util/ComputeUtilsTest.java       |    3 +
 .../matrix/SparseMatrixConstructorTest.java     |    1 -
 .../primitives/vector/AbstractVectorTest.java   |    1 -
 .../primitives/vector/MatrixVectorViewTest.java |   10 -
 .../apache/ignite/ml/trainers/BaggingTest.java  |  218 ++
 .../cpp/odbc-test/src/meta_queries_test.cpp     |   43 +
 .../cpp/odbc-test/src/sql_get_info_test.cpp     |    2 +-
 .../cpp/odbc/src/config/connection_info.cpp     |    2 +-
 .../thin-client-test/src/cache_client_test.cpp  |   27 +
 .../cpp/thin-client/include/Makefile.am         |    3 +-
 .../Apache.Ignite.Core.Tests.DotNetCore.csproj  |    1 +
 .../Apache.Ignite.Core.Tests.csproj             |    1 +
 .../ApiParity/IgniteConfigurationParityTest.cs  |    3 +-
 .../ApiParity/TcpCommunicationSpiParityTest.cs  |   84 +
 .../Cache/Query/CacheQueriesTest.cs             |    4 +
 .../Query/Linq/CacheLinqTest.Introspection.cs   |    4 +
 .../Cache/Query/Linq/CacheLinqTest.Misc.cs      |    3 +-
 .../IgniteConfigurationTest.cs                  |   16 +-
 .../Cache/Query/SqlFieldsQuery.cs               |    3 +
 .../Apache.Ignite.Core/Cache/Query/SqlQuery.cs  |    5 +
 .../Communication/Tcp/TcpCommunicationSpi.cs    |   99 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |    2 +
 .../Impl/Client/Cache/CacheClient.cs            |    4 +
 .../Impl/CacheFieldsQueryExecutor.cs            |    2 +
 .../dotnet/Apache.Ignite.Linq/QueryOptions.cs   |    1 +
 .../http/jetty/GridJettyRestHandler.java        |    1 -
 .../http/jetty/GridJettyRestProtocol.java       |    2 -
 .../stream/rocketmq/RocketMQStreamerTest.java   |    1 -
 .../ignite/internal/GridFactorySelfTest.java    |    2 -
 .../resource/GridResourceProcessorSelfTest.java |    8 +-
 .../GridSpringResourceInjectionSelfTest.java    |    2 -
 .../p2p/GridP2PUserVersionChangeSelfTest.java   |    2 +-
 .../util/nodestart/StartNodeCallableImpl.java   |  107 +-
 ...gniteProjectionStartStopRestartSelfTest.java |  198 +-
 .../storm/StormIgniteStreamerSelfTest.java      |    1 -
 .../tfrunning/TensorFlowServerManager.java      |    2 +-
 .../TensorFlowServerScriptFormatter.java        |    2 +-
 .../cluster/util/TensorFlowClusterResolver.java |   12 +-
 .../util/TensorFlowProcessBuilderSupplier.java  |   14 +-
 .../uri/GridUriDeploymentDiscovery.java         |    1 -
 .../uri/GridUriDeploymentFileProcessor.java     |    1 -
 .../spi/deployment/uri/UriDeploymentSpi.java    |    2 -
 .../scanners/http/UriDeploymentHttpScanner.java |    4 +-
 .../ignite/p2p/GridP2PDisabledSelfTest.java     |    3 +-
 .../apache/ignite/tools/GridToolsSelfTest.java  |    2 -
 .../commands/cache/VisorCacheCommand.scala      |   76 +-
 .../VisorCacheToggleStatisticsCommand.scala     |  152 +
 .../web-console/backend/app/browsersHandler.js  |    5 +
 .../e2e/testcafe/components/FormField.js        |   11 +-
 modules/web-console/frontend/app/app.js         |    4 +-
 .../activities-user-dialog.controller.js        |    6 +-
 .../activities-user-dialog.tpl.pug              |    2 +-
 .../components/form-field-size/controller.js    |   25 +-
 .../components/form-field-size/index.js         |    3 +-
 .../components/form-field-size/style.scss       |   15 +
 .../components/form-field-size/template.pug     |    2 +
 .../form-field/showValidationError.directive.js |   21 +-
 .../app/components/ignite-chart/controller.js   |   48 +-
 .../frontend/app/components/page-admin/index.js |   16 +-
 .../page-configure/components/pcValidation.js   |   18 +-
 .../app/components/page-configure/index.js      |   11 +-
 .../app/components/page-profile/controller.js   |   12 +-
 .../app/components/page-profile/template.pug    |    5 +-
 .../components/queries-notebook/controller.js   |  148 +-
 .../queries-notebook/template.tpl.pug           |    4 +-
 .../app/components/page-queries/index.js        |   17 +-
 .../components/page-queries/notebook.data.js    |    3 -
 .../app/components/page-signin/controller.ts    |    3 +
 .../components/timed-redirection/component.ts   |   29 +
 .../components/timed-redirection/controller.ts  |   60 +
 .../app/components/timed-redirection/index.ts   |   23 +
 .../app/components/timed-redirection/style.scss |   47 +
 .../components/timed-redirection/template.pug   |   22 +
 modules/web-console/frontend/app/data/i18n.js   |   25 +-
 .../app/modules/agent/AgentManager.service.js   |   63 +-
 .../agent/components/cluster-login/service.js   |    5 +
 .../app/modules/cluster/CacheMetrics.js         |    3 +
 .../frontend/app/modules/states/errors.state.js |   18 +-
 .../frontend/app/modules/user/user.module.js    |    8 -
 .../app/primitives/datepicker/index.pug         |    6 +-
 .../app/primitives/form-field/dropdown.pug      |    6 +-
 .../app/primitives/form-field/email.pug         |    6 +-
 .../app/primitives/form-field/number.pug        |    6 +-
 .../app/primitives/form-field/password.pug      |    8 +-
 .../app/primitives/form-field/phone.pug         |    5 +-
 .../frontend/app/primitives/form-field/text.pug |    6 +-
 .../app/primitives/form-field/typeahead.pug     |    6 +-
 .../frontend/app/primitives/modal/index.scss    |   26 +-
 .../app/primitives/timepicker/index.pug         |    6 +-
 modules/web-console/frontend/package.json       |    2 +-
 .../frontend/public/stylesheets/style.scss      |   58 -
 modules/web-console/frontend/views/403.tpl.pug  |   24 -
 modules/web-console/frontend/views/404.tpl.pug  |   24 -
 .../frontend/views/includes/header-left.pug     |    2 +-
 modules/web-console/frontend/views/index.pug    |    4 -
 .../web-agent/bin/ignite-web-agent.sh           |   38 +-
 .../service/DemoRandomCacheLoadService.java     |   22 +-
 .../cache/websession/WebSessionFilter.java      |    4 -
 .../ignite/startup/servlet/ServletStartup.java  |    1 -
 .../IgniteWebSessionSelfTestSuite.java          |    1 -
 .../config/benchmark-select.properties          |  159 +
 .../yardstick/IgniteAbstractBenchmark.java      |   43 +-
 .../yardstick/IgniteBenchmarkArguments.java     |   16 +-
 .../org/apache/ignite/yardstick/IgniteNode.java |    6 +-
 .../jdbc/JdbcSqlQueryRangeBenchmark.java        |   29 +-
 .../apache/ignite/yardstick/jdbc/JdbcUtils.java |   25 +-
 .../jdbc/NativeSqlQueryRangeBenchmark.java      |   24 +-
 .../ignite/yardstick/jdbc/SelectCommand.java    |   85 +
 .../ignite/yardstick/upload/model/Values10.java |    1 -
 .../zk/internal/ZookeeperDiscoveryImpl.java     |    5 -
 .../zk/ZookeeperDiscoverySpiTestSuite2.java     |   46 +-
 .../zk/ZookeeperDiscoverySpiTestSuite3.java     |   62 +
 .../zk/ZookeeperDiscoverySpiTestSuite4.java     |   57 +
 parent/pom.xml                                  |    3 +-
 1303 files changed, 25825 insertions(+), 16475 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/45a4a6f5/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/GridCacheOffheapManager.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/45a4a6f5/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/persistence/IgniteCacheDatabaseSharedManager.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/45a4a6f5/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalRecoveryTxLogicalRecordsTest.java
----------------------------------------------------------------------
diff --cc modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalRecoveryTxLogicalRecordsTest.java
index a4ab456,d2ea4f1..44dcb8c
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalRecoveryTxLogicalRecordsTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/persistence/db/wal/WalRecoveryTxLogicalRecordsTest.java
@@@ -49,14 -49,13 +49,14 @@@ import org.apache.ignite.internal.proce
  import org.apache.ignite.internal.processors.cache.GridCacheContext;
  import org.apache.ignite.internal.processors.cache.IgniteCacheOffheapManager;
  import org.apache.ignite.internal.processors.cache.IgniteRebalanceIterator;
- import org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtLocalPartition;
  import org.apache.ignite.internal.processors.cache.distributed.dht.preloader.IgniteDhtDemandedPartitionsMap;
+ import org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtLocalPartition;
  import org.apache.ignite.internal.processors.cache.persistence.CacheDataRow;
 +import org.apache.ignite.internal.processors.cache.persistence.CacheFreeList;
  import org.apache.ignite.internal.processors.cache.persistence.GridCacheDatabaseSharedManager;
 +import org.apache.ignite.internal.processors.cache.persistence.LazyCacheFreeList;
  import org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager;
  import org.apache.ignite.internal.processors.cache.persistence.freelist.AbstractFreeList;
 -import org.apache.ignite.internal.processors.cache.persistence.freelist.CacheFreeListImpl;
  import org.apache.ignite.internal.processors.cache.persistence.freelist.PagesList;
  import org.apache.ignite.internal.processors.cache.persistence.tree.reuse.ReuseListImpl;
  import org.apache.ignite.internal.util.typedef.F;

http://git-wip-us.apache.org/repos/asf/ignite/blob/45a4a6f5/modules/core/src/test/java/org/apache/ignite/testsuites/IgnitePdsTestSuite4.java
----------------------------------------------------------------------
diff --cc modules/core/src/test/java/org/apache/ignite/testsuites/IgnitePdsTestSuite4.java
index cfb17cd,027f341..148517e
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgnitePdsTestSuite4.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgnitePdsTestSuite4.java
@@@ -18,8 -18,8 +18,9 @@@
  package org.apache.ignite.testsuites;
  
  import junit.framework.TestSuite;
+ import org.apache.ignite.cache.ResetLostPartitionTest;
  import org.apache.ignite.internal.processors.cache.IgniteClusterActivateDeactivateTestWithPersistenceAndMemoryReuse;
 +import org.apache.ignite.internal.processors.cache.persistence.FreeListLazyInitializationTest;
  import org.apache.ignite.internal.processors.cache.persistence.IgnitePdsContinuousRestartTestWithSharedGroupAndIndexes;
  import org.apache.ignite.internal.processors.cache.persistence.IgnitePdsRecoveryAfterFileCorruptionTest;
  import org.apache.ignite.internal.processors.cache.persistence.IgnitePdsTaskCancelingTest;
@@@ -46,10 -46,10 +47,12 @@@ public class IgnitePdsTestSuite4 extend
  
          suite.addTestSuite(IgniteClusterActivateDeactivateTestWithPersistenceAndMemoryReuse.class);
  
 +        suite.addTestSuite(FreeListLazyInitializationTest.class);
 +
          suite.addTestSuite(IgnitePdsPartitionPreloadTest.class);
  
+         suite.addTestSuite(ResetLostPartitionTest.class);
+ 
          return suite;
      }