You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by vo...@apache.org on 2015/10/23 10:48:14 UTC

[48/50] [abbrv] ignite git commit: Merge branch 'ignite-1282' into ignite-1655

Merge branch 'ignite-1282' into ignite-1655

Conflicts:
	modules/core/src/main/java/org/apache/ignite/internal/portable/PortableReaderExImpl.java
	modules/platforms/dotnet/Apache.Ignite.Core/Impl/Portable/PortableSystemHandlers.cs


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

Branch: refs/heads/ignite-1655
Commit: 9feec400176103b41385b6d6b799d29dcd131f69
Parents: 4f504d2 f65a53e
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Fri Oct 23 11:25:26 2015 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Fri Oct 23 11:25:26 2015 +0300

----------------------------------------------------------------------
 DEVNOTES.txt                                    |    3 +-
 RELEASE_NOTES.txt                               |    2 +
 assembly/dependencies-fabric.xml                |    2 +-
 assembly/dependencies-hadoop.xml                |    1 +
 assembly/release-fabric-lgpl.xml                |   63 +
 assembly/release-fabric.xml                     |   10 +-
 assembly/release-hadoop-lgpl.xml                |   39 +
 bin/igniterouter.bat                            |    2 +-
 bin/igniterouter.sh                             |    2 +-
 examples-lgpl/README.txt                        |   27 +
 examples-lgpl/config/example-cache.xml          |   73 +
 examples-lgpl/config/example-ignite.xml         |   83 ++
 examples-lgpl/config/hibernate/README.txt       |    8 +
 .../hibernate/example-hibernate-L2-cache.xml    |   64 +
 examples-lgpl/pom-standalone.xml                |  186 +++
 examples-lgpl/pom.xml                           |  128 ++
 .../hibernate/HibernateL2CacheExample.java      |  245 ++++
 .../examples/datagrid/hibernate/Post.java       |  130 ++
 .../examples/datagrid/hibernate/User.java       |  154 ++
 .../datagrid/hibernate/package-info.java        |   22 +
 .../hibernate/CacheHibernatePersonStore.java    |  122 ++
 .../hibernate/CacheHibernateStoreExample.java   |  151 ++
 .../datagrid/store/hibernate/Person.hbm.xml     |   34 +
 .../datagrid/store/hibernate/hibernate.cfg.xml  |   41 +
 .../datagrid/store/hibernate/package-info.java  |   22 +
 .../misc/schedule/ComputeScheduleExample.java   |   82 ++
 .../examples/misc/schedule/package-info.java    |   22 +
 .../misc/schedule/ComputeScheduleExample.java   |   68 +
 .../java8/misc/schedule/package-info.java       |   22 +
 .../ignite/examples/java8/package-info.java     |   23 +
 .../scalar/examples/ScalarScheduleExample.scala |   66 +
 ...ibernateL2CacheExampleMultiNodeSelfTest.java |   31 +
 .../HibernateL2CacheExampleSelfTest.java        |   33 +
 .../IgniteLgplExamplesSelfTestSuite.java        |   48 +
 ...ibernateL2CacheExampleMultiNodeSelfTest.java |   29 +
 .../HibernateL2CacheExampleSelfTest.java        |   37 +
 .../IgniteLgplExamplesJ8SelfTestSuite.java      |   46 +
 .../ScalarLgplExamplesMultiNodeSelfTest.scala   |   33 +
 .../examples/ScalarLgplExamplesSelfTest.scala   |   36 +
 .../ScalarLgplExamplesSelfTestSuite.scala       |   37 +
 examples/config/hibernate/README.txt            |    8 -
 .../hibernate/example-hibernate-L2-cache.xml    |   64 -
 examples/pom-standalone.xml                     |   12 -
 examples/pom.xml                                |   12 -
 examples/schema-import/pom-standalone.xml       |   90 ++
 examples/schema-import/pom.xml                  |   23 +-
 .../computegrid/ComputeClosureExample.java      |    2 +-
 .../hibernate/HibernateL2CacheExample.java      |  245 ----
 .../examples/datagrid/hibernate/Post.java       |  130 --
 .../examples/datagrid/hibernate/User.java       |  154 --
 .../datagrid/hibernate/package-info.java        |   22 -
 .../hibernate/CacheHibernatePersonStore.java    |  122 --
 .../hibernate/CacheHibernateStoreExample.java   |  151 --
 .../datagrid/store/hibernate/Person.hbm.xml     |   34 -
 .../datagrid/store/hibernate/hibernate.cfg.xml  |   41 -
 .../datagrid/store/hibernate/package-info.java  |   22 -
 .../misc/schedule/ComputeScheduleExample.java   |   82 --
 .../examples/misc/schedule/package-info.java    |   22 -
 .../misc/schedule/ComputeScheduleExample.java   |   68 -
 .../java8/misc/schedule/package-info.java       |   22 -
 .../scalar/examples/ScalarScheduleExample.scala |   66 -
 ...ibernateL2CacheExampleMultiNodeSelfTest.java |   31 -
 .../HibernateL2CacheExampleSelfTest.java        |   33 -
 .../testsuites/IgniteExamplesSelfTestSuite.java |    4 -
 ...ibernateL2CacheExampleMultiNodeSelfTest.java |   29 -
 .../HibernateL2CacheExampleSelfTest.java        |   37 -
 .../tests/examples/ScalarExamplesSelfTest.scala |    5 -
 modules/apache-license-gen/README.txt           |   33 +
 modules/apache-license-gen/pom.xml              |    3 +
 .../JettyRestProcessorAbstractSelfTest.java     |  252 +++-
 .../TcpDiscoveryCloudIpFinderSelfTest.java      |    2 +
 .../org/apache/ignite/IgniteAtomicLong.java     |    2 +-
 .../org/apache/ignite/IgniteFileSystem.java     |    4 +-
 .../apache/ignite/IgniteSystemProperties.java   |    3 +
 .../org/apache/ignite/IgniteTransactions.java   |    4 -
 .../configuration/CacheConfiguration.java       |    9 +-
 .../java/org/apache/ignite/igfs/IgfsPath.java   |    2 +-
 .../apache/ignite/internal/IgniteKernal.java    |   75 +-
 .../managers/discovery/CustomEventListener.java |    4 +-
 .../discovery/GridDiscoveryManager.java         |   91 +-
 .../portable/GridPortableMarshaller.java        |   18 +-
 .../portable/PortableClassDescriptor.java       |    1 +
 .../internal/portable/PortableContext.java      |   19 +-
 .../internal/portable/PortableObjectImpl.java   |    4 +-
 .../portable/PortableObjectOffheapImpl.java     |    4 +-
 .../internal/portable/PortableReaderExImpl.java |   41 +
 .../ignite/internal/portable/PortableUtils.java |   23 +-
 .../portable/builder/PortableBuilderImpl.java   |    7 +
 .../portable/builder/PortableBuilderReader.java |    8 +
 .../cache/DynamicCacheChangeRequest.java        |   19 +
 .../cache/DynamicCacheDescriptor.java           |   46 +-
 .../processors/cache/GridCacheAdapter.java      |  357 +++--
 .../cache/GridCacheClearAllRunnable.java        |   18 +-
 .../cache/GridCacheConcurrentMap.java           |    4 +-
 .../processors/cache/GridCacheContext.java      |    2 +-
 .../processors/cache/GridCacheEventManager.java |   12 +-
 .../cache/GridCacheExplicitLockSpan.java        |   13 +-
 .../processors/cache/GridCacheIoManager.java    |  105 +-
 .../processors/cache/GridCacheMessage.java      |    7 -
 .../cache/GridCacheMvccCandidate.java           |    5 +-
 .../processors/cache/GridCacheMvccManager.java  |   67 +-
 .../GridCachePartitionExchangeManager.java      |   98 +-
 .../processors/cache/GridCacheProcessor.java    |  157 +-
 .../processors/cache/GridCacheProxyImpl.java    |   14 +-
 .../cache/GridCacheSharedContext.java           |   32 -
 .../processors/cache/GridCacheUtils.java        |    8 -
 .../processors/cache/IgniteCacheProxy.java      |    6 +-
 .../processors/cache/IgniteInternalCache.java   |   19 +-
 .../distributed/GridDistributedCacheEntry.java  |    2 +-
 .../dht/GridClientPartitionTopology.java        |   13 +-
 .../dht/GridDhtAffinityAssignmentRequest.java   |    5 -
 .../dht/GridDhtAffinityAssignmentResponse.java  |    5 -
 .../distributed/dht/GridDhtCacheAdapter.java    |    6 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |    4 +-
 .../distributed/dht/GridDhtLocalPartition.java  |    3 +-
 .../distributed/dht/GridDhtLockRequest.java     |   10 +-
 .../dht/GridDhtPartitionTopologyImpl.java       |   12 +-
 .../distributed/dht/GridDhtTxFinishRequest.java |    5 -
 .../distributed/dht/GridDhtTxPrepareFuture.java |    6 +-
 .../dht/GridDhtTxPrepareRequest.java            |    7 +-
 .../dht/GridPartitionedGetFuture.java           |    5 +-
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |    5 +
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |   17 +-
 .../dht/colocated/GridDhtColocatedCache.java    |   12 +-
 .../colocated/GridDhtColocatedLockFuture.java   |   27 +-
 .../dht/preloader/GridDhtForceKeysRequest.java  |    5 -
 .../dht/preloader/GridDhtForceKeysResponse.java |    5 -
 .../GridDhtPartitionDemandMessage.java          |    9 +-
 .../GridDhtPartitionSupplyMessage.java          |    8 +-
 .../GridDhtPartitionsAbstractMessage.java       |    5 -
 .../GridDhtPartitionsExchangeFuture.java        |   12 +-
 .../preloader/GridDhtPartitionsFullMessage.java |   12 +-
 .../GridDhtPartitionsSingleMessage.java         |   11 +-
 .../dht/preloader/GridDhtPreloader.java         |   26 +-
 .../distributed/near/GridNearCacheAdapter.java  |   21 +-
 .../near/GridNearCacheClearAllRunnable.java     |    9 +-
 .../distributed/near/GridNearGetFuture.java     |    2 +
 .../distributed/near/GridNearLockFuture.java    |   11 +-
 .../near/GridNearOptimisticTxPrepareFuture.java |   24 +-
 .../near/GridNearTxFinishFuture.java            |    4 +-
 .../cache/distributed/near/GridNearTxLocal.java |   21 +-
 .../cache/local/GridLocalCacheEntry.java        |    2 +-
 .../cache/query/GridCacheQueryManager.java      |   33 +-
 .../cache/query/GridCacheSqlIndexMetadata.java  |    7 +-
 .../cache/query/GridCacheSqlMetadata.java       |   22 +-
 .../continuous/CacheContinuousQueryHandler.java |   10 +-
 .../continuous/CacheContinuousQueryManager.java |   66 +-
 .../transactions/IgniteTxLocalAdapter.java      |   35 +-
 .../continuous/GridContinuousProcessor.java     |   20 +-
 .../datastructures/DataStructuresProcessor.java |   54 +-
 .../processors/igfs/IgfsDataManager.java        |    2 -
 .../processors/igfs/IgfsDeleteWorker.java       |  102 +-
 .../internal/processors/igfs/IgfsFileInfo.java  |   15 +-
 .../internal/processors/igfs/IgfsImpl.java      |  372 +----
 .../processors/igfs/IgfsMetaManager.java        | 1255 ++++++++++++----
 .../processors/igfs/IgfsOutputStreamImpl.java   |    2 +
 .../internal/processors/igfs/IgfsUtils.java     |   23 +
 .../cache/affinity/PlatformAffinity.java        |    5 +-
 .../processors/rest/GridRestCommand.java        |    8 +-
 .../processors/rest/GridRestProcessor.java      |  364 ++++-
 .../handlers/cache/GridCacheCommandHandler.java |  364 ++---
 .../handlers/query/QueryCommandHandler.java     |  195 ++-
 .../top/GridTopologyCommandHandler.java         |   31 +-
 .../rest/request/RestQueryRequest.java          |  175 +++
 .../rest/request/RestSqlQueryRequest.java       |  125 --
 .../ignite/internal/util/GridArgumentCheck.java |    5 +-
 .../ignite/internal/util/GridJavaProcess.java   |   12 +-
 .../ignite/internal/util/IgniteUtils.java       |    2 +-
 .../ignite/internal/util/lang/GridFunc.java     |   12 +
 .../util/nio/GridNioRecoveryDescriptor.java     |    4 +-
 .../apache/ignite/marshaller/Marshaller.java    |    2 +-
 .../optimized/OptimizedMarshallerUtils.java     |    6 +-
 .../marshaller/portable/PortableMarshaller.java |   40 +-
 .../org/apache/ignite/mxbean/IgniteMXBean.java  |    8 +-
 .../portable/PortableProtocolVersion.java       |   41 -
 .../communication/tcp/TcpCommunicationSpi.java  |   29 +-
 .../ignite/spi/deployment/DeploymentSpi.java    |    8 +-
 .../discovery/DiscoverySpiCustomMessage.java    |   12 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |  398 +++--
 .../spi/discovery/tcp/TcpDiscoveryImpl.java     |    6 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |    2 +-
 .../tcp/internal/TcpDiscoveryNodesRing.java     |   94 +-
 .../messages/TcpDiscoveryDiscardMessage.java    |   15 +-
 .../TcpDiscoveryNodeAddFinishedMessage.java     |    2 +-
 .../messages/TcpDiscoveryNodeAddedMessage.java  |   19 +-
 .../resources/META-INF/classnames.properties    |    1 -
 modules/core/src/test/config/tests.properties   |    3 +
 .../ignite/igfs/IgfsEventsAbstractSelfTest.java |    6 +-
 .../ignite/igfs/IgfsFragmentizerSelfTest.java   |    2 +-
 .../internal/GridUpdateNotifierSelfTest.java    |    1 +
 .../IgniteClientReconnectAbstractTest.java      |   35 +-
 .../IgniteClientReconnectCacheTest.java         |  154 ++
 .../GridDiscoveryManagerAliveCacheSelfTest.java |    2 +
 .../GridDiscoveryManagerAttributesSelfTest.java |   50 -
 .../GridPortableMarshallerSelfTest.java         |   15 +-
 .../cache/CacheAffinityCallSelfTest.java        |    4 +-
 .../processors/cache/CrossCacheLockTest.java    |  142 ++
 .../GridCacheAbstractFailoverSelfTest.java      |    3 +
 .../cache/GridCacheAbstractFullApiSelfTest.java |  486 ++++---
 .../GridCacheAbstractRemoveFailureTest.java     |    9 +-
 .../cache/GridCacheClearSelfTest.java           |  308 ++++
 .../GridCacheDeploymentOffHeapSelfTest.java     |   15 +
 .../GridCacheFinishPartitionsSelfTest.java      |    5 +-
 .../GridCacheVariableTopologySelfTest.java      |    3 +-
 ...IgniteCacheAtomicPutAllFailoverSelfTest.java |    4 +
 .../IgniteCacheConfigurationTemplateTest.java   |   31 +
 .../cache/IgniteCacheCreateRestartSelfTest.java |    3 +
 .../cache/IgniteCacheEntryListenerTxTest.java   |    4 +
 .../IgniteCacheP2pUnmarshallingErrorTest.java   |    7 +
 ...CacheP2pUnmarshallingRebalanceErrorTest.java |   12 +-
 .../cache/IgniteCachePutAllRestartTest.java     |    4 +-
 .../cache/IgniteDynamicCacheFilterTest.java     |  150 ++
 .../IgniteTxExceptionAbstractSelfTest.java      |    3 +
 ...omicOffheapQueueCreateMultiNodeSelfTest.java |    5 -
 ...ionedAtomicQueueCreateMultiNodeSelfTest.java |    9 +-
 ...artitionedOffHeapValuesQueueApiSelfTest.java |    4 +
 ...PartitionedQueueCreateMultiNodeSelfTest.java |   16 +-
 ...nedQueueFailoverDataConsistencySelfTest.java |    5 -
 ...GridCachePartitionedSetFailoverSelfTest.java |    4 +
 .../CacheAbstractRestartSelfTest.java           |  247 ++++
 .../distributed/CacheAffEarlySelfTest.java      |  245 ----
 .../distributed/CacheAffinityEarlyTest.java     |  168 +++
 ...acheAsyncOperationsFailoverAbstractTest.java |   11 +
 .../CacheGetFutureHangsSelfTest.java            |  159 +-
 ...NearDisabledAtomicInvokeRestartSelfTest.java |  179 +++
 ...abledTransactionalInvokeRestartSelfTest.java |  173 +++
 ...edTransactionalWriteReadRestartSelfTest.java |  124 ++
 .../CacheNoValueClassOnServerNodeTest.java      |    1 +
 .../CachePutAllFailoverAbstractTest.java        |   11 +
 .../IgniteCacheAtomicNodeRestartTest.java       |    8 +
 ...niteCacheClientNodeChangingTopologyTest.java |   10 +-
 .../IgniteCacheCreatePutMultiNodeSelfTest.java  |  151 ++
 .../distributed/IgniteCacheCreatePutTest.java   |  125 ++
 .../IgniteCachePutGetRestartAbstractTest.java   |    3 +
 .../IgniteCacheSizeFailoverTest.java            |    3 +
 .../IgniteTxPreloadAbstractTest.java            |   43 +-
 .../GridCacheColocatedTxExceptionSelfTest.java  |    5 -
 .../dht/GridCacheDhtEntrySelfTest.java          |    2 +-
 .../dht/GridCacheDhtPreloadPerformanceTest.java |  133 ++
 .../dht/GridCacheTxNodeFailureSelfTest.java     |    2 +
 .../dht/GridNearCacheTxNodeFailureSelfTest.java |    4 +
 ...gniteAtomicLongChangingTopologySelfTest.java |  190 ++-
 .../IgniteCacheCrossCacheTxFailoverTest.java    |    3 +
 .../IgniteCrossCacheTxNearEnabledSelfTest.java  |   28 +
 .../dht/IgniteCrossCacheTxSelfTest.java         |  213 +++
 ...GridCacheValueConsistencyAtomicSelfTest.java |    2 +-
 ...tomicClientOnlyMultiNodeFullApiSelfTest.java |   71 +-
 ...ledFairAffinityMultiNodeFullApiSelfTest.java |   12 +-
 ...icOffHeapTieredMultiNodeFullApiSelfTest.java |    7 +-
 .../near/GridCacheNearTxExceptionSelfTest.java  |    9 +-
 .../near/GridCacheNearTxForceKeyTest.java       |    2 +-
 ...achePartitionedMultiNodeFullApiSelfTest.java |  129 +-
 .../near/NearCacheMultithreadedUpdateTest.java  |  217 +++
 .../GridCacheReplicatedInvalidateSelfTest.java  |  249 ----
 .../GridCacheReplicatedTxExceptionSelfTest.java |    5 -
 .../replicated/GridReplicatedTxPreloadTest.java |    9 +-
 ...eCacheExpiryPolicyWithStoreAbstractTest.java |    5 +-
 .../GridCacheLocalTxExceptionSelfTest.java      |    5 -
 ...bledFairAffinityMultiJvmFullApiSelfTest.java |    5 +
 ...tomicNearEnabledMultiJvmFullApiSelfTest.java |    5 +
 ...ontinuousQueryReplicatedOneNodeSelfTest.java |  120 ++
 .../DataStreamerMultiThreadedSelfTest.java      |    4 +-
 .../DataStreamerMultinodeCreateCacheTest.java   |    2 +
 .../processors/igfs/IgfsAbstractSelfTest.java   |  927 +++++++++---
 .../igfs/IgfsClientCacheSelfTest.java           |   15 +-
 .../igfs/IgfsDataManagerSelfTest.java           |   13 +-
 .../igfs/IgfsMetaManagerSelfTest.java           |  258 ++--
 .../processors/igfs/IgfsMetricsSelfTest.java    |    2 +-
 .../processors/igfs/IgfsProcessorSelfTest.java  |   41 +-
 .../igfs/UniversalFileSystemAdapter.java        |    1 -
 ...lientDiscoverySpiFailureTimeoutSelfTest.java |   33 +-
 .../tcp/TcpClientDiscoverySpiSelfTest.java      |    2 +
 .../tcp/TcpDiscoveryMultiThreadedTest.java      |   53 +-
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java |  315 +++-
 .../testframework/junits/GridAbstractTest.java  |  116 +-
 .../junits/IgniteTestResources.java             |    8 +-
 .../junits/common/GridCommonAbstractTest.java   |   15 +-
 .../junits/multijvm/AffinityProcessProxy.java   |  440 ++++--
 .../multijvm/IgniteCacheProcessProxy.java       | 1357 ++++++++++++++----
 .../multijvm/IgniteClusterProcessProxy.java     |  115 +-
 .../multijvm/IgniteEventsProcessProxy.java      |   50 +-
 .../junits/multijvm/IgniteNodeRunner.java       |   39 +-
 .../junits/multijvm/IgniteProcessProxy.java     |  105 +-
 .../IgniteCacheFailoverTestSuite.java           |    4 -
 .../IgniteCacheFailoverTestSuite3.java          |   28 +-
 .../IgniteCacheFullApiSelfTestSuite.java        |    8 +-
 .../IgniteCacheLoadConsistencyTestSuite.java    |   42 +
 .../testsuites/IgniteCacheTestSuite3.java       |    2 -
 .../testsuites/IgniteCacheTestSuite4.java       |   24 +
 .../ignite/testsuites/IgniteIgfsTestSuite.java  |    6 +
 modules/extdata/uri/pom.xml                     |   11 +-
 .../processors/hadoop/igfs/HadoopIgfsUtils.java |   36 +
 .../hadoop/igfs/HadoopIgfsWrapper.java          |   54 +-
 ...oopFileSystemUniversalFileSystemAdapter.java |    4 +-
 .../HadoopIgfs20FileSystemAbstractSelfTest.java |   34 +-
 .../IgniteHadoopFileSystemAbstractSelfTest.java |    7 +-
 .../testsuites/IgniteHadoopTestSuite.java       |   19 +-
 .../CacheHibernateBlobStoreSelfTest.java        |    6 +-
 .../processors/query/h2/sql/GridSqlArray.java   |   52 +
 .../processors/query/h2/sql/GridSqlElement.java |    2 +-
 .../query/h2/sql/GridSqlFunction.java           |   60 +-
 .../query/h2/sql/GridSqlFunctionType.java       |    3 +
 .../query/h2/sql/GridSqlPlaceholder.java        |    7 +-
 .../query/h2/sql/GridSqlQueryParser.java        |   84 +-
 .../processors/query/h2/sql/GridSqlType.java    |   29 +-
 .../cache/CacheConfigurationP2PTest.java        |    3 +
 .../cache/SqlFieldsQuerySelfTest.java           |  172 +++
 .../query/h2/sql/GridQueryParsingTest.java      |   27 +
 .../IgniteCacheQuerySelfTestSuite.java          |    6 +-
 .../cpp/common/project/vs/common.vcxproj        |    4 +-
 .../src/portable_reader_writer_test.cpp         |  119 +-
 .../ignite/impl/portable/portable_common.h      |   11 +-
 .../ignite/impl/portable/portable_reader_impl.h |   36 +-
 .../ignite/impl/portable/portable_writer_impl.h |    5 +-
 .../Apache.Ignite.Benchmarks.csproj             |    1 +
 .../Apache.Ignite.Benchmarks/BenchmarkRunner.cs |    2 +-
 .../Portable/PortableReadBenchmark.cs           |  126 ++
 .../Compute/ComputeApiTest.cs                   |   27 +-
 .../Apache.Ignite.Core.Tests/LifecycleTest.cs   |    3 +-
 .../Portable/PortableApiSelfTest.cs             |  112 +-
 .../Portable/PortableSelfTest.cs                |  235 ++-
 .../Portable/PortableStructureTest.cs           |   21 +-
 .../Apache.Ignite.Core.csproj                   |    3 +-
 .../Apache.Ignite.Core/Cache/ICacheAffinity.cs  |    4 +-
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |    4 +-
 .../Impl/Cache/CacheAffinityImpl.cs             |   10 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |    2 +-
 .../Impl/Cache/Store/CacheStore.cs              |    5 +-
 .../Impl/Cluster/ClusterGroupImpl.cs            |    7 +-
 .../Impl/Cluster/ClusterNodeImpl.cs             |    7 +-
 .../Impl/Common/DelegateConverter.cs            |   30 +-
 .../Apache.Ignite.Core/Impl/IgniteManager.cs    |    4 +-
 .../Impl/Portable/IPortableTypeDescriptor.cs    |   21 +-
 .../Portable/Metadata/PortableMetadataImpl.cs   |    2 +-
 .../Impl/Portable/PortableBuilderImpl.cs        |   33 +-
 .../Impl/Portable/PortableCollectionInfo.cs     |  251 ----
 .../Impl/Portable/PortableFullTypeDescriptor.cs |   29 +-
 .../Impl/Portable/PortableReaderExtensions.cs   |   52 +
 .../Impl/Portable/PortableReaderImpl.cs         |  105 +-
 .../Impl/Portable/PortableReflectiveRoutines.cs |   36 +-
 .../Portable/PortableSurrogateTypeDescriptor.cs |   27 +-
 .../Impl/Portable/PortableSystemHandlers.cs     |  281 +---
 .../Impl/Portable/PortableUserObject.cs         |    6 +-
 .../Impl/Portable/PortableUtils.cs              |  358 ++---
 .../Impl/Portable/PortableWriterImpl.cs         |  181 +--
 .../Impl/Portable/PortablesImpl.cs              |    1 +
 .../Portable/Structure/PortableStructure.cs     |    4 +-
 .../Structure/PortableStructureEntry.cs         |    2 +-
 .../Structure/PortableStructureTracker.cs       |  132 ++
 .../Portable/IPortableRawReader.cs              |   31 +-
 .../Portable/IPortableRawWriter.cs              |   31 +-
 .../Portable/IPortableReader.cs                 |   47 +-
 .../Portable/IPortableWriter.cs                 |   33 +-
 .../Properties/AssemblyInfo.cs                  |    1 -
 .../http/jetty/GridJettyJsonConfig.java         |  158 +-
 .../http/jetty/GridJettyRestHandler.java        |  186 +--
 .../spi/deployment/uri/UriDeploymentSpi.java    |   93 +-
 .../scanners/http/UriDeploymentHttpScanner.java |   10 +-
 .../http/GridHttpDeploymentSelfTest.java        |  132 +-
 .../visor/commands/kill/VisorKillCommand.scala  |    2 +-
 .../scala/org/apache/ignite/visor/visor.scala   |    1 -
 modules/yardstick/pom.xml                       |   10 +-
 pom.xml                                         |  109 +-
 363 files changed, 14871 insertions(+), 7200 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/core/src/main/java/org/apache/ignite/internal/portable/GridPortableMarshaller.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableClassDescriptor.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableContext.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableReaderExImpl.java
----------------------------------------------------------------------
diff --cc modules/core/src/main/java/org/apache/ignite/internal/portable/PortableReaderExImpl.java
index 60d3bb4,015ed6c..13977ec
--- a/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableReaderExImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableReaderExImpl.java
@@@ -53,6 -38,21 +53,20 @@@ import java.util.TreeSet
  import java.util.UUID;
  import java.util.concurrent.ConcurrentHashMap;
  import java.util.concurrent.ConcurrentSkipListSet;
+ import org.apache.ignite.IgniteCheckedException;
+ import org.apache.ignite.internal.portable.streams.PortableHeapInputStream;
+ import org.apache.ignite.internal.portable.streams.PortableInputStream;
+ import org.apache.ignite.internal.util.GridEnumCache;
+ import org.apache.ignite.internal.util.lang.GridMapEntry;
+ import org.apache.ignite.internal.util.typedef.internal.SB;
+ import org.apache.ignite.internal.util.typedef.internal.U;
 -import org.apache.ignite.marshaller.portable.PortableMarshaller;
+ import org.apache.ignite.portable.PortableException;
+ import org.apache.ignite.portable.PortableInvalidClassException;
+ import org.apache.ignite.portable.PortableObject;
+ import org.apache.ignite.portable.PortableRawReader;
+ import org.apache.ignite.portable.PortableReader;
+ import org.jetbrains.annotations.NotNull;
+ import org.jetbrains.annotations.Nullable;
  
  import static java.nio.charset.StandardCharsets.UTF_8;
  import static org.apache.ignite.internal.portable.GridPortableMarshaller.ARR_LIST;
@@@ -2409,6 -2361,26 +2430,26 @@@ public class PortableReaderExImpl imple
      }
  
      /**
+      * @return Use timestamp flag.
+      * @throws PortableInvalidClassException If fails to find object type descriptor.
+      */
+     private boolean isUseTimestamp() throws PortableInvalidClassException {
+         in.position(start);
+ 
+         boolean dateObj = in.readByte() == DATE;
+ 
+         if (!dateObj) {
 -            in.position(start + GridPortableMarshaller.TYPE_ID_POS);
++            in.position(start + 2);
+ 
 -            int typeId = in.readInt(start + GridPortableMarshaller.TYPE_ID_POS);
++            int typeId = in.readInt(start + 2);
+ 
+             return ctx.isUseTimestamp(typeId);
+         }
+ 
+         return ctx.isUseTimestamp();
+     }
+ 
+     /**
       * @param raw Raw flag.
       * @return Value.
       */

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableUtils.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/core/src/main/java/org/apache/ignite/internal/portable/builder/PortableBuilderReader.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/core/src/main/java/org/apache/ignite/marshaller/portable/PortableMarshaller.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/core/src/test/java/org/apache/ignite/internal/portable/GridPortableMarshallerSelfTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Portable/PortableApiSelfTest.cs
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Portable/PortableSelfTest.cs
----------------------------------------------------------------------
diff --cc modules/platforms/dotnet/Apache.Ignite.Core.Tests/Portable/PortableSelfTest.cs
index 9820c38,f06bf43..3d33682
--- a/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Portable/PortableSelfTest.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Portable/PortableSelfTest.cs
@@@ -2036,10 -2134,38 +2110,35 @@@ namespace Apache.Ignite.Core.Tests.Port
  
                  IPortableRawReader rawReader = reader.GetRawReader();
  
 -                LocRaw = rawReader.ReadDate(true).Value;
 -                UtcRaw = rawReader.ReadDate(false).Value;
 -                LocNullRaw = rawReader.ReadDate(true).Value;
 -                UtcNullRaw = rawReader.ReadDate(false).Value;
 -                LocArrRaw = rawReader.ReadDateArray(true);
 -                UtcArrRaw = rawReader.ReadDateArray(false);
 +                UtcRaw = rawReader.ReadTimestamp().Value;
 +                UtcNullRaw = rawReader.ReadTimestamp().Value;
 +                UtcArrRaw = rawReader.ReadTimestampArray();
              }
          }
+ 
+         [Serializable]
+         private class SerializableObject
+         {
+             public int Foo { get; set; }
+ 
+             private bool Equals(SerializableObject other)
+             {
+                 return Foo == other.Foo;
+             }
+ 
+             public override bool Equals(object obj)
+             {
+                 if (ReferenceEquals(null, obj)) return false;
+                 if (ReferenceEquals(this, obj)) return true;
+                 if (obj.GetType() != GetType()) return false;
+ 
+                 return Equals((SerializableObject) obj);
+             }
+ 
+             public override int GetHashCode()
+             {
+                 return Foo;
+             }
+         }
      }
  }

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Portable/Metadata/PortableMetadataImpl.cs
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Portable/PortableBuilderImpl.cs
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Portable/PortableReaderImpl.cs
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Portable/PortableReflectiveRoutines.cs
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Portable/PortableSystemHandlers.cs
----------------------------------------------------------------------
diff --cc modules/platforms/dotnet/Apache.Ignite.Core/Impl/Portable/PortableSystemHandlers.cs
index d13128e,ff3fb85..c5f75a5
--- a/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Portable/PortableSystemHandlers.cs
+++ b/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Portable/PortableSystemHandlers.cs
@@@ -128,14 -104,14 +104,14 @@@ namespace Apache.Ignite.Core.Impl.Porta
                  new PortableSystemReader<decimal?[]>(PortableUtils.ReadDecimalArray);
  
              // 6. Date array.
 -            ReadHandlers[PortableUtils.TypeArrayDate] =
 -                new PortableSystemReader<DateTime?[]>(s => PortableUtils.ReadDateArray(s, false));
 +            ReadHandlers[PortableUtils.TypeArrayTimestamp] =
 +                new PortableSystemReader<DateTime?[]>(PortableUtils.ReadTimestampArray);
  
              // 7. String array.
-             ReadHandlers[PortableUtils.TypeArrayString] = new PortableSystemGenericArrayReader<string>();
+             ReadHandlers[PortableUtils.TypeArrayString] = new PortableSystemTypedArrayReader<string>();
  
              // 8. Guid array.
-             ReadHandlers[PortableUtils.TypeArrayGuid] = new PortableSystemGenericArrayReader<Guid?>();
+             ReadHandlers[PortableUtils.TypeArrayGuid] = new PortableSystemTypedArrayReader<Guid?>();
  
              // 9. Array.
              ReadHandlers[PortableUtils.TypeArray] = new PortableSystemReader(ReadArray);

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Portable/PortableUtils.cs
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/platforms/dotnet/Apache.Ignite.Core/Impl/Portable/PortableWriterImpl.cs
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/platforms/dotnet/Apache.Ignite.Core/Portable/IPortableRawReader.cs
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/platforms/dotnet/Apache.Ignite.Core/Portable/IPortableRawWriter.cs
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/platforms/dotnet/Apache.Ignite.Core/Portable/IPortableReader.cs
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/9feec400/modules/platforms/dotnet/Apache.Ignite.Core/Portable/IPortableWriter.cs
----------------------------------------------------------------------