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/01/10 06:26:25 UTC

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

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

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

commit e76fe02e2424f06b85e86f97628a5af119758589
Merge: b2c0835 25a645e
Author: Anton Vinogradov <av...@apache.org>
AuthorDate: Fri Jan 10 09:25:38 2020 +0300

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

 NOTICE                                             |    2 +-
 assembly/NOTICE_HADOOP                             |    2 +-
 assembly/NOTICE_IGNITE                             |    2 +-
 .../internal/jdbc2/JdbcStreamingSelfTest.java      |   91 +-
 .../ignite/jdbc/JdbcErrorsAbstractSelfTest.java    |    9 +-
 ...JdbcThinDriverPartitionAwarenessTestSuite.java} |   22 +-
 .../ignite/jdbc/thin/JdbcThinAbstractSelfTest.java |    4 +-
 .../JdbcThinConnectionMultipleAddressesTest.java   |    2 +-
 .../jdbc/thin/JdbcThinConnectionSelfTest.java      |  314 ++---
 .../jdbc/thin/JdbcThinDataSourceSelfTest.java      |    2 +-
 .../ignite/jdbc/thin/JdbcThinMetadataSelfTest.java |    8 +-
 ...nAwarenessReconnectionAndFailoverSelfTest.java} |   24 +-
 ...ava => JdbcThinPartitionAwarenessSelfTest.java} |   34 +-
 ...hinPartitionAwarenessTransactionsSelfTest.java} |    6 +-
 .../jdbc/thin/JdbcThinStatementSelfTest.java       |    8 +-
 modules/core/src/main/java/META-INF/NOTICE         |    2 +-
 .../src/main/java/org/apache/ignite/Ignite.java    |    7 +
 .../main/java/org/apache/ignite/IgniteBinary.java  |   16 +-
 .../main/java/org/apache/ignite/IgniteCluster.java |   19 +-
 .../java/org/apache/ignite/IgniteEncryption.java   |   73 +
 .../org/apache/ignite/IgniteSystemProperties.java  |   16 +-
 .../java/org/apache/ignite/cache/QueryEntity.java  |   11 +-
 .../org/apache/ignite/cluster/ClusterState.java    |   73 +
 .../ignite/configuration/ClientConfiguration.java  |   16 +-
 .../ignite/configuration/IgniteConfiguration.java  |   76 +-
 .../ignite/events/ClusterActivationEvent.java      |    5 +-
 ...tionEvent.java => ClusterStateChangeEvent.java} |   66 +-
 .../java/org/apache/ignite/events/EventType.java   |   12 +
 .../java/org/apache/ignite/internal/GridTopic.java |    6 +-
 .../org/apache/ignite/internal/IgniteFeatures.java |    6 +-
 .../org/apache/ignite/internal/IgniteKernal.java   |  155 ++-
 .../ignite/internal/IgniteNodeAttributes.java      |    3 -
 .../internal/binary/BinaryClassDescriptor.java     |   68 +-
 .../ignite/internal/binary/BinaryContext.java      |  321 ++---
 .../internal/binary/BinaryEnumObjectImpl.java      |   13 +-
 .../internal/binary/BinaryFieldAccessor.java       |    4 +-
 .../ignite/internal/binary/BinaryObjectExImpl.java |    4 +-
 .../ignite/internal/binary/BinaryReaderExImpl.java |    8 +-
 .../apache/ignite/internal/binary/BinaryUtils.java |   12 +-
 .../ignite/internal/binary/BinaryWriterExImpl.java |   29 +-
 .../internal/binary/builder/BinaryBuilderEnum.java |    2 +-
 .../binary/builder/BinaryBuilderSerializer.java    |    2 +-
 .../binary/builder/BinaryEnumArrayLazyValue.java   |    2 +-
 .../binary/builder/BinaryObjectArrayLazyValue.java |    2 +-
 .../binary/builder/BinaryObjectBuilderImpl.java    |    2 +-
 .../apache/ignite/internal/client/GridClient.java  |    2 +-
 .../internal/client/GridClientClusterState.java    |   20 +-
 .../ignite/internal/client/GridClientCompute.java  |    2 +-
 .../ignite/internal/client/GridClientData.java     |    2 +-
 .../client/impl/GridClientClusterStateImpl.java    |   29 +-
 .../impl/connection/GridClientConnection.java      |   25 +-
 .../connection/GridClientNioTcpConnection.java     |   57 +-
 .../client/thin/ClientCacheAffinityContext.java    |    2 +-
 .../client/thin/ClientCacheAffinityMapping.java    |   10 +-
 .../internal/client/thin/ProtocolVersion.java      |    2 +-
 .../internal/client/thin/ReliableChannel.java      |   16 +-
 .../internal/cluster/IgniteClusterAsyncImpl.java   |    9 +-
 .../ignite/internal/cluster/IgniteClusterImpl.java |   23 +-
 .../internal/commandline/ActivateCommand.java      |    7 +-
 .../ClusterReadOnlyModeDisableCommand.java         |   72 -
 .../ClusterReadOnlyModeEnableCommand.java          |   72 -
 .../commandline/ClusterStateChangeCommand.java     |  105 ++
 .../ignite/internal/commandline/Command.java       |   93 +-
 .../internal/commandline/CommandHandler.java       |    1 +
 .../ignite/internal/commandline/CommandList.java   |   11 +-
 .../internal/commandline/DeactivateCommand.java    |    7 +-
 .../ignite/internal/commandline/StateCommand.java  |   26 +-
 .../ignite/internal/commandline/WalCommands.java   |   15 +-
 .../internal/commandline/cache/CacheCommands.java  |   45 +-
 .../ignite/internal/jdbc/thin/AffinityCache.java   |    8 +-
 .../internal/jdbc/thin/ConnectionProperties.java   |   30 +-
 .../jdbc/thin/ConnectionPropertiesImpl.java        |   56 +-
 .../internal/jdbc/thin/JdbcThinConnection.java     |   52 +-
 ...=> JdbcThinPartitionAwarenessMappingGroup.java} |   16 +-
 .../ignite/internal/jdbc/thin/JdbcThinTcpIo.java   |    4 +-
 .../internal/managers/IgniteMBeansManager.java     |   26 +-
 .../managers/checkpoint/GridCheckpointManager.java |    4 +-
 .../managers/communication/GridIoManager.java      |    3 -
 .../communication/GridIoMessageFactory.java        |    6 +
 .../deployment/GridDeploymentPerVersionStore.java  |   16 +-
 .../managers/discovery/GridDiscoveryManager.java   |   27 +-
 .../managers/encryption/EncryptionMXBeanImpl.java} |   35 +-
 .../encryption/GenerateEncryptionKeyResponse.java  |   26 +-
 .../managers/encryption/GridEncryptionManager.java |  755 +++++++++--
 .../managers/encryption}/package-info.java         |    5 +-
 .../apache/ignite/internal/pagemem/FullPageId.java |    3 +
 .../pagemem/wal/IgniteWriteAheadLogManager.java    |    4 +-
 .../pagemem/wal/record/MasterKeyChangeRecord.java  |   68 +
 .../internal/pagemem/wal/record/WALRecord.java     |    5 +-
 .../processors/cache/CacheObjectAdapter.java       |    2 +-
 .../processors/cache/ClusterCachesInfo.java        |   31 +-
 .../cache/DynamicCacheChangeRequest.java           |   13 +
 .../internal/processors/cache/ExchangeActions.java |   13 +-
 .../processors/cache/GridCacheMapEntry.java        |    4 +-
 .../cache/GridCachePartitionExchangeManager.java   |   77 +-
 .../processors/cache/GridCacheProcessor.java       |   35 +-
 .../processors/cache/KeyCacheObjectImpl.java       |    2 +-
 .../processors/cache/StateChangeRequest.java       |   34 +-
 .../cache/binary/BinaryMetadataTransport.java      |    2 +-
 .../dht/GridDhtTopologyFutureAdapter.java          |    3 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java    |    4 +-
 .../dht/IgniteClusterReadOnlyException.java}       |   33 +-
 .../distributed/dht/atomic/GridDhtAtomicCache.java |    2 +-
 .../dht/preloader/GridDhtPartitionDemander.java    |   88 +-
 .../preloader/GridDhtPartitionsExchangeFuture.java |   16 +-
 .../GridCacheDatabaseSharedManager.java            |  125 +-
 .../cache/persistence/pagemem/PageMemoryEx.java    |   12 +-
 .../cache/persistence/pagemem/PageMemoryImpl.java  |  107 +-
 .../cache/persistence/pagemem/PagePool.java        |    4 +-
 .../persistence/pagemem/PagesWriteThrottle.java    |    9 +-
 .../pagemem/PagesWriteThrottlePolicy.java          |    7 +
 .../cache/persistence/tree/BPlusTree.java          |   34 +-
 .../wal/AbstractWalRecordsIterator.java            |    5 +-
 .../persistence/wal/FileWriteAheadLogManager.java  |   47 +-
 .../wal/filehandle/FileHandleManager.java          |    4 +-
 .../wal/filehandle/FileHandleManagerFactory.java   |    5 -
 .../wal/filehandle/FileHandleManagerImpl.java      |   33 +-
 .../wal/filehandle/FileWriteHandleImpl.java        |    2 +-
 .../wal/filehandle/FsyncFileHandleManagerImpl.java |   45 +-
 .../wal/filehandle/FsyncFileWriteHandle.java       |    6 +-
 .../wal/serializer/RecordDataV1Serializer.java     |   60 +-
 .../cache/query/QueryEntityTypeDescriptor.java     |   41 +-
 .../cache/store/GridCacheStoreManagerAdapter.java  |    2 +-
 .../cache/store/GridCacheWriteBehindStore.java     |    4 +-
 .../processors/cache/transactions/IgniteTxKey.java |    2 +-
 .../cache/transactions/IgniteTxManager.java        |   42 +-
 .../processors/cache/transactions/TxDeadlock.java  |    2 +-
 .../cache/transactions/TxEntryValueHolder.java     |    8 +-
 .../cluster/ChangeGlobalStateFinishMessage.java    |   26 +-
 .../cluster/ChangeGlobalStateMessage.java          |   29 +-
 .../cluster/DiscoveryDataClusterState.java         |  111 +-
 .../cluster/GridClusterStateProcessor.java         |  538 ++++----
 .../cluster/IGridClusterStateProcessor.java        |   38 +-
 .../processors/datastreamer/DataStreamerImpl.java  |   12 +-
 .../processors/metric/GridMetricManager.java       |   13 +-
 .../internal/processors/odbc/SqlStateCode.java     |    4 +-
 .../odbc/jdbc/JdbcCachePartitionsResult.java       |   14 +-
 .../odbc/jdbc/JdbcConnectionContext.java           |    2 +-
 .../processors/odbc/jdbc/JdbcRequestHandler.java   |   16 +-
 .../platform/PlatformNativeException.java          |    2 +-
 .../platform/client/ClientConnectionContext.java   |    2 +-
 .../platform/client/ClientMessageParser.java       |   14 +
 ...ava => ClientCachePartitionAwarenessGroup.java} |    6 +-
 .../client/cache/ClientCachePartitionsRequest.java |   30 +-
 .../cache/ClientCachePartitionsResponse.java       |    6 +-
 .../ClientClusterGroupGetNodeIdsRequest.java       |   77 ++
 ...a => ClientClusterGroupGetNodeIdsResponse.java} |   39 +-
 .../ClientClusterGroupGetNodesDetailsRequest.java  |   57 +
 ...ClientClusterGroupGetNodesDetailsResponse.java} |   39 +-
 .../cluster/ClientClusterGroupProjection.java      |  159 +++
 .../ClientClusterWalChangeStateResponse.java       |    2 +-
 .../processors/query/GridQueryProcessor.java       |    2 +-
 .../internal/processors/rest/GridRestCommand.java  |   19 +-
 .../processors/rest/GridRestProcessor.java         |    6 +-
 ...est.java => GridClientClusterStateRequest.java} |   40 +-
 .../client/message/GridClientStateRequest.java     |    3 +-
 ...a => GridChangeClusterStateCommandHandler.java} |   32 +-
 .../rest/protocols/tcp/GridTcpRestNioListener.java |   21 +-
 ...quest.java => GridRestClusterStateRequest.java} |   26 +-
 .../sql/optimizer/affinity/PartitionResult.java    |   12 +-
 .../affinity/PartitionTableAffinityDescriptor.java |    4 +-
 .../util/distributed/DistributedProcess.java       |  384 ++++++
 .../distributed/FullMessage.java}                  |   96 +-
 .../distributed/InitMessage.java}                  |   87 +-
 .../util/distributed/SingleNodeMessage.java        |  196 +++
 .../util/tostring/GridToStringBuilder.java         |   64 +-
 .../org/apache/ignite/marshaller/Marshaller.java   |    2 +
 .../EncryptionMXBean.java}                         |   51 +-
 .../org/apache/ignite/mxbean/IgniteMXBean.java     |  296 ++++-
 .../spi/communication/tcp/TcpCommunicationSpi.java |    2 +-
 .../ignite/spi/encryption/EncryptionSpi.java       |   18 +
 .../encryption/keystore/KeystoreEncryptionSpi.java |   94 +-
 .../spi/encryption/noop/NoopEncryptionSpi.java     |   11 +
 .../main/resources/META-INF/classnames.properties  |    2 +-
 .../cluster/GridClusterStateChangeSelfTest.java    |  144 ++
 .../internal/binary/BinaryMarshallerSelfTest.java  |    4 +-
 ... ThinClientAbstractPartitionAwarenessTest.java} |    6 +-
 ...lientPartitionAwarenessStableTopologyTest.java} |   16 +-
 ...entPartitionAwarenessUnstableTopologyTest.java} |   48 +-
 .../commandline/CommandHandlerParsingTest.java     |   67 +-
 .../encryption/AbstractEncryptionTest.java         |   36 +-
 .../internal/encryption/EncryptionMXBeanTest.java  |  143 ++
 .../MasterKeyChangeConsistencyCheckTest.java       |  163 +++
 .../internal/encryption/MasterKeyChangeTest.java   |  426 ++++++
 .../ignite/internal/metric/JmxExporterSpiTest.java |   78 ++
 .../AuthenticationProcessorNodeRestartTest.java    |   39 +-
 .../cache/ActiveOnStartPropertyTest.java           |  149 +++
 .../cache/AutoActivationPropertyTest.java          |  128 ++
 .../cache/CacheGroupsMetricsRebalanceTest.java     |  207 ++-
 ...ActiveStateChangeWithNodeOutOfBaselineTest.java |  134 ++
 .../cache/ClusterReadOnlyModeAbstractTest.java     |    3 +-
 .../processors/cache/ClusterReadOnlyModeTest.java  |    4 +-
 .../processors/cache/ClusterStateAbstractTest.java |  395 ++----
 .../cache/ClusterStateClientAbstractTest.java      |   58 +
 ... => ClusterStateClientPartitionedSelfTest.java} |   21 +-
 ...a => ClusterStateClientReplicatedSelfTest.java} |   21 +-
 .../cache/ClusterStateNoRebalanceAbstractTest.java |  219 +++
 ...=> ClusterStateNoRebalancePartitionedTest.java} |   21 +-
 ... => ClusterStateNoRebalanceReplicatedTest.java} |   21 +-
 .../cache/ClusterStateOnStartPropertyTest.java     |  396 ++++++
 .../cache/ClusterStatePartitionedSelfTest.java     |   14 +-
 .../cache/ClusterStateReplicatedSelfTest.java      |   15 +-
 .../cache/ClusterStateServerAbstractTest.java      |  206 +++
 .../processors/cache/ClusterStateTestUtils.java    |  124 ++
 .../cache/ClusterStateThinClientAbstractTest.java  |   80 ++
 ...ClusterStateThinClientPartitionedSelfTest.java} |   21 +-
 ... ClusterStateThinClientReplicatedSelfTest.java} |   21 +-
 .../cache/IgniteClusterActivateDeactivateTest.java | 1388 ++++++++++++--------
 ...usterActivateDeactivateTestWithPersistence.java |  259 ++--
 .../binary/BinaryMetadataRegistrationTest.java     |  230 ++++
 .../GridCacheBinaryObjectsAbstractSelfTest.java    |    2 +-
 .../GridCacheNodeFailureAbstractTest.java          |    4 -
 .../GridCachePartitionedTxSalvageSelfTest.java     |  258 ----
 .../baseline/ClusterActivationEventTest.java       |  296 +++--
 .../ClusterActivationEventWithPersistenceTest.java |   50 +
 .../persistence/db/wal/WalCompactionTest.java      |    2 +-
 .../pagemem/IgniteThrottlingUnitTest.java          |   17 +-
 .../cache/persistence/pagemem/NoOpWALManager.java  |    4 +-
 .../persistence/pagemem/PageMemoryImplTest.java    |  142 +-
 .../standbycluster/AbstractNodeJoinTemplate.java   |    8 +-
 ...ionIntegrityWithPrimaryIndexCorruptionTest.java |    4 +-
 .../cluster/ClusterReadOnlyModeNodeJoinTest.java   |    8 +-
 .../cluster/ClusterReadOnlyModeSelfTest.java       |   86 +-
 .../cluster/ClusterStateChangeEventTest.java       |  159 +++
 ...ClusterStateChangeEventWithPersistenceTest.java |   36 +
 .../internal/processors/igfs/IgfsIgniteMock.java   |   19 +-
 .../util/tostring/GridToStringBuilderSelfTest.java |    4 +-
 .../tostring/TransactionSensitiveDataTest.java     |  343 +++++
 .../encryption/KeystoreEncryptionSpiSelfTest.java  |   41 +-
 .../apache/ignite/testframework/GridTestUtils.java |   41 +-
 .../testframework/junits/GridAbstractTest.java     |   45 +-
 .../ignite/testframework/junits/IgniteMock.java    |    6 +
 .../junits/multijvm/IgniteClusterProcessProxy.java |    5 +-
 .../junits/multijvm/IgniteProcessProxy.java        |    6 +
 .../IgniteBasicWithPersistenceTestSuite.java       |   14 +-
 .../testsuites/IgniteBinaryObjectsTestSuite.java   |    5 +-
 .../testsuites/IgniteCacheFailoverTestSuite2.java  |    2 -
 .../testsuites/IgniteCacheMvccTestSuite5.java      |   12 +
 .../ignite/testsuites/IgniteCacheTestSuite5.java   |   12 +
 .../testsuites/IgniteKernalSelfTestSuite.java      |    4 +-
 .../ignite/testsuites/IgnitePdsTestSuite.java      |    7 +
 .../ignite/testsuites/IgnitePdsTestSuite2.java     |    6 +
 .../testsuites/IgniteStandByClusterSuite.java      |    4 +-
 .../ignite/testsuites/IgniteUtilSelfTestSuite.java |    2 +
 .../util/GridCommandHandlerAbstractTest.java       |   18 +-
 .../util/GridCommandHandlerClusterByClassTest.java |  136 +-
 ...idCommandHandlerClusterByClassWithSSLTest.java} |   18 +-
 .../ignite/util/GridCommandHandlerSslTest.java     |    7 +-
 .../apache/ignite/util/GridCommandHandlerTest.java |  136 +-
 .../ignite/util/GridCommandHandlerTestUtils.java   |   37 +
 .../util/GridCommandHandlerWithSSLTest.java}       |   17 +-
 .../control.sh_cache_help.output                   |    2 +-
 .../org.apache.ignite.util/control.sh_help.output  |   21 +-
 modules/core/src/test/resources/tde.jks            |  Bin 347 -> 813 bytes
 modules/flink/pom.xml                              |  194 ---
 .../org/apache/ignite/sink/flink/IgniteSink.java   |  197 ---
 .../apache/ignite/source/flink/IgniteSource.java   |  223 ----
 .../ignite/source/flink/TaskRemoteFilter.java      |   60 -
 .../ignite/sink/flink/FlinkIgniteSinkSelfTest.java |   84 --
 .../source/flink/FlinkIgniteSourceSelfTest.java    |  154 ---
 .../flink/src/test/resources/example-ignite.xml    |   73 -
 .../processors/query/h2/IgniteH2Indexing.java      |    4 +-
 .../processors/query/h2/dml/DmlBatchSender.java    |    4 +-
 .../processors/query/h2/dml/UpdatePlanBuilder.java |    4 +-
 .../processors/query/h2/opt/H2CacheRow.java        |    4 +-
 .../query/h2/sql/GridSqlQueryParser.java           |   16 +-
 .../query/h2/twostep/GridMapQueryExecutor.java     |   12 +-
 .../org/apache/ignite/client/ClientTestSuite.java  |    8 +-
 ...finityKeyNameAndValueFieldNameConflictTest.java |    2 +-
 ...usterReadOnlyModeDoesNotBreakSqlSelectTest.java |  121 ++
 .../index/H2TreeCorruptedTreeExceptionTest.java    |   98 +-
 .../index/StopNodeOnRebuildIndexFailureTest.java   |   10 +-
 .../cache/ttl/CacheTtlReadOnlyModeSelfTest.java    |   15 +-
 .../query/SqlQueriesTopologyMappingTest.java       |  185 +++
 .../IgniteBinaryCacheQueryTestSuite2.java          |    5 +-
 ...teCacheWithIndexingAndPersistenceTestSuite.java |    4 +
 .../IgniteCacheWithIndexingTestSuite.java          |    3 +
 ...dHandlerIndexingClusterByClassWithSSLTest.java} |   21 +-
 .../GridCommandHandlerIndexingWithSSLTest.java}    |   17 +-
 .../cpp/thin-client-test/src/cache_client_test.cpp |   18 +-
 .../ignite/thin/ignite_client_configuration.h      |   24 +-
 .../cpp/thin-client/project/vs/thin-client.vcxproj |    2 +-
 .../project/vs/thin-client.vcxproj.filters         |    6 +-
 .../src/impl/affinity/affinity_manager.cpp         |    4 +-
 .../src/impl/affinity/affinity_manager.h           |    6 +-
 ...areness_group.h => partition_awareness_group.h} |   12 +-
 .../src/impl/cache/cache_client_impl.cpp           |    2 +-
 .../cpp/thin-client/src/impl/data_channel.h        |    2 +-
 .../cpp/thin-client/src/impl/data_router.cpp       |    2 +-
 .../cpp/thin-client/src/impl/data_router.h         |   10 +-
 .../platforms/cpp/thin-client/src/impl/message.cpp |    2 +-
 .../platforms/cpp/thin-client/src/impl/message.h   |   16 +-
 .../Properties/AssemblyInfo.cs                     |    4 +-
 .../Apache.Ignite.AspNet.nuspec                    |   17 +-
 .../Properties/AssemblyInfo.cs                     |    4 +-
 .../Properties/AssemblyInfo.cs                     |    4 +-
 .../Apache.Ignite.Core.Tests.DotNetCore.csproj     |    5 +-
 .../Properties/AssemblyInfo.cs                     |    2 +-
 .../Properties/AssemblyInfo.cs                     |    4 +-
 .../Properties/AssemblyInfo.cs                     |    2 +-
 .../Apache.Ignite.Core.Tests.csproj                |    3 +-
 .../ApiParity/ClusterParityTest.cs                 |    6 +-
 .../Apache.Ignite.Core.Tests/AssertExtensions.cs   |   35 +-
 .../Client/Cache/CreateCacheTest.cs                |    4 +-
 ...yAwarenessTest.cs => PartitionAwarenessTest.cs} |   34 +-
 .../Client/ClientConnectionTest.cs                 |   23 +
 .../Client/ClientProtocolCompatibilityTest.cs      |   14 +-
 .../Client/ClientReconnectCompatibilityTest.cs     |   10 +-
 .../Client/ClientServerCompatibilityTest.cs        |  166 ++-
 .../Client/Cluster/ClientClusterGroupTests.cs      |  313 +++++
 .../Client/IgniteClientConfigurationTest.cs        |    4 +-
 .../Compute/ComputeApiTest.cs                      |   84 +-
 .../Config/Client/IgniteClientConfiguration.xml    |    2 +-
 .../dotnet/Apache.Ignite.Core.Tests/JavaServer.cs  |   53 +-
 .../Apache.Ignite.Core.Tests/JavaServer/pom.xml    |    2 +-
 .../JavaServer/src/main/java/Runner.java           |   20 +-
 .../Apache.Ignite.Core.Tests/ProcessExtensions.cs  |    1 +
 .../Properties/AssemblyInfo.cs                     |    4 +-
 .../Apache.Ignite.Core.Schema.nuspec               |   13 +-
 .../Apache.Ignite.Core/Apache.Ignite.Core.csproj   |   12 +-
 .../Apache.Ignite.Core/Apache.Ignite.Core.nuspec   |   23 +-
 .../Apache.Ignite.Core/Client/IClientCluster.cs    |    2 +-
 .../Client/IClientClusterGroup.cs                  |   96 ++
 .../Client/IClientClusterNode.cs                   |   98 ++
 .../Client/IgniteClientConfiguration.cs            |   10 +-
 .../IgniteClientConfigurationSection.xsd           |    2 +-
 .../Impl/Binary/BinaryProcessorClient.cs           |   31 +-
 .../Impl/Client/Cache/CacheClient.cs               |  250 ++--
 ...up.cs => ClientCachePartitionAwarenessGroup.cs} |    4 +-
 .../Client/Cache/Query/ClientQueryCursorBase.cs    |    5 +-
 .../Impl/Client/ClientContextBase.cs               |   79 ++
 .../Impl/Client/ClientFailoverSocket.cs            |   73 +-
 .../Apache.Ignite.Core/Impl/Client/ClientOp.cs     |    6 +-
 .../{IClientSocket.cs => ClientRequestContext.cs}  |   51 +-
 .../Impl/Client/ClientResponseContext.cs           |   51 +
 .../Apache.Ignite.Core/Impl/Client/ClientSocket.cs |   62 +-
 .../Apache.Ignite.Core/Impl/Client/ClientUtils.cs  |   58 +
 .../Impl/Client/Cluster/ClientCluster.cs           |   73 +-
 .../Impl/Client/Cluster/ClientClusterGroup.cs      |  313 +++++
 .../Client/Cluster/ClientClusterGroupProjection.cs |  166 +++
 .../Impl/Client/Cluster/ClientClusterNode.cs       |  171 +++
 .../Apache.Ignite.Core/Impl/Client/IgniteClient.cs |   71 +-
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs       |    2 +-
 .../Apache.Ignite.Core/Properties/AssemblyInfo.cs  |    2 +-
 .../Apache.Ignite.EntityFramework.nuspec           |   19 +-
 .../Properties/AssemblyInfo.cs                     |    4 +-
 .../Apache.Ignite.Linq.DotNetCore.csproj           |    2 +-
 .../Apache.Ignite.Linq/Apache.Ignite.Linq.nuspec   |   27 +-
 .../Apache.Ignite.Linq/Properties/AssemblyInfo.cs  |    4 +-
 .../Apache.Ignite.Log4Net.nuspec                   |   26 +-
 .../Properties/AssemblyInfo.cs                     |    4 +-
 .../Apache.Ignite.NLog/Apache.Ignite.NLog.nuspec   |   26 +-
 .../Apache.Ignite.NLog/Properties/AssemblyInfo.cs  |    2 +-
 .../Apache.Ignite/Properties/AssemblyInfo.cs       |    4 +-
 modules/platforms/dotnet/DEVNOTES.txt              |    3 +-
 modules/platforms/dotnet/build.ps1                 |    4 +-
 .../Properties/AssemblyInfo.cs                     |    4 +-
 .../Properties/AssemblyInfo.cs                     |    4 +-
 modules/platforms/dotnet/logo_ignite_128x128.png   |  Bin 0 -> 18667 bytes
 modules/platforms/dotnet/release/Program.cs        |   31 +-
 modules/platforms/dotnet/release/verify-nuget.ps1  |    5 +-
 .../protocols/http/jetty/GridJettyRestHandler.java |   58 +-
 modules/scalar-2.10/pom.xml                        |    2 +-
 modules/scalar/pom.xml                             |    2 +-
 modules/{flink => spring-data-2.2}/README.txt      |   21 +-
 .../licenses/apache-2.0.txt                        |    0
 modules/spring-data-2.2/pom.xml                    |  141 ++
 .../springdata22/repository/IgniteRepository.java  |   58 +
 .../config/EnableIgniteRepositories.java           |  119 ++
 .../config/IgniteRepositoriesRegistar.java}        |   29 +-
 .../IgniteRepositoryConfigurationExtension.java    |   49 +
 .../springdata22/repository/config/Query.java}     |   23 +-
 .../repository/config/RepositoryConfig.java}       |   46 +-
 .../repository/config/package-info.java}           |   13 +-
 .../springdata22/repository}/package-info.java     |    5 +-
 .../springdata22/repository/query/IgniteQuery.java |   82 ++
 .../repository/query/IgniteQueryGenerator.java     |  252 ++++
 .../repository/query/IgniteRepositoryQuery.java    |  312 +++++
 .../repository/query/package-info.java}            |   14 +-
 .../repository/support/ConditionFalse.java}        |   19 +-
 .../support/IgniteRepositoryFactory.java           |  168 +++
 .../support/IgniteRepositoryFactoryBean.java       |   91 ++
 .../repository/support/IgniteRepositoryImpl.java   |  164 +++
 .../repository/support}/package-info.java          |    4 +-
 .../springdata/IgniteSpringDataCrudSelfTest.java   |  353 +++++
 .../IgniteSpringDataQueriesSelfTest.java           |  317 +++++
 .../springdata/misc/ApplicationConfiguration.java} |   41 +-
 .../org/apache/ignite/springdata/misc/Person.java  |   98 ++
 .../ignite/springdata/misc/PersonRepository.java   |  119 ++
 .../springdata/misc/PersonSecondRepository.java    |   40 +
 .../testsuites/IgniteSpringData22TestSuite.java}   |   14 +-
 .../java/org/apache/ignite/IgniteSpringBean.java   |    7 +
 .../src/test/config/state/cluster-state.xml}       |   36 +-
 .../cluster/ClusterStateXmlPropertiesTest.java     |   90 ++
 .../ignite/testsuites/IgniteSpringTestSuite.java   |    5 +-
 .../app/modules/branding/branding.service.js       |    4 +-
 parent/pom.xml                                     |   10 +-
 pom.xml                                            |    2 +-
 398 files changed, 15944 insertions(+), 5584 deletions(-)