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

com.github.lontime.shaded.org.redisson.transaction.RedissonTransaction Maven / Gradle / Ivy

The newest version!
/**
 * Copyright (c) 2013-2021 Nikita Koksharov
 *
 * Licensed 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 com.github.lontime.shaded.org.redisson.transaction;

import io.netty.buffer.ByteBufUtil;
import com.github.lontime.shaded.org.redisson.RedissonBatch;
import com.github.lontime.shaded.org.redisson.RedissonLocalCachedMap;
import com.github.lontime.shaded.org.redisson.RedissonObject;
import com.github.lontime.shaded.org.redisson.RedissonTopic;
import com.github.lontime.shaded.org.redisson.api.*;
import com.github.lontime.shaded.org.redisson.api.listener.MessageListener;
import com.github.lontime.shaded.org.redisson.cache.LocalCachedMapDisable;
import com.github.lontime.shaded.org.redisson.cache.LocalCachedMapDisabledKey;
import com.github.lontime.shaded.org.redisson.cache.LocalCachedMapEnable;
import com.github.lontime.shaded.org.redisson.cache.LocalCachedMessageCodec;
import com.github.lontime.shaded.org.redisson.client.codec.Codec;
import com.github.lontime.shaded.org.redisson.command.CommandAsyncExecutor;
import com.github.lontime.shaded.org.redisson.command.CommandBatchService;
import com.github.lontime.shaded.org.redisson.connection.MasterSlaveEntry;
import com.github.lontime.shaded.org.redisson.misc.AsyncCountDownLatch;
import com.github.lontime.shaded.org.redisson.misc.CompletableFutureWrapper;
import com.github.lontime.shaded.org.redisson.transaction.operation.TransactionalOperation;
import com.github.lontime.shaded.org.redisson.transaction.operation.map.MapOperation;

import java.util.*;
import java.util.Map.Entry;
import java.util.concurrent.*;
import java.util.concurrent.atomic.AtomicBoolean;
import java.util.concurrent.atomic.AtomicInteger;

/**
 * 
 * @author Nikita Koksharov
 *
 */
public class RedissonTransaction implements RTransaction {

    private final CommandAsyncExecutor commandExecutor;
    private final AtomicBoolean executed = new AtomicBoolean();
    
    private final TransactionOptions options;
    private List operations = new CopyOnWriteArrayList<>();
    private Set localCaches = new HashSet<>();
    private final long startTime = System.currentTimeMillis();
    
    private final String id = generateId();
    
    public RedissonTransaction(CommandAsyncExecutor commandExecutor, TransactionOptions options) {
        super();
        this.options = options;
        this.commandExecutor = commandExecutor;
    }
    
    public RedissonTransaction(CommandAsyncExecutor commandExecutor, TransactionOptions options,
            List operations, Set localCaches) {
        super();
        this.commandExecutor = commandExecutor;
        this.options = options;
        this.operations = operations;
        this.localCaches = localCaches;
    }

    @Override
    public  RLocalCachedMap getLocalCachedMap(RLocalCachedMap fromInstance) {
        checkState();

        localCaches.add(fromInstance.getName());
        return new RedissonTransactionalLocalCachedMap(commandExecutor,
                operations, options.getTimeout(), executed, fromInstance, id);
    }
    
    @Override
    public  RBucket getBucket(String name) {
        checkState();
        
        return new RedissonTransactionalBucket(commandExecutor, options.getTimeout(), name, operations, executed, id);
    }
    
    @Override
    public  RBucket getBucket(String name, Codec codec) {
        checkState();

        return new RedissonTransactionalBucket(codec, commandExecutor, options.getTimeout(), name, operations, executed, id);
    }

    @Override
    public RBuckets getBuckets() {
        checkState();
        
        return new RedissonTransactionalBuckets(commandExecutor, options.getTimeout(), operations, executed, id);
    }

    @Override
    public RBuckets getBuckets(Codec codec) {
        checkState();
        
        return new RedissonTransactionalBuckets(codec, commandExecutor, options.getTimeout(), operations, executed, id);
    }
    
    @Override
    public  RSet getSet(String name) {
        checkState();
        
        return new RedissonTransactionalSet(commandExecutor, name, operations, options.getTimeout(), executed, id);        
    }
    
    @Override
    public  RSet getSet(String name, Codec codec) {
        checkState();
        
        return new RedissonTransactionalSet(codec, commandExecutor, name, operations, options.getTimeout(), executed, id);
    }
    
    @Override
    public  RSetCache getSetCache(String name) {
        checkState();
        
        return new RedissonTransactionalSetCache(commandExecutor, name, operations, options.getTimeout(), executed, id);        
    }
    
    @Override
    public  RSetCache getSetCache(String name, Codec codec) {
        checkState();
        
        return new RedissonTransactionalSetCache(codec, commandExecutor, name, operations, options.getTimeout(), executed, id);
    }

    @Override
    public  RMap getMap(String name) {
        checkState();
        
        return new RedissonTransactionalMap(commandExecutor, name, operations, options.getTimeout(), executed, id);
    }

    @Override
    public  RMap getMap(String name, Codec codec) {
        checkState();
        
        return new RedissonTransactionalMap(codec, commandExecutor, name, operations, options.getTimeout(), executed, id);
    }

    @Override
    public  RMapCache getMapCache(String name) {
        checkState();
        
        return new RedissonTransactionalMapCache(commandExecutor, name, operations, options.getTimeout(), executed, id);
    }

    @Override
    public  RMapCache getMapCache(String name, Codec codec) {
        checkState();
        
        return new RedissonTransactionalMapCache(codec, commandExecutor, name, operations, options.getTimeout(), executed, id);
    }
    
    @Override
    public RFuture commitAsync() {
        checkState();
        
        checkTimeout();
        
        BatchOptions batchOptions = createOptions();
        
        CommandBatchService transactionExecutor = new CommandBatchService(commandExecutor, batchOptions);
        for (TransactionalOperation transactionalOperation : operations) {
            transactionalOperation.commit(transactionExecutor);
        }

        String id = generateId();
        CompletionStage> future = disableLocalCacheAsync(id, localCaches, operations);
        CompletionStage ff = future
            .handle((hashes, ex) -> {
                    if (ex != null) {
                        throw new CompletionException(new TransactionException("Unable to execute transaction", ex));
                    }

                    try {
                        checkTimeout();
                    } catch (TransactionTimeoutException e) {
                        enableLocalCacheAsync(id, hashes);
                        CompletableFuture> f = new CompletableFuture<>();
                        f.completeExceptionally(e);
                        return f;
                    }

                    return hashes;
                })
            .thenCompose(hashes -> {
                RFuture> transactionFuture = transactionExecutor.executeAsync();
                return transactionFuture.handle((r, exc) -> {
                    if (exc != null) {
                        throw new CompletionException(new TransactionException("Unable to execute transaction", exc));
                    }

                    enableLocalCacheAsync(id, (Map) hashes);
                    executed.set(true);
                    return null;
                });
            });
        return new CompletableFutureWrapper<>(ff);
    }

    private BatchOptions createOptions() {
        MasterSlaveEntry entry = commandExecutor.getConnectionManager().getEntrySet().iterator().next();
        int syncSlaves = entry.getAvailableSlaves();
        if (options.getSyncSlaves() == -1) {
            syncSlaves = 0;
        } else if (options.getSyncSlaves() > 0) {
            syncSlaves = options.getSyncSlaves();
        }

        BatchOptions batchOptions = BatchOptions.defaults()
                .syncSlaves(syncSlaves, options.getSyncTimeout(), TimeUnit.MILLISECONDS)
                .responseTimeout(options.getResponseTimeout(), TimeUnit.MILLISECONDS)
                .retryAttempts(options.getRetryAttempts())
                .retryInterval(options.getRetryInterval(), TimeUnit.MILLISECONDS)
                .executionMode(BatchOptions.ExecutionMode.IN_MEMORY_ATOMIC);
        return batchOptions;
    }

    @Override
    public void commit() {
        commit(localCaches, operations);
    }
    
    public void commit(Set localCaches, List operations) {
        checkState();
        
        checkTimeout();
        
        BatchOptions batchOptions = createOptions();
        
        CommandBatchService transactionExecutor = new CommandBatchService(commandExecutor, batchOptions);
        for (TransactionalOperation transactionalOperation : operations) {
            transactionalOperation.commit(transactionExecutor);
        }

        String id = generateId();
        Map hashes = disableLocalCache(id, localCaches, operations);
        
        try {
            checkTimeout();
        } catch (TransactionTimeoutException e) {
            enableLocalCache(id, hashes);
            throw e;
        }

        try {
            
            transactionExecutor.execute();
        } catch (Exception e) {
            throw new TransactionException("Unable to execute transaction", e);
        }
        
        enableLocalCache(id, hashes);
        
        executed.set(true);
    }

    private void checkTimeout() {
        if (options.getTimeout() != -1 && System.currentTimeMillis() - startTime > options.getTimeout()) {
            rollbackAsync();
            throw new TransactionTimeoutException("Transaction was discarded due to timeout " + options.getTimeout() + " milliseconds");
        }
    }

    private RFuture> enableLocalCacheAsync(String requestId, Map hashes) {
        if (hashes.isEmpty()) {
            return new CompletableFutureWrapper<>((BatchResult) null);
        }
        
        RedissonBatch publishBatch = createBatch();
        for (Entry entry : hashes.entrySet()) {
            String name = RedissonObject.suffixName(entry.getKey().getName(), RedissonLocalCachedMap.TOPIC_SUFFIX);
            RTopicAsync topic = publishBatch.getTopic(name, LocalCachedMessageCodec.INSTANCE);
            LocalCachedMapEnable msg = new LocalCachedMapEnable(requestId, entry.getValue().getKeyIds().toArray(new byte[entry.getValue().getKeyIds().size()][]));
            topic.publishAsync(msg);
        }
        
        return publishBatch.executeAsync();
    }
    
    private void enableLocalCache(String requestId, Map hashes) {
        if (hashes.isEmpty()) {
            return;
        }
        
        RedissonBatch publishBatch = createBatch();
        for (Entry entry : hashes.entrySet()) {
            String name = RedissonObject.suffixName(entry.getKey().getName(), RedissonLocalCachedMap.TOPIC_SUFFIX);
            RTopicAsync topic = publishBatch.getTopic(name, LocalCachedMessageCodec.INSTANCE);
            LocalCachedMapEnable msg = new LocalCachedMapEnable(requestId, entry.getValue().getKeyIds().toArray(new byte[entry.getValue().getKeyIds().size()][]));
            topic.publishAsync(msg);
        }
        
        try {
            publishBatch.execute();
        } catch (Exception e) {
            // skip it. Disabled local cache entries are enabled once reach timeout.
        }
    }
    
    private Map disableLocalCache(String requestId, Set localCaches, List operations) {
        if (localCaches.isEmpty()) {
            return Collections.emptyMap();
        }
        
        Map hashes = new HashMap<>(localCaches.size());
        RedissonBatch batch = createBatch();
        for (TransactionalOperation transactionalOperation : operations) {
            if (localCaches.contains(transactionalOperation.getName())) {
                MapOperation mapOperation = (MapOperation) transactionalOperation;
                RedissonLocalCachedMap map = (RedissonLocalCachedMap) mapOperation.getMap();
                
                HashKey hashKey = new HashKey(transactionalOperation.getName(), transactionalOperation.getCodec());
                byte[] key = map.getLocalCacheView().toCacheKey(mapOperation.getKey()).getKeyHash();
                HashValue value = hashes.get(hashKey);
                if (value == null) {
                    value = new HashValue();
                    hashes.put(hashKey, value);
                }
                value.getKeyIds().add(key);

                String disabledKeysName = RedissonObject.suffixName(transactionalOperation.getName(), RedissonLocalCachedMap.DISABLED_KEYS_SUFFIX);
                RMultimapCacheAsync multimap = batch.getListMultimapCache(disabledKeysName, transactionalOperation.getCodec());
                LocalCachedMapDisabledKey localCacheKey = new LocalCachedMapDisabledKey(requestId, options.getResponseTimeout());
                multimap.putAsync(localCacheKey, ByteBufUtil.hexDump(key));
                multimap.expireKeyAsync(localCacheKey, options.getResponseTimeout(), TimeUnit.MILLISECONDS);
            }
        }

        try {
            batch.execute();
        } catch (Exception e) {
            throw new TransactionException("Unable to execute transaction over local cached map objects: " + localCaches, e);
        }
        
        CountDownLatch latch = new CountDownLatch(hashes.size());
        List topics = new ArrayList<>();
        for (Entry entry : hashes.entrySet()) {
            RTopic topic = RedissonTopic.createRaw(LocalCachedMessageCodec.INSTANCE,
                    commandExecutor, RedissonObject.suffixName(entry.getKey().getName(), requestId + RedissonLocalCachedMap.DISABLED_ACK_SUFFIX));
            topics.add(topic);
            topic.addListener(Object.class, new MessageListener() {
                @Override
                public void onMessage(CharSequence channel, Object msg) {
                    AtomicInteger counter = entry.getValue().getCounter();
                    if (counter.decrementAndGet() == 0) {
                        latch.countDown();
                    }
                }
            });
        }
        
        RedissonBatch publishBatch = createBatch();
        for (Entry entry : hashes.entrySet()) {
            String disabledKeysName = RedissonObject.suffixName(entry.getKey().getName(), RedissonLocalCachedMap.DISABLED_KEYS_SUFFIX);
            RMultimapCacheAsync multimap = publishBatch.getListMultimapCache(disabledKeysName, entry.getKey().getCodec());
            LocalCachedMapDisabledKey localCacheKey = new LocalCachedMapDisabledKey(requestId, options.getResponseTimeout());
            multimap.removeAllAsync(localCacheKey);
            
            RTopicAsync topic = publishBatch.getTopic(RedissonObject.suffixName(entry.getKey().getName(), RedissonLocalCachedMap.TOPIC_SUFFIX), LocalCachedMessageCodec.INSTANCE);
            RFuture future = topic.publishAsync(new LocalCachedMapDisable(requestId, 
                    entry.getValue().getKeyIds().toArray(new byte[entry.getValue().getKeyIds().size()][]), options.getResponseTimeout()));
            future.thenAccept(res -> {
                int receivers = res.intValue();
                AtomicInteger counter = entry.getValue().getCounter();
                if (counter.addAndGet(receivers) == 0) {
                    latch.countDown();
                }
            });
        }

        try {
            publishBatch.execute();
        } catch (Exception e) {
            throw new TransactionException("Unable to execute transaction over local cached map objects: " + localCaches, e);
        }
        
        for (RTopic topic : topics) {
            topic.removeAllListeners();
        }
        
        try {
            latch.await(options.getResponseTimeout(), TimeUnit.MILLISECONDS);
        } catch (InterruptedException e) {
            Thread.currentThread().interrupt();
        }
        return hashes;
    }
    
    private CompletionStage> disableLocalCacheAsync(String requestId, Set localCaches, List operations) {
        if (localCaches.isEmpty()) {
            return CompletableFuture.completedFuture(Collections.emptyMap());
        }
        
        Map hashes = new HashMap<>(localCaches.size());
        RedissonBatch batch = createBatch();
        for (TransactionalOperation transactionalOperation : operations) {
            if (localCaches.contains(transactionalOperation.getName())) {
                MapOperation mapOperation = (MapOperation) transactionalOperation;
                RedissonLocalCachedMap map = (RedissonLocalCachedMap) mapOperation.getMap();
                
                HashKey hashKey = new HashKey(transactionalOperation.getName(), transactionalOperation.getCodec());
                byte[] key = map.getLocalCacheView().toCacheKey(mapOperation.getKey()).getKeyHash();
                HashValue value = hashes.get(hashKey);
                if (value == null) {
                    value = new HashValue();
                    hashes.put(hashKey, value);
                }
                value.getKeyIds().add(key);

                String disabledKeysName = RedissonObject.suffixName(transactionalOperation.getName(), RedissonLocalCachedMap.DISABLED_KEYS_SUFFIX);
                RMultimapCacheAsync multimap = batch.getListMultimapCache(disabledKeysName, transactionalOperation.getCodec());
                LocalCachedMapDisabledKey localCacheKey = new LocalCachedMapDisabledKey(requestId, options.getResponseTimeout());
                multimap.putAsync(localCacheKey, ByteBufUtil.hexDump(key));
                multimap.expireKeyAsync(localCacheKey, options.getResponseTimeout(), TimeUnit.MILLISECONDS);
            }
        }

        CompletableFuture> result = new CompletableFuture<>();
        RFuture> batchListener = batch.executeAsync();
        batchListener.thenAccept(res -> {
                List> subscriptionFutures = new ArrayList<>();
                List topics = new ArrayList<>();

                AsyncCountDownLatch latch = new AsyncCountDownLatch();
                latch.latch(() -> {
                    for (RTopic t : topics) {
                        t.removeAllListenersAsync();
                    }
                    result.complete(hashes);
                }, hashes.size());

                for (Entry entry : hashes.entrySet()) {
                    String disabledAckName = RedissonObject.suffixName(entry.getKey().getName(),
                                            requestId + RedissonLocalCachedMap.DISABLED_ACK_SUFFIX);
                    RTopic topic = RedissonTopic.createRaw(LocalCachedMessageCodec.INSTANCE,
                                                                commandExecutor, disabledAckName);
                    topics.add(topic);
                    RFuture topicFuture = topic.addListenerAsync(Object.class, (channel, msg) -> {
                        AtomicInteger counter = entry.getValue().getCounter();
                        if (counter.decrementAndGet() == 0) {
                            latch.countDown();
                        }
                    });
                    subscriptionFutures.add(topicFuture.toCompletableFuture());
                }

                CompletableFuture subscriptionFuture = CompletableFuture.allOf(subscriptionFutures.toArray(new CompletableFuture[0]));
                subscriptionFuture.thenAccept(r -> {
                        RedissonBatch publishBatch = createBatch();
                        for (Entry entry : hashes.entrySet()) {
                            String disabledKeysName = RedissonObject.suffixName(entry.getKey().getName(), RedissonLocalCachedMap.DISABLED_KEYS_SUFFIX);
                            RMultimapCacheAsync multimap = publishBatch.getListMultimapCache(disabledKeysName, entry.getKey().getCodec());
                            LocalCachedMapDisabledKey localCacheKey = new LocalCachedMapDisabledKey(requestId, options.getResponseTimeout());
                            multimap.removeAllAsync(localCacheKey);

                            RTopicAsync topic = publishBatch.getTopic(RedissonObject.suffixName(entry.getKey().getName(),
                                                        RedissonLocalCachedMap.TOPIC_SUFFIX), LocalCachedMessageCodec.INSTANCE);
                            RFuture publishFuture = topic.publishAsync(new LocalCachedMapDisable(requestId,
                                                                    entry.getValue().getKeyIds().toArray(new byte[entry.getValue().getKeyIds().size()][]),
                                                                        options.getResponseTimeout()));
                            publishFuture.thenAccept(receivers -> {
                                AtomicInteger counter = entry.getValue().getCounter();
                                if (counter.addAndGet(receivers.intValue()) == 0) {
                                    latch.countDown();
                                }
                            });
                        }

                        RFuture> publishFuture = publishBatch.executeAsync();
                        publishFuture.thenAccept(res2 -> {
                            commandExecutor.getConnectionManager().newTimeout(timeout ->
                                    result.completeExceptionally(
                                                        new TransactionTimeoutException("Unable to execute transaction within "
                                                                + options.getResponseTimeout() + "ms")),
                                                            options.getResponseTimeout(), TimeUnit.MILLISECONDS);
                        });
                });
        });
        return result;
    }

    private RedissonBatch createBatch() {
        return new RedissonBatch(null, commandExecutor,
                                    BatchOptions.defaults().executionMode(BatchOptions.ExecutionMode.IN_MEMORY_ATOMIC));
    }

    protected static String generateId() {
        byte[] id = new byte[16];
        ThreadLocalRandom.current().nextBytes(id);
        return ByteBufUtil.hexDump(id);
    }

    @Override
    public void rollback() {
        rollback(operations);
    }
    
    public void rollback(List operations) {
        checkState();

        CommandBatchService executorService = new CommandBatchService(commandExecutor);
        for (TransactionalOperation transactionalOperation : operations) {
            transactionalOperation.rollback(executorService);
        }

        try {
            executorService.execute();
        } catch (Exception e) {
            throw new TransactionException("Unable to rollback transaction", e);
        }

        operations.clear();
        executed.set(true);
    }
    
    @Override
    public RFuture rollbackAsync() {
        checkState();

        CommandBatchService executorService = new CommandBatchService(commandExecutor);
        for (TransactionalOperation transactionalOperation : operations) {
            transactionalOperation.rollback(executorService);
        }

        RFuture> future = executorService.executeAsync();
        CompletionStage f = future.handle((res, e) -> {
            if (e != null) {
                throw new CompletionException(new TransactionException("Unable to rollback transaction", e));
            }

            operations.clear();
            executed.set(true);
            return null;
        });
        return new CompletableFutureWrapper<>(f);
    }
    
    public Set getLocalCaches() {
        return localCaches;
    }
    
    public List getOperations() {
        return operations;
    }

    protected void checkState() {
        if (executed.get()) {
            throw new IllegalStateException("Unable to execute operation. Transaction was finished!");
        }
    }
    
}