|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testPrimarySync() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheAbstractPrimarySyncSelfTest |
From |
To |
|
Change Variable Type c : Cache<Object,Object> to c : GridCache<Object,Object> in method public run() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedTxSalvageSelfTest.startTxAndPutKeys.fut.multithreadedAsync |
From |
To |
|
Change Variable Type near : Cache<Integer,String> to near : GridCache<Integer,String> in method public testReadThrough() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private checkDoubleGet(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation, put boolean) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiGetSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testPrimitiveType() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testMultithreadedPutAll() : void in class org.apache.ignite.cache.store.jdbc.GridCacheJdbcBlobStoreMultithreadedSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,ObjectValue> to cache2 : GridCache<Integer,ObjectValue> in method public testLuceneIndex2() : void in class org.apache.ignite.internal.processors.cache.GridCacheLuceneQueryIndexTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,TestValue1> to cache1 : GridCache<Integer,TestValue1> in method public testRebuildInterrupted() : void in class org.apache.ignite.internal.processors.query.h2.GridH2IndexRebuildTest |
From |
To |
|
Change Variable Type cache2 : Cache<String,Integer> to cache2 : GridCache<String,Integer> in method public _testJtaTwoCaches() : void in class org.apache.ignite.internal.processors.cache.GridCacheJtaSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testForAll() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiMultithreadedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testLocalNodeOnly() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private getAndSet(cacheName String) : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheAtomicLongApiSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,String> to cache1 : GridCache<Integer,String> in method public testBackupEntryReaders() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearReadersSelfTest |
From |
To |
|
Change Variable Type c : Cache<Object,Object> to c : GridCache<Object,Object> in method public route(ctx StreamerContext, stageName String, evt T) : ClusterNode in class org.apache.ignite.streamer.router.StreamerCacheAffinityEventRouter |
From |
To |
|
Change Variable Type myCache : Cache<String,Integer> to myCache : GridCache<String,Integer> in method public testFilteredKeySet() : void in class org.apache.ignite.internal.processors.cache.local.GridCacheLocalFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method public testTwoAnonymousClasses() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type dhtCache : Cache<Integer,String> to dhtCache : GridCache<Integer,String> in method public testReadThrough() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,String> to cache2 : GridCache<Integer,String> in method public testBatchSize1000() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testRestart() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheAbstractNodeRestartSelfTest |
From |
To |
|
Change Variable Type primary : Cache<String,Integer> to primary : GridCache<String,Integer> in method public testClear() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicNearOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private performTest() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadPutGetSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testLimitOnly() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,ObjectValue> to cache2 : GridCache<Integer,ObjectValue> in method public testLuceneIndex() : void in class org.apache.ignite.internal.processors.cache.GridCacheLuceneQueryIndexTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,String> to cache2 : GridCache<Integer,String> in method public testSync() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method private checkActiveState(grids Iterable<Ignite>) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadSelfTest |
From |
To |
|
Change Variable Type c : Cache<Object,Object> to c : GridCache<Object,Object> in method private checkMultiUpdateLocks(nearEnabled boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheMultiUpdateLockSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<Integer,Integer> to cache0 : GridCache<Integer,Integer> in method public testPrimaryRead() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMetricsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public call() : Void in class org.apache.ignite.internal.processors.cache.distributed.IgniteTxPessimisticOriginatingNodeFailureAbstractSelfTest.checkPrimaryNodeCrash.call |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private put(o Object, cacheKey Object) : void in class org.apache.ignite.loadtests.dsi.GridDsiPerfJob |
From |
To |
|
Change Variable Type cache2 : Cache<Object,Object> to cache2 : GridCache<Object,Object> in method private testCacheUsage(expCache1 int, expCache2 int, expCache3 int, expCacheE3 int, expCacheE4 int) : void in class org.apache.ignite.cache.hibernate.GridHibernateL2CacheConfigurationSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,Object> to cache2 : GridCache<Integer,Object> in method public testSwapDeployment() : void in class org.apache.ignite.internal.processors.cache.GridCacheSwapSelfTest |
From |
To |
|
Change Variable Type cache : Cache<?,?> to cache : GridCache<?,?> in method private sqlFieldsQuery() : void in class org.apache.ignite.examples.datagrid.CacheQueryExample |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testTxConsistency() : void in class org.apache.ignite.internal.processors.cache.distributed.IgniteTxConsistencyRestartAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public execute() : Object in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockPutTask.map.singletonMap |
From |
To |
|
Change Variable Type cache : Cache<?,?> to cache : GridCache<?,?> in method public execute() : Object in class org.apache.ignite.internal.processors.cache.query.jdbc.GridCacheQueryJdbcMetadataTask.JdbcDriverMetadataJob |
From |
To |
|
Change Variable Type cache3 : Cache<String,String> to cache3 : GridCache<String,String> in method public testBasicOps() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheBasicOpAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testAffinity() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<UUID>,Person> to cache : GridCache<CacheAffinityKey<UUID>,Person> in method private sqlQueryWithJoin() : void in class org.apache.ignite.examples.datagrid.CacheQueryExample |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testAllEntries() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<GridTestKey,Long> to cache : GridCache<GridTestKey,Long> in method public onLifecycleEvent(type LifecycleEventType) : void in class org.apache.ignite.loadtests.colocation.GridTestLifecycleBean |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private performanceTest() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testOptimisticTransaction() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheColocatedOptimisticTransactionSelfTest |
From |
To |
|
Change Variable Type gCache : Cache<Object,Object> to gCache : GridCache<Object,Object> in method private checkGroupLockWithExternalLock(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<String,String> to cache2 : GridCache<String,String> in method public testOptimisticTransaction() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheBasicOpAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<String,Object> to cache : GridCache<String,Object> in method public main(args String[]) : void in class org.apache.ignite.examples.misc.client.memcache.MemcacheRestExample |
From |
To |
|
Change Variable Type cacheInner : Cache<Integer,String> to cacheInner : GridCache<Integer,String> in method public testOptimisticTransaction() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheColocatedOptimisticTransactionSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,ValueObject> to cache : GridCache<Integer,ValueObject> in method public testLoadCache() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryLoadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,TestValue> to cache : GridCache<Integer,TestValue> in method private asyncOpsAsyncCommitCallable() : Callable<Collection<WeakReference<Object>>> in class org.apache.ignite.internal.processors.cache.GridCacheReferenceCleanupSelfTest |
From |
To |
|
Change Variable Type factCache : Cache<Integer,Object> to factCache : GridCache<Integer,Object> in method private populateFacts() : void in class org.apache.ignite.examples.datagrid.starschema.CacheStarSchemaExample |
From |
To |
|
Change Variable Type cache0 : Cache<Integer,Integer> to cache0 : GridCache<Integer,Integer> in method public testBackupPut() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMetricsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,TestValue> to cache : GridCache<Integer,TestValue> in method private severalAsyncOpsCallable() : Callable<Collection<WeakReference<Object>>> in class org.apache.ignite.internal.processors.cache.GridCacheReferenceCleanupSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testRemove() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiMultithreadedSelfTest |
From |
To |
|
Change Variable Type c : Cache<Object,Object> to c : GridCache<Object,Object> in method protected run(arg VisorQueryArg) : IgniteBiTuple<? extends Exception,VisorQueryResultEx> in class org.apache.ignite.internal.visor.query.VisorQueryTask.VisorQueryJob |
From |
To |
|
Change Variable Type cache0 : Cache<Integer,Integer> to cache0 : GridCache<Integer,Integer> in method private checkPut(grid int) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheAtomicNearCacheSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Long,Long> to cache : GridCache<Long,Long> in method private populate() : GridCache<Long,Long> in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapAndSwapSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,String> to cache1 : GridCache<Integer,String> in method private checkPuts(cnt int, ignites Ignite...) : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheMultiNodeAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testStopByCallback() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testForceTransformBackupConsistency() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.atomic.GridCacheValueConsistencyAtomicSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testTimeInterval() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type namedCache : Cache<Object,Object> to namedCache : GridCache<Object,Object> in method public testPut() : void in class org.apache.ignite.client.integration.ClientAbstractSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,String> to cache1 : GridCache<Integer,String> in method public testAsync() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method private populateDimensions() : void in class org.apache.ignite.examples.datagrid.starschema.CacheStarSchemaExample |
From |
To |
|
Change Variable Type gCache : Cache<Object,Object> to gCache : GridCache<Object,Object> in method private checkGroupLockPutOneKey(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testReloadAll() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testBackupLoad() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridPartitionedBackupLoadSelfTest |
From |
To |
|
Change Variable Type checkCache : Cache<Integer,String> to checkCache : GridCache<Integer,String> in method public testLock() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheNodeFailureAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<String,Person> to cache : GridCache<String,Person> in method protected beforeTestsStarted() : void in class org.apache.ignite.jdbc.JdbcStatementSelfTest |
From |
To |
|
Change Variable Type firstCache : Cache<Integer,String> to firstCache : GridCache<Integer,String> in method public testSynchronousCommit() : void in class org.apache.ignite.internal.processors.cache.GridCacheReplicatedSynchronousCommitTest |
From |
To |
|
Change Variable Type prj0 : Cache<Object,Object> to prj0 : GridCache<Object,Object> in method public testPutAllPutAll() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private visitUsingAffinityRun() : void in class org.apache.ignite.examples.datagrid.CacheAffinityExample |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testReloadCache() : void in class org.apache.ignite.internal.processors.cache.GridCacheBasicStoreAbstractTest |
From |
To |
|
Change Variable Type c2 : Cache<String,MyValue> to c2 : GridCache<String,MyValue> in method public checkCache(keys Object[]) : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadLifecycleSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testPolicyConsistency() : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheEvictionTouchSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testRestarts() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheQueryNodeRestartSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testLockAsyncWithTimeoutEntryBackup() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Object,Object> to cache1 : GridCache<Object,Object> in method public testUnswapAdvanced() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.GridCacheReplicatedUnswapAdvancedSelfTest |
From |
To |
|
Change Variable Type data : Cache<Integer,Integer> to data : GridCache<Integer,Integer> in method public testSecondCachePutRemove() : void in class org.apache.ignite.spi.checkpoint.cache.GridCacheCheckpointSpiSecondCacheSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private checkNearEvictionMaxSize() : void in class org.apache.ignite.internal.processors.cache.eviction.lru.GridCacheNearOnlyLruNearEvictionPolicySelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<Integer>,Integer> to cache : GridCache<CacheAffinityKey<Integer>,Integer> in method private checkUpdateEntry(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheGroupLockPartitionedAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testInternalKeysPreloading() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryInternalKeysSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method public testReduceQuery() : void in class org.apache.ignite.internal.processors.cache.GridCacheReduceQueryMultithreadedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testSwapIterator() : void in class org.apache.ignite.internal.processors.cache.GridCacheSwapSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,CacheValue> to cache : GridCache<Integer,CacheValue> in method public testWithoutStoreLoad() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryIndexSelfTest |
From |
To |
|
Change Variable Type dht : Cache<Integer,String> to dht : GridCache<Integer,String> in method public testReadThrough() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOneNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testDeployment5() : void in class org.apache.ignite.internal.processors.cache.GridCacheDeploymentSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,String> to cache2 : GridCache<Integer,String> in method public testAsync() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,EnemyCamp> to cache2 : GridCache<Integer,EnemyCamp> in method public testGeoMultithreaded() : void in class org.apache.ignite.internal.processors.query.h2.GridH2IndexingGeoSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private checkSingleLock(key int) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private checkRestarts(writeOrder CacheAtomicWriteOrderMode, writeSync CacheWriteSynchronizationMode) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.atomic.GridCacheAtomicInvalidPartitionHandlingSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testRollbacks(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation, put boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheTransactionalAbstractMetricsSelfTest |
From |
To |
|
Change Variable Type c2 : Cache<Object,MyValue> to c2 : GridCache<Object,MyValue> in method public checkScanQuery(keys Object[]) : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadLifecycleSelfTest |
From |
To |
|
Change Variable Type metaCache : Cache to metaCache : GridCache in method public testConfiguration() : void in class org.apache.ignite.internal.processors.fs.GridGgfsStreamsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method protected keys() : Collection<Integer> in class org.apache.ignite.internal.processors.cache.integration.IgniteCacheNoReadThroughAbstractTest |
From |
To |
|
Change Variable Type cache0 : Cache<Integer,String> to cache0 : GridCache<Integer,String> in method public testLocalLoadCache() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedLoadCacheSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<String,Integer> to cache0 : GridCache<String,Integer> in method public testExpiredEntriesPreloading() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheExpiredEntriesPreloadAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private checkSwap() : void in class org.apache.ignite.internal.processors.cache.GridCacheSwapPreloadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testMultithreadedExplicitTx() : void in class org.apache.ignite.cache.store.jdbc.GridCacheJdbcBlobStoreMultithreadedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testStop(startTx boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheStopSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testLargeObjects() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadBigDataSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testReload() : void in class org.apache.ignite.internal.processors.cache.GridCacheBasicStoreAbstractTest |
From |
To |
|
Change Variable Type c : Cache<Object,Object> to c : GridCache<Object,Object> in method protected beforeTest() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryMultiThreadedSelfTest |
From |
To |
|
Change Variable Type nearOnlyCache : Cache<Object,Object> to nearOnlyCache : GridCache<Object,Object> in method public testUpdateNearOnlyReader() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOnlySelfTest |
From |
To |
|
Change Variable Type cache : Cache<?,?> to cache : GridCache<?,?> in method private doWarmup(grids Iterable<Ignite>) : void in class org.apache.ignite.IgniteBasicWarmupClosure |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testNonPersistentMode() : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheAtomicReferenceApiSelfAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private checkSingleWrites() : void in class org.apache.ignite.internal.processors.cache.GridCacheWriteBehindStorePartitionedMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,String> to cache1 : GridCache<Integer,String> in method public testTwoNodesTwoKeysNoBackups() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearReadersSelfTest |
From |
To |
|
Change Variable Type cache : Cache<?,?> to cache : GridCache<?,?> in method private cleanup() : void in class org.apache.ignite.cache.hibernate.GridHibernateL2CacheSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testProjectionFiltered() : void in class org.apache.ignite.internal.processors.cache.GridCacheIteratorPerformanceTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testPutAndRollbackCheckDht() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedFilteredPutSelfTest |
From |
To |
|
Change Variable Type cache : Cache<IncorrectCacheKey,String> to cache : GridCache<IncorrectCacheKey,String> in method private checkGet(atomicityMode CacheAtomicityMode) : void in class org.apache.ignite.internal.processors.cache.GridCacheKeyCheckSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testPutGetRemoveObject() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method public testTestSyncCommitFlag() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFlagsTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public performTest() : void in class org.apache.ignite.internal.processors.cache.GridCacheGlobalClearAllSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testPutWithFilterTx(key Integer, txConcurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapMultiThreadedUpdateSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method public testSwap() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheAbstractDistributedByteArrayValuesSelfTest |
From |
To |
|
Change Variable Type personCache : Cache<CacheAffinityKey<String>,Person> to personCache : GridCache<CacheAffinityKey<String>,Person> in method protected beforeTestsStarted() : void in class org.apache.ignite.jdbc.JdbcMetadataSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testAddDataFromMap() : void in class org.apache.ignite.internal.processors.dataload.GridDataLoaderImplSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method public call() : Object in class org.apache.ignite.internal.processors.cache.GridCacheFinishPartitionsSelfTest.runTransactions.runMultiThreaded |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method protected afterTest() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiGetSelfTest |
From |
To |
|
Change Variable Type c0 : Cache<String,Integer> to c0 : GridCache<String,Integer> in method public testAutomaticPreload() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadDelayedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testPutIfAbsentFromBackup() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedBasicStoreMultiNodeSelfTest |
From |
To |
|
Change Variable Type c : Cache<UUID,Person> to c : GridCache<UUID,Person> in method public testLuceneReduceQuery() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedQuerySelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Object,Object> to cache2 : GridCache<Object,Object> in method public testUnswapAdvanced() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.GridCacheReplicatedUnswapAdvancedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testPutTx(key Integer, txConcurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapMultiThreadedUpdateSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testNearUpdateRequestLost() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheAtomicTimeoutSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testLocalSync() : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheDistributedEvictionsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testPaginationGet0() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedQuerySelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,String> to cache2 : GridCache<Integer,String> in method public testBatchSize10000() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testRemoveInTxSimple() : void in class org.apache.ignite.internal.processors.cache.IgniteTxMultiNodeAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method protected keys() : Collection<Integer> in class org.apache.ignite.internal.processors.cache.integration.IgniteCacheNoWriteThroughAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method protected checkTransactionalRead(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractTxReadTest |
From |
To |
|
Change Variable Type c : Cache<GridSpringCacheTestKey,String> to c : GridCache<GridSpringCacheTestKey,String> in method public testComplexKeyEvict() : void in class org.apache.ignite.spring.GridSpringCacheManagerSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,ValueObject> to cache : GridCache<Integer,ValueObject> in method public testReloadAll() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryLoadSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private getAndAdd(cacheName String) : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheAtomicLongApiSelfTest |
From |
To |
|
Change Variable Type eCache : Cache<Integer,String> to eCache : GridCache<Integer,String> in method public testReloadAll() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCachePartitionedReloadAllAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method private doFilteredPut() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedFilteredPutSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,Object> to cache2 : GridCache<Integer,Object> in method private checkP2PUndeploy(cacheName String) : void in class org.apache.ignite.internal.processors.cache.GridCacheP2PUndeploySelfTest |
From |
To |
|
Change Variable Type cache : Cache<GridTestKey,Long> to cache : GridCache<GridTestKey,Long> in method private colocateJobs() : void in class org.apache.ignite.loadtests.colocation.GridTestMain |
From |
To |
|
Change Variable Type cache0 : Cache<Object,Object> to cache0 : GridCache<Object,Object> in method private doWarmup(grids Iterable<Ignite>) : void in class org.apache.ignite.IgniteBasicWarmupClosure |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method private onItemNear(putCntr boolean, ignite Ignite, itemKey String, retry int) : void in class org.apache.ignite.internal.processors.cache.IgniteTxMultiNodeAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testCommits(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation, put boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheTransactionalAbstractMetricsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testUpdateInFilter() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type gCache : Cache<Object,Object> to gCache : GridCache<Object,Object> in method private checkGroupLockRemoveOneKey(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method public testCompareAndSet() : void in class org.apache.ignite.client.integration.ClientAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testClientNode() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheRendezvousAffinityClientSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<UUID,Person> to cache0 : GridCache<UUID,Person> in method public testMultipleNodesQuery() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private checkToString() : void in class org.apache.ignite.internal.processors.cache.GridCacheObjectToStringSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method public testReduceQuery() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testEmptyGrid() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type c0 : Cache<String,Integer> to c0 : GridCache<String,Integer> in method public testManualPreload() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadDelayedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private checkPuts(cnt int, ignites Ignite...) : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheMultiNodeAbstractTest |
From |
To |
|
Change Variable Type c1 : Cache<String,MyValue> to c1 : GridCache<String,MyValue> in method public checkCache(keys Object[]) : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadLifecycleSelfTest |
From |
To |
|
Change Variable Type checkCache : Cache<Integer,String> to checkCache : GridCache<Integer,String> in method public testLockFromNearOrBackup() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedExplicitLockNodeFailureSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public call() : Void in class org.apache.ignite.internal.processors.cache.distributed.IgniteTxOriginatingNodeFailureAbstractSelfTest.testTxOriginatingNodeFails.call |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method public testAnonymousClasses() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<String,Integer> to cache0 : GridCache<String,Integer> in method public testPutRemove() : void in class org.apache.ignite.internal.processors.cache.GridCacheValueConsistencyAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<K,V> to cache : GridCache<K,V> in method public waitTopologyUpdate(cacheName String, backups int, log IgniteLogger) : void in class org.apache.ignite.testframework.GridTestUtils |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testReloadAsync() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,TestObject> to cache : GridCache<Integer,TestObject> in method protected beforeTestsStarted() : void in class org.apache.ignite.jdbc.JdbcPreparedStatementSelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<String>,String> to cache : GridCache<CacheAffinityKey<String>,String> in method private checkGetPut(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testFilteredPut() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheEventAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method protected beforeTest() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredEvictionAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Long> to c : GridCache<Integer,Long> in method public testMultiThreadedSwapUnswapLong() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryMultiThreadedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testIteration() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private doTest() : void in class org.apache.ignite.internal.processors.cache.GridCacheReloadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testPartitionEntrySetRemove() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedFullApiSelfTest |
From |
To |
|
Change Variable Type c1 : Cache<String,Integer> to c1 : GridCache<String,Integer> in method public testAutomaticPreload() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadDelayedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testPaginationIterator(cacheName String) : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,Object> to cache2 : GridCache<Integer,Object> in method public testDeployment() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testLock() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheNodeFailureAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Integer> to cache : GridCache<Object,Integer> in method public testPartitionGroupLock() : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheEvictionTouchSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public _testGettingRemovedKey() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedNearDisabledMetricsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testExpiration() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testPutGet(key Integer) : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapMultiThreadedUpdateAbstractSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,ObjectValue> to cache1 : GridCache<Integer,ObjectValue> in method public testLuceneIndex2() : void in class org.apache.ignite.internal.processors.cache.GridCacheLuceneQueryIndexTest |
From |
To |
|
Change Variable Type strCache : Cache<String,String> to strCache : GridCache<String,String> in method protected beforeTestsStarted() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFieldsQuerySelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<String,String> to cache2 : GridCache<String,String> in method public testBasicOps() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheBasicOpAbstractTest |
From |
To |
|
Change Variable Type prj0 : Cache<Object,Object> to prj0 : GridCache<Object,Object> in method public testPutAllManyKeysTwoReaders() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearReadersSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testTypeProjection() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractProjectionSelfTest |
From |
To |
|
Change Variable Type c2 : Cache<String,Integer> to c2 : GridCache<String,Integer> in method public testManualPreload() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadDelayedSelfTest |
From |
To |
|
Change Variable Type near : Cache<Integer,String> to near : GridCache<Integer,String> in method public testNoTransactionSinglePutx() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<Integer,CacheValue> to cache0 : GridCache<Integer,CacheValue> in method public testWithStoreLoad() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryIndexSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testRemoveInTxQueried() : void in class org.apache.ignite.internal.processors.cache.IgniteTxMultiNodeAbstractTest |
From |
To |
|
Change Variable Type metaCache : Cache<IgniteUuid,GridGgfsFileInfo> to metaCache : GridCache<IgniteUuid,GridGgfsFileInfo> in method public testDeleteCacheConsistency() : void in class org.apache.ignite.internal.processors.fs.GridGgfsProcessorSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<Integer,Integer> to cache0 : GridCache<Integer,Integer> in method private checkReaderEvict() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheAtomicNearCacheSelfTest |
From |
To |
|
Change Variable Type c2 : Cache<Object,MyValue> to c2 : GridCache<Object,MyValue> in method public checkScanQuery(keys Object[]) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedPreloadLifecycleSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,EnemyCamp> to cache : GridCache<Integer,EnemyCamp> in method public call() : Void in class org.apache.ignite.internal.processors.query.h2.GridH2IndexingGeoSelfTest.testGeoMultithreaded.qryFut.runMultiThreadedAsync |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testDisabledPreloader() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadDisabledSelfTest |
From |
To |
|
Change Variable Type dht : Cache<Object,Object> to dht : GridCache<Object,Object> in method public testGetFromClientNode() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheClientModesAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public main(args String[]) : void in class org.apache.ignite.examples.datagrid.CacheAffinityExample |
From |
To |
|
Change Variable Type orgCache : Cache<String,Organization> to orgCache : GridCache<String,Organization> in method protected beforeTestsStarted() : void in class org.apache.ignite.jdbc.JdbcMetadataSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private compareAndSet(cacheName String) : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheAtomicLongApiSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,String> to cache1 : GridCache<Integer,String> in method public testBatchSize1() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type gCache : Cache<Object,Object> to gCache : GridCache<Object,Object> in method private checkGetAfterPut(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testFlush() : void in class org.apache.ignite.internal.processors.dataload.GridDataLoaderProcessorSelfTest |
From |
To |
|
Change Variable Type gCache : Cache<Object,Object> to gCache : GridCache<Object,Object> in method private checkGetPut(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,int[]> to c : GridCache<String,int[]> in method protected afterTest() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheAbstractJobExecutionTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testPutGetRemove() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testScanQueryEvents(customSubjId boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,TestValue> to cache : GridCache<Integer,TestValue> in method private syncOpAsyncCommitCallable() : Callable<Collection<WeakReference<Object>>> in class org.apache.ignite.internal.processors.cache.GridCacheReferenceCleanupSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testReload() : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheEvictionTouchSelfTest |
From |
To |
|
Change Variable Type caches : Collection<? extends Cache<?,?>> to caches : Collection<? extends GridCache<?,?>> in method protected run(arg IgniteBiTuple<Boolean,String>) : Map<String,VisorCacheMetrics> in class org.apache.ignite.internal.visor.cache.VisorCacheMetricsCollectorTask.VisorCacheMetricsJob |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testReadThrough() : void in class org.apache.ignite.internal.processors.cache.GridCacheWriteBehindStoreAbstractTest |
From |
To |
|
Change Variable Type mc : Cache<Integer,String> to mc : GridCache<Integer,String> in method public testAffinityWithPut() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedAffinitySelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,TestValue> to c : GridCache<Integer,TestValue> in method public testPromote() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredAbstractSelfTest |
From |
To |
|
Change Variable Type nearCache : Cache<String,Integer> to nearCache : GridCache<String,Integer> in method public testClear() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<ObjectKey,ObjectValue> to cache2 : GridCache<ObjectKey,ObjectValue> in method public testLuceneIndex3() : void in class org.apache.ignite.internal.processors.cache.GridCacheLuceneQueryIndexTest |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method public testSelectQuery() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type c2 : Cache<String,Integer> to c2 : GridCache<String,Integer> in method public testAutomaticPreload() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadDelayedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public call() : Void in class org.apache.ignite.internal.processors.cache.distributed.IgniteTxPessimisticOriginatingNodeFailureAbstractSelfTest.testTxOriginatingNodeFails.call |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testWritesReads() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractMetricsSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private decrementAndGet(cacheName String) : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheAtomicLongApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Person> to cache : GridCache<Integer,Person> in method public testQuery() : void in class org.apache.ignite.internal.processors.cache.GridCacheSqlQueryMultiThreadedSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private testAddMultinode(collocated boolean) : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheQueueMultiNodeAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private checkEvictions() : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheDistributedEvictionsSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,TestValue1> to cache1 : GridCache<Integer,TestValue1> in method public testRebuildIndexes() : void in class org.apache.ignite.internal.processors.query.h2.GridH2IndexRebuildTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method protected keys() : Collection<Integer> in class org.apache.ignite.internal.processors.cache.IgniteCacheInvokeAbstractTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private doWork() : void in class org.apache.ignite.loadtests.dsi.GridDsiPerfJob |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private checkLeak(mode CacheAtomicityMode) : void in class org.apache.ignite.internal.processors.cache.GridCacheLeakTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testWriteThrough() : void in class org.apache.ignite.internal.processors.cache.GridCacheBasicStoreAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private findAbsentKeys(workerNode Ignite, keys Collection<Integer>) : Collection<Integer> in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockFailoverSelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<UUID>,Person> to cache : GridCache<CacheAffinityKey<UUID>,Person> in method private sqlQuery() : void in class org.apache.ignite.examples.datagrid.CacheQueryExample |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testNodeLeft() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.GridCacheReplicatedQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method public testNamedCache() : void in class org.apache.ignite.marshaller.GridMarshallerAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<String>,String> to cache : GridCache<CacheAffinityKey<String>,String> in method private checkGroupLockPutWrongKey(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type nodeCache : Cache<String,Integer> to nodeCache : GridCache<String,Integer> in method public testPartitionEntrySetRemove() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testNodeJoin() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<String,String> to cache1 : GridCache<String,String> in method public testOptimisticTransaction() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheBasicOpAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testLockAsyncWithTimeoutEntryNear() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Object,Object> to cache2 : GridCache<Object,Object> in method protected beforeTestsStarted() : void in class org.apache.ignite.jdbc.JdbcLocalCachesSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Long,Long> to cache : GridCache<Long,Long> in method public testPeek() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapAndSwapSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testLostIterator() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.GridCacheReplicatedQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method private clearCaches() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheEventAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testNamedCache() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFieldsQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testRemoveAllFiltered() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiMultithreadedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,ValueObject> to cache : GridCache<Integer,ValueObject> in method public testLoadCacheAsyncFiltered() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryLoadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<SampleKey,SampleValue> to cache : GridCache<SampleKey,SampleValue> in method public applyx() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtMultiBackupTest.testPut.run |
From |
To |
|
Change Variable Type cache : Cache<Integer,TestObject> to cache : GridCache<Integer,TestObject> in method protected beforeTestsStarted() : void in class org.apache.ignite.jdbc.JdbcResultSetSelfTest |
From |
To |
|
Change Variable Type c : Cache to c : GridCache in method protected run(cacheNames Set<String>) : Void in class org.apache.ignite.internal.visor.cache.VisorCachePreloadTask.VisorCachesPreloadJob |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testCandidates(gridCnt int) : void in class org.apache.ignite.internal.processors.cache.GridCacheMvccManagerSelfTest |
From |
To |
|
Change Variable Type dfltCache : Cache<String,String> to dfltCache : GridCache<String,String> in method public testPut() : void in class org.apache.ignite.client.integration.ClientAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testEvictSingle() : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheEvictionTouchSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testPutAndRollbackCheckNear() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedFilteredPutSelfTest |
From |
To |
|
Change Variable Type c : Cache<Object,String> to c : GridCache<Object,String> in method public testCacheAndEvictAll() : void in class org.apache.ignite.spring.GridSpringDynamicCacheManagerSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method protected run(cacheName String) : GridCacheSqlMetadata in class org.apache.ignite.internal.visor.cache.VisorCacheMetadataTask.VisorCacheMetadataJob |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testLockUnlock() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method public testPut() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredEvictionAbstractSelfTest |
From |
To |
|
Change Variable Type gCache : Cache<Object,Object> to gCache : GridCache<Object,Object> in method private checkSanityCheckDisabled(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method private doTestPutAndPutAll(cache int, offheapSwap int, offheapEmpty boolean, swapEmpty boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheMemoryModeSelfTest |
From |
To |
|
Change Variable Type c0 : Cache<String,Integer> to c0 : GridCache<String,Integer> in method public testAutomaticPreload() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadMessageCountTest |
From |
To |
|
Change Variable Type metaCache : Cache<Object,Object> to metaCache : GridCache<Object,Object> in method public testCreateFileFragmented() : void in class org.apache.ignite.internal.processors.fs.GridGgfsStreamsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Account> to cache : GridCache<Integer,Account> in method public main(args String[]) : void in class org.apache.ignite.examples.datagrid.CacheTransactionExample |
From |
To |
|
Change Variable Type cache0 : Cache to cache0 : GridCache in method public testClear() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearPartitionedClearSelfTest |
From |
To |
|
Change Variable Type nodeCache : Cache<String,Integer> to nodeCache : GridCache<String,Integer> in method public testPartitionEntrySetIterator() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testReload() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method public testPeekExpiredTx() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private createRemove(cacheName String) : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheAtomicLongApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testPutFromBackup() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedBasicStoreMultiNodeSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testUnloadOneBackupTwoNodes() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadUnloadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testPaginationGet(cacheName String) : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,ValueObject> to cache : GridCache<Integer,ValueObject> in method public testReloadAllFiltered() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryLoadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testTransactionSingleGet() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOneNodeSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,String> to c : GridCache<String,String> in method public testAllowEmptyEntries() : void in class org.apache.ignite.internal.processors.cache.eviction.random.GridCacheRandomEvictionPolicySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method protected keys() : Collection<Integer> in class org.apache.ignite.internal.processors.cache.IgniteCacheEntryListenerAbstractTest |
From |
To |
|
Change Variable Type cache0 : Cache<Integer,Integer> to cache0 : GridCache<Integer,Integer> in method private checkPutRemoveGet() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheAtomicNearCacheSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,TestValue> to cache : GridCache<Integer,TestValue> in method public call() : Collection<WeakReference<Object>> in class org.apache.ignite.internal.processors.cache.GridCacheReferenceCleanupSelfTest.oneAsyncOpCallable |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method public testPeekExpired() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicClientOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Long,Object> to cache : GridCache<Long,Object> in method private sample(g Ignite, cacheName String) : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheMultiNodeDataStructureTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<String>,Object> to cache : GridCache<CacheAffinityKey<String>,Object> in method private put(o Object, cacheKey String, terminalId String) : void in class org.apache.ignite.internal.processors.cache.GridCacheConcurrentTxMultiNodeTest.PerfJob |
From |
To |
|
Change Variable Type cache : Cache<IncorrectCacheKey,String> to cache : GridCache<IncorrectCacheKey,String> in method private checkRemove(atomicityMode CacheAtomicityMode) : void in class org.apache.ignite.internal.processors.cache.GridCacheKeyCheckSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private regionCache(regionName String) : GridCache<Object,Object> in class org.apache.ignite.cache.hibernate.GridHibernateRegionFactory |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,Object> to cache1 : GridCache<Integer,Object> in method public testEvictions() : void in class org.apache.ignite.internal.processors.cache.GridCachePreloadingEvictionsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public main(args String...) : void in class org.apache.ignite.loadtests.swap.GridSwapEvictAllBenchmark |
From |
To |
|
Change Variable Type cache1 : Cache<String,String> to cache1 : GridCache<String,String> in method public testBasicOpsAsync() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheBasicOpAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testLostIterator() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.GridCacheReplicatedFieldsQuerySelfTest |
From |
To |
|
Change Variable Type namedCache : Cache<Integer,Integer> to namedCache : GridCache<Integer,Integer> in method protected beforeTestsStarted() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFieldsQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testReadThrough() : void in class org.apache.ignite.internal.processors.cache.GridCacheBasicStoreAbstractTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method private checkUnswap(key Integer) : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredAbstractSelfTest |
From |
To |
|
Change Variable Type gCache : Cache<Object,Object> to gCache : GridCache<Object,Object> in method private checkGroupLockGetOneKey(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method private checkPeekTxRemove(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private keyForNode(node ClusterNode, type int) : Integer in class org.apache.ignite.internal.processors.cache.IgniteTxExceptionAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method public testGetFromBackupNode() : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionedGetSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,?> to cache : GridCache<Object,?> in method public readFromSwap(key Object) : Object in class org.apache.ignite.internal.processors.query.h2.IgniteH2Indexing.RowDescriptor |
From |
To |
|
Change Variable Type c1 : Cache<Object,MyValue> to c1 : GridCache<Object,MyValue> in method public onLifecycleEvent(evt LifecycleEventType) : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadLifecycleSelfTest.lifecycleBean |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testMissesOnEmptyCache() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractMetricsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testContainsKey() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiMultithreadedSelfTest |
From |
To |
|
Change Variable Type prj1 : Cache<Object,Object> to prj1 : GridCache<Object,Object> in method public testPutAllPutAll() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type primaryCache : Cache<Integer,Integer> to primaryCache : GridCache<Integer,Integer> in method private checkReaderRemove() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheAtomicNearCacheSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private test(mode Mode, keysCnt int) : void in class org.apache.ignite.internal.processors.cache.GridCacheClearAllSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testMultiThreadedNewQueries() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryMultiThreadedSelfTest |
From |
To |
|
Change Variable Type prj1 : Cache<Object,Object> to prj1 : GridCache<Object,Object> in method public testPutAllRemoveAll() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,TestValue2> to cache2 : GridCache<Integer,TestValue2> in method public testRebuildIndexes() : void in class org.apache.ignite.internal.processors.query.h2.GridH2IndexRebuildTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testReloadAllAsync() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<?,?> to cache : GridCache<?,?> in method protected afterTest() : void in class org.apache.ignite.internal.processors.cache.GridCacheBasicStoreMultithreadedAbstractTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,ObjectValue> to cache2 : GridCache<Integer,ObjectValue> in method public testLuceneIndex1() : void in class org.apache.ignite.internal.processors.cache.GridCacheLuceneQueryIndexTest |
From |
To |
|
Change Variable Type c : Cache to c : GridCache in method protected run(arg GridTuple3<Set<String>,Long,Object[]>) : Map<String,Integer> in class org.apache.ignite.internal.visor.cache.VisorCacheLoadTask.VisorCachesLoadJob |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testMissingCommitVersion() : void in class org.apache.ignite.internal.processors.cache.GridCacheMissingCommitVersionSelfTest |
From |
To |
|
Change Variable Type cache : Cache<SampleKey,SampleValue> to cache : GridCache<SampleKey,SampleValue> in method public testPut() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtMultiBackupTest |
From |
To |
|
Change Variable Type near : Cache<Integer,String> to near : GridCache<Integer,String> in method public testRemove() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOneNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public main(args String[]) : void in class org.apache.ignite.examples.datagrid.CacheContinuousQueryExample |
From |
To |
|
Change Variable Type primaryCache : Cache<Integer,Integer> to primaryCache : GridCache<Integer,Integer> in method private checkReaderEvict() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheAtomicNearCacheSelfTest |
From |
To |
|
Change Variable Type near : Cache<Integer,String> to near : GridCache<Integer,String> in method public testReadThrough() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOneNodeSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testLargeObjectsWithLifeCycleBean() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadBigDataSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testPutFromPrimary() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedBasicStoreMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,byte[]> to cache : GridCache<Integer,byte[]> in method private memoryTest() : void in class org.apache.ignite.loadtests.cache.GridCacheLoadTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testBuffering() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<String>,String> to cache : GridCache<CacheAffinityKey<String>,String> in method private checkNearReadersUpdate(touchAffKey boolean, concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheGroupLockPartitionedMultiNodeAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testRemoveInTxQueriedMultiThreaded() : void in class org.apache.ignite.internal.processors.cache.IgniteTxMultiNodeAbstractTest |
From |
To |
|
Change Variable Type c1 : Cache<String,Integer> to c1 : GridCache<String,Integer> in method public testDelayedPreload() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadDelayedSelfTest |
From |
To |
|
Change Variable Type nearCache : Cache<String,Integer> to nearCache : GridCache<String,Integer> in method public testClear() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicClientOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method protected testKey() : int in class org.apache.ignite.internal.processors.cache.distributed.near.IgniteTxReentryNearSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<String,String> to cache0 : GridCache<String,String> in method public testNamedCache() : void in class org.apache.ignite.marshaller.GridMarshallerAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private checkValues(key int, val int) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.atomic.GridCacheAtomicPreloadSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,TestValue> to c : GridCache<Integer,TestValue> in method private checkPutGetRemoveObjectTx(key Integer, txConcurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredAbstractSelfTest |
From |
To |
|
Change Variable Type near : Cache<Integer,String> to near : GridCache<Integer,String> in method public testNoTransactionSinglePut() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiNodeSelfTest |
From |
To |
|
Change Variable Type gCache : Cache<Object,Object> to gCache : GridCache<Object,Object> in method private checkGroupPartitionLock(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testOrderByOnly() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testScanFilters() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testMultipleOperations() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedBasicStoreMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testMapping() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtMappingSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<String,Integer> to cache1 : GridCache<String,Integer> in method public testPeekFiltered() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<String,String> to cache1 : GridCache<String,String> in method public testBasicOps() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheBasicOpAbstractTest |
From |
To |
|
Change Variable Type cacheInner : Cache<Integer,Object> to cacheInner : GridCache<Integer,Object> in method private testAtomic0(caches GridCache<Integer,Object>[]) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheAbstractPartitionedOnlyByteArrayValuesSelfTest |
From |
To |
|
Change Variable Type cache : Cache<K,V> to cache : GridCache<K,V> in method public onEntryAccessed(rmv boolean, entry CacheEntry<K,V>) : void in class org.apache.ignite.cache.eviction.random.CacheRandomEvictionPolicy |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private getAndIncrement(cacheName String) : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheAtomicLongApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public apply(o Object) : Integer in class org.apache.ignite.internal.processors.cache.GridCacheAdapter.GlobalSizeCallable |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method public testGetFromPrimaryNode() : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionedGetSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private removeSetData(setId IgniteUuid, topVer long) : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheDataStructuresManager |
From |
To |
|
Change Variable Type cache : Cache<Integer,ObjectValue> to cache : GridCache<Integer,ObjectValue> in method public testQuery() : void in class org.apache.ignite.internal.processors.cache.GridIndexingWithNoopSwapSelfTest |
From |
To |
|
Change Variable Type c : Cache to c : GridCache in method protected run(names Set<String>) : Map<String,IgniteBiTuple<Integer,Integer>> in class org.apache.ignite.internal.visor.cache.VisorCacheSwapBackupsTask.VisorCachesSwapBackupsJob |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testMultithreadedPut() : void in class org.apache.ignite.cache.store.jdbc.GridCacheJdbcBlobStoreMultithreadedSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,String> to cache1 : GridCache<Integer,String> in method public testSync() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type nearCache : Cache<String,Integer> to nearCache : GridCache<String,Integer> in method public testClearKeys() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method private checkNearAndPrimary(gridCnt int, priThreads int, nearThreads int) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeCounterSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,TestValue> to c : GridCache<Integer,TestValue> in method private checkPutGetRemoveObject(key Integer) : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredAbstractSelfTest |
From |
To |
|
Change Variable Type dataCache : Cache<Object,Object> to dataCache : GridCache<Object,Object> in method private checkAffinity(blockSize int, info GridGgfsFileInfo, affinity Iterable<IgniteFsBlockLocation>) : void in class org.apache.ignite.internal.processors.fs.GridGgfsDataManagerSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<Integer,Integer> to cache0 : GridCache<Integer,Integer> in method public testWritesReads() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractMetricsSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,String> to cache1 : GridCache<Integer,String> in method private checkActivePartitionTransfer(keyCnt int, nodeCnt int, sameCoord boolean, shuffle boolean) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadSelfTest |
From |
To |
|
Change Variable Type prj : Cache<InternalKey,Object> to prj : GridCache<InternalKey,Object> in method public testInternalKeys() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePutArrayValueSelfTest |
From |
To |
|
Change Variable Type cache : Cache<UUID,String> to cache : GridCache<UUID,String> in method private checkGroupPartitionLock(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method private performanceMultithreadedTest() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testImplicitLockReaders() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearReadersSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method public testStringType() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public applyx() : void in class org.apache.ignite.loadtests.cache.GridCacheSwapLoadTest.doPut.runMultiThreadedAsync |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testReloadAsyncFiltered() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public run() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheAbstractNodeRestartSelfTest.checkRestartWithTx.t |
From |
To |
|
Change Variable Type cache0 : Cache<String,String> to cache0 : GridCache<String,String> in method public testDefaultCache() : void in class org.apache.ignite.marshaller.GridMarshallerAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method private keys() : Collection<Integer> in class org.apache.ignite.internal.processors.cache.expiry.IgniteCacheExpiryPolicyAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method protected checkRollback(map ConcurrentMap<Integer,String>, concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.IgniteTxAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Object,V> to cache : GridCache<Object,V> in method public readValueFromOffheapAndSwap(spaceName String, key Object, ldr ClassLoader) : V in class org.apache.ignite.internal.managers.GridManagerAdapter.onKernalStart.onContextInitialized |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private addAndGet(cacheName String) : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheAtomicLongApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testPaginationIteratorKeepAll() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type personCache : Cache<CacheAffinityKey<String>,Person> to personCache : GridCache<CacheAffinityKey<String>,Person> in method protected beforeTestsStarted() : void in class org.apache.ignite.internal.processors.cache.query.reducefields.GridCacheAbstractReduceFieldsQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<String>,String> to cache : GridCache<CacheAffinityKey<String>,String> in method private checkGroupLockPutOneKey(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<GridTestKey,Long> to cache : GridCache<GridTestKey,Long> in method public loadCache(clo IgniteBiInClosure<GridTestKey,Long>, args Object...) : void in class org.apache.ignite.loadtests.colocation.GridTestCacheStore |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testGetPutRemove() : void in class org.apache.ignite.internal.processors.cache.GridCacheBasicApiAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public _testPartitionedMixed() : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheEvictionFilterSelfTest |
From |
To |
|
Change Variable Type cache3 : Cache<Integer,EnemyCamp> to cache3 : GridCache<Integer,EnemyCamp> in method public testGeoMultithreaded() : void in class org.apache.ignite.internal.processors.query.h2.GridH2IndexingGeoSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method public testRandomEntryMultiThreaded() : void in class org.apache.ignite.internal.processors.cache.GridCacheConcurrentMapTest |
From |
To |
|
Change Variable Type c : Cache to c : GridCache in method public testAddAll() : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheQueueMultiNodeAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testSimpleKeyEvict() : void in class org.apache.ignite.spring.GridSpringCacheManagerSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testPutIfAbsentFromPrimary() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedBasicStoreMultiNodeSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method private waitForUnload(gridCnt long, cnt long, wait long) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadUnloadSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testFlushTimeout() : void in class org.apache.ignite.internal.processors.dataload.GridDataLoaderProcessorSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public run() : void in class org.apache.ignite.examples.datagrid.CacheAffinityExample.visitUsingMapKeysToNodes.run |
From |
To |
|
Change Variable Type c : Cache<Object,Object> to c : GridCache<Object,Object> in method private checkEvictionFilter() : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheEvictionFilterSelfTest |
From |
To |
|
Change Variable Type primary : Cache<String,Integer> to primary : GridCache<String,Integer> in method public testClear() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testRehash() : void in class org.apache.ignite.internal.processors.cache.GridCacheConcurrentMapSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private cache(ignite Ignite, cacheName String) : GridCacheProjectionEx<Object,Object> in class org.apache.ignite.internal.processors.rest.handlers.cache.GridCacheCommandHandler |
From |
To |
|
Change Variable Type cache : Cache<Integer,ArrayObject> to cache : GridCache<Integer,ArrayObject> in method public testArray() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testImplicit() : void in class org.apache.ignite.internal.processors.cache.GridCacheDaemonNodeAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method public testPeekPartitionedModes() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private groupData(data Iterable<Integer>) : Map<Integer,T2<Integer,Collection<Integer>>> in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockPutTask.map.singletonMap |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<String>,String> to cache : GridCache<CacheAffinityKey<String>,String> in method private checkGroupLockWriteThrough(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method package startThreads(exec ExecutorService, ignite Ignite, concurrentGetNum int, threadsNum int, getKeyNum int, finish AtomicBoolean, cntr AtomicLong, randomGet boolean) : Collection<Future<?>> in class org.apache.ignite.storevalbytes.GridCacheStoreValueBytesTest |
From |
To |
|
Change Variable Type personCache : Cache<CacheAffinityKey<String>,Person> to personCache : GridCache<CacheAffinityKey<String>,Person> in method protected beforeTestsStarted() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFieldsQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,ObjectValue> to cache : GridCache<Integer,ObjectValue> in method public testObjectQuery() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testLockAsyncWithTimeoutEntryPrimary() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testSqlQueryEvents(customSubjId boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Long,Long> to cache : GridCache<Long,Long> in method public main(args String[]) : void in class org.apache.ignite.loadtests.dsi.cacheget.GridBenchmarkCacheGetLoadTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Person> to cache : GridCache<Integer,Person> in method private testFieldsQueryEvents(customSubjId boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Long,Long> to cache : GridCache<Long,Long> in method public testIterators() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapAndSwapSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testTransform() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,H2TextValue> to c : GridCache<Integer,H2TextValue> in method public testH2Text() : void in class org.apache.ignite.internal.processors.cache.GridCacheFullTextQueryMultithreadedSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<Integer,Integer> to cache0 : GridCache<Integer,Integer> in method public testPrimaryPut() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMetricsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,CacheValue> to cache : GridCache<Integer,CacheValue> in method public _testSwapEviction() : void in class org.apache.ignite.internal.processors.cache.GridCacheSwapSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,TestValue> to cache : GridCache<Integer,TestValue> in method public call() : Collection<WeakReference<Object>> in class org.apache.ignite.internal.processors.cache.GridCacheReferenceCleanupSelfTest.atomicLongCallable |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testTypedProjection() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<Object,String> to c : GridCache<Object,String> in method public testPutAndEvictAll() : void in class org.apache.ignite.spring.GridSpringDynamicCacheManagerSelfTest |
From |
To |
|
Change Variable Type nearOnly : Cache<Object,Object> to nearOnly : GridCache<Object,Object> in method public testGetFromClientNode() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheClientModesAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method protected run(cacheName String) : Void in class org.apache.ignite.internal.visor.cache.VisorCacheResetMetricsTask.VisorCacheResetMetricsJob |
From |
To |
|
Change Variable Type cache : Cache<Integer,ValueObject> to cache : GridCache<Integer,ValueObject> in method public testReloadAllAsync() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryLoadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<String>,String> to cache : GridCache<CacheAffinityKey<String>,String> in method private checkGetPutEmptyCache(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testUnswap() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public run() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheAbstractNodeRestartSelfTest.checkRestartWithTxPutAll.t |
From |
To |
|
Change Variable Type cache1 : Cache<Object,Object> to cache1 : GridCache<Object,Object> in method protected beforeTestsStarted() : void in class org.apache.ignite.jdbc.JdbcLocalCachesSelfTest |
From |
To |
|
Change Variable Type c : Cache<?,?> to c : GridCache<?,?> in method public call() : Collection<CacheSqlMetadata> in class org.apache.ignite.internal.processors.cache.query.GridCacheQueryManager.MetadataJob |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public main(args String[]) : void in class org.apache.ignite.storevalbytes.GridCacheStoreValueBytesTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testGetAllWithNulls() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,TestValue2> to cache2 : GridCache<Integer,TestValue2> in method public testRebuildInterrupted() : void in class org.apache.ignite.internal.processors.query.h2.GridH2IndexRebuildTest |
From |
To |
|
Change Variable Type cache3 : Cache<Object,Object> to cache3 : GridCache<Object,Object> in method private testCacheUsage(expCache1 int, expCache2 int, expCache3 int, expCacheE3 int, expCacheE4 int) : void in class org.apache.ignite.cache.hibernate.GridHibernateL2CacheConfigurationSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testDisabled() : void in class org.apache.ignite.internal.processors.cache.GridCacheStoreValueBytesSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,Object> to cache1 : GridCache<Integer,Object> in method public testDeployment() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type c : Cache<UUID,Person> to c : GridCache<UUID,Person> in method public testScanReduceQuery() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedQuerySelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,String> to cache1 : GridCache<Integer,String> in method public testDisabledPreloader() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadDisabledSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,String> to cache1 : GridCache<Integer,String> in method private checkNodes(keyCnt int, nodeCnt int, sameCoord boolean, shuffle boolean) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testPeekRemove() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testMultithreaded() : void in class org.apache.ignite.internal.processors.cache.GridCacheWriteBehindStoreAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testReloadAllFiltered() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Long,Long> to cache : GridCache<Long,Long> in method public main(args String[]) : void in class org.apache.ignite.loadtests.cache.GridCacheBenchmark |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testEvict() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,byte[]> to c : GridCache<Integer,byte[]> in method private checkPutGetRemoveByteArray(key Integer) : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testReadersUpdate(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearTxMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<String>,String> to cache : GridCache<CacheAffinityKey<String>,String> in method private checkGetAfterPut(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type metaCache : Cache<IgniteUuid,GridGgfsFileInfo> to metaCache : GridCache<IgniteUuid,GridGgfsFileInfo> in method private checkOversizeDelay() : void in class org.apache.ignite.internal.processors.fs.GridGgfsSizeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testDhtUpdateRequestLost() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheAtomicTimeoutSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<String,Integer> to cache0 : GridCache<String,Integer> in method public testPutRemoveAll() : void in class org.apache.ignite.internal.processors.cache.GridCacheValueConsistencyAbstractSelfTest |
From |
To |
|
Change Variable Type primary : Cache<String,Integer> to primary : GridCache<String,Integer> in method public testClear() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicClientOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public main(args String[]) : void in class org.apache.ignite.loadtests.capacity.GridCapacityLoadTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,ObjectValue> to cache : GridCache<Integer,ObjectValue> in method public testObjectQueryWithSwap() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,String> to cache1 : GridCache<Integer,String> in method public testBatchSize1000() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,String> to cache2 : GridCache<Integer,String> in method public testBackupEntryReaders() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearReadersSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public call() : Object in class org.apache.ignite.internal.processors.cache.eviction.GridCacheEvictionAbstractTest.checkPartitionedMultiThreaded.multithreaded |
From |
To |
|
Change Variable Type c1 : Cache<Integer,String> to c1 : GridCache<Integer,String> in method private checkNodes(keyCnt int, nodeCnt int) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadStartStopSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testMultiThreadedSwapUnswapString() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryMultiThreadedSelfTest |
From |
To |
|
Change Variable Type dimCache : Cache<Integer,Object> to dimCache : GridCache<Integer,Object> in method private queryProductPurchases() : void in class org.apache.ignite.examples.datagrid.starschema.CacheStarSchemaExample |
From |
To |
|
Change Variable Type c : Cache<Object,String> to c : GridCache<Object,String> in method public testCacheAndEvict() : void in class org.apache.ignite.spring.GridSpringDynamicCacheManagerSelfTest |
From |
To |
|
Change Variable Type cache : Cache<GridTestKey,Long> to cache : GridCache<GridTestKey,Long> in method public main(args String[]) : void in class org.apache.ignite.loadtests.colocation.GridTestMain |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public test() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheMultithreadedFailoverAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private checkTransaction(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheNodeFailureAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testExplicit() : void in class org.apache.ignite.internal.processors.cache.GridCacheDaemonNodeAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testReadEvictedPartition() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffheapUpdateSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testReloadAll() : void in class org.apache.ignite.internal.processors.cache.GridCacheBasicStoreAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testPutAll() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedBasicStoreMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,ValueObject> to cache : GridCache<Integer,ValueObject> in method public testReloadAsync() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryLoadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testEvictAll() : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheEvictionTouchSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private checkTxWrites() : void in class org.apache.ignite.internal.processors.cache.GridCacheWriteBehindStorePartitionedMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,String> to cache : GridCache<Object,String> in method private checkGroupLockReadAffinityKey(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method public testTwoTx() : void in class org.apache.ignite.internal.processors.cache.GridCacheNestedTxAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testWrite() : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionedWritesTest |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method public testInvalidateFlag() : void in class org.apache.ignite.client.integration.ClientAbstractMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<IncorrectCacheKey,String> to cache : GridCache<IncorrectCacheKey,String> in method private checkPut(atomicityMode CacheAtomicityMode) : void in class org.apache.ignite.internal.processors.cache.GridCacheKeyCheckSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testCacheProxy() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testEvents() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,ObjectValue> to cache1 : GridCache<Integer,ObjectValue> in method public testRemoveIndex() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method public testCacheValuesGet() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type metaCache : Cache<Object,Object> to metaCache : GridCache<Object,Object> in method private validateLocalGgfsConfigurations(cfgs IgniteFsConfiguration[]) : void in class org.apache.ignite.internal.processors.fs.IgniteFsProcessor |
From |
To |
|
Change Variable Type cache : Cache<Long,Long> to cache : GridCache<Long,Long> in method public testUnswapAll() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapAndSwapSelfTest |
From |
To |
|
Change Variable Type orgCache : Cache<String,Organization> to orgCache : GridCache<String,Organization> in method protected beforeTestsStarted() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFieldsQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testEvict() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicClientOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testWriteThrough() : void in class org.apache.ignite.internal.processors.cache.GridCacheWriteBehindStoreAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testDifferentKeyTypes() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cacheE4 : Cache<Object,Object> to cacheE4 : GridCache<Object,Object> in method private testCacheUsage(expCache1 int, expCache2 int, expCache3 int, expCacheE3 int, expCacheE4 int) : void in class org.apache.ignite.cache.hibernate.GridHibernateL2CacheConfigurationSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,CacheValue> to cache : GridCache<Integer,CacheValue> in method public testSwap() : void in class org.apache.ignite.internal.processors.cache.GridCacheSwapSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method protected keyForNode(idx int) : Integer in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapMultiThreadedUpdateAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testNearEnabledOneNode() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearEvictionSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private compareCaches(expVals Map<Integer,Integer>) : boolean in class org.apache.ignite.internal.processors.cache.distributed.GridCacheMultithreadedFailoverAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testMvccFinishKeys() : void in class org.apache.ignite.internal.processors.cache.GridCacheFinishPartitionsSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Object,Object> to cache1 : GridCache<Object,Object> in method private testCacheUsage(expCache1 int, expCache2 int, expCache3 int, expCacheE3 int, expCacheE4 int) : void in class org.apache.ignite.cache.hibernate.GridHibernateL2CacheConfigurationSelfTest |
From |
To |
|
Change Variable Type c : Cache<Object,Object> to c : GridCache<Object,Object> in method public testTwoObjectsTextSearch() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<String,Integer> to cache1 : GridCache<String,Integer> in method public _testJtaTwoCaches() : void in class org.apache.ignite.internal.processors.cache.GridCacheJtaSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<String,String> to cache2 : GridCache<String,String> in method public testBasicOpsAsync() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheBasicOpAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<Long>,Long> to cache : GridCache<CacheAffinityKey<Long>,Long> in method private gridGainPutAll(ignite Ignite, max long, threads int) : void in class org.apache.ignite.loadtests.cache.GridCacheGroupLockComparisonTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testRemoveAllWithNulls() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type dataCache : Cache<GridGgfsBlockKey,byte[]> to dataCache : GridCache<GridGgfsBlockKey,byte[]> in method public testOpenPrefetchOverride() : void in class org.apache.ignite.fs.GridGgfsHadoopDualAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Long,String> to cache : GridCache<Long,String> in method private loadCache() : void in class org.apache.ignite.loadtests.cache.GridCacheWriteBehindStoreLoadTest |
From |
To |
|
Change Variable Type cacheE3 : Cache<Object,Object> to cacheE3 : GridCache<Object,Object> in method private testCacheUsage(expCache1 int, expCache2 int, expCache3 int, expCacheE3 int, expCacheE4 int) : void in class org.apache.ignite.cache.hibernate.GridHibernateL2CacheConfigurationSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testNearOnlyAffinity() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheClientModesAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,GridCacheDeploymentTestValue> to cache : GridCache<String,GridCacheDeploymentTestValue> in method public execute() : Object in class org.apache.ignite.tests.p2p.GridCacheDeploymentTestTask1.map.asMap |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private keyForNode(node ClusterNode, type int) : Integer in class org.apache.ignite.internal.processors.cache.IgniteTxStoreExceptionAbstractSelfTest |
From |
To |
|
Change Variable Type prj1 : Cache<Object,Object> to prj1 : GridCache<Object,Object> in method public testPutAllManyKeysOneReader() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearReadersSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testPeekMode() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,ObjectValue> to cache1 : GridCache<Integer,ObjectValue> in method public testLuceneIndex1() : void in class org.apache.ignite.internal.processors.cache.GridCacheLuceneQueryIndexTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testEnabled() : void in class org.apache.ignite.internal.processors.cache.GridCacheStoreValueBytesSelfTest |
From |
To |
|
Change Variable Type cache : Cache<?,?> to cache : GridCache<?,?> in method protected afterTest() : void in class org.apache.ignite.internal.processors.cache.GridCacheWriteBehindStoreAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public main(args String[]) : void in class org.apache.ignite.examples.datagrid.CacheEventsExample |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method public testCacheContainsGet() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testSize() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicClientOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private checkPutTx(putBefore boolean, concurrency IgniteTxConcurrency, isolation IgniteTxIsolation, keys Integer...) : void in class org.apache.ignite.internal.processors.cache.IgniteTxStoreExceptionAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method private checkPutAllGetAllRemoveAllTx(txConcurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testPutRemoveAll() : void in class org.apache.ignite.internal.processors.cache.GridCacheValueConsistencyAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,ObjectValue> to cache : GridCache<Integer,ObjectValue> in method public testTextQueryOnProjection() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type c : Cache<?,?> to c : GridCache<?,?> in method protected run(arg IgniteBiTuple<Boolean,String>) : Map<String,VisorCacheMetrics> in class org.apache.ignite.internal.visor.cache.VisorCacheMetricsCollectorTask.VisorCacheMetricsJob |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testPutWithFilter(key Integer) : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapMultiThreadedUpdateAbstractSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<Integer,Integer> to cache0 : GridCache<Integer,Integer> in method private checkReaderRemove() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheAtomicNearCacheSelfTest |
From |
To |
|
Change Variable Type nearCache : Cache<String,Integer> to nearCache : GridCache<String,Integer> in method public testClearKeys() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicClientOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method public testRandomEntry() : void in class org.apache.ignite.internal.processors.cache.GridCacheConcurrentMapTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testLockAsyncWithTimeoutEntry() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method private checkNodes(keyCnt int, nodeCnt int) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadStartStopSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testGetOutTx() : void in class org.apache.ignite.internal.processors.cache.GridCacheExAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,Integer> to cache2 : GridCache<Integer,Integer> in method public testRemoteNodeCallback() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryReplicatedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,?> to cache : GridCache<String,?> in method public call() : Object in class org.apache.ignite.internal.processors.cache.datastructures.partitioned.GridCachePartitionedQueueCreateMultiNodeSelfTest.testQueueCreation.fut.multithreadedAsync |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testRemoveAll() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiMultithreadedSelfTest |
From |
To |
|
Change Variable Type locCache : Cache<Object,Object> to locCache : GridCache<Object,Object> in method public testUpdateInPessimisticTxOnRemoteNode() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffheapUpdateSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testTryFlush() : void in class org.apache.ignite.internal.processors.dataload.GridDataLoaderProcessorSelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<String>,String> to cache : GridCache<CacheAffinityKey<String>,String> in method private checkGetRemove(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testGetAll() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiMultithreadedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method private onRemoveItemQueried(putCntr boolean, ignite Ignite, retry int) : void in class org.apache.ignite.internal.processors.cache.IgniteTxMultiNodeAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method private onItemPrimary(putCntr boolean, ignite Ignite, itemKey String, retry int) : void in class org.apache.ignite.internal.processors.cache.IgniteTxMultiNodeAbstractTest |
From |
To |
|
Change Variable Type caches : List<Cache<Integer,Integer>> to caches : List<GridCache<Integer,Integer>> in method private compareCaches(expVals Map<Integer,Integer>) : boolean in class org.apache.ignite.internal.processors.cache.distributed.GridCacheMultithreadedFailoverAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private checkBackupConsistency(key int) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testContainsValue() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiMultithreadedSelfTest |
From |
To |
|
Change Variable Type c : Cache<Object,Integer> to c : GridCache<Object,Integer> in method public main(args String[]) : void in class org.apache.ignite.loadtests.cache.GridCacheAffinityTransactionsOffHeapTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testMultiThreadedSameQuery() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryMultiThreadedSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method protected run(arg Set<String>) : Map<String,IgniteBiTuple<Integer,Integer>> in class org.apache.ignite.internal.visor.cache.VisorCacheClearTask.VisorCachesClearJob |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method private testTransactionMixed0(caches GridCache<Integer,Object>[], concurrency IgniteTxConcurrency, key1 Integer, val1 byte[], key2 Integer, val2 Object) : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheAbstractDistributedByteArrayValuesSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Long,Long> to cache : GridCache<Long,Long> in method public testGet() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapAndSwapSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testUnloadEvents() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedUnloadEventsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private checkSimpleTxs(nearEnabled boolean, concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.atomic.GridCacheAtomicPreloadSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method private checkPutGetRemove(key Integer) : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testInternalKey() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private doWork() : void in class org.apache.ignite.internal.processors.cache.GridCacheConcurrentTxMultiNodeTest.PerfJob |
From |
To |
|
Change Variable Type c1 : Cache<String,Integer> to c1 : GridCache<String,Integer> in method public testAutomaticPreload() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadMessageCountTest |
From |
To |
|
Change Variable Type prj2 : Cache<Object,Object> to prj2 : GridCache<Object,Object> in method public testPutAllManyKeysTwoReaders() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearReadersSelfTest |
From |
To |
|
Change Variable Type lastCache : Cache<Integer,String> to lastCache : GridCache<Integer,String> in method private checkActivePartitionTransfer(keyCnt int, nodeCnt int, sameCoord boolean, shuffle boolean) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadSelfTest |
From |
To |
|
Change Variable Type c : Cache<?,?> to c : GridCache<?,?> in method public getCacheNames() : Collection<String> in class org.apache.ignite.cache.spring.SpringCacheManager |
From |
To |
|
Change Variable Type cache : Cache<Integer,Person> to cache : GridCache<Integer,Person> in method private testTextQueryEvents(customSubjId boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method protected loadTest(writeClos CIX1<CacheProjection<Integer,Integer>>, readClos CIX1<CacheProjection<Integer,Integer>>) : void in class org.apache.ignite.loadtests.cache.GridCacheAbstractLoadTest |
From |
To |
|
Change Variable Type prj : Cache<Integer,Integer> to prj : GridCache<Integer,Integer> in method public call() : Object in class org.apache.ignite.internal.processors.cache.GridCacheMixedPartitionExchangeSelfTest.testNodeJoinLeave.fut.runMultiThreadedAsync |
From |
To |
|
Change Variable Type c1 : Cache<String,String> to c1 : GridCache<String,String> in method public testScanQuery() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private checkPutTx(putBefore boolean, concurrency IgniteTxConcurrency, isolation IgniteTxIsolation, keys Integer...) : void in class org.apache.ignite.internal.processors.cache.IgniteTxExceptionAbstractSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,String> to cache1 : GridCache<Integer,String> in method public testBatchSize10000() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testNotExistingKeys() : void in class org.apache.ignite.internal.processors.cache.GridCacheBasicStoreAbstractTest |
From |
To |
|
Change Variable Type gCache : Cache<Object,Object> to gCache : GridCache<Object,Object> in method private checkGetPutEmptyCache(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method package doTest(cache int, offheapSwap int, offheapEmpty boolean, swapEmpty boolean, x CIX1<GridCache<String,Integer>>) : void in class org.apache.ignite.internal.processors.cache.GridCacheMemoryModeSelfTest |
From |
To |
|
Change Variable Type dataCache : Cache to dataCache : GridCache in method public testConfiguration() : void in class org.apache.ignite.internal.processors.fs.GridGgfsStreamsSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private removeSet0(name String) : boolean in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheDataStructuresManager |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public call() : Void in class org.apache.ignite.cache.hibernate.GridHibernateAccessStrategyAdapter.ClearKeyCallable |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testLoadCache() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method public testCacheExpire() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private key(ignite Ignite, mode int) : Integer in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheAtomicNearCacheSelfTest |
From |
To |
|
Change Variable Type factCache : Cache<Integer,FactPurchase> to factCache : GridCache<Integer,FactPurchase> in method private body(prj CacheProjection<Integer,FactPurchase>) : List<Map.Entry<Integer,FactPurchase>> in class org.apache.ignite.internal.processors.cache.GridCacheCrossCacheQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,ValueObject> to cache : GridCache<Integer,ValueObject> in method public testLoadCacheFiltered() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryLoadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private checkCommit(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.GridCacheReplicatedInvalidateSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testPutRemove() : void in class org.apache.ignite.internal.processors.cache.GridCacheValueConsistencyAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,ObjectValue> to cache : GridCache<Integer,ObjectValue> in method public testFullTextSearch() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private checkNonLocalKey(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheGroupLockPartitionedMultiNodeAbstractSelfTest |
From |
To |
|
Change Variable Type cacheInner : Cache<Integer,Object> to cacheInner : GridCache<Integer,Object> in method private testTransactionMixed0(caches GridCache<Integer,Object>[], concurrency IgniteTxConcurrency, key1 Integer, val1 byte[], key2 Integer, val2 Object) : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheAbstractDistributedByteArrayValuesSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testPutFromNear() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedBasicStoreMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public main(args String[]) : void in class org.apache.ignite.examples.datagrid.store.CacheStoreLoadDataExample |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,ObjectValue> to cache1 : GridCache<Integer,ObjectValue> in method public testLuceneIndex() : void in class org.apache.ignite.internal.processors.cache.GridCacheLuceneQueryIndexTest |
From |
To |
|
Change Variable Type cache : Cache<Long,Long> to cache : GridCache<Long,Long> in method public testSql() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapAndSwapSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<String,Integer> to cache2 : GridCache<String,Integer> in method public testPeekFiltered() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method protected keys() : Collection<Integer> in class org.apache.ignite.internal.processors.cache.integration.IgniteCacheNoLoadPreviousValueAbstractTest |
From |
To |
|
Change Variable Type cache0 : Cache<UUID,Person> to cache0 : GridCache<UUID,Person> in method public testSingleNodeQuery() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedQuerySelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testSimpleKeyPut() : void in class org.apache.ignite.spring.GridSpringCacheManagerSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method private checkNodes(keyCnt int, nodeCnt int, sameCoord boolean, shuffle boolean) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private findAbsentKeys(workerNode Ignite, keys Collection<Integer>) : Collection<Integer> in class org.apache.ignite.internal.processors.cache.GridCachePutAllFailoverSelfTest |
From |
To |
|
Change Variable Type c2 : Cache<Object,MyValue> to c2 : GridCache<Object,MyValue> in method public onLifecycleEvent(evt LifecycleEventType) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedPreloadLifecycleSelfTest.lifecycleBean |
From |
To |
|
Change Variable Type near : Cache<Integer,String> to near : GridCache<Integer,String> in method public testConcurrentOps() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiNodeSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method public testPeekAsyncPartitionedModes() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testLoadCacheWithPredicate() : void in class org.apache.ignite.internal.processors.cache.GridCacheBasicStoreAbstractTest |
From |
To |
|
Change Variable Type c : Cache<Integer,ObjectValue> to c : GridCache<Integer,ObjectValue> in method public testObjectQueryWithSwap() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method protected run(names Set<String>) : Map<String,IgniteBiTuple<Integer,Integer>> in class org.apache.ignite.internal.visor.cache.VisorCacheCompactTask.VisorCachesCompactJob |
From |
To |
|
Change Variable Type nearCache : Cache<String,Integer> to nearCache : GridCache<String,Integer> in method public testSize() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<Object>,Integer> to cache : GridCache<CacheAffinityKey<Object>,Integer> in method public testGroupLock() : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheEvictionTouchSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<Integer,Integer> to cache0 : GridCache<Integer,Integer> in method private checkPutAll() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheAtomicNearCacheSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testGet() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiMultithreadedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testLockReentry() : void in class org.apache.ignite.internal.processors.cache.IgniteTxReentryAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private runConcurrentTest(g Ignite, keysCnt int, batchSize int) : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheBatchEvictUnswapSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testGetPutRemove() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheEventAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private checkTransactionSingleGet(key int) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiNodeSelfTest |
From |
To |
|
Change Variable Type near : Cache<Integer,String> to near : GridCache<Integer,String> in method public testNoTransactionWriteThrough() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiNodeSelfTest |
From |
To |
|
Change Variable Type sndCache0 : Cache<Integer,Integer> to sndCache0 : GridCache<Integer,Integer> in method public testPutAndRemove() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractRemoveFailureTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,Object> to cache1 : GridCache<Integer,Object> in method private checkP2PUndeploy(cacheName String) : void in class org.apache.ignite.internal.processors.cache.GridCacheP2PUndeploySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testAffinityProcessor() : void in class org.apache.ignite.internal.processors.affinity.GridAffinityProcessorAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,EnemyCamp> to cache : GridCache<Integer,EnemyCamp> in method public testGeo() : void in class org.apache.ignite.internal.processors.query.h2.GridH2IndexingGeoSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method public testClear() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearPartitionedClearSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private checkNearEvictionMaxSize() : void in class org.apache.ignite.internal.processors.cache.eviction.lru.GridCacheLruNearEvictionPolicySelfTest |
From |
To |
|
Change Variable Type cache : Cache<?,?> to cache : GridCache<?,?> in method private initialize() : void in class org.apache.ignite.examples.datagrid.CacheQueryExample |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testDhtUpdateResponseLost() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheAtomicTimeoutSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private incrementAndGet(cacheName String) : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheAtomicLongApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testPut() : void in class org.apache.ignite.internal.processors.cache.eviction.lru.GridCacheLruEvictionPolicySelfTest |
From |
To |
|
Change Variable Type c1 : Cache<String,Integer> to c1 : GridCache<String,Integer> in method public testManualPreload() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadDelayedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testCompactExpired() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type c : Cache<Object,Object> to c : GridCache<Object,Object> in method protected afterTest() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryMultiThreadedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method private runTest(c IgniteInClosure<GridCache<String,Integer>>) : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiMultithreadedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private checkPartitioned(endSize int, endPlcSize int, near boolean) : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheEvictionAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,EnemyCamp> to cache : GridCache<Integer,EnemyCamp> in method public testGeoMultithreaded() : void in class org.apache.ignite.internal.processors.query.h2.GridH2IndexingGeoSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,TestValue> to c : GridCache<Integer,TestValue> in method public testMultiThreadedSwapUnswapObject() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryMultiThreadedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method protected finalChecks() : void in class org.apache.ignite.internal.processors.cache.IgniteTxAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private checkTransactionTimeout(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.distributed.IgniteTxTimeoutAbstractTest |
From |
To |
|
Change Variable Type gCache : Cache<Object,Object> to gCache : GridCache<Object,Object> in method private checkGetRemove(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testFiltered() : void in class org.apache.ignite.internal.processors.cache.GridCacheIteratorPerformanceTest |
From |
To |
|
Change Variable Type c : Cache<?,?> to c : GridCache<?,?> in method protected awaitPartitionMapExchange() : void in class org.apache.ignite.testframework.junits.common.GridCommonAbstractTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private caches(res VisorNodeDataCollectorJobResult, arg VisorNodeDataCollectorTaskArg) : void in class org.apache.ignite.internal.visor.node.VisorNodeDataCollectorJob |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method private checkActivePartitionTransfer(keyCnt int, nodeCnt int, sameCoord boolean, shuffle boolean) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testPutAllWithNulls() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testIteration() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheEntrySetIterationPreloadingSelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<String>,String> to cache : GridCache<CacheAffinityKey<String>,String> in method private checkGroupLockGetOneKey(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method private doPutAndRollback() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedFilteredPutSelfTest |
From |
To |
|
Change Variable Type cache : Cache<K,V> to cache : GridCache<K,V> in method public publicCache(name String) : GridCache<K,V> in class org.apache.ignite.internal.processors.cache.GridCacheProcessor |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private checkTransactionTimeout(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.local.GridCacheLocalTxTimeoutSelfTest |
From |
To |
|
Change Variable Type prj0 : Cache<Object,Object> to prj0 : GridCache<Object,Object> in method public testPutDebug() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testSimpleKey() : void in class org.apache.ignite.spring.GridSpringCacheManagerSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method private checkNearAndPrimaryMultiNode(gridCnt int) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeCounterSelfTest |
From |
To |
|
Change Variable Type cp : Cache<Integer,String> to cp : GridCache<Integer,String> in method public testSecondCachePutRemove() : void in class org.apache.ignite.spi.checkpoint.cache.GridCacheCheckpointSpiSecondCacheSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,Object> to cache2 : GridCache<Integer,Object> in method public testOffHeapDeployment() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,String> to cache1 : GridCache<Integer,String> in method public testSynchronousCommitNodeLeave() : void in class org.apache.ignite.internal.processors.cache.GridCacheReplicatedSynchronousCommitTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testProjection() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private getAndSetInTx(cacheName String) : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheAtomicLongApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public checkTransactionSingleGetRemove(key int) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<GridTestKey,Long> to cache : GridCache<GridTestKey,Long> in method private localPoolRun() : void in class org.apache.ignite.loadtests.colocation.GridTestMain |
From |
To |
|
Change Variable Type dataCache : Cache<GridGgfsBlockKey,byte[]> to dataCache : GridCache<GridGgfsBlockKey,byte[]> in method public testOpenPrefetch() : void in class org.apache.ignite.internal.processors.fs.GridGgfsDualAbstractSelfTest |
From |
To |
|
Change Variable Type factCache : Cache<Integer,FactPurchase> to factCache : GridCache<Integer,FactPurchase> in method private queryProductPurchases() : void in class org.apache.ignite.examples.datagrid.starschema.CacheStarSchemaExample |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private checkPreloadOrder(first CacheMode, second CacheMode) : void in class org.apache.ignite.internal.processors.cache.GridCacheOrderedPreloadingSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testDifferentValueTypes() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type orgCache : Cache<String,Organization> to orgCache : GridCache<String,Organization> in method protected beforeTestsStarted() : void in class org.apache.ignite.jdbc.JdbcComplexQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<UUID>,Person> to cache : GridCache<CacheAffinityKey<UUID>,Person> in method private sqlQueryWithTransformer() : void in class org.apache.ignite.examples.datagrid.CacheQueryExample |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method protected checkCommit(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.IgniteTxAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<UUID,String> to cache : GridCache<UUID,String> in method public testGroupLockWrongPartition() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheGroupLockPartitionedAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<Long>,Long> to cache : GridCache<CacheAffinityKey<Long>,Long> in method private gridGainGroupLock(ignite Ignite, max long, threads int) : void in class org.apache.ignite.loadtests.cache.GridCacheGroupLockComparisonTest |
From |
To |
|
Change Variable Type cache : Cache<?,?> to cache : GridCache<?,?> in method protected afterTest() : void in class org.apache.ignite.loadtests.cache.GridCacheWriteBehindStoreLoadTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testIllegalBounds() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type dimCache : Cache<Integer,Object> to dimCache : GridCache<Integer,Object> in method private populateFacts() : void in class org.apache.ignite.examples.datagrid.starschema.CacheStarSchemaExample |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public apply() : void in class org.apache.ignite.fs.GridGgfsFragmentizerSelfTest.testDeleteFragmentizing.retryAssert |
From |
To |
|
Change Variable Type c : Cache<UUID,Person> to c : GridCache<UUID,Person> in method public testTransformQuery() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<Object,Object> to cache0 : GridCache<Object,Object> in method private checkMultiUpdateLocks(nearEnabled boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheMultiUpdateLockSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testLockFromNearOrBackup() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedExplicitLockNodeFailureSelfTest |
From |
To |
|
Change Variable Type c : Cache<UUID,Person> to c : GridCache<UUID,Person> in method public testSqlReduceQuery() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedQuerySelfTest |
From |
To |
|
Change Variable Type orgCache : Cache<String,Organization> to orgCache : GridCache<String,Organization> in method protected beforeTestsStarted() : void in class org.apache.ignite.internal.processors.cache.query.reducefields.GridCacheAbstractReduceFieldsQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,int[]> to cache : GridCache<String,int[]> in method private checkTransactions(concur IgniteTxConcurrency, isolation IgniteTxIsolation, jobCnt int) : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheAbstractJobExecutionTest |
From |
To |
|
Change Variable Type cache : Cache<PersonKey,Person> to cache : GridCache<PersonKey,Person> in method public _testComplexKeys() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFieldsQuerySelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,EnemyCamp> to cache1 : GridCache<Integer,EnemyCamp> in method public testGeoMultithreaded() : void in class org.apache.ignite.internal.processors.query.h2.GridH2IndexingGeoSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method private onPrimary() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeCounterSelfTest.IncrementItemJob |
From |
To |
|
Change Variable Type cache : Cache<EmptyObject,EmptyObject> to cache : GridCache<EmptyObject,EmptyObject> in method public testEmptyObject() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type c1 : Cache<Object,MyValue> to c1 : GridCache<Object,MyValue> in method public onLifecycleEvent(evt LifecycleEventType) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedPreloadLifecycleSelfTest.lifecycleBean |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private putGet() : void in class org.apache.ignite.examples.datagrid.CachePutGetExample |
From |
To |
|
Change Variable Type near : Cache<Integer,String> to near : GridCache<Integer,String> in method public testOptimisticTxWriteThrough() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOneNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private checkPutAll() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheAtomicNearCacheSelfTest |
From |
To |
|
Change Variable Type primaryCache : Cache<Integer,Object> to primaryCache : GridCache<Integer,Object> in method public testSwap() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheAbstractDistributedByteArrayValuesSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testPutGetRemoveByteArray() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private checkBackups(backups int, func CacheAffinityFunction) : void in class org.apache.ignite.GridCacheAffinityBackupsSelfTest |
From |
To |
|
Change Variable Type c0 : Cache<String,Integer> to c0 : GridCache<String,Integer> in method public testDelayedPreload() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadDelayedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Object> to cache : GridCache<String,Object> in method private populateCache() : void in class org.apache.ignite.internal.processors.rest.RestProcessorTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private checkSwapMultithreaded() : void in class org.apache.ignite.internal.processors.cache.GridCacheSwapPreloadSelfTest |
From |
To |
|
Change Variable Type cache3 : Cache<String,String> to cache3 : GridCache<String,String> in method public testBasicOpsAsync() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheBasicOpAbstractTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method private checkRestart() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCachePreloadRestartAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testClearKeys() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Object> to c : GridCache<Integer,Object> in method public testMultiThreadedSwapUnswapLongString() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryMultiThreadedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testPeek() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Long,Person> to cache : GridCache<Long,Person> in method public main(args String[]) : void in class org.apache.ignite.examples.datagrid.store.CacheStoreExample |
From |
To |
|
Change Variable Type cache : Cache<Integer,ValueObject> to cache : GridCache<Integer,ValueObject> in method public testLoadCacheAsync() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryLoadSelfTest |
From |
To |
|
Change Variable Type cache3 : Cache<String,String> to cache3 : GridCache<String,String> in method public testOptimisticTransaction() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheBasicOpAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method public testAffinity() : void in class org.apache.ignite.marshaller.GridMarshallerAbstractTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,String> to cache1 : GridCache<Integer,String> in method public testIntegrity() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<Integer,Integer> to cache0 : GridCache<Integer,Integer> in method public testNearRead() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMetricsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Long> to cache : GridCache<Integer,Long> in method public _testOptimisticSerializableConsistency() : void in class org.apache.ignite.internal.processors.cache.IgniteTxMultiThreadedAbstractTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method private checkPutGetRemoveTx(key Integer, txConcurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method public testRemove() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredEvictionAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<?,?> to cache : GridCache<?,?> in method public execute() : Object in class org.apache.ignite.internal.processors.cache.query.jdbc.GridCacheQueryJdbcTask.JdbcDriverJob |
From |
To |
|
Change Variable Type cache : Cache<Key,GridCacheQueryTestValue> to cache : GridCache<Key,GridCacheQueryTestValue> in method public testComplexType() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testClear() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testBasicOps() : void in class org.apache.ignite.internal.processors.cache.GridCacheBasicApiAbstractTest |
From |
To |
|
Change Variable Type gCache : Cache<Object,Object> to gCache : GridCache<Object,Object> in method private checkGroupLockWriteThrough(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type intCache : Cache<Integer,Integer> to intCache : GridCache<Integer,Integer> in method protected beforeTestsStarted() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFieldsQuerySelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,Integer> to cache1 : GridCache<Integer,Integer> in method public testRemoteNodeCallback() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryReplicatedSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method private onNear() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeCounterSelfTest.IncrementItemJob |
From |
To |
|
Change Variable Type cache : Cache<Integer,ValueObject> to cache : GridCache<Integer,ValueObject> in method public testReloadAllAsyncFiltered() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryLoadSelfTest |
From |
To |
|
Change Variable Type near : Cache<Integer,String> to near : GridCache<Integer,String> in method public testPessimisticWriteThrough() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<UUID>,Person> to cache : GridCache<CacheAffinityKey<UUID>,Person> in method private textQuery() : void in class org.apache.ignite.examples.datagrid.CacheQueryExample |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testPutxIfAbsentTx(key Integer, txConcurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapMultiThreadedUpdateSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testPreloadEvents() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCachePreloadEventsAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testPutxIfAbsent(key Integer) : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapMultiThreadedUpdateAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method private checkNodes(g Ignite) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtEvictionsDisabledSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testForcePreload() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedPreloadEventsSelfTest |
From |
To |
|
Change Variable Type nearCache : Cache<String,Integer> to nearCache : GridCache<String,Integer> in method public testClear() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicNearOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private testPut(key Integer) : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapMultiThreadedUpdateAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testEmptyWeakIterator() : void in class org.apache.ignite.internal.processors.cache.GridCacheConcurrentMapSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testReloadAll() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCachePartitionedReloadAllAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testRehashRandom() : void in class org.apache.ignite.internal.processors.cache.GridCacheConcurrentMapSelfTest |
From |
To |
|
Change Variable Type personCache : Cache<CacheAffinityKey<String>,Person> to personCache : GridCache<CacheAffinityKey<String>,Person> in method protected beforeTestsStarted() : void in class org.apache.ignite.jdbc.JdbcComplexQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<String>,String> to cache : GridCache<CacheAffinityKey<String>,String> in method private checkGroupLockRemoveOneKey(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<Object,String> to c : GridCache<Object,String> in method public testPutAndEvict() : void in class org.apache.ignite.spring.GridSpringDynamicCacheManagerSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method private onRemoveItemSimple(putCntr boolean, ignite Ignite, retry int) : void in class org.apache.ignite.internal.processors.cache.IgniteTxMultiNodeAbstractTest |
From |
To |
|
Change Variable Type dataCache : Cache<GridGgfsBlockKey,byte[]> to dataCache : GridCache<GridGgfsBlockKey,byte[]> in method public testDeleteCacheConsistency() : void in class org.apache.ignite.internal.processors.fs.GridGgfsProcessorSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,String> to cache2 : GridCache<Integer,String> in method public testTwoNodesTwoKeysOneBackup() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearReadersSelfTest |
From |
To |
|
Change Variable Type primary : Cache<String,Integer> to primary : GridCache<String,Integer> in method public testClearKeys() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<?,?> to cache : GridCache<?,?> in method private sqlFieldsQueryWithJoin() : void in class org.apache.ignite.examples.datagrid.CacheQueryExample |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testEntriesByFilter() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type nearCache : Cache<String,Integer> to nearCache : GridCache<String,Integer> in method public testLockUnlock() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,TestValue> to c : GridCache<Integer,TestValue> in method public testLockUnlock() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredAbstractSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<ObjectKey,ObjectValue> to cache1 : GridCache<ObjectKey,ObjectValue> in method public testLuceneIndex3() : void in class org.apache.ignite.internal.processors.cache.GridCacheLuceneQueryIndexTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private testAddPollMultinode(collocated boolean) : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheQueueMultiNodeAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method protected executeJob(gridSize int, arg Object) : Object in class org.apache.ignite.client.ClientPutPortableTask |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private putAllGetAll() : void in class org.apache.ignite.examples.datagrid.CachePutGetExample |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public _testDeploymentGroupLock() : void in class org.apache.ignite.internal.processors.cache.GridCacheDeploymentSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testReloadAllAsyncFiltered() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testTypedProjection() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractProjectionSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method private getAndDecrement(cacheName String) : void in class org.apache.ignite.internal.processors.cache.datastructures.GridCacheAtomicLongApiSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<Integer,Integer> to cache0 : GridCache<Integer,Integer> in method public testNearPut() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMetricsSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<UUID,Person> to cache0 : GridCache<UUID,Person> in method public testIncludeBackupsAndEnableDedup() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedQuerySelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testMultiThreadedReduceQuery() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryMultiThreadedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testSynchronousEvictions() : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheSynchronousEvictionsFailoverSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<UUID,Person> to cache0 : GridCache<UUID,Person> in method public testFieldsQuery() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedQuerySelfTest |
From |
To |
|
Change Variable Type prj0 : Cache<Object,Object> to prj0 : GridCache<Object,Object> in method public testPutAllManyKeysOneReader() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearReadersSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testSingleQueryMetrics() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryMetricsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testEvictExpired() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicNearOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testLoadCache() : void in class org.apache.ignite.internal.processors.cache.GridCacheBasicStoreAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private checkConcurrentPuts() : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheConcurrentEvictionsSelfTest |
From |
To |
|
Change Variable Type prj0 : Cache<Object,Object> to prj0 : GridCache<Object,Object> in method public testPutAllRemoveAll() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private checkPartitions() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCachePartitionedAffinityFilterSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method protected testKey() : int in class org.apache.ignite.internal.processors.cache.distributed.dht.IgniteTxReentryColocatedSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Long,Object> to cache1 : GridCache<Long,Object> in method public _testCacheRedeployVersionChangeContinuousMode() : void in class org.apache.ignite.p2p.GridP2PUserVersionChangeSelfTest |
From |
To |
|
Change Variable Type nearOnly : Cache<Object,Object> to nearOnly : GridCache<Object,Object> in method public testNodeLeave() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOnlyTopologySelfTest |
From |
To |
|
Change Variable Type caches : Cache<Integer,Integer>[] to caches : GridCache<Integer,Integer>[] in method private test(mode Mode, keysCnt int) : void in class org.apache.ignite.internal.processors.cache.GridCacheClearAllSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,byte[]> to c : GridCache<Integer,byte[]> in method public testLargeObjectsWithLifeCycleBean() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadBigDataSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testFilteredPutCheckDht() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedFilteredPutSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method private waitExpired(keys Collection<Integer>) : void in class org.apache.ignite.internal.processors.cache.expiry.IgniteCacheExpiryPolicyAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testQueryLocal() : void in class org.apache.ignite.internal.processors.cache.local.GridCacheLocalQuerySelfTest |
From |
To |
|
Change Variable Type lastCache : Cache<Integer,String> to lastCache : GridCache<Integer,String> in method public testMultipleNodes() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method private testReadersUpdate(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearTxMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<?,?> to cache : GridCache<?,?> in method protected afterTest() : void in class org.apache.ignite.cache.hibernate.GridHibernateL2CacheConfigurationSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method private top2string(grids Iterable<Ignite>) : String in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method protected primaryCache(key String) : GridCache<String,Integer> in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testEvictAll() : void in class org.apache.ignite.spring.GridSpringCacheManagerSelfTest |
From |
To |
|
Change Variable Type lastCache : Cache<Integer,String> to lastCache : GridCache<Integer,String> in method private checkNodes(keyCnt int, nodeCnt int, sameCoord boolean, shuffle boolean) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<ObjectValue,Integer> to cache : GridCache<ObjectValue,Integer> in method public testTextIndexedKey() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public main(args String[]) : void in class org.apache.ignite.loadtests.continuous.GridContinuousOperationsLoadTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testNearUpdateResponseLost() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheAtomicTimeoutSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testPut() : void in class org.apache.ignite.internal.processors.cache.eviction.fifo.GridCacheFifoEvictionPolicySelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testIntegerType() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,HttpSession> to cache : GridCache<String,HttpSession> in method private testSingleRequest(cfg String) : void in class org.apache.ignite.internal.websession.WebSessionSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<UUID,Person> to cache0 : GridCache<UUID,Person> in method public testLuceneAndSqlMultithreaded() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedQueryMultiThreadedSelfTest |
From |
To |
|
Change Variable Type factCache : Cache<Integer,FactPurchase> to factCache : GridCache<Integer,FactPurchase> in method private queryStorePurchases() : void in class org.apache.ignite.examples.datagrid.starschema.CacheStarSchemaExample |
From |
To |
|
Change Variable Type c1 : Cache<Object,MyValue> to c1 : GridCache<Object,MyValue> in method public checkCache(keys Object[]) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedPreloadLifecycleSelfTest |
From |
To |
|
Change Variable Type checkCache : Cache<Integer,String> to checkCache : GridCache<Integer,String> in method private checkTransaction(concurrency IgniteTxConcurrency, isolation IgniteTxIsolation) : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheNodeFailureAbstractTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method public call() : Boolean in class org.apache.ignite.loadtests.datastructures.GridCachePartitionedAtomicLongLoadTest.AtomicCallable |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method public testTxFinishPartitions() : void in class org.apache.ignite.internal.processors.cache.GridCacheFinishPartitionsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testBasicOps() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheMixedModeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testMisses() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractMetricsSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<Integer,Integer> to cache0 : GridCache<Integer,Integer> in method private checkRemove() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheAtomicNearCacheSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method public testCacheContainsEntriesGet1() : void in class org.apache.ignite.lang.GridFuncSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public testUnloadOneBackThreeNodesWithLifeCycleBean() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadUnloadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testAccumulativeMetrics() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryMetricsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private getId() : long in class org.apache.ignite.loadtests.dsi.GridDsiPerfJob |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public call() : Void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheEntrySetAbstractSelfTest.testEntrySet.runMultiThreaded |
From |
To |
|
Change Variable Type cache3 : Cache<Integer,String> to cache3 : GridCache<Integer,String> in method public testSynchronousCommitNodeLeave() : void in class org.apache.ignite.internal.processors.cache.GridCacheReplicatedSynchronousCommitTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private checkKeySet(g Ignite) : void in class org.apache.ignite.internal.processors.cache.GridCacheValueConsistencyAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method public testGetFromNearNode() : void in class org.apache.ignite.internal.processors.cache.GridCachePartitionedGetSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testNodeLeft() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.GridCacheReplicatedFieldsQuerySelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testMultiThreadedScanQuery() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryMultiThreadedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private checkPolicyConsistency() : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheConcurrentEvictionConsistencySelfTest |
From |
To |
|
Change Variable Type c : Cache<String,String> to c : GridCache<String,String> in method public testEvictionEvent() : void in class org.apache.ignite.internal.processors.cache.GridCacheEvictionEventAbstractTest |
From |
To |
|
Change Variable Type cache2 : Cache<Long,Object> to cache2 : GridCache<Long,Object> in method public _testCacheRedeployVersionChangeContinuousMode() : void in class org.apache.ignite.p2p.GridP2PUserVersionChangeSelfTest |
From |
To |
|
Change Variable Type near : Cache<K,V> to near : GridCache<K,V> in method public isLockedByThread() : boolean in class org.apache.ignite.internal.processors.cache.GridCacheEntryImpl |
From |
To |
|
Change Variable Type cache3 : Cache<Integer,Object> to cache3 : GridCache<Integer,Object> in method public testDeployment() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type near : Cache<Integer,String> to near : GridCache<Integer,String> in method public testOptimisticWriteThrough() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testConcurrentGet() : void in class org.apache.ignite.internal.processors.cache.GridCacheBasicStoreMultithreadedAbstractTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Value> to cache : GridCache<Integer,Value> in method public testReplicated() : void in class org.apache.ignite.internal.processors.cache.GridCacheEntryMemorySizeSelfTest |
From |
To |
|
Change Variable Type cache0 : Cache<Integer,Integer> to cache0 : GridCache<Integer,Integer> in method public testBackupRead() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearMetricsSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testTransactionSingleGetRemove() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOneNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache to cache : GridCache in method public _testFormat() : void in class org.apache.ignite.internal.processors.fs.GridGgfsAbstractSelfTest |
From |
To |
|
Change Variable Type c2 : Cache<Object,MyValue> to c2 : GridCache<Object,MyValue> in method public checkCache(keys Object[]) : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedPreloadLifecycleSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public call() : Object in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearEvictionSelfTest.testNearEnabledTwoNodes.broadcast |
From |
To |
|
Change Variable Type prj1 : Cache<Object,Object> to prj1 : GridCache<Object,Object> in method public testPutAllManyKeysTwoReaders() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearReadersSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private checkPrimaryNodeCrash(commmit boolean) : void in class org.apache.ignite.internal.processors.cache.distributed.IgniteTxPessimisticOriginatingNodeFailureAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testPutxShouldNotTriggerLoadWithTx() : void in class org.apache.ignite.internal.processors.cache.GridCacheStorePutxSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Long> to cache : GridCache<Integer,Long> in method public run() : void in class org.apache.ignite.examples.datagrid.CachePopularNumbersExample.scheduleQuery.task |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private checkPut(grid int) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheAtomicNearCacheSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testFilteredPutCheckNear() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedFilteredPutSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Value> to cache : GridCache<Integer,Value> in method public testLocal() : void in class org.apache.ignite.internal.processors.cache.GridCacheEntryMemorySizeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Long,Person> to cache : GridCache<Long,Person> in method public loadCache(clo IgniteBiInClosure<Long,Person>, args Object...) : void in class org.apache.ignite.examples.datagrid.store.dummy.CacheDummyPersonStore |
From |
To |
|
Change Variable Type c : Cache<GridSpringCacheTestKey,String> to c : GridCache<GridSpringCacheTestKey,String> in method public testComplexKey() : void in class org.apache.ignite.spring.GridSpringCacheManagerSelfTest |
From |
To |
|
Change Variable Type cache : Cache<BadHashKeyObject,Integer> to cache : GridCache<BadHashKeyObject,Integer> in method public testBadHashObjectKey() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testCallbackForPreload() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testEvictExpired() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicClientOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method private runBenchmark(keysCnt int, batchSize int, outputFileName String) : void in class org.apache.ignite.loadtests.swap.GridSwapEvictAllBenchmark |
From |
To |
|
Change Variable Type cache1 : Cache<Object,Object> to cache1 : GridCache<Object,Object> in method private checkCache(g Ignite, cacheName String, simulateTimeout boolean, configureTimeout boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheSlowTxWarnTest |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method public testDefaultCache() : void in class org.apache.ignite.marshaller.GridMarshallerAbstractTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,String> to cache2 : GridCache<Integer,String> in method public testIntegrity() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testPutDebug() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type c : Cache<GridSpringCacheTestKey,String> to c : GridCache<GridSpringCacheTestKey,String> in method public testComplexKeyPut() : void in class org.apache.ignite.spring.GridSpringCacheManagerSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Long,Long> to cache : GridCache<Long,Long> in method public testIteratorsCleanup() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapAndSwapSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,Object> to cache1 : GridCache<Integer,Object> in method public testOffHeapDeployment() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapSelfTest |
From |
To |
|
Change Variable Type dimCache : Cache<Integer,Object> to dimCache : GridCache<Integer,Object> in method private body(prj CacheProjection<Integer,FactPurchase>) : List<Map.Entry<Integer,FactPurchase>> in class org.apache.ignite.internal.processors.cache.GridCacheCrossCacheQuerySelfTest |
From |
To |
|
Change Variable Type primary : Cache<String,Integer> to primary : GridCache<String,Integer> in method public testClearKeys() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheAtomicClientOnlyMultiNodeFullApiSelfTest |
From |
To |
|
Change Variable Type c2 : Cache<String,Integer> to c2 : GridCache<String,Integer> in method public testAutomaticPreload() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadMessageCountTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Student> to cache : GridCache<Integer,Student> in method public call() : Object in class org.apache.ignite.loadtests.cache.GridCacheSingleNodeLoadTest.runTest.runMultiThreaded |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method public testPeekExpired() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public call() : Object in class org.apache.ignite.internal.processors.cache.datastructures.partitioned.GridCachePartitionedQueueCreateMultiNodeSelfTest.testTx.fut.multithreadedAsync |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,String> to cache2 : GridCache<Integer,String> in method public testBatchSize1() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,String> to c : GridCache<Integer,String> in method public call() : Object in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearEvictionSelfTest.testNearEnabledThreeNodes.broadcast |
From |
To |
|
Change Variable Type cache : Cache<Long,Long> to cache : GridCache<Long,Long> in method public testUnswap() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapAndSwapSelfTest |
From |
To |
|
Change Variable Type nearOnly : Cache<Object,Object> to nearOnly : GridCache<Object,Object> in method public testPutFromClientNode() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheClientModesAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testIterationAndUpdates() : void in class org.apache.ignite.internal.processors.cache.query.continuous.GridCacheContinuousQueryAbstractSelfTest |
From |
To |
|
Change Variable Type emptyCaches : Collection<Cache<Integer,String>> to emptyCaches : Collection<GridCache<Integer,String>> in method public testReloadAll() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCachePartitionedReloadAllAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testEvictExpired() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testClientOnlyNode() : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.GridCacheReplicatedQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,Integer> to cache : GridCache<String,Integer> in method public testReloadFiltered() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public run() : void in class org.apache.ignite.internal.processors.cache.distributed.GridCacheAbstractNodeRestartSelfTest.checkRestartWithPut.t |
From |
To |
|
Change Variable Type cache : Cache<Integer,CacheValue> to cache : GridCache<Integer,CacheValue> in method public testOffHeap() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method private localIterators() : void in class org.apache.ignite.examples.datagrid.CacheApiExample |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public testCacheValueDeploymentOnPut() : void in class org.apache.ignite.internal.managers.deployment.GridDeploymentMessageCountSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,String> to cache1 : GridCache<Integer,String> in method public testTwoNodesTwoKeysOneBackup() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearReadersSelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,byte[]> to c : GridCache<Integer,byte[]> in method private checkPutGetRemoveTxByteArray(key Integer, txConcurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapTieredAbstractSelfTest |
From |
To |
|
Change Variable Type anotherCache : Cache<Double,Boolean> to anotherCache : GridCache<Double,Boolean> in method public testTypeProjection() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractProjectionSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method public testOffHeapIterator() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffHeapSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Object> to cache : GridCache<Integer,Object> in method private testAtomic0(caches GridCache<Integer,Object>[]) : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheAbstractPartitionedOnlyByteArrayValuesSelfTest |
From |
To |
|
Change Variable Type cache1 : Cache<Integer,Object> to cache1 : GridCache<Integer,Object> in method public testSwapDeployment() : void in class org.apache.ignite.internal.processors.cache.GridCacheSwapSelfTest |
From |
To |
|
Change Variable Type rmtCache : Cache<Object,Object> to rmtCache : GridCache<Object,Object> in method public testUpdateInPessimisticTxOnRemoteNode() : void in class org.apache.ignite.internal.processors.cache.GridCacheOffheapUpdateSelfTest |
From |
To |
|
Change Variable Type cache : Cache<CacheAffinityKey<String>,String> to cache : GridCache<CacheAffinityKey<String>,String> in method private checkGroupLockRemoveWrongKey(concurrency IgniteTxConcurrency) : void in class org.apache.ignite.internal.processors.cache.GridCacheGroupLockAbstractSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,ObjectValue> to cache : GridCache<Integer,ObjectValue> in method public testRemoveIndex() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,String> to cache : GridCache<Integer,String> in method public testPutIfAbsentFromNear() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedBasicStoreMultiNodeSelfTest |
From |
To |
|
Change Variable Type cache : Cache<Object,Object> to cache : GridCache<Object,Object> in method public _testNoPrimitives() : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFieldsQuerySelfTest |
From |
To |
|
Change Variable Type c : Cache<Integer,Integer> to c : GridCache<Integer,Integer> in method public testReduceWithPagination() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCachePartitionedQuerySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,Integer> to cache : GridCache<Integer,Integer> in method private assertCacheContent(expVals Map<Integer,GridTuple<Integer>>) : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractRemoveFailureTest |
From |
To |
|
Change Variable Type c2 : Cache<Object,MyValue> to c2 : GridCache<Object,MyValue> in method public onLifecycleEvent(evt LifecycleEventType) : void in class org.apache.ignite.internal.processors.cache.distributed.replicated.preloader.GridCacheReplicatedPreloadLifecycleSelfTest.lifecycleBean |
From |
To |
|
Change Variable Type dhtCache : Cache<Object,Object> to dhtCache : GridCache<Object,Object> in method public testUpdateNearOnlyReader() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearOnlySelfTest |
From |
To |
|
Change Variable Type cache : Cache<Integer,ValueObject> to cache : GridCache<Integer,ValueObject> in method public testReload() : void in class org.apache.ignite.internal.processors.cache.GridCacheQueryLoadSelfTest |
From |
To |
|
Change Variable Type c2 : Cache<String,Integer> to c2 : GridCache<String,Integer> in method public testDelayedPreload() : void in class org.apache.ignite.internal.processors.cache.distributed.dht.GridCacheDhtPreloadDelayedSelfTest |
From |
To |
|
Change Variable Type cache : Cache<String,String> to cache : GridCache<String,String> in method private checkPolicy0() : void in class org.apache.ignite.internal.processors.cache.eviction.GridCacheEmptyEntriesAbstractSelfTest |
From |
To |
|
Change Variable Type c : Cache<String,Integer> to c : GridCache<String,Integer> in method private checkTtl(inTx boolean, oldEntry boolean) : void in class org.apache.ignite.internal.processors.cache.GridCacheAbstractFullApiSelfTest |
From |
To |
|
Change Variable Type cache2 : Cache<Integer,String> to cache2 : GridCache<Integer,String> in method public testTwoNodesTwoKeysNoBackups() : void in class org.apache.ignite.internal.processors.cache.distributed.near.GridCacheNearReadersSelfTest |
From |
To |