Merge remote-tracking branch 'remotes/origin/sql-store' into sql-store-cmp

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

Branch: refs/heads/sql-store-cmp
Commit: 9536656f1b57815f84eb4c2ddd59cd0b7a8c0db9
Parents: 6a6f5d1 c908509
Author: sboikov <sboi...@gridgain.com>
Authored: Thu Feb 4 17:36:30 2016 +0300
Committer: sboikov <sboi...@gridgain.com>
Committed: Thu Feb 4 17:36:30 2016 +0300

----------------------------------------------------------------------
 .gitignore                                      |    1 +
 .../examples/datagrid/CacheAffinityExample.java |    8 +-
 .../java8/datagrid/CacheAffinityExample.java    |    6 +-
 modules/benchmarks/pom.xml                      |   32 +-
 .../benchmarks/jmh/cache/PutBenchmark.java      |  170 --
 .../ignite/benchmarks/model/IntValue.java       |   91 --
 .../benchmarks/jmh/JmhAbstractBenchmark.java    |  150 ++
 .../jmh/cache/JmhCacheAbstractBenchmark.java    |  181 +++
 .../jmh/cache/JmhCachePutBenchmark.java         |  124 ++
 .../jmh/runner/JmhIdeBenchmarkRunner.java       |  232 +++
 .../internal/benchmarks/model/IntValue.java     |   91 ++
 .../internal/client/ClientGetAffinityTask.java  |    4 +-
 .../java/org/apache/ignite/IgniteCache.java     |   45 +-
 .../java/org/apache/ignite/IgniteCluster.java   |    7 +-
 .../ignite/binary/BinaryBasicIdMapper.java      |  167 ++
 .../ignite/binary/BinaryBasicNameMapper.java    |  141 ++
 .../apache/ignite/binary/BinaryIdMapper.java    |   19 +-
 .../apache/ignite/binary/BinaryNameMapper.java  |   47 +
 .../ignite/binary/BinaryTypeConfiguration.java  |   23 +-
 .../org/apache/ignite/cache/CacheEntry.java     |    9 +-
 .../apache/ignite/cache/CacheInterceptor.java   |    5 +
 .../apache/ignite/cache/affinity/Affinity.java  |   24 +-
 .../configuration/BinaryConfiguration.java      |   28 +
 .../configuration/IgniteConfiguration.java      |    8 +-
 .../ignite/internal/IgniteNodeAttributes.java   |    3 +
 .../org/apache/ignite/internal/IgnitionEx.java  |    7 +-
 .../internal/binary/BinaryClassDescriptor.java  |   29 +-
 .../ignite/internal/binary/BinaryContext.java   |  347 ++--
 .../internal/binary/BinaryEnumObjectImpl.java   |   13 +-
 .../internal/binary/BinaryFieldAccessor.java    |   45 +-
 .../internal/binary/BinaryInternalIdMapper.java |  161 --
 .../internal/binary/BinaryInternalMapper.java   |  131 ++
 .../internal/binary/BinaryMarshaller.java       |    5 +-
 .../binary/BinaryMetadataCollector.java         |   22 +-
 .../binary/BinaryObjectOffheapImpl.java         |   34 +-
 .../internal/binary/BinaryPrimitives.java       |  117 +-
 .../internal/binary/BinaryReaderExImpl.java     |   14 +-
 .../internal/binary/BinaryWriterExImpl.java     |   30 +-
 .../internal/binary/GridBinaryMarshaller.java   |   28 +-
 .../binary/builder/BinaryBuilderSerializer.java |   16 +-
 .../binary/builder/BinaryObjectBuilderImpl.java |    2 +-
 .../streams/BinaryAbstractInputStream.java      |   53 +-
 .../streams/BinaryAbstractOutputStream.java     |   90 +-
 .../binary/streams/BinaryAbstractStream.java    |   34 -
 .../binary/streams/BinaryHeapInputStream.java   |   43 +-
 .../binary/streams/BinaryHeapOutputStream.java  |   86 +-
 .../streams/BinaryMemoryAllocatorChunk.java     |    9 +-
 .../streams/BinaryOffheapInputStream.java       |   42 +-
 .../streams/BinaryOffheapOutputStream.java      |   94 +-
 .../internal/direct/DirectMessageReader.java    |    2 +-
 .../internal/direct/DirectMessageWriter.java    |    2 +-
 .../stream/v1/DirectByteBufferStreamImplV1.java |  106 +-
 .../stream/v2/DirectByteBufferStreamImplV2.java |  351 ++++-
 .../ignite/internal/jdbc/JdbcConnection.java    |   14 +-
 .../affinity/GridAffinityProcessor.java         |   60 +-
 .../processors/cache/CacheEntryImplEx.java      |   14 +-
 .../processors/cache/CacheMetricsSnapshot.java  |    4 +-
 .../processors/cache/CacheOperationContext.java |   43 +-
 .../processors/cache/GridCacheAdapter.java      |  483 ++++--
 .../cache/GridCacheAffinityManager.java         |   47 +-
 .../processors/cache/GridCacheContext.java      |   33 +-
 .../cache/GridCacheEvictionManager.java         |    7 +-
 .../processors/cache/GridCacheMapEntry.java     |    8 +-
 .../cache/GridCacheOffheapSwapEntry.java        |   24 +-
 .../processors/cache/GridCacheProcessor.java    |   43 +-
 .../processors/cache/GridCacheProxyImpl.java    |   62 +-
 .../cache/GridCacheSwapEntryImpl.java           |   61 +-
 .../processors/cache/GridCacheUtils.java        |   36 +-
 .../processors/cache/IgniteCacheProxy.java      |   94 +-
 .../processors/cache/IgniteInternalCache.java   |   85 +
 .../cache/affinity/GridCacheAffinityImpl.java   |   48 +-
 .../binary/CacheObjectBinaryProcessorImpl.java  |  127 +-
 .../dht/CacheDistributedGetFutureAdapter.java   |   15 -
 .../distributed/dht/GridDhtCacheAdapter.java    |    7 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |    6 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |    4 +-
 .../dht/GridPartitionedGetFuture.java           |   38 +-
 .../dht/GridPartitionedSingleGetFuture.java     |   17 +-
 .../dht/atomic/GridDhtAtomicCache.java          |  203 ++-
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |   10 +-
 .../dht/atomic/GridNearAtomicUpdateRequest.java |   22 +-
 .../dht/colocated/GridDhtColocatedCache.java    |   42 +-
 .../dht/preloader/GridDhtPartitionDemander.java |    4 +-
 .../distributed/near/GridNearAtomicCache.java   |    6 +-
 .../distributed/near/GridNearCacheAdapter.java  |    6 +-
 .../distributed/near/GridNearCacheEntry.java    |    3 +-
 .../distributed/near/GridNearGetFuture.java     |   45 +-
 ...arOptimisticSerializableTxPrepareFuture.java |    2 +-
 .../near/GridNearOptimisticTxPrepareFuture.java |    4 +
 .../GridNearPessimisticTxPrepareFuture.java     |    2 +
 .../near/GridNearTransactionalCache.java        |    9 +-
 .../near/GridNearTxFinishFuture.java            |   96 +-
 .../processors/cache/dr/GridCacheDrInfo.java    |   49 +-
 .../local/atomic/GridLocalAtomicCache.java      |  106 +-
 .../continuous/CacheContinuousQueryHandler.java |    9 +
 .../cache/transactions/IgniteTxEntry.java       |   32 +-
 .../transactions/IgniteTxLocalAdapter.java      |  277 +++-
 .../cache/transactions/IgniteTxLocalEx.java     |    3 +-
 .../cache/transactions/IgniteTxManager.java     |    4 +-
 .../cache/version/GridCacheVersionManager.java  |   23 +-
 .../IgniteCacheObjectProcessorImpl.java         |    7 +-
 .../processors/platform/PlatformIgnition.java   |    6 +-
 .../platform/PlatformNoopProcessor.java         |   15 +
 .../processors/platform/PlatformProcessor.java  |   25 +
 .../platform/PlatformProcessorImpl.java         |   34 +-
 .../platform/cache/PlatformCache.java           |   16 +-
 .../cpp/PlatformCppConfigurationClosure.java    |   32 +
 .../dotnet/PlatformDotNetCacheStore.java        |   39 +-
 .../PlatformDotNetConfigurationClosure.java     |   80 +-
 .../platform/memory/PlatformAbstractMemory.java |    6 +-
 .../PlatformBigEndianOutputStreamImpl.java      |   14 +-
 .../memory/PlatformInputStreamImpl.java         |   53 +-
 .../platform/memory/PlatformMemoryUtils.java    |  108 +-
 .../memory/PlatformOutputStreamImpl.java        |   58 +-
 .../utils/PlatformConfigurationUtils.java       |  621 ++++++++
 .../platform/utils/PlatformUtils.java           |   52 +-
 .../processors/service/ServiceContextImpl.java  |    4 +-
 .../processors/task/GridTaskProcessor.java      |    2 +-
 .../ignite/internal/util/GridHandleTable.java   |   17 +-
 .../ignite/internal/util/GridJavaProcess.java   |    3 -
 .../internal/util/GridSpinReadWriteLock.java    |   10 +-
 .../apache/ignite/internal/util/GridUnsafe.java | 1483 +++++++++++++++++-
 .../ignite/internal/util/IgniteUtils.java       |  106 +-
 .../internal/util/io/GridUnsafeDataInput.java   |  145 +-
 .../internal/util/io/GridUnsafeDataOutput.java  |  165 +-
 .../util/offheap/unsafe/GridUnsafeMap.java      |   75 +-
 .../util/offheap/unsafe/GridUnsafeMemory.java   |  106 +-
 .../optimized/OptimizedClassDescriptor.java     |   22 +-
 .../optimized/OptimizedMarshaller.java          |    5 +-
 .../optimized/OptimizedMarshallerUtils.java     |   44 +-
 .../optimized/OptimizedObjectInputStream.java   |   10 +-
 .../OptimizedObjectStreamRegistry.java          |    4 +-
 .../PlatformDotNetCacheStoreFactoryNative.java  |   58 +
 .../ignite/spi/discovery/tcp/ClientImpl.java    |    6 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |   11 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |    1 -
 .../TcpDiscoveryMulticastIpFinder.java          |   12 +-
 .../TcpDiscoveryCustomEventMessage.java         |   10 +-
 .../java/org/apache/ignite/GridTestIoUtils.java |  117 +-
 .../ignite/internal/GridAffinityMappedTest.java |    8 +-
 .../internal/GridAffinityNoCacheSelfTest.java   |  300 ++++
 .../internal/GridAffinityP2PSelfTest.java       |    8 +-
 .../ignite/internal/GridAffinitySelfTest.java   |   10 +-
 .../binary/BinaryBasicIdMapperSelfTest.java     |   51 +
 .../binary/BinaryBasicNameMapperSelfTest.java   |   50 +
 .../BinaryConfigurationConsistencySelfTest.java |  231 +++
 .../internal/binary/BinaryEnumsSelfTest.java    |   12 +-
 .../binary/BinaryFieldsOffheapSelfTest.java     |   13 +-
 .../BinaryFooterOffsetsOffheapSelfTest.java     |   13 +-
 .../binary/BinaryMarshallerSelfTest.java        |  525 ++++++-
 .../BinaryObjectBuilderAdditionalSelfTest.java  |    4 +-
 ...naryObjectBuilderDefaultMappersSelfTest.java | 1149 ++++++++++++++
 .../binary/BinaryObjectBuilderSelfTest.java     | 1108 -------------
 ...ilderSimpleNameLowerCaseMappersSelfTest.java |   41 +
 .../BinarySimpleNameTestPropertySelfTest.java   |   94 ++
 .../binary/GridBinaryMetaDataSelfTest.java      |  371 -----
 .../binary/GridBinaryWildcardsSelfTest.java     |  338 +++-
 ...aultBinaryMappersBinaryMetaDataSelfTest.java |  389 +++++
 ...CaseBinaryMappersBinaryMetaDataSelfTest.java |   41 +
 .../internal/binary/TestMappedObject.java       |   25 +
 .../mutabletest/GridBinaryTestClasses.java      |    3 +-
 ...BuilderNonCompactDefaultMappersSelfTest.java |   30 +
 .../BinaryObjectBuilderNonCompactSelfTest.java  |   30 -
 ...mpactSimpleNameLowerCaseMappersSelfTest.java |   31 +
 .../AbstractBinaryStreamByteOrderSelfTest.java  |  464 ++++++
 .../BinaryHeapStreamByteOrderSelfTest.java      |   29 +
 .../BinaryOffheapStreamByteOrderSelfTest.java   |   31 +
 ...ByteBufferStreamImplV2ByteOrderSelfTest.java |  244 +++
 .../cache/CacheGetEntryAbstractTest.java        |  803 ++++++++++
 ...GetEntryOptimisticReadCommittedSeltTest.java |   36 +
 ...etEntryOptimisticRepeatableReadSeltTest.java |   36 +
 ...eGetEntryOptimisticSerializableSeltTest.java |   36 +
 ...etEntryPessimisticReadCommittedSeltTest.java |   36 +
 ...tEntryPessimisticRepeatableReadSeltTest.java |   36 +
 ...GetEntryPessimisticSerializableSeltTest.java |   36 +
 .../cache/CacheReadThroughRestartSelfTest.java  |   43 +-
 .../CacheSerializableTransactionsTest.java      |  142 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |  145 +-
 .../cache/GridCacheAffinityRoutingSelfTest.java |   10 +-
 .../cache/GridCacheConcurrentMapSelfTest.java   |   13 +-
 .../GridCacheConcurrentTxMultiNodeTest.java     |    4 +-
 .../GridCacheConditionalDeploymentSelfTest.java |    4 +-
 .../GridCacheDaemonNodeAbstractSelfTest.java    |   17 +-
 .../GridCacheDeploymentOffHeapSelfTest.java     |    4 +-
 ...ridCacheDeploymentOffHeapValuesSelfTest.java |   41 +
 .../cache/GridCacheDeploymentSelfTest.java      |    8 +-
 .../cache/GridCacheEntryMemorySizeSelfTest.java |    6 +-
 .../GridCacheInterceptorAbstractSelfTest.java   |  172 +-
 ...hePartitionedProjectionAffinitySelfTest.java |    8 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |    4 +-
 .../cache/GridCacheUtilsSelfTest.java           |  136 +-
 .../GridCacheBinaryObjectsAbstractSelfTest.java |   17 +-
 .../GridCacheBinaryStoreAbstractSelfTest.java   |   10 +
 ...naryStoreBinariesDefaultMappersSelfTest.java |   81 +
 .../GridCacheBinaryStoreBinariesSelfTest.java   |   66 -
 ...yStoreBinariesSimpleNameMappersSelfTest.java |   40 +
 ...GridCacheDhtEvictionNearReadersSelfTest.java |    2 +-
 .../dht/GridCacheDhtMultiBackupTest.java        |    4 +-
 .../near/GridCacheNearOnlyTopologySelfTest.java |    4 +-
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |    4 +-
 ...titionedExplicitLockNodeFailureSelfTest.java |    6 +-
 .../GridCacheRebalancingSyncSelfTest.java       |    8 +
 .../GridCacheReplicatedPreloadSelfTest.java     |  108 ++
 .../RandomEvictionPolicyCacheSizeSelfTest.java  |   79 -
 .../random/RandomEvictionPolicySelfTest.java    |  363 -----
 ...ContinuousQueryFailoverAbstractSelfTest.java |    6 +
 ...ridCacheContinuousQueryAbstractSelfTest.java |   10 +-
 ...ntinuousQueryPartitionAtomicOneNodeTest.java |   37 +
 ...heContinuousQueryPartitionTxOneNodeTest.java |   37 +
 ...tinuousQueryReplicatedAtomicOneNodeTest.java |   31 +
 ...ontinuousQueryReplicatedOneNodeSelfTest.java |  120 --
 ...eContinuousQueryReplicatedTxOneNodeTest.java |  193 +++
 .../processors/igfs/IgfsStreamsSelfTest.java    |    4 +-
 .../GridServicePackagePrivateSelfTest.java      |   51 +
 .../processors/service/inner/MyService.java     |   30 +
 .../service/inner/MyServiceFactory.java         |   30 +
 .../processors/service/inner/MyServiceImpl.java |   45 +
 ...dUnsafeDataInputOutputByteOrderSelfTest.java |  249 +++
 .../ignite/lang/GridBasicPerformanceTest.java   |   11 +-
 .../ignite/loadtests/dsi/GridDsiClient.java     |    4 +-
 .../tcp/GridCacheDhtLockBackupSelfTest.java     |    4 +-
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java |    5 +-
 .../config/GridTestProperties.java              |    5 +-
 .../testframework/junits/GridAbstractTest.java  |   30 +-
 .../multijvm/IgniteCacheProcessProxy.java       |   59 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |    2 +-
 .../testsuites/IgniteBinaryBasicTestSuite.java  |   95 ++
 ...ctsSimpleNameMapperComputeGridTestSuite.java |   38 +
 .../IgniteBinaryObjectsTestSuite.java           |   40 +-
 ...iteBinarySimpleNameMapperBasicTestSuite.java |   38 +
 ...rySimpleNameMapperCacheFullApiTestSuite.java |   39 +
 .../IgniteCacheEvictionSelfTestSuite.java       |    4 -
 .../testsuites/IgniteCacheTestSuite3.java       |    2 +
 .../testsuites/IgniteCacheTestSuite4.java       |   12 +
 .../testsuites/IgniteComputeGridTestSuite.java  |    4 +-
 .../testsuites/IgniteKernalSelfTestSuite.java   |    4 +-
 .../IgniteMarshallerSelfTestSuite.java          |    4 +
 modules/docker/1.5.0.final/Dockerfile           |   40 +
 modules/docker/1.5.0.final/run.sh               |   50 +
 modules/docker/Dockerfile                       |    6 +-
 .../tests/p2p/CacheDeploymentTestEnumValue.java |   47 +
 .../p2p/CacheDeploymentTestStoreFactory.java    |  113 ++
 .../hadoop/shuffle/HadoopShuffleJob.java        |    5 +-
 .../hadoop/shuffle/HadoopShuffleMessage.java    |   10 +-
 .../shuffle/streams/HadoopDataOutStream.java    |    6 +-
 .../HadoopConcurrentHashMultimapSelftest.java   |    6 +-
 .../collections/HadoopSkipListSelfTest.java     |    5 +-
 .../query/h2/opt/GridH2IndexBase.java           |    5 +-
 .../query/h2/opt/GridH2TreeIndex.java           |    2 +-
 .../IgniteBinaryCacheQueryTestSuite.java        |  186 +--
 ...narySimpleNameMapperCacheQueryTestSuite.java |   38 +
 .../IgniteCacheQuerySelfTestSuite.java          |   10 +-
 modules/kafka/README.txt                        |  111 +-
 modules/kafka/pom.xml                           |   69 +-
 .../ignite/stream/kafka/KafkaStreamer.java      |    2 +-
 .../kafka/connect/IgniteSinkConnector.java      |   91 ++
 .../kafka/connect/IgniteSinkConstants.java      |   38 +
 .../stream/kafka/connect/IgniteSinkTask.java    |  165 ++
 .../kafka/IgniteKafkaStreamerSelfTestSuite.java |    9 +-
 .../stream/kafka/KafkaEmbeddedBroker.java       |  387 -----
 .../kafka/KafkaIgniteStreamerSelfTest.java      |   13 +-
 .../ignite/stream/kafka/SimplePartitioner.java  |   53 -
 .../ignite/stream/kafka/TestKafkaBroker.java    |  237 +++
 .../kafka/connect/IgniteSinkConnectorTest.java  |  250 +++
 .../kafka/src/test/resources/example-ignite.xml |   71 +
 .../cpp/common/include/ignite/common/exports.h  |    3 +
 .../cpp/common/include/ignite/common/java.h     |    9 +
 .../cpp/common/project/vs/common.vcxproj        |    2 +-
 .../platforms/cpp/common/project/vs/module.def  |    5 +-
 modules/platforms/cpp/common/src/exports.cpp    |   12 +
 modules/platforms/cpp/common/src/java.cpp       |   44 +
 .../Apache.Ignite.Benchmarks.csproj             |    4 +-
 .../Apache.Ignite.Core.Tests.TestDll.csproj     |    4 +-
 .../Apache.Ignite.Core.Tests.csproj             |    5 +-
 .../Binary/BinarySelfTest.cs                    |    9 +
 .../Cache/CacheAbstractTest.cs                  |    2 +-
 .../Cache/CacheAffinityTest.cs                  |    2 +-
 .../Cache/CacheConfigurationTest.cs             |  538 +++++++
 .../Cache/CacheDynamicStartTest.cs              |    4 +-
 .../Cache/CacheTestAsyncWrapper.cs              |    7 +
 .../Query/CacheQueriesCodeConfigurationTest.cs  |  295 ++++
 .../Cache/Query/CacheQueriesTest.cs             |    2 +-
 .../Continuous/ContinuousQueryAbstractTest.cs   |    2 +-
 .../Cache/Store/CacheStoreSessionTest.cs        |    2 +-
 .../Cache/Store/CacheStoreTest.cs               |   23 +-
 .../Config/Compute/compute-grid2.xml            |   21 +
 .../Config/Compute/compute-grid3.xml            |   31 +-
 .../Dataload/DataStreamerTest.cs                |    4 +-
 .../Apache.Ignite.Core.Tests/ExceptionsTest.cs  |    2 +-
 .../IgniteConfigurationTest.cs                  |  367 +++++
 .../Apache.Ignite.Core.Tests/MarshallerTest.cs  |    4 +-
 .../SerializationTest.cs                        |    2 +-
 .../Apache.Ignite.Core.Tests/TestRunner.cs      |    5 +-
 .../Apache.Ignite.Core.csproj                   |   37 +-
 .../Apache.Ignite.Core.ruleset                  |   26 +
 .../Binary/BinaryConfiguration.cs               |   30 +-
 .../Binary/BinaryTypeConfiguration.cs           |    5 +
 .../Binary/BinaryTypeNames.cs                   |   64 +-
 .../Cache/CachePartialUpdateException.cs        |    3 +
 .../Apache.Ignite.Core/Cache/CacheResult.cs     |   41 +-
 .../Configuration/CacheAtomicWriteOrderMode.cs  |   43 +
 .../Cache/Configuration/CacheAtomicityMode.cs   |   54 +
 .../Cache/Configuration/CacheConfiguration.cs   |  601 +++++++
 .../Cache/Configuration/CacheMemoryMode.cs      |   60 +
 .../Cache/Configuration/CacheMode.cs            |   52 +
 .../Cache/Configuration/CacheRebalanceMode.cs   |   51 +
 .../CacheWriteSynchronizationMode.cs            |   45 +
 .../Cache/Configuration/QueryAlias.cs           |   59 +
 .../Cache/Configuration/QueryEntity.cs          |  401 +++++
 .../Cache/Configuration/QueryField.cs           |  109 ++
 .../Cache/Configuration/QueryIndex.cs           |  137 ++
 .../Cache/Configuration/QueryIndexField.cs      |   66 +
 .../Cache/Configuration/QueryIndexType.cs       |   40 +
 .../Configuration/QuerySqlFieldAttribute.cs     |   60 +
 .../Configuration/QueryTextFieldAttribute.cs    |   36 +
 .../Cache/Event/ICacheEntryEventFilter.cs       |    1 +
 .../Cache/Event/ICacheEntryEventListener.cs     |    1 +
 .../dotnet/Apache.Ignite.Core/Cache/ICache.cs   |    6 +
 .../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 +
 .../Apache.Ignite.Core/Common/IFactory.cs       |   34 +
 .../Compute/ComputeJobAdapter.cs                |    2 +-
 .../Compute/ComputeJobResultPolicy.cs           |    2 -
 .../Compute/ComputeTaskAdapter.cs               |    3 +
 .../Compute/ComputeTaskSplitAdapter.cs          |   18 +-
 .../Datastream/StreamTransformer.cs             |    2 +
 .../Datastream/StreamVisitor.cs                 |    2 +
 .../Discovery/IDiscoverySpi.cs                  |   32 +
 .../Discovery/Tcp/ITcpDiscoveryIpFinder.cs      |   34 +
 .../Multicast/TcpDiscoveryMulticastIpFinder.cs  |  133 ++
 .../Tcp/Static/TcpDiscoveryStaticIpFinder.cs    |   84 +
 .../Discovery/Tcp/TcpDiscoveryIpFinderBase.cs   |   78 +
 .../Discovery/Tcp/TcpDiscoverySpi.cs            |  144 ++
 .../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/IIgnite.cs        |   29 +-
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |  347 +++-
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |   30 +-
 .../Apache.Ignite.Core/Impl/Binary/Binary.cs    |   50 +-
 .../Impl/Binary/BinaryFullTypeDescriptor.cs     |    2 +-
 .../Impl/Binary/BinaryObject.cs                 |   44 +-
 .../Impl/Binary/BinaryObjectBuilder.cs          |   75 +-
 .../Impl/Binary/BinaryReader.cs                 |    1 +
 .../Impl/Binary/BinaryReaderExtensions.cs       |   19 +
 .../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 +
 .../Apache.Ignite.Core/Impl/Binary/JavaTypes.cs |   92 ++
 .../Impl/Binary/Marshaller.cs                   |   27 +-
 .../Impl/Binary/Metadata/BinaryType.cs          |    2 +
 .../Impl/Binary/SerializableObjectHolder.cs     |   13 +-
 .../Impl/Binary/Structure/BinaryStructure.cs    |    3 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |   51 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheOp.cs    |    3 +-
 .../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/Cache/Store/CacheStore.cs              |   20 +-
 .../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 +
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs    |   48 +
 .../Impl/IgniteConfigurationEx.cs               |   57 -
 .../Apache.Ignite.Core/Impl/IgniteManager.cs    |    5 +-
 .../Apache.Ignite.Core/Impl/IgniteProxy.cs      |   18 +-
 .../Apache.Ignite.Core/Impl/IgniteUtils.cs      |   13 +-
 .../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            |    4 +-
 .../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       |    4 +-
 .../Impl/Unmanaged/IgniteJniNativeMethods.cs    |   11 +-
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |    5 +-
 .../Impl/Unmanaged/UnmanagedUtils.cs            |   22 +-
 .../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 +-
 .../visor/commands/node/VisorNodeCommand.scala  |    1 +
 .../commands/top/VisorTopologyCommand.scala     |    5 +-
 .../scala/org/apache/ignite/visor/visor.scala   |    3 +-
 .../config/benchmark-multicast.properties       |    7 +
 .../org/apache/ignite/yardstick/IgniteNode.java |    3 +
 .../IgniteGetEntriesPutAllTxBenchmark.java      |   73 +
 .../cache/IgnitePutGetEntryBenchmark.java       |   47 +
 .../cache/IgnitePutGetEntryTxBenchmark.java     |   73 +
 .../apache/ignite/yarn/ApplicationMaster.java   |   12 +-
 .../apache/ignite/yarn/ClusterProperties.java   |  144 +-
 .../yarn/IgniteApplicationMasterSelfTest.java   |   52 +
 parent/pom.xml                                  |  124 +-
 pom.xml                                         |   16 -
 424 files changed, 20619 insertions(+), 6564 deletions(-)
----------------------------------------------------------------------


Reply via email to