You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by av...@apache.org on 2020/06/16 10:17:44 UTC

[ignite] 01/01: Merge remote-tracking branch 'remotes/origin/master' into ignite-ducktape

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

av pushed a commit to branch ignite-ducktape
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit b173b50d38851bdc053c39eaba942cb39ea69756
Merge: 4bfa3aa 974fb5a
Author: Anton Vinogradov <av...@apache.org>
AuthorDate: Tue Jun 16 13:15:08 2020 +0300

    Merge remote-tracking branch 'remotes/origin/master' into ignite-ducktape

 .github/PULL_REQUEST_TEMPLATE.md                   |   4 +-
 README.md                                          |   6 +-
 assembly/libs/README.txt                           |   1 -
 modules/aws/pom.xml                                |  12 +
 .../rest/AbstractRestProcessorSelfTest.java        |   8 +
 .../rest/JettyRestProcessorAbstractSelfTest.java   | 169 ++++--
 .../jdbc/thin/JdbcThinConnectionSelfTest.java      |  68 ++-
 .../ignite/jdbc/thin/JdbcThinMetadataSelfTest.java | 105 ++++
 .../thin/JdbcThinPreparedStatementSelfTest.java    | 310 +++++++++--
 .../jdbc/thin/JdbcThinResultSetSelfTest.java       |  49 +-
 .../thin/JdbcThinStreamingAbstractSelfTest.java    |  68 +++
 .../apache/ignite/jdbc/thin/JdbcThinTcpIoTest.java |   4 +-
 .../java/org/apache/ignite/IgniteSnapshot.java     |   9 +
 .../org/apache/ignite/IgniteSystemProperties.java  |   8 +
 .../java/org/apache/ignite/cache/CacheMetrics.java |  12 +
 .../configuration/DataStorageConfiguration.java    |   5 +-
 .../org/apache/ignite/internal/IgniteFeatures.java |  10 +-
 .../org/apache/ignite/internal/IgniteKernal.java   |  69 +--
 .../ignite/internal/MarshallerContextImpl.java     |  27 +-
 .../ignite/internal/SecurityAwareBiPredicate.java  |   8 +-
 .../ignite/internal/TransactionsMXBeanImpl.java    |  10 +
 .../internal/binary/BinaryClassDescriptor.java     |   2 +-
 .../ignite/internal/binary/BinaryContext.java      |  14 +-
 .../ignite/internal/binary/BinaryMarshaller.java   |   2 +-
 .../ignite/internal/binary/BinaryReaderExImpl.java |   6 -
 .../ignite/internal/binary/BinaryWriterExImpl.java |   2 +-
 .../internal/binary/GridBinaryMarshaller.java      |   3 -
 .../client/thin/ClientBinaryMarshaller.java        |   2 +-
 .../client/thin/ClientClusterGroupImpl.java        |  14 +-
 .../internal/client/thin/ClientClusterImpl.java    |  12 +
 .../internal/client/thin/ClientComputeImpl.java    |  46 +-
 .../internal/client/thin/TcpIgniteClient.java      |   2 +-
 .../internal/cluster/ClusterGroupAdapter.java      | 220 +++++---
 .../internal/commandline/query/KillCommand.java    |  22 +-
 .../internal/commandline/query/KillSubcommand.java |   5 +
 .../commandline/snapshot/SnapshotCommand.java      |  25 +-
 .../commandline/snapshot/SnapshotSubcommand.java   |   5 +-
 .../internal/jdbc/thin/ConnectionProperties.java   |  16 +
 .../jdbc/thin/ConnectionPropertiesImpl.java        |  17 +-
 .../internal/jdbc/thin/JdbcThinConnection.java     | 620 +++++++++++++++++----
 .../jdbc/thin/JdbcThinPreparedStatement.java       |  17 +-
 .../internal/jdbc/thin/JdbcThinResultSet.java      |   2 +-
 .../internal/jdbc/thin/JdbcThinStatement.java      |   2 +-
 .../ignite/internal/jdbc/thin/JdbcThinTcpIo.java   |  36 +-
 .../ignite/internal/jdbc2/JdbcResultSet.java       |   2 +-
 .../deployment/GridDeploymentCommunication.java    |   9 +-
 .../marshaller/optimized/OptimizedMarshaller.java  |  23 +-
 .../OptimizedObjectPooledStreamRegistry.java       |  89 +++
 .../OptimizedObjectSharedStreamRegistry.java       | 121 ++++
 .../optimized/OptimizedObjectStreamRegistry.java   | 170 +-----
 .../pagemem/wal/record/MasterKeyChangeRecord.java  |   2 +-
 .../cache/CacheAffinitySharedManager.java          |   3 +
 .../cache/CacheClusterMetricsMXBeanImpl.java       |   5 +
 .../processors/cache/CacheGroupMetricsImpl.java    |  10 +-
 .../cache/CacheLocalMetricsMXBeanImpl.java         |   5 +
 .../processors/cache/CacheMetricsImpl.java         |  61 ++
 .../processors/cache/CacheMetricsSnapshot.java     |   5 +
 .../processors/cache/CacheMetricsSnapshotV2.java   |  12 +
 .../processors/cache/ClusterCachesInfo.java        |  75 ++-
 .../cache/GatewayProtectedCacheProxy.java          |   8 +-
 .../processors/cache/GridCacheAdapter.java         |   6 +
 .../processors/cache/GridCacheProcessor.java       | 113 +++-
 .../processors/cache/IgniteCacheProxyImpl.java     |  53 +-
 .../cache/LongOperationsDumpSettingsClosure.java   |   8 +-
 .../binary/CacheObjectBinaryProcessorImpl.java     |  29 +-
 .../distributed/GridDistributedCacheEntry.java     |   4 +
 .../dht/GridDhtTopologyFutureAdapter.java          |   8 +-
 .../preloader/GridDhtPartitionsExchangeFuture.java |  44 +-
 .../GridCacheDatabaseSharedManager.java            |  83 ++-
 .../cache/persistence/GridCacheOffheapManager.java |  15 +-
 .../IgniteCacheDatabaseSharedManager.java          |   8 +-
 .../persistence/checkpoint/CheckpointEntry.java    |  15 +-
 .../persistence/checkpoint/CheckpointHistory.java  | 294 +++++++---
 .../persistence/file/FilePageStoreManager.java     |   4 +-
 .../cache/persistence/pagemem/PageMemoryImpl.java  |  12 +-
 .../snapshot/IgniteSnapshotManager.java            | 144 ++++-
 .../persistence/snapshot/SnapshotFutureTask.java   |   8 +-
 .../persistence/snapshot/SnapshotMXBeanImpl.java   |   5 +
 .../persistence/wal/FileWriteAheadLogManager.java  |   4 +-
 .../wal/aware/SegmentCompressStorage.java          |   2 -
 .../continuous/CacheContinuousQueryHandler.java    |  14 +
 .../continuous/CacheContinuousQueryListener.java   |  12 +-
 .../continuous/CacheContinuousQueryManager.java    |  28 +-
 .../CacheContinuousQueryPartitionRecovery.java     |  16 +-
 .../query/continuous/SecurityAwareFilter.java      |  22 +-
 .../SecurityAwareTransformerFactory.java           |  22 +-
 .../cache/transactions/IgniteTxManager.java        | 291 ++++++++--
 .../TxCollisionsDumpSettingsClosure.java}          |  33 +-
 .../cache/transactions/TxDeadlockDetection.java    |   8 +-
 .../cluster/GridClusterStateProcessor.java         |   4 +-
 .../GridCacheAtomicSequenceImpl.java               |   9 +
 .../datastructures/GridCacheLockImpl.java          |   3 +
 .../processors/odbc/ClientListenerNioListener.java |   2 +-
 .../internal/processors/odbc/SqlListenerUtils.java |  28 +-
 .../odbc/jdbc/JdbcBinaryTypeGetRequest.java        |  76 +++
 .../odbc/jdbc/JdbcBinaryTypeGetResult.java         | 107 ++++
 .../odbc/jdbc/JdbcBinaryTypeNameGetRequest.java    |  93 ++++
 .../odbc/jdbc/JdbcBinaryTypeNameGetResult.java     |  92 +++
 .../odbc/jdbc/JdbcBinaryTypeNamePutRequest.java    | 109 ++++
 .../odbc/jdbc/JdbcBinaryTypePutRequest.java        |  88 +++
 .../odbc/jdbc/JdbcConnectionContext.java           |   2 +-
 .../processors/odbc/jdbc/JdbcMessageParser.java    |  12 +-
 .../processors/odbc/jdbc/JdbcProtocolContext.java  |  28 +-
 .../internal/processors/odbc/jdbc/JdbcQuery.java   |   5 +-
 .../odbc/jdbc/JdbcQueryExecuteRequest.java         |   4 +-
 .../internal/processors/odbc/jdbc/JdbcRequest.java |  32 ++
 .../processors/odbc/jdbc/JdbcRequestHandler.java   | 118 ++++
 .../internal/processors/odbc/jdbc/JdbcResult.java  |  24 +
 .../processors/odbc/jdbc/JdbcThinFeature.java      |   8 +-
 .../odbc/jdbc/JdbcUpdateBinarySchemaResult.java    |  89 +++
 .../internal/processors/odbc/jdbc/JdbcUtils.java   |  24 +-
 .../internal/processors/platform/PlatformLock.java | 108 ++++
 .../processors/platform/PlatformProcessorImpl.java |  15 +
 .../processors/platform/cache/PlatformCache.java   |   3 +
 .../cache/query/PlatformContinuousQueryImpl.java   |  95 +++-
 .../cache/query/PlatformFieldsQueryCursor.java     |  16 +-
 .../platform/client/compute/ClientComputeTask.java |   4 +-
 .../platform/services/PlatformServices.java        |  23 +-
 .../processors/platform/utils/PlatformUtils.java   |   2 +-
 .../internal/processors/query/QueryUtils.java      |  26 +-
 .../internal/processors/rest/GridRestCommand.java  |   4 +-
 .../processors/rest/GridRestProcessor.java         |  15 +-
 .../AbstractSecurityAwareExternalizable.java       |  17 +
 .../processors/security/SecurityUtils.java         |  11 +-
 .../apache/ignite/internal/util/IgniteUtils.java   |  30 +
 .../apache/ignite/internal/util/lang/GridFunc.java |  14 +
 .../visor/snapshot/VisorSnapshotCancelTask.java    |  62 +++
 .../apache/ignite/mxbean/CacheMetricsMXBean.java   |  17 +-
 .../org/apache/ignite/mxbean/SnapshotMXBean.java   |  10 +-
 .../apache/ignite/mxbean/TransactionsMXBean.java   |  20 +
 .../spi/communication/tcp/TcpCommunicationSpi.java |   4 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java       |   7 -
 .../main/resources/META-INF/classnames.properties  |   7 +
 .../org/apache/ignite/client/IgniteBinaryTest.java |  27 +
 .../ignite/internal/ClusterGroupSelfTest.java      | 118 ++--
 .../internal/client/thin/ClusterGroupTest.java     |   8 +-
 .../internal/client/thin/ComputeTaskTest.java      |  46 +-
 .../encryption/AbstractEncryptionTest.java         |   5 +-
 .../internal/encryption/MasterKeyChangeTest.java   |  43 ++
 .../GridDeploymentMessageCountSelfTest.java        |   2 +-
 .../optimized/OptimizedMarshallerTest.java         |   4 +-
 .../optimized/OptimizedObjectStreamSelfTest.java   |  21 +-
 ...ateDestroyClusterReadOnlyModeAbstractTest.java} |  31 +-
 .../CacheCreateDestroyClusterReadOnlyModeTest.java | 186 +++++++
 .../processors/cache/CacheGroupMetricsTest.java    |  68 ++-
 .../processors/cache/CacheMetricsManageTest.java   | 342 +++++++++++-
 .../cache/ClusterReadOnlyModeTestUtils.java        |  87 +--
 .../DataStorageConfigurationValidationTest.java    |  17 +
 ...IgniteCacheClusterReadOnlyModeAbstractTest.java | 263 +++++++++
 .../IgniteCacheClusterReadOnlyModeSelfTest.java    | 531 ++++++++++++++++++
 ...niteCacheInvokeClusterReadOnlyModeSelfTest.java | 141 +++++
 ...gniteCacheStoreClusterReadOnlyModeSelfTest.java | 302 ++++++++++
 ...usterActivateDeactivateTestWithPersistence.java |   8 +-
 ...gniteNearCacheClusterReadOnlyModeSelfTest.java} |  28 +-
 ...earCacheInvokeClusterReadOnlyModeSelfTest.java} |  32 +-
 .../IgniteAtomicLongClusterReadOnlyTest.java       | 150 +++++
 .../IgniteAtomicReferenceClusterReadOnlyTest.java  | 114 ++++
 .../IgniteAtomicSequenceClusterReadOnlyTest.java   | 126 +++++
 .../IgniteAtomicStampedClusterReadOnlyTest.java    | 132 +++++
 ...niteCollectionsClusterReadOnlyAbstractTest.java | 227 ++++++++
 .../IgniteCountDownLatchClusterReadOnlyTest.java   | 129 +++++
 ...tructuresCreateDeniedInClusterReadOnlyMode.java | 156 ++++++
 .../IgniteDataStructuresTestUtils.java             | 129 +++++
 .../datastructures/IgniteLockAbstractSelfTest.java |  19 +
 .../IgniteQueueClusterReadOnlyTest.java            |  91 +++
 .../IgniteSetClusterReadOnlyTest.java              |  62 +++
 ....java => IgniteCacheMultiClientsStartTest.java} |   4 +-
 .../mvcc/CacheMvccConfigurationValidationTest.java |  30 +
 .../persistence/CheckpointReadLockFailureTest.java |   2 -
 .../IgnitePdsBinaryMetadataAsyncWritingTest.java   |  18 +-
 .../IgnitePdsCacheEntriesExpirationTest.java       | 323 +++++++++++
 .../IgnitePdsCacheRebalancingAbstractTest.java     |   8 +-
 .../persistence/IgnitePdsCorruptedIndexTest.java   |   2 +-
 .../PersistenceDirectoryWarningLoggingTest.java    |  25 +
 .../persistence/WalPreloadingConcurrentTest.java   |  10 +-
 .../db/IgniteSequentialNodeCrashRecoveryTest.java  | 130 ++++-
 .../db/wal/HistoricalReservationTest.java          | 227 ++++++++
 .../db/wal/IgniteWalHistoryReservationsTest.java   | 144 +++--
 .../db/wal/IgniteWalRecoveryPPCTest.java           |   8 +-
 .../db/wal/IgniteWalReplayingAfterRestartTest.java |  26 +-
 .../persistence/db/wal/WalOnNodeStartTest.java     |   1 +
 .../snapshot/AbstractSnapshotSelfTest.java         |  84 ++-
 .../snapshot/IgniteClusterSnapshotSelfTest.java    |  32 +-
 .../snapshot/IgniteSnapshotMXBeanTest.java         |  17 +
 .../snapshot/IgniteSnapshotManagerSelfTest.java    |   6 +-
 .../TxDeadlockDetectionNoHangsTest.java            |  12 +-
 .../transactions/TxWithKeyContentionSelfTest.java  | 338 +++++++++++
 .../TxWithSmallTimeoutAndContentionOneKeyTest.java |   9 +
 .../cluster/ClusterReadOnlyModeSelfTest.java       |  57 +-
 .../processors/rest/RestProcessorHangTest.java     | 148 +++++
 .../AbstractContinuousQuerySandboxTest.java        | 132 +++++
 .../sandbox/ContinuousQuerySandboxTest.java        |  64 +++
 .../ContinuousQueryWithTransformerSandboxTest.java |  73 +++
 .../GridServiceClusterReadOnlyModeTest.java        | 114 ++++
 .../GridServiceDeployClusterReadOnlyModeTest.java  | 393 +++++++++++++
 .../redeploy/GridSingleSplitsRedeployLoadTest.java |   2 +-
 .../apache/ignite/p2p/SharedDeploymentTest.java    |  54 ++
 .../platform/PlatformCacheWriteMetricsTask.java    |   5 +
 .../PlatformComputeActiveTaskFuturesTask.java      |  70 +++
 .../ignite/platform/PlatformDeployServiceTask.java |  18 +-
 .../apache/ignite/testframework/GridTestUtils.java |  45 +-
 .../ignite/testframework/junits/IgniteMock.java    |   2 +-
 .../junits/common/GridCommonAbstractTest.java      |   2 +
 .../IgniteCacheDataStructuresSelfTestSuite.java    |  17 +
 .../IgniteCacheFullApiSelfTestSuite.java           |  11 +
 .../testsuites/IgniteCacheMvccTestSuite5.java      |   2 +
 .../testsuites/IgniteCacheMvccTestSuite6.java      |   4 +-
 .../ignite/testsuites/IgniteCacheTestSuite5.java   |   2 +
 .../ignite/testsuites/IgniteCacheTestSuite6.java   |   4 +-
 .../ignite/testsuites/IgniteCacheTestSuite7.java   |   3 +
 .../ignite/testsuites/IgnitePdsMvccTestSuite4.java |   2 +
 .../ignite/testsuites/IgnitePdsTestSuite4.java     |   7 +-
 .../ignite/testsuites/IgniteReproducingSuite.java  |   6 +-
 .../testsuites/IgniteRestHandlerTestSuite.java     |   4 +-
 .../testsuites/IgniteServiceGridTestSuite.java     |   4 +
 .../ignite/testsuites/IgniteUtilSelfTestSuite.java |   2 +
 .../ignite/testsuites/SecurityTestSuite.java       |   4 +
 .../ignite/thread/ThreadPoolMetricsTest.java       | 131 +++++
 .../apache/ignite/util/GridCommandHandlerTest.java |  22 +-
 ...ridCommandHandlerClusterByClassTest_help.output |  12 +
 ...andHandlerClusterByClassWithSSLTest_help.output |  12 +
 modules/core/src/test/resources/tde.jks            | Bin 813 -> 1033 bytes
 modules/extdata/p2p/META-INF/ignite.xml            |   2 +-
 .../p2p/{ => classic}/SingleSplitTestTask.java     |   3 +-
 .../ignite/tests/p2p/compute/ExternalLambda.java}  |  28 +-
 .../ignite/tests/p2p/compute/ExternalLambda.java}  |  28 +-
 .../processors/query/h2/IgniteH2Indexing.java      |   9 +-
 .../processors/query/h2/opt/GridH2Table.java       |  33 +-
 .../processors/query/h2/opt/TableStatistics.java   |   2 +-
 .../query/h2/sql/GridSqlQueryParser.java           |  21 +-
 .../query/h2/twostep/AbstractReducer.java          |  14 +-
 .../GridCacheSqlDdlClusterReadOnlyModeTest.java    | 172 ++++++
 .../cache/index/H2DynamicTableSelfTest.java        |   3 +-
 .../persistence/db/wal/IgniteWalRecoveryTest.java  |   4 +-
 .../IgniteClusterSnapshotWithIndexesTest.java      |  15 +-
 .../query/IgniteSqlSplitterSelfTest.java           |   4 +-
 .../processors/query/SqlSystemViewsSelfTest.java   |  20 +-
 .../query/h2/GridIndexRebuildSelfTest.java         |  66 ++-
 .../h2/twostep/RetryCauseMessageSelfTest.java      |  28 +-
 .../IgniteCacheWithIndexingTestSuite.java          |   2 +
 .../ignite/util/KillCommandsCommandShTest.java     |  26 +-
 .../apache/ignite/util/KillCommandsMXBeanTest.java |  51 +-
 .../apache/ignite/util/KillCommandsSQLTest.java    |   5 +-
 .../org/apache/ignite/util/KillCommandsTests.java  |   6 +-
 .../ml/math/distances/ChebyshevDistance.java}      |  26 +-
 .../ml/math/distances/CosineSimilarity.java}       |  26 +-
 .../ignite/ml/math/distances/DistanceMeasure.java  |  22 +-
 .../ml/math/distances/EuclideanDistance.java       |  16 +-
 .../ignite/ml/math/distances/HammingDistance.java  |  18 -
 .../ignite/ml/math/distances/JaccardIndex.java}    |  38 +-
 .../ml/math/distances/ManhattanDistance.java       |  18 -
 ...clideanDistance.java => MinkowskiDistance.java} |  54 +-
 .../ignite/ml/math/MathImplLocalTestSuite.java     |   4 +
 .../ml/math/distances/CosineSimilarityTest.java}   |  34 +-
 .../ignite/ml/math/distances/DistanceTest.java     | 108 +++-
 .../ignite/ml/math/distances/JaccardIndexTest.java |  43 ++
 .../ExpiryCacheHolderTest.cs                       |   7 +-
 .../Apache.Ignite.Core.Tests.DotNetCore.csproj     |  34 ++
 .../Apache.Ignite.Core.Tests.csproj                |   2 +
 .../Cache/CacheTestAsyncWrapper.cs                 |   8 +-
 .../Cache/Platform/PlatformCacheTest.cs            | 276 ++++-----
 .../Continuous/ContinuousQueryAbstractTest.cs      | 142 ++++-
 .../Continuous/ContinuousQueryAtomicBackupTest.cs  |   7 +-
 .../ContinuousQueryAtomicNoBackupTest.cs           |   7 +-
 .../ContinuousQueryNoBackupAbstractTest.cs         |   3 +-
 .../ContinuousQueryTransactionalBackupTest.cs      |   3 +
 .../ContinuousQueryTransactionalNoBackupTest.cs    |   3 +
 .../Client/ClientConnectionTest.cs                 |  48 +-
 .../Client/Compute/ComputeClientTests.cs           | 132 +++--
 .../IgniteLockFailoverTests.cs                     | 105 ++++
 .../Apache.Ignite.Core.Tests/IgniteLockTests.cs    | 329 +++++++++++
 .../Process/ListDataReader.cs                      |   5 +
 .../Services/ServicesTest.cs                       | 173 +++++-
 .../dotnet/Apache.Ignite.Core.Tests/TestBase.cs    |  31 +-
 .../Apache.Ignite.Core/Apache.Ignite.Core.csproj   |   5 +
 .../dotnet/Apache.Ignite.Core/Cache/ICache.cs      |  42 +-
 .../Query/Continuous/IContinuousQueryHandle.cs     |   2 +-
 ...ryHandle.cs => IContinuousQueryHandleFields.cs} |  22 +-
 .../Apache.Ignite.Core/Cache/Query/QueryBase.cs    |  17 +-
 .../Cache/Query/SqlFieldsQuery.cs                  |  43 +-
 .../Apache.Ignite.Core/Client/ClientStatusCode.cs  |  12 +-
 .../Configuration/LockConfiguration.cs             |  68 +++
 .../platforms/dotnet/Apache.Ignite.Core/IIgnite.cs |  33 +-
 .../dotnet/Apache.Ignite.Core/IIgniteLock.cs       |  81 +++
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs     | 136 ++---
 .../Query/Continuous/ContinuousQueryHandleImpl.cs  |  53 +-
 .../Impl/Cache/Query/FieldsQueryCursor.cs          |  20 +-
 .../Impl/Cache/Query/IQueryBaseInternal.cs}        |  23 +-
 .../Impl/Client/Cache/CacheClient.cs               |  28 +-
 .../Client/Cache/Query/ClientFieldsQueryCursor.cs  |   6 +-
 .../Impl/Client/Cache/Query/ClientQueryCursor.cs   |   6 +-
 .../Client/Cache/Query/ClientQueryCursorBase.cs    |  19 +-
 .../Apache.Ignite.Core/Impl/Client/ClientSocket.cs |  42 +-
 .../Impl/Client/Compute/ComputeClient.cs           |  53 +-
 .../Impl/Common/DelegateConverter.cs               |  65 ++-
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs      |   5 +-
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs       |  37 +-
 .../dotnet/Apache.Ignite.Core/Impl/IgniteLock.cs   | 114 ++++
 .../Apache.Ignite.DotNetCore.sln.DotSettings       |   2 +
 modules/rocketmq/README.txt                        |  25 -
 modules/rocketmq/licenses/apache-2.0.txt           | 202 -------
 modules/rocketmq/pom.xml                           |  94 ----
 .../ignite/stream/rocketmq/RocketMQStreamer.java   | 151 -----
 .../ignite/stream/rocketmq/package-info.java       |  21 -
 .../stream/rocketmq/RocketMQStreamerTest.java      | 215 -------
 .../stream/rocketmq/RocketMQStreamerTestSuite.java |  31 --
 .../ignite/stream/rocketmq/TestRocketMQServer.java | 148 -----
 .../ignite/stream/rocketmq/package-info.java       |  21 -
 .../repository/query/IgniteRepositoryQuery.java    |  52 +-
 .../repository/support/IgniteRepositoryImpl.java   |  51 +-
 .../IgniteSpringDataCrudSelfExpressionTest.java    |  33 +-
 .../springdata/IgniteSpringDataCrudSelfTest.java   | 229 ++++----
 .../IgniteSpringDataQueriesSelfTest.java           |  32 +-
 .../springdata/misc/ApplicationConfiguration.java  |  23 +-
 .../ignite/springdata/misc/CacheNamesBean.java     |  11 +-
 .../org/apache/ignite/springdata/misc/Person.java  |  16 +-
 .../misc/{CacheNamesBean.java => PersonKey.java}   |  35 +-
 .../ignite/springdata/misc/PersonRepository.java   |   5 +-
 .../misc/PersonRepositoryWithCompoundKey.java}     |  22 +-
 .../springdata/misc/PersonSecondRepository.java    |   2 +-
 .../repository/query/IgniteRepositoryQuery.java    |  52 +-
 .../repository/support/IgniteRepositoryImpl.java   |  51 +-
 .../IgniteSpringDataCrudSelfExpressionTest.java    |  33 +-
 .../springdata/IgniteSpringDataCrudSelfTest.java   | 231 ++++----
 .../IgniteSpringDataQueriesSelfTest.java           |  18 +-
 .../springdata/misc/ApplicationConfiguration.java  |  23 +-
 .../ignite/springdata/misc/CacheNamesBean.java     |  12 +-
 .../org/apache/ignite/springdata/misc/Person.java  |  16 +-
 .../apache/ignite/springdata/misc/PersonKey.java}  |  35 +-
 .../ignite/springdata/misc/PersonRepository.java   |   5 +-
 ...n.java => PersonRepositoryWithCompoundKey.java} |  22 +-
 .../springdata/misc/PersonSecondRepository.java    |   2 +-
 .../repository/query/IgniteRepositoryQuery.java    |  72 ++-
 .../repository/support/IgniteRepositoryImpl.java   |  51 +-
 .../springdata/IgniteSpringDataCrudSelfTest.java   | 169 ++++--
 .../springdata/misc/ApplicationConfiguration.java  |  25 +-
 .../org/apache/ignite/springdata/misc/Person.java  |  19 +-
 .../apache/ignite/springdata/misc/PersonKey.java}  |  35 +-
 .../ignite/springdata/misc/PersonRepository.java   |   7 +-
 .../misc/PersonRepositoryWithCompoundKey.java}     |  22 +-
 parent/pom.xml                                     |   6 +-
 pom.xml                                            |   1 -
 342 files changed, 13831 insertions(+), 3648 deletions(-)