You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by nt...@apache.org on 2016/02/01 15:21:31 UTC

[23/49] ignite git commit: Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/ignite

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


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

Branch: refs/heads/ignite-2435
Commit: 8823e46860c520abfc9b9c718df5c2d92f0c820f
Parents: 7a11154 79db260
Author: Valentin Kulichenko <va...@gmail.com>
Authored: Thu Jan 28 16:09:36 2016 -0800
Committer: Valentin Kulichenko <va...@gmail.com>
Committed: Thu Jan 28 16:09:36 2016 -0800

----------------------------------------------------------------------
 .../examples/datagrid/CacheAffinityExample.java |   8 +-
 .../java8/datagrid/CacheAffinityExample.java    |   6 +-
 modules/benchmarks/pom.xml                      |  30 --
 .../benchmarks/jmh/JmhAbstractBenchmark.java    | 150 ++++++++
 .../jmh/cache/JmhCacheAbstractBenchmark.java    | 181 ++++++++++
 .../jmh/cache/JmhCachePutBenchmark.java         | 122 +++++++
 .../benchmarks/jmh/cache/PutBenchmark.java      | 170 ---------
 .../jmh/runner/JmhIdeBenchmarkRunner.java       | 214 +++++++++++
 .../internal/client/ClientGetAffinityTask.java  |   4 +-
 .../java/org/apache/ignite/IgniteCluster.java   |   7 +-
 .../apache/ignite/cache/affinity/Affinity.java  |  24 +-
 .../affinity/GridAffinityProcessor.java         |  60 ++--
 .../cache/GridCacheAffinityManager.java         |  47 ++-
 .../cache/affinity/GridCacheAffinityImpl.java   |  48 ++-
 .../near/GridNearTxFinishFuture.java            |  96 ++---
 .../ignite/internal/GridAffinityMappedTest.java |   8 +-
 .../internal/GridAffinityNoCacheSelfTest.java   | 290 +++++++++++++++
 .../internal/GridAffinityP2PSelfTest.java       |   8 +-
 .../ignite/internal/GridAffinitySelfTest.java   |   8 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |   4 +-
 .../cache/GridCacheAffinityRoutingSelfTest.java |  10 +-
 .../GridCacheConcurrentTxMultiNodeTest.java     |   4 +-
 .../GridCacheDaemonNodeAbstractSelfTest.java    |  17 +-
 .../cache/GridCacheDeploymentSelfTest.java      |   8 +-
 .../cache/GridCacheEntryMemorySizeSelfTest.java |   6 +-
 ...hePartitionedProjectionAffinitySelfTest.java |   8 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |   4 +-
 .../dht/GridCacheDhtMultiBackupTest.java        |   4 +-
 .../near/GridCacheNearOnlyTopologySelfTest.java |   4 +-
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |   4 +-
 ...titionedExplicitLockNodeFailureSelfTest.java |   6 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |  10 +-
 .../processors/igfs/IgfsStreamsSelfTest.java    |   4 +-
 .../ignite/loadtests/dsi/GridDsiClient.java     |   4 +-
 .../tcp/GridCacheDhtLockBackupSelfTest.java     |   4 +-
 .../testsuites/IgniteComputeGridTestSuite.java  |   4 +-
 .../cpp/common/project/vs/common.vcxproj        |   2 +-
 .../Apache.Ignite.Benchmarks.csproj             |   4 +-
 .../Apache.Ignite.Core.Tests.TestDll.csproj     |   4 +-
 .../Apache.Ignite.Core.Tests.csproj             |   2 +-
 .../Apache.Ignite.Core.csproj                   |   8 +-
 .../Apache.Ignite.Core.ruleset                  |  26 ++
 .../Binary/BinaryConfiguration.cs               |   3 +
 .../Binary/BinaryTypeConfiguration.cs           |   5 +
 .../Binary/BinaryTypeNames.cs                   |  64 ++--
 .../Cache/CachePartialUpdateException.cs        |   3 +
 .../Apache.Ignite.Core/Cache/CacheResult.cs     |  41 ++-
 .../Cache/Event/ICacheEntryEventFilter.cs       |   1 +
 .../Cache/Event/ICacheEntryEventListener.cs     |   1 +
 .../Cache/Query/Continuous/ContinuousQuery.cs   |   2 +-
 .../Apache.Ignite.Core/Cache/Query/QueryBase.cs |   2 +-
 .../Cache/Query/SqlFieldsQuery.cs               |   2 +-
 .../Apache.Ignite.Core/Cache/Query/SqlQuery.cs  |   6 +-
 .../Apache.Ignite.Core/Cache/Query/TextQuery.cs |   7 +-
 .../Cache/Store/CacheStoreAdapter.cs            |   4 +
 .../Compute/ComputeJobAdapter.cs                |   2 +-
 .../Compute/ComputeJobResultPolicy.cs           |   2 -
 .../Compute/ComputeTaskAdapter.cs               |   3 +
 .../Compute/ComputeTaskSplitAdapter.cs          |  18 +-
 .../Datastream/StreamTransformer.cs             |   2 +
 .../Datastream/StreamVisitor.cs                 |   2 +
 .../Apache.Ignite.Core/Events/CacheEvent.cs     |   8 +-
 .../Events/CacheQueryExecutedEvent.cs           |   4 +-
 .../Events/CacheQueryReadEvent.cs               |   6 +-
 .../Events/CacheRebalancingEvent.cs             |   4 +-
 .../Events/CheckpointEvent.cs                   |   4 +-
 .../Apache.Ignite.Core/Events/DiscoveryEvent.cs |   4 +-
 .../Apache.Ignite.Core/Events/EventBase.cs      |  70 +++-
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |   3 +-
 .../Apache.Ignite.Core/Impl/Binary/Binary.cs    |  47 +--
 .../Impl/Binary/BinaryFullTypeDescriptor.cs     |   2 +-
 .../Impl/Binary/BinaryObject.cs                 |  44 ++-
 .../Impl/Binary/BinaryObjectBuilder.cs          |  75 ++--
 .../Impl/Binary/BinaryReader.cs                 |   1 +
 .../Impl/Binary/BinaryReflectiveSerializer.cs   |   2 +-
 .../Impl/Binary/BinarySystemHandlers.cs         |   9 +-
 .../Impl/Binary/BinaryUtils.cs                  |   7 +-
 .../Impl/Binary/BinaryWriter.cs                 |   3 +
 .../Impl/Binary/Io/BinaryHeapStream.cs          |   9 +
 .../Impl/Binary/Marshaller.cs                   |  19 +-
 .../Impl/Binary/Metadata/BinaryType.cs          |   2 +
 .../Impl/Binary/SerializableObjectHolder.cs     |  13 +-
 .../Impl/Binary/Structure/BinaryStructure.cs    |   3 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |  42 ++-
 .../Impl/Cache/Query/AbstractQueryCursor.cs     |   4 +-
 .../Continuous/ContinuousQueryFilterHolder.cs   |   2 +-
 .../Continuous/ContinuousQueryHandleImpl.cs     |   4 +-
 .../Impl/Cache/Query/FieldsQueryCursor.cs       |   2 +
 .../Impl/Cache/Query/QueryCursor.cs             |   2 +
 .../Impl/Common/CancelledTask.cs                |   3 +
 .../Common/CopyOnWriteConcurrentDictionary.cs   |   1 +
 .../Impl/Common/DelegateConverter.cs            |  11 +-
 .../Apache.Ignite.Core/Impl/Common/Future.cs    |   2 +
 .../Impl/Common/LoadedAssembliesResolver.cs     |   1 +
 .../Closure/ComputeAbstractClosureTask.cs       |   3 +
 .../Compute/Closure/ComputeMultiClosureTask.cs  |   2 +
 .../Closure/ComputeReducingClosureTask.cs       |   2 +
 .../Compute/Closure/ComputeSingleClosureTask.cs |   2 +
 .../Impl/Datastream/DataStreamerBatch.cs        |   1 +
 .../Impl/Datastream/DataStreamerImpl.cs         |   5 +-
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs   |  56 +--
 .../Impl/Handle/HandleRegistry.cs               |   1 +
 .../Apache.Ignite.Core/Impl/IgniteUtils.cs      |  11 +-
 .../Impl/InteropExceptionHolder.cs              |  11 +-
 .../Memory/PlatformBigEndianMemoryStream.cs     |   8 +
 .../Impl/Memory/PlatformMemory.cs               |   2 +
 .../Impl/Memory/PlatformMemoryManager.cs        |   2 +
 .../Impl/Memory/PlatformMemoryStream.cs         |   2 +
 .../Impl/Memory/PlatformRawMemory.cs            |   2 +
 .../Apache.Ignite.Core/Impl/PlatformTarget.cs   |   3 +-
 .../Impl/Resource/ResourceProcessor.cs          |   2 +-
 .../Impl/Resource/ResourceTypeDescriptor.cs     |   2 +-
 .../Impl/Services/ServiceProxy.cs               |   2 +
 .../Impl/Services/ServiceProxyInvoker.cs        |   1 +
 .../Impl/Transactions/TransactionsImpl.cs       |   2 +
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |   5 +-
 .../Services/ServiceInvocationException.cs      |   2 +
 modules/platforms/dotnet/Apache.Ignite.FxCop    | 354 +++----------------
 modules/platforms/dotnet/Apache.Ignite.sln      |   4 +-
 .../Apache.Ignite.sln.TeamCity.DotSettings      |  30 ++
 .../dotnet/Apache.Ignite/Apache.Ignite.csproj   |   5 +-
 .../Apache.Ignite.Examples.csproj               |   4 +-
 .../Apache.Ignite.ExamplesDll.csproj            |   4 +-
 parent/pom.xml                                  |   3 +-
 124 files changed, 1816 insertions(+), 932 deletions(-)
----------------------------------------------------------------------