You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by sk...@apache.org on 2021/03/15 15:21:12 UTC

[ignite] branch master updated: Revert "IGNITE-14079 Added test for checking partition eviction order. Fixes #8719"

This is an automated email from the ASF dual-hosted git repository.

sk0x50 pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/ignite.git


The following commit(s) were added to refs/heads/master by this push:
     new 0056126  Revert "IGNITE-14079 Added test for checking partition eviction order. Fixes #8719"
0056126 is described below

commit 0056126cf4ae467f1939bfe88fff21309350c20f
Author: Slava Koptilin <sl...@gmail.com>
AuthorDate: Mon Mar 15 18:19:49 2021 +0300

    Revert "IGNITE-14079 Added test for checking partition eviction order. Fixes #8719"
    
    This reverts commit 1370230b2bf9bda8da7511caa0c18e2d6e88e639.
---
 .../internal/processors/cache/GridCacheUtils.java  |   3 -
 .../dht/topology/PartitionEvictionOrderTest.java   | 159 ---------------------
 2 files changed, 162 deletions(-)

diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheUtils.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheUtils.java
index 76f8fcb..ff023d0 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheUtils.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheUtils.java
@@ -180,9 +180,6 @@ public class GridCacheUtils {
     /** System cache name. */
     public static final String UTILITY_CACHE_NAME = "ignite-sys-cache";
 
-    /** System cache group id. */
-    public static final int UTILITY_CACHE_GROUP_ID = cacheGroupId(UTILITY_CACHE_NAME, null);
-
     /** Reserved cache names */
     public static final String[] RESERVED_NAMES = new String[] {
         UTILITY_CACHE_NAME,
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/PartitionEvictionOrderTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/PartitionEvictionOrderTest.java
deleted file mode 100644
index 35fff50..0000000
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/topology/PartitionEvictionOrderTest.java
+++ /dev/null
@@ -1,159 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.internal.processors.cache.distributed.dht.topology;
-
-import java.util.ArrayList;
-import java.util.Collections;
-import java.util.List;
-import org.apache.ignite.IgniteCache;
-import org.apache.ignite.IgniteCheckedException;
-import org.apache.ignite.IgniteSystemProperties;
-import org.apache.ignite.cache.CacheRebalanceMode;
-import org.apache.ignite.configuration.CacheConfiguration;
-import org.apache.ignite.configuration.DataRegionConfiguration;
-import org.apache.ignite.configuration.DataStorageConfiguration;
-import org.apache.ignite.configuration.IgniteConfiguration;
-import org.apache.ignite.internal.IgniteEx;
-import org.apache.ignite.internal.NodeStoppingException;
-import org.apache.ignite.internal.processors.cache.GridCacheAdapter;
-import org.apache.ignite.internal.processors.cache.IgniteInternalCache;
-import org.apache.ignite.internal.processors.resource.DependencyResolver;
-import org.apache.ignite.internal.util.typedef.T2;
-import org.apache.ignite.internal.util.typedef.internal.CU;
-import org.apache.ignite.testframework.TestDependencyResolver;
-import org.apache.ignite.testframework.junits.WithSystemProperty;
-import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
-import org.junit.Test;
-
-import static org.apache.ignite.IgniteSystemProperties.IGNITE_PDS_WAL_REBALANCE_THRESHOLD;
-import static org.apache.ignite.cache.CacheAtomicityMode.ATOMIC;
-import static org.apache.ignite.cache.CacheMode.REPLICATED;
-import static org.apache.ignite.cluster.ClusterState.ACTIVE;
-
-/**
- * Tests that {@link CacheRebalanceMode#SYNC} caches are evicted at first.
- */
-public class PartitionEvictionOrderTest extends GridCommonAbstractTest {
-    /** {@inheritDoc} */
-    @Override protected IgniteConfiguration getConfiguration(String igniteInstanceName) throws Exception {
-        IgniteConfiguration cfg = super.getConfiguration(igniteInstanceName);
-
-        cfg.setDataStorageConfiguration(new DataStorageConfiguration()
-            .setDefaultDataRegionConfiguration(new DataRegionConfiguration().setPersistenceEnabled(true)));
-
-        CacheConfiguration<Long, Long> atomicCcfg = new CacheConfiguration<Long, Long>(DEFAULT_CACHE_NAME)
-            .setAtomicityMode(ATOMIC)
-            .setRebalanceMode(CacheRebalanceMode.ASYNC)
-            .setCacheMode(REPLICATED);
-
-        cfg.setCacheConfiguration(atomicCcfg);
-
-        return cfg;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected void beforeTest() throws Exception {
-        super.beforeTest();
-
-        cleanPersistenceDir();
-    }
-
-    /** {@inheritDoc} */
-    @Override protected void afterTest() throws Exception {
-        super.afterTest();
-
-        stopAllGrids();
-
-        cleanPersistenceDir();
-    }
-
-    /**
-     * Tests that {@link CacheRebalanceMode#SYNC} caches are evicted at first.
-     */
-    @Test
-    @WithSystemProperty(key = IgniteSystemProperties.IGNITE_EVICTION_PERMITS, value = "1")
-    @WithSystemProperty(key = IGNITE_PDS_WAL_REBALANCE_THRESHOLD, value = "500_000")
-    public void testSyncCachesEvictedAtFirst() throws Exception {
-        IgniteEx node0 = startGrid(0);
-
-        node0.cluster().state(ACTIVE);
-
-        IgniteEx node1 = startGrid(1);
-
-        node0.cluster().setBaselineTopology(node1.cluster().topologyVersion());
-
-        GridCacheAdapter<Object, Object> utilCache0 = grid(0).context().cache().internalCache(CU.UTILITY_CACHE_NAME);
-
-        IgniteCache<Object, Object> cache = node0.getOrCreateCache(DEFAULT_CACHE_NAME);
-
-        for (int i = 0; i < 1000; i++) {
-            utilCache0.put(i, i);
-
-            cache.put(i, i);
-        }
-
-        awaitPartitionMapExchange();
-
-        stopGrid(0);
-
-        GridCacheAdapter<Object, Object> utilCache1 = grid(1).context().cache().internalCache(CU.UTILITY_CACHE_NAME);
-
-        IgniteInternalCache<Object, Object> cache2 = grid(1).context().cache().cache(DEFAULT_CACHE_NAME);
-
-        for (int i = 0; i < 2000; i++) {
-            try {
-                cache2.put(i, i + 1);
-
-                utilCache1.put(i, i + 1);
-            }
-            catch (IgniteCheckedException e) {
-                e.printStackTrace();
-            }
-        }
-
-        List<T2<Integer, Integer>> evictionOrder = Collections.synchronizedList(new ArrayList<>());
-
-        TestDependencyResolver rslvr = new TestDependencyResolver(new DependencyResolver() {
-            @Override public <T> T resolve(T instance) {
-                if (instance instanceof GridDhtPartitionTopologyImpl) {
-                    GridDhtPartitionTopologyImpl top = (GridDhtPartitionTopologyImpl) instance;
-
-                    top.partitionFactory((ctx, grp, id, recovery) -> new GridDhtLocalPartition(ctx, grp, id, recovery) {
-                        @Override public long clearAll(EvictionContext evictionCtx) throws NodeStoppingException {
-                            evictionOrder.add(new T2<>(grp.groupId(), id));
-
-                            return super.clearAll(evictionCtx);
-                        }
-                    });
-                }
-
-                return instance;
-            }
-        });
-
-        startGrid(0, rslvr);
-
-        awaitPartitionMapExchange(true, true, null);
-
-        assertEquals(utilCache0.affinity().partitions() + grid(0).cachex(DEFAULT_CACHE_NAME).affinity().partitions(),
-            evictionOrder.size());
-
-        for (int i = 0; i < utilCache0.affinity().partitions(); i++)
-            assertEquals(CU.UTILITY_CACHE_GROUP_ID, evictionOrder.get(i).get1().intValue());
-    }
-}