All Downloads are FREE. Search and download functionalities are using the official Maven repository.

org.infinispan.interceptors.impl.BaseStateTransferInterceptor Maven / Gradle / Ivy

package org.infinispan.interceptors.impl;

import java.util.concurrent.CompletableFuture;
import java.util.concurrent.Executor;
import java.util.concurrent.ScheduledExecutorService;
import java.util.concurrent.ScheduledFuture;
import java.util.concurrent.TimeUnit;
import java.util.concurrent.atomic.AtomicReferenceFieldUpdater;
import java.util.function.BiFunction;
import java.util.function.Consumer;

import org.infinispan.commands.TopologyAffectedCommand;
import org.infinispan.commands.VisitableCommand;
import org.infinispan.commands.remote.GetKeysInGroupCommand;
import org.infinispan.configuration.cache.Configuration;
import org.infinispan.context.InvocationContext;
import org.infinispan.distribution.ch.ConsistentHash;
import org.infinispan.distribution.group.GroupManager;
import org.infinispan.factories.KnownComponentNames;
import org.infinispan.factories.annotations.ComponentName;
import org.infinispan.factories.annotations.Inject;
import org.infinispan.interceptors.BasicInvocationStage;
import org.infinispan.interceptors.DDAsyncInterceptor;
import org.infinispan.interceptors.InvocationComposeHandler;
import org.infinispan.interceptors.InvocationStage;
import org.infinispan.remoting.RemoteException;
import org.infinispan.remoting.transport.jgroups.SuspectException;
import org.infinispan.statetransfer.OutdatedTopologyException;
import org.infinispan.statetransfer.StateTransferLock;
import org.infinispan.statetransfer.StateTransferManager;
import org.infinispan.topology.CacheTopology;
import org.infinispan.util.concurrent.CompletableFutures;
import org.infinispan.util.concurrent.TimeoutException;
import org.infinispan.util.logging.Log;
import org.infinispan.util.logging.LogFactory;

/**
 * A base class for a state transfer interceptor. It contains the base code to avoid duplicating in the two current
 * different implementations.
 * 

* Also, it has some utilities methods with the most common logic. * * @author Pedro Ruivo * @since 9.0 */ public abstract class BaseStateTransferInterceptor extends DDAsyncInterceptor { private final boolean trace = getLog().isTraceEnabled(); protected StateTransferManager stateTransferManager; protected StateTransferLock stateTransferLock; protected Executor remoteExecutor; private GroupManager groupManager; private ScheduledExecutorService timeoutExecutor; private long transactionDataTimeout; private final InvocationComposeHandler handleLocalGetKeysInGroupReturn = this::handleLocalGetKeysInGroupReturn; @Inject public void init(StateTransferLock stateTransferLock, Configuration configuration, StateTransferManager stateTransferManager, GroupManager groupManager, @ComponentName(KnownComponentNames.TIMEOUT_SCHEDULE_EXECUTOR) ScheduledExecutorService timeoutExecutor, @ComponentName(KnownComponentNames.REMOTE_COMMAND_EXECUTOR) Executor remoteExecutor) { this.stateTransferLock = stateTransferLock; this.stateTransferManager = stateTransferManager; this.groupManager = groupManager; this.timeoutExecutor = timeoutExecutor; this.remoteExecutor = remoteExecutor; transactionDataTimeout = configuration.clustering().remoteTimeout(); } @Override public BasicInvocationStage visitGetKeysInGroupCommand(InvocationContext ctx, GetKeysInGroupCommand command) throws Throwable { updateTopologyId(command); if (ctx.isOriginLocal()) { return invokeNext(ctx, command) .compose(handleLocalGetKeysInGroupReturn); } else { return invokeNext(ctx, command).thenAccept((rCtx, rCommand, rv) -> { GetKeysInGroupCommand cmd = (GetKeysInGroupCommand) rCommand; final int commandTopologyId = cmd.getTopologyId(); String groupName = cmd.getGroupName(); if (groupManager.isOwner(groupName) && currentTopologyId() != commandTopologyId) { throw new OutdatedTopologyException( "Cache topology changed while the command was executing: expected " + commandTopologyId + ", got " + currentTopologyId()); } }); } } private BasicInvocationStage handleLocalGetKeysInGroupReturn(BasicInvocationStage stage, InvocationContext ctx, VisitableCommand command, Object rv, Throwable t) throws Throwable { GetKeysInGroupCommand cmd = (GetKeysInGroupCommand) command; final int commandTopologyId = cmd.getTopologyId(); boolean shouldRetry; if (t != null) { // Must retry if we got an OutdatedTopologyException or SuspectException Throwable ce = t; while (ce instanceof RemoteException) { ce = ce.getCause(); } shouldRetry = ce instanceof OutdatedTopologyException || ce instanceof SuspectException; } else { // Only check the topology id if if we are an owner shouldRetry = groupManager.isOwner(cmd.getGroupName()) && currentTopologyId() != commandTopologyId; } if (shouldRetry) { logRetry(cmd); // We increment the topology id so that updateTopologyIdAndWaitForTransactionData waits for the next topology. // Without this, we could retry the command too fast and we could get the OutdatedTopologyException again. int newTopologyId = Math.max(currentTopologyId(), commandTopologyId + 1); cmd.setTopologyId(newTopologyId); CompletableFuture transactionDataFuture = stateTransferLock.transactionDataFuture(newTopologyId); return retryWhenDone(transactionDataFuture, newTopologyId, ctx, command) .compose(this::handleLocalGetKeysInGroupReturn); } else { return stage; } } protected final void logRetry(VisitableCommand command) { if (trace) { getLog().tracef("Retrying command because of topology change: %s", command); } } protected final int currentTopologyId() { final CacheTopology cacheTopology = stateTransferManager.getCacheTopology(); return cacheTopology == null ? -1 : cacheTopology.getTopologyId(); } protected final void updateTopologyId(TopologyAffectedCommand command) throws InterruptedException { // set the topology id if it was not set before (ie. this is local command) // TODO Make tx commands extend FlagAffectedCommand so we can use CACHE_MODE_LOCAL in TransactionTable.cleanupStaleTransactions if (command.getTopologyId() == -1) { CacheTopology cacheTopology = stateTransferManager.getCacheTopology(); if (cacheTopology != null) { command.setTopologyId(cacheTopology.getTopologyId()); } } } protected InvocationStage retryWhenDone( CompletableFuture future, int topologyId, InvocationContext ctx, T command) throws Throwable { if (future.isDone()) { getLog().tracef("Retrying command %s for topology %d", command, topologyId); return invokeNext(ctx, command); } else { CancellableRetry cancellableRetry = new CancellableRetry<>(command, topologyId, stateTransferManager); // We have to use handleAsync and rethrow the exception in the handler, rather than // thenComposeAsync(), because if `future` completes with an exception we want to continue in remoteExecutor CompletableFuture retryFuture = future.handleAsync(cancellableRetry, remoteExecutor); cancellableRetry.setRetryFuture(retryFuture); // We want to time out the current command future, not the main topology-waiting future, // but the command future can take longer time to finish. ScheduledFuture timeoutFuture = timeoutExecutor.schedule(cancellableRetry, transactionDataTimeout, TimeUnit.MILLISECONDS); cancellableRetry.setTimeoutFuture(timeoutFuture); return invokeNextAsync(ctx, command, retryFuture); } } protected abstract Log getLog(); private static class CancellableRetry implements BiFunction, Runnable { private static final AtomicReferenceFieldUpdater cancellableRetryUpdater = AtomicReferenceFieldUpdater.newUpdater(CancellableRetry.class, Throwable.class, "cancelled"); private static final AtomicReferenceFieldUpdater timeoutFutureUpdater = AtomicReferenceFieldUpdater.newUpdater(CancellableRetry.class, Object.class, "timeoutFuture"); private static final Log log = LogFactory.getLog(CancellableRetry.class); private static final Throwable DUMMY = new Throwable("Command is retried"); // should not be ever thrown private final T command; private final int topologyId; private final StateTransferManager stateTransferManager; private volatile Throwable cancelled = null; // retryFuture is not volatile because it is used only in the timeout handler = run() // and that is scheduled after retryFuture is set private CompletableFuture retryFuture; // ScheduledFuture does not have any dummy implementations, so we'll use plain Object as the field private volatile Object timeoutFuture; public CancellableRetry(T command, int topologyId, StateTransferManager stateTransferManager) { this.command = command; this.topologyId = topologyId; this.stateTransferManager = stateTransferManager; } /** * This is called when the topology future completes (successfully or exceptionally) */ @Override public Void apply(Void nil, Throwable throwable) { if (!timeoutFutureUpdater.compareAndSet(this, null, DUMMY)) { ((ScheduledFuture) timeoutFuture).cancel(false); } if (throwable != null) { throw CompletableFutures.asCompletionException(throwable); } if (!cancellableRetryUpdater.compareAndSet(this, null, DUMMY)) { log.tracef("Not retrying command %s as it has been cancelled.", command); throw CompletableFutures.asCompletionException(cancelled); } log.tracef("Retrying command %s for topology %d", command, topologyId); return null; } /** * This is called when the timeout elapses. */ @Override public void run() { TimeoutException timeoutException = new TimeoutException("Timed out waiting for topology " + topologyId); if (cancellableRetryUpdater.compareAndSet(this, null, timeoutException)) { retryFuture.completeExceptionally(timeoutException); } } void setRetryFuture(CompletableFuture retryFuture) { this.retryFuture = retryFuture; } void setTimeoutFuture(ScheduledFuture timeoutFuture) { if (!timeoutFutureUpdater.compareAndSet(this, null, timeoutFuture)) { timeoutFuture.cancel(false); } } } }





© 2015 - 2025 Weber Informatics LLC | Privacy Policy