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

com.github.lontime.shaded.org.redisson.RedissonExecutorService 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;

import io.netty.buffer.ByteBuf;
import io.netty.buffer.ByteBufUtil;
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.client.codec.Codec;
import com.github.lontime.shaded.org.redisson.client.codec.LongCodec;
import com.github.lontime.shaded.org.redisson.client.codec.StringCodec;
import com.github.lontime.shaded.org.redisson.client.protocol.RedisCommands;
import com.github.lontime.shaded.org.redisson.command.CommandAsyncExecutor;
import com.github.lontime.shaded.org.redisson.connection.ConnectionManager;
import com.github.lontime.shaded.org.redisson.executor.*;
import com.github.lontime.shaded.org.redisson.executor.params.*;
import com.github.lontime.shaded.org.redisson.misc.CompletableFutureWrapper;
import com.github.lontime.shaded.org.redisson.misc.Injector;
import com.github.lontime.shaded.org.redisson.remote.ResponseEntry;
import com.github.lontime.shaded.org.redisson.remote.ResponseEntry.Result;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;

import java.io.*;
import java.lang.invoke.SerializedLambda;
import java.lang.ref.ReferenceQueue;
import java.lang.reflect.Method;
import java.lang.reflect.Modifier;
import java.time.Duration;
import java.time.LocalDateTime;
import java.time.ZonedDateTime;
import java.util.*;
import java.util.concurrent.*;

/**
 * 
 * @author Nikita Koksharov
 *
 */
public class RedissonExecutorService implements RScheduledExecutorService {

    private static final Logger LOGGER = LoggerFactory.getLogger(RedissonExecutorService.class);
    
    private static final RemoteInvocationOptions RESULT_OPTIONS = RemoteInvocationOptions.defaults().noAck().expectResultWithin(1, TimeUnit.HOURS);
    
    public static final int SHUTDOWN_STATE = 1;
    public static final int TERMINATED_STATE = 2;
    
    private final CommandAsyncExecutor commandExecutor;
    private final ConnectionManager connectionManager;
    private final Codec codec;
    private final Redisson redisson;
    
    private final String tasksName;
    private final String schedulerQueueName;
    private final String schedulerChannelName;
    private final String tasksRetryIntervalName;
    private final String tasksExpirationTimeName;
    
    private final String workersChannelName;
    private final String workersSemaphoreName;
    private final String workersCounterName;
    
    private final String tasksCounterName;
    private final String statusName;
    private final RTopic terminationTopic;
    private final RedissonExecutorRemoteService remoteService;
    private final RTopic workersTopic;
    private int workersGroupListenerId;

    private final RemoteExecutorServiceAsync asyncScheduledService;
    private final RemoteExecutorServiceAsync asyncScheduledServiceAtFixed;
    private final RemoteExecutorServiceAsync asyncService;
    private final RemoteExecutorServiceAsync asyncServiceWithoutResult;
    
    private final ScheduledTasksService scheduledRemoteService;
    private final TasksService executorRemoteService;
    
    private final Map, ClassBody> class2body = new ConcurrentHashMap<>();

    private final String name;
    private final String requestQueueName;
    private final String responseQueueName;
    private final QueueTransferService queueTransferService;
    private final String executorId;
    private final ConcurrentMap responses;

    private final ReferenceQueue> referenceDueue = new ReferenceQueue<>();
    private final Collection references = Collections.newSetFromMap(new ConcurrentHashMap<>());

    private final IdGenerator idGenerator;
    
    public RedissonExecutorService(Codec codec, CommandAsyncExecutor commandExecutor, Redisson redisson,
                                   String name, QueueTransferService queueTransferService, ConcurrentMap responses,
                                   ExecutorOptions options) {
        super();
        this.codec = codec;
        this.commandExecutor = commandExecutor;
        this.connectionManager = commandExecutor.getConnectionManager();
        this.name = commandExecutor.getConnectionManager().getConfig().getNameMapper().map(name);
        this.redisson = redisson;
        this.queueTransferService = queueTransferService;
        this.responses = responses;

        if (codec == connectionManager.getCodec()) {
            this.executorId = connectionManager.getId();
        } else {
            this.executorId = connectionManager.getId() + ":" + RemoteExecutorServiceAsync.class.getName() + ":" + name;
        }
        
        remoteService = new RedissonExecutorRemoteService(codec, name, commandExecutor, executorId, responses);
        requestQueueName = remoteService.getRequestQueueName(RemoteExecutorService.class);
        responseQueueName = remoteService.getResponseQueueName(executorId);
        String objectName = requestQueueName;
        tasksCounterName = objectName + ":counter";
        tasksName = objectName + ":tasks";
        statusName = objectName + ":status";
        terminationTopic = RedissonTopic.createRaw(LongCodec.INSTANCE, commandExecutor, objectName + ":termination-topic");

        tasksRetryIntervalName = objectName + ":retry-interval";
        tasksExpirationTimeName = objectName + ":expiration";
        schedulerChannelName = objectName + ":scheduler-channel";
        schedulerQueueName = objectName + ":scheduler";
        
        workersChannelName = objectName + ":workers-channel";
        workersSemaphoreName = objectName + ":workers-semaphore";
        workersCounterName = objectName + ":workers-counter";
        
        workersTopic = RedissonTopic.createRaw(commandExecutor, workersChannelName);

        remoteService.setStatusName(statusName);
        remoteService.setSchedulerQueueName(schedulerQueueName);
        remoteService.setTasksCounterName(tasksCounterName);
        remoteService.setTasksExpirationTimeName(tasksExpirationTimeName);
        remoteService.setTasksRetryIntervalName(tasksRetryIntervalName);
        remoteService.setTerminationTopicName(terminationTopic.getChannelNames().get(0));

        executorRemoteService = new TasksService(codec, name, commandExecutor, executorId, responses);
        executorRemoteService.setTerminationTopicName(terminationTopic.getChannelNames().get(0));
        executorRemoteService.setTasksCounterName(tasksCounterName);
        executorRemoteService.setStatusName(statusName);
        executorRemoteService.setTasksName(tasksName);
        executorRemoteService.setSchedulerChannelName(schedulerChannelName);
        executorRemoteService.setSchedulerQueueName(schedulerQueueName);
        executorRemoteService.setTasksRetryIntervalName(tasksRetryIntervalName);
        executorRemoteService.setTasksExpirationTimeName(tasksExpirationTimeName);
        executorRemoteService.setTasksRetryInterval(options.getTaskRetryInterval());
        asyncService = executorRemoteService.get(RemoteExecutorServiceAsync.class, RESULT_OPTIONS);
        asyncServiceWithoutResult = executorRemoteService.get(RemoteExecutorServiceAsync.class, RemoteInvocationOptions.defaults().noAck().noResult());
        
        scheduledRemoteService = new ScheduledTasksService(codec, name, commandExecutor, executorId, responses);
        scheduledRemoteService.setTerminationTopicName(terminationTopic.getChannelNames().get(0));
        scheduledRemoteService.setTasksCounterName(tasksCounterName);
        scheduledRemoteService.setStatusName(statusName);
        scheduledRemoteService.setSchedulerQueueName(schedulerQueueName);
        scheduledRemoteService.setSchedulerChannelName(schedulerChannelName);
        scheduledRemoteService.setTasksName(tasksName);
        scheduledRemoteService.setTasksRetryIntervalName(tasksRetryIntervalName);
        scheduledRemoteService.setTasksExpirationTimeName(tasksExpirationTimeName);
        scheduledRemoteService.setTasksRetryInterval(options.getTaskRetryInterval());
        asyncScheduledService = scheduledRemoteService.get(RemoteExecutorServiceAsync.class, RESULT_OPTIONS);
        asyncScheduledServiceAtFixed = scheduledRemoteService.get(RemoteExecutorServiceAsync.class, RemoteInvocationOptions.defaults().noAck().noResult());

        idGenerator = options.getIdGenerator();
    }
    
    protected String generateActiveWorkersId() {
        byte[] id = new byte[16];
        ThreadLocalRandom.current().nextBytes(id);
        return ByteBufUtil.hexDump(id);
    }

    @Override
    public int getTaskCount() {
        return commandExecutor.get(getTaskCountAsync());
    }

    @Override
    public RFuture getTaskCountAsync() {
        return commandExecutor.readAsync(getName(), LongCodec.INSTANCE, RedisCommands.GET_INTEGER, tasksCounterName);
    }

    @Override
    public boolean hasTask(String taskId) {
        return commandExecutor.get(hasTaskAsync(taskId));
    }

    @Override
    public Set getTaskIds() {
        return commandExecutor.get(getTaskIdsAsync());
    }

    @Override
    public RFuture> getTaskIdsAsync() {
        return commandExecutor.writeAsync(tasksName, StringCodec.INSTANCE, RedisCommands.HKEYS, tasksName);
    }

    @Override
    public RFuture hasTaskAsync(String taskId) {
        return commandExecutor.writeAsync(tasksName, LongCodec.INSTANCE, RedisCommands.HEXISTS, tasksName, taskId);
    }

    @Override
    public int countActiveWorkers() {
        String id = generateActiveWorkersId();
        int subscribers = (int) workersTopic.publish(id);
        if (subscribers == 0) {
            return 0;
        }

        RSemaphore semaphore = redisson.getSemaphore(workersSemaphoreName + ":" + id);
        try {
            semaphore.tryAcquire(subscribers, 10, TimeUnit.MINUTES);
        } catch (InterruptedException e) {
            Thread.currentThread().interrupt();
        }
        RAtomicLong atomicLong = redisson.getAtomicLong(workersCounterName + ":" + id);
        long result = atomicLong.get();
        redisson.getKeys().delete(semaphore, atomicLong);
        return (int) result;
    }
    
    @Override
    public void registerWorkers(int workers) {
        registerWorkers(WorkerOptions.defaults().workers(workers));
    }
    
    @Override
    public void registerWorkers(WorkerOptions options) {
        if (options.getWorkers() == 0) {
            throw new IllegalArgumentException("workers amount can't be zero");
        }
        
        QueueTransferTask task = new QueueTransferTask(connectionManager) {
            @Override
            protected RTopic getTopic() {
                return RedissonTopic.createRaw(LongCodec.INSTANCE, commandExecutor, schedulerChannelName);
            }

            @Override
            protected RFuture pushTaskAsync() {
                return commandExecutor.evalWriteAsync(name, LongCodec.INSTANCE, RedisCommands.EVAL_LONG,
                        "local expiredTaskIds = redis.call('zrangebyscore', KEYS[2], 0, ARGV[1], 'limit', 0, ARGV[2]); "
                      + "local retryInterval = redis.call('get', KEYS[4]);"
                      + "if #expiredTaskIds > 0 then "
                          + "redis.call('zrem', KEYS[2], unpack(expiredTaskIds));"
                          + "if retryInterval ~= false then "
                              + "local startTime = tonumber(ARGV[1]) + tonumber(retryInterval);"
                          
                              + "for i = 1, #expiredTaskIds, 1 do "
                                  + "local name = expiredTaskIds[i];"
                                  + "local scheduledName = expiredTaskIds[i];"
                                  + "if string.sub(scheduledName, 1, 2) ~= 'ff' then "
                                      + "scheduledName = 'ff' .. scheduledName; "
                                  + "else "
                                      + "name = string.sub(name, 3, string.len(name)); "
                                  + "end;"
                                      
                                  + "redis.call('zadd', KEYS[2], startTime, scheduledName);"
                                  + "local v = redis.call('zrange', KEYS[2], 0, 0); "
                                  // if new task added to queue head then publish its startTime 
                                  // to all scheduler workers 
                                  + "if v[1] == expiredTaskIds[i] then "
                                      + "redis.call('publish', KEYS[3], startTime); "
                                  + "end;"
                                    
                                + "if redis.call('linsert', KEYS[1], 'before', name, name) < 1 then "
                                    + "redis.call('rpush', KEYS[1], name); "
                                + "else "
                                    + "redis.call('lrem', KEYS[1], -1, name); "
                                + "end; "
                              + "end; "
                          + "else "
                              + "redis.call('rpush', KEYS[1], unpack(expiredTaskIds));"
                          + "end; "
                      + "end; "
                        // get startTime from scheduler queue head task
                      + "local v = redis.call('zrange', KEYS[2], 0, 0, 'WITHSCORES'); "
                      + "if v[1] ~= nil then "
                         + "return v[2]; "
                      + "end "
                      + "return nil;",
                      Arrays.asList(requestQueueName, schedulerQueueName, schedulerChannelName, tasksRetryIntervalName), 
                      System.currentTimeMillis(), 50);
            }
        };
        queueTransferService.schedule(getName(), task);
        
        TasksRunnerService service = 
                new TasksRunnerService(commandExecutor, redisson, codec, requestQueueName, responses);
        service.setStatusName(statusName);
        service.setTasksCounterName(tasksCounterName);
        service.setTasksName(tasksName);
        service.setTerminationTopicName(terminationTopic.getChannelNames().get(0));
        service.setSchedulerChannelName(schedulerChannelName);
        service.setSchedulerQueueName(schedulerQueueName);
        service.setTasksExpirationTimeName(tasksExpirationTimeName);
        service.setTasksRetryIntervalName(tasksRetryIntervalName);
        if (options.getTasksInjector() != null) {
            service.setTasksInjector(options.getTasksInjector());
        }

        ExecutorService es = commandExecutor.getConnectionManager().getExecutor();
        if (options.getExecutorService() != null) {
            es = options.getExecutorService();
        }

        remoteService.setListeners(options.getListeners());
        remoteService.setTaskTimeout(options.getTaskTimeout());
        remoteService.register(RemoteExecutorService.class, service, options.getWorkers(), es);
        workersGroupListenerId = workersTopic.addListener(String.class, new MessageListener() {
            @Override
            public void onMessage(CharSequence channel, String id) {
                redisson.getAtomicLong(workersCounterName + ":" + id).getAndAdd(options.getWorkers());
                redisson.getSemaphore(workersSemaphoreName + ":" + id).release();
            }
        });
    }
    
    @Override
    public void registerWorkers(int workers, ExecutorService executor) {
        registerWorkers(WorkerOptions.defaults().workers(workers).executorService(executor));
    }
    
    @Override
    public void execute(Runnable task) {
        check(task);
        RemotePromise promise = (RemotePromise) asyncServiceWithoutResult.executeRunnable(
                                            createTaskParameters(task)).toCompletableFuture();
        syncExecute(promise);
    }
    
    @Override
    public void execute(Runnable... tasks) {
        if (tasks.length == 0) {
            throw new NullPointerException("Tasks are not defined");
        }

        TasksBatchService executorRemoteService = createBatchService();
        RemoteExecutorServiceAsync asyncServiceWithoutResult = executorRemoteService.get(RemoteExecutorServiceAsync.class, RemoteInvocationOptions.defaults().noAck().noResult());
        for (Runnable task : tasks) {
            check(task);
            asyncServiceWithoutResult.executeRunnable(createTaskParameters(task));
        }
        
        List result = executorRemoteService.executeAdd();
        if (!result.get(0)) {
            throw new RejectedExecutionException("Tasks have been rejected. ExecutorService is in shutdown state");
        }
    }

    private TasksBatchService createBatchService() {
        TasksBatchService executorRemoteService = new TasksBatchService(codec, getName(), commandExecutor, executorId, responses);
        executorRemoteService.setTasksExpirationTimeName(tasksExpirationTimeName);
        executorRemoteService.setTerminationTopicName(terminationTopic.getChannelNames().get(0));
        executorRemoteService.setTasksCounterName(tasksCounterName);
        executorRemoteService.setStatusName(statusName);
        executorRemoteService.setTasksName(tasksName);
        executorRemoteService.setSchedulerChannelName(schedulerChannelName);
        executorRemoteService.setSchedulerQueueName(schedulerQueueName);
        executorRemoteService.setTasksRetryIntervalName(tasksRetryIntervalName);
        return executorRemoteService;
    }
    
    private byte[] encode(Object task) {
        // erase RedissonClient field to avoid its serialization
        Injector.inject(task, null);
        
        ByteBuf buf = null;
        try {
            buf = codec.getValueEncoder().encode(task);
            byte[] dst = new byte[buf.readableBytes()];
            buf.readBytes(dst);
            return dst;
        } catch (IOException e) {
            throw new IllegalArgumentException(e);
        } finally {
            if (buf != null) {
                buf.release();
            }
        }
    }
    
    public static class ClassBody {
        
        private byte[] lambda;
        private byte[] clazz;
        private String clazzName;
        
        public ClassBody(byte[] lambda, byte[] clazz, String clazzName) {
            super();
            this.lambda = lambda;
            this.clazz = clazz;
            this.clazzName = clazzName;
        }
        
        public String getClazzName() {
            return clazzName;
        }
        
        public byte[] getClazz() {
            return clazz;
        }
        
        public byte[] getLambda() {
            return lambda;
        }
        
    }

    private ClassBody getClassBody(Object task) {
        Class c = task.getClass();
        ClassBody result = class2body.get(c);
        if (result == null) {
            String className = c.getName();
            String classAsPath = className.replace('.', '/') + ".class";
            InputStream classStream = c.getClassLoader().getResourceAsStream(classAsPath);
            
            byte[] lambdaBody = null;
            if (classStream == null) {
                ByteArrayOutputStream os = new ByteArrayOutputStream();
                try {
                    ObjectOutput oo = new ObjectOutputStream(os);
                    oo.writeObject(task);
                } catch (Exception e) {
                    throw new IllegalArgumentException("Unable to serialize lambda", e);
                }
                lambdaBody = os.toByteArray();
                
                SerializedLambda lambda;
                try {
                    Method writeReplace = task.getClass().getDeclaredMethod("writeReplace");
                    writeReplace.setAccessible(true);
                    lambda = (SerializedLambda) writeReplace.invoke(task);
                } catch (Exception ex) {
                    throw new IllegalArgumentException("Lambda should implement java.io.Serializable interface", ex);
                }
                
                className = lambda.getCapturingClass().replace('/', '.');
                classStream = task.getClass().getClassLoader().getResourceAsStream(lambda.getCapturingClass() + ".class");
            }
            
            byte[] classBody;
            try {
                DataInputStream s = new DataInputStream(classStream);
                classBody = new byte[s.available()];
                s.readFully(classBody);
            } catch (IOException e) {
                throw new IllegalArgumentException(e);
            } finally {
                try {
                    classStream.close();
                } catch (IOException e) {
                    // skip
                }
            }
            
            result = new ClassBody(lambdaBody, classBody, className);
            class2body.put(c, result);
        }
        return result;
    }

    @Override
    public void shutdown() {
        queueTransferService.remove(getName());
        remoteService.deregister(RemoteExecutorService.class);
        workersTopic.removeListener(workersGroupListenerId);
        
        commandExecutor.get(commandExecutor.evalWriteAsync(getName(), LongCodec.INSTANCE, RedisCommands.EVAL_VOID,
                "if redis.call('exists', KEYS[2]) == 0 then "
                     + "if redis.call('get', KEYS[1]) == '0' or redis.call('exists', KEYS[1]) == 0 then "
                        + "redis.call('set', KEYS[2], ARGV[2]);"
                        + "redis.call('publish', KEYS[3], ARGV[2]);"
                     + "else "
                        + "redis.call('set', KEYS[2], ARGV[1]);"
                     + "end;"
                + "end;", 
                Arrays.asList(tasksCounterName, statusName, terminationTopic.getChannelNames().get(0), tasksRetryIntervalName),
                SHUTDOWN_STATE, TERMINATED_STATE));
    }

    @Override
    public String getName() {
        return commandExecutor.getConnectionManager().getConfig().getNameMapper().unmap(name);
    }
    
    @Override
    public boolean delete() {
        return commandExecutor.get(deleteAsync());
    }
    
    @Override
    public RFuture deleteAsync() {
        RFuture deleteFuture = redisson.getKeys().deleteAsync(
                requestQueueName, statusName, tasksCounterName, schedulerQueueName, tasksName, tasksRetryIntervalName);
        CompletionStage f = deleteFuture.thenApply(res -> res > 0);
        return new CompletableFutureWrapper<>(f);
    }
    
    @Override
    public List shutdownNow() {
        throw new UnsupportedOperationException();
    }

    @Override
    public boolean isShutdown() {
        return checkState(SHUTDOWN_STATE);
    }

    private boolean checkState(int state) {
        return commandExecutor.get(commandExecutor.evalWriteAsync(getName(), codec, RedisCommands.EVAL_BOOLEAN,
                "if redis.call('exists', KEYS[1]) == 1 and tonumber(redis.call('get', KEYS[1])) >= tonumber(ARGV[1]) then "
                + "return 1;"
            + "end;"
            + "return 0;", 
                Arrays.asList(statusName),
                state));
    }

    @Override
    public boolean isTerminated() {
        return checkState(TERMINATED_STATE);
    }

    @Override
    public boolean awaitTermination(long timeout, TimeUnit unit) throws InterruptedException {
        if (isTerminated()) {
            return true;
        }
        
        CountDownLatch latch = new CountDownLatch(1);
        MessageListener listener = new MessageListener() {
            @Override
            public void onMessage(CharSequence channel, Long msg) {
                if (msg == TERMINATED_STATE) {
                    latch.countDown();
                }
            }
        };
        int listenerId = terminationTopic.addListener(Long.class, listener);

        if (isTerminated()) {
            terminationTopic.removeListener(listenerId);
            return true;
        }
        
        boolean res = latch.await(timeout, unit);
        terminationTopic.removeListener(listenerId);
        return res;
    }

    @Override
    public  RExecutorFuture submit(Callable task) {
        return submit(idGenerator.generateId(), task);
    }

    @Override
    public  RExecutorFuture submit(Callable task, long timeToLive, TimeUnit timeUnit) {
        return submit(idGenerator.generateId(), task, Duration.ofMillis(timeUnit.toMillis(timeToLive)));
    }

    @Override
    public  RExecutorFuture submitAsync(Callable task, long timeToLive, TimeUnit timeUnit) {
        return submitAsync(idGenerator.generateId(), task, Duration.ofMillis(timeUnit.toMillis(timeToLive)));
    }

    @Override
    public  RExecutorFuture submitAsync(Callable task) {
        return submitAsync(idGenerator.generateId(), task);
    }
    
    @Override
    public RExecutorBatchFuture submit(Callable... tasks) {
        if (tasks.length == 0) {
            throw new NullPointerException("Tasks are not defined");
        }

        List> result = new ArrayList<>();
        TasksBatchService executorRemoteService = createBatchService();
        RemoteExecutorServiceAsync asyncService = executorRemoteService.get(RemoteExecutorServiceAsync.class, RESULT_OPTIONS);
        for (Callable task : tasks) {
            check(task);
            RemotePromise promise = (RemotePromise) asyncService.executeCallable(createTaskParameters(task)).toCompletableFuture();
            RedissonExecutorFuture executorFuture = new RedissonExecutorFuture(promise);
            result.add(executorFuture);
        }
        
        List addResult = executorRemoteService.executeAdd();
        if (!addResult.get(0)) {
            throw new RejectedExecutionException("Tasks have been rejected. ExecutorService is in shutdown state");
        }

        CompletableFuture future = CompletableFuture.allOf(result.stream()
                                                                    .map(CompletionStage::toCompletableFuture)
                                                                    .toArray(CompletableFuture[]::new));
        return new RedissonExecutorBatchFuture(future, result);
    }

    protected TaskParameters createTaskParameters(Callable task) {
        return createTaskParameters(idGenerator.generateId(), task);
    }

    protected TaskParameters createTaskParameters(String taskId, Callable task) {
        ClassBody classBody = getClassBody(task);
        byte[] state = encode(task);
        String id = taskId;
        return new TaskParameters(id, classBody.getClazzName(), classBody.getClazz(), classBody.getLambda(), state);
    }
    
    protected TaskParameters createTaskParameters(Runnable task) {
        return createTaskParameters(idGenerator.generateId(), task);
    }

    protected TaskParameters createTaskParameters(String taskId, Runnable task) {
        ClassBody classBody = getClassBody(task);
        byte[] state = encode(task);
        String id = taskId;
        return new TaskParameters(id, classBody.getClazzName(), classBody.getClazz(), classBody.getLambda(), state);
    }

    @Override
    public RExecutorBatchFuture submitAsync(Callable... tasks) {
        if (tasks.length == 0) {
            throw new NullPointerException("Tasks are not defined");
        }

        TasksBatchService executorRemoteService = createBatchService();
        RemoteExecutorServiceAsync asyncService = executorRemoteService.get(RemoteExecutorServiceAsync.class, RESULT_OPTIONS);
        List> result = new ArrayList<>();
        for (Callable task : tasks) {
            check(task);
            RemotePromise promise = (RemotePromise) asyncService.executeCallable(createTaskParameters(task)).toCompletableFuture();
            RedissonExecutorFuture executorFuture = new RedissonExecutorFuture(promise);
            result.add(executorFuture);
        }
        
        executorRemoteService.executeAddAsync().whenComplete((res, e) -> {
            if (e != null) {
                for (RExecutorFuture executorFuture : result) {
                    executorFuture.toCompletableFuture().completeExceptionally(e);
                }
                return;
            }
            
            for (Boolean bool : res) {
                if (!bool) {
                    RejectedExecutionException ex = new RejectedExecutionException("Task rejected. ExecutorService is in shutdown state");
                    for (RExecutorFuture executorFuture : result) {
                        executorFuture.toCompletableFuture().completeExceptionally(ex);
                    }
                    break;
                }
            }
        });

        CompletableFuture future = CompletableFuture.allOf(result.stream()
                                                                    .map(CompletionStage::toCompletableFuture)
                                                                    .toArray(CompletableFuture[]::new));
        return new RedissonExecutorBatchFuture(future, result);
    }


    private  void addListener(RemotePromise result) {
        result.getAddFuture().whenComplete((res, e) -> {
            if (e != null) {
                result.toCompletableFuture().completeExceptionally(e);
                return;
            }
            
            if (!res) {
                result.toCompletableFuture().completeExceptionally(new RejectedExecutionException("Task rejected. ExecutorService is in shutdown state"));
            }
        });
    }
    
    private void check(Object task) {
        if (task == null) {
            throw new NullPointerException("Task is not defined");
        }
        if (task.getClass().isAnonymousClass()) {
            throw new IllegalArgumentException("Task can't be created using anonymous class");
        }
        if (task.getClass().isMemberClass()
                && !Modifier.isStatic(task.getClass().getModifiers())) {
            throw new IllegalArgumentException("Task class is an inner class and it should be static");
        }
    }

    private  void syncExecute(RemotePromise promise) {
        CompletableFuture addFuture = promise.getAddFuture();
        Boolean res = addFuture.join();
        if (!res) {
            throw new RejectedExecutionException("Task rejected. ExecutorService is in shutdown state");
        }
    }

    @Override
    public  RExecutorFuture submit(Runnable task, T result) {
        RemotePromise future = (RemotePromise) submit(task).toCompletableFuture();
        CompletableFuture f = future.thenApply(res -> result);
        return new RedissonExecutorFuture(f, future.getRequestId());
    }

    @Override
    public RExecutorBatchFuture submit(Runnable... tasks) {
        if (tasks.length == 0) {
            throw new NullPointerException("Tasks are not defined");
        }

        List> result = new ArrayList<>();
        TasksBatchService executorRemoteService = createBatchService();
        RemoteExecutorServiceAsync asyncService = executorRemoteService.get(RemoteExecutorServiceAsync.class, RESULT_OPTIONS);
        for (Runnable task : tasks) {
            check(task);
            RemotePromise promise = (RemotePromise) asyncService.executeRunnable(createTaskParameters(task)).toCompletableFuture();
            RedissonExecutorFuture executorFuture = new RedissonExecutorFuture(promise);
            result.add(executorFuture);
        }
        
        List addResult = executorRemoteService.executeAdd();
        if (!addResult.get(0)) {
            throw new RejectedExecutionException("Tasks have been rejected. ExecutorService is in shutdown state");
        }

        CompletableFuture future = CompletableFuture.allOf(result.stream()
                                                                    .map(CompletionStage::toCompletableFuture)
                                                                    .toArray(CompletableFuture[]::new));
        return new RedissonExecutorBatchFuture(future, result);
    }
    
    @Override
    public RExecutorBatchFuture submitAsync(Runnable... tasks) {
        if (tasks.length == 0) {
            throw new NullPointerException("Tasks are not defined");
        }

        TasksBatchService executorRemoteService = createBatchService();
        RemoteExecutorServiceAsync asyncService = executorRemoteService.get(RemoteExecutorServiceAsync.class, RESULT_OPTIONS);
        List> result = new ArrayList<>();
        for (Runnable task : tasks) {
            check(task);
            RemotePromise promise = (RemotePromise) asyncService.executeRunnable(createTaskParameters(task)).toCompletableFuture();
            RedissonExecutorFuture executorFuture = new RedissonExecutorFuture(promise);
            result.add(executorFuture);
        }
        
        executorRemoteService.executeAddAsync().whenComplete((res, e) -> {
            if (e != null) {
                for (RExecutorFuture executorFuture : result) {
                    executorFuture.toCompletableFuture().completeExceptionally(e);
                }
                return;
            }
            
            for (Boolean bool : res) {
                if (!bool) {
                    RejectedExecutionException ex = new RejectedExecutionException("Task rejected. ExecutorService is in shutdown state");
                    for (RExecutorFuture executorFuture : result) {
                        executorFuture.toCompletableFuture().completeExceptionally(ex);
                    }
                    break;
                }
            }
        });

        CompletableFuture future = CompletableFuture.allOf(result.stream()
                                                                    .map(CompletionStage::toCompletableFuture)
                                                                    .toArray(CompletableFuture[]::new));
        return new RedissonExecutorBatchFuture(future, result);
    }

    
    @Override
    public RExecutorFuture submit(Runnable task) {
        return submit(idGenerator.generateId(), task);
    }

    @Override
    public RExecutorFuture submit(Runnable task, long timeToLive, TimeUnit timeUnit) {
        return submit(idGenerator.generateId(), task, Duration.ofMillis(timeUnit.toMillis(timeToLive)));
    }

    @Override
    public RExecutorFuture submitAsync(Runnable task, long timeToLive, TimeUnit timeUnit) {
        return submitAsync(idGenerator.generateId(), task, Duration.ofMillis(timeUnit.toMillis(timeToLive)));
    }

    @Override
    public RExecutorFuture submitAsync(Runnable task) {
        return submitAsync(idGenerator.generateId(), task);
    }
    
    private void cancelResponseHandling(String requestId) {
        synchronized (responses) {
            ResponseEntry entry = responses.get(responseQueueName);
            if (entry == null) {
                return;
            }
            
            List list = entry.getResponses().remove(requestId);
            if (list != null) {
                for (Result result : list) {
                    result.getResponseTimeoutFuture().cancel(true);
                }
            }
            if (entry.getResponses().isEmpty()) {
                responses.remove(responseQueueName, entry);
            }
        }
    }
    
    @Override
    public RScheduledFuture schedule(Runnable task, long delay, TimeUnit unit) {
        return schedule(idGenerator.generateId(), task, Duration.ofMillis(unit.toMillis(delay)));
    }

    private  RExecutorFuture createFuture(RemotePromise promise) {
        RExecutorFuture f = new RedissonExecutorFuture(promise);
        storeReference(f, promise.getRequestId());
        return f;
    }
    
    private  RScheduledFuture createFuture(RemotePromise promise, long scheduledExecutionTime) {
        RedissonScheduledFuture f = new RedissonScheduledFuture(promise, scheduledExecutionTime);
        storeReference(f, promise.getRequestId());
        return f;
    }
    
    private void storeReference(RExecutorFuture future, String requestId) {
        while (true) {
            RedissonExecutorFutureReference r = (RedissonExecutorFutureReference) referenceDueue.poll();
            if (r == null) {
                break;
            }
            references.remove(r);
            
            if (r.getPromise().getNumberOfDependents() == 0) {
                cancelResponseHandling(r.getRequestId());
            }
        }
        
        CompletableFuture promise = ((CompletableFutureWrapper) future).toCompletableFuture();
        RedissonExecutorFutureReference reference = new RedissonExecutorFutureReference(requestId, future, referenceDueue, promise);
        references.add(reference);
    }
    
    @Override
    public RScheduledFuture scheduleAsync(Runnable task, long delay, TimeUnit unit) {
        return scheduleAsync(idGenerator.generateId(), task, Duration.ofMillis(unit.toMillis(delay)));
    }
    
    @Override
    public  RScheduledFuture schedule(Callable task, long delay, TimeUnit unit) {
        return schedule(idGenerator.generateId(), task, Duration.ofMillis(unit.toMillis(delay)));
    }
    
    @Override
    public  RScheduledFuture scheduleAsync(Callable task, long delay, TimeUnit unit) {
        return scheduleAsync(idGenerator.generateId(), task, Duration.ofMillis(unit.toMillis(delay)));
    }

    @Override
    public RScheduledFuture schedule(Runnable command, long delay, TimeUnit unit, long ttl, TimeUnit ttlUnit) {
        return schedule(idGenerator.generateId(), command, Duration.ofMillis(unit.toMillis(delay)), Duration.ofMillis(ttlUnit.toMillis(ttl)));
    }

    @Override
    public RScheduledFuture scheduleAsync(Runnable task, long delay, TimeUnit unit, long timeToLive, TimeUnit ttlUnit) {
        return scheduleAsync(idGenerator.generateId(), task, Duration.ofMillis(unit.toMillis(delay)), Duration.ofMillis(ttlUnit.toMillis(timeToLive)));
    }

    @Override
    public  RScheduledFuture schedule(Callable callable, long delay, TimeUnit unit, long timeToLive, TimeUnit ttlUnit) {
        return schedule(idGenerator.generateId(), callable, Duration.ofMillis(unit.toMillis(delay)), Duration.ofMillis(ttlUnit.toMillis(timeToLive)));
    }

    @Override
    public  RScheduledFuture scheduleAsync(Callable task, long delay, TimeUnit unit, long timeToLive, TimeUnit ttlUnit) {
        return scheduleAsync(idGenerator.generateId(), task, Duration.ofMillis(unit.toMillis(delay)), Duration.ofMillis(ttlUnit.toMillis(timeToLive)));
    }

    private ScheduledParameters createScheduledParameters(String id, Duration timeToLive, ClassBody classBody, byte[] state, long startTime) {
        ScheduledParameters params = new ScheduledParameters(id, classBody.getClazzName(), classBody.getClazz(), classBody.getLambda(), state, startTime);
        if (timeToLive.toMillis() > 0) {
            params.setTtl(timeToLive.toMillis());
        }
        return params;
    }

    @Override
    public RScheduledFuture scheduleAtFixedRate(Runnable task, long initialDelay, long period, TimeUnit unit) {
        return scheduleAtFixedRate(idGenerator.generateId(), task, Duration.ofMillis(unit.toMillis(initialDelay)), Duration.ofMillis(unit.toMillis(period)));
    }
    
    @Override
    public RScheduledFuture scheduleAtFixedRateAsync(Runnable task, long initialDelay, long period, TimeUnit unit) {
        return scheduleAtFixedRate(idGenerator.generateId(), task, Duration.ofMillis(unit.toMillis(initialDelay)), Duration.ofMillis(unit.toMillis(period)));
    }

    @Override
    public RScheduledFuture schedule(Runnable task, CronSchedule cronSchedule) {
        return schedule(idGenerator.generateId(), task, cronSchedule);
    }
    
    @Override
    public RScheduledFuture scheduleAsync(Runnable task, CronSchedule cronSchedule) {
        return scheduleAsync(idGenerator.generateId(), task, cronSchedule);
    }
    
    @Override
    public RScheduledFuture scheduleWithFixedDelay(Runnable task, long initialDelay, long delay, TimeUnit unit) {
        return scheduleWithFixedDelay(idGenerator.generateId(), task, Duration.ofMillis(unit.toMillis(initialDelay)), Duration.ofMillis(unit.toMillis(delay)));
    }
    
    @Override
    public RScheduledFuture scheduleWithFixedDelayAsync(Runnable task, long initialDelay, long delay, TimeUnit unit) {
        return scheduleWithFixedDelayAsync(idGenerator.generateId(), task, Duration.ofMillis(unit.toMillis(initialDelay)), Duration.ofMillis(unit.toMillis(delay)));
    }

    @Override
    public Boolean cancelTask(String taskId) {
        return commandExecutor.get(cancelTaskAsync(taskId));
    }

    @Override
    public RFuture cancelTaskAsync(String taskId) {
        return scheduledRemoteService.cancelExecutionAsync(taskId);
    }

    private  T poll(List> futures, long timeout, TimeUnit timeUnit) throws InterruptedException, TimeoutException {
        CompletableFuture future = CompletableFuture.anyOf(futures.toArray(new CompletableFuture[0]));
        try {
            if (timeout == -1) {
                return (T) future.get();
            } else {
                return (T) future.get(timeout, timeUnit);
            }
        } catch (ExecutionException e) {
            throw commandExecutor.convertException(e);
        }
    }
    
    @Override
    public  T invokeAny(Collection> tasks) throws InterruptedException, ExecutionException {
        try {
            return invokeAny(tasks, -1, null);
        } catch (TimeoutException cannotHappen) {
            return null;
        }
    }

    @Override
    public  T invokeAny(Collection> tasks,
                           long timeout, TimeUnit unit) throws InterruptedException, ExecutionException, TimeoutException {
        if (tasks == null) {
            throw new NullPointerException();
        }

        List> futures = new ArrayList<>();
        for (Callable callable : tasks) {
            RExecutorFuture future = submit(callable);
            futures.add(future.toCompletableFuture());
        }

        T result = poll(futures, timeout, unit);
        for (CompletableFuture f : futures) {
            f.cancel(true);
        }
        return result;
    }

    @Override
    public  List> invokeAll(Collection> tasks) throws InterruptedException {
        if (tasks == null) {
            throw new NullPointerException();
        }
        
        RExecutorBatchFuture future = submit(tasks.toArray(new Callable[0]));
        try {
            future.toCompletableFuture().join();
        } catch (Exception e) {
            // skip
        }
        List futures = future.getTaskFutures();
        return (List>) futures;
    }

    @Override
    public  List> invokeAll(Collection> tasks,
                                         long timeout, TimeUnit unit) throws InterruptedException {
        if (tasks == null || unit == null) {
            throw new NullPointerException();
        }
        
        RExecutorBatchFuture future = submit(tasks.toArray(new Callable[0]));
        try {
            future.toCompletableFuture().get(timeout, unit);
        } catch (ExecutionException | TimeoutException | CancellationException e) {
            // skip
        }
        List futures = future.getTaskFutures();
        return (List>) futures;
    }

    @Override
    public  RExecutorFuture submit(String id, Callable task) {
        RemotePromise promise = (RemotePromise) submitAsync(id, task).toCompletableFuture();
        syncExecute(promise);
        return createFuture(promise);
    }

    @Override
    public  RExecutorFuture submitAsync(String id, Callable task) {
        check(task);
        TaskParameters params = createTaskParameters(id, task);
        RemotePromise result = (RemotePromise) asyncService.executeCallable(params).toCompletableFuture();
        addListener(result);
        return createFuture(result);
    }

    @Override
    public  RExecutorFuture submit(String id, Callable task, Duration timeToLive) {
        RemotePromise promise = (RemotePromise) submitAsync(id, task, timeToLive).toCompletableFuture();
        syncExecute(promise);
        return createFuture(promise);
    }

    @Override
    public  RExecutorFuture submitAsync(String id, Callable task, Duration timeToLive) {
        check(task);
        TaskParameters taskParameters = createTaskParameters(id, task);
        taskParameters.setTtl(timeToLive.toMillis());
        RemotePromise result = (RemotePromise) asyncService.executeCallable(taskParameters).toCompletableFuture();
        addListener(result);
        return createFuture(result);
    }

    @Override
    public RExecutorFuture submit(String id, Runnable task, Duration timeToLive) {
        RemotePromise promise = (RemotePromise) submitAsync(id, task, timeToLive).toCompletableFuture();
        syncExecute(promise);
        return createFuture(promise);
    }

    @Override
    public RExecutorFuture submitAsync(String id, Runnable task, Duration timeToLive) {
        check(task);
        TaskParameters taskParameters = createTaskParameters(id, task);
        taskParameters.setTtl(timeToLive.toMillis());
        RemotePromise result = (RemotePromise) asyncService.executeRunnable(taskParameters).toCompletableFuture();
        addListener(result);
        return createFuture(result);
    }

    @Override
    public RExecutorFuture submit(String id, Runnable task) {
        RemotePromise promise = (RemotePromise) submitAsync(id, task).toCompletableFuture();
        syncExecute(promise);
        return createFuture(promise);
    }

    @Override
    public RExecutorFuture submitAsync(String id, Runnable task) {
        check(task);
        RemotePromise result = (RemotePromise) asyncService.executeRunnable(createTaskParameters(id, task)).toCompletableFuture();
        addListener(result);
        return createFuture(result);
    }

    @Override
    public RScheduledFuture schedule(String id, Runnable command, Duration delay) {
        RedissonScheduledFuture future = (RedissonScheduledFuture) scheduleAsync(id, command, delay);
        RemotePromise rp = future.getInnerPromise();
        syncExecute(rp);
        return future;
    }

    @Override
    public RScheduledFuture scheduleAsync(String id, Runnable task, Duration delay) {
        return scheduleAsync(id, task, delay, Duration.ZERO);
    }

    @Override
    public RScheduledFuture schedule(String id, Runnable command, Duration delay, Duration timeToLive) {
        RedissonScheduledFuture future = (RedissonScheduledFuture) scheduleAsync(id, command, delay, timeToLive);
        RemotePromise rp = future.getInnerPromise();
        syncExecute(rp);
        return future;
    }

    @Override
    public RScheduledFuture scheduleAsync(String id, Runnable task, Duration delay, Duration timeToLive) {
        check(task);
        ClassBody classBody = getClassBody(task);
        byte[] state = encode(task);
        long startTime = System.currentTimeMillis() + delay.toMillis();
        ScheduledParameters params = createScheduledParameters(id, timeToLive, classBody, state, startTime);
        RemotePromise result = (RemotePromise) asyncScheduledService.scheduleRunnable(params).toCompletableFuture();
        addListener(result);
        return createFuture(result, startTime);
    }

    @Override
    public  RScheduledFuture schedule(String id, Callable callable, Duration delay) {
        RedissonScheduledFuture future = (RedissonScheduledFuture) scheduleAsync(id, callable, delay);
        RemotePromise rp = future.getInnerPromise();
        syncExecute(rp);
        return future;
    }

    @Override
    public  RScheduledFuture scheduleAsync(String id, Callable task, Duration delay) {
        return scheduleAsync(id, task, delay, Duration.ZERO);
    }

    @Override
    public  RScheduledFuture schedule(String id, Callable callable, Duration delay, Duration timeToLive) {
        RedissonScheduledFuture future = (RedissonScheduledFuture) scheduleAsync(id, callable, delay, timeToLive);
        RemotePromise rp = future.getInnerPromise();
        syncExecute(rp);
        return future;
    }

    @Override
    public  RScheduledFuture scheduleAsync(String id, Callable task, Duration delay, Duration timeToLive) {
        check(task);
        ClassBody classBody = getClassBody(task);
        byte[] state = encode(task);
        long startTime = System.currentTimeMillis() + delay.toMillis();
        ScheduledParameters params = createScheduledParameters(id, timeToLive, classBody, state, startTime);
        RemotePromise result = (RemotePromise) asyncScheduledService.scheduleCallable(params).toCompletableFuture();
        addListener(result);
        return createFuture(result, startTime);
    }

    @Override
    public RScheduledFuture scheduleAtFixedRate(String id, Runnable command, Duration initialDelay, Duration period) {
        RedissonScheduledFuture future = (RedissonScheduledFuture) scheduleAtFixedRateAsync(id, command, initialDelay, period);
        RemotePromise rp = future.getInnerPromise();
        syncExecute(rp);
        return future;
    }

    @Override
    public RScheduledFuture scheduleAtFixedRateAsync(String id, Runnable task, Duration initialDelay, Duration period) {
        check(task);
        ClassBody classBody = getClassBody(task);
        byte[] state = encode(task);
        long startTime = System.currentTimeMillis() + initialDelay.toMillis();

        String taskId = id;
        ScheduledAtFixedRateParameters params = new ScheduledAtFixedRateParameters(taskId);
        params.setClassName(classBody.getClazzName());
        params.setClassBody(classBody.getClazz());
        params.setLambdaBody(classBody.getLambda());
        params.setState(state);
        params.setStartTime(startTime);
        params.setPeriod(period.toMillis());
        params.setExecutorId(executorId);
        RemotePromise result = (RemotePromise) asyncScheduledServiceAtFixed.scheduleAtFixedRate(params).toCompletableFuture();
        addListener(result);
        return createFuture(result, startTime);
    }

    @Override
    public RScheduledFuture scheduleWithFixedDelay(String id, Runnable command, Duration initialDelay, Duration delay) {
        RedissonScheduledFuture future = (RedissonScheduledFuture) scheduleWithFixedDelayAsync(id, command, initialDelay, delay);
        RemotePromise rp = future.getInnerPromise();
        syncExecute(rp);
        return future;
    }

    @Override
    public RScheduledFuture scheduleWithFixedDelayAsync(String id, Runnable task, Duration initialDelay, Duration delay) {
        check(task);
        ClassBody classBody = getClassBody(task);
        byte[] state = encode(task);
        long startTime = System.currentTimeMillis() + initialDelay.toMillis();

        String taskId = id;
        ScheduledWithFixedDelayParameters params = new ScheduledWithFixedDelayParameters(taskId);
        params.setClassName(classBody.getClazzName());
        params.setClassBody(classBody.getClazz());
        params.setLambdaBody(classBody.getLambda());
        params.setState(state);
        params.setStartTime(startTime);
        params.setDelay(delay.toMillis());
        params.setExecutorId(executorId);
        RemotePromise result = (RemotePromise) asyncScheduledServiceAtFixed.scheduleWithFixedDelay(params).toCompletableFuture();
        addListener(result);
        return createFuture(result, startTime);
    }

    @Override
    public RScheduledFuture schedule(String id, Runnable task, CronSchedule cronSchedule) {
        RedissonScheduledFuture future = (RedissonScheduledFuture) scheduleAsync(id, task, cronSchedule);
        RemotePromise rp = future.getInnerPromise();
        syncExecute(rp);
        return future;
    }

    @Override
    public RScheduledFuture scheduleAsync(String id, Runnable task, CronSchedule cronSchedule) {
        check(task);
        ClassBody classBody = getClassBody(task);
        byte[] state = encode(task);
        ZonedDateTime currentDate = ZonedDateTime.of(LocalDateTime.now(), cronSchedule.getZoneId());
        ZonedDateTime startDate = cronSchedule.getExpression().nextTimeAfter(currentDate);
        if (startDate == null) {
            throw new IllegalArgumentException("Wrong cron expression! Unable to calculate start date");
        }
        long startTime = startDate.toInstant().toEpochMilli();

        String taskId = id;
        ScheduledCronExpressionParameters params = new ScheduledCronExpressionParameters(taskId);
        params.setClassName(classBody.getClazzName());
        params.setClassBody(classBody.getClazz());
        params.setLambdaBody(classBody.getLambda());
        params.setState(state);
        params.setStartTime(startTime);
        params.setCronExpression(cronSchedule.getExpression().getExpr());
        params.setTimezone(cronSchedule.getZoneId().toString());
        params.setExecutorId(executorId);
        RemotePromise result = (RemotePromise) asyncScheduledServiceAtFixed.schedule(params).toCompletableFuture();
        addListener(result);
        RedissonScheduledFuture f = new RedissonScheduledFuture(result, startTime) {
            public long getDelay(TimeUnit unit) {
                return unit.convert(startDate.toInstant().toEpochMilli() - System.currentTimeMillis(), TimeUnit.MILLISECONDS);
            };
        };
        storeReference(f, result.getRequestId());
        return f;
    }

}