package com.xcong.excoin.modules.okxNewPrice; import cn.hutool.core.util.ObjectUtil; import cn.hutool.core.util.StrUtil; import com.alibaba.fastjson.JSON; import com.alibaba.fastjson.JSONObject; import com.xcong.excoin.modules.okxNewPrice.celue.CaoZuoService; import com.xcong.excoin.modules.okxNewPrice.okxWs.*; import com.xcong.excoin.modules.okxNewPrice.okxWs.enums.CoinEnums; import com.xcong.excoin.modules.okxNewPrice.okxWs.enums.OrderParamEnums; import com.xcong.excoin.modules.okxNewPrice.utils.SSLConfig; import com.xcong.excoin.modules.okxNewPrice.wangge.WangGeService; import com.xcong.excoin.utils.RedisUtils; import lombok.extern.slf4j.Slf4j; import org.java_websocket.client.WebSocketClient; import org.java_websocket.handshake.ServerHandshake; import org.springframework.beans.factory.annotation.Autowired; import org.springframework.boot.autoconfigure.condition.ConditionalOnProperty; import org.springframework.stereotype.Component; import javax.annotation.PostConstruct; import javax.annotation.PreDestroy; import java.math.BigDecimal; import java.net.URI; import java.net.URISyntaxException; import java.util.concurrent.*; import java.util.concurrent.atomic.AtomicReference; /** * OKX 新价格 WebSocket 客户端类,用于连接 OKX 的 WebSocket 接口, * 实时获取并处理标记价格(mark price)数据,并将价格信息存储到 Redis 中。 * 同时支持心跳检测、自动重连以及异常恢复机制。 * @author Administrator */ @Slf4j @Component @ConditionalOnProperty(prefix = "app", name = "quant", havingValue = "true") public class OkxQuantWebSocketClient { @Autowired private WangGeService wangGeService; @Autowired private CaoZuoService caoZuoService; @Autowired private RedisUtils redisUtils; private WebSocketClient webSocketClient; private ScheduledExecutorService heartbeatExecutor; private volatile ScheduledFuture pongTimeoutFuture; private final AtomicReference lastMessageTime = new AtomicReference<>(System.currentTimeMillis()); private static final String WS_URL_MONIPAN = "wss://wspap.okx.com:8443/ws/v5/private"; private static final String WS_URL_SHIPAN = "wss://ws.okx.com:8443/ws/v5/private"; private static final boolean INTERNET = false; /** * 订阅频道指令 */ private static final String SUBSCRIBE = "subscribe"; private static final String UNSUBSCRIBE = "unsubscribe"; // 心跳超时时间(秒),小于30秒 private static final int HEARTBEAT_TIMEOUT = 10; // 共享线程池用于重连等异步任务 private final ExecutorService sharedExecutor = Executors.newCachedThreadPool(r -> { Thread t = new Thread(r, "okx-ws-account-order-worker"); t.setDaemon(true); return t; }); /** * 初始化方法,在 Spring Bean 构造完成后执行。 * 负责建立 WebSocket 连接并启动心跳检测任务。 */ @PostConstruct public void init() { connect(); startHeartbeat(); } /** * 销毁方法,在 Spring Bean 销毁前执行。 * 关闭 WebSocket 连接、停止心跳定时器及相关的线程资源。 */ @PreDestroy public void destroy() { if (webSocketClient != null && webSocketClient.isOpen()) { subscribeAccountChannel(UNSUBSCRIBE); subscribePositionChannel(UNSUBSCRIBE); subscribeOrderInfoChannel(UNSUBSCRIBE); webSocketClient.close(); } shutdownExecutorGracefully(heartbeatExecutor); if (pongTimeoutFuture != null) { pongTimeoutFuture.cancel(true); } shutdownExecutorGracefully(sharedExecutor); } private void shutdownExecutorGracefully(ExecutorService executor) { if (executor == null || executor.isTerminated()) { return; } try { executor.shutdown(); if (!executor.awaitTermination(5, TimeUnit.SECONDS)) { executor.shutdownNow(); } } catch (InterruptedException e) { Thread.currentThread().interrupt(); executor.shutdownNow(); } } /** * 建立与 OKX WebSocket 服务器的连接。 * 设置回调函数以监听连接打开、接收消息、关闭和错误事件。 */ private void connect() { try { InstrumentsWs.handleEvent(redisUtils); wangGeService.initWangGe(); SSLConfig.configureSSL(); System.setProperty("https.protocols", "TLSv1.2,TLSv1.3"); String WS_URL = WS_URL_MONIPAN; if (INTERNET){ WS_URL = WS_URL_SHIPAN; } URI uri = new URI(WS_URL); webSocketClient = new WebSocketClient(uri) { @Override public void onOpen(ServerHandshake handshake) { log.info("OKX account-order WebSocket连接成功"); // 检查应用是否正在关闭 if (!sharedExecutor.isShutdown()) { resetHeartbeatTimer(); websocketLogin(); } else { log.warn("应用正在关闭,忽略WebSocket连接成功回调"); } } @Override public void onMessage(String message) { lastMessageTime.set(System.currentTimeMillis()); handleWebSocketMessage(message); resetHeartbeatTimer(); } @Override public void onClose(int code, String reason, boolean remote) { log.warn("OKX account-order WebSocket连接关闭: code={}, reason={}", code, reason); cancelPongTimeout(); if (sharedExecutor != null && !sharedExecutor.isShutdown() && !sharedExecutor.isTerminated()) { sharedExecutor.execute(() -> { try { reconnectWithBackoff(); } catch (InterruptedException e) { Thread.currentThread().interrupt(); log.error("重连线程被中断", e); } catch (Exception e) { log.error("重连失败", e); } }); } else { log.warn("共享线程池已关闭,无法执行重连任务"); } } @Override public void onError(Exception ex) { log.error("OKX account-order WebSocket发生错误", ex); } }; webSocketClient.connect(); } catch (URISyntaxException e) { log.error("WebSocket URI格式错误", e); } } private void websocketLogin() { LoginWs.websocketLogin(webSocketClient); } private void subscribeBalanceAndPositionChannel(String option) { BalanceAndPositionWs.subscribeBalanceAndPositionChannel(webSocketClient, option); } private void subscribeOrderInfoChannel(String option) { OrderInfoWs.subscribeOrderInfoChannel(webSocketClient, option); } private void subscribeAccountChannel(String option) { AccountWs.subscribeAccountChannel(webSocketClient, option); } private void subscribePositionChannel(String option) { PositionsWs.subscribePositionChannel(webSocketClient, option); } /** * 处理从 WebSocket 收到的消息。 * 包括订阅确认、错误响应、心跳响应以及实际的数据推送。 * * @param message 来自 WebSocket 的原始字符串消息 */ private void handleWebSocketMessage(String message) { try { if ("pong".equals(message)) { log.info("收到心跳响应"); cancelPongTimeout(); return; } JSONObject response = JSON.parseObject(message); String event = response.getString("event"); if ("login".equals(event)) { String code = response.getString("code"); if ("0".equals(code)) { String connId = response.getString("connId"); log.info("WebSocket登录成功, connId: {}", connId); subscribeAccountChannel(SUBSCRIBE); subscribeOrderInfoChannel(SUBSCRIBE); subscribePositionChannel(SUBSCRIBE); } else { log.error("WebSocket登录失败, code: {}, msg: {}", code, response.getString("msg")); } } else if ("subscribe".equals(event)) { log.info("订阅成功: {}", response.getJSONObject("arg")); } else if ("error".equals(event)) { log.error("订阅错误: code={}, msg={}", response.getString("code"), response.getString("msg")); } else if ("channel-conn-count".equals(event)) { log.info("连接限制更新: channel={}, connCount={}", response.getString("channel"), response.getString("connCount")); } else { processPushData(response); } } catch (Exception e) { log.error("处理WebSocket消息失败: {}", message, e); } } /** * 解析并处理价格推送数据。 * 将最新的标记价格存入 Redis 并触发后续业务逻辑比较处理。 * * @param response 包含价格数据的 JSON 对象 */ private void processPushData(JSONObject response) { JSONObject arg = response.getJSONObject("arg"); if (arg == null) { log.warn("无效的推送数据,缺少 'arg' 字段"); return; } String channel = arg.getString("channel"); if (channel == null) { log.warn("无效的推送数据,缺少 'channel' 字段"); return; } if (OrderInfoWs.ORDERINFOWS_CHANNEL.equals(channel)) { OrderInfoWs.handleEvent(response, redisUtils); }else if (AccountWs.ACCOUNTWS_CHANNEL.equals(channel)) { AccountWs.handleEvent(response, redisUtils); } else if (PositionsWs.POSITIONSWS_CHANNEL.equals(channel)) { PositionsWs.handleEvent(response, redisUtils); String posKey = PositionsWs.POSITIONSWS_CHANNEL + ":" + CoinEnums.HE_YUE.getCode() + ":pos"; String pos = (String) redisUtils.get(posKey); if (StrUtil.isBlank(pos)) { log.error("未获取到持仓数量"); TradeOrderWs.orderEvent(webSocketClient, redisUtils, OrderParamEnums.INIT.getValue()); return; } String state = (String) redisUtils.get(InstrumentsWs.INSTRUMENTSWS_CHANNEL + ":" + CoinEnums.HE_YUE.getCode() + ":state"); String uplKey = PositionsWs.POSITIONSWS_CHANNEL + ":" + CoinEnums.HE_YUE.getCode() + ":upl"; String totalOrderUsdtKey = AccountWs.ACCOUNTWS_CHANNEL + ":" + CoinEnums.USDT.getCode() + ":totalOrderUsdt"; String upl = ObjectUtil.isEmpty(redisUtils.get(uplKey)) ? "0" : (String)redisUtils.get(uplKey); String totalOrderUsdt = (String) redisUtils.get(totalOrderUsdtKey); BigDecimal multiply = new BigDecimal(upl).multiply(new BigDecimal("-1")); if (new BigDecimal(totalOrderUsdt).compareTo(multiply) < 0 || OrderParamEnums.STATE_3.getValue().equals(state)) { log.error("持仓盈亏超过下单总保证金,止损冷静一天......"); TradeOrderWs.orderEvent(webSocketClient, redisUtils, OrderParamEnums.OUT.getValue()); return; } String side = caoZuoService.caoZuo(); if (StrUtil.isNotBlank(pos)) { TradeOrderWs.orderEvent(webSocketClient, redisUtils, side); } } else if (BalanceAndPositionWs.CHANNEL_NAME.equals(channel)) { BalanceAndPositionWs.handleEvent(response); } } /** * 启动心跳检测任务。 * 使用 ScheduledExecutorService 定期检查是否需要发送 ping 请求来维持连接。 */ private void startHeartbeat() { if (heartbeatExecutor != null && !heartbeatExecutor.isTerminated()) { heartbeatExecutor.shutdownNow(); } heartbeatExecutor = Executors.newSingleThreadScheduledExecutor(r -> { Thread t = new Thread(r, "okx-account-order-heartbeat"); t.setDaemon(true); return t; }); heartbeatExecutor.scheduleWithFixedDelay(this::checkHeartbeatTimeout, 25, 25, TimeUnit.SECONDS); } /** * 重置心跳计时器。 * 当收到新消息或发送 ping 后取消当前超时任务并重新安排下一次超时检查。 */ private void resetHeartbeatTimer() { cancelPongTimeout(); // 检查线程池状态,避免在关闭过程中提交任务 if (heartbeatExecutor != null && !heartbeatExecutor.isShutdown()) { pongTimeoutFuture = heartbeatExecutor.schedule(this::checkHeartbeatTimeout, HEARTBEAT_TIMEOUT, TimeUnit.SECONDS); } } /** * 检查心跳超时情况。 * 若长时间未收到任何消息则主动发送 ping 请求保持连接活跃。 */ private void checkHeartbeatTimeout() { long currentTime = System.currentTimeMillis(); long lastTime = lastMessageTime.get(); if (currentTime - lastTime >= HEARTBEAT_TIMEOUT * 1000L) { sendPing(); } } /** * 发送 ping 请求至 WebSocket 服务端。 * 用于维持长连接有效性。 */ private void sendPing() { try { if (webSocketClient != null && webSocketClient.isOpen()) { webSocketClient.send("ping"); log.debug("发送ping请求"); } } catch (Exception e) { log.warn("发送ping失败", e); } } /** * 取消当前的心跳超时任务。 * 在收到 pong 或其他有效消息时调用此方法避免不必要的断开重连。 */ private void cancelPongTimeout() { if (pongTimeoutFuture != null && !pongTimeoutFuture.isDone()) { pongTimeoutFuture.cancel(true); } } /** * 执行 WebSocket 重连操作。 * 在连接意外中断后尝试重新建立连接。 */ private void reconnectWithBackoff() throws InterruptedException { int attempt = 0; int maxAttempts = 5; long delayMs = 1000; while (attempt < maxAttempts) { try { Thread.sleep(delayMs); connect(); return; } catch (Exception e) { log.warn("第{}次重连失败", attempt + 1, e); delayMs *= 2; attempt++; } } log.error("超过最大重试次数({})仍未连接成功", maxAttempts); } }