![JAR search and dependency download from the Maven repository](/logo.png)
com.github.lontime.shaded.org.redisson.connection.ReplicatedConnectionManager 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.connection;
import io.netty.util.concurrent.ScheduledFuture;
import com.github.lontime.shaded.org.redisson.api.NodeType;
import com.github.lontime.shaded.org.redisson.api.RFuture;
import com.github.lontime.shaded.org.redisson.client.RedisClient;
import com.github.lontime.shaded.org.redisson.client.RedisConnection;
import com.github.lontime.shaded.org.redisson.client.RedisConnectionException;
import com.github.lontime.shaded.org.redisson.client.protocol.RedisCommands;
import com.github.lontime.shaded.org.redisson.config.*;
import com.github.lontime.shaded.org.redisson.connection.ClientConnectionsEntry.FreezeReason;
import com.github.lontime.shaded.org.redisson.misc.AsyncCountDownLatch;
import com.github.lontime.shaded.org.redisson.misc.RedisURI;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
import java.net.InetSocketAddress;
import java.util.Collections;
import java.util.Map;
import java.util.Set;
import java.util.UUID;
import java.util.concurrent.CompletableFuture;
import java.util.concurrent.CompletionStage;
import java.util.concurrent.ConcurrentHashMap;
import java.util.concurrent.TimeUnit;
import java.util.concurrent.atomic.AtomicReference;
import java.util.stream.Collectors;
/**
* {@link ConnectionManager} for AWS ElastiCache Replication Groups or Azure Redis Cache. By providing all nodes
* of the replication group to this manager, the role of each node can be polled to determine
* if a failover has occurred resulting in a new master.
*
* @author Nikita Koksharov
* @author Steve Ungerer
*/
public class ReplicatedConnectionManager extends MasterSlaveConnectionManager {
private static final String ROLE_KEY = "role";
private final Logger log = LoggerFactory.getLogger(getClass());
private final AtomicReference currentMaster = new AtomicReference<>();
private ScheduledFuture> monitorFuture;
private enum Role {
master,
slave
}
public ReplicatedConnectionManager(ReplicatedServersConfig cfg, Config config, UUID id) {
super(config, id);
this.config = create(cfg);
initTimer(this.config);
for (String address : cfg.getNodeAddresses()) {
RedisURI addr = new RedisURI(address);
CompletionStage connectionFuture = connectToNode(cfg, addr, addr.getHost());
RedisConnection connection = null;
try {
connection = connectionFuture.toCompletableFuture().join();
} catch (Exception e) {
// skip
}
if (connection == null) {
continue;
}
Role role = Role.valueOf(connection.sync(RedisCommands.INFO_REPLICATION).get(ROLE_KEY));
if (Role.master.equals(role)) {
currentMaster.set(connection.getRedisClient().getAddr());
log.info("{} is the master", addr);
this.config.setMasterAddress(addr.toString());
} else {
log.info("{} is a slave", addr);
this.config.addSlaveAddress(addr.toString());
}
}
if (currentMaster.get() == null) {
stopThreads();
throw new RedisConnectionException("Can't connect to servers!");
}
if (this.config.getReadMode() != ReadMode.MASTER && this.config.getSlaveAddresses().isEmpty()) {
log.warn("ReadMode = " + this.config.getReadMode() + ", but slave nodes are not found! Please specify all nodes in replicated mode.");
}
initSingleEntry();
scheduleMasterChangeCheck(cfg);
}
@Override
protected void startDNSMonitoring(RedisClient masterHost) {
// disabled
}
@Override
protected MasterSlaveServersConfig create(BaseMasterSlaveServersConfig> cfg) {
MasterSlaveServersConfig res = super.create(cfg);
res.setDatabase(((ReplicatedServersConfig) cfg).getDatabase());
return res;
}
private void scheduleMasterChangeCheck(ReplicatedServersConfig cfg) {
if (isShuttingDown()) {
return;
}
monitorFuture = group.schedule(() -> {
if (isShuttingDown()) {
return;
}
Set slaveIPs = Collections.newSetFromMap(new ConcurrentHashMap<>());
AsyncCountDownLatch latch = new AsyncCountDownLatch();
latch.latch(() -> {
checkFailedSlaves(slaveIPs);
scheduleMasterChangeCheck(cfg);
}, cfg.getNodeAddresses().size());
for (String address : cfg.getNodeAddresses()) {
RedisURI uri = new RedisURI(address);
checkNode(latch, uri, cfg, slaveIPs);
}
}, cfg.getScanInterval(), TimeUnit.MILLISECONDS);
}
private void checkFailedSlaves(Set slaveIPs) {
MasterSlaveEntry entry = getEntry(singleSlotRange.getStartSlot());
Set failedSlaves = entry.getAllEntries().stream()
.filter(e -> e.getNodeType() == NodeType.SLAVE
&& !slaveIPs.contains(e.getClient().getAddr()))
.map(e -> e.getClient())
.collect(Collectors.toSet());
for (RedisClient slave : failedSlaves) {
if (entry.slaveDown(slave.getAddr(), FreezeReason.MANAGER)) {
log.info("slave: {} is down", slave);
disconnectNode(new RedisURI(slave.getConfig().getAddress().getScheme(),
slave.getAddr().getAddress().getHostAddress(),
slave.getAddr().getPort()));
}
}
}
private void checkNode(AsyncCountDownLatch latch, RedisURI uri, ReplicatedServersConfig cfg, Set slaveIPs) {
CompletionStage connectionFuture = connectToNode(cfg, uri, uri.getHost());
connectionFuture.whenComplete((connection, exc) -> {
if (exc != null) {
log.error(exc.getMessage(), exc);
latch.countDown();
return;
}
if (isShuttingDown()) {
return;
}
RFuture
© 2015 - 2025 Weber Informatics LLC | Privacy Policy