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

[22/22] ignite git commit: Merge remote-tracking branch 'remotes/origin/ignite-2.0' into ignite-1794

Merge remote-tracking branch 'remotes/origin/ignite-2.0' into ignite-1794


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

Branch: refs/heads/ignite-1794
Commit: b34c9481e129dfab6569c542b5ba3408e42a710a
Parents: d992b94 f440480
Author: sboikov <sb...@gridgain.com>
Authored: Thu Apr 20 12:38:38 2017 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Thu Apr 20 12:38:38 2017 +0300

----------------------------------------------------------------------
 assembly/release-fabric-base.xml                |   5 -
 config/dotnet/default-dotnet.xml                |  45 --
 .../benchmarks/jmh/tree/BPlusTreeBenchmark.java |   1 +
 .../org/apache/ignite/IgniteFileSystem.java     |   2 +-
 .../store/jdbc/CacheAbstractJdbcStore.java      |  37 +-
 .../cache/store/jdbc/CacheJdbcPojoStore.java    |   1 -
 .../configuration/CacheConfiguration.java       |  17 +-
 .../configuration/FileSystemConfiguration.java  |   8 +-
 .../configuration/MemoryConfiguration.java      |  15 +-
 .../MemoryPolicyConfiguration.java              |  34 +-
 .../org/apache/ignite/internal/IgniteEx.java    |   2 +-
 .../apache/ignite/internal/IgniteKernal.java    |   8 +-
 .../mem/IgniteOutOfMemoryException.java         |  51 ++
 .../internal/mem/OutOfMemoryException.java      |  51 --
 .../pagemem/impl/PageMemoryNoStoreImpl.java     |  16 +-
 .../processors/cache/GridCacheAdapter.java      |   5 +-
 .../processors/cache/GridCacheMapEntry.java     |   2 +-
 .../cache/GridCacheSharedContext.java           |   6 +-
 .../processors/cache/GridCacheUtils.java        |  92 ++-
 .../IgniteCacheDatabaseSharedManager.java       |  12 +-
 .../distributed/GridDistributedLockRequest.java |  14 +-
 .../distributed/GridDistributedTxMapping.java   |  68 +-
 .../GridDistributedTxRemoteAdapter.java         |   2 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |   2 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |  28 +-
 .../dht/atomic/GridDhtAtomicCache.java          |  38 +-
 ...arOptimisticSerializableTxPrepareFuture.java | 218 +++---
 .../near/GridNearOptimisticTxPrepareFuture.java |  95 ++-
 .../GridNearPessimisticTxPrepareFuture.java     | 186 +++--
 .../near/GridNearSingleGetRequest.java          |   4 +-
 .../near/GridNearTxFinishFuture.java            |   6 +-
 .../cache/distributed/near/GridNearTxLocal.java |  30 +-
 .../near/GridNearTxPrepareFutureAdapter.java    |  30 +-
 .../local/atomic/GridLocalAtomicCache.java      |  35 +-
 .../cache/transactions/IgniteTxAdapter.java     |  16 +-
 .../cache/transactions/IgniteTxEntry.java       |  39 +-
 .../cache/transactions/IgniteTxHandler.java     |  49 +-
 .../IgniteTxImplicitSingleStateImpl.java        |   6 +
 .../transactions/IgniteTxLocalAdapter.java      |   7 +-
 .../cache/transactions/IgniteTxLocalState.java  |  10 +
 .../cache/transactions/IgniteTxManager.java     |   7 +-
 .../cache/transactions/IgniteTxState.java       |   2 +-
 .../cache/transactions/IgniteTxStateImpl.java   |  52 +-
 .../internal/processors/igfs/IgfsAsyncImpl.java |   2 +-
 .../internal/processors/igfs/IgfsImpl.java      |   2 +-
 .../processors/igfs/IgfsNoopProcessor.java      |   4 +-
 .../internal/processors/igfs/IgfsProcessor.java |  30 +-
 .../processors/igfs/IgfsProcessorAdapter.java   |   4 +-
 .../internal/processors/igfs/IgfsUtils.java     |   3 +
 .../IgfsMetaDirectoryListingAddProcessor.java   |   5 +-
 .../processors/query/GridQueryProcessor.java    |  10 +-
 .../lang/gridfunc/PredicateCollectionView.java  |   7 +-
 .../util/lang/gridfunc/PredicateMapView.java    |   6 -
 .../util/lang/gridfunc/PredicateSetView.java    |   6 -
 .../lang/gridfunc/ReadOnlyCollectionView.java   |   6 -
 .../lang/gridfunc/ReadOnlyCollectionView2X.java |   6 -
 .../lang/gridfunc/TransformCollectionView.java  |   7 +-
 .../util/lang/gridfunc/TransformMapView.java    |   6 -
 .../test/config/loaders/grid-cfg-2-grids.xml    |   6 +-
 .../store/jdbc/CacheJdbcPojoStoreTest.java      | 147 ++--
 .../internal/TestRecordingCommunicationSpi.java |   9 +
 .../pagemem/impl/PageMemoryNoLoadSelfTest.java  |   2 +-
 .../CacheMemoryPolicyConfigurationTest.java     |   6 +-
 ...sCacheTxNearEnabledRandomOperationsTest.java |  28 +
 .../cache/CrossCacheTxRandomOperationsTest.java |  23 +-
 .../cache/IgniteOnePhaseCommitInvokeTest.java   | 213 ++++++
 .../CacheLateAffinityAssignmentTest.java        |   3 +-
 .../dht/GridNearCacheTxNodeFailureSelfTest.java |  31 -
 .../IgniteCachePutRetryAbstractSelfTest.java    |  25 +-
 ...gniteCachePutRetryTransactionalSelfTest.java |   2 +-
 .../dht/IgniteCrossCacheTxSelfTest.java         |   8 +
 .../atomic/IgniteCacheAtomicProtocolTest.java   |  16 +-
 .../processors/database/BPlusTreeSelfTest.java  |   7 +-
 .../database/FreeListImplSelfTest.java          |   8 +-
 .../database/MetadataStorageSelfTest.java       |   2 +-
 ...lockMessageSystemPoolStarvationSelfTest.java |   8 +-
 .../processors/igfs/IgfsIgniteMock.java         |   2 +-
 .../igfs/IgfsProcessorValidationSelfTest.java   |  19 +-
 .../testframework/junits/GridAbstractTest.java  |   9 +-
 .../ignite/testframework/junits/IgniteMock.java |   4 +
 .../junits/common/GridCommonAbstractTest.java   |  79 +++
 .../junits/multijvm/IgniteProcessProxy.java     |   2 +-
 .../IgniteCacheFailoverTestSuite.java           |   2 -
 .../testsuites/IgniteCacheTestSuite2.java       |   5 +
 .../h2/GridBinaryH2IndexingGeoSelfTest.java     |  35 -
 .../query/h2/GridH2IndexingGeoSelfTest.java     | 470 -------------
 .../h2/GridH2IndexingSegmentedGeoSelfTest.java  |  37 -
 .../query/h2/H2IndexingAbstractGeoSelfTest.java | 673 +++++++++++++++++++
 .../query/h2/H2IndexingBinaryGeoSelfTest.java   |  30 +
 .../H2IndexingBinarySegmentedGeoSelfTest.java   |  30 +
 .../query/h2/H2IndexingGeoSelfTest.java         |  30 +
 .../h2/H2IndexingSegmentedGeoSelfTest.java      |  30 +
 .../testsuites/GeoSpatialIndexingTestSuite.java |  16 +-
 .../hadoop/igfs/HadoopIgfsEndpoint.java         |   6 +-
 .../hadoop/impl/HadoopAbstractSelfTest.java     |   4 +-
 .../impl/HadoopTaskExecutionSelfTest.java       |  16 +-
 ...opClientProtocolMultipleServersSelfTest.java |   8 +-
 .../client/HadoopClientProtocolSelfTest.java    |   7 +-
 ...IgniteHadoopFileSystemHandshakeSelfTest.java | 119 +---
 .../processors/query/h2/IgniteH2Indexing.java   |   2 +-
 .../query/h2/ddl/DdlStatementsProcessor.java    |  19 +-
 .../IgniteCacheAbstractFieldsQuerySelfTest.java |  10 +-
 .../cache/index/AbstractSchemaSelfTest.java     |   8 +-
 .../index/DuplicateKeyValueClassesSelfTest.java |  94 +++
 .../DynamicIndexAbstractBasicSelfTest.java      | 186 ++++-
 .../index/DynamicIndexAbstractSelfTest.java     |  35 +-
 .../h2/database/InlineIndexHelperTest.java      |   3 +
 .../IgniteCacheQuerySelfTestSuite.java          |   4 +
 .../java/org/apache/ignite/ml/math/Algebra.java |  18 +-
 .../org/apache/ignite/ml/math/Constants.java    |  35 +-
 .../java/org/apache/ignite/ml/math/Matrix.java  |   8 +-
 .../org/apache/ignite/ml/math/MurmurHash.java   |  31 +-
 .../org/apache/ignite/ml/math/ValueMapper.java  |   6 +-
 .../decompositions/CholeskyDecomposition.java   |   2 +-
 .../math/decompositions/EigenDecomposition.java |  23 +-
 .../ml/math/decompositions/LUDecomposition.java |  16 +-
 .../ignite/ml/math/functions/Functions.java     |   7 +-
 .../functions/IntIntDoubleToVoidFunction.java   |   6 +-
 .../ml/math/impls/matrix/CacheMatrix.java       |  19 +-
 .../ml/math/impls/matrix/PivotedMatrixView.java |  38 +-
 .../impls/matrix/SparseDistributedMatrix.java   |  17 +-
 .../storage/matrix/CacheMatrixStorage.java      |  10 +-
 .../matrix/DenseOffHeapMatrixStorage.java       |   9 +-
 .../storage/vector/CacheVectorStorage.java      |   8 +-
 .../storage/vector/DelegateVectorStorage.java   |  12 +-
 .../storage/vector/MatrixVectorStorage.java     |  27 +-
 .../vector/SparseLocalOffHeapVectorStorage.java |   4 +-
 .../ml/math/impls/vector/AbstractVector.java    |  16 +-
 .../ml/math/impls/vector/CacheVector.java       |  10 +-
 .../ml/math/impls/vector/ConstantVector.java    |   4 +-
 .../ml/math/impls/vector/DelegatingVector.java  |   2 +-
 .../ml/math/impls/vector/MatrixVectorView.java  |  12 +-
 .../ml/math/impls/vector/PivotedVectorView.java |  23 +-
 .../ml/math/impls/vector/RandomVector.java      |  10 +-
 .../math/impls/vector/SingleElementVector.java  |   8 +-
 .../impls/vector/SingleElementVectorView.java   |   4 +-
 .../ml/math/impls/vector/SparseLocalVector.java |   4 +-
 .../ml/math/impls/matrix/CacheMatrixTest.java   |   4 +-
 .../math/impls/vector/AbstractVectorTest.java   |   6 +-
 modules/platforms/cpp/odbc/README.txt           |  17 +-
 .../Apache.Ignite.Core.Tests.csproj             |   7 +
 .../Binary/BinaryBuilderSelfTest.cs             |   3 +-
 .../BinaryBuilderSelfTestDynamicRegistration.cs |   2 +
 .../Binary/BinaryBuilderSelfTestSimpleName.cs   |   2 +
 .../Binary/BinaryCompactFooterInteropTest.cs    |   4 +-
 .../BinaryConfigurationTest.cs                  |   4 +-
 .../Cache/AddArgCacheEntryProcessor.cs          |  91 +++
 .../Cache/Affinity/AffinityFunctionTest.cs      |   1 -
 .../Cache/Affinity/AffinityTest.cs              |  10 +-
 .../BinarizableAddArgCacheEntryProcessor.cs     |  53 ++
 .../Cache/BinarizableTestException.cs           |  51 ++
 .../Cache/CacheAbstractTest.cs                  | 422 +++---------
 .../Cache/CacheDynamicStartTest.cs              | 164 ++---
 .../Cache/CacheForkedTest.cs                    |   6 +-
 .../Cache/CacheTestKey.cs                       |  68 ++
 .../Cache/NonSerializableCacheEntryProcessor.cs |  40 ++
 .../Cache/NonSerializableException.cs           |  40 ++
 .../Cache/Query/CacheQueriesTest.cs             |  35 +-
 .../Continuous/ContinuousQueryAbstractTest.cs   |  45 +-
 .../Continuous/ContinuousQueryJavaFilterTest.cs |  21 +-
 .../Cache/Store/CacheParallelLoadStoreTest.cs   |   9 +-
 .../Cache/Store/CacheStoreSessionTest.cs        |  15 +-
 .../Cache/Store/CacheStoreTest.cs               |  17 +-
 .../Cache/TestReferenceObject.cs                |  40 ++
 .../Compute/AbstractTaskTest.cs                 |  29 +-
 .../Compute/BinarizableClosureTaskTest.cs       |  14 +-
 .../Compute/BinarizableTaskTest.cs              |  15 -
 .../Compute/ComputeApiTest.cs                   |   9 +-
 .../Compute/ComputeApiTestFullFooter.cs         |   4 +-
 .../Compute/FailoverTaskSelfTest.cs             |   6 -
 .../Compute/ResourceTaskTest.cs                 |  60 +-
 .../Compute/SerializableClosureTaskTest.cs      |   1 +
 .../Compute/TaskAdapterTest.cs                  |   6 -
 .../Compute/TaskResultTest.cs                   |  12 -
 .../Dataload/DataStreamerTest.cs                |  55 +-
 .../Apache.Ignite.Core.Tests/DeploymentTest.cs  |   4 +-
 .../Apache.Ignite.Core.Tests/EventsTest.cs      |  65 +-
 .../Apache.Ignite.Core.Tests/ExceptionsTest.cs  |  13 +-
 .../Apache.Ignite.Core.Tests/ExecutableTest.cs  |  57 +-
 .../Apache.Ignite.Core.Tests/FutureTest.cs      |  18 +-
 .../IgniteStartStopTest.cs                      |  55 +-
 .../Apache.Ignite.Core.Tests/IgniteTestBase.cs  |  51 +-
 .../Apache.Ignite.Core.Tests/LifecycleTest.cs   |  45 +-
 .../Apache.Ignite.Core.Tests/LoadDllTest.cs     |  11 +-
 .../Apache.Ignite.Core.Tests/MessagingTest.cs   |  30 +-
 .../Impl/Binary/BinaryUtils.cs                  | 207 ++----
 .../apache/ignite/cache/spring/SpringCache.java |   6 +
 .../GridSpringResourceInjectionSelfTest.java    |  20 +-
 .../views/templates/agent-download.tpl.pug      |   6 +-
 parent/pom.xml                                  |   2 +-
 190 files changed, 3458 insertions(+), 2905 deletions(-)
----------------------------------------------------------------------