com.github.lontime.shaded.org.redisson.RedissonBoundedBlockingQueue Maven / Gradle / Ivy
/**
* 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 com.github.lontime.shaded.org.redisson.api.RBoundedBlockingQueue;
import com.github.lontime.shaded.org.redisson.api.RFuture;
import com.github.lontime.shaded.org.redisson.api.RedissonClient;
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.protocol.RedisCommand;
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.decoder.ListDrainToDecoder;
import com.github.lontime.shaded.org.redisson.misc.CompletableFutureWrapper;
import java.time.Duration;
import java.util.*;
import java.util.concurrent.CompletableFuture;
import java.util.concurrent.CompletionException;
import java.util.concurrent.CompletionStage;
import java.util.concurrent.TimeUnit;
import java.util.function.Consumer;
/**
* Distributed and concurrent implementation of bounded {@link java.util.concurrent.BlockingQueue}.
*
* @author Nikita Koksharov
*/
public class RedissonBoundedBlockingQueue extends RedissonQueue implements RBoundedBlockingQueue {
private final RedissonBlockingQueue blockingQueue;
protected RedissonBoundedBlockingQueue(CommandAsyncExecutor commandExecutor, String name, RedissonClient redisson) {
super(commandExecutor, name, redisson);
blockingQueue = new RedissonBlockingQueue(commandExecutor, name, redisson);
}
protected RedissonBoundedBlockingQueue(Codec codec, CommandAsyncExecutor commandExecutor, String name, RedissonClient redisson) {
super(codec, commandExecutor, name, redisson);
blockingQueue = new RedissonBlockingQueue(commandExecutor, name, redisson);
}
private String getSemaphoreName() {
return prefixName("redisson_bqs", getRawName());
}
@Override
public RFuture addAsync(V e) {
RFuture future = offerAsync(e);
CompletionStage f = future.handle((res, ex) -> {
if (ex != null) {
throw new CompletionException(ex);
}
if (!res) {
throw new CompletionException(new IllegalStateException("Queue is full"));
}
return true;
});
return new CompletableFutureWrapper<>(f);
}
@Override
public RFuture putAsync(V e) {
RedissonQueueSemaphore semaphore = createSemaphore(e);
return semaphore.acquireAsync();
}
private RedissonQueueSemaphore createSemaphore(V e) {
RedissonQueueSemaphore semaphore = new RedissonQueueSemaphore(commandExecutor, getSemaphoreName());
semaphore.setQueueName(getRawName());
semaphore.setValue(e);
return semaphore;
}
@Override
public void put(V e) throws InterruptedException {
RedissonQueueSemaphore semaphore = createSemaphore(e);
semaphore.acquire();
}
@Override
public RFuture offerAsync(V e) {
RedissonQueueSemaphore semaphore = createSemaphore(e);
return semaphore.tryAcquireAsync();
}
@Override
public boolean offer(V e, long timeout, TimeUnit unit) throws InterruptedException {
RedissonQueueSemaphore semaphore = createSemaphore(e);
return semaphore.tryAcquire(timeout, unit);
}
@Override
public RFuture offerAsync(V e, long timeout, TimeUnit unit) {
RedissonQueueSemaphore semaphore = createSemaphore(e);
return semaphore.tryAcquireAsync(timeout, unit);
}
@Override
public RFuture takeAsync() {
RFuture takeFuture = blockingQueue.takeAsync();
return wrapTakeFuture(takeFuture);
}
private RFuture wrapTakeFuture(RFuture takeFuture) {
CompletableFuture f = takeFuture.toCompletableFuture().thenCompose(res -> {
if (res == null) {
return CompletableFuture.completedFuture(null);
}
return createSemaphore(null).releaseAsync().handle((r, ex) -> res);
});
f.whenComplete((r, e) -> {
if (f.isCancelled()) {
takeFuture.cancel(false);
}
});
return new CompletableFutureWrapper<>(f);
}
@Override
public RFuture removeAsync(Object o) {
return removeAllAsync(Collections.singleton(o));
}
@Override
public RFuture removeAllAsync(Collection> c) {
if (c.isEmpty()) {
return new CompletableFutureWrapper<>(false);
}
String channelName = RedissonSemaphore.getChannelName(getSemaphoreName());
return commandExecutor.evalWriteAsync(getRawName(), codec, RedisCommands.EVAL_BOOLEAN,
"local count = 0; " +
"for i = 1, #ARGV, 1 do "
+ "if redis.call('lrem', KEYS[1], 0, ARGV[i]) == 1 then "
+ "count = count + 1; "
+ "end; "
+"end; "
+ "if count > 0 then "
+ "local value = redis.call('incrby', KEYS[2], count); "
+ "redis.call('publish', KEYS[3], value); "
+ "return 1;"
+ "end;"
+ "return 0 ",
Arrays.