Merge remote-tracking branch 'remotes/origin/ignite-45' into ignite-525 Conflicts: modules/core/src/main/java/org/apache/ignite/IgniteDataStreamer.java
Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/c42bf53c Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/c42bf53c Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/c42bf53c Branch: refs/heads/ignite-45 Commit: c42bf53c72f502f21d691194c4cbc941438aaf79 Parents: 0d8ec47 bd8b180 Author: ivasilinets <ivasilin...@gridgain.com> Authored: Fri Mar 20 18:47:30 2015 +0300 Committer: ivasilinets <ivasilin...@gridgain.com> Committed: Fri Mar 20 18:47:30 2015 +0300 ---------------------------------------------------------------------- DEVNOTES.txt | 5 + NOTICE.txt | 2 +- examples/config/example-cache.xml | 5 +- examples/config/example-compute.xml | 70 - examples/config/example-ignite.xml | 83 + examples/config/example-streamer.xml | 20 +- examples/config/filesystem/example-igfs.xml | 3 +- examples/config/servlet/readme.txt | 2 +- examples/pom-standalone.xml | 2 +- examples/schema-import/db-demo-script.bat | 99 + examples/schema-import/db-demo-server.bat | 97 + examples/schema-import/db-demo-wizard.bat | 89 + examples/schema-import/db-demo.bat | 93 + examples/schema-import/demo.sql | 10 + .../ignite/examples/ComputeNodeStartup.java | 35 - .../ignite/examples/ExampleNodeStartup.java | 35 + .../computegrid/ComputeBroadcastExample.java | 8 +- .../computegrid/ComputeCallableExample.java | 8 +- .../computegrid/ComputeClosureExample.java | 8 +- .../ComputeClusterGroupsExample.java | 8 +- .../ComputeContinuousMapperExample.java | 8 +- .../ComputeExecutorServiceExample.java | 8 +- .../ComputeFibonacciContinuationExample.java | 8 +- .../computegrid/ComputeReducerExample.java | 8 +- .../computegrid/ComputeRunnableExample.java | 8 +- .../computegrid/ComputeScheduleExample.java | 8 +- .../computegrid/ComputeTaskMapExample.java | 8 +- .../computegrid/ComputeTaskSplitExample.java | 8 +- .../failover/ComputeFailoverExample.java | 1 - .../montecarlo/CreditRiskExample.java | 8 +- .../examples/datagrid/CacheAffinityExample.java | 33 +- .../examples/datagrid/CacheApiExample.java | 30 +- .../datagrid/CacheContinuousQueryExample.java | 101 +- .../datagrid/CacheDataStreamerExample.java | 52 +- .../examples/datagrid/CacheEventsExample.java | 77 +- .../examples/datagrid/CacheNodeStartup.java | 35 - .../datagrid/CachePopularNumbersExample.java | 59 +- .../examples/datagrid/CachePutGetExample.java | 42 +- .../examples/datagrid/CacheQueryExample.java | 88 +- .../datagrid/CacheTransactionExample.java | 59 +- .../starschema/CacheStarSchemaExample.java | 81 +- .../datagrid/starschema/DimProduct.java | 1 - .../examples/datagrid/starschema/DimStore.java | 1 - .../datagrid/starschema/FactPurchase.java | 2 - .../store/CacheNodeWithStoreStartup.java | 44 +- .../store/dummy/CacheDummyPersonStore.java | 1 - .../store/jdbc/CacheJdbcPojoPersonStore.java | 3 - .../datastructures/IgniteAtomicLongExample.java | 10 +- .../IgniteAtomicReferenceExample.java | 10 +- .../IgniteAtomicSequenceExample.java | 10 +- .../IgniteAtomicStampedExample.java | 10 +- .../IgniteCountDownLatchExample.java | 10 +- .../datastructures/IgniteQueueExample.java | 33 +- .../datastructures/IgniteSetExample.java | 34 +- .../ignite/examples/events/EventsExample.java | 10 +- .../examples/messaging/MessagingExample.java | 8 +- .../messaging/MessagingPingPongExample.java | 8 +- .../MessagingPingPongListenActorExample.java | 8 +- .../misc/deployment/DeploymentExample.java | 8 +- .../misc/springbean/SpringBeanExample.java | 6 +- .../examples/servicegrid/ServicesExample.java | 8 +- .../apache/ignite/examples/ComputeExample.java | 57 - .../ignite/examples/MessagingExample.java | 162 -- .../ignite/examples/java8/ComputeExample.java | 56 + .../examples/java8/ExampleNodeStartup.java | 35 + .../ignite/examples/java8/ExamplesUtils.java | 129 ++ .../ignite/examples/java8/MessagingExample.java | 162 ++ .../java8/streaming/numbers/CacheConfig.java | 52 + .../streaming/numbers/QueryPopularNumbers.java | 69 + .../streaming/numbers/StreamRandomNumbers.java | 79 + .../examples/ScalarCacheAffinityExample.scala | 115 + .../examples/ScalarCacheAffinityExample1.scala | 121 -- .../examples/ScalarCacheAffinityExample2.scala | 116 - .../ScalarCacheAffinitySimpleExample.scala | 83 - .../scalar/examples/ScalarCacheExample.scala | 27 +- .../ScalarCachePopularNumbersExample.scala | 88 +- .../examples/ScalarCacheQueryExample.scala | 36 +- .../scalar/examples/ScalarClosureExample.scala | 4 +- .../examples/ScalarContinuationExample.scala | 4 +- .../examples/ScalarCreditRiskExample.scala | 4 +- .../examples/ScalarPiCalculationExample.scala | 55 - .../scalar/examples/ScalarPingPongExample.scala | 4 +- .../scalar/examples/ScalarPrimeExample.scala | 4 +- .../scalar/examples/ScalarScheduleExample.scala | 4 +- .../examples/ScalarSnowflakeSchemaExample.scala | 83 +- .../scalar/examples/ScalarTaskExample.scala | 4 +- .../examples/ScalarWorldShortestMapReduce.scala | 4 +- .../CacheExamplesMultiNodeSelfTest.java | 2 +- .../examples/MessagingExamplesSelfTest.java | 2 +- .../tests/examples/ScalarExamplesSelfTest.scala | 17 +- .../ClientAbstractMultiThreadedSelfTest.java | 192 +- .../client/ClientDefaultCacheSelfTest.java | 48 - .../client/ClientTopologyCacheSelfTest.java | 288 --- .../ClientAbstractMultiNodeSelfTest.java | 282 --- .../integration/ClientAbstractSelfTest.java | 797 ------- .../client/suite/IgniteClientTestSuite.java | 2 - .../ignite/jdbc/JdbcComplexQuerySelfTest.java | 1 - .../loadtests/client/ClientTcpSslLoadTest.java | 2 - .../clients/src/test/resources/spring-cache.xml | 4 +- .../ignite/codegen/MessageCodeGenerator.java | 3 + .../src/main/java/org/apache/ignite/Ignite.java | 52 +- .../org/apache/ignite/IgniteDataStreamer.java | 32 +- .../apache/ignite/IgniteSystemProperties.java | 5 + .../main/java/org/apache/ignite/Ignition.java | 20 +- .../apache/ignite/cache/CacheInterceptor.java | 5 +- .../ignite/cache/CacheInterceptorAdapter.java | 3 + .../org/apache/ignite/cache/CacheManager.java | 399 ++-- .../apache/ignite/cache/CachingProvider.java | 155 +- .../affinity/CacheAffinityFunctionContext.java | 3 +- .../fair/CachePartitionFairAffinity.java | 99 +- .../cache/eviction/CacheEvictionFilter.java | 9 +- .../eviction/fifo/CacheFifoEvictionPolicy.java | 16 +- .../eviction/igfs/CacheIgfsEvictionFilter.java | 3 + .../CacheIgfsPerBlockLruEvictionPolicy.java | 23 +- .../eviction/lru/CacheLruEvictionPolicy.java | 16 +- .../random/CacheRandomEvictionPolicy.java | 16 +- .../cache/store/jdbc/CacheJdbcBlobStore.java | 1 + .../org/apache/ignite/cluster/ClusterGroup.java | 40 +- .../configuration/CacheConfiguration.java | 169 +- .../configuration/IgniteConfiguration.java | 168 +- .../configuration/IgniteReflectionFactory.java | 216 ++ .../configuration/NearCacheConfiguration.java | 112 + .../org/apache/ignite/events/EventType.java | 26 + .../apache/ignite/internal/GridComponent.java | 9 +- .../internal/GridEventConsumeHandler.java | 18 +- .../ignite/internal/GridKernalContextImpl.java | 10 +- .../ignite/internal/GridKernalGateway.java | 5 + .../ignite/internal/GridKernalGatewayImpl.java | 8 + .../apache/ignite/internal/GridKernalState.java | 2 +- .../internal/GridMessageListenHandler.java | 9 +- .../internal/GridNodeOrderComparator.java | 10 + .../ignite/internal/GridPluginComponent.java | 2 +- .../apache/ignite/internal/IgniteKernal.java | 115 +- .../ignite/internal/IgniteNodeAttributes.java | 2 +- .../org/apache/ignite/internal/IgnitionEx.java | 201 +- .../client/GridClientPartitionAffinity.java | 8 +- .../internal/cluster/ClusterGroupAdapter.java | 94 +- .../ignite/internal/cluster/ClusterGroupEx.java | 6 +- .../cluster/IgniteClusterAsyncImpl.java | 10 + .../internal/events/DiscoveryCustomEvent.java | 18 + .../internal/managers/GridManagerAdapter.java | 2 +- .../managers/communication/GridIoManager.java | 7 + .../communication/GridIoMessageFactory.java | 6 + .../discovery/GridDiscoveryManager.java | 554 +++-- .../eventstorage/GridEventStorageManager.java | 3 +- .../processors/GridProcessorAdapter.java | 2 +- .../affinity/AffinityTopologyVersion.java | 204 ++ .../affinity/GridAffinityAssignment.java | 12 +- .../affinity/GridAffinityAssignmentCache.java | 110 +- .../affinity/GridAffinityProcessor.java | 44 +- .../processors/affinity/GridAffinityUtils.java | 10 +- .../GridCacheAffinityFunctionContextImpl.java | 16 +- .../cache/CacheEntryPredicateAdapter.java | 20 +- .../cache/CacheEntryPredicateContainsValue.java | 6 + .../cache/DynamicCacheChangeBatch.java | 75 + .../cache/DynamicCacheChangeRequest.java | 169 ++ .../cache/DynamicCacheDescriptor.java | 171 ++ .../internal/processors/cache/GridCache.java | 5 + .../processors/cache/GridCacheAdapter.java | 80 +- .../cache/GridCacheAffinityManager.java | 72 +- .../processors/cache/GridCacheAtomicFuture.java | 4 +- .../processors/cache/GridCacheAttributes.java | 358 +-- .../cache/GridCacheClearAllRunnable.java | 6 +- .../cache/GridCacheConcurrentMap.java | 18 +- .../processors/cache/GridCacheContext.java | 79 +- .../GridCacheDefaultAffinityKeyMapper.java | 2 +- .../cache/GridCacheDeploymentManager.java | 17 +- .../processors/cache/GridCacheEntryEx.java | 11 +- .../processors/cache/GridCacheEventManager.java | 26 +- .../cache/GridCacheEvictionManager.java | 49 +- .../cache/GridCacheEvictionRequest.java | 14 +- .../cache/GridCacheExplicitLockSpan.java | 20 +- .../processors/cache/GridCacheGateway.java | 56 +- .../processors/cache/GridCacheIoManager.java | 25 +- .../cache/GridCacheLoaderWriterStore.java | 6 +- .../GridCacheLoaderWriterStoreFactory.java | 59 + .../processors/cache/GridCacheMapEntry.java | 27 +- .../cache/GridCacheMapEntryFactory.java | 3 +- .../processors/cache/GridCacheMessage.java | 5 +- .../cache/GridCacheMvccCandidate.java | 7 +- .../processors/cache/GridCacheMvccManager.java | 54 +- .../GridCachePartitionExchangeManager.java | 269 ++- .../processors/cache/GridCachePreloader.java | 3 +- .../cache/GridCachePreloaderAdapter.java | 3 +- .../processors/cache/GridCacheProcessor.java | 2041 ++++++++++++------ .../processors/cache/GridCacheProxyImpl.java | 12 + .../cache/GridCacheSharedContext.java | 39 +- .../processors/cache/GridCacheSwapManager.java | 13 +- .../processors/cache/GridCacheTtlManager.java | 12 +- .../processors/cache/GridCacheUtils.java | 152 +- .../cache/IgniteCacheExistsException.java | 52 + .../processors/cache/IgniteCacheProxy.java | 156 +- .../cache/affinity/GridCacheAffinityImpl.java | 11 +- .../CacheDataStructuresManager.java | 17 +- .../distributed/GridCacheTtlUpdateRequest.java | 12 +- .../GridDistributedCacheAdapter.java | 25 +- .../GridDistributedTxRemoteAdapter.java | 3 +- .../dht/GridClientPartitionTopology.java | 101 +- .../dht/GridDhtAffinityAssignmentRequest.java | 12 +- .../dht/GridDhtAffinityAssignmentResponse.java | 13 +- .../dht/GridDhtAssignmentFetchFuture.java | 12 +- .../distributed/dht/GridDhtCacheAdapter.java | 80 +- .../distributed/dht/GridDhtCacheEntry.java | 13 +- .../cache/distributed/dht/GridDhtGetFuture.java | 7 +- .../distributed/dht/GridDhtLocalPartition.java | 6 +- .../distributed/dht/GridDhtLockFuture.java | 7 +- .../distributed/dht/GridDhtLockRequest.java | 11 +- .../dht/GridDhtPartitionTopology.java | 27 +- .../dht/GridDhtPartitionTopologyImpl.java | 99 +- .../distributed/dht/GridDhtTopologyFuture.java | 10 +- .../dht/GridDhtTransactionalCacheAdapter.java | 11 +- .../distributed/dht/GridDhtTxFinishRequest.java | 11 +- .../cache/distributed/dht/GridDhtTxLocal.java | 5 +- .../distributed/dht/GridDhtTxLocalAdapter.java | 5 +- .../distributed/dht/GridDhtTxPrepareFuture.java | 12 +- .../dht/GridDhtTxPrepareRequest.java | 11 +- .../cache/distributed/dht/GridDhtTxRemote.java | 7 +- .../distributed/dht/GridNoStorageCacheMap.java | 6 +- .../dht/GridPartitionedGetFuture.java | 47 +- .../dht/atomic/GridDhtAtomicCache.java | 66 +- .../dht/atomic/GridDhtAtomicCacheEntry.java | 3 +- .../dht/atomic/GridDhtAtomicUpdateFuture.java | 7 +- .../dht/atomic/GridDhtAtomicUpdateRequest.java | 11 +- .../dht/atomic/GridNearAtomicUpdateFuture.java | 52 +- .../dht/atomic/GridNearAtomicUpdateRequest.java | 11 +- .../dht/colocated/GridDhtColocatedCache.java | 31 +- .../colocated/GridDhtColocatedCacheEntry.java | 7 +- .../colocated/GridDhtColocatedLockFuture.java | 98 +- .../dht/preloader/GridDhtForceKeysFuture.java | 9 +- .../dht/preloader/GridDhtForceKeysRequest.java | 12 +- .../GridDhtPartitionDemandMessage.java | 12 +- .../preloader/GridDhtPartitionDemandPool.java | 48 +- .../preloader/GridDhtPartitionExchangeId.java | 28 +- .../dht/preloader/GridDhtPartitionFullMap.java | 8 +- .../dht/preloader/GridDhtPartitionMap.java | 2 +- .../GridDhtPartitionsExchangeFuture.java | 142 +- .../preloader/GridDhtPartitionsFullMessage.java | 18 +- .../dht/preloader/GridDhtPreloader.java | 17 +- .../preloader/GridDhtPreloaderAssignments.java | 9 +- .../distributed/near/GridNearAtomicCache.java | 5 +- .../distributed/near/GridNearCacheAdapter.java | 66 +- .../distributed/near/GridNearCacheEntry.java | 10 +- .../distributed/near/GridNearGetFuture.java | 61 +- .../distributed/near/GridNearGetRequest.java | 12 +- .../distributed/near/GridNearGetResponse.java | 12 +- .../distributed/near/GridNearLockFuture.java | 86 +- .../distributed/near/GridNearLockRequest.java | 13 +- .../near/GridNearTransactionalCache.java | 13 +- .../near/GridNearTxFinishFuture.java | 3 +- .../near/GridNearTxFinishRequest.java | 11 +- .../cache/distributed/near/GridNearTxLocal.java | 37 +- .../near/GridNearTxPrepareFuture.java | 50 +- .../near/GridNearTxPrepareRequest.java | 11 +- .../distributed/near/GridNearTxRemote.java | 3 +- .../processors/cache/dr/GridCacheDrManager.java | 3 +- .../cache/dr/os/GridOsCacheDrManager.java | 3 +- .../processors/cache/local/GridLocalCache.java | 18 +- .../local/atomic/GridLocalAtomicCache.java | 12 +- .../query/GridCacheDistributedQueryManager.java | 26 +- .../cache/query/GridCacheQueryAdapter.java | 9 +- .../cache/query/GridCacheQueryManager.java | 37 +- .../continuous/CacheContinuousQueryHandler.java | 36 +- .../continuous/CacheContinuousQueryManager.java | 33 +- .../jdbc/GridCacheQueryJdbcMetadataTask.java | 11 +- .../query/jdbc/GridCacheQueryJdbcTask.java | 12 +- .../jdbc/GridCacheQueryJdbcValidationTask.java | 7 +- .../cache/transactions/IgniteInternalTx.java | 10 +- .../cache/transactions/IgniteTxAdapter.java | 38 +- .../transactions/IgniteTxLocalAdapter.java | 17 +- .../cache/transactions/IgniteTxManager.java | 10 +- .../cache/version/GridCacheVersion.java | 19 +- .../cache/version/GridCacheVersionManager.java | 22 +- .../cacheobject/IgniteCacheObjectProcessor.java | 4 +- .../IgniteCacheObjectProcessorImpl.java | 13 +- .../processors/clock/GridClockDeltaVersion.java | 10 +- .../processors/clock/GridClockServer.java | 2 +- .../clock/GridClockSyncProcessor.java | 2 +- .../continuous/GridContinuousHandler.java | 15 +- .../continuous/GridContinuousProcessor.java | 79 +- .../datastreamer/DataStreamProcessor.java | 3 +- .../datastreamer/DataStreamerCacheUpdaters.java | 25 +- .../datastreamer/DataStreamerImpl.java | 37 +- .../datastreamer/DataStreamerRequest.java | 2 +- .../datastreamer/DataStreamerUpdateJob.java | 17 +- .../datastructures/DataStructuresProcessor.java | 2 +- .../datastructures/GridCacheSetImpl.java | 3 +- .../dr/IgniteDrDataStreamerCacheUpdater.java | 9 +- .../processors/igfs/IgfsDataManager.java | 67 +- .../processors/igfs/IgfsMetaManager.java | 46 +- .../internal/processors/igfs/IgfsProcessor.java | 46 +- .../internal/processors/igfs/IgfsServer.java | 4 +- .../processors/igfs/IgfsServerManager.java | 4 +- .../processors/job/GridJobProcessor.java | 1 + .../plugin/IgnitePluginProcessor.java | 2 +- .../processors/query/GridQueryIndexing.java | 9 +- .../processors/query/GridQueryProcessor.java | 55 +- .../service/GridServiceProcessor.java | 3 +- .../processors/task/GridTaskProcessor.java | 7 +- .../timeout/GridTimeoutProcessor.java | 2 +- .../ignite/internal/util/IgniteUtils.java | 153 +- .../ignite/internal/util/lang/GridFunc.java | 2 +- .../ignite/internal/util/nio/GridNioServer.java | 120 +- .../ignite/internal/util/worker/GridWorker.java | 26 +- .../ignite/internal/visor/cache/VisorCache.java | 17 +- .../visor/cache/VisorCacheConfiguration.java | 19 +- .../cache/VisorCacheEvictionConfiguration.java | 11 - .../cache/VisorCacheNearConfiguration.java | 6 +- .../cache/VisorCachePreloadConfiguration.java | 114 - .../visor/cache/VisorCachePreloadTask.java | 82 - .../cache/VisorCacheRebalanceConfiguration.java | 114 + .../visor/cache/VisorCacheRebalanceTask.java | 82 + .../visor/node/VisorNodeDataCollectorJob.java | 11 +- .../ignite/lang/IgniteProductVersion.java | 28 +- .../java/org/apache/ignite/lang/IgniteUuid.java | 7 +- .../optimized/OptimizedClassDescriptor.java | 268 ++- .../optimized/OptimizedObjectInputStream.java | 93 +- .../optimized/OptimizedObjectOutputStream.java | 64 +- .../jobstealing/JobStealingCollisionSpi.java | 2 +- .../communication/tcp/TcpCommunicationSpi.java | 1 + .../spi/discovery/DiscoverySpiDataExchange.java | 8 +- .../spi/discovery/DiscoverySpiListener.java | 3 +- .../discovery/tcp/TcpClientDiscoverySpi.java | 19 +- .../spi/discovery/tcp/TcpDiscoverySpi.java | 118 +- .../tcp/internal/TcpDiscoveryNode.java | 10 +- .../TcpDiscoveryCustomEventMessage.java | 1 + .../messages/TcpDiscoveryNodeAddedMessage.java | 26 +- .../ignite/startup/BasicWarmupClosure.java | 8 +- .../apache/ignite/stream/StreamReceiver.java | 42 + .../apache/ignite/stream/StreamTransformer.java | 51 + .../org/apache/ignite/stream/package-info.java | 21 + .../resources/META-INF/classnames.properties | 53 +- .../core/src/main/resources/ignite.properties | 2 +- modules/core/src/test/config/example-cache.xml | 7 +- .../core/src/test/config/examples.properties | 14 +- modules/core/src/test/config/igfs-loopback.xml | 1 - modules/core/src/test/config/igfs-shmem.xml | 1 - .../test/config/websession/example-cache.xml | 8 +- .../test/config/websession/spring-cache-1.xml | 4 - .../test/config/websession/spring-cache-2.xml | 4 - .../test/config/websession/spring-cache-3.xml | 4 - .../ignite/IgniteCacheAffinitySelfTest.java | 8 +- ...CachePartitionFairAffinityNodesSelfTest.java | 2 +- .../GridCachePartitionFairAffinitySelfTest.java | 9 +- .../GridCacheLoadOnlyStoreAdapterSelfTest.java | 2 +- .../IgniteCacheExpiryStoreLoadSelfTest.java | 4 +- ...eJdbcStoreAbstractMultithreadedSelfTest.java | 16 +- ...CacheJdbcBlobStoreMultithreadedSelfTest.java | 67 +- .../ignite/igfs/IgfsEventsAbstractSelfTest.java | 3 +- .../igfs/IgfsFragmentizerAbstractSelfTest.java | 2 +- .../ignite/internal/GridAffinitySelfTest.java | 2 +- .../ignite/internal/GridDiscoverySelfTest.java | 3 +- .../GridProjectionForCachesSelfTest.java | 72 +- .../ignite/internal/GridProjectionSelfTest.java | 36 +- .../internal/GridUpdateNotifierSelfTest.java | 2 + .../GridDiscoveryManagerAliveCacheSelfTest.java | 10 +- .../discovery/GridDiscoveryManagerSelfTest.java | 128 +- .../GridAffinityProcessorAbstractSelfTest.java | 12 +- .../cache/GridCacheAbstractFlagsTest.java | 7 +- ...cheAbstractFullApiMultithreadedSelfTest.java | 2 +- .../cache/GridCacheAbstractFullApiSelfTest.java | 121 +- .../GridCacheAbstractLocalStoreSelfTest.java | 11 +- .../cache/GridCacheAbstractSelfTest.java | 28 +- ...acheAbstractUsersAffinityMapperSelfTest.java | 6 +- .../cache/GridCacheAffinityApiSelfTest.java | 24 +- .../cache/GridCacheAlwaysEvictionPolicy.java | 14 +- .../GridCacheAtomicMessageCountSelfTest.java | 28 +- ...dCacheAtomicUsersAffinityMapperSelfTest.java | 5 +- .../cache/GridCacheBasicStoreAbstractTest.java | 10 +- ...acheBasicStoreMultithreadedAbstractTest.java | 2 +- .../cache/GridCacheClearAllSelfTest.java | 31 +- .../cache/GridCacheClearLocallySelfTest.java | 382 ++++ .../cache/GridCacheClearLocalySelfTest.java | 335 --- ...dCacheColocatedTxStoreExceptionSelfTest.java | 6 +- .../GridCacheConcurrentTxMultiNodeTest.java | 3 - ...idCacheConfigurationConsistencySelfTest.java | 222 +- ...ridCacheConfigurationValidationSelfTest.java | 35 +- .../GridCacheDaemonNodeAbstractSelfTest.java | 3 +- .../GridCacheDeploymentOffHeapSelfTest.java | 3 +- .../cache/GridCacheDeploymentSelfTest.java | 3 +- .../cache/GridCacheEntryMemorySizeSelfTest.java | 3 +- .../GridCacheEvictionEventAbstractTest.java | 8 - .../GridCacheExAbstractFullApiSelfTest.java | 6 +- .../GridCacheFinishPartitionsSelfTest.java | 20 +- ...idCacheGetAndTransformStoreAbstractTest.java | 11 +- .../cache/GridCacheIncrementTransformTest.java | 2 - .../GridCacheInterceptorAbstractSelfTest.java | 333 +-- ...cheInterceptorAtomicNearEnabledSelfTest.java | 11 +- ...erceptorAtomicPrimaryWriteOrderSelfTest.java | 8 +- .../GridCacheInterceptorAtomicSelfTest.java | 8 +- ...GridCacheInterceptorNearEnabledSelfTest.java | 7 +- .../cache/GridCacheInterceptorSelfTest.java | 8 +- .../GridCacheKeyCheckNearEnabledSelfTest.java | 6 +- .../cache/GridCacheKeyCheckSelfTest.java | 7 +- .../processors/cache/GridCacheLeakTest.java | 3 +- .../cache/GridCacheLifecycleAwareSelfTest.java | 27 +- ...GridCacheMixedPartitionExchangeSelfTest.java | 35 +- .../cache/GridCacheMultiUpdateLockSelfTest.java | 10 +- ...ridCacheMultinodeUpdateAbstractSelfTest.java | 18 +- ...ultinodeUpdateAtomicNearEnabledSelfTest.java | 6 +- .../GridCacheMultinodeUpdateAtomicSelfTest.java | 6 +- ...CacheMultinodeUpdateNearEnabledSelfTest.java | 6 +- .../cache/GridCacheMultinodeUpdateSelfTest.java | 6 +- .../cache/GridCacheMvccPartitionedSelfTest.java | 1 - .../cache/GridCacheObjectToStringSelfTest.java | 3 +- .../processors/cache/GridCacheOffHeapTest.java | 3 +- .../GridCacheOffHeapTieredAbstractSelfTest.java | 4 +- .../cache/GridCacheOffheapUpdateSelfTest.java | 2 +- .../GridCacheOnCopyFlagAbstractSelfTest.java | 4 +- .../cache/GridCacheP2PUndeploySelfTest.java | 3 - .../cache/GridCachePartitionedGetSelfTest.java | 4 +- .../GridCachePartitionedLocalStoreSelfTest.java | 6 +- ...chePartitionedOffHeapLocalStoreSelfTest.java | 6 +- ...hePartitionedProjectionAffinitySelfTest.java | 1 - .../cache/GridCachePartitionedWritesTest.java | 6 +- .../GridCachePreloadingEvictionsSelfTest.java | 5 +- .../cache/GridCachePutAllFailoverSelfTest.java | 2 +- .../GridCacheReferenceCleanupSelfTest.java | 3 +- .../cache/GridCacheReloadSelfTest.java | 5 +- .../GridCacheReplicatedLocalStoreSelfTest.java | 6 +- ...CacheReplicatedTxStoreExceptionSelfTest.java | 6 +- ...heReplicatedUsersAffinityMapperSelfTest.java | 5 +- .../GridCacheReturnValueTransferSelfTest.java | 11 +- .../cache/GridCacheStorePutxSelfTest.java | 2 +- .../cache/GridCacheSwapPreloadSelfTest.java | 1 - .../cache/GridCacheSwapReloadSelfTest.java | 2 +- .../processors/cache/GridCacheTestEntryEx.java | 26 +- ...ridCacheTxPartitionedLocalStoreSelfTest.java | 6 +- .../GridCacheTxUsersAffinityMapperSelfTest.java | 5 +- .../GridCacheValueBytesPreloadingSelfTest.java | 3 +- ...idCacheValueConsistencyAbstractSelfTest.java | 10 +- ...istencyTransactionalNearEnabledSelfTest.java | 6 +- .../cache/GridCacheVersionMultinodeTest.java | 13 +- .../GridCacheWriteBehindStoreAbstractTest.java | 4 +- ...BehindStorePartitionedMultiNodeSelfTest.java | 6 +- .../IgniteCacheAbstractStopBusySelfTest.java | 11 +- .../cache/IgniteCacheAbstractTest.java | 24 +- .../cache/IgniteCacheAtomicInvokeTest.java | 6 +- .../cache/IgniteCacheAtomicLocalInvokeTest.java | 6 +- ...niteCacheAtomicLocalWithStoreInvokeTest.java | 6 +- .../IgniteCacheAtomicNearEnabledInvokeTest.java | 8 +- .../IgniteCacheAtomicNearPeekModesTest.java | 28 + ...eCacheAtomicPrimaryWriteOrderInvokeTest.java | 6 +- ...micPrimaryWriteOrderWithStoreInvokeTest.java | 6 +- .../IgniteCacheEntryListenerAbstractTest.java | 191 +- ...IgniteCacheEntryListenerAtomicLocalTest.java | 6 +- .../IgniteCacheEntryListenerAtomicTest.java | 6 +- .../IgniteCacheEntryListenerTxLocalTest.java | 6 +- .../cache/IgniteCacheEntryListenerTxTest.java | 6 +- .../cache/IgniteCacheInvokeReadThroughTest.java | 11 +- .../cache/IgniteCachePeekModesAbstractTest.java | 32 +- .../cache/IgniteCacheStartStopLoadTest.java | 135 ++ .../cache/IgniteCacheTxInvokeTest.java | 6 +- .../cache/IgniteCacheTxLocalInvokeTest.java | 6 +- .../IgniteCacheTxNearEnabledInvokeTest.java | 8 +- .../cache/IgniteCacheTxNearPeekModesTest.java | 28 + .../cache/IgniteCacheTxPreloadNoWriteTest.java | 1 - .../cache/IgniteCachingProviderSelfTest.java | 4 +- .../IgniteClientAffinityAssignmentSelfTest.java | 7 +- .../cache/IgniteDynamicCacheStartSelfTest.java | 663 ++++++ .../cache/IgnitePutAllLargeBatchSelfTest.java | 3 +- ...tAllUpdateNonPreloadedPartitionSelfTest.java | 2 +- .../cache/IgniteStaticCacheStartSelfTest.java | 98 + .../cache/IgniteTxReentryAbstractSelfTest.java | 4 +- .../IgniteTxStoreExceptionAbstractSelfTest.java | 18 +- ...IgniteCacheAbstractExecutionContextTest.java | 12 +- .../IgniteCacheAtomicExecutionContextTest.java | 6 +- ...iteCachePartitionedExecutionContextTest.java | 6 +- ...niteCacheReplicatedExecutionContextTest.java | 6 +- .../IgniteCacheTxExecutionContextTest.java | 6 +- ...actQueueFailoverDataConsistencySelfTest.java | 4 +- ...CacheAtomicReferenceApiSelfAbstractTest.java | 2 +- ...idCacheAtomicStampedApiSelfAbstractTest.java | 2 +- .../GridCacheSetAbstractSelfTest.java | 10 +- .../IgniteAtomicLongApiAbstractSelfTest.java | 2 +- .../IgniteCollectionAbstractTest.java | 1 - ...idCachePartitionedNodeRestartTxSelfTest.java | 2 - ...dCachePartitionedQueueEntryMoveSelfTest.java | 3 +- .../GridCacheAbstractJobExecutionTest.java | 30 +- ...tractPartitionedByteArrayValuesSelfTest.java | 9 +- .../GridCacheAbstractPrimarySyncSelfTest.java | 5 +- .../GridCacheAtomicTimeoutSelfTest.java | 7 +- .../GridCacheClientModesAbstractSelfTest.java | 24 +- ...acheEntrySetIterationPreloadingSelfTest.java | 4 +- .../distributed/GridCacheLockAbstractTest.java | 1 - .../distributed/GridCacheMixedModeSelfTest.java | 6 +- ...dCacheMultithreadedFailoverAbstractTest.java | 19 +- ...dCachePartitionedAffinityFilterSelfTest.java | 1 - ...chePartitionedReloadAllAbstractSelfTest.java | 6 +- .../GridCachePreloadEventsAbstractSelfTest.java | 3 +- ...GridCachePreloadRestartAbstractSelfTest.java | 4 +- .../GridCacheTransformEventSelfTest.java | 1 - .../IgniteCrossCacheTxStoreSelfTest.java | 75 +- ...iteTxConsistencyRestartAbstractSelfTest.java | 4 +- ...tPartitionedOnlyByteArrayValuesSelfTest.java | 4 +- ...heAbstractTransformWriteThroughSelfTest.java | 6 +- ...acheAtomicExpiredEntriesPreloadSelfTest.java | 6 +- .../dht/GridCacheAtomicFullApiSelfTest.java | 5 +- .../dht/GridCacheAtomicNearCacheSelfTest.java | 3 +- ...idCacheAtomicNearEnabledFullApiSelfTest.java | 8 +- ...EnabledPrimaryWriteOrderFullApiSelfTest.java | 8 +- .../dht/GridCacheClientOnlySelfTest.java | 8 +- .../dht/GridCacheColocatedDebugTest.java | 5 +- .../dht/GridCacheColocatedFailoverSelfTest.java | 6 +- ...eColocatedOptimisticTransactionSelfTest.java | 4 +- .../GridCacheColocatedPrimarySyncSelfTest.java | 8 +- .../GridCacheColocatedTxExceptionSelfTest.java | 6 +- ...ssimisticOriginatingNodeFailureSelfTest.java | 6 +- ...dCacheColocatedTxSingleThreadedSelfTest.java | 2 +- .../GridCacheDhtAtomicRemoveFailureTest.java | 3 +- .../dht/GridCacheDhtEntrySelfTest.java | 1 - .../dht/GridCacheDhtEntrySetSelfTest.java | 3 +- ...GridCacheDhtEvictionNearReadersSelfTest.java | 10 +- .../dht/GridCacheDhtEvictionSelfTest.java | 9 +- .../GridCacheDhtEvictionsDisabledSelfTest.java | 3 +- ...idCacheDhtExpiredEntriesPreloadSelfTest.java | 6 +- .../dht/GridCacheDhtInternalEntrySelfTest.java | 7 +- .../dht/GridCacheDhtMappingSelfTest.java | 1 - .../dht/GridCacheDhtPreloadDelayedSelfTest.java | 1 - .../GridCacheDhtPreloadDisabledSelfTest.java | 5 +- .../dht/GridCacheDhtRemoveFailureTest.java | 3 +- .../distributed/dht/GridCacheDhtTestUtils.java | 7 +- .../dht/GridCacheDhtTxPreloadSelfTest.java | 3 +- .../dht/GridCacheGlobalLoadTest.java | 12 +- ...ePartitionedNearDisabledFullApiSelfTest.java | 8 +- ...ePartitionedNearDisabledMetricsSelfTest.java | 3 +- ...nedNearDisabledMultiNodeFullApiSelfTest.java | 8 +- ...bledMultiNodeP2PDisabledFullApiSelfTest.java | 8 +- ...isabledTxOriginatingNodeFailureSelfTest.java | 6 +- ...idCachePartitionedPreloadEventsSelfTest.java | 14 +- ...dCachePartitionedTopologyChangeSelfTest.java | 3 +- ...itionedTxOriginatingNodeFailureSelfTest.java | 5 - ...IgniteCacheContainsKeyColocatedSelfTest.java | 5 +- ...teTxConsistencyColocatedRestartSelfTest.java | 5 +- .../atomic/GridCacheAtomicPreloadSelfTest.java | 3 +- ...lueConsistencyAtomicNearEnabledSelfTest.java | 14 +- ...micPrimaryWriteOrderNearEnabledSelfTest.java | 6 +- ...CacheContainsKeyColocatedAtomicSelfTest.java | 5 +- ...tNearPartitionedByteArrayValuesSelfTest.java | 5 +- ...tomicClientOnlyMultiNodeFullApiSelfTest.java | 15 +- ...GridCacheAtomicMultiNodeFullApiSelfTest.java | 4 +- ...omicMultiNodeP2PDisabledFullApiSelfTest.java | 5 +- ...omicNearEnabledMultiNodeFullApiSelfTest.java | 8 +- ...imaryWriteOrderMultiNodeFullApiSelfTest.java | 8 +- ...eAtomicNearOnlyMultiNodeFullApiSelfTest.java | 8 +- .../GridCacheAtomicNearRemoveFailureTest.java | 3 +- .../GridCacheAtomicOffHeapFullApiSelfTest.java | 5 +- ...heAtomicOffHeapMultiNodeFullApiSelfTest.java | 5 +- ...cPrimaryWriteOrderNearRemoveFailureTest.java | 3 +- .../near/GridCacheExNearFullApiSelfTest.java | 6 +- .../near/GridCacheGetStoreErrorSelfTest.java | 39 +- .../GridCacheNearEvictionEventSelfTest.java | 5 - .../near/GridCacheNearEvictionSelfTest.java | 7 +- ...dCacheNearExpiredEntriesPreloadSelfTest.java | 6 +- .../near/GridCacheNearJobExecutionSelfTest.java | 3 +- .../near/GridCacheNearMultiGetSelfTest.java | 2 - .../near/GridCacheNearMultiNodeSelfTest.java | 9 +- .../near/GridCacheNearOneNodeSelfTest.java | 4 +- ...idCacheNearOnlyMultiNodeFullApiSelfTest.java | 48 +- .../near/GridCacheNearOnlySelfTest.java | 7 - .../near/GridCacheNearOnlyTopologySelfTest.java | 36 +- .../GridCacheNearPartitionedClearSelfTest.java | 5 +- .../near/GridCacheNearPrimarySyncSelfTest.java | 8 +- .../GridCacheNearReaderPreloadSelfTest.java | 5 +- .../near/GridCacheNearReadersSelfTest.java | 12 +- .../near/GridCacheNearRemoveFailureTest.java | 3 +- .../near/GridCacheNearTxMultiNodeSelfTest.java | 3 +- ...ssimisticOriginatingNodeFailureSelfTest.java | 6 - .../near/GridCacheNearTxPreloadSelfTest.java | 2 +- ...rtitionedAffinityHashIdResolverSelfTest.java | 16 +- .../GridCachePartitionedAffinitySelfTest.java | 2 - .../near/GridCachePartitionedBasicApiTest.java | 3 +- ...ePartitionedBasicStoreMultiNodeSelfTest.java | 3 +- ...ionedClientOnlyNoPrimaryFullApiSelfTest.java | 15 +- .../near/GridCachePartitionedEventSelfTest.java | 3 +- .../GridCachePartitionedEvictionSelfTest.java | 2 +- ...titionedExplicitLockNodeFailureSelfTest.java | 2 +- ...GridCachePartitionedFilteredPutSelfTest.java | 3 +- .../GridCachePartitionedFullApiSelfTest.java | 1 - ...idCachePartitionedHitsAndMissesSelfTest.java | 10 +- .../GridCachePartitionedLoadCacheSelfTest.java | 3 +- ...achePartitionedMultiNodeCounterSelfTest.java | 3 +- ...achePartitionedMultiNodeFullApiSelfTest.java | 25 +- ...idCachePartitionedMultiNodeLockSelfTest.java | 3 +- .../GridCachePartitionedMultiNodeSelfTest.java | 2 - ...ePartitionedMultiThreadedPutGetSelfTest.java | 9 +- ...itionedNearOnlyNoPrimaryFullApiSelfTest.java | 6 +- ...GridCachePartitionedNodeFailureSelfTest.java | 2 - .../GridCachePartitionedNodeRestartTest.java | 3 +- ...achePartitionedPreloadLifecycleSelfTest.java | 1 - .../GridCachePartitionedStorePutSelfTest.java | 2 +- .../GridCachePartitionedTxSalvageSelfTest.java | 3 +- ...achePartitionedTxSingleThreadedSelfTest.java | 1 - ...idCacheRendezvousAffinityClientSelfTest.java | 2 +- .../near/GridPartitionedBackupLoadSelfTest.java | 2 +- .../near/IgniteCacheNearReadCommittedTest.java | 5 +- ...stractReplicatedByteArrayValuesSelfTest.java | 1 - .../GridCacheReplicatedEvictionSelfTest.java | 5 +- .../GridCacheReplicatedFullApiSelfTest.java | 5 +- .../GridCacheReplicatedTxExceptionSelfTest.java | 6 +- ...ssimisticOriginatingNodeFailureSelfTest.java | 7 +- .../GridCacheSyncReplicatedPreloadSelfTest.java | 3 +- .../GridCacheBatchEvictUnswapSelfTest.java | 6 +- ...heConcurrentEvictionConsistencySelfTest.java | 3 +- .../GridCacheConcurrentEvictionsSelfTest.java | 9 +- .../GridCacheDistributedEvictionsSelfTest.java | 42 +- .../GridCacheEmptyEntriesAbstractSelfTest.java | 5 +- .../eviction/GridCacheEvictionAbstractTest.java | 20 +- .../GridCacheEvictionFilterSelfTest.java | 18 +- .../GridCacheEvictionLockUnlockSelfTest.java | 12 +- .../GridCacheEvictionTouchSelfTest.java | 2 +- ...cheSynchronousEvictionsFailoverSelfTest.java | 5 +- .../GridCacheLruNearEvictionPolicySelfTest.java | 6 +- ...heNearOnlyLruNearEvictionPolicySelfTest.java | 11 +- .../IgniteCacheAtomicExpiryPolicyTest.java | 6 +- .../IgniteCacheAtomicLocalExpiryPolicyTest.java | 6 +- ...maryWriteOrderWithStoreExpiryPolicyTest.java | 6 +- ...iteCacheAtomicWithStoreExpiryPolicyTest.java | 6 +- .../IgniteCacheExpiryPolicyAbstractTest.java | 11 +- ...eCacheExpiryPolicyWithStoreAbstractTest.java | 10 +- .../expiry/IgniteCacheTxExpiryPolicyTest.java | 6 +- .../IgniteCacheTxLocalExpiryPolicyTest.java | 6 +- .../IgniteCacheTxWithStoreExpiryPolicyTest.java | 6 +- .../IgniteCacheAtomicLoadAllTest.java | 6 +- .../IgniteCacheAtomicLoaderWriterTest.java | 6 +- .../IgniteCacheAtomicLocalLoadAllTest.java | 6 +- ...CacheAtomicLocalNoLoadPreviousValueTest.java | 6 +- ...IgniteCacheAtomicLocalNoReadThroughTest.java | 6 +- ...gniteCacheAtomicLocalNoWriteThroughTest.java | 6 +- ...tomicNearEnabledNoLoadPreviousValueTest.java | 8 +- ...CacheAtomicNearEnabledNoReadThroughTest.java | 8 +- ...acheAtomicNearEnabledNoWriteThroughTest.java | 8 +- ...gniteCacheAtomicNoLoadPreviousValueTest.java | 6 +- .../IgniteCacheAtomicNoReadThroughTest.java | 6 +- .../IgniteCacheAtomicNoWriteThroughTest.java | 6 +- .../IgniteCacheAtomicStoreSessionTest.java | 6 +- .../IgniteCacheLoadAllAbstractTest.java | 107 +- .../IgniteCacheLoaderWriterAbstractTest.java | 12 +- ...iteCacheNoLoadPreviousValueAbstractTest.java | 5 +- .../IgniteCacheNoReadThroughAbstractTest.java | 63 +- .../IgniteCacheNoWriteThroughAbstractTest.java | 5 +- .../IgniteCacheStoreSessionAbstractTest.java | 4 +- ...acheStoreSessionWriteBehindAbstractTest.java | 11 +- .../integration/IgniteCacheTxLoadAllTest.java | 6 +- .../IgniteCacheTxLoaderWriterTest.java | 6 +- .../IgniteCacheTxLocalLoadAllTest.java | 5 +- ...niteCacheTxLocalNoLoadPreviousValueTest.java | 6 +- .../IgniteCacheTxLocalNoReadThroughTest.java | 6 +- .../IgniteCacheTxLocalNoWriteThroughTest.java | 6 +- ...cheTxNearEnabledNoLoadPreviousValueTest.java | 8 +- ...niteCacheTxNearEnabledNoReadThroughTest.java | 8 +- ...iteCacheTxNearEnabledNoWriteThroughTest.java | 8 +- .../IgniteCacheTxNoLoadPreviousValueTest.java | 6 +- .../IgniteCacheTxNoReadThroughTest.java | 6 +- .../IgniteCacheTxNoWriteThroughTest.java | 6 +- .../IgniteCacheTxStoreSessionTest.java | 6 +- ...dCacheAtomicLocalMetricsNoStoreSelfTest.java | 13 +- .../GridCacheLocalByteArrayValuesSelfTest.java | 1 - .../local/GridCacheLocalLoadAllSelfTest.java | 2 +- ...ridCacheContinuousQueryAbstractSelfTest.java | 93 +- ...ontinuousQueryAtomicNearEnabledSelfTest.java | 8 +- .../GridCacheContinuousQueryAtomicSelfTest.java | 6 +- ...eContinuousQueryPartitionedOnlySelfTest.java | 6 +- .../DataStreamProcessorSelfTest.java | 33 +- .../IgniteDataStreamerPerformanceTest.java | 5 +- .../processors/igfs/IgfsAbstractSelfTest.java | 2 +- ...sCachePerBlockLruEvictionPolicySelfTest.java | 8 +- .../processors/igfs/IgfsCacheSelfTest.java | 4 +- .../igfs/IgfsDataManagerSelfTest.java | 2 +- .../igfs/IgfsMetaManagerSelfTest.java | 3 +- .../processors/igfs/IgfsMetricsSelfTest.java | 8 +- .../processors/igfs/IgfsModesSelfTest.java | 4 +- .../processors/igfs/IgfsProcessorSelfTest.java | 2 +- .../processors/igfs/IgfsSizeSelfTest.java | 4 +- .../processors/igfs/IgfsStreamsSelfTest.java | 2 +- .../processors/igfs/IgfsTaskSelfTest.java | 4 +- .../IgfsAbstractRecordResolverSelfTest.java | 3 +- .../ipc/shmem/IpcSharedMemoryNodeStartup.java | 3 +- .../unsafe/GridUnsafeMemorySelfTest.java | 1 + .../GridCircularBufferPerformanceTest.java | 1 + .../loadtests/GridCacheMultiNodeLoadTest.java | 3 +- .../cache/GridCachePutRemoveLoadTest.java | 373 ---- .../cache/GridCacheSingleNodeLoadTest.java | 182 -- .../GridCacheWriteBehindStoreLoadTest.java | 2 +- .../communication/GridIoManagerBenchmark0.java | 1 + .../GridCachePartitionedAtomicLongLoadTest.java | 1 - ...dBoundedConcurrentLinkedHashSetLoadTest.java | 2 +- .../loadtests/hashmap/GridCacheTestContext.java | 1 + .../OptimizedMarshallerNodeFailoverTest.java | 2 + ...arshallerSerialPersistentFieldsSelfTest.java | 110 + .../discovery/AbstractDiscoverySelfTest.java | 2 +- .../tcp/TcpDiscoverySpiStartStopSelfTest.java | 2 +- .../GridCacheStoreValueBytesNode.java | 132 -- .../GridCacheStoreValueBytesTest.java | 343 --- .../ignite/testframework/GridTestUtils.java | 29 +- .../testframework/junits/GridAbstractTest.java | 134 +- .../ignite/testframework/junits/IgniteMock.java | 26 + .../junits/common/GridAbstractExamplesTest.java | 2 +- .../junits/common/GridCommonAbstractTest.java | 3 +- .../junits/spi/GridSpiAbstractTest.java | 5 +- .../ignite/testsuites/IgniteCacheTestSuite.java | 2 + .../IgniteMarshallerSelfTestSuite.java | 1 + .../webapp/META-INF/ignite-webapp-config.xml | 7 +- modules/core/src/test/webapp/WEB-INF/web.xml | 2 +- .../tests/p2p/GridExternalAffinityFunction.java | 2 +- .../processors/hadoop/HadoopContext.java | 4 +- .../HadoopExternalCommunication.java | 4 +- .../HadoopIgfs20FileSystemAbstractSelfTest.java | 4 +- .../igfs/HadoopIgfsDualAbstractSelfTest.java | 2 +- ...oopSecondaryFileSystemConfigurationTest.java | 4 +- .../igfs/IgfsNearOnlyMultiNodeSelfTest.java | 27 +- .../IgniteHadoopFileSystemAbstractSelfTest.java | 4 +- .../IgniteHadoopFileSystemClientSelfTest.java | 3 +- ...IgniteHadoopFileSystemHandshakeSelfTest.java | 3 +- .../IgniteHadoopFileSystemIpcCacheSelfTest.java | 2 +- ...niteHadoopFileSystemLoggerStateSelfTest.java | 2 +- ...teHadoopFileSystemSecondaryModeSelfTest.java | 4 +- .../taskexecutor/HadoopExecutorServiceTest.java | 1 + .../HibernateL2CacheConfigurationSelfTest.java | 4 +- .../hibernate/HibernateL2CacheSelfTest.java | 4 +- .../HibernateL2CacheTransactionalSelfTest.java | 3 +- .../processors/query/h2/IgniteH2Indexing.java | 34 +- .../query/h2/opt/GridLuceneIndex.java | 1 + .../query/h2/sql/GridSqlQueryParser.java | 1 + .../GridCacheAbstractFieldsQuerySelfTest.java | 4 +- .../cache/GridCacheCrossCacheQuerySelfTest.java | 2 - .../cache/GridCacheOffHeapAndSwapSelfTest.java | 4 +- .../cache/GridCacheQuerySimpleBenchmark.java | 1 + .../cache/GridIndexingWithNoopSwapSelfTest.java | 3 +- .../cache/IgniteCacheAbstractQuerySelfTest.java | 33 +- ...hePartitionedQueryMultiThreadedSelfTest.java | 2 - .../cache/IgniteCacheQueryLoadSelfTest.java | 2 +- .../IgniteCacheQueryMultiThreadedSelfTest.java | 1 - ...gniteCacheSqlQueryMultiThreadedSelfTest.java | 4 +- ...GridCachePartitionedFieldsQuerySelfTest.java | 7 +- .../IgniteCacheAtomicFieldsQuerySelfTest.java | 6 +- ...cheAtomicNearEnabledFieldsQuerySelfTest.java | 8 +- ...niteCachePartitionedFieldsQuerySelfTest.java | 6 +- .../IgniteCacheQueryNodeRestartSelfTest.java | 3 +- ...dCacheAbstractReduceFieldsQuerySelfTest.java | 7 +- ...ridCacheReduceFieldsQueryAtomicSelfTest.java | 6 +- .../query/h2/sql/GridQueryParsingTest.java | 2 +- .../GridTmLookupLifecycleAwareSelfTest.java | 12 +- .../scala/org/apache/ignite/scalar/scalar.scala | 19 +- .../scalar/src/test/resources/spring-cache.xml | 6 +- .../test/resources/spring-ping-pong-partner.xml | 2 +- .../ignite/schema/ui/SchemaImportApp.java | 133 +- .../org/apache/ignite/IgniteSpringBean.java | 36 + .../ignite/cache/spring/SpringCacheManager.java | 6 +- .../ignite/visor/commands/VisorConsole.scala | 6 +- .../commands/cache/VisorCacheCommand.scala | 17 +- .../visor/commands/logo_ignite_128x128.png | Bin 18667 -> 0 bytes .../ignite/visor/commands/logo_ignite_48x48.png | Bin 16572 -> 0 bytes .../scala/org/apache/ignite/visor/visor.scala | 2 +- .../cache/websession/IgniteWebSession.java | 286 --- .../websession/IgniteWebSessionFilter.java | 466 ---- .../websession/IgniteWebSessionListener.java | 196 -- .../ignite/cache/websession/WebSession.java | 286 +++ .../cache/websession/WebSessionFilter.java | 467 ++++ .../cache/websession/WebSessionListener.java | 196 ++ .../IgniteServletContextListenerStartup.java | 181 -- .../startup/servlet/IgniteServletStartup.java | 187 -- .../servlet/ServletContextListenerStartup.java | 181 ++ .../ignite/startup/servlet/ServletStartup.java | 187 ++ .../org/apache/ignite/yardstick/IgniteNode.java | 4 +- pom.xml | 6 +- 765 files changed, 14453 insertions(+), 11584 deletions(-) ---------------------------------------------------------------------- http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c42bf53c/modules/core/src/main/java/org/apache/ignite/IgniteDataStreamer.java ---------------------------------------------------------------------- diff --cc modules/core/src/main/java/org/apache/ignite/IgniteDataStreamer.java index 72fa6a7,ddfd7a0..46b9598 --- a/modules/core/src/main/java/org/apache/ignite/IgniteDataStreamer.java +++ b/modules/core/src/main/java/org/apache/ignite/IgniteDataStreamer.java @@@ -18,10 -18,9 +18,10 @@@ package org.apache.ignite; import org.apache.ignite.lang.*; + import org.apache.ignite.stream.*; import org.jetbrains.annotations.*; +import javax.cache.*; - import java.io.*; import java.util.*; /** @@@ -376,27 -375,9 +376,9 @@@ public interface IgniteDataStreamer<K, * The method is invoked automatically on objects managed by the * {@code try-with-resources} statement. * - * @throws IgniteException If failed to close data streamer. + * @throws CacheException If failed to close data streamer. * @throws IgniteInterruptedException If thread has been interrupted. */ - @Override public void close() throws IgniteException, IgniteInterruptedException; + @Override public void close() throws CacheException, IgniteInterruptedException; - /** - * Updates cache with batch of entries. Usually it is enough to configure {@link IgniteDataStreamer#allowOverwrite(boolean)} - * property and appropriate internal cache updater will be chosen automatically. But in some cases to achieve best - * performance custom user-defined implementation may help. - * <p> - * Data streamer can be configured to use custom implementation of updater instead of default one using - * {@link IgniteDataStreamer#updater(IgniteDataStreamer.Updater)} method. - */ - interface Updater<K, V> extends Serializable { - /** - * Updates cache with batch of entries. - * - * @param cache Cache. - * @param entries Collection of entries. - * @throws CacheException If failed. - */ - public void update(IgniteCache<K, V> cache, Collection<Map.Entry<K, V>> entries) throws CacheException; - } } http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c42bf53c/modules/core/src/main/java/org/apache/ignite/internal/processors/datastreamer/DataStreamerImpl.java ---------------------------------------------------------------------- diff --cc modules/core/src/main/java/org/apache/ignite/internal/processors/datastreamer/DataStreamerImpl.java index 9d6bd62,05e7b44..2e438d1 --- a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastreamer/DataStreamerImpl.java +++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastreamer/DataStreamerImpl.java @@@ -306,9 -306,9 +307,9 @@@ public class DataStreamerImpl<K, V> imp ClusterNode node = F.first(ctx.grid().cluster().forCacheNodes(cacheName).nodes()); if (node == null) - throw new IgniteException("Failed to get node for cache: " + cacheName); + throw new CacheException("Failed to get node for cache: " + cacheName); - updater = allow ? DataStreamerCacheUpdaters.<K, V>individual() : ISOLATED_UPDATER; + rcvr = allow ? DataStreamerCacheUpdaters.<K, V>individual() : ISOLATED_UPDATER; } /** {@inheritDoc} */