Search in sources :

Example 1 with TransactionsMXBean

use of org.apache.ignite.mxbean.TransactionsMXBean in project ignite by apache.

the class CacheMetricsManageTest method testKeyCollisionsMetricDifferentTimeout.

/**
 * Tests metric change interval.
 */
@Test
public void testKeyCollisionsMetricDifferentTimeout() throws Exception {
    Assume.assumeFalse("https://issues.apache.org/jira/browse/IGNITE-9224", MvccFeatureChecker.forcedMvcc());
    backups = 2;
    useTestCommSpi = true;
    Ignite ig = startGridsMultiThreaded(3);
    int contCnt = (int) U.staticField(IgniteTxManager.class, "COLLISIONS_QUEUE_THRESHOLD") * 5;
    CountDownLatch txLatch = new CountDownLatch(contCnt);
    ig.cluster().active(true);
    client = true;
    Ignite cl = startGrid();
    IgniteTransactions txMgr = cl.transactions();
    CacheConfiguration<?, ?> dfltCacheCfg = getCacheConfiguration();
    dfltCacheCfg.setStatisticsEnabled(true);
    String cacheName = dfltCacheCfg.getName();
    IgniteCache<Integer, Integer> cache = ig.cache(cacheName);
    IgniteCache<Integer, Integer> cache0 = cl.cache(cacheName);
    final Integer keyId = primaryKey(cache);
    CountDownLatch blockOnce = new CountDownLatch(1);
    for (Ignite ig0 : G.allGrids()) {
        if (ig0.configuration().isClientMode())
            continue;
        TestRecordingCommunicationSpi commSpi0 = (TestRecordingCommunicationSpi) ig0.configuration().getCommunicationSpi();
        commSpi0.blockMessages(new IgniteBiPredicate<ClusterNode, Message>() {

            @Override
            public boolean apply(ClusterNode node, Message msg) {
                if (msg instanceof GridNearTxFinishResponse && blockOnce.getCount() > 0) {
                    blockOnce.countDown();
                    return true;
                }
                return false;
            }
        });
    }
    IgniteInternalFuture f = GridTestUtils.runAsync(() -> {
        try (Transaction tx = txMgr.txStart(PESSIMISTIC, READ_COMMITTED)) {
            cache0.put(keyId, 0);
            tx.commit();
        }
    });
    blockOnce.await();
    GridCompoundFuture<?, ?> finishFut = new GridCompoundFuture<>();
    for (int i = 0; i < contCnt; ++i) {
        IgniteInternalFuture f0 = GridTestUtils.runAsync(() -> {
            try (Transaction tx = txMgr.txStart(PESSIMISTIC, READ_COMMITTED)) {
                cache0.put(keyId, 0);
                tx.commit();
                txLatch.countDown();
            }
        });
        finishFut.add(f0);
    }
    finishFut.markInitialized();
    for (Ignite ig0 : G.allGrids()) {
        TestRecordingCommunicationSpi commSpi0 = (TestRecordingCommunicationSpi) ig0.configuration().getCommunicationSpi();
        if (ig0.configuration().isClientMode())
            continue;
        commSpi0.stopBlock();
    }
    CacheMetricsMXBean mxBeanCache = mxBean(0, cacheName, CacheLocalMetricsMXBeanImpl.class);
    IgniteTxManager txManager = ((IgniteEx) ig).context().cache().context().tm();
    final TransactionsMXBean txMXBean1 = txMXBean(0);
    final TransactionsMXBean txMXBean2 = txMXBean(1);
    for (int i = 0; i < 10; ++i) {
        txMXBean1.setTxKeyCollisionsInterval(ThreadLocalRandom.current().nextInt(1000, 1100));
        txMXBean2.setTxKeyCollisionsInterval(ThreadLocalRandom.current().nextInt(1000, 1100));
        mxBeanCache.getTxKeyCollisions();
        mxBeanCache.clear();
        try {
            U.invoke(IgniteTxManager.class, txManager, "collectTxCollisionsInfo");
        } catch (IgniteCheckedException e) {
            fail(e.toString());
        }
        U.sleep(500);
    }
    f.get();
    finishFut.get();
    txLatch.await();
}
Also used : ClusterNode(org.apache.ignite.cluster.ClusterNode) Message(org.apache.ignite.plugin.extensions.communication.Message) CacheMetricsMXBean(org.apache.ignite.mxbean.CacheMetricsMXBean) IgniteTxManager(org.apache.ignite.internal.processors.cache.transactions.IgniteTxManager) CountDownLatch(java.util.concurrent.CountDownLatch) IgniteTransactions(org.apache.ignite.IgniteTransactions) IgniteInternalFuture(org.apache.ignite.internal.IgniteInternalFuture) GridCompoundFuture(org.apache.ignite.internal.util.future.GridCompoundFuture) GridNearTxFinishResponse(org.apache.ignite.internal.processors.cache.distributed.near.GridNearTxFinishResponse) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) TransactionsMXBean(org.apache.ignite.mxbean.TransactionsMXBean) TestRecordingCommunicationSpi(org.apache.ignite.internal.TestRecordingCommunicationSpi) IgniteCheckedException(org.apache.ignite.IgniteCheckedException) Transaction(org.apache.ignite.transactions.Transaction) Ignite(org.apache.ignite.Ignite) GridCommonAbstractTest(org.apache.ignite.testframework.junits.common.GridCommonAbstractTest) Test(org.junit.Test)

Example 2 with TransactionsMXBean

use of org.apache.ignite.mxbean.TransactionsMXBean in project ignite by apache.

the class TransactionsMXBeanImplTest method testBasic.

/**
 */
@Test
public void testBasic() throws Exception {
    IgniteEx ignite = startGrid(0);
    ignite.cluster().state(ACTIVE);
    TransactionsMXBean bean = txMXBean(0);
    ignite.transactions().txStart();
    ignite.cache(DEFAULT_CACHE_NAME).put(0, 0);
    String res = bean.getActiveTransactions(null, null, null, null, null, null, null, null, false, false);
    assertEquals("1", res);
    res = bean.getActiveTransactions(null, null, null, null, null, null, null, null, true, false);
    assertTrue(res.indexOf("Tx:") > 0);
    res = bean.getActiveTransactions(null, null, null, null, null, null, null, null, false, true);
    assertEquals("1", res);
    doSleep(500);
    res = bean.getActiveTransactions(null, null, null, null, null, null, null, null, false, false);
    assertEquals("0", res);
}
Also used : TransactionsMXBean(org.apache.ignite.mxbean.TransactionsMXBean) GridCommonAbstractTest(org.apache.ignite.testframework.junits.common.GridCommonAbstractTest) Test(org.junit.Test)

Example 3 with TransactionsMXBean

use of org.apache.ignite.mxbean.TransactionsMXBean in project ignite by apache.

the class GridTransactionsSystemUserTimeMetricsTest method testJmxParametersSpreading.

/**
 * Test that changing of JMX parameters spreads on cluster correctly.
 *
 * @throws Exception If failed.
 */
@Test
public void testJmxParametersSpreading() throws Exception {
    IgniteEx client2 = startGrid(CLIENT_2);
    try {
        TransactionsMXBean tmMxBean = getMxBean(CLIENT, "Transactions", TransactionsMXBeanImpl.class, TransactionsMXBean.class);
        TransactionsMXBean tmMxBean2 = getMxBean(CLIENT_2, "Transactions", TransactionsMXBeanImpl.class, TransactionsMXBean.class);
        int oldLimit = tmMxBean.getTransactionTimeDumpSamplesPerSecondLimit();
        long oldThreshold = tmMxBean.getLongTransactionTimeDumpThreshold();
        double oldCoefficient = tmMxBean.getTransactionTimeDumpSamplesCoefficient();
        try {
            int newLimit = 1234;
            long newThreshold = 99999;
            double newCoefficient = 0.01;
            applyJmxParameters(null, newCoefficient, newLimit);
            applyJmxParameters(newThreshold, null, null, tmMxBean2, client2);
            assertEquals(newLimit, tmMxBean2.getTransactionTimeDumpSamplesPerSecondLimit());
            assertEquals(newThreshold, tmMxBean.getLongTransactionTimeDumpThreshold());
            assertTrue(tmMxBean2.getTransactionTimeDumpSamplesCoefficient() - newCoefficient < 0.0001);
        } finally {
            applyJmxParameters(oldThreshold, oldCoefficient, oldLimit);
        }
    } finally {
        // CLIENT grid is stopped in afterTest.
        stopGrid(CLIENT_2);
    }
}
Also used : TransactionsMXBean(org.apache.ignite.mxbean.TransactionsMXBean) IgniteEx(org.apache.ignite.internal.IgniteEx) GridCommonAbstractTest(org.apache.ignite.testframework.junits.common.GridCommonAbstractTest) Test(org.junit.Test)

Example 4 with TransactionsMXBean

use of org.apache.ignite.mxbean.TransactionsMXBean in project ignite by apache.

the class IgniteMBeansManager method registerMBeansAfterNodeStarted.

/**
 * Registers kernal MBeans (for kernal, metrics, thread pools) after node start.
 *
 * @throws IgniteCheckedException if fails to register any of the MBeans.
 */
public void registerMBeansAfterNodeStarted() throws IgniteCheckedException {
    if (U.IGNITE_MBEANS_DISABLED)
        return;
    // Kernal
    IgniteMXBean kernalMXBean = new IgniteMXBeanImpl(kernal);
    registerMBean("Kernal", IgniteKernal.class.getSimpleName(), kernalMXBean, IgniteMXBean.class);
    // Metrics
    ClusterMetricsMXBean locMetricsBean = new ClusterLocalNodeMetricsMXBeanImpl(ctx.discovery());
    registerMBean("Kernal", locMetricsBean.getClass().getSimpleName(), locMetricsBean, ClusterMetricsMXBean.class);
    ClusterMetricsMXBean metricsBean = new ClusterMetricsMXBeanImpl(kernal.cluster(), ctx);
    registerMBean("Kernal", metricsBean.getClass().getSimpleName(), metricsBean, ClusterMetricsMXBean.class);
    // Transaction metrics
    TransactionMetricsMxBean txMetricsMXBean = new TransactionMetricsMxBeanImpl(ctx.cache().transactions().metrics());
    registerMBean("TransactionMetrics", txMetricsMXBean.getClass().getSimpleName(), txMetricsMXBean, TransactionMetricsMxBean.class);
    // Transactions
    TransactionsMXBean txMXBean = new TransactionsMXBeanImpl(ctx);
    registerMBean("Transactions", txMXBean.getClass().getSimpleName(), txMXBean, TransactionsMXBean.class);
    // Queries management
    QueryMXBean qryMXBean = new QueryMXBeanImpl(ctx);
    registerMBean("Query", qryMXBean.getClass().getSimpleName(), qryMXBean, QueryMXBean.class);
    // Compute task management
    ComputeMXBean computeMXBean = new ComputeMXBeanImpl(ctx);
    registerMBean("Compute", computeMXBean.getClass().getSimpleName(), computeMXBean, ComputeMXBean.class);
    // Service management
    ServiceMXBean serviceMXBean = new ServiceMXBeanImpl(ctx);
    registerMBean("Service", serviceMXBean.getClass().getSimpleName(), serviceMXBean, ServiceMXBean.class);
    // Data storage
    DataStorageMXBean dataStorageMXBean = new DataStorageMXBeanImpl(ctx);
    registerMBean("DataStorage", dataStorageMXBean.getClass().getSimpleName(), dataStorageMXBean, DataStorageMXBean.class);
    // Baseline configuration
    BaselineAutoAdjustMXBean baselineAutoAdjustMXBean = new BaselineAutoAdjustMXBeanImpl(ctx);
    registerMBean("Baseline", baselineAutoAdjustMXBean.getClass().getSimpleName(), baselineAutoAdjustMXBean, BaselineAutoAdjustMXBean.class);
    // Encryption
    EncryptionMXBean encryptionMXBean = new EncryptionMXBeanImpl(ctx);
    registerMBean("Encryption", encryptionMXBean.getClass().getSimpleName(), encryptionMXBean, EncryptionMXBean.class);
    // Snapshot.
    SnapshotMXBean snpMXBean = new SnapshotMXBeanImpl(ctx);
    registerMBean("Snapshot", snpMXBean.getClass().getSimpleName(), snpMXBean, SnapshotMXBean.class);
    // Defragmentation.
    DefragmentationMXBean defragMXBean = new DefragmentationMXBeanImpl(ctx);
    registerMBean("Defragmentation", defragMXBean.getClass().getSimpleName(), defragMXBean, DefragmentationMXBean.class);
    // Metrics configuration
    MetricsMxBean metricsMxBean = new MetricsMxBeanImpl(ctx.metric(), log);
    registerMBean("Metrics", metricsMxBean.getClass().getSimpleName(), metricsMxBean, MetricsMxBean.class);
    ctx.pools().registerMxBeans(this);
    if (U.IGNITE_TEST_FEATURES_ENABLED) {
        WorkersControlMXBean workerCtrlMXBean = new WorkersControlMXBeanImpl(ctx.workersRegistry());
        registerMBean("Kernal", workerCtrlMXBean.getClass().getSimpleName(), workerCtrlMXBean, WorkersControlMXBean.class);
    }
    FailureHandlingMxBean blockOpCtrlMXBean = new FailureHandlingMxBeanImpl(ctx.workersRegistry(), ctx.cache().context().database());
    registerMBean("Kernal", blockOpCtrlMXBean.getClass().getSimpleName(), blockOpCtrlMXBean, FailureHandlingMxBean.class);
    if (ctx.query().moduleEnabled())
        ctx.query().getIndexing().registerMxBeans(this);
    PerformanceStatisticsMBeanImpl performanceStatMbean = new PerformanceStatisticsMBeanImpl(ctx);
    registerMBean("PerformanceStatistics", performanceStatMbean.getClass().getSimpleName(), performanceStatMbean, PerformanceStatisticsMBean.class);
}
Also used : QueryMXBean(org.apache.ignite.mxbean.QueryMXBean) TransactionMetricsMxBeanImpl(org.apache.ignite.internal.TransactionMetricsMxBeanImpl) QueryMXBeanImpl(org.apache.ignite.internal.QueryMXBeanImpl) ComputeMXBean(org.apache.ignite.mxbean.ComputeMXBean) ClusterLocalNodeMetricsMXBeanImpl(org.apache.ignite.internal.ClusterLocalNodeMetricsMXBeanImpl) EncryptionMXBeanImpl(org.apache.ignite.internal.managers.encryption.EncryptionMXBeanImpl) ServiceMXBean(org.apache.ignite.mxbean.ServiceMXBean) BaselineAutoAdjustMXBean(org.apache.ignite.mxbean.BaselineAutoAdjustMXBean) WorkersControlMXBeanImpl(org.apache.ignite.internal.worker.WorkersControlMXBeanImpl) SnapshotMXBeanImpl(org.apache.ignite.internal.processors.cache.persistence.snapshot.SnapshotMXBeanImpl) DefragmentationMXBean(org.apache.ignite.mxbean.DefragmentationMXBean) DataStorageMXBeanImpl(org.apache.ignite.internal.processors.cache.persistence.DataStorageMXBeanImpl) EncryptionMXBean(org.apache.ignite.mxbean.EncryptionMXBean) IgniteKernal(org.apache.ignite.internal.IgniteKernal) TransactionsMXBeanImpl(org.apache.ignite.internal.TransactionsMXBeanImpl) ClusterMetricsMXBeanImpl(org.apache.ignite.internal.ClusterMetricsMXBeanImpl) ServiceMXBeanImpl(org.apache.ignite.internal.ServiceMXBeanImpl) IgniteMXBean(org.apache.ignite.mxbean.IgniteMXBean) DataStorageMXBean(org.apache.ignite.mxbean.DataStorageMXBean) PerformanceStatisticsMBeanImpl(org.apache.ignite.internal.processors.performancestatistics.PerformanceStatisticsMBeanImpl) ComputeMXBeanImpl(org.apache.ignite.internal.ComputeMXBeanImpl) ClusterMetricsMXBean(org.apache.ignite.mxbean.ClusterMetricsMXBean) TransactionMetricsMxBean(org.apache.ignite.mxbean.TransactionMetricsMxBean) SnapshotMXBean(org.apache.ignite.mxbean.SnapshotMXBean) TransactionsMXBean(org.apache.ignite.mxbean.TransactionsMXBean) BaselineAutoAdjustMXBeanImpl(org.apache.ignite.internal.processors.cluster.BaselineAutoAdjustMXBeanImpl) WorkersControlMXBean(org.apache.ignite.mxbean.WorkersControlMXBean) FailureHandlingMxBean(org.apache.ignite.mxbean.FailureHandlingMxBean) TransactionMetricsMxBean(org.apache.ignite.mxbean.TransactionMetricsMxBean) MetricsMxBean(org.apache.ignite.mxbean.MetricsMxBean) TransactionMetricsMxBeanImpl(org.apache.ignite.internal.TransactionMetricsMxBeanImpl) MetricsMxBeanImpl(org.apache.ignite.internal.processors.metric.MetricsMxBeanImpl) DefragmentationMXBeanImpl(org.apache.ignite.internal.processors.cache.persistence.defragmentation.DefragmentationMXBeanImpl) IgniteMXBeanImpl(org.apache.ignite.internal.IgniteMXBeanImpl) FailureHandlingMxBeanImpl(org.apache.ignite.internal.worker.FailureHandlingMxBeanImpl)

Example 5 with TransactionsMXBean

use of org.apache.ignite.mxbean.TransactionsMXBean in project ignite by apache.

the class TransactionsMXBeanImplTest method testChangeLongOperationsDumpTimeoutOnImmutableCluster.

/**
 * Test to verify the correct change of {@link TransactionsMXBean#getLongOperationsDumpTimeout()}
 * in an immutable cluster.
 *
 * @throws Exception If failed.
 */
@Test
@WithSystemProperty(key = IGNITE_LONG_OPERATIONS_DUMP_TIMEOUT, value = "100")
public void testChangeLongOperationsDumpTimeoutOnImmutableCluster() throws Exception {
    Map<IgniteEx, TransactionsMXBean> allNodes = startGridAndActivate(2);
    Map<IgniteEx, TransactionsMXBean> clientNodes = new HashMap<>();
    Map<IgniteEx, TransactionsMXBean> srvNodes = new HashMap<>(allNodes);
    clientNode = true;
    for (int i = 2; i < 4; i++) {
        IgniteEx igniteEx = startGrid(i);
        TransactionsMXBean transactionsMXBean = txMXBean(i);
        allNodes.put(igniteEx, transactionsMXBean);
        clientNodes.put(igniteEx, transactionsMXBean);
    }
    // check for default value
    checkPropertyValueViaTxMxBean(allNodes, 100L, TransactionsMXBean::getLongOperationsDumpTimeout);
    // create property update latches for client nodes
    Map<IgniteEx, List<CountDownLatch>> updateLatches = new HashMap<>();
    clientNodes.keySet().forEach(ignite -> updateLatches.put(ignite, F.asList(new CountDownLatch(1), new CountDownLatch(1))));
    clientNodes.forEach((igniteEx, bean) -> igniteEx.context().distributedMetastorage().listen((key) -> key.startsWith(DIST_CONF_PREFIX), (String key, Serializable oldVal, Serializable newVal) -> {
        if ((long) newVal == 200)
            updateLatches.get(igniteEx).get(0).countDown();
        if ((long) newVal == 300)
            updateLatches.get(igniteEx).get(1).countDown();
    }));
    long newTimeout = 200L;
    // update value via server node
    updatePropertyViaTxMxBean(allNodes, TransactionsMXBean::setLongOperationsDumpTimeout, newTimeout);
    // check new value in server nodes
    checkPropertyValueViaTxMxBean(srvNodes, newTimeout, TransactionsMXBean::getLongOperationsDumpTimeout);
    // check new value in client nodes
    for (List<CountDownLatch> list : updateLatches.values()) {
        CountDownLatch countDownLatch = list.get(0);
        countDownLatch.await(100, TimeUnit.MILLISECONDS);
    }
    newTimeout = 300L;
    // update value via server node
    updatePropertyViaTxMxBean(clientNodes, TransactionsMXBean::setLongOperationsDumpTimeout, newTimeout);
    // check new value in server nodes
    checkPropertyValueViaTxMxBean(srvNodes, newTimeout, TransactionsMXBean::getLongOperationsDumpTimeout);
    // check new value on client nodes
    for (List<CountDownLatch> list : updateLatches.values()) {
        CountDownLatch countDownLatch = list.get(1);
        countDownLatch.await(100, TimeUnit.MILLISECONDS);
    }
}
Also used : ListeningTestLogger(org.apache.ignite.testframework.ListeningTestLogger) LogListener(org.apache.ignite.testframework.LogListener) Transaction(org.apache.ignite.transactions.Transaction) GridTestUtils.waitForCondition(org.apache.ignite.testframework.GridTestUtils.waitForCondition) HashMap(java.util.HashMap) CacheRebalanceMode(org.apache.ignite.cache.CacheRebalanceMode) Function(java.util.function.Function) RendezvousAffinityFunction(org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction) IGNITE_LONG_TRANSACTION_TIME_DUMP_THRESHOLD(org.apache.ignite.IgniteSystemProperties.IGNITE_LONG_TRANSACTION_TIME_DUMP_THRESHOLD) Map(java.util.Map) BiConsumer(java.util.function.BiConsumer) LogListener.matches(org.apache.ignite.testframework.LogListener.matches) DataStorageConfiguration(org.apache.ignite.configuration.DataStorageConfiguration) Collections.singletonMap(java.util.Collections.singletonMap) IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_COEFFICIENT(org.apache.ignite.IgniteSystemProperties.IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_COEFFICIENT) ACTIVE(org.apache.ignite.cluster.ClusterState.ACTIVE) F(org.apache.ignite.internal.util.typedef.F) GridCommonAbstractTest(org.apache.ignite.testframework.junits.common.GridCommonAbstractTest) IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_PER_SECOND_LIMIT(org.apache.ignite.IgniteSystemProperties.IGNITE_TRANSACTION_TIME_DUMP_SAMPLES_PER_SECOND_LIMIT) IGNITE_TX_OWNER_DUMP_REQUESTS_ALLOWED(org.apache.ignite.IgniteSystemProperties.IGNITE_TX_OWNER_DUMP_REQUESTS_ALLOWED) IGNITE_DUMP_TX_COLLISIONS_INTERVAL(org.apache.ignite.IgniteSystemProperties.IGNITE_DUMP_TX_COLLISIONS_INTERVAL) Test(org.junit.Test) TransactionProxyImpl(org.apache.ignite.internal.processors.cache.transactions.TransactionProxyImpl) FULL_SYNC(org.apache.ignite.cache.CacheWriteSynchronizationMode.FULL_SYNC) TransactionsMXBean(org.apache.ignite.mxbean.TransactionsMXBean) TRANSACTIONAL(org.apache.ignite.cache.CacheAtomicityMode.TRANSACTIONAL) Serializable(java.io.Serializable) TimeUnit(java.util.concurrent.TimeUnit) WithSystemProperty(org.apache.ignite.testframework.junits.WithSystemProperty) CountDownLatch(java.util.concurrent.CountDownLatch) List(java.util.List) IgniteConfiguration(org.apache.ignite.configuration.IgniteConfiguration) CacheConfiguration(org.apache.ignite.configuration.CacheConfiguration) IGNITE_LONG_OPERATIONS_DUMP_TIMEOUT(org.apache.ignite.IgniteSystemProperties.IGNITE_LONG_OPERATIONS_DUMP_TIMEOUT) DataRegionConfiguration(org.apache.ignite.configuration.DataRegionConfiguration) Serializable(java.io.Serializable) HashMap(java.util.HashMap) CountDownLatch(java.util.concurrent.CountDownLatch) TransactionsMXBean(org.apache.ignite.mxbean.TransactionsMXBean) List(java.util.List) GridCommonAbstractTest(org.apache.ignite.testframework.junits.common.GridCommonAbstractTest) Test(org.junit.Test) WithSystemProperty(org.apache.ignite.testframework.junits.WithSystemProperty)

Aggregations

TransactionsMXBean (org.apache.ignite.mxbean.TransactionsMXBean)9 GridCommonAbstractTest (org.apache.ignite.testframework.junits.common.GridCommonAbstractTest)6 Test (org.junit.Test)6 Transaction (org.apache.ignite.transactions.Transaction)3 CountDownLatch (java.util.concurrent.CountDownLatch)2 IgniteCheckedException (org.apache.ignite.IgniteCheckedException)2 TransactionProxyImpl (org.apache.ignite.internal.processors.cache.transactions.TransactionProxyImpl)2 LogListener (org.apache.ignite.testframework.LogListener)2 Serializable (java.io.Serializable)1 Collections.singletonMap (java.util.Collections.singletonMap)1 HashMap (java.util.HashMap)1 List (java.util.List)1 Map (java.util.Map)1 TimeUnit (java.util.concurrent.TimeUnit)1 AtomicInteger (java.util.concurrent.atomic.AtomicInteger)1 AtomicReference (java.util.concurrent.atomic.AtomicReference)1 BiConsumer (java.util.function.BiConsumer)1 Function (java.util.function.Function)1 Ignite (org.apache.ignite.Ignite)1 IGNITE_DUMP_TX_COLLISIONS_INTERVAL (org.apache.ignite.IgniteSystemProperties.IGNITE_DUMP_TX_COLLISIONS_INTERVAL)1