diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/RedisCollectorTaskKeyExpirationListener.java b/collector-terminal-management/src/main/java/com/docus/server/common/RedisCollectorTaskKeyExpirationListener.java deleted file mode 100644 index ab0057e..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/common/RedisCollectorTaskKeyExpirationListener.java +++ /dev/null @@ -1,30 +0,0 @@ -package com.docus.server.common; - -import com.docus.infrastructure.redis.listener.RedisKeyExpirationListener; -import com.docus.server.service.impl.RedisKeyExpirationService; -import org.springframework.data.redis.listener.RedisMessageListenerContainer; -import org.springframework.stereotype.Component; - -import javax.annotation.Resource; - -@Component -public class RedisCollectorTaskKeyExpirationListener extends RedisKeyExpirationListener { - - @Resource - private RedisKeyExpirationService redisKeyExpirationService; - - public RedisCollectorTaskKeyExpirationListener(RedisMessageListenerContainer listenerContainer) { - super(listenerContainer); - } - - @Override - protected void processExpireKey(String expireKey) { - redisKeyExpirationService.expired(expireKey); - } - - @Override - protected boolean validExpireKey(String expireKey) { - return expireKey.startsWith("schCollectorRecord:noRetryTask:expireKey:") - || expireKey.startsWith("schCollectorRecord:isRetryTask:expireKey:"); - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/SchCollectorTask.java b/collector-terminal-management/src/main/java/com/docus/server/common/SchCollectorTask.java deleted file mode 100644 index 287085c..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/common/SchCollectorTask.java +++ /dev/null @@ -1,439 +0,0 @@ -package com.docus.server.common; - -import com.docus.core.util.DateUtil; -import com.docus.core.util.Func; -import com.docus.core.util.json.JSON; -import com.docus.infrastructure.redis.service.RedisOps; -import com.docus.server.api.taskdistribute.TaskDistributeApi; -import com.docus.server.common.netty.CommMsg; -import com.docus.server.common.netty.server.ChannelRepository; -import com.docus.server.dto.scheduling.management.schcollector.task.ReportDownTwoDTO; -import com.docus.server.dto.scheduling.management.schcollector.task.ReportTaskTwoDTO; -import com.docus.server.dto.scheduling.management.schcollector.task.SchCollectorTaskDTO; -import com.docus.server.dto.scheduling.management.schterminator.NettyTerminatorDTO; -import com.docus.server.entity.scheduling.management.SchCollectRecord; -import com.docus.server.entity.scheduling.management.SchCollectRecordRetryLog; -import com.docus.server.entity.scheduling.management.SchCollector; -import com.docus.server.enums.BusyStateEnum; -import com.docus.server.enums.RetryTaskEnum; -import com.docus.server.service.ISchCollectRecordRetryLogService; -import com.docus.server.service.ISchCollectRecordService; -import com.docus.server.service.ISchCollectorService; -import com.docus.server.service.ISchTerminatorService; -import com.google.common.collect.Lists; -import io.netty.buffer.Unpooled; -import io.netty.channel.Channel; -import io.netty.util.CharsetUtil; -import lombok.extern.slf4j.Slf4j; -import org.springframework.scheduling.annotation.Scheduled; -import org.springframework.stereotype.Component; -import org.springframework.util.CollectionUtils; - -import javax.annotation.Resource; -import java.util.ArrayList; -import java.util.Date; -import java.util.List; -import java.util.Map; -import java.util.concurrent.BlockingQueue; -import java.util.concurrent.LinkedBlockingQueue; - -@Component -@Slf4j -public class SchCollectorTask { - @Resource - private ChannelRepository channelRepository; - @Resource - private TaskDistributeApi taskDistributeApi; - @Resource - private ISchCollectRecordService iSchCollectRecordService; - @Resource - private ISchCollectRecordRetryLogService iSchCollectRecordRetryLogService; - @Resource - private ISchTerminatorService iSchTerminatorService; - @Resource - private ISchCollectorService iSchCollectorService; - @Resource - private RedisOps redisOps; - - private BlockingQueue retryTaskQueue = new LinkedBlockingQueue<>(); - - //定时任务 - // 5 * * * * ? 在每分钟的5秒执行 - @Scheduled(cron = "0/1 * * * * ?") - public void runTask() { - try { - log.info("定时任务: 开始执行"); - - //在线并且空闲的终端 - List terminalList = channelRepository.getAvailTerminator(); - - //没有可用的通道 - if (Func.isEmpty(terminalList)) { - return; - } - - //:todo 任务平台需要修改发布任务策略 - List reportDownTwoDTOList = getTask(terminalList.size()); - - if (Func.isEmpty(reportDownTwoDTOList) || Func.isBlank(reportDownTwoDTOList.get(0).getPatientId())) { - return; - } - - //只采集,有优先级的 - for (NettyTerminatorDTO terminal : terminalList) { - for (ReportDownTwoDTO report : reportDownTwoDTOList) { - //先找出有只采集的任务。 - ReportTaskTwoDTO reportTaskTwoDto = report.getTasks().get(0); - if (!CollectionUtils.isEmpty(terminal.getOnlyCollectorIds()) && terminal.getOnlyCollectorIds().contains(reportTaskTwoDto.getCollectorId()) - && BusyStateEnum.IDLE.equals(terminal.getBusyState())) { - //把这个任务派给这个终端,并且把这个终端设置成繁忙 - if (!CollectionUtils.isEmpty(terminal.getPriorityCollectorIds()) && terminal.getPriorityCollectorIds().contains(reportTaskTwoDto.getCollectorId())) { - //把这个任务派给这个终端 - terminal.setBusyState(BusyStateEnum.BUSY); - iSchTerminatorService.saveOrUpdate(terminal.getTerminatorIp(), terminal); - - tcpToClient(terminal, report); - } - return; - } - } - } - - //只采集没有优先级 - for (NettyTerminatorDTO terminal : terminalList) { - //把刚才已经分配任务过的采集器排除 - if (BusyStateEnum.BUSY.equals(terminal.getBusyState())) { - continue; - } - - for (ReportDownTwoDTO report : reportDownTwoDTOList) { - //先找出有只采集的任务。 - ReportTaskTwoDTO reportTaskTwoDto = report.getTasks().get(0); - if (!CollectionUtils.isEmpty(terminal.getOnlyCollectorIds()) && terminal.getOnlyCollectorIds().contains(reportTaskTwoDto.getCollectorId()) - && BusyStateEnum.IDLE.equals(terminal.getBusyState())) { - //把这个任务派给这个终端,并且把这个终端设置成繁忙 - terminal.setBusyState(BusyStateEnum.BUSY); - iSchTerminatorService.saveOrUpdate(terminal.getTerminatorIp(), terminal); - - tcpToClient(terminal, report); - return; - } - } - } - - - //无只采集,有优先级 - for (NettyTerminatorDTO terminal : terminalList) { - - //把刚才已经分配任务过的采集器排除 - if (BusyStateEnum.BUSY.equals(terminal.getBusyState())) { - continue; - } - - for (ReportDownTwoDTO report : reportDownTwoDTOList) { - //先找出有只采集的任务。 - ReportTaskTwoDTO reportTaskTwoDto = report.getTasks().get(0); - if (!CollectionUtils.isEmpty(terminal.getPriorityCollectorIds()) && terminal.getPriorityCollectorIds().contains(reportTaskTwoDto.getCollectorId()) - && BusyStateEnum.IDLE.equals(terminal.getBusyState())) { - //把这个任务派给这个终端 - terminal.setBusyState(BusyStateEnum.BUSY); - iSchTerminatorService.saveOrUpdate(terminal.getTerminatorIp(), terminal); - - tcpToClient(terminal, report); - return; - } - } - } - - - //无只采集,无优先级 - for (NettyTerminatorDTO terminal : terminalList) { - - //把刚才已经分配任务过的采集器排除 - if (BusyStateEnum.BUSY.equals(terminal.getBusyState())) { - continue; - } - - for (ReportDownTwoDTO report : reportDownTwoDTOList) { - //先找出有只采集的任务。 - //把这个任务派给这个终端 - ReportTaskTwoDTO reportTaskTwoDto = report.getTasks().get(0); - terminal.setBusyState(BusyStateEnum.BUSY); - iSchTerminatorService.saveOrUpdate(terminal.getTerminatorIp(), terminal); - - tcpToClient(terminal, report); - return; - } - } - - //只采集,空闲的。 - //获取只采集的任务,并且进行分配。 - for (NettyTerminatorDTO terminal : terminalList) { - //把刚才已经分配任务过的采集器排除 - if (BusyStateEnum.BUSY.equals(terminal.getBusyState())) { - continue; - } - - List onlyTaskInfos = getOnlyTaskInfos(terminal.getOnlyCollectorIds()); - - - if (CollectionUtils.isEmpty(onlyTaskInfos) || Func.isBlank(onlyTaskInfos.get(0).getPatientId())) { - return; - } - - for (ReportDownTwoDTO report : onlyTaskInfos) { - //将这条任务分配这个这个终端 - //下发 - terminal.setBusyState(BusyStateEnum.BUSY); - iSchTerminatorService.saveOrUpdate(terminal.getTerminatorIp(), terminal); - - tcpToClient(terminal, report); - - return; - } - } - log.info("定时任务: 执行完毕"); - } catch ( - Exception e) { - log.error("定时任务执行出错", e); - } - - } - - private void tcpToClient(NettyTerminatorDTO terminal, ReportDownTwoDTO reportDownTwoDTO) { - Channel channel = channelRepository.get(terminal.getTerminatorIp()); - - Map params = reportDownTwoDTO.getParams(); - - SchCollectorTaskDTO messageContent = new SchCollectorTaskDTO(); - - if (CollectionUtils.isEmpty(params)) { - //不是重试任务 - SchCollectRecord schCollectRecord = iSchCollectRecordService.saveOrUpdateRecord(terminal, reportDownTwoDTO); - - messageContent.setCollectorRecordId(schCollectRecord.getId()); - messageContent.setIsRetry(String.valueOf(RetryTaskEnum.NO_RETRY_TASK.getValue())); - messageContent.setTaskInfo(reportDownTwoDTO); - } else { - //重试任务 - SchCollectRecordRetryLog schCollectRecordRetryLog = iSchCollectRecordRetryLogService.saveOrUpdateRecordRetryLog(terminal, reportDownTwoDTO); - - messageContent.setCollectorRecordId(schCollectRecordRetryLog.getId()); - messageContent.setIsRetry(String.valueOf(RetryTaskEnum.RETRY_TASK.getValue())); - messageContent.setTaskInfo(reportDownTwoDTO); - } - - CommMsg commMsg = CommMsg.builder() - .messageType(MsgConstants.SCH_DISTRIBUTE_TASKS) - .messageTime(DateUtil.formatDateTime(new Date())) - .content(JSON.toJSON(messageContent)) - .build(); - - //tcp 下发任务到终端 - if (channel != null) { - channel.writeAndFlush(Unpooled.copiedBuffer(JSON.toJSON(commMsg), CharsetUtil.UTF_8)); - } - - String isRetry = messageContent.getIsRetry(); - Long collectorRecordId = messageContent.getCollectorRecordId(); - String collectorId = messageContent.getTaskInfo().getTasks().get(0).getCollectorId(); - SchCollector schCollector = iSchCollectorService.findByCollectorId(collectorId); - - if (RetryTaskEnum.NO_RETRY_TASK.equals(isRetry)) { - redisOps.setEx(String.format("schCollectorRecord:noRetryTask:expireKey:%s", collectorRecordId), String.valueOf(collectorRecordId), schCollector.getTaskTimeout()); - } else { - redisOps.setEx(String.format("schCollectorRecord:isRetryTask:expireKey:%s", collectorRecordId), String.valueOf(collectorRecordId), schCollector.getTaskTimeout()); - } - - - } - - - public void addRetryTask(ReportDownTwoDTO reportDownTwoDTO) { - this.retryTaskQueue.add(reportDownTwoDTO); - } - - - //根据有效终端,一次获取一批任务,例如10个终端,获取10个不同类型任务 - public List getTask(int size) throws InterruptedException { -// return taskDistributeApi.getTask(String.valueOf(size)); - - //mock - - String collectorId1 = "{\n" + - " \"createTime\": \"2022-12-03 12:39:30\",\n" + - " \"hospitals\": [\n" + - " {\n" + - " \"admissDate\": \"2023-12-31 01:01:01\",\n" + - " \"admissId\": \"amid_999901\",\n" + - " \"admissTimes\": 1,\n" + - " \"disDate\": \"2023-12-31 01:01:01\",\n" + - " \"disDeptName\": \"22222\",\n" + - " \"patientId\": \"758878610105573376\"\n" + - " }\n" + - " ],\n" + - " \"jzh\": \"jzh_999901\",\n" + - " \"patient\": {\n" + - " \"inpatientNo\": \"999901\",\n" + - " \"name\": \"ceshi\",\n" + - " \"patientId\": \"758878610105573376\"\n" + - " },\n" + - " \"patientId\": \"758878610105573376\",\n" + - " \"recordType\": \"1\",\n" + - " \"tasks\": [\n" + - " {\n" + - " \"collectorId\": \"1\",\n" + - " \"patientId\": \"758878610105573376\",\n" + - " \"taskId\": 834292710565826560\n" + - " }\n" + - " ]\n" + - "}"; - ReportDownTwoDTO reportDownTwoDTO1 = JSON.fromJSON(collectorId1, ReportDownTwoDTO.class); - - - String collectorId2 = "{\n" + - " \"createTime\": \"2022-12-03 12:39:30\",\n" + - " \"hospitals\": [\n" + - " {\n" + - " \"admissDate\": \"2023-12-31 01:01:01\",\n" + - " \"admissId\": \"amid_999901\",\n" + - " \"admissTimes\": 1,\n" + - " \"disDate\": \"2023-12-31 01:01:01\",\n" + - " \"disDeptName\": \"22222\",\n" + - " \"patientId\": \"758878610105573376\"\n" + - " }\n" + - " ],\n" + - " \"jzh\": \"jzh_999901\",\n" + - " \"patient\": {\n" + - " \"inpatientNo\": \"999901\",\n" + - " \"name\": \"ceshi\",\n" + - " \"patientId\": \"758878610105573376\"\n" + - " },\n" + - " \"patientId\": \"758878610105573376\",\n" + - " \"recordType\": \"1\",\n" + - " \"tasks\": [\n" + - " {\n" + - " \"collectorId\": \"2\",\n" + - " \"patientId\": \"758878610105573376\",\n" + - " \"taskId\": 834292712465846272\n" + - " }\n" + - " ]\n" + - "}"; - ReportDownTwoDTO reportDownTwoDTO2 = JSON.fromJSON(collectorId2, ReportDownTwoDTO.class); - - - String collectorId3 = "{\n" + - " \"createTime\": \"2023-01-09 19:26:11\",\n" + - " \"hospitals\": [\n" + - " {\n" + - " \"admissDate\": \"2023-12-31 01:01:01\",\n" + - " \"admissId\": \"amid_297974\",\n" + - " \"admissTimes\": 21,\n" + - " \"disDate\": \"2023-12-31 01:01:01\",\n" + - " \"disDeptName\": \"普外二科(甲乳胸烧伤整形)\",\n" + - " \"patientId\": \"772389719349678080\"\n" + - " }\n" + - " ],\n" + - " \"jzh\": \"jzh_297974\",\n" + - " \"patient\": {\n" + - " \"inpatientNo\": \"297974\",\n" + - " \"name\": \"曾美英\",\n" + - " \"patientId\": \"772389719349678080\"\n" + - " },\n" + - " \"patientId\": \"772389719349678080\",\n" + - " \"recordType\": \"1\",\n" + - " \"tasks\": [\n" + - " {\n" + - " \"collectorId\": \"3\",\n" + - " \"patientId\": \"772389719349678080\",\n" + - " \"taskId\": 838201379426750464\n" + - " }\n" + - " ]\n" + - "}"; - ReportDownTwoDTO reportDownTwoDTO3 = JSON.fromJSON(collectorId3, ReportDownTwoDTO.class); - -// List allTaskList = Lists.newArrayList(reportDownTwoDTO1, reportDownTwoDTO2, reportDownTwoDTO3); - List allTaskList = new ArrayList<>(); - - if (!CollectionUtils.isEmpty(this.retryTaskQueue)) { - ReportDownTwoDTO retryTask = (ReportDownTwoDTO) this.retryTaskQueue.take(); - //重试任务 - allTaskList.add(retryTask); - } - - return allTaskList; - - } - - //根据采集器id类型,一次获取一批采集器类型任务 - private List getOnlyTaskInfos(List collectorIds) { -// return taskDistributeApi.getTask(collectorIds.get(0)); - - //mock - - - String collectorId2 = "{\n" + - " \"createTime\": \"2022-12-03 12:39:30\",\n" + - " \"hospitals\": [\n" + - " {\n" + - " \"admissDate\": \"2023-12-31 01:01:01\",\n" + - " \"admissId\": \"amid_999901\",\n" + - " \"admissTimes\": 1,\n" + - " \"disDate\": \"2023-12-31 01:01:01\",\n" + - " \"disDeptName\": \"22222\",\n" + - " \"patientId\": \"758878610105573376\"\n" + - " }\n" + - " ],\n" + - " \"jzh\": \"jzh_999901\",\n" + - " \"patient\": {\n" + - " \"inpatientNo\": \"999901\",\n" + - " \"name\": \"ceshi\",\n" + - " \"patientId\": \"758878610105573376\"\n" + - " },\n" + - " \"patientId\": \"758878610105573376\",\n" + - " \"recordType\": \"1\",\n" + - " \"tasks\": [\n" + - " {\n" + - " \"collectorId\": \"2\",\n" + - " \"patientId\": \"758878610105573376\",\n" + - " \"taskId\": 834292712465846272\n" + - " }\n" + - " ]\n" + - "}"; - ReportDownTwoDTO reportDownTwoDTO2 = JSON.fromJSON(collectorId2, ReportDownTwoDTO.class); - - - String collectorId3 = "{\n" + - " \"createTime\": \"2022-12-03 12:39:30\",\n" + - " \"hospitals\": [\n" + - " {\n" + - " \"admissDate\": \"2023-12-31 01:01:01\",\n" + - " \"admissId\": \"amid_999901\",\n" + - " \"admissTimes\": 1,\n" + - " \"disDate\": \"2023-12-31 01:01:01\",\n" + - " \"disDeptName\": \"22222\",\n" + - " \"patientId\": \"758878610105573376\"\n" + - " }\n" + - " ],\n" + - " \"jzh\": \"jzh_999901\",\n" + - " \"patient\": {\n" + - " \"inpatientNo\": \"999901\",\n" + - " \"name\": \"ceshi\",\n" + - " \"patientId\": \"758878610105573376\"\n" + - " },\n" + - " \"patientId\": \"758878610105573376\",\n" + - " \"recordType\": \"1\",\n" + - " \"tasks\": [\n" + - " {\n" + - " \"collectorId\": \"3\",\n" + - " \"patientId\": \"758878610105573376\",\n" + - " \"taskId\": 834292883635392512\n" + - " }\n" + - " ]\n" + - "}"; - ReportDownTwoDTO reportDownTwoDTO3 = JSON.fromJSON(collectorId3, ReportDownTwoDTO.class); - - return Lists.newArrayList(reportDownTwoDTO2, reportDownTwoDTO3); - } -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/TerminatorListener.java b/collector-terminal-management/src/main/java/com/docus/server/common/TerminatorListener.java deleted file mode 100644 index 14dda2f..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/common/TerminatorListener.java +++ /dev/null @@ -1,31 +0,0 @@ -package com.docus.server.common; - -import com.docus.server.entity.scheduling.management.SchTerminator; -import com.docus.server.enums.BusyStateEnum; -import com.docus.server.enums.OnlineStateEnum; -import com.docus.server.service.ISchTerminatorService; -import org.springframework.context.ApplicationListener; -import org.springframework.context.event.ContextRefreshedEvent; -import org.springframework.stereotype.Component; - -import javax.annotation.Resource; -import java.util.List; - -/** - * 重启置空 - */ -@Component -public class TerminatorListener implements ApplicationListener { - @Resource - private ISchTerminatorService iSchTerminatorService; - - @Override - public void onApplicationEvent(ContextRefreshedEvent event) { - List terminators = iSchTerminatorService.findAll(); - terminators.forEach(p -> { - p.setBusyState(BusyStateEnum.IDLE); - p.setOnlineState(OnlineStateEnum.OFFLINE); - }); - iSchTerminatorService.batchUpdate(terminators); - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/netty/ChannelAttribute.java b/collector-terminal-management/src/main/java/com/docus/server/common/netty/ChannelAttribute.java new file mode 100644 index 0000000..5d3f659 --- /dev/null +++ b/collector-terminal-management/src/main/java/com/docus/server/common/netty/ChannelAttribute.java @@ -0,0 +1,51 @@ +package com.docus.server.common.netty; + +import io.netty.channel.ChannelHandlerContext; +import io.netty.util.Attribute; +import io.netty.util.AttributeKey; + +public class ChannelAttribute { + + /** + * 属性键名称 + */ + private AttributeKey attributeKey; + + public ChannelAttribute(String key) { + this.attributeKey = AttributeKey.valueOf(key); + } + + /** + * 设置属性 + * + * @param ctx 通道上下文 + * @param value 值 + */ + public void setAttribute(ChannelHandlerContext ctx, T value) { + Attribute attribute = getAttribute(ctx); + attribute.set(value); + } + + /** + * 获取属性值 + * + * @param ctx 通道上下文 + * @return 属性值 有可能为 null + */ + public T getAttributeValue(ChannelHandlerContext ctx) { + Attribute attribute = getAttribute(ctx); + T value = attribute.get(); + return value; + } + + /** + * 永远不会返回 null + * + * @param ctx channel 上下 + * @return ctx 关联的 channle 的 attribute + */ + private Attribute getAttribute(ChannelHandlerContext ctx) { + return ctx.channel().attr(attributeKey); + } + +} diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/ChannelRepository.java b/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/ChannelRepository.java index 9a8a58c..e496ca6 100644 --- a/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/ChannelRepository.java +++ b/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/ChannelRepository.java @@ -1,22 +1,12 @@ package com.docus.server.common.netty.server; -import com.docus.server.dto.scheduling.management.schterminator.NettyTerminatorDTO; -import com.docus.server.enums.BusyStateEnum; -import com.docus.server.enums.OnlineStateEnum; -import com.docus.server.service.ISchTerminatorService; -import com.docus.server.vo.scheduling.management.schterminator.SchTerminatorVO; import io.netty.channel.Channel; import io.netty.util.AttributeKey; import lombok.extern.slf4j.Slf4j; import org.springframework.stereotype.Component; -import org.springframework.util.CollectionUtils; -import javax.annotation.Resource; -import java.util.Collections; -import java.util.List; import java.util.Map; import java.util.concurrent.ConcurrentHashMap; -import java.util.stream.Collectors; /** * 客户端IP和通信信道的映射 @@ -24,37 +14,22 @@ import java.util.stream.Collectors; @Component @Slf4j public class ChannelRepository { - @Resource - private ISchTerminatorService iSchTerminatorService; /** - * + * */ - private final static Map IP_CHANNEL_CACHE_MAP = new ConcurrentHashMap<>(); - - /** - * - */ - private final static Map IP_TERMINATOR_CACHE_MAP = new ConcurrentHashMap<>(); + private final static Map COLLECTOR_ID_CHANNEL_CACHE_MAP = new ConcurrentHashMap<>(); /** * 终端上线 */ - public void put(NettyTerminatorDTO nettyTerminatorDTO, Channel channel) { - //客户端上线 - String terminatorIp = nettyTerminatorDTO.getTerminatorIp(); - - //更新数据库终端数据 - SchTerminatorVO schTerminatorVO = iSchTerminatorService.saveOrUpdate(terminatorIp, nettyTerminatorDTO); - nettyTerminatorDTO.setId(schTerminatorVO.getId()); + public void put(String collectorId, Channel channel) { //缓存 - IP_CHANNEL_CACHE_MAP.put(terminatorIp, channel); - IP_TERMINATOR_CACHE_MAP.put(terminatorIp, nettyTerminatorDTO); + COLLECTOR_ID_CHANNEL_CACHE_MAP.put(collectorId, channel); AttributeKey attributeKey = AttributeKey.valueOf("ip"); - channel.attr(attributeKey).set(terminatorIp); - + channel.attr(attributeKey).set(collectorId); } @@ -69,38 +44,14 @@ public class ChannelRepository { } public Channel get(String key) { - return IP_CHANNEL_CACHE_MAP.get(key); - } - - public NettyTerminatorDTO getTerminatorByIp(String key) { - return IP_TERMINATOR_CACHE_MAP.get(key); - } - - public Map getIpToChannelCacheMap() { - return IP_CHANNEL_CACHE_MAP; - } - - public Map getIpToTerminatorCacheMap() { - return IP_TERMINATOR_CACHE_MAP; - } - - public List getAvailTerminator() { - if (!CollectionUtils.isEmpty(IP_TERMINATOR_CACHE_MAP)) { - return IP_TERMINATOR_CACHE_MAP.values().stream().filter(p -> OnlineStateEnum.ONLINE.equals(p.getOnlineState()) - && BusyStateEnum.IDLE.equals(p.getBusyState())).collect(Collectors.toList()); - } - return Collections.emptyList(); + return COLLECTOR_ID_CHANNEL_CACHE_MAP.get(key); } /** * 终端离线 */ public void remove(String key) { - IP_CHANNEL_CACHE_MAP.remove(key); - - NettyTerminatorDTO nettyTerminatorDTO = new NettyTerminatorDTO(); - nettyTerminatorDTO.setOnlineState(OnlineStateEnum.OFFLINE); - iSchTerminatorService.saveOrUpdate(key, nettyTerminatorDTO); + COLLECTOR_ID_CHANNEL_CACHE_MAP.remove(key); } } diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/NettyServerInitializer.java b/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/NettyServerInitializer.java index 04f4600..2ea873c 100644 --- a/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/NettyServerInitializer.java +++ b/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/NettyServerInitializer.java @@ -1,7 +1,6 @@ package com.docus.server.common.netty.server; import com.docus.server.common.netty.server.handler.NettyBusinessHandler; -import com.docus.server.common.netty.server.handler.NettyHeartbeatHandler; import io.netty.channel.Channel; import io.netty.channel.ChannelInitializer; import io.netty.handler.timeout.IdleStateHandler; @@ -45,7 +44,7 @@ public class NettyServerInitializer extends ChannelInitializer { // .addLast(new StringEncoder()) // 加载业务处理器 - .addLast(new NettyHeartbeatHandler(channelRepository)) +// .addLast(new NettyHeartbeatHandler(channelRepository)) .addLast(businessHandler); // .addLast(new EchoServerHandler()); } diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/handler/NettyBusinessHandler.java b/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/handler/NettyBusinessHandler.java index 9770f10..35777fb 100644 --- a/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/handler/NettyBusinessHandler.java +++ b/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/handler/NettyBusinessHandler.java @@ -1,28 +1,32 @@ package com.docus.server.common.netty.server.handler; +import com.docus.core.util.DateUtil; import com.docus.core.util.Func; import com.docus.core.util.StringUtils; import com.docus.core.util.json.JSON; import com.docus.server.common.MsgConstants; +import com.docus.server.common.netty.ChannelAttribute; import com.docus.server.common.netty.CommMsg; import com.docus.server.common.netty.server.ChannelRepository; -import com.docus.server.dto.scheduling.management.schterminator.NettyTerminatorDTO; -import com.docus.server.enums.BusyStateEnum; -import com.docus.server.enums.OnlineStateEnum; -import com.fasterxml.jackson.core.type.TypeReference; +import com.docus.server.common.netty.state.DeviceStateContext; import io.netty.buffer.ByteBuf; +import io.netty.buffer.Unpooled; import io.netty.channel.Channel; import io.netty.channel.ChannelHandler; import io.netty.channel.ChannelHandlerContext; import io.netty.channel.SimpleChannelInboundHandler; import io.netty.channel.group.ChannelGroup; import io.netty.channel.group.DefaultChannelGroup; +import io.netty.handler.timeout.IdleStateEvent; +import io.netty.util.CharsetUtil; import io.netty.util.concurrent.GlobalEventExecutor; import lombok.extern.slf4j.Slf4j; import org.springframework.stereotype.Component; import javax.annotation.Resource; +import java.io.Serializable; import java.net.InetSocketAddress; +import java.util.Date; /** * 业务消息处理 @@ -34,11 +38,15 @@ public class NettyBusinessHandler extends SimpleChannelInboundHandler { private static final ChannelGroup DEFAULT_CHANNEL_GROUP = new DefaultChannelGroup(GlobalEventExecutor.INSTANCE); + public static final ChannelAttribute session = new ChannelAttribute<>("state"); + @Resource private ChannelRepository repository; @Override - protected void channelRead0(ChannelHandlerContext channelHandlerContext, ByteBuf msg) throws Exception { + protected void channelRead0(ChannelHandlerContext ctx, ByteBuf msg) throws Exception { + DeviceStateContext deviceStateContext = session.getAttributeValue(ctx); + ByteBuf buf = (ByteBuf) msg; //创建目标大小的数组 byte[] barray = new byte[buf.readableBytes()]; @@ -52,35 +60,91 @@ public class NettyBusinessHandler extends SimpleChannelInboundHandler { return; } - CommMsg commMsg = JSON.fromJSONWithGeneric(message, new TypeReference>() { - }); + CommMsg commMsg = JSON.fromJSON(message, CommMsg.class); String messageType = commMsg.getMessageType(); String messageTime = commMsg.getMessageTime(); - TerminatorContent messageContent = commMsg.getContent(); + Serializable messageContent = commMsg.getContent(); + + if (messageType.equals(MsgConstants.ONLINE_REGISTER)) { + //===========login ok,切换到已登录状态=============== + deviceStateContext.onLoginSucc("device-123", System.currentTimeMillis(), 10, "设备认证通过"); + + CommMsg login_ok = CommMsg.builder() + .messageTime(DateUtil.formatDateTime(new Date())) + .content("login ok") + .messageType("response") + .build(); + ctx.writeAndFlush(Unpooled.copiedBuffer(JSON.toJSON(login_ok), CharsetUtil.UTF_8)); + + } else if (messageType.equals(MsgConstants.HEARTBEAT_REQUEST)) { + + //============状态为上行数据============= + deviceStateContext.onHeartbeat(System.currentTimeMillis(), "设备上行了数据"); + //==============处理数据================ + System.out.println("收到数据:" + msg); + + //============返回消息================== + CommMsg resp = CommMsg.builder() + .messageTime(DateUtil.formatDateTime(new Date())) + .content("HEARTBEAT_REQUEST ok") + .messageType("response HEARTBEAT_REQUEST") + .build(); + ctx.writeAndFlush(Unpooled.copiedBuffer(JSON.toJSON(resp), CharsetUtil.UTF_8)); + + + log.info("接受到【终端-采集器】客户端的心跳消息:消息类型={},消息时间={},消息内容={}", messageType, messageTime, messageContent); + + InetSocketAddress ipSocket = (InetSocketAddress) ctx.channel().remoteAddress(); + String clientIp = ipSocket.getAddress().getHostAddress(); - if (messageType.equals(MsgConstants.TERMINATOR_RESTART)) { + log.info("【终端-采集器IP】:{},连接上线,IP地址信息:{}", clientIp, clientIp); + + + } else if (messageType.equals(MsgConstants.TERMINATOR_RESTART)) { log.info("接受到终端重启命令,内容{}", messageContent); - } - if (messageType.equals(MsgConstants.COLLECTOR_RESTART)) { + } else if (messageType.equals(MsgConstants.COLLECTOR_RESTART)) { log.info("收到采集器重启命令,内容{}", messageContent); - } - if (messageType.equals(MsgConstants.VIRTUAL_RESTART)) { + } else if (messageType.equals(MsgConstants.VIRTUAL_RESTART)) { log.info("收到虚拟机重启命令,内容{}", messageContent); - } - if (messageType.equals(MsgConstants.UPDATE_COLLECTOR_FILE)) { + } else if (messageType.equals(MsgConstants.UPDATE_COLLECTOR_FILE)) { log.info("收到更新采集器文件命令,内容{}", messageContent); - } - if (messageType.equals(MsgConstants.UPDATE_COLLECTOR_CONFIG)) { + } else if (messageType.equals(MsgConstants.UPDATE_COLLECTOR_CONFIG)) { log.info("收到更新采集器配置命令,内容{}", messageContent); - } - if (messageType.equals(MsgConstants.SCH_DISTRIBUTE_TASKS)) { + } else if (messageType.equals(MsgConstants.SCH_DISTRIBUTE_TASKS)) { log.info("收到采集调度器下发任务命令,内容{}", messageContent); + + } + + + System.out.println("channelRead0:" + deviceStateContext.toString()); + } + + /** + * 空闲一段时间,就进行检查 (当前时间-上次上行数据的时间) 如果大于设定的超时时间 设备状态就就行一次 onTimeout + */ + @Override + public void userEventTriggered(ChannelHandlerContext ctx, Object evt) throws Exception { + System.out.println(getClass().getSimpleName() + "." + "userEventTriggered" + ctx.channel().remoteAddress()); + if (evt instanceof IdleStateEvent) { + DeviceStateContext deviceStateContext = session.getAttributeValue(ctx); + long lastUpdateTime = deviceStateContext.getLastUpdateTime(); + long currentTimeMillis = System.currentTimeMillis(); + long intervalTime = currentTimeMillis - lastUpdateTime; + + if (intervalTime > deviceStateContext.getHeartRate()) { + //==============发生超时,进入超时状态============== + deviceStateContext.onTimeout("设备发生超时"); + System.out.println("userEventTriggered:" + deviceStateContext.toString()); + } + } else { + //不是超时事件,进行传递 + super.userEventTriggered(ctx, evt); } } @@ -91,20 +155,22 @@ public class NettyBusinessHandler extends SimpleChannelInboundHandler { public void channelActive(ChannelHandlerContext ctx) throws Exception { ctx.fireChannelRegistered(); + //链接成功 + DeviceStateContext deviceStateContext = new DeviceStateContext(ctx.channel(), true); + //===========设置设备状态为 未登录================= + deviceStateContext.onConnect(System.currentTimeMillis(), "设备 active"); + //更新添加 state 属性 + session.setAttribute(ctx, deviceStateContext); + System.out.println("channelActive:" + deviceStateContext.toString()); + + //===========设置设备状态为 未登录================= InetSocketAddress ipSocket = (InetSocketAddress) ctx.channel().remoteAddress(); String clientIp = ipSocket.getAddress().getHostAddress(); - log.info("【采集器-终端IP】:{},连接上线,IP地址信息:{}", clientIp, clientIp); - - String clientId = repository.getClientKey(ctx.channel()); - - if (Func.isBlank(clientId)) { + log.info("【终端-采集器IP】:{},连接上线,IP地址信息:{}", clientIp, clientIp); - NettyTerminatorDTO nettyTerminatorDTO = new NettyTerminatorDTO(); - nettyTerminatorDTO.setTerminatorIp(clientIp); - nettyTerminatorDTO.setBusyState(BusyStateEnum.IDLE); - nettyTerminatorDTO.setOnlineState(OnlineStateEnum.OFFLINE); + if (Func.isNotBlank(clientIp)) { - repository.put(nettyTerminatorDTO, ctx.channel()); + repository.put(clientIp, ctx.channel()); } DEFAULT_CHANNEL_GROUP.add(ctx.channel()); @@ -125,6 +191,11 @@ public class NettyBusinessHandler extends SimpleChannelInboundHandler { if (clientId != null) { repository.remove(clientId); } + + //================设置为断开================ + DeviceStateContext deviceStateContext = session.getAttributeValue(ctx); + deviceStateContext.onDisconnect("设备 inactive"); + System.out.println("channelInactive:" + deviceStateContext.toString()); } /** @@ -132,12 +203,23 @@ public class NettyBusinessHandler extends SimpleChannelInboundHandler { */ @Override public void exceptionCaught(ChannelHandlerContext ctx, Throwable cause) throws Exception { + //==============发生异常切换到断开模式=============== + System.out.println("exceptionCaught:" + cause.getMessage()); + DeviceStateContext deviceStateContext = session.getAttributeValue(ctx); + deviceStateContext.onDisconnect(cause.getMessage()); + System.out.println("exceptionCaught:" + deviceStateContext.toString()); + + cause.printStackTrace(); - Channel channel = ctx.channel(); - if (channel.isActive()) { + String clientId = repository.getClientKey(ctx.channel()); + log.error("通道发生异常,终端连接:{}", clientId); + //移除终端,终端离线 + if (clientId != null) { + repository.remove(clientId); + } + if (ctx.channel().isActive()) { ctx.close(); } - super.exceptionCaught(ctx, cause); } diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/handler/NettyHeartbeatHandler.java b/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/handler/NettyHeartbeatHandler.java index 6bac1c7..3cb249d 100644 --- a/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/handler/NettyHeartbeatHandler.java +++ b/collector-terminal-management/src/main/java/com/docus/server/common/netty/server/handler/NettyHeartbeatHandler.java @@ -1,104 +1,97 @@ -package com.docus.server.common.netty.server.handler; - -import com.docus.core.util.Func; -import com.docus.core.util.StringUtils; -import com.docus.core.util.json.JSON; -import com.docus.server.common.MsgConstants; -import com.docus.server.common.netty.CommMsg; -import com.docus.server.common.netty.server.ChannelRepository; -import com.docus.server.dto.scheduling.management.schterminator.NettyTerminatorDTO; -import com.docus.server.enums.BusyStateEnum; -import com.docus.server.enums.OnlineStateEnum; -import com.fasterxml.jackson.core.type.TypeReference; -import io.netty.buffer.ByteBuf; -import io.netty.channel.ChannelHandler; -import io.netty.channel.ChannelHandlerContext; -import io.netty.channel.ChannelInboundHandlerAdapter; -import lombok.extern.slf4j.Slf4j; - -import java.net.InetSocketAddress; - -/** - * 客户端和服务端心跳 - */ -@Slf4j -@ChannelHandler.Sharable -public class NettyHeartbeatHandler extends ChannelInboundHandlerAdapter { - - @Override - public void channelRead(ChannelHandlerContext ctx, Object msg) throws Exception { - ByteBuf buf = (ByteBuf) msg; - //创建目标大小的数组 - byte[] barray = new byte[buf.readableBytes()]; - //把数据从bytebuf转移到byte[] - buf.getBytes(0, barray); - //将byte[]转成字符串用于打印 - String message = new String(barray); - //空消息不处理 - if (!StringUtils.hasText(message)) { - return; - } - - CommMsg commMsg = JSON.fromJSONWithGeneric(message, new TypeReference>() { - }); - - String messageType = commMsg.getMessageType(); - String messageTime = commMsg.getMessageTime(); - TerminatorContent messageContent = commMsg.getContent(); - - if (messageType.equals(MsgConstants.HEARTBEAT_REQUEST)) { - - log.info("接收到客户端的心跳"); - - - log.info("接受到【采集器-终端】的心跳消息:消息类型={},消息时间={},消息内容={}", messageType, messageTime, messageContent); - - InetSocketAddress ipSocket = (InetSocketAddress) ctx.channel().remoteAddress(); - String clientIp = ipSocket.getAddress().getHostAddress(); - - log.info("【采集器-终端IP】:{},连接上线,IP地址信息:{}", clientIp, clientIp); - - String clientKey = repository.getClientKey(ctx.channel()); - - if (Func.isNotBlank(clientKey)) { - - NettyTerminatorDTO nettyTerminatorDTO = new NettyTerminatorDTO(); - nettyTerminatorDTO.setTerminatorIp(clientIp); - nettyTerminatorDTO.setBusyState(BusyStateEnum.IDLE); - nettyTerminatorDTO.setOnlineState(OnlineStateEnum.ONLINE); - - //将ip和channel进行映射 - repository.put(nettyTerminatorDTO, ctx.channel()); - } - - } else { - - if (ctx.channel().isOpen()) { - //触发下一个handler - ctx.fireChannelRead(msg); - } - } - - } - - private ChannelRepository repository; - - public NettyHeartbeatHandler(ChannelRepository repository) { - this.repository = repository; - } - - @Override - public void exceptionCaught(ChannelHandlerContext ctx, Throwable cause) throws Exception { - cause.printStackTrace(); - String clientId = repository.getClientKey(ctx.channel()); - log.error("通道发生异常,终端连接:{}", clientId); - //移除终端,终端离线 - if (clientId != null) { - repository.remove(clientId); - } - if (ctx.channel().isActive()) { - ctx.close(); - } - super.exceptionCaught(ctx, cause); - } -} +//package com.docus.server.common.netty.server.handler; +// +//import com.docus.core.util.Func; +//import com.docus.core.util.StringUtils; +//import com.docus.core.util.json.JSON; +//import com.docus.server.common.MsgConstants; +//import com.docus.server.common.netty.CommMsg; +//import com.docus.server.common.netty.server.ChannelRepository; +//import io.netty.buffer.ByteBuf; +//import io.netty.channel.ChannelHandler; +//import io.netty.channel.ChannelHandlerContext; +//import io.netty.channel.ChannelInboundHandlerAdapter; +//import lombok.extern.slf4j.Slf4j; +// +//import java.io.Serializable; +//import java.net.InetSocketAddress; +// +///** +// * 客户端和服务端心跳 +// */ +//@Slf4j +//@ChannelHandler.Sharable +//public class NettyHeartbeatHandler extends ChannelInboundHandlerAdapter { +// +// @Override +// public void channelRead(ChannelHandlerContext ctx, Object msg) throws Exception { +// ByteBuf buf = (ByteBuf) msg; +// //创建目标大小的数组 +// byte[] barray = new byte[buf.readableBytes()]; +// //把数据从bytebuf转移到byte[] +// buf.getBytes(0, barray); +// //将byte[]转成字符串用于打印 +// String message = new String(barray); +// //空消息不处理 +// if (!StringUtils.hasText(message)) { +// return; +// } +// +// CommMsg commMsg = JSON.fromJSON(message, CommMsg.class); +// +// String messageType = commMsg.getMessageType(); +// String messageTime = commMsg.getMessageTime(); +// Serializable messageContent = commMsg.getContent(); +// +// if (messageType.equals(MsgConstants.HEARTBEAT_REQUEST)) { +// +// log.info("接收到客户端的心跳"); +// +// +// log.info("接受到【采集器-终端】的心跳消息:消息类型={},消息时间={},消息内容={}", messageType, messageTime, messageContent); +// +// InetSocketAddress ipSocket = (InetSocketAddress) ctx.channel().remoteAddress(); +// String clientIp = ipSocket.getAddress().getHostAddress(); +// +// log.info("【采集器-终端IP】:{},连接上线,IP地址信息:{}", clientIp, clientIp); +// +// String clientKey = repository.getClientKey(ctx.channel()); +// +// if (Func.isNotBlank(clientKey)) { +// +// //将ip和channel进行映射 +// repository.put(clientKey, ctx.channel()); +// } +// +// } else { +// +// if (ctx.channel().isOpen()) { +// //触发下一个handler +// ctx.fireChannelRead(msg); +// } +// } +// +// } +// +// private ChannelRepository repository; +// +// public NettyHeartbeatHandler(ChannelRepository repository) { +// this.repository = repository; +// } +// +// +// +// @Override +// public void exceptionCaught(ChannelHandlerContext ctx, Throwable cause) throws Exception { +// cause.printStackTrace(); +// String clientId = repository.getClientKey(ctx.channel()); +// log.error("通道发生异常,终端连接:{}", clientId); +// //移除终端,终端离线 +// if (clientId != null) { +// repository.remove(clientId); +// } +// if (ctx.channel().isActive()) { +// ctx.close(); +// } +// super.exceptionCaught(ctx, cause); +// } +//} diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/AbstractState.java b/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/AbstractState.java new file mode 100644 index 0000000..3fc665f --- /dev/null +++ b/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/AbstractState.java @@ -0,0 +1,44 @@ +package com.docus.server.common.netty.state; + +/** + * describe:所有状态类的基类 + */ +public abstract class AbstractState implements IDeviceState { + protected DeviceStateContext stateCtx; + + public AbstractState(DeviceStateContext stateCtx) { + this.stateCtx = stateCtx; + } + + + @Override + public void onConnect(long connectedTime, String describe) { + throw new IllegalStateException(getStateName() + " 此状态不应该进行链接动作"); + } + + @Override + public void onDisconnect(String describe) { + throw new IllegalStateException(getStateName() + " 此状态不应该进行断开链接动作"); + } + + @Override + public void onLoginSucc(String deviceId, long lastUpdateTime, long heartRate, String describe) { + throw new IllegalStateException(getStateName() + " 此状态不应该进行登录动作"); + } + + @Override + public void onLoginFailed(String describe) { + throw new IllegalStateException(getStateName() + " 此状态不应该进行登录失败动作"); + } + + @Override + public void onHeartbeat(long lastUpdateTime, String describe) { + throw new IllegalStateException(getStateName() + " 此状态不应该进行心跳动作"); + } + + @Override + public void onTimeout(String describe) { + throw new IllegalStateException(getStateName() + " 此状态不应该进行进入超时动作"); + } + +} \ No newline at end of file diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/DeviceStateContext.java b/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/DeviceStateContext.java new file mode 100644 index 0000000..e4204cf --- /dev/null +++ b/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/DeviceStateContext.java @@ -0,0 +1,239 @@ +package com.docus.server.common.netty.state; + +import io.netty.channel.Channel; + +import java.util.ArrayList; +import java.util.List; +import java.util.concurrent.locks.ReentrantReadWriteLock; + +/** + * describe:设备状态切换类 + */ +public class DeviceStateContext implements IDeviceState { + /** + * 是否开启记录所有的状态转变 + */ + boolean history; + + /** + * 记录状态转换的历史 + */ + private static class HistoryInfoDTO { + private String describe; + private String state; + + public HistoryInfoDTO(String describe, String state) { + this.describe = describe; + this.state = state; + } + + @Override + public String toString() { + return "HistoryInfoDTO{" + + "describe='" + describe + '\'' + + ", state='" + state + '\'' + + '}'; + } + } + + List historyState = new ArrayList<>(); + /** + * 防止竞争的读写锁 + */ + ReentrantReadWriteLock lock = new ReentrantReadWriteLock(); + + + /** + * 设备的上下文信息 + */ + private Channel channel; + + /** + * 设备的 deviceId + */ + private String deviceId; + + /** + * 链接时间 + */ + + private long connectTime; + + /** + * 设备的上次更新时间 + */ + private long lastUpdateTime; + + /** + * 心跳周期 单位 s + */ + private long heartRate; + + /** + * 设备当前状态 + */ + private IDeviceState state; + + /** + * @param channel 管理的 channel 信息 + */ + public DeviceStateContext(Channel channel) { + this.channel = channel; + setState(new NoConnectedState(this), "初始化"); + } + + /** + * @param channel 管理的 channel 信息 + * @param history true 开始记录历史状态 + */ + public DeviceStateContext(Channel channel, boolean history) { + this.history = history; + this.channel = channel; + setState(new NoConnectedState(this), "初始化"); + } + + ///////////////////////////get/set//////////////////////// + + public Channel getChannel() { + return channel; + } + + public void setChannel(Channel channel) { + this.channel = channel; + } + + public String getDeviceId() { + return deviceId; + } + + public void setDeviceId(String deviceId) { + this.deviceId = deviceId; + } + + public long getConnectTime() { + return connectTime; + } + + public void setConnectTime(long connectTime) { + this.connectTime = connectTime; + } + + public long getLastUpdateTime() { + return lastUpdateTime; + } + + public void setLastUpdateTime(long lastUpdateTime) { + this.lastUpdateTime = lastUpdateTime; + } + + public long getHeartRate() { + return heartRate; + } + + public void setHeartRate(long heartRate) { + this.heartRate = heartRate; + } + + public IDeviceState getState() { + return state; + } + + public void setState(IDeviceState state, String describe) { + this.state = state; + //把每次切换的状态加入到历史状态中 + historyState.add(new HistoryInfoDTO(describe, state.getStateName())); + } + + + ///////////////////////////状态切换//////////////////////// + + + @Override + public void onConnect(long connectTime, String describe) { + lock.writeLock().lock(); + try { + state.onConnect(connectTime, describe); + } finally { + lock.writeLock().unlock(); + } + } + + @Override + public void onDisconnect(String describe) { + lock.writeLock().lock(); + try { + state.onDisconnect(describe); + } finally { + lock.writeLock().unlock(); + } + } + + @Override + public void onLoginSucc(String deviceId, long lastUpdateTime, long heartRate, String describe) throws IllegalStateException { + lock.writeLock().lock(); + try { + state.onLoginSucc(deviceId, lastUpdateTime, heartRate, describe); + } finally { + lock.writeLock().unlock(); + } + } + + @Override + public void onLoginFailed(String describe) { + lock.writeLock().lock(); + try { + state.onLoginFailed(describe); + } finally { + lock.writeLock().unlock(); + } + } + + @Override + public void onHeartbeat(long lastUpdateTime, String describe) { + lock.writeLock().lock(); + try { + state.onHeartbeat(lastUpdateTime, describe); + } finally { + lock.writeLock().unlock(); + } + } + + + @Override + public void onTimeout(String describe) { + lock.writeLock().lock(); + try { + state.onTimeout(describe); + } finally { + lock.writeLock().unlock(); + } + } + + @Override + public String getStateName() { + return null; + } + + /** + * 关闭链接 + */ + protected void closeChannle(String describe) { + setState(new NoConnectedState(this), describe); + //关闭此 channel + this.channel.close(); + } + + + @Override + public String toString() { + return "DeviceStateContext{" + + " state=" + state.getStateName() + + ", channel=" + channel + + ", deviceId='" + deviceId + '\'' + + ", connectTime=" + connectTime + + ", lastUpdateTime=" + lastUpdateTime + + ", lock=" + lock + + ", \nhistory=" + historyState + + '}'; + } +} \ No newline at end of file diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/IDeviceState.java b/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/IDeviceState.java new file mode 100644 index 0000000..dc6cc1a --- /dev/null +++ b/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/IDeviceState.java @@ -0,0 +1,58 @@ +package com.docus.server.common.netty.state; + +/** + * describe:设备各种状态下的行为总和 + */ +public interface IDeviceState { + /** + * 设备新建立链接 + * + * @param connectedTime 建立链接的时间 + * @param describe 描述在什么时候进行的此动作 + */ + void onConnect(long connectedTime, String describe); + + /** + * 断开链接 + * + * @param describe 描述在什么时候进行的此动作 + */ + void onDisconnect(String describe); + + /** + * 登录动作 + * + * @param deviceId 设备 id + * @param lastUpdateTime 设备上行数据的时间 + * @param heartRate + * @param describe 描述在什么时候进行的此动作 + */ + void onLoginSucc(String deviceId, long lastUpdateTime, long heartRate, String describe); + + /** + * 登录失败 + * + * @param describe 描述在什么时候进行的此动作 + */ + void onLoginFailed(String describe); + + /** + * 只要有数据上报,都属于心跳 + * + * @param lastUpdateTime 最新更新时间 + * @param describe 描述在什么时候进行的此动作 + */ + void onHeartbeat(long lastUpdateTime, String describe); + + /** + * 进入超时 + * + * @param describe + */ + void onTimeout(String describe); + + /** + * 返回当前状态的名字 + */ + String getStateName(); +} diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/LoggedState.java b/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/LoggedState.java new file mode 100644 index 0000000..5d3445d --- /dev/null +++ b/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/LoggedState.java @@ -0,0 +1,35 @@ +package com.docus.server.common.netty.state; + +/** + * describe: + */ +public class LoggedState extends AbstractState { + public LoggedState(DeviceStateContext stateCtx) { + super(stateCtx); + } + + @Override + public void onDisconnect(String describe) { + //直接关闭链接 + this.stateCtx.closeChannle(describe); + } + + @Override + public void onHeartbeat(long lastUpdateTime, String describe) { + //把当前状态放进去 + this.stateCtx.setState(this, describe); + //状态不变更新 lastUpdateTime + this.stateCtx.setLastUpdateTime(lastUpdateTime); + } + + @Override + public void onTimeout(String describe) { + //状态模式设置为超时状态 + this.stateCtx.setState(new TimeoutState(this.stateCtx), describe); + } + + @Override + public String getStateName() { + return "logged"; + } +} \ No newline at end of file diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/NoConnectedState.java b/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/NoConnectedState.java new file mode 100644 index 0000000..7f6b580 --- /dev/null +++ b/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/NoConnectedState.java @@ -0,0 +1,26 @@ +package com.docus.server.common.netty.state; + +/** + * describe:未连接状态 + */ +public class NoConnectedState extends AbstractState { + public NoConnectedState(DeviceStateContext ctx) { + super(ctx); + } + + @Override + public void onConnect(long connectedTime, String describe) { + stateCtx.setConnectTime(connectedTime); + stateCtx.setState(new NoLoginState(this.stateCtx), describe); + } + + @Override + public void onDisconnect(String describe) { + this.stateCtx.closeChannle(describe); + } + + @Override + public String getStateName() { + return "noConnected"; + } +} \ No newline at end of file diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/NoLoginState.java b/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/NoLoginState.java new file mode 100644 index 0000000..57fc894 --- /dev/null +++ b/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/NoLoginState.java @@ -0,0 +1,42 @@ +package com.docus.server.common.netty.state; + +/** + * describe:未登录状态 + */ +public class NoLoginState extends AbstractState { + public NoLoginState(DeviceStateContext ctx) { + super(ctx); + } + + @Override + public void onDisconnect(String describe) { + this.stateCtx.closeChannle(describe); + } + + @Override + public void onLoginSucc(String deviceId, long lastUpdateTime, long heartRate, String describe) { + //设置数据 + this.stateCtx.setDeviceId(deviceId); + this.stateCtx.setLastUpdateTime(lastUpdateTime); + this.stateCtx.setHeartRate(heartRate); + //状态转移 + this.stateCtx.setState(new LoggedState(this.stateCtx), describe); + } +// +// @Override +// public void onLoginFailed(String describe) { +// //为登录模式下,登录失败,直接断开链接。 +// this.stateCtx.closeChannle(describe); +// } +// +// @Override +// public void onTimeout(String describe) { +// //在未登录状态下,超时无数据,直接断开链接 +// this.stateCtx.closeChannle(describe); +// } + + @Override + public String getStateName() { + return "noLogin"; + } +} \ No newline at end of file diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/TimeoutState.java b/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/TimeoutState.java new file mode 100644 index 0000000..f115e91 --- /dev/null +++ b/collector-terminal-management/src/main/java/com/docus/server/common/netty/state/TimeoutState.java @@ -0,0 +1,45 @@ +package com.docus.server.common.netty.state; + +/** + * describe:超时无数据状态 + */ +public class TimeoutState extends AbstractState { + public static final int MAX_TIMEOUT = 3; + + + /** + * 进入超时状态的次数,如果超过 3 次则断开链接 + */ + private int count; + + public TimeoutState(DeviceStateContext stateCtx) { + super(stateCtx); + this.count = 1; + } + + + @Override + public void onTimeout(String describe) { + //把当前状态放进去 + this.stateCtx.setState(this, describe); + this.count++; + //连续 timeout 到一定次数就关闭连接,切换到 断开链接状态 + if (this.count >= MAX_TIMEOUT) { + //断开链接 + this.stateCtx.closeChannle(describe); + } + } + + @Override + public void onHeartbeat(long lastUpdateTime, String describe) { + //=======更新最后更新时间========= + this.stateCtx.setLastUpdateTime(lastUpdateTime); + //=======状态转换为已登录========= + this.stateCtx.setState(new LoggedState(this.stateCtx), describe); + } + + @Override + public String getStateName() { + return "timeout"; + } +} \ No newline at end of file diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/process/ChannelProcessor.java b/collector-terminal-management/src/main/java/com/docus/server/common/process/ChannelProcessor.java deleted file mode 100644 index 076813b..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/common/process/ChannelProcessor.java +++ /dev/null @@ -1,152 +0,0 @@ -package com.docus.server.common.process; - -import com.docus.core.util.Func; -import com.docus.log.context.TrackContext; -import com.docus.log.processor.AbstractProcessor; -import com.docus.server.common.netty.server.ChannelRepository; -import com.docus.server.dto.scheduling.management.schcollectrecord.EditSchCollectRecordDTO; -import com.docus.server.dto.scheduling.management.schterminator.EditSchTerminatorDTO; -import com.docus.server.dto.scheduling.management.schterminator.NettyTerminatorDTO; -import com.docus.server.enums.BusyStateEnum; -import com.docus.server.enums.RetryTaskEnum; -import com.docus.server.enums.StateEnum; -import com.docus.server.service.ISchCollectRecordRetryLogService; -import com.docus.server.service.ISchCollectRecordService; -import com.docus.server.service.ISchTerminatorService; -import com.docus.server.vo.scheduling.management.schcollectrecord.SchCollectRecordVO; -import com.docus.server.vo.scheduling.management.schcollectrecordretrylog.SchCollectRecordRetryLogVO; -import com.docus.server.vo.scheduling.management.schterminator.SchTerminatorVO; - -import javax.annotation.Resource; -import java.util.Arrays; -import java.util.List; -import java.util.stream.Collectors; - -/** - * channel 管理 - */ -public class ChannelProcessor extends AbstractProcessor { - @Resource - private ChannelRepository channelRepository; - @Resource - private ISchTerminatorService iSchTerminatorService; - @Resource - private ISchCollectRecordService iSchCollectRecordService; - @Resource - private ISchCollectRecordRetryLogService iSchCollectRecordRetryLogService; - - @Override - protected Object doProcess(TrackContext context) { - String group = context.getGroup(); - - switch (group) { - case "SchCollectRecordController-edit": - return doSchCollectRecordControllerEdit(context); - case "SchTerminatorController": - return doSchTerminatorController(context); - case "RedisKeyExpirationService-expired": - return doRedisKeyExpired(context); - default: - return true; - } - } - - private Object doRedisKeyExpired(TrackContext context) { - boolean error = context.isError(); - String expireKey = (String) context.getArgs()[0]; - - String recordId = expireKey.substring(expireKey.lastIndexOf(":") + 1); - - if (!error) { - - if (expireKey.startsWith("schCollectorRecord:isRetryTask:expireKey:")) { - retryTask(recordId); - } - if (expireKey.startsWith("schCollectorRecord:noRetryTask:expireKey:")) { - noRetryTask(recordId); - - } - } - return null; - } - - private boolean doSchCollectRecordControllerEdit(TrackContext context) { - return logCollectRecord(context); - } - - private boolean doSchTerminatorController(TrackContext context) { - return logTerminator(context); - } - - private boolean logCollectRecord(TrackContext context) { - boolean error = context.isError(); - - EditSchCollectRecordDTO collectRecordDTO = (EditSchCollectRecordDTO) context.getArgs()[0]; - - if (!error) { - - if (RetryTaskEnum.NO_RETRY_TASK.equals(collectRecordDTO.getIsRetryTask())) { - - noRetryTask(String.valueOf(collectRecordDTO.getId())); - - } else if (RetryTaskEnum.RETRY_TASK.equals(collectRecordDTO.getIsRetryTask())) { - - retryTask(String.valueOf(collectRecordDTO.getId())); - - } - - } - return error; - - } - - private void retryTask(String recordLogId) { - SchCollectRecordRetryLogVO retryLogVO = iSchCollectRecordRetryLogService.findById(recordLogId); - - updateTerminatorState(retryLogVO.getTerminatorId(), retryLogVO.getTaskExecState()); - - } - - private void noRetryTask(String recordId) { - - SchCollectRecordVO schCollectRecordVO = iSchCollectRecordService.findById(recordId); - - updateTerminatorState(schCollectRecordVO.getTerminatorId(), schCollectRecordVO.getTaskExecState()); - } - - private void updateTerminatorState(Long terminatorId, StateEnum taskExecState) { - SchTerminatorVO schTerminatorVO = iSchTerminatorService.findById(String.valueOf(terminatorId)); - - NettyTerminatorDTO nettyTerminatorDTO = channelRepository.getTerminatorByIp(String.valueOf(schTerminatorVO.getTerminatorIp())); - - if (Func.isEmpty(nettyTerminatorDTO)) { - return; - } - - List stateEnums = Arrays.asList(StateEnum.values()); - - if (stateEnums.contains(taskExecState)) { - nettyTerminatorDTO.setBusyState(BusyStateEnum.IDLE); - } - } - - private boolean logTerminator(TrackContext context) { - boolean error = context.isError(); - EditSchTerminatorDTO terminatorDTO = (EditSchTerminatorDTO) context.getArgs()[0]; - if (!error) { - SchTerminatorVO terminatorVO = iSchTerminatorService.findById(String.valueOf(terminatorDTO.getId())); - - NettyTerminatorDTO nettyTerminatorDTO = channelRepository.getTerminatorByIp(terminatorVO.getTerminatorIp()); - - if (Func.isNotBlank(terminatorDTO.getOnlyCollectorIds())) { - List onlyList = Arrays.stream(terminatorDTO.getOnlyCollectorIds().split(",")).map(String::valueOf).collect(Collectors.toList()); - nettyTerminatorDTO.setOnlyCollectorIds(onlyList); - } - if (Func.isNotBlank(terminatorDTO.getPriorityCollectorIds())) { - List priList = Arrays.stream(terminatorDTO.getPriorityCollectorIds().split(",")).map(String::valueOf).collect(Collectors.toList()); - nettyTerminatorDTO.setPriorityCollectorIds(priList); - } - } - return error; - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/process/CollectorVersionProcessor.java b/collector-terminal-management/src/main/java/com/docus/server/common/process/CollectorVersionProcessor.java deleted file mode 100644 index ac4c504..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/common/process/CollectorVersionProcessor.java +++ /dev/null @@ -1,72 +0,0 @@ -package com.docus.server.common.process; - -import com.docus.infrastructure.redis.service.IdService; -import com.docus.log.context.TrackContext; -import com.docus.log.processor.AbstractProcessor; -import com.docus.server.dto.scheduling.management.schcollector.UpdateSchCollectorDTO; -import com.docus.server.entity.scheduling.management.SchCollector; -import com.docus.server.entity.scheduling.management.SchCollectorVersion; -import com.docus.server.entity.scheduling.management.SchCollectorVersionLog; -import com.docus.server.entity.scheduling.management.SchSystemParams; -import com.docus.server.enums.StateEnum; -import com.docus.server.infrastructure.dao.ISchCollectorDao; -import com.docus.server.infrastructure.dao.ISchCollectorVersionDao; -import com.docus.server.infrastructure.dao.ISchCollectorVersionLogDao; -import com.docus.server.infrastructure.dao.ISchSystemParamsDao; - -import javax.annotation.Resource; - -/** - * 日志管理 - */ -public class CollectorVersionProcessor extends AbstractProcessor { - @Resource - private ISchCollectorVersionLogDao iSchCollectorVersionLogDao; - @Resource - private ISchCollectorVersionDao iSchCollectorVersionDao; - @Resource - private ISchSystemParamsDao iSchSystemParamsDao; - @Resource - private ISchCollectorDao iSchCollectorDao; - @Resource - private IdService idService; - - @Override - public Object beforeProcess(TrackContext context) { - super.beforeProcess(context); - UpdateSchCollectorDTO updateDTO = (UpdateSchCollectorDTO) context.getArgs()[0]; - Long collectorId = updateDTO.getCollectorId(); - SchCollector schCollector = iSchCollectorDao.findOneBy("collectorId", collectorId); - SchCollectorVersion preVersion = iSchCollectorVersionDao.findById(schCollector.getCollectorVersionId()); - return preVersion.getCollectVersion(); - } - - @Override - protected Object doProcess(TrackContext context) { - logProcess(context); - return null; - } - - private void logProcess(TrackContext context) { - - boolean error = context.isError(); - - UpdateSchCollectorDTO updateDTO = (UpdateSchCollectorDTO) context.getArgs()[0]; - Long collectorId = updateDTO.getCollectorId(); - String preVersion = (String) context.getBeforeResult(); - SchCollectorVersion curVersion = iSchCollectorVersionDao.findById(updateDTO.getCollectorVersionId()); - SchSystemParams schSystemParams = iSchSystemParamsDao.findOneBy("paramValue", collectorId); - - SchCollectorVersionLog log = new SchCollectorVersionLog(); - log.setId(idService.getDateSeq()); - log.setCollectorId(collectorId); - log.setOperationModule(context.getGroup()); - log.setOperationType(context.getAction()); - log.setOperationDesc(context.getDesc()); - log.setOperationContent(String.format("采集器:%s,上一个版本是:%s,更换成当前版本是:%s", schSystemParams.getParamName(), preVersion, curVersion.getCollectVersion())); - log.setState(error ? StateEnum.FAIL : StateEnum.OK); - - iSchCollectorVersionLogDao.save(log); - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/process/TcpProcessor.java b/collector-terminal-management/src/main/java/com/docus/server/common/process/TcpProcessor.java deleted file mode 100644 index 49831e6..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/common/process/TcpProcessor.java +++ /dev/null @@ -1,62 +0,0 @@ -package com.docus.server.common.process; - -import com.docus.core.util.json.JSON; -import com.docus.log.context.TrackContext; -import com.docus.log.processor.AbstractProcessor; -import com.docus.server.common.MsgConstants; -import com.docus.server.dto.scheduling.management.schcollector.UpdateSchCollectorDTO; -import com.docus.server.dto.scheduling.management.schterminator.CommMsgDTO; -import com.docus.server.entity.scheduling.management.SchCollectorVersionFile; -import com.docus.server.service.ICommMsgService; -import com.docus.server.service.ISchCollectorVersionFileService; -import com.docus.server.service.ISchCollectorVersionService; -import com.docus.server.vo.scheduling.management.schcollectorversion.SchCollectorVersionVO; -import com.docus.server.vo.scheduling.management.schcollectorversion.TcpSchCollectorVersionContentVO; -import com.google.common.collect.Lists; - -import javax.annotation.Resource; -import java.util.List; - -/** - * tcp 管理 - */ -public class TcpProcessor extends AbstractProcessor { - @Resource - private ICommMsgService iCommMsgService; - @Resource - private ISchCollectorVersionFileService iSchCollectorVersionFileService; - @Resource - private ISchCollectorVersionService iSchCollectorVersionService; - - @Override - protected Object doProcess(TrackContext context) { - return logProcess(context); - } - - private boolean logProcess(TrackContext context) { - boolean error = context.isError(); - if (!error) { - UpdateSchCollectorDTO updateSchCollectorDTO = (UpdateSchCollectorDTO) context.getArgs()[0]; - Long collectorId = updateSchCollectorDTO.getCollectorId(); - Long collectorVersionId = updateSchCollectorDTO.getCollectorVersionId(); - - SchCollectorVersionFile schCollectorVersionFile = iSchCollectorVersionFileService.findByCollectorIdAndVersionId(collectorId, collectorVersionId); - SchCollectorVersionVO schCollectorVersionVO = iSchCollectorVersionService.findById(String.valueOf(collectorVersionId)); - - TcpSchCollectorVersionContentVO tcpSchCollectorVersionContentVO = new TcpSchCollectorVersionContentVO(); - tcpSchCollectorVersionContentVO.setCollectorId(collectorId); - tcpSchCollectorVersionContentVO.setFilePath(schCollectorVersionFile.getFilePath()); - tcpSchCollectorVersionContentVO.setCollectorVersion(schCollectorVersionVO.getCollectVersion()); - - List tcpSchCollectorVersionContentVOList = Lists.newArrayList(tcpSchCollectorVersionContentVO); - - CommMsgDTO commMsgDTO = CommMsgDTO.builder() - .content(JSON.toJSON(tcpSchCollectorVersionContentVOList)) - .messageType(MsgConstants.UPDATE_COLLECTOR_FILE) - .build(); - - iCommMsgService.clientsCommand(commMsgDTO); - } - return error; - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/test/DispatchService.java b/collector-terminal-management/src/main/java/com/docus/server/common/test/DispatchService.java deleted file mode 100644 index 8132d99..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/common/test/DispatchService.java +++ /dev/null @@ -1,107 +0,0 @@ -package com.docus.server.common.test; - -import java.util.ArrayList; -import java.util.List; - -public class DispatchService { - - public void dispatch() { - - - //获取所有空闲的终端 - List terminalList = new ArrayList<>(); - List taskInfos = this.getTaskInfos(terminalList.size()); - - - - //只采集,有优先级的 - for (Terminal terminal : terminalList) { - for (TaskInfo taskInfo : taskInfos) { - //先找出有只采集的任务。 - if (terminal.getOnlyTags().contains(taskInfo.getCollectType())) { - //把这个任务派给这个终端,并且把这个终端设置成繁忙 - if (terminal.getPriorityTags().contains(taskInfo.getCollectType())) { - //把这个任务派给这个终端 - terminal.setState(1); - return; - } - } - } - } - - //只采集没有优先级 - for (Terminal terminal : terminalList) { - //把刚才已经分配任务过的采集器排除 - if (terminal.getState() == 1) { - continue; - } - - for (TaskInfo taskInfo : taskInfos) { - //先找出有只采集的任务。 - if (terminal.getOnlyTags().contains(taskInfo.getCollectType())) { - //把这个任务派给这个终端,并且把这个终端设置成繁忙 - - terminal.setState(1); - return; - } - } - } - - - //无只采集,有优先级 - for (Terminal terminal : terminalList) { - - //把刚才已经分配任务过的采集器排除 - if (terminal.getState() == 1) { - continue; - } - - for (TaskInfo taskInfo : taskInfos) { - //先找出有只采集的任务。 - if (terminal.getPriorityTags().contains(taskInfo.getCollectType())) { - //把这个任务派给这个终端 - terminal.setState(1); - return; - } - } - } - - - //无只采集,无优先级 - for (Terminal terminal : terminalList) { - - //把刚才已经分配任务过的采集器排除 - if (terminal.getState() == 1) { - continue; - } - - for (TaskInfo taskInfo : taskInfos) { - //先找出有只采集的任务。 - //把这个任务派给这个终端 - terminal.setState(1); - return; - } - } - - } - - private void dispatchTask(List taskInfos, Terminal terminal) { - for (TaskInfo taskInfo : taskInfos) { - //先找出有只采集的任务。 - if (terminal.getOnlyTags().contains(taskInfo.getCollectType())) { - //把这个任务派给这个终端 - return; - } - if (terminal.getPriorityTags().contains(taskInfo.getCollectType())) { - //把这个任务派给这个终端 - return; - } - } - } - - - public List getTaskInfos(int size) { - return null; - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/test/TaskInfo.java b/collector-terminal-management/src/main/java/com/docus/server/common/test/TaskInfo.java deleted file mode 100644 index 08f8b45..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/common/test/TaskInfo.java +++ /dev/null @@ -1,14 +0,0 @@ -package com.docus.server.common.test; - -import lombok.Data; - -@Data -public class TaskInfo { - - private Long taskId; - - private String collectType; - - private String info; - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/test/Terminal.java b/collector-terminal-management/src/main/java/com/docus/server/common/test/Terminal.java deleted file mode 100644 index 4af50fa..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/common/test/Terminal.java +++ /dev/null @@ -1,16 +0,0 @@ -package com.docus.server.common.test; - -import lombok.Data; - -import java.util.List; - -@Data -public class Terminal { - - private String id; - private String collectType; - private List priorityTags; - private List onlyTags; - private Integer state; - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/utils/StartUpExeUtils.java b/collector-terminal-management/src/main/java/com/docus/server/common/utils/StartUpExeUtils.java new file mode 100644 index 0000000..b6b4250 --- /dev/null +++ b/collector-terminal-management/src/main/java/com/docus/server/common/utils/StartUpExeUtils.java @@ -0,0 +1,170 @@ +package com.docus.server.common.utils; + +import org.springframework.stereotype.Component; + +import java.io.BufferedReader; +import java.io.IOException; +import java.io.InputStreamReader; + +@Component +public class StartUpExeUtils { + + public static void main(String[] args) throws IOException { +// startUpExeOnly("H:\\tools\\Navicat Premium 12免安装\\Navicat Premium 12\\navicat.exe"); +// killExeOnly("navicat.exe"); + + startUpExe("H:\\tools\\Navicat Premium 12免安装\\Navicat Premium 12\\navicat.exe", "navicat.exe"); + } + + private static boolean startExeStatus = true;//exe启动状态 + + //仅启动exe客户端,不检查进程 + public static void startUpExeOnly(String exePath) throws IOException { + if (exePath != "") { + Runtime.getRuntime().exec(exePath); + } + } + + /** + * 仅kill指定进程 + * + * @param procName + * @throws IOException + */ + public static void killExeOnly(String procName) throws IOException { + if (procName != "") { + String command = "taskkill /F /IM " + procName; + Runtime.getRuntime().exec("cmd /c " + command); + } + } + + //启动exe客户端 + public static boolean startUpExe(String exePath, String procName) { + if (exePath != "" && procName != "") { + String result = checkProcess(procName);//检查exe进程 + if (result.isEmpty()) { + try { + Runtime.getRuntime().exec(exePath); + } catch (Exception e) { + e.printStackTrace(); + System.out.println("程序:" + exePath + "不存在!"); + } + } + } + return startExeStatus; + } + + //启动exe客户端,并传参 + public static boolean startUpExe(String exePath, String procName, int subId, String curModeId, String riskSet1, String riskSet2, String riskSet3) { + if (exePath != "" && procName != "") { + String result = checkProcess(procName);//检查exe进程 + if (result.isEmpty()) { + try { + //启动exe执行程序 + String[] cmd = {exePath, subId + "", curModeId, riskSet1, riskSet2, riskSet3}; + Runtime.getRuntime().exec(cmd); + } catch (Exception e) { + e.printStackTrace(); + System.out.println("程序:" + exePath + "不存在!"); + } + } + } + return startExeStatus; + } + + /** + * 检查进程是否存在,存在则杀死进程 + * + * @param procName + */ + public static String checkProcess(String procName) { + String result = ""; + //判断是否存在进程 + Boolean existProc = false; + BufferedReader bufferedReader = null; + try { + Process proc = Runtime.getRuntime().exec("tasklist -fi " + '"' + "imagename eq " + procName + '"'); + bufferedReader = new BufferedReader(new InputStreamReader(proc.getInputStream())); + String line = null; + while ((line = bufferedReader.readLine()) != null) { + if (line.contains(procName)) { + existProc = true;//存在 + } + } + } catch (Exception ex) { + result = "查询程序进程异常:" + ex.getMessage(); + System.out.println("查询程序进程异常:" + ex.getMessage()); + return result; + } finally { + if (bufferedReader != null) { + try { + bufferedReader.close(); + } catch (Exception ex) { + } + } + } + + // 存在,则先杀死该进程 + if (existProc) { + BufferedReader br = null; + try { + if (procName != "") { + //执行cmd命令 + String command = "taskkill /F /IM " + procName; + Runtime runtime = Runtime.getRuntime(); + Process process = runtime.exec("cmd /c " + command); + br = new BufferedReader(new InputStreamReader(process.getInputStream(), "UTF-8")); + String line = null; + StringBuilder build = new StringBuilder(); + while ((line = br.readLine()) != null) { + build.append(line); + } + } + } catch (Exception e) { + result = "关闭程序进程异常:" + e.getMessage(); + System.out.println("关闭程序进程异常:" + e.getMessage()); + return result; + } finally { + if (br != null) { + try { + br.close(); + } catch (Exception ex) { + } + } + } + } + return result; + } + + /** + * 仅检查进程是否存在 + * + * @param procName + */ + public static boolean checkProcessOnly(String procName) { + //判断是否存在进程 + Boolean existProc = false; + BufferedReader bufferedReader = null; + try { + Process proc = Runtime.getRuntime().exec("tasklist -fi " + '"' + "imagename eq " + procName + '"'); + bufferedReader = new BufferedReader(new InputStreamReader(proc.getInputStream())); + String line = null; + while ((line = bufferedReader.readLine()) != null) { + if (line.contains(procName)) { + existProc = true;//存在 + } + } + } catch (Exception ex) { + System.out.println("查询程序进程异常:" + ex.getMessage()); + return existProc; + } finally { + if (bufferedReader != null) { + try { + bufferedReader.close(); + } catch (Exception ex) { + } + } + } + return existProc; + } +} diff --git a/collector-terminal-management/src/main/java/com/docus/server/common/utils/SystemInfoUtils.java b/collector-terminal-management/src/main/java/com/docus/server/common/utils/SystemInfoUtils.java new file mode 100644 index 0000000..9219cc6 --- /dev/null +++ b/collector-terminal-management/src/main/java/com/docus/server/common/utils/SystemInfoUtils.java @@ -0,0 +1,313 @@ +package com.docus.server.common.utils; + +import com.alibaba.fastjson.JSONArray; +import com.alibaba.fastjson.JSONObject; +import oshi.SystemInfo; +import oshi.hardware.CentralProcessor; +import oshi.hardware.GlobalMemory; +import oshi.hardware.HardwareAbstractionLayer; +import oshi.hardware.NetworkIF; +import oshi.software.os.FileSystem; +import oshi.software.os.OSFileStore; +import oshi.software.os.OperatingSystem; +import oshi.util.Util; + +import java.io.BufferedReader; +import java.io.IOException; +import java.io.InputStreamReader; +import java.net.InetAddress; +import java.net.UnknownHostException; +import java.text.DecimalFormat; +import java.util.Formatter; +import java.util.HashMap; +import java.util.List; +import java.util.Map; +import java.util.Optional; +import java.util.Properties; +import java.util.StringTokenizer; + +/** + * 系统消息工具类 + **/ +public class SystemInfoUtils { + + private static final int OSHI_WAIT_SECOND = 1000; + private static final int SLEEP_TIME = 2 * 1000; + private static SystemInfo systemInfo = new SystemInfo(); + private static HardwareAbstractionLayer hardware = systemInfo.getHardware(); + private static OperatingSystem operatingSystem = systemInfo.getOperatingSystem(); + + public static void main(String[] args) throws Exception { + JSONObject info = getInfo(); + System.out.println(info); + } + + public static JSONObject getCpuInfo() { + JSONObject cpuInfo = new JSONObject(); + CentralProcessor processor = hardware.getProcessor(); + // CPU信息 + long[] prevTicks = processor.getSystemCpuLoadTicks(); + Util.sleep(OSHI_WAIT_SECOND); + long[] ticks = processor.getSystemCpuLoadTicks(); + long nice = ticks[CentralProcessor.TickType.NICE.getIndex()] - prevTicks[CentralProcessor.TickType.NICE.getIndex()]; + long irq = ticks[CentralProcessor.TickType.IRQ.getIndex()] - prevTicks[CentralProcessor.TickType.IRQ.getIndex()]; + long softirq = ticks[CentralProcessor.TickType.SOFTIRQ.getIndex()] - prevTicks[CentralProcessor.TickType.SOFTIRQ.getIndex()]; + long steal = ticks[CentralProcessor.TickType.STEAL.getIndex()] - prevTicks[CentralProcessor.TickType.STEAL.getIndex()]; + long cSys = ticks[CentralProcessor.TickType.SYSTEM.getIndex()] - prevTicks[CentralProcessor.TickType.SYSTEM.getIndex()]; + long user = ticks[CentralProcessor.TickType.USER.getIndex()] - prevTicks[CentralProcessor.TickType.USER.getIndex()]; + long iowait = ticks[CentralProcessor.TickType.IOWAIT.getIndex()] - prevTicks[CentralProcessor.TickType.IOWAIT.getIndex()]; + long idle = ticks[CentralProcessor.TickType.IDLE.getIndex()] - prevTicks[CentralProcessor.TickType.IDLE.getIndex()]; + long totalCpu = user + nice + cSys + idle + iowait + irq + softirq + steal; + //cpu核数 + cpuInfo.put("cpuNum", processor.getLogicalProcessorCount()); + //cpu系统使用率 + cpuInfo.put("cSys", new DecimalFormat("#.##%").format(cSys * 1.0 / totalCpu)); + //cpu用户使用率 + cpuInfo.put("user", new DecimalFormat("#.##%").format(user * 1.0 / totalCpu)); + //cpu当前等待率 + cpuInfo.put("iowait", new DecimalFormat("#.##%").format(iowait * 1.0 / totalCpu)); + //cpu当前使用率 + cpuInfo.put("idle", new DecimalFormat("#.##%").format(1.0 - (idle * 1.0 / totalCpu))); + return cpuInfo; + } + + /** + * 系统jvm信息 + */ + public static JSONObject getJvmInfo() { + JSONObject cpuInfo = new JSONObject(); + Properties props = System.getProperties(); + Runtime runtime = Runtime.getRuntime(); + long jvmTotalMemoryByte = runtime.totalMemory(); + long freeMemoryByte = runtime.freeMemory(); + //jvm总内存 + cpuInfo.put("total", formatByte(runtime.totalMemory())); + //空闲空间 + cpuInfo.put("free", formatByte(runtime.freeMemory())); + //jvm最大可申请 + cpuInfo.put("max", formatByte(runtime.maxMemory())); + //vm已使用内存 + cpuInfo.put("user", formatByte(jvmTotalMemoryByte - freeMemoryByte)); + //jvm内存使用率 + cpuInfo.put("usageRate", new DecimalFormat("#.##%").format((jvmTotalMemoryByte - freeMemoryByte) * 1.0 / jvmTotalMemoryByte)); + //jdk版本 + cpuInfo.put("jdkVersion", props.getProperty("java.version")); + //jdk路径 + cpuInfo.put("jdkHome", props.getProperty("java.home")); + return cpuInfo; + } + + /** + * 系统内存信息 + */ + public static JSONObject getMemInfo() { + JSONObject cpuInfo = new JSONObject(); + GlobalMemory memory = systemInfo.getHardware().getMemory(); + //总内存 + long totalByte = memory.getTotal(); + //剩余 + long acaliableByte = memory.getAvailable(); + //总内存 + cpuInfo.put("total", formatByte(totalByte)); + //使用 + cpuInfo.put("used", formatByte(totalByte - acaliableByte)); + //剩余内存 + cpuInfo.put("free", formatByte(acaliableByte)); + //使用率 + cpuInfo.put("usageRate", new DecimalFormat("#.##%").format((totalByte - acaliableByte) * 1.0 / totalByte)); + return cpuInfo; + } + + /** + * 带宽 + */ + public static JSONArray networkIFs() throws Exception { + JSONObject cpuInfo; + JSONArray sysFiles = new JSONArray(); + + List networkIFs = systemInfo.getHardware().getNetworkIFs(); + for (NetworkIF networkIF : networkIFs) { + String name = networkIF.getName(); + long receiveBytes = networkIF.getBytesRecv(); + long transmitBytes = networkIF.getBytesSent(); + + cpuInfo = new JSONObject(); + //名称 + cpuInfo.put("name", name); + //网络接收 + cpuInfo.put("receiveBytes", formatNumber(receiveBytes / (1024.0 * (2 * 1000 / 1000)))); + //网络发送 + cpuInfo.put("transmitBytes", formatNumber(transmitBytes / (1024.0 * (2 * 1000 / 1000)))); + + sysFiles.add(cpuInfo); + } + return sysFiles; + } + + public static JSONObject getNetWork() { + JSONObject networkInfo = new JSONObject(); + Properties props = System.getProperties(); + String os = props.getProperty("os.name").toLowerCase(); + os = os.startsWith("win") ? "windows" : "linux"; + Map result = new HashMap<>(); + Process pro = null; + Runtime r = Runtime.getRuntime(); + BufferedReader input = null; + try { + String command = "windows".equals(os) ? "netstat -e" : "ifconfig"; + pro = r.exec(command); + input = new BufferedReader(new InputStreamReader(pro.getInputStream())); + long result1[] = readInLine(input, os); + Thread.sleep(SLEEP_TIME); + pro.destroy(); + input.close(); + pro = r.exec(command); + input = new BufferedReader(new InputStreamReader(pro.getInputStream())); + long result2[] = readInLine(input, os); + String rxPercent = formatNumber((result2[0] - result1[0]) / (1024.0 * (SLEEP_TIME / 1000)));// 下行速率(kB/s) + String txPercent = formatNumber((result2[1] - result1[1]) / (1024.0 * (SLEEP_TIME / 1000)));// 上行速率(kB/s) + networkInfo.put("rxPercent", rxPercent); + networkInfo.put("txPercent", txPercent); + } catch (Exception e) { + e.printStackTrace(); + } finally { + if (input != null) { + try { + input.close(); + } catch (IOException e) { + e.printStackTrace(); + } + } + Optional.ofNullable(pro).ifPresent(p -> p.destroy()); + } + return networkInfo; + } + + private static long[] readInLine(BufferedReader input, String osType) { + long arr[] = new long[2]; + StringTokenizer tokenStat = null; + try { + if (osType.equals("linux")) { // 获取linux环境下的网口上下行速率 + long rx = 0, tx = 0; + String line = null; + //RX packets:4171603 errors:0 dropped:0 overruns:0 frame:0 + //TX packets:4171603 errors:0 dropped:0 overruns:0 carrier:0 + while ((line = input.readLine()) != null) { + if (line.indexOf("RX packets") >= 0) { + rx += Long.parseLong(line.substring(line.indexOf("RX packets") + 11, line.indexOf(" ", line.indexOf("RX packets") + 11))); + } else if (line.indexOf("TX packets") >= 0) { + tx += Long.parseLong(line.substring(line.indexOf("TX packets") + 11, line.indexOf(" ", line.indexOf("TX packets") + 11))); + } + } + arr[0] = rx; + arr[1] = tx; + } else { // 获取windows环境下的网口上下行速率 + input.readLine(); + input.readLine(); + input.readLine(); + input.readLine(); + tokenStat = new StringTokenizer(input.readLine()); + tokenStat.nextToken(); + arr[0] = Long.parseLong(tokenStat.nextToken()); + arr[1] = Long.parseLong(tokenStat.nextToken()); + } + } catch (Exception e) { + e.printStackTrace(); + } + return arr; + } + + + private static String formatNumber(double f) { + return new Formatter().format("%.2f", f).toString(); + } + + /** + * 系统盘符信息 + */ + public static JSONArray getSysFileInfo() { + JSONObject cpuInfo; + JSONArray sysFiles = new JSONArray(); + FileSystem fileSystem = operatingSystem.getFileSystem(); + List fsArray = fileSystem.getFileStores(); + for (OSFileStore fs : fsArray) { + cpuInfo = new JSONObject(); + //盘符路径 + cpuInfo.put("dirName", fs.getMount()); + //盘符类型 + cpuInfo.put("sysTypeName", fs.getType()); + //文件类型 + cpuInfo.put("typeName", fs.getName()); + //总大小 + cpuInfo.put("total", formatByte(fs.getTotalSpace())); + //剩余大小 + cpuInfo.put("free", formatByte(fs.getUsableSpace())); + //已经使用量 + cpuInfo.put("used", formatByte(fs.getTotalSpace() - fs.getUsableSpace())); + if (fs.getTotalSpace() == 0) { + //资源的使用率 + cpuInfo.put("usage", 0); + } else { + cpuInfo.put("usage", new DecimalFormat("#.##%").format((fs.getTotalSpace() - fs.getUsableSpace()) * 1.0 / fs.getTotalSpace())); + } + sysFiles.add(cpuInfo); + } + return sysFiles; + } + + /** + * 系统信息 + */ + public static JSONObject getSysInfo() throws UnknownHostException { + JSONObject cpuInfo = new JSONObject(); + Properties props = System.getProperties(); + //操作系统名 + cpuInfo.put("osName", props.getProperty("os.name")); + //系统架构 + cpuInfo.put("osArch", props.getProperty("os.arch")); + //服务器名称 + cpuInfo.put("computerName", InetAddress.getLocalHost().getHostName()); + //服务器Ip + cpuInfo.put("computerIp", InetAddress.getLocalHost().getHostAddress()); + //项目路径 + cpuInfo.put("userDir", props.getProperty("user.dir")); + return cpuInfo; + } + + + /** + * 所有系统信息 + */ + public static JSONObject getInfo() throws Exception { + JSONObject info = new JSONObject(); + info.put("cpuInfo", getCpuInfo()); + info.put("jvmInfo", getJvmInfo()); + info.put("memInfo", getMemInfo()); + info.put("sysInfo", getSysInfo()); + info.put("sysFileInfo", getSysFileInfo()); + info.put("networkInfo", getNetWork()); + return info; + } + + /** + * 单位转换 + */ + private static String formatByte(long byteNumber) { + //换算单位 + double FORMAT = 1024.0; + double kbNumber = byteNumber / FORMAT; + if (kbNumber < FORMAT) { + return new DecimalFormat("#.##KB").format(kbNumber); + } + double mbNumber = kbNumber / FORMAT; + if (mbNumber < FORMAT) { + return new DecimalFormat("#.##MB").format(mbNumber); + } + double gbNumber = mbNumber / FORMAT; + if (gbNumber < FORMAT) { + return new DecimalFormat("#.##GB").format(gbNumber); + } + double tbNumber = gbNumber / FORMAT; + return new DecimalFormat("#.##TB").format(tbNumber); + } +} diff --git a/collector-terminal-management/src/main/java/com/docus/server/controller/CommMsgController.java b/collector-terminal-management/src/main/java/com/docus/server/controller/CommMsgController.java deleted file mode 100644 index 437f03c..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/controller/CommMsgController.java +++ /dev/null @@ -1,25 +0,0 @@ -package com.docus.server.controller; - -import com.docus.server.api.scheduling.management.CommMsgApi; -import com.docus.server.dto.scheduling.management.schterminator.CommMsgDTO; -import com.docus.server.service.ICommMsgService; -import org.springframework.web.bind.annotation.RestController; - -import javax.annotation.Resource; - -/** - * 通用消息体 TCP API - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@RestController -public class CommMsgController implements CommMsgApi { - @Resource - private ICommMsgService iCommMsgService; - - @Override - public void clientCommand(CommMsgDTO commMsgDTO) { - iCommMsgService.clientCommand(commMsgDTO); - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/controller/FileController.java b/collector-terminal-management/src/main/java/com/docus/server/controller/FileController.java deleted file mode 100644 index dc42eab..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/controller/FileController.java +++ /dev/null @@ -1,31 +0,0 @@ -package com.docus.server.controller; - -import com.docus.server.api.scheduling.management.FileApi; -import com.docus.server.service.IFileUploadService; -import org.springframework.web.bind.annotation.RestController; -import org.springframework.web.multipart.MultipartFile; - -import javax.annotation.Resource; -import javax.servlet.http.HttpServletResponse; - -/** - * 文件上传下载 API - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@RestController -public class FileController implements FileApi { - @Resource - private IFileUploadService iFileUploadService; - - @Override - public void downloadFile(String filePath, HttpServletResponse response) throws Exception { - iFileUploadService.downloadFile(filePath, response); - } - - @Override - public void uploadFile(MultipartFile[] multipartFiles, String pathKey) throws Exception { - iFileUploadService.uploadFile(multipartFiles, pathKey); - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectErrorLogController.java b/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectErrorLogController.java deleted file mode 100644 index ca41df1..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectErrorLogController.java +++ /dev/null @@ -1,81 +0,0 @@ -package com.docus.server.controller; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.api.scheduling.management.SchCollectErrorLogApi; -import com.docus.server.dto.scheduling.management.schcollecterrorlog.AddSchCollectErrorLogDTO; -import com.docus.server.dto.scheduling.management.schcollecterrorlog.DeleteSchCollectErrorLogDTO; -import com.docus.server.dto.scheduling.management.schcollecterrorlog.EditSchCollectErrorLogDTO; -import com.docus.server.service.ISchCollectErrorLogService; -import com.docus.server.vo.scheduling.management.schcollecterrorlog.SchCollectErrorLogVO; -import org.springframework.web.bind.annotation.RestController; -import org.springframework.web.multipart.MultipartFile; - -import javax.annotation.Resource; - -/** - * 采集器异常日志 控制器类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@RestController -public class SchCollectErrorLogController implements SchCollectErrorLogApi { - @Resource - private ISchCollectErrorLogService iSchCollectErrorLogService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectErrorLogVO findById(String id) { - return iSchCollectErrorLogService.findById(id); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return iSchCollectErrorLogService.search(searchDTO); - } - - /** - * 新增 - * - * @param addSchCollectErrorLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchCollectErrorLogDTO addSchCollectErrorLogDTO, MultipartFile[] multipartFiles) throws Exception { - return iSchCollectErrorLogService.add(addSchCollectErrorLogDTO, multipartFiles); - } - - /** - * 编辑 - * - * @param editSchCollectErrorLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchCollectErrorLogDTO editSchCollectErrorLogDTO) { - return iSchCollectErrorLogService.edit(editSchCollectErrorLogDTO); - } - - /** - * 批量删除 - * - * @param deleteSchCollectErrorLogDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectErrorLogDTO deleteSchCollectErrorLogDTO) { - return iSchCollectErrorLogService.delete(deleteSchCollectErrorLogDTO); - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectRecordController.java b/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectRecordController.java deleted file mode 100644 index f39a5a1..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectRecordController.java +++ /dev/null @@ -1,103 +0,0 @@ -package com.docus.server.controller; - -import com.docus.core.util.ParamsUtils; -import com.docus.core.util.json.JSON; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.log.annotation.TrackGroup; -import com.docus.server.api.scheduling.management.SchCollectRecordApi; -import com.docus.server.common.SchCollectorTask; -import com.docus.server.common.process.ChannelProcessor; -import com.docus.server.dto.scheduling.management.schcollector.task.ReportDownTwoDTO; -import com.docus.server.dto.scheduling.management.schcollectrecord.AddSchCollectRecordDTO; -import com.docus.server.dto.scheduling.management.schcollectrecord.DeleteSchCollectRecordDTO; -import com.docus.server.dto.scheduling.management.schcollectrecord.EditSchCollectRecordDTO; -import com.docus.server.dto.scheduling.management.schcollectrecord.RetrySchCollectRecordDTO; -import com.docus.server.entity.scheduling.management.SchCollectRecord; -import com.docus.server.enums.RetryTaskEnum; -import com.docus.server.service.ISchCollectRecordService; -import com.docus.server.vo.scheduling.management.schcollectrecord.SchCollectRecordVO; -import org.springframework.web.bind.annotation.RestController; - -import javax.annotation.Resource; - -/** - * 采集记录表 控制器类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@RestController -public class SchCollectRecordController implements SchCollectRecordApi { - @Resource - private ISchCollectRecordService iSchCollectRecordService; - @Resource - private SchCollectorTask schedulerTask; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectRecordVO findById(String id) { - return iSchCollectRecordService.findById(id); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return iSchCollectRecordService.search(searchDTO); - } - - /** - * 新增 - * - * @param addSchCollectRecordDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public SchCollectRecord add(AddSchCollectRecordDTO addSchCollectRecordDTO) { - return iSchCollectRecordService.add(addSchCollectRecordDTO); - } - - /** - * 编辑 - * - * @param editSchCollectRecordDTO 编辑参数 - * @return 成功或失败 - */ - @TrackGroup(group = "SchCollectRecordController-edit", processor = ChannelProcessor.class) - @Override - public boolean edit(EditSchCollectRecordDTO editSchCollectRecordDTO) { - return iSchCollectRecordService.edit(editSchCollectRecordDTO); - } - - /** - * 批量删除 - * - * @param deleteSchCollectRecordDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectRecordDTO deleteSchCollectRecordDTO) { - return iSchCollectRecordService.delete(deleteSchCollectRecordDTO); - } - - @Override - public void retryTask(RetrySchCollectRecordDTO retrySchCollectRecordDTO) { - ReportDownTwoDTO report = JSON.fromJSON(retrySchCollectRecordDTO.getTaskOriginJson(), ReportDownTwoDTO.class); - - report.setParams(ParamsUtils - .addParam("collectRecordId", retrySchCollectRecordDTO.getId()) - .addParam("isRetryTask", RetryTaskEnum.RETRY_TASK.getValue()) - .param()); - schedulerTask.addRetryTask(report); - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectRecordRetryLogController.java b/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectRecordRetryLogController.java deleted file mode 100644 index cad13fa..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectRecordRetryLogController.java +++ /dev/null @@ -1,81 +0,0 @@ -package com.docus.server.controller; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.api.scheduling.management.SchCollectRecordRetryLogApi; -import com.docus.server.dto.scheduling.management.schcollectrecordretrylog.AddSchCollectRecordRetryLogDTO; -import com.docus.server.dto.scheduling.management.schcollectrecordretrylog.DeleteSchCollectRecordRetryLogDTO; -import com.docus.server.dto.scheduling.management.schcollectrecordretrylog.EditSchCollectRecordRetryLogDTO; -import com.docus.server.entity.scheduling.management.SchCollectRecordRetryLog; -import com.docus.server.service.ISchCollectRecordRetryLogService; -import com.docus.server.vo.scheduling.management.schcollectrecordretrylog.SchCollectRecordRetryLogVO; -import org.springframework.web.bind.annotation.RestController; - -import javax.annotation.Resource; - -/** - * 采集记录表重试表 控制器类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@RestController -public class SchCollectRecordRetryLogController implements SchCollectRecordRetryLogApi { - @Resource - private ISchCollectRecordRetryLogService iSchCollectRecordRetryLogService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectRecordRetryLogVO findById(String id) { - return iSchCollectRecordRetryLogService.findById(id); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return iSchCollectRecordRetryLogService.search(searchDTO); - } - - /** - * 新增 - * - * @param addSchCollectRecordRetryLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public SchCollectRecordRetryLog add(AddSchCollectRecordRetryLogDTO addSchCollectRecordRetryLogDTO) { - return iSchCollectRecordRetryLogService.add(addSchCollectRecordRetryLogDTO); - } - - /** - * 编辑 - * - * @param editSchCollectRecordRetryLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchCollectRecordRetryLogDTO editSchCollectRecordRetryLogDTO) { - return iSchCollectRecordRetryLogService.edit(editSchCollectRecordRetryLogDTO); - } - - /** - * 批量删除 - * - * @param deleteSchCollectRecordRetryLogDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectRecordRetryLogDTO deleteSchCollectRecordRetryLogDTO) { - return iSchCollectRecordRetryLogService.delete(deleteSchCollectRecordRetryLogDTO); - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectorConfigController.java b/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectorConfigController.java deleted file mode 100644 index e630329..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectorConfigController.java +++ /dev/null @@ -1,94 +0,0 @@ -package com.docus.server.controller; - -import com.docus.core.util.json.JSON; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.api.scheduling.management.SchCollectorConfigApi; -import com.docus.server.dto.scheduling.management.schcollectorconfig.AddSchCollectorConfigDTO; -import com.docus.server.dto.scheduling.management.schcollectorconfig.DeleteSchCollectorConfigDTO; -import com.docus.server.dto.scheduling.management.schcollectorconfig.EditSchCollectorConfigDTO; -import com.docus.server.service.ISchCollectorConfigService; -import com.docus.server.vo.scheduling.management.schcollectorconfig.SchCollectorConfigVO; -import com.google.common.collect.Maps; -import org.springframework.web.bind.annotation.RestController; - -import javax.annotation.Resource; -import java.util.HashMap; - -/** - * 采集器配置 控制器类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@RestController -public class SchCollectorConfigController implements SchCollectorConfigApi { - @Resource - private ISchCollectorConfigService iSchCollectorConfigService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectorConfigVO findById(String id) { - return iSchCollectorConfigService.findById(id); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return iSchCollectorConfigService.search(searchDTO); - } - - /** - * 新增 - * - * @param addSchCollectorConfigDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchCollectorConfigDTO addSchCollectorConfigDTO) { - return iSchCollectorConfigService.add(addSchCollectorConfigDTO); - } - - /** - * 编辑 - * - * @param editSchCollectorConfigDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchCollectorConfigDTO editSchCollectorConfigDTO) { - return iSchCollectorConfigService.edit(editSchCollectorConfigDTO); - } - - /** - * 批量删除 - * - * @param deleteSchCollectorConfigDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectorConfigDTO deleteSchCollectorConfigDTO) { - return iSchCollectorConfigService.delete(deleteSchCollectorConfigDTO); - } - - - public static void main(String[] args) { - - HashMap objectObjectHashMap = Maps.newHashMap(); - objectObjectHashMap.put("ocr.url", "http://192.168.2.13/ocr"); - objectObjectHashMap.put("ocr.name", "lin"); - objectObjectHashMap.put("ocr.pwd", "123"); - System.out.println(JSON.toJSON(objectObjectHashMap)); - - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectorController.java b/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectorController.java deleted file mode 100644 index 5c1ae14..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectorController.java +++ /dev/null @@ -1,94 +0,0 @@ -package com.docus.server.controller; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.log.annotation.TrackLogGroup; -import com.docus.server.api.scheduling.management.SchCollectorApi; -import com.docus.server.common.process.CollectorVersionProcessor; -import com.docus.server.dto.scheduling.management.schcollector.AddSchCollectorDTO; -import com.docus.server.dto.scheduling.management.schcollector.DeleteSchCollectorDTO; -import com.docus.server.dto.scheduling.management.schcollector.EditSchCollectorDTO; -import com.docus.server.dto.scheduling.management.schcollector.UpdateSchCollectorDTO; -import com.docus.server.service.ISchCollectorService; -import com.docus.server.vo.scheduling.management.schcollector.SchCollectorVO; -import org.springframework.web.bind.annotation.RestController; - -import javax.annotation.Resource; - -/** - * 采集器管理 控制器类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@RestController -public class SchCollectorController implements SchCollectorApi { - @Resource - private ISchCollectorService iSchCollectorService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectorVO findById(String id) { - return iSchCollectorService.findById(id); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return iSchCollectorService.search(searchDTO); - } - - /** - * 新增 - * - * @param addSchCollectorDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchCollectorDTO addSchCollectorDTO) { - return iSchCollectorService.add(addSchCollectorDTO); - } - - /** - * 编辑 - * - * @param editSchCollectorDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchCollectorDTO editSchCollectorDTO) { - return iSchCollectorService.edit(editSchCollectorDTO); - } - - /** - * 批量删除 - * - * @param deleteSchCollectorDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectorDTO deleteSchCollectorDTO) { - return iSchCollectorService.delete(deleteSchCollectorDTO); - } - - /** - * 选为当前版本并更新 - * - * @return 成功或失败 - */ - @TrackLogGroup(group = "采集器管理", action = "更新", desc = "更新采集器版本", processor = CollectorVersionProcessor.class) - @Override - public boolean updateVersion(UpdateSchCollectorDTO updateDTO) { - return iSchCollectorService.updateVersion(updateDTO); - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectorVersionController.java b/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectorVersionController.java deleted file mode 100644 index 0ceb4d2..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectorVersionController.java +++ /dev/null @@ -1,84 +0,0 @@ -package com.docus.server.controller; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.api.scheduling.management.SchCollectorVersionApi; -import com.docus.server.dto.scheduling.management.schcollectorversion.AddSchCollectorVersionDTO; -import com.docus.server.dto.scheduling.management.schcollectorversion.DeleteSchCollectorVersionDTO; -import com.docus.server.dto.scheduling.management.schcollectorversion.EditSchCollectorVersionDTO; -import com.docus.server.service.ISchCollectorService; -import com.docus.server.service.ISchCollectorVersionService; -import com.docus.server.vo.scheduling.management.schcollectorversion.SchCollectorVersionVO; -import org.springframework.web.bind.annotation.RestController; - -import javax.annotation.Resource; - -/** - * 采集器版本列表管理 控制器类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@RestController -public class SchCollectorVersionController implements SchCollectorVersionApi { - @Resource - private ISchCollectorVersionService iSchCollectorVersionService; - @Resource - private ISchCollectorService iSchCollectorService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectorVersionVO findById(String id) { - return iSchCollectorVersionService.findById(id); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return iSchCollectorVersionService.search(searchDTO); - } - - /** - * 新增 - * - * @param addSchCollectorVersionDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchCollectorVersionDTO addSchCollectorVersionDTO) { - return iSchCollectorVersionService.add(addSchCollectorVersionDTO); - } - - /** - * 编辑 - * - * @param editSchCollectorVersionDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchCollectorVersionDTO editSchCollectorVersionDTO) { - return iSchCollectorVersionService.edit(editSchCollectorVersionDTO); - } - - /** - * 批量删除 - * - * @param deleteSchCollectorVersionDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectorVersionDTO deleteSchCollectorVersionDTO) { - return iSchCollectorVersionService.delete(deleteSchCollectorVersionDTO); - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectorVersionFileController.java b/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectorVersionFileController.java deleted file mode 100644 index 4e33b9f..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectorVersionFileController.java +++ /dev/null @@ -1,114 +0,0 @@ -package com.docus.server.controller; - -import cn.hutool.core.util.StrUtil; -import com.docus.core.util.Func; -import com.docus.infrastructure.web.exception.ApiException; -import com.docus.infrastructure.web.exception.ExceptionCode; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.api.scheduling.management.SchCollectorVersionFileApi; -import com.docus.server.dto.scheduling.management.schcollectorversionfile.AddSchCollectorVersionFileDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionfile.DeleteSchCollectorVersionFileDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionfile.EditSchCollectorVersionFileDTO; -import com.docus.server.entity.scheduling.management.SchCollectorVersion; -import com.docus.server.service.ISchCollectorVersionFileService; -import com.docus.server.service.ISchCollectorVersionService; -import com.docus.server.vo.scheduling.management.schcollectorversionfile.SchCollectorVersionFileVO; -import lombok.extern.slf4j.Slf4j; -import org.springframework.web.bind.annotation.RestController; -import org.springframework.web.multipart.MultipartFile; - -import javax.annotation.Resource; - -/** - * 采集器版本列表更新包管理 控制器类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@RestController -@Slf4j -public class SchCollectorVersionFileController implements SchCollectorVersionFileApi { - @Resource - private ISchCollectorVersionFileService iSchCollectorVersionFileService; - @Resource - private ISchCollectorVersionService iSchCollectorVersionService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectorVersionFileVO findById(String id) { - return iSchCollectorVersionFileService.findById(id); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return iSchCollectorVersionFileService.search(searchDTO); - } - - /** - * 新增 - * - * @param addDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchCollectorVersionFileDTO addDTO, MultipartFile[] multipartFiles) throws Exception { - if (fileValid(multipartFiles, addDTO)) { - throw new ApiException(ExceptionCode.ParamIllegal.getCode(), "请选择文件和填写上传文件信息!"); - } - - SchCollectorVersion schCollectorVersion = iSchCollectorVersionService.findByVersion(addDTO.getCollectorId(), addDTO.getCollectorVersionNo()); - - if (null != schCollectorVersion) { - throw new ApiException(ExceptionCode.ParamIllegal.getCode(), "当前采集器版本号已存在!"); - } - - iSchCollectorVersionFileService.addVersionAndFile(addDTO, multipartFiles); - - return true; - } - - private boolean fileValid(MultipartFile[] multipartFiles, AddSchCollectorVersionFileDTO addSchCollectorVersionFileDTO) { - return multipartFiles == null - || multipartFiles.length == 0 - || StrUtil.isBlank(addSchCollectorVersionFileDTO.getCollectorVersionNo()) - || Func.isEmpty(addSchCollectorVersionFileDTO.getCollectorId()); - } - - public boolean add(AddSchCollectorVersionFileDTO addSchCollectorVersionFileDTO) { - return iSchCollectorVersionFileService.add(addSchCollectorVersionFileDTO); - } - - /** - * 编辑 - * - * @param editSchCollectorVersionFileDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchCollectorVersionFileDTO editSchCollectorVersionFileDTO) { - return iSchCollectorVersionFileService.edit(editSchCollectorVersionFileDTO); - } - - /** - * 批量删除 - * - * @param deleteSchCollectorVersionFileDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectorVersionFileDTO deleteSchCollectorVersionFileDTO) { - return iSchCollectorVersionFileService.delete(deleteSchCollectorVersionFileDTO); - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectorVersionLogController.java b/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectorVersionLogController.java deleted file mode 100644 index b9430cd..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/controller/SchCollectorVersionLogController.java +++ /dev/null @@ -1,80 +0,0 @@ -package com.docus.server.controller; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.api.scheduling.management.SchCollectorVersionLogApi; -import com.docus.server.dto.scheduling.management.schcollectorversionlog.AddSchCollectorVersionLogDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionlog.DeleteSchCollectorVersionLogDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionlog.EditSchCollectorVersionLogDTO; -import com.docus.server.service.ISchCollectorVersionLogService; -import com.docus.server.vo.scheduling.management.schcollectorversionlog.SchCollectorVersionLogVO; -import org.springframework.web.bind.annotation.RestController; - -import javax.annotation.Resource; - -/** - * 采集器版本更新日志管理 控制器类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@RestController -public class SchCollectorVersionLogController implements SchCollectorVersionLogApi { - @Resource - private ISchCollectorVersionLogService iSchCollectorVersionLogService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectorVersionLogVO findById(String id) { - return iSchCollectorVersionLogService.findById(id); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return iSchCollectorVersionLogService.search(searchDTO); - } - - /** - * 新增 - * - * @param addSchCollectorVersionLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchCollectorVersionLogDTO addSchCollectorVersionLogDTO) { - return iSchCollectorVersionLogService.add(addSchCollectorVersionLogDTO); - } - - /** - * 编辑 - * - * @param editSchCollectorVersionLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchCollectorVersionLogDTO editSchCollectorVersionLogDTO) { - return iSchCollectorVersionLogService.edit(editSchCollectorVersionLogDTO); - } - - /** - * 批量删除 - * - * @param deleteSchCollectorVersionLogDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectorVersionLogDTO deleteSchCollectorVersionLogDTO) { - return iSchCollectorVersionLogService.delete(deleteSchCollectorVersionLogDTO); - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/controller/SchOperationLogController.java b/collector-terminal-management/src/main/java/com/docus/server/controller/SchOperationLogController.java deleted file mode 100644 index ab44752..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/controller/SchOperationLogController.java +++ /dev/null @@ -1,80 +0,0 @@ -package com.docus.server.controller; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.api.scheduling.management.SchOperationLogApi; -import com.docus.server.dto.scheduling.management.schoperationlog.AddSchOperationLogDTO; -import com.docus.server.dto.scheduling.management.schoperationlog.DeleteSchOperationLogDTO; -import com.docus.server.dto.scheduling.management.schoperationlog.EditSchOperationLogDTO; -import com.docus.server.service.ISchOperationLogService; -import com.docus.server.vo.scheduling.management.schoperationlog.SchOperationLogVO; -import org.springframework.web.bind.annotation.RestController; - -import javax.annotation.Resource; - -/** - * 采集调度器操作日志 控制器类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@RestController -public class SchOperationLogController implements SchOperationLogApi { - @Resource - private ISchOperationLogService iSchOperationLogService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchOperationLogVO findById(String id) { - return iSchOperationLogService.findById(id); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return iSchOperationLogService.search(searchDTO); - } - - /** - * 新增 - * - * @param addSchOperationLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchOperationLogDTO addSchOperationLogDTO) { - return iSchOperationLogService.add(addSchOperationLogDTO); - } - - /** - * 编辑 - * - * @param editSchOperationLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchOperationLogDTO editSchOperationLogDTO) { - return iSchOperationLogService.edit(editSchOperationLogDTO); - } - - /** - * 批量删除 - * - * @param deleteSchOperationLogDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchOperationLogDTO deleteSchOperationLogDTO) { - return iSchOperationLogService.delete(deleteSchOperationLogDTO); - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/controller/SchSystemParamsController.java b/collector-terminal-management/src/main/java/com/docus/server/controller/SchSystemParamsController.java deleted file mode 100644 index 78ec4cf..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/controller/SchSystemParamsController.java +++ /dev/null @@ -1,80 +0,0 @@ -package com.docus.server.controller; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.api.scheduling.management.SchSystemParamsApi; -import com.docus.server.dto.scheduling.management.schsystemparams.AddSchSystemParamsDTO; -import com.docus.server.dto.scheduling.management.schsystemparams.DeleteSchSystemParamsDTO; -import com.docus.server.dto.scheduling.management.schsystemparams.EditSchSystemParamsDTO; -import com.docus.server.service.ISchSystemParamsService; -import com.docus.server.vo.scheduling.management.schsystemparams.SchSystemParamsVO; -import org.springframework.web.bind.annotation.RestController; - -import javax.annotation.Resource; - -/** - * 系统参数表 控制器类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@RestController -public class SchSystemParamsController implements SchSystemParamsApi { - @Resource - private ISchSystemParamsService iSchSystemParamsService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchSystemParamsVO findById(String id) { - return iSchSystemParamsService.findById(id); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return iSchSystemParamsService.search(searchDTO); - } - - /** - * 新增 - * - * @param addSchSystemParamsDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchSystemParamsDTO addSchSystemParamsDTO) { - return iSchSystemParamsService.add(addSchSystemParamsDTO); - } - - /** - * 编辑 - * - * @param editSchSystemParamsDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchSystemParamsDTO editSchSystemParamsDTO) { - return iSchSystemParamsService.edit(editSchSystemParamsDTO); - } - - /** - * 批量删除 - * - * @param deleteSchSystemParamsDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchSystemParamsDTO deleteSchSystemParamsDTO) { - return iSchSystemParamsService.delete(deleteSchSystemParamsDTO); - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/controller/SchTerminatorController.java b/collector-terminal-management/src/main/java/com/docus/server/controller/SchTerminatorController.java deleted file mode 100644 index 65700e2..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/controller/SchTerminatorController.java +++ /dev/null @@ -1,87 +0,0 @@ -package com.docus.server.controller; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.log.annotation.TrackGroup; -import com.docus.server.api.scheduling.management.SchTerminatorApi; -import com.docus.server.common.netty.server.ChannelRepository; -import com.docus.server.common.process.ChannelProcessor; -import com.docus.server.dto.scheduling.management.schterminator.AddSchTerminatorDTO; -import com.docus.server.dto.scheduling.management.schterminator.DeleteSchTerminatorDTO; -import com.docus.server.dto.scheduling.management.schterminator.EditSchTerminatorDTO; -import com.docus.server.service.ISchTerminatorService; -import com.docus.server.vo.scheduling.management.schterminator.SchTerminatorVO; -import org.springframework.web.bind.annotation.RestController; - -import javax.annotation.Resource; - -/** - * 执行管理器 控制器类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@RestController -public class SchTerminatorController implements SchTerminatorApi { - @Resource - private ISchTerminatorService iSchTerminatorService; - @Resource - private ChannelRepository channelRepository; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchTerminatorVO findById(String id) { - return iSchTerminatorService.findById(id); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return iSchTerminatorService.search(searchDTO); - } - - /** - * 新增 - * - * @param addSchTerminatorDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchTerminatorDTO addSchTerminatorDTO) { - return iSchTerminatorService.add(addSchTerminatorDTO); - } - - /** - * 编辑 - * - * @param editSchTerminatorDTO 编辑参数 - * @return 成功或失败 - */ - @TrackGroup(group = "SchTerminatorController", processor = ChannelProcessor.class) - @Override - public boolean edit(EditSchTerminatorDTO editSchTerminatorDTO) { - return iSchTerminatorService.edit(editSchTerminatorDTO); - } - - /** - * 批量删除 - * - * @param deleteSchTerminatorDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchTerminatorDTO deleteSchTerminatorDTO) { - return iSchTerminatorService.delete(deleteSchTerminatorDTO); - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/controller/SchVirtualLogController.java b/collector-terminal-management/src/main/java/com/docus/server/controller/SchVirtualLogController.java deleted file mode 100644 index 181b93e..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/controller/SchVirtualLogController.java +++ /dev/null @@ -1,80 +0,0 @@ -package com.docus.server.controller; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.api.scheduling.management.SchVirtualLogApi; -import com.docus.server.dto.scheduling.management.schvirtuallog.AddSchVirtualLogDTO; -import com.docus.server.dto.scheduling.management.schvirtuallog.DeleteSchVirtualLogDTO; -import com.docus.server.dto.scheduling.management.schvirtuallog.EditSchVirtualLogDTO; -import com.docus.server.service.ISchVirtualLogService; -import com.docus.server.vo.scheduling.management.schvirtuallog.SchVirtualLogVO; -import org.springframework.web.bind.annotation.RestController; - -import javax.annotation.Resource; - -/** - * 虚拟机使用情况 控制器类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@RestController -public class SchVirtualLogController implements SchVirtualLogApi { - @Resource - private ISchVirtualLogService iSchVirtualLogService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchVirtualLogVO findById(String id) { - return iSchVirtualLogService.findById(id); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return iSchVirtualLogService.search(searchDTO); - } - - /** - * 新增 - * - * @param addSchVirtualLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchVirtualLogDTO addSchVirtualLogDTO) { - return iSchVirtualLogService.add(addSchVirtualLogDTO); - } - - /** - * 编辑 - * - * @param editSchVirtualLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchVirtualLogDTO editSchVirtualLogDTO) { - return iSchVirtualLogService.edit(editSchVirtualLogDTO); - } - - /** - * 批量删除 - * - * @param deleteSchVirtualLogDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchVirtualLogDTO deleteSchVirtualLogDTO) { - return iSchVirtualLogService.delete(deleteSchVirtualLogDTO); - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/convert/CommMsgConvert.java b/collector-terminal-management/src/main/java/com/docus/server/convert/CommMsgConvert.java deleted file mode 100644 index fae23c5..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/convert/CommMsgConvert.java +++ /dev/null @@ -1,24 +0,0 @@ -package com.docus.server.convert; - -import com.docus.server.common.netty.CommMsg; -import com.docus.server.dto.scheduling.management.schterminator.CommMsgDTO; -import org.mapstruct.Mapper; -import org.mapstruct.Mappings; -import org.mapstruct.factory.Mappers; - -/** - * 通用消息转换器 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Mapper -public interface CommMsgConvert { - - CommMsgConvert INSTANCE = Mappers.getMapper(CommMsgConvert.class); - - @Mappings({}) - CommMsg convertDO(CommMsgDTO commMsgDTO); - -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectErrorLogConvert.java b/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectErrorLogConvert.java deleted file mode 100644 index b3c3c7f..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectErrorLogConvert.java +++ /dev/null @@ -1,48 +0,0 @@ -package com.docus.server.convert; - -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectErrorLog; -import com.docus.server.dto.scheduling.management.schcollecterrorlog.AddSchCollectErrorLogDTO; -import com.docus.server.dto.scheduling.management.schcollecterrorlog.EditSchCollectErrorLogDTO; -import com.docus.server.dto.scheduling.management.schcollecterrorlog.DeleteSchCollectErrorLogDTO; -import com.docus.server.vo.scheduling.management.schcollecterrorlog.SchCollectErrorLogVO; - -import org.mapstruct.Mapper; -import org.mapstruct.Mappings; -import org.mapstruct.factory.Mappers; - -import java.util.List; - -/** - * 采集器异常日志 服务转换器 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Mapper -public interface SchCollectErrorLogConvert { - - SchCollectErrorLogConvert INSTANCE = Mappers.getMapper(SchCollectErrorLogConvert.class); - - @Mappings({}) - SchCollectErrorLog convertDO(AddSchCollectErrorLogDTO addSchCollectErrorLogDTO); - - @Mappings({}) - SchCollectErrorLog convertDO(EditSchCollectErrorLogDTO editSchCollectErrorLogDTO); - - @Mappings({}) - List convertAddDOList(List addSchCollectErrorLogDTO); - - @Mappings({}) - List convertEditDOList(List editSchCollectErrorLogDTO); - - @Mappings({}) - SchCollectErrorLogVO convertVO(SchCollectErrorLog schCollectErrorLog); - - @Mappings({}) - List convertVO(List schCollectErrorLogList); - - @Mappings({}) - PageResult convertVO(PageResult pageResult); -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectRecordConvert.java b/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectRecordConvert.java deleted file mode 100644 index 2ead1ea..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectRecordConvert.java +++ /dev/null @@ -1,47 +0,0 @@ -package com.docus.server.convert; - -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schcollectrecord.AddSchCollectRecordDTO; -import com.docus.server.dto.scheduling.management.schcollectrecord.EditSchCollectRecordDTO; -import com.docus.server.entity.scheduling.management.SchCollectRecord; -import com.docus.server.vo.scheduling.management.schcollectrecord.SchCollectRecordVO; -import org.mapstruct.Mapper; -import org.mapstruct.MappingTarget; -import org.mapstruct.Mappings; -import org.mapstruct.factory.Mappers; - -import java.util.List; - -/** - * 采集记录表 服务转换器 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Mapper -public interface SchCollectRecordConvert { - - SchCollectRecordConvert INSTANCE = Mappers.getMapper(SchCollectRecordConvert.class); - - @Mappings({}) - SchCollectRecord convertDO(AddSchCollectRecordDTO addSchCollectRecordDTO); - - @Mappings({}) - SchCollectRecord convertDO(EditSchCollectRecordDTO editSchCollectRecordDTO, @MappingTarget SchCollectRecord schCollectRecord); - - @Mappings({}) - List convertAddDOList(List addSchCollectRecordDTO); - - @Mappings({}) - List convertEditDOList(List editSchCollectRecordDTO); - - @Mappings({}) - SchCollectRecordVO convertVO(SchCollectRecord schCollectRecord); - - @Mappings({}) - List convertVO(List schCollectRecordList); - - @Mappings({}) - PageResult convertVO(PageResult pageResult); -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectRecordRetryLogConvert.java b/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectRecordRetryLogConvert.java deleted file mode 100644 index 8a4ccdd..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectRecordRetryLogConvert.java +++ /dev/null @@ -1,51 +0,0 @@ -package com.docus.server.convert; - -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schcollectrecord.EditSchCollectRecordDTO; -import com.docus.server.dto.scheduling.management.schcollectrecordretrylog.AddSchCollectRecordRetryLogDTO; -import com.docus.server.dto.scheduling.management.schcollectrecordretrylog.EditSchCollectRecordRetryLogDTO; -import com.docus.server.entity.scheduling.management.SchCollectRecordRetryLog; -import com.docus.server.vo.scheduling.management.schcollectrecordretrylog.SchCollectRecordRetryLogVO; -import org.mapstruct.Mapper; -import org.mapstruct.MappingTarget; -import org.mapstruct.Mappings; -import org.mapstruct.factory.Mappers; - -import java.util.List; - -/** - * 采集记录表重试表 服务转换器 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Mapper -public interface SchCollectRecordRetryLogConvert { - - SchCollectRecordRetryLogConvert INSTANCE = Mappers.getMapper(SchCollectRecordRetryLogConvert.class); - - @Mappings({}) - SchCollectRecordRetryLog convertDO(EditSchCollectRecordDTO editSchCollectRecordDTO, @MappingTarget SchCollectRecordRetryLog schCollectRecordRetryLog); - - @Mappings({}) - SchCollectRecordRetryLog convertDO(AddSchCollectRecordRetryLogDTO addSchCollectRecordRetryLogDTO); - - @Mappings({}) - SchCollectRecordRetryLog convertDO(EditSchCollectRecordRetryLogDTO editSchCollectRecordRetryLogDTO); - - @Mappings({}) - List convertAddDOList(List addSchCollectRecordRetryLogDTO); - - @Mappings({}) - List convertEditDOList(List editSchCollectRecordRetryLogDTO); - - @Mappings({}) - SchCollectRecordRetryLogVO convertVO(SchCollectRecordRetryLog schCollectRecordRetryLog); - - @Mappings({}) - List convertVO(List schCollectRecordRetryLogList); - - @Mappings({}) - PageResult convertVO(PageResult pageResult); -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectorConfigConvert.java b/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectorConfigConvert.java deleted file mode 100644 index e7ccd72..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectorConfigConvert.java +++ /dev/null @@ -1,44 +0,0 @@ -package com.docus.server.convert; - -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schcollectorconfig.AddSchCollectorConfigDTO; -import com.docus.server.dto.scheduling.management.schcollectorconfig.EditSchCollectorConfigDTO; -import com.docus.server.entity.scheduling.management.SchCollectorConfig; -import com.docus.server.vo.scheduling.management.schcollectorconfig.SchCollectorConfigVO; -import com.docus.server.vo.scheduling.management.schcollectorconfig.TcpSchCollectorConfigVO; -import org.mapstruct.Mapper; -import org.mapstruct.Mappings; -import org.mapstruct.factory.Mappers; - -import java.util.List; - -/** - * 采集器配置 服务转换器 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Mapper -public interface SchCollectorConfigConvert { - - SchCollectorConfigConvert INSTANCE = Mappers.getMapper(SchCollectorConfigConvert.class); - - @Mappings({}) - SchCollectorConfig convertDO(AddSchCollectorConfigDTO addSchCollectorConfigDTO); - - @Mappings({}) - SchCollectorConfig convertDO(EditSchCollectorConfigDTO editSchCollectorConfigDTO); - - @Mappings({}) - SchCollectorConfigVO convertVO(SchCollectorConfig schCollectorConfig); - - @Mappings({}) - PageResult convertVO(PageResult pageResult); - - @Mappings({}) - List convertTcpVOList(List publicConfig); - - @Mappings({}) - TcpSchCollectorConfigVO convertTcpVO(SchCollectorConfig schCollectorConfig); -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectorConvert.java b/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectorConvert.java deleted file mode 100644 index c2d2f16..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectorConvert.java +++ /dev/null @@ -1,47 +0,0 @@ -package com.docus.server.convert; - -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schcollector.AddSchCollectorDTO; -import com.docus.server.dto.scheduling.management.schcollector.EditSchCollectorDTO; -import com.docus.server.entity.scheduling.management.SchCollector; -import com.docus.server.vo.scheduling.management.schcollector.SchCollectorVO; -import org.mapstruct.Mapper; -import org.mapstruct.Mappings; -import org.mapstruct.factory.Mappers; - -import java.util.List; - -/** - * 采集器管理 服务转换器 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Mapper -public interface SchCollectorConvert { - - SchCollectorConvert INSTANCE = Mappers.getMapper(SchCollectorConvert.class); - - @Mappings({}) - SchCollector convertDO(AddSchCollectorDTO addSchCollectorDTO); - - @Mappings({}) - SchCollector convertDO(EditSchCollectorDTO editSchCollectorDTO); - - @Mappings({}) - List convertAddDOList(List addSchCollectorDTO); - - @Mappings({}) - List convertEditDOList(List editSchCollectorDTO); - - @Mappings({}) - SchCollectorVO convertVO(SchCollector schCollector); - - @Mappings({}) - List convertVO(List schCollectorList); - - @Mappings({}) - PageResult convertVO(PageResult pageResult); - -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectorVersionConvert.java b/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectorVersionConvert.java deleted file mode 100644 index 131d256..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectorVersionConvert.java +++ /dev/null @@ -1,46 +0,0 @@ -package com.docus.server.convert; - -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schcollectorversion.AddSchCollectorVersionDTO; -import com.docus.server.dto.scheduling.management.schcollectorversion.EditSchCollectorVersionDTO; -import com.docus.server.entity.scheduling.management.SchCollectorVersion; -import com.docus.server.vo.scheduling.management.schcollectorversion.SchCollectorVersionVO; -import org.mapstruct.Mapper; -import org.mapstruct.Mappings; -import org.mapstruct.factory.Mappers; - -import java.util.List; - -/** - * 采集器版本列表管理 服务转换器 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Mapper -public interface SchCollectorVersionConvert { - - SchCollectorVersionConvert INSTANCE = Mappers.getMapper(SchCollectorVersionConvert.class); - - @Mappings({}) - SchCollectorVersion convertDO(AddSchCollectorVersionDTO addSchCollectorVersionDTO); - - @Mappings({}) - SchCollectorVersion convertDO(EditSchCollectorVersionDTO editSchCollectorVersionDTO); - - @Mappings({}) - List convertAddDOList(List addSchCollectorVersionDTO); - - @Mappings({}) - List convertEditDOList(List editSchCollectorVersionDTO); - - @Mappings({}) - SchCollectorVersionVO convertVO(SchCollectorVersion schCollectorVersion); - - @Mappings({}) - List convertVO(List schCollectorVersionList); - - @Mappings({}) - PageResult convertVO(PageResult pageResult); -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectorVersionFileConvert.java b/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectorVersionFileConvert.java deleted file mode 100644 index cbfdcac..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectorVersionFileConvert.java +++ /dev/null @@ -1,48 +0,0 @@ -package com.docus.server.convert; - -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectorVersionFile; -import com.docus.server.dto.scheduling.management.schcollectorversionfile.AddSchCollectorVersionFileDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionfile.EditSchCollectorVersionFileDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionfile.DeleteSchCollectorVersionFileDTO; -import com.docus.server.vo.scheduling.management.schcollectorversionfile.SchCollectorVersionFileVO; - -import org.mapstruct.Mapper; -import org.mapstruct.Mappings; -import org.mapstruct.factory.Mappers; - -import java.util.List; - -/** - * 采集器版本列表更新包管理 服务转换器 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Mapper -public interface SchCollectorVersionFileConvert { - - SchCollectorVersionFileConvert INSTANCE = Mappers.getMapper(SchCollectorVersionFileConvert.class); - - @Mappings({}) - SchCollectorVersionFile convertDO(AddSchCollectorVersionFileDTO addSchCollectorVersionFileDTO); - - @Mappings({}) - SchCollectorVersionFile convertDO(EditSchCollectorVersionFileDTO editSchCollectorVersionFileDTO); - - @Mappings({}) - List convertAddDOList(List addSchCollectorVersionFileDTO); - - @Mappings({}) - List convertEditDOList(List editSchCollectorVersionFileDTO); - - @Mappings({}) - SchCollectorVersionFileVO convertVO(SchCollectorVersionFile schCollectorVersionFile); - - @Mappings({}) - List convertVO(List schCollectorVersionFileList); - - @Mappings({}) - PageResult convertVO(PageResult pageResult); -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectorVersionLogConvert.java b/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectorVersionLogConvert.java deleted file mode 100644 index 6ed24c6..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/convert/SchCollectorVersionLogConvert.java +++ /dev/null @@ -1,48 +0,0 @@ -package com.docus.server.convert; - -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectorVersionLog; -import com.docus.server.dto.scheduling.management.schcollectorversionlog.AddSchCollectorVersionLogDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionlog.EditSchCollectorVersionLogDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionlog.DeleteSchCollectorVersionLogDTO; -import com.docus.server.vo.scheduling.management.schcollectorversionlog.SchCollectorVersionLogVO; - -import org.mapstruct.Mapper; -import org.mapstruct.Mappings; -import org.mapstruct.factory.Mappers; - -import java.util.List; - -/** - * 采集器版本更新日志管理 服务转换器 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Mapper -public interface SchCollectorVersionLogConvert { - - SchCollectorVersionLogConvert INSTANCE = Mappers.getMapper(SchCollectorVersionLogConvert.class); - - @Mappings({}) - SchCollectorVersionLog convertDO(AddSchCollectorVersionLogDTO addSchCollectorVersionLogDTO); - - @Mappings({}) - SchCollectorVersionLog convertDO(EditSchCollectorVersionLogDTO editSchCollectorVersionLogDTO); - - @Mappings({}) - List convertAddDOList(List addSchCollectorVersionLogDTO); - - @Mappings({}) - List convertEditDOList(List editSchCollectorVersionLogDTO); - - @Mappings({}) - SchCollectorVersionLogVO convertVO(SchCollectorVersionLog schCollectorVersionLog); - - @Mappings({}) - List convertVO(List schCollectorVersionLogList); - - @Mappings({}) - PageResult convertVO(PageResult pageResult); -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/convert/SchOperationLogConvert.java b/collector-terminal-management/src/main/java/com/docus/server/convert/SchOperationLogConvert.java deleted file mode 100644 index 5c98766..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/convert/SchOperationLogConvert.java +++ /dev/null @@ -1,48 +0,0 @@ -package com.docus.server.convert; - -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchOperationLog; -import com.docus.server.dto.scheduling.management.schoperationlog.AddSchOperationLogDTO; -import com.docus.server.dto.scheduling.management.schoperationlog.EditSchOperationLogDTO; -import com.docus.server.dto.scheduling.management.schoperationlog.DeleteSchOperationLogDTO; -import com.docus.server.vo.scheduling.management.schoperationlog.SchOperationLogVO; - -import org.mapstruct.Mapper; -import org.mapstruct.Mappings; -import org.mapstruct.factory.Mappers; - -import java.util.List; - -/** - * 采集调度器操作日志 服务转换器 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Mapper -public interface SchOperationLogConvert { - - SchOperationLogConvert INSTANCE = Mappers.getMapper(SchOperationLogConvert.class); - - @Mappings({}) - SchOperationLog convertDO(AddSchOperationLogDTO addSchOperationLogDTO); - - @Mappings({}) - SchOperationLog convertDO(EditSchOperationLogDTO editSchOperationLogDTO); - - @Mappings({}) - List convertAddDOList(List addSchOperationLogDTO); - - @Mappings({}) - List convertEditDOList(List editSchOperationLogDTO); - - @Mappings({}) - SchOperationLogVO convertVO(SchOperationLog schOperationLog); - - @Mappings({}) - List convertVO(List schOperationLogList); - - @Mappings({}) - PageResult convertVO(PageResult pageResult); -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/convert/SchSystemParamsConvert.java b/collector-terminal-management/src/main/java/com/docus/server/convert/SchSystemParamsConvert.java deleted file mode 100644 index f3bb4c2..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/convert/SchSystemParamsConvert.java +++ /dev/null @@ -1,48 +0,0 @@ -package com.docus.server.convert; - -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchSystemParams; -import com.docus.server.dto.scheduling.management.schsystemparams.AddSchSystemParamsDTO; -import com.docus.server.dto.scheduling.management.schsystemparams.EditSchSystemParamsDTO; -import com.docus.server.dto.scheduling.management.schsystemparams.DeleteSchSystemParamsDTO; -import com.docus.server.vo.scheduling.management.schsystemparams.SchSystemParamsVO; - -import org.mapstruct.Mapper; -import org.mapstruct.Mappings; -import org.mapstruct.factory.Mappers; - -import java.util.List; - -/** - * 系统参数表 服务转换器 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Mapper -public interface SchSystemParamsConvert { - - SchSystemParamsConvert INSTANCE = Mappers.getMapper(SchSystemParamsConvert.class); - - @Mappings({}) - SchSystemParams convertDO(AddSchSystemParamsDTO addSchSystemParamsDTO); - - @Mappings({}) - SchSystemParams convertDO(EditSchSystemParamsDTO editSchSystemParamsDTO); - - @Mappings({}) - List convertAddDOList(List addSchSystemParamsDTO); - - @Mappings({}) - List convertEditDOList(List editSchSystemParamsDTO); - - @Mappings({}) - SchSystemParamsVO convertVO(SchSystemParams schSystemParams); - - @Mappings({}) - List convertVO(List schSystemParamsList); - - @Mappings({}) - PageResult convertVO(PageResult pageResult); -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/convert/SchTerminatorConvert.java b/collector-terminal-management/src/main/java/com/docus/server/convert/SchTerminatorConvert.java deleted file mode 100644 index 4df7807..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/convert/SchTerminatorConvert.java +++ /dev/null @@ -1,42 +0,0 @@ -package com.docus.server.convert; - -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schterminator.AddSchTerminatorDTO; -import com.docus.server.dto.scheduling.management.schterminator.EditSchTerminatorDTO; -import com.docus.server.entity.scheduling.management.SchTerminator; -import com.docus.server.vo.scheduling.management.schterminator.SchTerminatorVO; -import org.mapstruct.Mapper; -import org.mapstruct.MappingTarget; -import org.mapstruct.Mappings; -import org.mapstruct.factory.Mappers; - -import java.util.List; - -/** - * 执行管理器 服务转换器 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Mapper -public interface SchTerminatorConvert { - - SchTerminatorConvert INSTANCE = Mappers.getMapper(SchTerminatorConvert.class); - - @Mappings({}) - SchTerminator convertDO(AddSchTerminatorDTO addSchTerminatorDTO); - - @Mappings({}) - SchTerminator convertDO(EditSchTerminatorDTO editSchTerminatorDTO, @MappingTarget SchTerminator schTerminator1); - - @Mappings({}) - SchTerminatorVO convertVO(SchTerminator schTerminator); - - @Mappings({}) - List convertVO(List schTerminatorList); - - @Mappings({}) - PageResult convertVO(PageResult pageResult); - -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/convert/SchVirtualLogConvert.java b/collector-terminal-management/src/main/java/com/docus/server/convert/SchVirtualLogConvert.java deleted file mode 100644 index 48555b2..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/convert/SchVirtualLogConvert.java +++ /dev/null @@ -1,46 +0,0 @@ -package com.docus.server.convert; - -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schvirtuallog.AddSchVirtualLogDTO; -import com.docus.server.dto.scheduling.management.schvirtuallog.EditSchVirtualLogDTO; -import com.docus.server.entity.scheduling.management.SchVirtualLog; -import com.docus.server.vo.scheduling.management.schvirtuallog.SchVirtualLogVO; -import org.mapstruct.Mapper; -import org.mapstruct.Mappings; -import org.mapstruct.factory.Mappers; - -import java.util.List; - -/** - * 虚拟机使用情况 服务转换器 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Mapper -public interface SchVirtualLogConvert { - - SchVirtualLogConvert INSTANCE = Mappers.getMapper(SchVirtualLogConvert.class); - - @Mappings({}) - SchVirtualLog convertDO(AddSchVirtualLogDTO addSchVirtualLogDTO); - - @Mappings({}) - SchVirtualLog convertDO(EditSchVirtualLogDTO editSchVirtualLogDTO); - - @Mappings({}) - List convertAddDOList(List addSchVirtualLogDTO); - - @Mappings({}) - List convertEditDOList(List editSchVirtualLogDTO); - - @Mappings({}) - SchVirtualLogVO convertVO(SchVirtualLog schVirtualLog); - - @Mappings({}) - List convertVO(List schVirtualLogList); - - @Mappings({}) - PageResult convertVO(PageResult pageResult); -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectErrorLogDao.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectErrorLogDao.java deleted file mode 100644 index 7b348ba..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectErrorLogDao.java +++ /dev/null @@ -1,57 +0,0 @@ -package com.docus.server.infrastructure.dao; - -import com.docus.infrastructure.core.db.dao.IBaseDao; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectErrorLog; - -import java.util.List; - -/** - * 采集器异常日志 数据访问接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectErrorLogDao extends IBaseDao { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollectErrorLog findById(String id); - - /** - * 新增 - * - * @param schCollectErrorLog 新增参数 - * @return 成功或失败 - */ - boolean add(SchCollectErrorLog schCollectErrorLog); - - /** - * 编辑 - * - * @param schCollectErrorLog 编辑参数 - * @return 成功或失败 - */ - boolean edit(SchCollectErrorLog schCollectErrorLog); - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - int delete(List ids); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectRecordDao.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectRecordDao.java deleted file mode 100644 index 02c920a..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectRecordDao.java +++ /dev/null @@ -1,57 +0,0 @@ -package com.docus.server.infrastructure.dao; - -import com.docus.infrastructure.core.db.dao.IBaseDao; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectRecord; - -import java.util.List; - -/** - * 采集记录表 数据访问接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectRecordDao extends IBaseDao { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollectRecord findById(String id); - - /** - * 新增 - * - * @param schCollectRecord 新增参数 - * @return 成功或失败 - */ - boolean add(SchCollectRecord schCollectRecord); - - /** - * 编辑 - * - * @param schCollectRecord 编辑参数 - * @return 成功或失败 - */ - boolean edit(SchCollectRecord schCollectRecord); - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - int delete(List ids); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectRecordRetryLogDao.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectRecordRetryLogDao.java deleted file mode 100644 index e8e4e67..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectRecordRetryLogDao.java +++ /dev/null @@ -1,57 +0,0 @@ -package com.docus.server.infrastructure.dao; - -import com.docus.infrastructure.core.db.dao.IBaseDao; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectRecordRetryLog; - -import java.util.List; - -/** - * 采集记录表重试表 数据访问接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectRecordRetryLogDao extends IBaseDao { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollectRecordRetryLog findById(String id); - - /** - * 新增 - * - * @param schCollectRecordRetryLog 新增参数 - * @return 成功或失败 - */ - boolean add(SchCollectRecordRetryLog schCollectRecordRetryLog); - - /** - * 编辑 - * - * @param schCollectRecordRetryLog 编辑参数 - * @return 成功或失败 - */ - boolean edit(SchCollectRecordRetryLog schCollectRecordRetryLog); - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - int delete(List ids); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectorConfigDao.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectorConfigDao.java deleted file mode 100644 index 77667d7..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectorConfigDao.java +++ /dev/null @@ -1,57 +0,0 @@ -package com.docus.server.infrastructure.dao; - -import com.docus.infrastructure.core.db.dao.IBaseDao; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectorConfig; - -import java.util.List; - -/** - * 采集器配置 数据访问接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectorConfigDao extends IBaseDao { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollectorConfig findById(String id); - - /** - * 新增 - * - * @param schCollectorConfig 新增参数 - * @return 成功或失败 - */ - boolean add(SchCollectorConfig schCollectorConfig); - - /** - * 编辑 - * - * @param schCollectorConfig 编辑参数 - * @return 成功或失败 - */ - boolean edit(SchCollectorConfig schCollectorConfig); - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - int delete(List ids); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectorDao.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectorDao.java deleted file mode 100644 index 0c01fea..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectorDao.java +++ /dev/null @@ -1,57 +0,0 @@ -package com.docus.server.infrastructure.dao; - -import com.docus.infrastructure.core.db.dao.IBaseDao; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollector; - -import java.util.List; - -/** - * 采集器管理 数据访问接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectorDao extends IBaseDao { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollector findById(String id); - - /** - * 新增 - * - * @param schCollector 新增参数 - * @return 成功或失败 - */ - boolean add(SchCollector schCollector); - - /** - * 编辑 - * - * @param schCollector 编辑参数 - * @return 成功或失败 - */ - boolean edit(SchCollector schCollector); - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - int delete(List ids); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectorVersionDao.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectorVersionDao.java deleted file mode 100644 index 6922d3e..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectorVersionDao.java +++ /dev/null @@ -1,66 +0,0 @@ -package com.docus.server.infrastructure.dao; - -import com.docus.infrastructure.core.db.dao.IBaseDao; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectorVersion; - -import java.util.List; - -/** - * 采集器版本列表管理 数据访问接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectorVersionDao extends IBaseDao { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollectorVersion findById(String id); - - /** - * 新增 - * - * @param schCollectorVersion 新增参数 - * @return 成功或失败 - */ - boolean add(SchCollectorVersion schCollectorVersion); - - /** - * 编辑 - * - * @param schCollectorVersion 编辑参数 - * @return 成功或失败 - */ - boolean edit(SchCollectorVersion schCollectorVersion); - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - int delete(List ids); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - - /** - * 根据采集器id和版本号查询是否重复 - * - * @param collectorId 采集器id - * @param collectorVersionNo 版本号码 - * @return SchCollectorVersion - */ - SchCollectorVersion findByVersion(Long collectorId, String collectorVersionNo); - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectorVersionFileDao.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectorVersionFileDao.java deleted file mode 100644 index 7ad13d0..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectorVersionFileDao.java +++ /dev/null @@ -1,58 +0,0 @@ -package com.docus.server.infrastructure.dao; - -import com.docus.infrastructure.core.db.dao.IBaseDao; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectorVersionFile; - -import java.util.List; - -/** - * 采集器版本列表更新包管理 数据访问接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectorVersionFileDao extends IBaseDao { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollectorVersionFile findById(String id); - - /** - * 新增 - * - * @param schCollectorVersionFile 新增参数 - * @return 成功或失败 - */ - boolean add(SchCollectorVersionFile schCollectorVersionFile); - - /** - * 编辑 - * - * @param schCollectorVersionFile 编辑参数 - * @return 成功或失败 - */ - boolean edit(SchCollectorVersionFile schCollectorVersionFile); - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - int delete(List ids); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - - SchCollectorVersionFile findByVersionIdAndCollectorId(Long collectorId, Long collectorVersionId); -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectorVersionLogDao.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectorVersionLogDao.java deleted file mode 100644 index b643b9d..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchCollectorVersionLogDao.java +++ /dev/null @@ -1,57 +0,0 @@ -package com.docus.server.infrastructure.dao; - -import com.docus.infrastructure.core.db.dao.IBaseDao; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectorVersionLog; - -import java.util.List; - -/** - * 采集器版本更新日志管理 数据访问接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectorVersionLogDao extends IBaseDao { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollectorVersionLog findById(String id); - - /** - * 新增 - * - * @param schCollectorVersionLog 新增参数 - * @return 成功或失败 - */ - boolean add(SchCollectorVersionLog schCollectorVersionLog); - - /** - * 编辑 - * - * @param schCollectorVersionLog 编辑参数 - * @return 成功或失败 - */ - boolean edit(SchCollectorVersionLog schCollectorVersionLog); - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - int delete(List ids); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchOperationLogDao.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchOperationLogDao.java deleted file mode 100644 index c7cd7f0..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchOperationLogDao.java +++ /dev/null @@ -1,57 +0,0 @@ -package com.docus.server.infrastructure.dao; - -import com.docus.infrastructure.core.db.dao.IBaseDao; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchOperationLog; - -import java.util.List; - -/** - * 采集调度器操作日志 数据访问接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchOperationLogDao extends IBaseDao { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchOperationLog findById(String id); - - /** - * 新增 - * - * @param schOperationLog 新增参数 - * @return 成功或失败 - */ - boolean add(SchOperationLog schOperationLog); - - /** - * 编辑 - * - * @param schOperationLog 编辑参数 - * @return 成功或失败 - */ - boolean edit(SchOperationLog schOperationLog); - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - int delete(List ids); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchSystemParamsDao.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchSystemParamsDao.java deleted file mode 100644 index c0a6f92..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchSystemParamsDao.java +++ /dev/null @@ -1,57 +0,0 @@ -package com.docus.server.infrastructure.dao; - -import com.docus.infrastructure.core.db.dao.IBaseDao; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchSystemParams; - -import java.util.List; - -/** - * 系统参数表 数据访问接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchSystemParamsDao extends IBaseDao { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchSystemParams findById(String id); - - /** - * 新增 - * - * @param schSystemParams 新增参数 - * @return 成功或失败 - */ - boolean add(SchSystemParams schSystemParams); - - /** - * 编辑 - * - * @param schSystemParams 编辑参数 - * @return 成功或失败 - */ - boolean edit(SchSystemParams schSystemParams); - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - int delete(List ids); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchTerminatorDao.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchTerminatorDao.java deleted file mode 100644 index dc31c51..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchTerminatorDao.java +++ /dev/null @@ -1,57 +0,0 @@ -package com.docus.server.infrastructure.dao; - -import com.docus.infrastructure.core.db.dao.IBaseDao; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchTerminator; - -import java.util.List; - -/** - * 执行管理器 数据访问接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchTerminatorDao extends IBaseDao { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchTerminator findById(String id); - - /** - * 新增 - * - * @param schTerminator 新增参数 - * @return 成功或失败 - */ - boolean add(SchTerminator schTerminator); - - /** - * 编辑 - * - * @param schTerminator 编辑参数 - * @return 成功或失败 - */ - boolean edit(SchTerminator schTerminator); - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - int delete(List ids); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchVirtualLogDao.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchVirtualLogDao.java deleted file mode 100644 index 3c4d740..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/ISchVirtualLogDao.java +++ /dev/null @@ -1,57 +0,0 @@ -package com.docus.server.infrastructure.dao; - -import com.docus.infrastructure.core.db.dao.IBaseDao; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchVirtualLog; - -import java.util.List; - -/** - * 虚拟机使用情况 数据访问接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchVirtualLogDao extends IBaseDao { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchVirtualLog findById(String id); - - /** - * 新增 - * - * @param schVirtualLog 新增参数 - * @return 成功或失败 - */ - boolean add(SchVirtualLog schVirtualLog); - - /** - * 编辑 - * - * @param schVirtualLog 编辑参数 - * @return 成功或失败 - */ - boolean edit(SchVirtualLog schVirtualLog); - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - int delete(List ids); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectErrorLogDaoImpl.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectErrorLogDaoImpl.java deleted file mode 100644 index 7b5d50d..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectErrorLogDaoImpl.java +++ /dev/null @@ -1,104 +0,0 @@ -package com.docus.server.infrastructure.dao.impl; - -import com.baomidou.mybatisplus.core.conditions.query.LambdaQueryWrapper; -import com.baomidou.mybatisplus.core.toolkit.Wrappers; -import com.docus.infrastructure.core.db.dao.impl.BaseDaoImpl; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectErrorLog; -import com.docus.server.infrastructure.dao.ISchCollectErrorLogDao; -import com.docus.server.infrastructure.mapper.SchCollectErrorLogMapper; -import com.github.pagehelper.PageHelper; -import org.springframework.stereotype.Repository; - -import java.util.Date; -import java.util.List; - -/** - * 采集器异常日志 数据访问实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Repository -public class SchCollectErrorLogDaoImpl extends BaseDaoImpl implements ISchCollectErrorLogDao { - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectErrorLog findById(String id) { - return super.findById(id); - } - - /** - * 新增 - * - * @param schCollectErrorLog 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(SchCollectErrorLog schCollectErrorLog) { - return super.save(schCollectErrorLog); - } - - /** - * 编辑 - * - * @param schCollectErrorLog 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(SchCollectErrorLog schCollectErrorLog) { - return super.updateById(schCollectErrorLog); - } - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - @Override - public int delete(List ids) { - return super.deleteByIds(ids); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - //分页 - PageHelper.startPage(searchDTO.getPageNum(), searchDTO.getPageSize()); - LambdaQueryWrapper query = Wrappers.lambdaQuery(); - //时间范围,默认按createTime - if (searchDTO.getBeginTime() != null) { - query.ge(SchCollectErrorLog::getCreateTime, searchDTO.getBeginTime()); - } - if (searchDTO.getEndTime() != null) { - Date endTime = searchDTO.getEndTime(); - query.le(SchCollectErrorLog::getCreateTime, endTime); - } - //关键字比较,多个列or - //if (!StringUtils.isEmpty(searchDTO.getKeyword())) { - //单个列用like - //query. like(SchCollectErrorLog::getxxx, searchDTO.getKeyword()); - //多个列用like - //query. and(sub -> sub.like(SchCollectErrorLog::getxx1, searchDTO.getKeyword()) - // оr(). like(SchCollectErrorLog::getXX2, searchDTO.getKeyword())) - //); - //} - //默认createTime倒序排序 - query.orderByDesc(SchCollectErrorLog::getCreateTime); - List list = super.find(query); - return new PageResult<>(list); - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectRecordDaoImpl.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectRecordDaoImpl.java deleted file mode 100644 index 7bc4249..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectRecordDaoImpl.java +++ /dev/null @@ -1,101 +0,0 @@ -package com.docus.server.infrastructure.dao.impl; - -import com.baomidou.mybatisplus.core.conditions.query.LambdaQueryWrapper; -import com.baomidou.mybatisplus.core.toolkit.Wrappers; -import com.docus.core.util.Func; -import com.docus.infrastructure.core.db.dao.impl.BaseDaoImpl; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectRecord; -import com.docus.server.infrastructure.dao.ISchCollectRecordDao; -import com.docus.server.infrastructure.mapper.SchCollectRecordMapper; -import com.github.pagehelper.PageHelper; -import org.springframework.stereotype.Repository; - -import java.util.List; - -/** - * 采集记录表 数据访问实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Repository -public class SchCollectRecordDaoImpl extends BaseDaoImpl implements ISchCollectRecordDao { - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectRecord findById(String id) { - return super.findById(id); - } - - /** - * 新增 - * - * @param schCollectRecord 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(SchCollectRecord schCollectRecord) { - return super.save(schCollectRecord); - } - - /** - * 编辑 - * - * @param schCollectRecord 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(SchCollectRecord schCollectRecord) { - return super.updateById(schCollectRecord); - } - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - @Override - public int delete(List ids) { - return super.deleteByIds(ids); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - //分页 - PageHelper.startPage(searchDTO.getPageNum(), searchDTO.getPageSize()); - LambdaQueryWrapper query = Wrappers.lambdaQuery(); - //时间范围,默认按createTime - if (searchDTO.getBeginTime() != null) { - query.ge(SchCollectRecord::getCreateTime, searchDTO.getBeginTime()); - } - if (searchDTO.getEndTime() != null) { - query.le(SchCollectRecord::getCreateTime, searchDTO.getEndTime()); - } - - Object collectorId = searchDTO.getParams("collectorId"); - - if (Func.isNotEmpty(collectorId)) { - query.eq(SchCollectRecord::getCollectorId, collectorId); - } - - //默认createTime倒序排序 - query.orderByDesc(SchCollectRecord::getCreateTime); - List list = super.find(query); - return new PageResult<>(list); - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectRecordRetryLogDaoImpl.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectRecordRetryLogDaoImpl.java deleted file mode 100644 index b946fdf..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectRecordRetryLogDaoImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -package com.docus.server.infrastructure.dao.impl; - -import com.baomidou.mybatisplus.core.conditions.query.LambdaQueryWrapper; -import com.baomidou.mybatisplus.core.toolkit.Wrappers; -import com.docus.core.util.Func; -import com.docus.infrastructure.core.db.dao.impl.BaseDaoImpl; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectRecordRetryLog; -import com.docus.server.infrastructure.dao.ISchCollectRecordRetryLogDao; -import com.docus.server.infrastructure.mapper.SchCollectRecordRetryLogMapper; -import com.github.pagehelper.PageHelper; -import org.springframework.stereotype.Repository; - -import java.util.List; - -/** - * 采集记录表重试表 数据访问实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Repository -public class SchCollectRecordRetryLogDaoImpl extends BaseDaoImpl implements ISchCollectRecordRetryLogDao { - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectRecordRetryLog findById(String id) { - return super.findById(id); - } - - /** - * 新增 - * - * @param schCollectRecordRetryLog 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(SchCollectRecordRetryLog schCollectRecordRetryLog) { - return super.save(schCollectRecordRetryLog); - } - - /** - * 编辑 - * - * @param schCollectRecordRetryLog 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(SchCollectRecordRetryLog schCollectRecordRetryLog) { - return super.updateById(schCollectRecordRetryLog); - } - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - @Override - public int delete(List ids) { - return super.deleteByIds(ids); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - //分页 - PageHelper.startPage(searchDTO.getPageNum(), searchDTO.getPageSize()); - LambdaQueryWrapper query = Wrappers.lambdaQuery(); - //时间范围,默认按createTime - if (searchDTO.getBeginTime() != null) { - query.ge(SchCollectRecordRetryLog::getCreateTime, searchDTO.getBeginTime()); - } - if (searchDTO.getEndTime() != null) { - query.le(SchCollectRecordRetryLog::getCreateTime, searchDTO.getEndTime()); - } - - Object collectorId = searchDTO.getParams("collectorId"); - - if (Func.isNotEmpty(collectorId)) { - query.eq(SchCollectRecordRetryLog::getCollectorId, collectorId); - } - //默认createTime倒序排序 - query.orderByDesc(SchCollectRecordRetryLog::getCreateTime); - List list = super.find(query); - return new PageResult<>(list); - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectorConfigDaoImpl.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectorConfigDaoImpl.java deleted file mode 100644 index 4a8a128..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectorConfigDaoImpl.java +++ /dev/null @@ -1,109 +0,0 @@ -package com.docus.server.infrastructure.dao.impl; - -import com.baomidou.mybatisplus.core.conditions.query.LambdaQueryWrapper; -import com.baomidou.mybatisplus.core.toolkit.Wrappers; -import com.docus.infrastructure.core.db.dao.impl.BaseDaoImpl; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectorConfig; -import com.docus.server.infrastructure.dao.ISchCollectorConfigDao; -import com.docus.server.infrastructure.mapper.SchCollectorConfigMapper; -import com.github.pagehelper.PageHelper; -import org.springframework.stereotype.Repository; - -import java.util.Date; -import java.util.List; - -/** - * 采集器配置 数据访问实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Repository -public class SchCollectorConfigDaoImpl extends BaseDaoImpl implements ISchCollectorConfigDao { - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectorConfig findById(String id) { - return super.findById(id); - } - - /** - * 新增 - * - * @param schCollectorConfig 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(SchCollectorConfig schCollectorConfig) { - return super.save(schCollectorConfig); - } - - /** - * 编辑 - * - * @param schCollectorConfig 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(SchCollectorConfig schCollectorConfig) { - return super.updateById(schCollectorConfig); - } - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - @Override - public int delete(List ids) { - return super.deleteByIds(ids); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - //分页 - PageHelper.startPage(searchDTO.getPageNum(), searchDTO.getPageSize()); - LambdaQueryWrapper query = Wrappers.lambdaQuery(); - //时间范围,默认按createTime - if (searchDTO.getBeginTime() != null) { - query.ge(SchCollectorConfig::getCreateTime, searchDTO.getBeginTime()); - } - if (searchDTO.getEndTime() != null) { - Date endTime = searchDTO.getEndTime(); - query.le(SchCollectorConfig::getCreateTime, endTime); - } - - if (searchDTO.getParams("collectorId") != null && searchDTO.getParams("collectorId") != "") { - query.eq(SchCollectorConfig::getCollectorId, searchDTO.getParams("collectorId")); - } - - if (searchDTO.getParams("configType") != null && searchDTO.getParams("configType") != "") { - query.eq(SchCollectorConfig::getConfigType, searchDTO.getParams("configType")); - } - - if (searchDTO.getEndTime() != null) { - Date endTime = searchDTO.getEndTime(); - query.le(SchCollectorConfig::getCreateTime, endTime); - } - - //默认createTime倒序排序 - query.orderByDesc(SchCollectorConfig::getCreateTime); - List list = super.find(query); - return new PageResult<>(list); - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectorDaoImpl.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectorDaoImpl.java deleted file mode 100644 index b7a4582..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectorDaoImpl.java +++ /dev/null @@ -1,102 +0,0 @@ -package com.docus.server.infrastructure.dao.impl; - -import com.baomidou.mybatisplus.core.conditions.query.LambdaQueryWrapper; -import com.baomidou.mybatisplus.core.toolkit.Wrappers; -import com.docus.core.util.Func; -import com.docus.infrastructure.core.db.dao.impl.BaseDaoImpl; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollector; -import com.docus.server.infrastructure.dao.ISchCollectorDao; -import com.docus.server.infrastructure.mapper.SchCollectorMapper; -import com.github.pagehelper.PageHelper; -import org.springframework.stereotype.Repository; - -import java.util.Date; -import java.util.List; - -/** - * 采集器管理 数据访问实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Repository -public class SchCollectorDaoImpl extends BaseDaoImpl implements ISchCollectorDao { - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollector findById(String id) { - return super.findById(id); - } - - /** - * 新增 - * - * @param schCollector 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(SchCollector schCollector) { - return super.save(schCollector); - } - - /** - * 编辑 - * - * @param schCollector 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(SchCollector schCollector) { - return super.updateById(schCollector); - } - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - @Override - public int delete(List ids) { - return super.deleteByIds(ids); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - //分页 - PageHelper.startPage(searchDTO.getPageNum(), searchDTO.getPageSize()); - LambdaQueryWrapper query = Wrappers.lambdaQuery(); - //时间范围,默认按createTime - if (searchDTO.getBeginTime() != null) { - query.ge(SchCollector::getCreateTime, searchDTO.getBeginTime()); - } - if (searchDTO.getEndTime() != null) { - Date endTime = searchDTO.getEndTime(); - query.le(SchCollector::getCreateTime, endTime); - } - - Object collectorId = searchDTO.getParams("collectorId"); - if (Func.isNotEmpty(collectorId)) { - query.eq(SchCollector::getCollectorId, collectorId); - } - - //默认createTime倒序排序 - query.orderByDesc(SchCollector::getCreateTime); - List list = super.find(query); - return new PageResult<>(list); - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectorVersionDaoImpl.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectorVersionDaoImpl.java deleted file mode 100644 index 5b2d1af..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectorVersionDaoImpl.java +++ /dev/null @@ -1,117 +0,0 @@ -package com.docus.server.infrastructure.dao.impl; - -import com.baomidou.mybatisplus.core.conditions.query.LambdaQueryWrapper; -import com.baomidou.mybatisplus.core.toolkit.Wrappers; -import com.docus.core.util.Func; -import com.docus.infrastructure.core.db.dao.impl.BaseDaoImpl; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectorVersion; -import com.docus.server.infrastructure.dao.ISchCollectorVersionDao; -import com.docus.server.infrastructure.mapper.SchCollectorVersionMapper; -import com.github.pagehelper.PageHelper; -import org.springframework.stereotype.Repository; - -import java.util.Date; -import java.util.List; - -/** - * 采集器版本列表管理 数据访问实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Repository -public class SchCollectorVersionDaoImpl extends BaseDaoImpl implements ISchCollectorVersionDao { - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectorVersion findById(String id) { - return super.findById(id); - } - - /** - * 新增 - * - * @param schCollectorVersion 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(SchCollectorVersion schCollectorVersion) { - return super.save(schCollectorVersion); - } - - /** - * 编辑 - * - * @param schCollectorVersion 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(SchCollectorVersion schCollectorVersion) { - return super.updateById(schCollectorVersion); - } - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - @Override - public int delete(List ids) { - return super.deleteByIds(ids); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - //分页 - PageHelper.startPage(searchDTO.getPageNum(), searchDTO.getPageSize()); - LambdaQueryWrapper query = Wrappers.lambdaQuery(); - //时间范围,默认按createTime - if (searchDTO.getBeginTime() != null) { - query.ge(SchCollectorVersion::getCreateTime, searchDTO.getBeginTime()); - } - if (searchDTO.getEndTime() != null) { - Date endTime = searchDTO.getEndTime(); - query.le(SchCollectorVersion::getCreateTime, endTime); - } - - Object collectorId = searchDTO.getParams("collectorId"); - if (Func.isNotEmpty(collectorId)) { - query.eq(SchCollectorVersion::getCollectorId, collectorId); - } - - //默认createTime倒序排序 - query.orderByDesc(SchCollectorVersion::getCreateTime); - List list = super.find(query); - return new PageResult<>(list); - } - - @Override - public SchCollectorVersion findByVersion(Long collectorId, String collectorVersionNo) { - LambdaQueryWrapper query = Wrappers.lambdaQuery(); - - if (Func.isNotEmpty(collectorId)) { - query.ge(SchCollectorVersion::getCollectorId, collectorId); - } - if (Func.isNotBlank(collectorVersionNo)) { - query.le(SchCollectorVersion::getCollectVersion, collectorVersionNo); - } - - return super.findOne(query); - - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectorVersionFileDaoImpl.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectorVersionFileDaoImpl.java deleted file mode 100644 index 35bdb84..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectorVersionFileDaoImpl.java +++ /dev/null @@ -1,112 +0,0 @@ -package com.docus.server.infrastructure.dao.impl; - -import com.baomidou.mybatisplus.core.conditions.query.LambdaQueryWrapper; -import com.baomidou.mybatisplus.core.toolkit.Wrappers; -import com.docus.core.util.Func; -import com.docus.infrastructure.core.db.dao.impl.BaseDaoImpl; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectorVersionFile; -import com.docus.server.enums.CancelEnum; -import com.docus.server.infrastructure.dao.ISchCollectorVersionFileDao; -import com.docus.server.infrastructure.mapper.SchCollectorVersionFileMapper; -import com.github.pagehelper.PageHelper; -import org.springframework.stereotype.Repository; - -import java.util.Date; -import java.util.List; - -/** - * 采集器版本列表更新包管理 数据访问实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Repository -public class SchCollectorVersionFileDaoImpl extends BaseDaoImpl implements ISchCollectorVersionFileDao { - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectorVersionFile findById(String id) { - return super.findById(id); - } - - /** - * 新增 - * - * @param schCollectorVersionFile 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(SchCollectorVersionFile schCollectorVersionFile) { - return super.save(schCollectorVersionFile); - } - - /** - * 编辑 - * - * @param schCollectorVersionFile 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(SchCollectorVersionFile schCollectorVersionFile) { - return super.updateById(schCollectorVersionFile); - } - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - @Override - public int delete(List ids) { - return super.deleteByIds(ids); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - //分页 - PageHelper.startPage(searchDTO.getPageNum(), searchDTO.getPageSize()); - LambdaQueryWrapper query = Wrappers.lambdaQuery(); - //时间范围,默认按createTime - if (searchDTO.getBeginTime() != null) { - query.ge(SchCollectorVersionFile::getCreateTime, searchDTO.getBeginTime()); - } - if (searchDTO.getEndTime() != null) { - Date endTime = searchDTO.getEndTime(); - query.le(SchCollectorVersionFile::getCreateTime, endTime); - } - - //默认createTime倒序排序 - query.orderByDesc(SchCollectorVersionFile::getCreateTime); - List list = super.find(query); - return new PageResult<>(list); - } - - @Override - public SchCollectorVersionFile findByVersionIdAndCollectorId(Long collectorId, Long collectorVersionId) { - LambdaQueryWrapper query = Wrappers.lambdaQuery(); - if (Func.isNotEmpty(collectorId)) { - query.eq(SchCollectorVersionFile::getCollectorId, collectorId); - } - if (Func.isNotEmpty(collectorVersionId)) { - query.eq(SchCollectorVersionFile::getCollectorVersionId, collectorVersionId); - } - query.ne(SchCollectorVersionFile::getState, CancelEnum.CANCEL); - - return super.findOne(query); - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectorVersionLogDaoImpl.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectorVersionLogDaoImpl.java deleted file mode 100644 index f18fe88..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchCollectorVersionLogDaoImpl.java +++ /dev/null @@ -1,100 +0,0 @@ -package com.docus.server.infrastructure.dao.impl; - -import com.baomidou.mybatisplus.core.conditions.query.LambdaQueryWrapper; -import com.baomidou.mybatisplus.core.toolkit.Wrappers; -import com.docus.core.util.Func; -import com.docus.infrastructure.core.db.dao.impl.BaseDaoImpl; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchCollectorVersionLog; -import com.docus.server.infrastructure.dao.ISchCollectorVersionLogDao; -import com.docus.server.infrastructure.mapper.SchCollectorVersionLogMapper; -import com.github.pagehelper.PageHelper; -import org.springframework.stereotype.Repository; - -import java.util.Date; -import java.util.List; - -/** - * 采集器版本更新日志管理 数据访问实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Repository -public class SchCollectorVersionLogDaoImpl extends BaseDaoImpl implements ISchCollectorVersionLogDao { - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectorVersionLog findById(String id) { - return super.findById(id); - } - - /** - * 新增 - * - * @param schCollectorVersionLog 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(SchCollectorVersionLog schCollectorVersionLog) { - return super.save(schCollectorVersionLog); - } - - /** - * 编辑 - * - * @param schCollectorVersionLog 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(SchCollectorVersionLog schCollectorVersionLog) { - return super.updateById(schCollectorVersionLog); - } - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - @Override - public int delete(List ids) { - return super.deleteByIds(ids); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - //分页 - PageHelper.startPage(searchDTO.getPageNum(), searchDTO.getPageSize()); - LambdaQueryWrapper query = Wrappers.lambdaQuery(); - //时间范围,默认按createTime - if (searchDTO.getBeginTime() != null) { - query.ge(SchCollectorVersionLog::getCreateTime, searchDTO.getBeginTime()); - } - if (searchDTO.getEndTime() != null) { - Date endTime = searchDTO.getEndTime(); - query.le(SchCollectorVersionLog::getCreateTime, endTime); - } - Object collectorId = searchDTO.getParams("collectorId"); - if (Func.isNotEmpty(collectorId)) { - query.eq(SchCollectorVersionLog::getCollectorId, collectorId); - } - //默认createTime倒序排序 - query.orderByDesc(SchCollectorVersionLog::getCreateTime); - List list = super.find(query); - return new PageResult<>(list); - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchOperationLogDaoImpl.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchOperationLogDaoImpl.java deleted file mode 100644 index 15ee014..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchOperationLogDaoImpl.java +++ /dev/null @@ -1,104 +0,0 @@ -package com.docus.server.infrastructure.dao.impl; - -import com.baomidou.mybatisplus.core.conditions.query.LambdaQueryWrapper; -import com.baomidou.mybatisplus.core.toolkit.Wrappers; -import com.docus.infrastructure.core.db.dao.impl.BaseDaoImpl; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchOperationLog; -import com.docus.server.infrastructure.dao.ISchOperationLogDao; -import com.docus.server.infrastructure.mapper.SchOperationLogMapper; -import com.github.pagehelper.PageHelper; -import org.springframework.stereotype.Repository; - -import java.util.Date; -import java.util.List; - -/** - * 采集调度器操作日志 数据访问实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Repository -public class SchOperationLogDaoImpl extends BaseDaoImpl implements ISchOperationLogDao { - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchOperationLog findById(String id) { - return super.findById(id); - } - - /** - * 新增 - * - * @param schOperationLog 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(SchOperationLog schOperationLog) { - return super.save(schOperationLog); - } - - /** - * 编辑 - * - * @param schOperationLog 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(SchOperationLog schOperationLog) { - return super.updateById(schOperationLog); - } - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - @Override - public int delete(List ids) { - return super.deleteByIds(ids); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - //分页 - PageHelper.startPage(searchDTO.getPageNum(), searchDTO.getPageSize()); - LambdaQueryWrapper query = Wrappers.lambdaQuery(); - //时间范围,默认按createTime - if (searchDTO.getBeginTime() != null) { - query.ge(SchOperationLog::getCreateTime, searchDTO.getBeginTime()); - } - if (searchDTO.getEndTime() != null) { - Date endTime = searchDTO.getEndTime(); - query.le(SchOperationLog::getCreateTime, endTime); - } - //关键字比较,多个列or - //if (!StringUtils.isEmpty(searchDTO.getKeyword())) { - //单个列用like - //query. like(SchOperationLog::getxxx, searchDTO.getKeyword()); - //多个列用like - //query. and(sub -> sub.like(SchOperationLog::getxx1, searchDTO.getKeyword()) - // оr(). like(SchOperationLog::getXX2, searchDTO.getKeyword())) - //); - //} - //默认createTime倒序排序 - query.orderByDesc(SchOperationLog::getCreateTime); - List list = super.find(query); - return new PageResult<>(list); - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchSystemParamsDaoImpl.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchSystemParamsDaoImpl.java deleted file mode 100644 index aee63ab..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchSystemParamsDaoImpl.java +++ /dev/null @@ -1,103 +0,0 @@ -package com.docus.server.infrastructure.dao.impl; - -import com.baomidou.mybatisplus.core.conditions.query.LambdaQueryWrapper; -import com.baomidou.mybatisplus.core.toolkit.Wrappers; -import com.docus.core.util.Func; -import com.docus.infrastructure.core.db.dao.impl.BaseDaoImpl; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchSystemParams; -import com.docus.server.infrastructure.dao.ISchSystemParamsDao; -import com.docus.server.infrastructure.mapper.SchSystemParamsMapper; -import com.github.pagehelper.PageHelper; -import org.springframework.stereotype.Repository; - -import java.util.Date; -import java.util.List; - -/** - * 系统参数表 数据访问实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Repository -public class SchSystemParamsDaoImpl extends BaseDaoImpl implements ISchSystemParamsDao { - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchSystemParams findById(String id) { - return super.findById(id); - } - - /** - * 新增 - * - * @param schSystemParams 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(SchSystemParams schSystemParams) { - return super.save(schSystemParams); - } - - /** - * 编辑 - * - * @param schSystemParams 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(SchSystemParams schSystemParams) { - return super.updateById(schSystemParams); - } - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - @Override - public int delete(List ids) { - return super.deleteByIds(ids); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - //分页 - PageHelper.startPage(searchDTO.getPageNum(), searchDTO.getPageSize()); - LambdaQueryWrapper query = Wrappers.lambdaQuery(); - //时间范围,默认按createTime - if (searchDTO.getBeginTime() != null) { - query.ge(SchSystemParams::getCreateTime, searchDTO.getBeginTime()); - } - if (searchDTO.getEndTime() != null) { - Date endTime = searchDTO.getEndTime(); - query.le(SchSystemParams::getCreateTime, endTime); - } - - //分组查询系统参数表 - String paramGroup = String.valueOf(searchDTO.getParams("paramGroup")); - if (Func.isNotBlank(paramGroup)) { - query.eq(SchSystemParams::getParamGroup, paramGroup); - } - - //默认createTime倒序排序 - query.orderByDesc(SchSystemParams::getCreateTime); - List list = super.find(query); - return new PageResult<>(list); - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchTerminatorDaoImpl.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchTerminatorDaoImpl.java deleted file mode 100644 index dfe4493..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchTerminatorDaoImpl.java +++ /dev/null @@ -1,101 +0,0 @@ -package com.docus.server.infrastructure.dao.impl; - -import com.baomidou.mybatisplus.core.conditions.query.LambdaQueryWrapper; -import com.baomidou.mybatisplus.core.toolkit.Wrappers; -import com.docus.infrastructure.core.db.dao.impl.BaseDaoImpl; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchTerminator; -import com.docus.server.infrastructure.dao.ISchTerminatorDao; -import com.docus.server.infrastructure.mapper.SchTerminatorMapper; -import com.github.pagehelper.PageHelper; -import org.springframework.stereotype.Repository; - -import java.util.Date; -import java.util.List; - -/** - * 执行管理器 数据访问实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Repository -public class SchTerminatorDaoImpl extends BaseDaoImpl implements ISchTerminatorDao { - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchTerminator findById(String id) { - return super.findById(id); - } - - /** - * 新增 - * - * @param schTerminator 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(SchTerminator schTerminator) { - return super.save(schTerminator); - } - - /** - * 编辑 - * - * @param schTerminator 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(SchTerminator schTerminator) { - return super.updateById(schTerminator); - } - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - @Override - public int delete(List ids) { - return super.deleteByIds(ids); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - //分页 - PageHelper.startPage(searchDTO.getPageNum(), searchDTO.getPageSize()); - LambdaQueryWrapper query = Wrappers.lambdaQuery(); - //时间范围,默认按createTime - if (searchDTO.getBeginTime() != null) { - query.ge(SchTerminator::getCreateTime, searchDTO.getBeginTime()); - } - if (searchDTO.getEndTime() != null) { - Date endTime = searchDTO.getEndTime(); - query.le(SchTerminator::getCreateTime, endTime); - } - - //在线状态 - if (searchDTO.getParams("onlineState") != null) { - query.eq(SchTerminator::getOnlineState, searchDTO.getParams("onlineState")); - } - - //默认createTime倒序排序 - query.orderByDesc(SchTerminator::getCreateTime); - List list = super.find(query); - return new PageResult<>(list); - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchVirtualLogDaoImpl.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchVirtualLogDaoImpl.java deleted file mode 100644 index 685a5ce..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/dao/impl/SchVirtualLogDaoImpl.java +++ /dev/null @@ -1,104 +0,0 @@ -package com.docus.server.infrastructure.dao.impl; - -import com.baomidou.mybatisplus.core.conditions.query.LambdaQueryWrapper; -import com.baomidou.mybatisplus.core.toolkit.Wrappers; -import com.docus.infrastructure.core.db.dao.impl.BaseDaoImpl; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.entity.scheduling.management.SchVirtualLog; -import com.docus.server.infrastructure.dao.ISchVirtualLogDao; -import com.docus.server.infrastructure.mapper.SchVirtualLogMapper; -import com.github.pagehelper.PageHelper; -import org.springframework.stereotype.Repository; - -import java.util.Date; -import java.util.List; - -/** - * 虚拟机使用情况 数据访问实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Repository -public class SchVirtualLogDaoImpl extends BaseDaoImpl implements ISchVirtualLogDao { - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchVirtualLog findById(String id) { - return super.findById(id); - } - - /** - * 新增 - * - * @param schVirtualLog 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(SchVirtualLog schVirtualLog) { - return super.save(schVirtualLog); - } - - /** - * 编辑 - * - * @param schVirtualLog 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(SchVirtualLog schVirtualLog) { - return super.updateById(schVirtualLog); - } - - /** - * 批量删除 - * - * @param ids 主键ids - * @return 成功或失败 - */ - @Override - public int delete(List ids) { - return super.deleteByIds(ids); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - //分页 - PageHelper.startPage(searchDTO.getPageNum(), searchDTO.getPageSize()); - LambdaQueryWrapper query = Wrappers.lambdaQuery(); - //时间范围,默认按createTime - if (searchDTO.getBeginTime() != null) { - query.ge(SchVirtualLog::getCreateTime, searchDTO.getBeginTime()); - } - if (searchDTO.getEndTime() != null) { - Date endTime = searchDTO.getEndTime(); - query.le(SchVirtualLog::getCreateTime, endTime); - } - //关键字比较,多个列or - //if (!StringUtils.isEmpty(searchDTO.getKeyword())) { - //单个列用like - //query. like(SchVirtualLog::getxxx, searchDTO.getKeyword()); - //多个列用like - //query. and(sub -> sub.like(SchVirtualLog::getxx1, searchDTO.getKeyword()) - // оr(). like(SchVirtualLog::getXX2, searchDTO.getKeyword())) - //); - //} - //默认createTime倒序排序 - query.orderByDesc(SchVirtualLog::getCreateTime); - List list = super.find(query); - return new PageResult<>(list); - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectErrorLogMapper.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectErrorLogMapper.java deleted file mode 100644 index edae3c3..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectErrorLogMapper.java +++ /dev/null @@ -1,17 +0,0 @@ -package com.docus.server.infrastructure.mapper; - -import com.docus.server.entity.scheduling.management.SchCollectErrorLog; -import com.baomidou.mybatisplus.core.mapper.BaseMapper; -import org.apache.ibatis.annotations.Mapper; - -/** -* -* 采集器异常日志 Mapper 接口 -* -* @author AutoGenerator -* @since 2023-07-15 -*/ -@Mapper -public interface SchCollectErrorLogMapper extends BaseMapper { - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectRecordMapper.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectRecordMapper.java deleted file mode 100644 index 6ffdc55..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectRecordMapper.java +++ /dev/null @@ -1,17 +0,0 @@ -package com.docus.server.infrastructure.mapper; - -import com.docus.server.entity.scheduling.management.SchCollectRecord; -import com.baomidou.mybatisplus.core.mapper.BaseMapper; -import org.apache.ibatis.annotations.Mapper; - -/** -* -* 采集记录表 Mapper 接口 -* -* @author AutoGenerator -* @since 2023-07-15 -*/ -@Mapper -public interface SchCollectRecordMapper extends BaseMapper { - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectRecordRetryLogMapper.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectRecordRetryLogMapper.java deleted file mode 100644 index 9759a7d..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectRecordRetryLogMapper.java +++ /dev/null @@ -1,17 +0,0 @@ -package com.docus.server.infrastructure.mapper; - -import com.docus.server.entity.scheduling.management.SchCollectRecordRetryLog; -import com.baomidou.mybatisplus.core.mapper.BaseMapper; -import org.apache.ibatis.annotations.Mapper; - -/** -* -* 采集记录表重试表 Mapper 接口 -* -* @author AutoGenerator -* @since 2023-07-15 -*/ -@Mapper -public interface SchCollectRecordRetryLogMapper extends BaseMapper { - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectorConfigMapper.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectorConfigMapper.java deleted file mode 100644 index 70ffe03..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectorConfigMapper.java +++ /dev/null @@ -1,17 +0,0 @@ -package com.docus.server.infrastructure.mapper; - -import com.docus.server.entity.scheduling.management.SchCollectorConfig; -import com.baomidou.mybatisplus.core.mapper.BaseMapper; -import org.apache.ibatis.annotations.Mapper; - -/** -* -* 采集器配置 Mapper 接口 -* -* @author AutoGenerator -* @since 2023-07-15 -*/ -@Mapper -public interface SchCollectorConfigMapper extends BaseMapper { - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectorMapper.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectorMapper.java deleted file mode 100644 index f23ff29..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectorMapper.java +++ /dev/null @@ -1,17 +0,0 @@ -package com.docus.server.infrastructure.mapper; - -import com.docus.server.entity.scheduling.management.SchCollector; -import com.baomidou.mybatisplus.core.mapper.BaseMapper; -import org.apache.ibatis.annotations.Mapper; - -/** -* -* 采集器管理 Mapper 接口 -* -* @author AutoGenerator -* @since 2023-07-15 -*/ -@Mapper -public interface SchCollectorMapper extends BaseMapper { - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectorVersionFileMapper.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectorVersionFileMapper.java deleted file mode 100644 index eabc60e..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectorVersionFileMapper.java +++ /dev/null @@ -1,17 +0,0 @@ -package com.docus.server.infrastructure.mapper; - -import com.docus.server.entity.scheduling.management.SchCollectorVersionFile; -import com.baomidou.mybatisplus.core.mapper.BaseMapper; -import org.apache.ibatis.annotations.Mapper; - -/** -* -* 采集器版本列表更新包管理 Mapper 接口 -* -* @author AutoGenerator -* @since 2023-07-15 -*/ -@Mapper -public interface SchCollectorVersionFileMapper extends BaseMapper { - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectorVersionLogMapper.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectorVersionLogMapper.java deleted file mode 100644 index 55c8ca1..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectorVersionLogMapper.java +++ /dev/null @@ -1,17 +0,0 @@ -package com.docus.server.infrastructure.mapper; - -import com.docus.server.entity.scheduling.management.SchCollectorVersionLog; -import com.baomidou.mybatisplus.core.mapper.BaseMapper; -import org.apache.ibatis.annotations.Mapper; - -/** -* -* 采集器版本更新日志管理 Mapper 接口 -* -* @author AutoGenerator -* @since 2023-07-15 -*/ -@Mapper -public interface SchCollectorVersionLogMapper extends BaseMapper { - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectorVersionMapper.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectorVersionMapper.java deleted file mode 100644 index 452219e..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchCollectorVersionMapper.java +++ /dev/null @@ -1,17 +0,0 @@ -package com.docus.server.infrastructure.mapper; - -import com.docus.server.entity.scheduling.management.SchCollectorVersion; -import com.baomidou.mybatisplus.core.mapper.BaseMapper; -import org.apache.ibatis.annotations.Mapper; - -/** -* -* 采集器版本列表管理 Mapper 接口 -* -* @author AutoGenerator -* @since 2023-07-15 -*/ -@Mapper -public interface SchCollectorVersionMapper extends BaseMapper { - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchOperationLogMapper.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchOperationLogMapper.java deleted file mode 100644 index 97ef0f1..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchOperationLogMapper.java +++ /dev/null @@ -1,17 +0,0 @@ -package com.docus.server.infrastructure.mapper; - -import com.docus.server.entity.scheduling.management.SchOperationLog; -import com.baomidou.mybatisplus.core.mapper.BaseMapper; -import org.apache.ibatis.annotations.Mapper; - -/** -* -* 采集调度器操作日志 Mapper 接口 -* -* @author AutoGenerator -* @since 2023-07-15 -*/ -@Mapper -public interface SchOperationLogMapper extends BaseMapper { - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchSystemParamsMapper.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchSystemParamsMapper.java deleted file mode 100644 index 7305c16..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchSystemParamsMapper.java +++ /dev/null @@ -1,17 +0,0 @@ -package com.docus.server.infrastructure.mapper; - -import com.docus.server.entity.scheduling.management.SchSystemParams; -import com.baomidou.mybatisplus.core.mapper.BaseMapper; -import org.apache.ibatis.annotations.Mapper; - -/** -* -* 系统参数表 Mapper 接口 -* -* @author AutoGenerator -* @since 2023-07-15 -*/ -@Mapper -public interface SchSystemParamsMapper extends BaseMapper { - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchTerminatorMapper.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchTerminatorMapper.java deleted file mode 100644 index 910a074..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchTerminatorMapper.java +++ /dev/null @@ -1,17 +0,0 @@ -package com.docus.server.infrastructure.mapper; - -import com.docus.server.entity.scheduling.management.SchTerminator; -import com.baomidou.mybatisplus.core.mapper.BaseMapper; -import org.apache.ibatis.annotations.Mapper; - -/** -* -* 执行管理器 Mapper 接口 -* -* @author AutoGenerator -* @since 2023-07-15 -*/ -@Mapper -public interface SchTerminatorMapper extends BaseMapper { - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchVirtualLogMapper.java b/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchVirtualLogMapper.java deleted file mode 100644 index 168b239..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/infrastructure/mapper/SchVirtualLogMapper.java +++ /dev/null @@ -1,17 +0,0 @@ -package com.docus.server.infrastructure.mapper; - -import com.docus.server.entity.scheduling.management.SchVirtualLog; -import com.baomidou.mybatisplus.core.mapper.BaseMapper; -import org.apache.ibatis.annotations.Mapper; - -/** -* -* 虚拟机使用情况 Mapper 接口 -* -* @author AutoGenerator -* @since 2023-07-15 -*/ -@Mapper -public interface SchVirtualLogMapper extends BaseMapper { - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/ICommMsgService.java b/collector-terminal-management/src/main/java/com/docus/server/service/ICommMsgService.java deleted file mode 100644 index 615eee7..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/ICommMsgService.java +++ /dev/null @@ -1,21 +0,0 @@ -package com.docus.server.service; - -import com.docus.server.dto.scheduling.management.schterminator.CommMsgDTO; - -public interface ICommMsgService { - - /** - * 向客户端发送TCP命令 - * - * @param commMsgDTO 消息体 - */ - void clientCommand(CommMsgDTO commMsgDTO); - - /** - * 向所有客户端发送TCP命令 - * - * @param commMsgDTO 消息体 - */ - void clientsCommand(CommMsgDTO commMsgDTO); - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/IFileUploadService.java b/collector-terminal-management/src/main/java/com/docus/server/service/IFileUploadService.java deleted file mode 100644 index 00e46ec..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/IFileUploadService.java +++ /dev/null @@ -1,14 +0,0 @@ -package com.docus.server.service; - -import com.docus.server.vo.scheduling.management.schcollectorversionfile.UploadFileVO; -import org.springframework.web.multipart.MultipartFile; - -import javax.servlet.http.HttpServletResponse; -import java.util.List; - -public interface IFileUploadService { - - List uploadFile(MultipartFile[] multipartFiles, String pathKey) throws Exception; - - void downloadFile(String filePath, HttpServletResponse response); -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectErrorLogService.java b/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectErrorLogService.java deleted file mode 100644 index 8e96d9f..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectErrorLogService.java +++ /dev/null @@ -1,58 +0,0 @@ -package com.docus.server.service; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schcollecterrorlog.AddSchCollectErrorLogDTO; -import com.docus.server.dto.scheduling.management.schcollecterrorlog.DeleteSchCollectErrorLogDTO; -import com.docus.server.dto.scheduling.management.schcollecterrorlog.EditSchCollectErrorLogDTO; -import com.docus.server.vo.scheduling.management.schcollecterrorlog.SchCollectErrorLogVO; -import org.springframework.web.multipart.MultipartFile; - -/** - * 采集器异常日志 服务接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectErrorLogService { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollectErrorLogVO findById(String id); - - /** - * 新增 - * - * @param addSchCollectErrorLogDTO 新增参数 - * @param multipartFiles 异常任务截图 - * @return 成功或失败 - */ - boolean add(AddSchCollectErrorLogDTO addSchCollectErrorLogDTO, MultipartFile[] multipartFiles) throws Exception; - - /** - * 编辑 - * - * @param editSchCollectErrorLogDTO 编辑参数 - * @return 成功或失败 - */ - boolean edit(EditSchCollectErrorLogDTO editSchCollectErrorLogDTO); - - /** - * 批量删除 - * - * @param deleteSchCollectErrorLogDTO 删除参数 - * @return 成功或失败 - */ - int delete(DeleteSchCollectErrorLogDTO deleteSchCollectErrorLogDTO); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectRecordRetryLogService.java b/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectRecordRetryLogService.java deleted file mode 100644 index d45ea0e..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectRecordRetryLogService.java +++ /dev/null @@ -1,61 +0,0 @@ -package com.docus.server.service; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schcollector.task.ReportDownTwoDTO; -import com.docus.server.dto.scheduling.management.schcollectrecordretrylog.AddSchCollectRecordRetryLogDTO; -import com.docus.server.dto.scheduling.management.schcollectrecordretrylog.DeleteSchCollectRecordRetryLogDTO; -import com.docus.server.dto.scheduling.management.schcollectrecordretrylog.EditSchCollectRecordRetryLogDTO; -import com.docus.server.dto.scheduling.management.schterminator.NettyTerminatorDTO; -import com.docus.server.entity.scheduling.management.SchCollectRecordRetryLog; -import com.docus.server.vo.scheduling.management.schcollectrecordretrylog.SchCollectRecordRetryLogVO; - -/** - * 采集记录表重试表 服务接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectRecordRetryLogService { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollectRecordRetryLogVO findById(String id); - - /** - * 新增 - * - * @param addSchCollectRecordRetryLogDTO 新增参数 - * @return 成功或失败 - */ - SchCollectRecordRetryLog add(AddSchCollectRecordRetryLogDTO addSchCollectRecordRetryLogDTO); - - /** - * 编辑 - * - * @param editSchCollectRecordRetryLogDTO 编辑参数 - * @return 成功或失败 - */ - boolean edit(EditSchCollectRecordRetryLogDTO editSchCollectRecordRetryLogDTO); - - /** - * 批量删除 - * - * @param deleteSchCollectRecordRetryLogDTO 删除参数 - * @return 成功或失败 - */ - int delete(DeleteSchCollectRecordRetryLogDTO deleteSchCollectRecordRetryLogDTO); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - - SchCollectRecordRetryLog saveOrUpdateRecordRetryLog(NettyTerminatorDTO terminal, ReportDownTwoDTO reportDownTwoDTO); -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectRecordService.java b/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectRecordService.java deleted file mode 100644 index c06f13b..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectRecordService.java +++ /dev/null @@ -1,61 +0,0 @@ -package com.docus.server.service; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schcollector.task.ReportDownTwoDTO; -import com.docus.server.dto.scheduling.management.schcollectrecord.AddSchCollectRecordDTO; -import com.docus.server.dto.scheduling.management.schcollectrecord.DeleteSchCollectRecordDTO; -import com.docus.server.dto.scheduling.management.schcollectrecord.EditSchCollectRecordDTO; -import com.docus.server.dto.scheduling.management.schterminator.NettyTerminatorDTO; -import com.docus.server.entity.scheduling.management.SchCollectRecord; -import com.docus.server.vo.scheduling.management.schcollectrecord.SchCollectRecordVO; - -/** - * 采集记录表 服务接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectRecordService { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollectRecordVO findById(String id); - - /** - * 新增 - * - * @param addSchCollectRecordDTO 新增参数 - * @return 成功或失败 - */ - SchCollectRecord add(AddSchCollectRecordDTO addSchCollectRecordDTO); - - /** - * 编辑 - * - * @param editSchCollectRecordDTO 编辑参数 - * @return 成功或失败 - */ - boolean edit(EditSchCollectRecordDTO editSchCollectRecordDTO); - - /** - * 批量删除 - * - * @param deleteSchCollectRecordDTO 删除参数 - * @return 成功或失败 - */ - int delete(DeleteSchCollectRecordDTO deleteSchCollectRecordDTO); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - - SchCollectRecord saveOrUpdateRecord(NettyTerminatorDTO terminal, ReportDownTwoDTO messageContent); -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectorConfigService.java b/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectorConfigService.java deleted file mode 100644 index 23398eb..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectorConfigService.java +++ /dev/null @@ -1,61 +0,0 @@ -package com.docus.server.service; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schcollectorconfig.AddSchCollectorConfigDTO; -import com.docus.server.dto.scheduling.management.schcollectorconfig.DeleteSchCollectorConfigDTO; -import com.docus.server.dto.scheduling.management.schcollectorconfig.EditSchCollectorConfigDTO; -import com.docus.server.vo.scheduling.management.schcollectorconfig.SchCollectorConfigVO; - -/** - * 采集器配置 服务接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectorConfigService { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollectorConfigVO findById(String id); - - /** - * 新增 - * - * @param addSchCollectorConfigDTO 新增参数 - * @return 成功或失败 - */ - boolean add(AddSchCollectorConfigDTO addSchCollectorConfigDTO); - - /** - * 编辑 - * - * @param editSchCollectorConfigDTO 编辑参数 - * @return 成功或失败 - */ - boolean edit(EditSchCollectorConfigDTO editSchCollectorConfigDTO); - - /** - * 批量删除 - * - * @param deleteSchCollectorConfigDTO 删除参数 - * @return 成功或失败 - */ - int delete(DeleteSchCollectorConfigDTO deleteSchCollectorConfigDTO); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - - /** - * 更新采集器配置 - */ - void updateCollectorConfig(); -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectorService.java b/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectorService.java deleted file mode 100644 index 7278571..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectorService.java +++ /dev/null @@ -1,68 +0,0 @@ -package com.docus.server.service; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schcollector.AddSchCollectorDTO; -import com.docus.server.dto.scheduling.management.schcollector.DeleteSchCollectorDTO; -import com.docus.server.dto.scheduling.management.schcollector.EditSchCollectorDTO; -import com.docus.server.dto.scheduling.management.schcollector.UpdateSchCollectorDTO; -import com.docus.server.entity.scheduling.management.SchCollector; -import com.docus.server.vo.scheduling.management.schcollector.SchCollectorVO; - -/** - * 采集器管理 服务接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectorService { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollectorVO findById(String id); - - /** - * 新增 - * - * @param addSchCollectorDTO 新增参数 - * @return 成功或失败 - */ - boolean add(AddSchCollectorDTO addSchCollectorDTO); - - /** - * 编辑 - * - * @param editSchCollectorDTO 编辑参数 - * @return 成功或失败 - */ - boolean edit(EditSchCollectorDTO editSchCollectorDTO); - - /** - * 批量删除 - * - * @param deleteSchCollectorDTO 删除参数 - * @return 成功或失败 - */ - int delete(DeleteSchCollectorDTO deleteSchCollectorDTO); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - - /** - * 选为当前版本并更新 - * - * @return 成功或失败 - */ - boolean updateVersion(UpdateSchCollectorDTO schCollector); - - SchCollector findByCollectorId(String collectorId); - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectorVersionFileService.java b/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectorVersionFileService.java deleted file mode 100644 index 92ad266..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectorVersionFileService.java +++ /dev/null @@ -1,65 +0,0 @@ -package com.docus.server.service; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schcollectorversionfile.AddSchCollectorVersionFileDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionfile.DeleteSchCollectorVersionFileDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionfile.EditSchCollectorVersionFileDTO; -import com.docus.server.entity.scheduling.management.SchCollectorVersionFile; -import com.docus.server.vo.scheduling.management.schcollectorversionfile.SchCollectorVersionFileVO; -import org.springframework.web.multipart.MultipartFile; - -/** - * 采集器版本列表更新包管理 服务接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectorVersionFileService { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollectorVersionFileVO findById(String id); - - /** - * 新增 - * - * @param addSchCollectorVersionFileDTO 新增参数 - * @return 成功或失败 - */ - boolean add(AddSchCollectorVersionFileDTO addSchCollectorVersionFileDTO); - - /** - * 编辑 - * - * @param editSchCollectorVersionFileDTO 编辑参数 - * @return 成功或失败 - */ - boolean edit(EditSchCollectorVersionFileDTO editSchCollectorVersionFileDTO); - - /** - * 批量删除 - * - * @param deleteSchCollectorVersionFileDTO 删除参数 - * @return 成功或失败 - */ - int delete(DeleteSchCollectorVersionFileDTO deleteSchCollectorVersionFileDTO); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - - /** - * 新增版本和版本文件 - */ - void addVersionAndFile(AddSchCollectorVersionFileDTO addSchCollectorVersionFileDTO, MultipartFile[] multipartFiles) throws Exception; - - SchCollectorVersionFile findByCollectorIdAndVersionId(Long collectorId, Long collectorVersionId); -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectorVersionLogService.java b/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectorVersionLogService.java deleted file mode 100644 index 9cd38a6..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectorVersionLogService.java +++ /dev/null @@ -1,56 +0,0 @@ -package com.docus.server.service; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schcollectorversionlog.AddSchCollectorVersionLogDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionlog.DeleteSchCollectorVersionLogDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionlog.EditSchCollectorVersionLogDTO; -import com.docus.server.vo.scheduling.management.schcollectorversionlog.SchCollectorVersionLogVO; - -/** - * 采集器版本更新日志管理 服务接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectorVersionLogService { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollectorVersionLogVO findById(String id); - - /** - * 新增 - * - * @param addSchCollectorVersionLogDTO 新增参数 - * @return 成功或失败 - */ - boolean add(AddSchCollectorVersionLogDTO addSchCollectorVersionLogDTO); - - /** - * 编辑 - * - * @param editSchCollectorVersionLogDTO 编辑参数 - * @return 成功或失败 - */ - boolean edit(EditSchCollectorVersionLogDTO editSchCollectorVersionLogDTO); - - /** - * 批量删除 - * - * @param deleteSchCollectorVersionLogDTO 删除参数 - * @return 成功或失败 - */ - int delete(DeleteSchCollectorVersionLogDTO deleteSchCollectorVersionLogDTO); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectorVersionService.java b/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectorVersionService.java deleted file mode 100644 index edeaac4..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/ISchCollectorVersionService.java +++ /dev/null @@ -1,65 +0,0 @@ -package com.docus.server.service; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schcollectorversion.AddSchCollectorVersionDTO; -import com.docus.server.dto.scheduling.management.schcollectorversion.DeleteSchCollectorVersionDTO; -import com.docus.server.dto.scheduling.management.schcollectorversion.EditSchCollectorVersionDTO; -import com.docus.server.entity.scheduling.management.SchCollectorVersion; -import com.docus.server.vo.scheduling.management.schcollectorversion.SchCollectorVersionVO; - -/** - * 采集器版本列表管理 服务接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchCollectorVersionService { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchCollectorVersionVO findById(String id); - - /** - * 新增 - * - * @param addSchCollectorVersionDTO 新增参数 - * @return 成功或失败 - */ - boolean add(AddSchCollectorVersionDTO addSchCollectorVersionDTO); - - /** - * 编辑 - * - * @param editSchCollectorVersionDTO 编辑参数 - * @return 成功或失败 - */ - boolean edit(EditSchCollectorVersionDTO editSchCollectorVersionDTO); - - /** - * 批量删除 - * - * @param deleteSchCollectorVersionDTO 删除参数 - * @return 成功或失败 - */ - int delete(DeleteSchCollectorVersionDTO deleteSchCollectorVersionDTO); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - - /** - * 查询当前采集器和版本号是否重复 - * @param collectorId - * @param collectorVersionNo - * @return - */ - SchCollectorVersion findByVersion(Long collectorId, String collectorVersionNo); -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/ISchOperationLogService.java b/collector-terminal-management/src/main/java/com/docus/server/service/ISchOperationLogService.java deleted file mode 100644 index a63ad23..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/ISchOperationLogService.java +++ /dev/null @@ -1,56 +0,0 @@ -package com.docus.server.service; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schoperationlog.AddSchOperationLogDTO; -import com.docus.server.dto.scheduling.management.schoperationlog.DeleteSchOperationLogDTO; -import com.docus.server.dto.scheduling.management.schoperationlog.EditSchOperationLogDTO; -import com.docus.server.vo.scheduling.management.schoperationlog.SchOperationLogVO; - -/** - * 采集调度器操作日志 服务接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchOperationLogService { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchOperationLogVO findById(String id); - - /** - * 新增 - * - * @param addSchOperationLogDTO 新增参数 - * @return 成功或失败 - */ - boolean add(AddSchOperationLogDTO addSchOperationLogDTO); - - /** - * 编辑 - * - * @param editSchOperationLogDTO 编辑参数 - * @return 成功或失败 - */ - boolean edit(EditSchOperationLogDTO editSchOperationLogDTO); - - /** - * 批量删除 - * - * @param deleteSchOperationLogDTO 删除参数 - * @return 成功或失败 - */ - int delete(DeleteSchOperationLogDTO deleteSchOperationLogDTO); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/ISchSystemParamsService.java b/collector-terminal-management/src/main/java/com/docus/server/service/ISchSystemParamsService.java deleted file mode 100644 index c62ece0..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/ISchSystemParamsService.java +++ /dev/null @@ -1,69 +0,0 @@ -package com.docus.server.service; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schsystemparams.AddSchSystemParamsDTO; -import com.docus.server.dto.scheduling.management.schsystemparams.DeleteSchSystemParamsDTO; -import com.docus.server.dto.scheduling.management.schsystemparams.EditSchSystemParamsDTO; -import com.docus.server.entity.scheduling.management.SchSystemParams; -import com.docus.server.vo.scheduling.management.schsystemparams.SchSystemParamsVO; - -import java.util.List; -import java.util.Map; - -/** - * 系统参数表 服务接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchSystemParamsService { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchSystemParamsVO findById(String id); - - /** - * 新增 - * - * @param addSchSystemParamsDTO 新增参数 - * @return 成功或失败 - */ - boolean add(AddSchSystemParamsDTO addSchSystemParamsDTO); - - /** - * 编辑 - * - * @param editSchSystemParamsDTO 编辑参数 - * @return 成功或失败 - */ - boolean edit(EditSchSystemParamsDTO editSchSystemParamsDTO); - - /** - * 批量删除 - * - * @param deleteSchSystemParamsDTO 删除参数 - * @return 成功或失败 - */ - int delete(DeleteSchSystemParamsDTO deleteSchSystemParamsDTO); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - - - /** - * 采集器id获取采集器名称 - * - * @param paramValueIds 采集器ids - * @return Map - */ - Map find(List paramValueIds); -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/ISchTerminatorService.java b/collector-terminal-management/src/main/java/com/docus/server/service/ISchTerminatorService.java deleted file mode 100644 index af4064f..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/ISchTerminatorService.java +++ /dev/null @@ -1,72 +0,0 @@ -package com.docus.server.service; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schterminator.AddSchTerminatorDTO; -import com.docus.server.dto.scheduling.management.schterminator.DeleteSchTerminatorDTO; -import com.docus.server.dto.scheduling.management.schterminator.EditSchTerminatorDTO; -import com.docus.server.dto.scheduling.management.schterminator.NettyTerminatorDTO; -import com.docus.server.entity.scheduling.management.SchTerminator; -import com.docus.server.vo.scheduling.management.schterminator.SchTerminatorVO; - -import java.util.List; - -/** - * 执行管理器 服务接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchTerminatorService { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchTerminatorVO findById(String id); - - /** - * 新增 - * - * @param addSchTerminatorDTO 新增参数 - * @return 成功或失败 - */ - boolean add(AddSchTerminatorDTO addSchTerminatorDTO); - - /** - * 编辑 - * - * @param editSchTerminatorDTO 编辑参数 - * @return 成功或失败 - */ - boolean edit(EditSchTerminatorDTO editSchTerminatorDTO); - - /** - * 批量删除 - * - * @param deleteSchTerminatorDTO 删除参数 - * @return 成功或失败 - */ - int delete(DeleteSchTerminatorDTO deleteSchTerminatorDTO); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); - - /** - * 新增或更新 - * @param terminatorIp - * @param nettyTerminatorDTO - * @return - */ - SchTerminatorVO saveOrUpdate(String terminatorIp, NettyTerminatorDTO nettyTerminatorDTO); - - List findAll(); - - void batchUpdate(List terminators); -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/ISchVirtualLogService.java b/collector-terminal-management/src/main/java/com/docus/server/service/ISchVirtualLogService.java deleted file mode 100644 index be3fe7e..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/ISchVirtualLogService.java +++ /dev/null @@ -1,56 +0,0 @@ -package com.docus.server.service; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.dto.scheduling.management.schvirtuallog.AddSchVirtualLogDTO; -import com.docus.server.dto.scheduling.management.schvirtuallog.DeleteSchVirtualLogDTO; -import com.docus.server.dto.scheduling.management.schvirtuallog.EditSchVirtualLogDTO; -import com.docus.server.vo.scheduling.management.schvirtuallog.SchVirtualLogVO; - -/** - * 虚拟机使用情况 服务接口 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -public interface ISchVirtualLogService { - /** - * 按主键查询 - * - * @param id 主键id - * @return 实体 - */ - SchVirtualLogVO findById(String id); - - /** - * 新增 - * - * @param addSchVirtualLogDTO 新增参数 - * @return 成功或失败 - */ - boolean add(AddSchVirtualLogDTO addSchVirtualLogDTO); - - /** - * 编辑 - * - * @param editSchVirtualLogDTO 编辑参数 - * @return 成功或失败 - */ - boolean edit(EditSchVirtualLogDTO editSchVirtualLogDTO); - - /** - * 批量删除 - * - * @param deleteSchVirtualLogDTO 删除参数 - * @return 成功或失败 - */ - int delete(DeleteSchVirtualLogDTO deleteSchVirtualLogDTO); - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - PageResult search(SearchDTO searchDTO); -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/impl/CommMsgServiceImpl.java b/collector-terminal-management/src/main/java/com/docus/server/service/impl/CommMsgServiceImpl.java deleted file mode 100644 index 7e4f4d0..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/impl/CommMsgServiceImpl.java +++ /dev/null @@ -1,58 +0,0 @@ -package com.docus.server.service.impl; - -import com.docus.core.util.DateUtil; -import com.docus.core.util.json.JSON; -import com.docus.server.common.netty.CommMsg; -import com.docus.server.common.netty.server.ChannelRepository; -import com.docus.server.convert.CommMsgConvert; -import com.docus.server.dto.scheduling.management.schterminator.CommMsgDTO; -import com.docus.server.service.ICommMsgService; -import io.netty.buffer.Unpooled; -import io.netty.channel.Channel; -import io.netty.util.CharsetUtil; -import lombok.extern.slf4j.Slf4j; -import org.springframework.stereotype.Service; - -import javax.annotation.Resource; -import java.util.Date; -import java.util.Map; -import java.util.Set; - -@Service -@Slf4j -public class CommMsgServiceImpl implements ICommMsgService { - - @Resource - private ChannelRepository channelRepository; - - @Override - public void clientCommand(CommMsgDTO commMsgDTO) { - Channel channel = channelRepository.get(commMsgDTO.getTerminatorIp()); - - CommMsg commMsg = CommMsgConvert.INSTANCE.convertDO(commMsgDTO); - commMsg.setMessageTime(DateUtil.formatDateTime(new Date())); - - if (channel != null) { - channel.writeAndFlush(Unpooled.copiedBuffer(JSON.toJSON(commMsg), CharsetUtil.UTF_8)); - } - } - - @Override - public void clientsCommand(CommMsgDTO commMsgDTO) { - - Map channelMap = channelRepository.getIpToChannelCacheMap(); - Set keySet = channelMap.keySet(); - - for (String clientIp : keySet) { - Channel channel = channelMap.get(clientIp); - - CommMsg commMsg = CommMsgConvert.INSTANCE.convertDO(commMsgDTO); - commMsg.setMessageTime(DateUtil.formatDateTime(new Date())); - - if (channel != null) { - channel.writeAndFlush(Unpooled.copiedBuffer(JSON.toJSON(commMsg), CharsetUtil.UTF_8)); - } - - } - } -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/impl/FileUploadServiceImpl.java b/collector-terminal-management/src/main/java/com/docus/server/service/impl/FileUploadServiceImpl.java deleted file mode 100644 index 647a2bb..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/impl/FileUploadServiceImpl.java +++ /dev/null @@ -1,137 +0,0 @@ -package com.docus.server.service.impl; - -import cn.hutool.core.util.StrUtil; -import com.docus.core.util.Func; -import com.docus.infrastructure.web.exception.ApiException; -import com.docus.infrastructure.web.exception.ExceptionCode; -import com.docus.server.service.IFileUploadService; -import com.docus.server.vo.scheduling.management.schcollectorversionfile.UploadFileVO; -import lombok.extern.slf4j.Slf4j; -import org.springframework.beans.factory.annotation.Value; -import org.springframework.stereotype.Service; -import org.springframework.web.multipart.MultipartFile; - -import javax.servlet.ServletOutputStream; -import javax.servlet.http.HttpServletResponse; -import java.io.BufferedInputStream; -import java.io.BufferedOutputStream; -import java.io.File; -import java.io.FileInputStream; -import java.net.URLEncoder; -import java.time.LocalDateTime; -import java.time.format.DateTimeFormatter; -import java.util.ArrayList; -import java.util.List; -import java.util.UUID; - -@Service -@Slf4j -public class FileUploadServiceImpl implements IFileUploadService { - - @Value("${file.uploadFolder:D://docus/}") - private String saveFilePath; - - private static final String COLLECTOR_PACKAGES = "collector_packages"; - - private static DateTimeFormatter ymdDtf = DateTimeFormatter.ofPattern("yyyyMMdd"); - - @Override - public List uploadFile(MultipartFile[] multipartFiles, String pathKey) throws Exception { - - if (Func.isBlank(pathKey)) { - pathKey = COLLECTOR_PACKAGES; - } - - List uploadFileVOList = new ArrayList<>(); - - for (MultipartFile multipartFile : multipartFiles) { - - valid(multipartFile); - - uploadFileVOList.add(actionUploadFile(multipartFile, pathKey)); - } - return uploadFileVOList; - - } - - private UploadFileVO actionUploadFile(MultipartFile multipartFile, String pathKey) throws Exception { - - String todayFormat = ymdDtf.format(LocalDateTime.now()); - - String path = pathKey + "/" + todayFormat + "/" + UUID.randomUUID().toString() + "/"; - File fileDir = new File(saveFilePath + path); - if (!fileDir.exists()) { - fileDir.mkdirs(); - } - String fileName = path + multipartFile.getOriginalFilename(); - - File dest = new File(saveFilePath + fileName); - - multipartFile.transferTo(dest); - - - UploadFileVO uploadFileVO = new UploadFileVO(); - uploadFileVO.setFileName(multipartFile.getOriginalFilename()); - uploadFileVO.setFileSize(multipartFile.getSize()); - uploadFileVO.setFileTitle(multipartFile.getName()); - uploadFileVO.setFileType(multipartFile.getContentType()); - uploadFileVO.setFilePath(fileName); - - return uploadFileVO; - } - - @Override - public void downloadFile(String path, HttpServletResponse response) { - - try { - //获取要下载的文件 - File file = new File(saveFilePath + "/" + path); - - //设置响应的内容类型为二进制流,即文件类型 - response.setContentType("application/octet-stream"); - - //设置文件名 - response.setHeader("Content-Disposition", "attachment;filename=" + URLEncoder.encode(file.getName(), "UTF-8")); - - //创建输入流 - FileInputStream inputStream = new FileInputStream(file); - BufferedInputStream buffInputStream = new BufferedInputStream(inputStream); - - //创建输出流 - ServletOutputStream outputStream = response.getOutputStream(); - BufferedOutputStream buffOutputStream = new BufferedOutputStream(outputStream); - - //循环读取数据并写入到响应输出流中 - byte[] buffer = new byte[1024]; - int len = -1; - while ((len = buffInputStream.read(buffer)) != -1) { - buffOutputStream.write(buffer, 0, len); - } - - //关闭流 - buffOutputStream.flush(); - buffOutputStream.close(); - outputStream.flush(); - outputStream.close(); - buffInputStream.close(); - inputStream.close(); - } catch (Exception e) { - log.error(e.getMessage(), e); - } - } - - private void valid(MultipartFile multipartFile) { - if (multipartFile.isEmpty()) { - throw new ApiException(ExceptionCode.ParamIllegal.getCode(), "上传失败,请选择文件!"); - } - - String originalFilename = multipartFile.getOriginalFilename(); - if (StrUtil.isBlank(originalFilename)) { - throw new ApiException(ExceptionCode.ParamIllegal.getCode(), "未找到原文件文件名!"); - } - if (!originalFilename.contains(".")) { - throw new ApiException(ExceptionCode.ParamIllegal.getCode(), "原文件名未识别到后缀!"); - } - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/impl/RedisKeyExpirationService.java b/collector-terminal-management/src/main/java/com/docus/server/service/impl/RedisKeyExpirationService.java deleted file mode 100644 index 51230cc..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/impl/RedisKeyExpirationService.java +++ /dev/null @@ -1,56 +0,0 @@ -package com.docus.server.service.impl; - -import com.docus.core.util.DateUtil; -import com.docus.log.annotation.TrackGroup; -import com.docus.server.common.process.ChannelProcessor; -import com.docus.server.entity.scheduling.management.SchCollectRecord; -import com.docus.server.entity.scheduling.management.SchCollectRecordRetryLog; -import com.docus.server.enums.StateEnum; -import com.docus.server.enums.SubStateEnum; -import com.docus.server.infrastructure.dao.ISchCollectRecordDao; -import com.docus.server.infrastructure.dao.ISchCollectRecordRetryLogDao; -import org.springframework.stereotype.Service; - -import javax.annotation.Resource; - -@Service -public class RedisKeyExpirationService { - @Resource - private ISchCollectRecordDao iSchCollectRecordDao; - @Resource - private ISchCollectRecordRetryLogDao iSchCollectRecordRetryLogDao; - - @TrackGroup(group = "RedisKeyExpirationService-expired", processor = ChannelProcessor.class) - public void expired(String expireKey) { - - if (expireKey.startsWith("schCollectorRecord:noRetryTask:expireKey:")) { - System.out.println("expireKey过期了===" + expireKey); - - String recordId = expireKey.substring(expireKey.lastIndexOf(":") + 1); - - SchCollectRecord collectRecord = iSchCollectRecordDao.findById(recordId); - collectRecord.setTaskExecState(StateEnum.FAIL); - //超时作废 - collectRecord.setSubTaskExecState(SubStateEnum.CANCEL); - collectRecord.setUpdateTime(DateUtil.now()); - collectRecord.setLastTaskErrorMsg("任务超时,触发任务作废"); - iSchCollectRecordDao.updateById(collectRecord); - - } - if (expireKey.startsWith("schCollectorRecord:isRetryTask:expireKey:")) { - System.out.println("expireKey过期了===" + expireKey); - - String logRecordId = expireKey.substring(expireKey.lastIndexOf(":") + 1); - - SchCollectRecordRetryLog recordRetryLog = iSchCollectRecordRetryLogDao.findById(logRecordId); - recordRetryLog.setTaskExecState(StateEnum.FAIL); - recordRetryLog.setSubTaskExecState(SubStateEnum.CANCEL); - recordRetryLog.setUpdateTime(DateUtil.now()); - recordRetryLog.setLastTaskErrorMsg("任务超时,触发任务作废"); - iSchCollectRecordRetryLogDao.updateById(recordRetryLog); - - } - - } - -} diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectErrorLogServiceImpl.java b/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectErrorLogServiceImpl.java deleted file mode 100644 index 0c1c8a6..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectErrorLogServiceImpl.java +++ /dev/null @@ -1,103 +0,0 @@ -package com.docus.server.service.impl; - -import com.docus.infrastructure.redis.service.IdService; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.convert.SchCollectErrorLogConvert; -import com.docus.server.dto.scheduling.management.schcollecterrorlog.AddSchCollectErrorLogDTO; -import com.docus.server.dto.scheduling.management.schcollecterrorlog.DeleteSchCollectErrorLogDTO; -import com.docus.server.dto.scheduling.management.schcollecterrorlog.EditSchCollectErrorLogDTO; -import com.docus.server.entity.scheduling.management.SchCollectErrorLog; -import com.docus.server.infrastructure.dao.ISchCollectErrorLogDao; -import com.docus.server.service.IFileUploadService; -import com.docus.server.service.ISchCollectErrorLogService; -import com.docus.server.vo.scheduling.management.schcollecterrorlog.SchCollectErrorLogVO; -import com.docus.server.vo.scheduling.management.schcollectorversionfile.UploadFileVO; -import org.springframework.stereotype.Service; -import org.springframework.util.CollectionUtils; -import org.springframework.web.multipart.MultipartFile; - -import javax.annotation.Resource; -import java.util.List; - -/** - * 采集器异常日志 服务实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Service -public class SchCollectErrorLogServiceImpl implements ISchCollectErrorLogService { - @Resource - private ISchCollectErrorLogDao iSchCollectErrorLogDao; - @Resource - private IFileUploadService iFileUploadService; - @Resource - private IdService idService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectErrorLogVO findById(String id) { - return SchCollectErrorLogConvert.INSTANCE.convertVO(iSchCollectErrorLogDao.findById(id)); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return SchCollectErrorLogConvert.INSTANCE.convertVO(iSchCollectErrorLogDao.search(searchDTO)); - } - - /** - * 新增 - * - * @param addSchCollectErrorLogDTO 编辑参数 - * @param multipartFiles 采集器异常任务截图 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchCollectErrorLogDTO addSchCollectErrorLogDTO, MultipartFile[] multipartFiles) throws Exception { - - List uploadFileVOList = iFileUploadService.uploadFile(multipartFiles, "COLLECTOR_TASK_ERROR_LOG"); - - SchCollectErrorLog schCollectErrorLog = SchCollectErrorLogConvert.INSTANCE.convertDO(addSchCollectErrorLogDTO); - if (!CollectionUtils.isEmpty(uploadFileVOList)) { - schCollectErrorLog.setScreenPath(uploadFileVOList.get(0).getFilePath()); - } - schCollectErrorLog.setId(idService.getDateSeq()); - return iSchCollectErrorLogDao.add(schCollectErrorLog); - } - - /** - * 编辑 - * - * @param editSchCollectErrorLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchCollectErrorLogDTO editSchCollectErrorLogDTO) { - SchCollectErrorLog schCollectErrorLog = SchCollectErrorLogConvert.INSTANCE.convertDO(editSchCollectErrorLogDTO); - return iSchCollectErrorLogDao.edit(schCollectErrorLog); - } - - /** - * 批量删除 - * - * @param deleteSchCollectErrorLogDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectErrorLogDTO deleteSchCollectErrorLogDTO) { - return iSchCollectErrorLogDao.delete(deleteSchCollectErrorLogDTO.getIds()); - } -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectRecordRetryLogServiceImpl.java b/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectRecordRetryLogServiceImpl.java deleted file mode 100644 index 1d26223..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectRecordRetryLogServiceImpl.java +++ /dev/null @@ -1,141 +0,0 @@ -package com.docus.server.service.impl; - -import com.docus.core.util.DateUtil; -import com.docus.core.util.ListUtils; -import com.docus.core.util.json.JSON; -import com.docus.core.util.property.Setters; -import com.docus.infrastructure.redis.service.IdService; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.convert.SchCollectRecordRetryLogConvert; -import com.docus.server.dto.scheduling.management.schcollector.task.ReportDownTwoDTO; -import com.docus.server.dto.scheduling.management.schcollectrecordretrylog.AddSchCollectRecordRetryLogDTO; -import com.docus.server.dto.scheduling.management.schcollectrecordretrylog.DeleteSchCollectRecordRetryLogDTO; -import com.docus.server.dto.scheduling.management.schcollectrecordretrylog.EditSchCollectRecordRetryLogDTO; -import com.docus.server.dto.scheduling.management.schterminator.NettyTerminatorDTO; -import com.docus.server.entity.scheduling.management.SchCollectRecordRetryLog; -import com.docus.server.entity.scheduling.management.SchSystemParams; -import com.docus.server.enums.SubStateEnum; -import com.docus.server.infrastructure.dao.ISchCollectRecordRetryLogDao; -import com.docus.server.infrastructure.dao.ISchSystemParamsDao; -import com.docus.server.service.ISchCollectRecordRetryLogService; -import com.docus.server.vo.scheduling.management.schcollectrecordretrylog.SchCollectRecordRetryLogVO; -import org.springframework.stereotype.Service; -import org.springframework.transaction.annotation.Transactional; -import org.springframework.util.CollectionUtils; - -import javax.annotation.Resource; -import java.util.List; -import java.util.Map; - -/** - * 采集记录表重试表 服务实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Service -public class SchCollectRecordRetryLogServiceImpl implements ISchCollectRecordRetryLogService { - @Resource - private ISchCollectRecordRetryLogDao iSchCollectRecordRetryLogDao; - @Resource - private ISchSystemParamsDao iSchSystemParamsDao; - @Resource - private IdService idService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectRecordRetryLogVO findById(String id) { - return SchCollectRecordRetryLogConvert.INSTANCE.convertVO(iSchCollectRecordRetryLogDao.findById(id)); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - PageResult result = SchCollectRecordRetryLogConvert.INSTANCE.convertVO(iSchCollectRecordRetryLogDao.search(searchDTO)); - - if (CollectionUtils.isEmpty(result.getList())) { - return new PageResult<>(); - } - - List schSystemParams = iSchSystemParamsDao.findBy("paramValue", ListUtils.distinctSelect(result.getList(), SchCollectRecordRetryLogVO::getCollectorId)); - Map taskConfigRetryLogMap = ListUtils.toMap(schSystemParams, SchSystemParams::getParamValue); - - Setters.instance().list(result.getList()).cycleSetProperties(p -> { - String collectorId = String.valueOf(p.getCollectorId()); - if (taskConfigRetryLogMap.containsKey(collectorId)) { - p.setCollectorName(taskConfigRetryLogMap.get(collectorId).getParamName()); - } - }); - - return result; - } - - @Transactional(rollbackFor = Exception.class) - @Override - public SchCollectRecordRetryLog saveOrUpdateRecordRetryLog(NettyTerminatorDTO terminal, ReportDownTwoDTO messageContent) { - //新增采集记录表 - AddSchCollectRecordRetryLogDTO retryLogDTO = new AddSchCollectRecordRetryLogDTO(); - retryLogDTO.setId(idService.getDateSeq()); - retryLogDTO.setCollectRecordId(Long.valueOf(String.valueOf(messageContent.getParams().get("collectRecordId")))); - retryLogDTO.setCollectorId(Long.valueOf(messageContent.getTasks().get(0).getCollectorId())); - retryLogDTO.setTerminatorId(terminal.getId()); - retryLogDTO.setTaskId(messageContent.getTasks().get(0).getTaskId()); - SchSystemParams params = iSchSystemParamsDao.findOneBy("paramValue", messageContent.getTasks().get(0).getCollectorId()); - retryLogDTO.setTaskName(String.format("%s%s%s", messageContent.getPatient().getName(), params.getParamName(), "采集")); - retryLogDTO.setTaskMemo(String.format("%s%s%s", messageContent.getPatient().getName(), params.getParamName(), "采集")); - retryLogDTO.setStartTime(DateUtil.now()); - retryLogDTO.setTaskDetailInfo(String.format("病案号:%s,姓名:%s,采集类型:%s", messageContent.getPatientId(), messageContent.getPatient().getName(), params.getParamName())); - retryLogDTO.setSubTaskExecState(SubStateEnum.RECEIVE); - retryLogDTO.setTaskOriginJson(JSON.toJSON(messageContent)); - - return this.add(retryLogDTO); - } - - /** - * 新增 - * - * @param addSchCollectRecordRetryLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public SchCollectRecordRetryLog add(AddSchCollectRecordRetryLogDTO addSchCollectRecordRetryLogDTO) { - SchCollectRecordRetryLog schCollectRecordRetryLog = SchCollectRecordRetryLogConvert.INSTANCE.convertDO(addSchCollectRecordRetryLogDTO); - iSchCollectRecordRetryLogDao.add(schCollectRecordRetryLog); - return schCollectRecordRetryLog; - } - - /** - * 编辑 - * - * @param editSchCollectRecordRetryLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchCollectRecordRetryLogDTO editSchCollectRecordRetryLogDTO) { - SchCollectRecordRetryLog schCollectRecordRetryLog = SchCollectRecordRetryLogConvert.INSTANCE.convertDO(editSchCollectRecordRetryLogDTO); - return iSchCollectRecordRetryLogDao.edit(schCollectRecordRetryLog); - } - - /** - * 批量删除 - * - * @param deleteSchCollectRecordRetryLogDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectRecordRetryLogDTO deleteSchCollectRecordRetryLogDTO) { - return iSchCollectRecordRetryLogDao.delete(deleteSchCollectRecordRetryLogDTO.getIds()); - } -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectRecordServiceImpl.java b/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectRecordServiceImpl.java deleted file mode 100644 index 152f416..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectRecordServiceImpl.java +++ /dev/null @@ -1,173 +0,0 @@ -package com.docus.server.service.impl; - -import com.docus.core.util.DateUtil; -import com.docus.core.util.ListUtils; -import com.docus.core.util.json.JSON; -import com.docus.core.util.property.Setters; -import com.docus.infrastructure.redis.service.IdService; -import com.docus.infrastructure.web.exception.ApiException; -import com.docus.infrastructure.web.exception.ExceptionCode; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.convert.SchCollectRecordConvert; -import com.docus.server.convert.SchCollectRecordRetryLogConvert; -import com.docus.server.dto.scheduling.management.schcollector.task.ReportDownTwoDTO; -import com.docus.server.dto.scheduling.management.schcollectrecord.AddSchCollectRecordDTO; -import com.docus.server.dto.scheduling.management.schcollectrecord.DeleteSchCollectRecordDTO; -import com.docus.server.dto.scheduling.management.schcollectrecord.EditSchCollectRecordDTO; -import com.docus.server.dto.scheduling.management.schterminator.NettyTerminatorDTO; -import com.docus.server.entity.scheduling.management.SchCollectRecord; -import com.docus.server.entity.scheduling.management.SchCollectRecordRetryLog; -import com.docus.server.entity.scheduling.management.SchSystemParams; -import com.docus.server.enums.RetryTaskEnum; -import com.docus.server.enums.SubStateEnum; -import com.docus.server.infrastructure.dao.ISchCollectRecordDao; -import com.docus.server.infrastructure.dao.ISchCollectRecordRetryLogDao; -import com.docus.server.infrastructure.dao.ISchSystemParamsDao; -import com.docus.server.infrastructure.dao.ISchTerminatorDao; -import com.docus.server.service.ISchCollectRecordService; -import com.docus.server.vo.scheduling.management.schcollectrecord.SchCollectRecordVO; -import org.springframework.stereotype.Service; -import org.springframework.transaction.annotation.Transactional; -import org.springframework.util.CollectionUtils; - -import javax.annotation.Resource; -import java.util.List; -import java.util.Map; - -/** - * 采集记录表 服务实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Service -public class SchCollectRecordServiceImpl implements ISchCollectRecordService { - @Resource - private ISchCollectRecordDao iSchCollectRecordDao; - @Resource - private ISchTerminatorDao iSchTerminatorDao; - @Resource - private ISchCollectRecordRetryLogDao iSchCollectRecordRetryLogDao; - @Resource - private ISchSystemParamsDao iSchSystemParamsDao; - @Resource - private IdService idService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectRecordVO findById(String id) { - return SchCollectRecordConvert.INSTANCE.convertVO(iSchCollectRecordDao.findById(id)); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - PageResult result = SchCollectRecordConvert.INSTANCE.convertVO(iSchCollectRecordDao.search(searchDTO)); - - if (CollectionUtils.isEmpty(result.getList())) { - return new PageResult<>(); - } - - List schSystemParams = iSchSystemParamsDao.findBy("paramValue", ListUtils.distinctSelect(result.getList(), SchCollectRecordVO::getCollectorId)); - Map taskConfigRetryLogMap = ListUtils.toMap(schSystemParams, SchSystemParams::getParamValue); - - Setters.instance().list(result.getList()).cycleSetProperties(p -> { - String collectorId = String.valueOf(p.getCollectorId()); - if (taskConfigRetryLogMap.containsKey(collectorId)) { - p.setCollectorName(taskConfigRetryLogMap.get(collectorId).getParamName()); - } - }); - - return result; - } - - @Transactional(rollbackFor = Exception.class) - @Override - public SchCollectRecord saveOrUpdateRecord(NettyTerminatorDTO terminal, ReportDownTwoDTO messageContent) { - //新增采集记录表 - AddSchCollectRecordDTO addSchCollectRecordDTO = new AddSchCollectRecordDTO(); - addSchCollectRecordDTO.setId(idService.getDateSeq()); - addSchCollectRecordDTO.setCollectorId(Long.valueOf(messageContent.getTasks().get(0).getCollectorId())); - addSchCollectRecordDTO.setTerminatorId(terminal.getId()); - addSchCollectRecordDTO.setTaskId(messageContent.getTasks().get(0).getTaskId()); - SchSystemParams params = iSchSystemParamsDao.findOneBy("paramValue", messageContent.getTasks().get(0).getCollectorId()); - addSchCollectRecordDTO.setTaskName(String.format("%s%s%s", messageContent.getPatient().getName(), params.getParamName(), "采集")); - addSchCollectRecordDTO.setTaskMemo(String.format("%s%s%s", messageContent.getPatient().getName(), params.getParamName(), "采集")); - addSchCollectRecordDTO.setStartTime(DateUtil.now()); - addSchCollectRecordDTO.setTaskDetailInfo(String.format("病案号:%s,姓名:%s,采集类型:%s", messageContent.getPatientId(), messageContent.getPatient().getName(), params.getParamName())); - addSchCollectRecordDTO.setSubTaskExecState(SubStateEnum.RECEIVE); - addSchCollectRecordDTO.setTaskOriginJson(JSON.toJSON(messageContent)); - - return this.add(addSchCollectRecordDTO); - } - - /** - * 新增 - * - * @param addSchCollectRecordDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public SchCollectRecord add(AddSchCollectRecordDTO addSchCollectRecordDTO) { - SchCollectRecord schCollectRecord = SchCollectRecordConvert.INSTANCE.convertDO(addSchCollectRecordDTO); - iSchCollectRecordDao.add(schCollectRecord); - return schCollectRecord; - } - - /** - * 编辑 - * - * @param editSchCollectRecordDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchCollectRecordDTO editSchCollectRecordDTO) { - RetryTaskEnum isRetryTask = editSchCollectRecordDTO.getIsRetryTask(); - Long id = editSchCollectRecordDTO.getId(); - - if (RetryTaskEnum.NO_RETRY_TASK.equals(isRetryTask)) { - //不是重试任务 - SchCollectRecord schCollectRecord = iSchCollectRecordDao.findById(id); - - if (null == schCollectRecord) { - throw new ApiException(ExceptionCode.ParamIllegal.getCode(), "不重复任务采集记录不存在!" + id); - } - - schCollectRecord = SchCollectRecordConvert.INSTANCE.convertDO(editSchCollectRecordDTO, schCollectRecord); - - return iSchCollectRecordDao.updateById(schCollectRecord); - } else { - //重试任务 - SchCollectRecordRetryLog schCollectRecordRetryLog = iSchCollectRecordRetryLogDao.findById(id); - - if (null == schCollectRecordRetryLog) { - throw new ApiException(ExceptionCode.ParamIllegal.getCode(), "不重复任务采集记录不存在!" + id); - } - schCollectRecordRetryLog = SchCollectRecordRetryLogConvert.INSTANCE.convertDO(editSchCollectRecordDTO, schCollectRecordRetryLog); - return iSchCollectRecordRetryLogDao.updateById(schCollectRecordRetryLog); - } - } - - /** - * 批量删除 - * - * @param deleteSchCollectRecordDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectRecordDTO deleteSchCollectRecordDTO) { - return iSchCollectRecordDao.delete(deleteSchCollectRecordDTO.getIds()); - } -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectorConfigServiceImpl.java b/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectorConfigServiceImpl.java deleted file mode 100644 index 6c4adcc..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectorConfigServiceImpl.java +++ /dev/null @@ -1,167 +0,0 @@ -package com.docus.server.service.impl; - -import com.docus.core.util.Func; -import com.docus.core.util.ListUtils; -import com.docus.core.util.json.JSON; -import com.docus.core.util.property.Setters; -import com.docus.infrastructure.redis.service.IdService; -import com.docus.infrastructure.web.exception.ApiException; -import com.docus.infrastructure.web.exception.ExceptionCode; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.common.MsgConstants; -import com.docus.server.convert.SchCollectorConfigConvert; -import com.docus.server.dto.scheduling.management.schcollectorconfig.AddSchCollectorConfigDTO; -import com.docus.server.dto.scheduling.management.schcollectorconfig.DeleteSchCollectorConfigDTO; -import com.docus.server.dto.scheduling.management.schcollectorconfig.EditSchCollectorConfigDTO; -import com.docus.server.dto.scheduling.management.schterminator.CommMsgDTO; -import com.docus.server.entity.scheduling.management.SchCollectorConfig; -import com.docus.server.entity.scheduling.management.SchSystemParams; -import com.docus.server.enums.ConfigTypeEnum; -import com.docus.server.infrastructure.dao.ISchCollectorConfigDao; -import com.docus.server.infrastructure.dao.ISchSystemParamsDao; -import com.docus.server.service.ICommMsgService; -import com.docus.server.service.ISchCollectorConfigService; -import com.docus.server.vo.scheduling.management.schcollectorconfig.SchCollectorConfigVO; -import com.docus.server.vo.scheduling.management.schcollectorconfig.TcpSchCollectorConfigContentVO; -import com.docus.server.vo.scheduling.management.schcollectorconfig.TcpSchCollectorConfigVO; -import org.springframework.stereotype.Service; -import org.springframework.util.CollectionUtils; - -import javax.annotation.Resource; -import java.util.List; -import java.util.Map; - -/** - * 采集器配置 服务实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Service -public class SchCollectorConfigServiceImpl implements ISchCollectorConfigService { - @Resource - private ISchCollectorConfigDao iSchCollectorConfigDao; - @Resource - private ISchSystemParamsDao iSchSystemParamsDao; - @Resource - private IdService idService; - @Resource - private ICommMsgService iCommMsgService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectorConfigVO findById(String id) { - return SchCollectorConfigConvert.INSTANCE.convertVO(iSchCollectorConfigDao.findById(id)); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - - PageResult result = SchCollectorConfigConvert.INSTANCE.convertVO(iSchCollectorConfigDao.search(searchDTO)); - if (CollectionUtils.isEmpty(result.getList())) { - return new PageResult<>(); - } - - List schSystemParams = iSchSystemParamsDao.findBy("paramValue", ListUtils.distinctSelect(result.getList(), SchCollectorConfigVO::getCollectorId)); - Map taskConfigRetryLogMap = ListUtils.toMap(schSystemParams, SchSystemParams::getParamValue); - - Setters.instance().list(result.getList()).cycleSetProperties(p -> { - String collectorId = String.valueOf(p.getCollectorId()); - if (taskConfigRetryLogMap.containsKey(collectorId)) { - p.setCollectorName(taskConfigRetryLogMap.get(collectorId).getParamName()); - } else { - p.setCollectorName("公共"); - } - }); - - return result; - } - - /** - * 新增 - * - * @param addSchCollectorConfigDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchCollectorConfigDTO addSchCollectorConfigDTO) { - - Long collectorId = addSchCollectorConfigDTO.getCollectorId(); - - SchCollectorConfig schCollectorConfigDO = iSchCollectorConfigDao.findOneBy("collectorId", collectorId); - - if (Func.notNull(schCollectorConfigDO)) { - throw new ApiException(ExceptionCode.ParamIllegal.getCode(), "采集器类型已经存在"); - } - - SchCollectorConfig schCollectorConfig = SchCollectorConfigConvert.INSTANCE.convertDO(addSchCollectorConfigDTO); - schCollectorConfig.setId(idService.getDateSeq()); - if (addSchCollectorConfigDTO.getConfigType().equals(ConfigTypeEnum.PUBLIC_CONFIG)) { - schCollectorConfig.setCollectorId(0L); //共有类型 - } - - return iSchCollectorConfigDao.add(schCollectorConfig); - - } - - /** - * 编辑 - * - * @param editSchCollectorConfigDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchCollectorConfigDTO editSchCollectorConfigDTO) { - SchCollectorConfig schCollectorConfig = iSchCollectorConfigDao.findById(editSchCollectorConfigDTO.getId()); - schCollectorConfig.setConfigJson(editSchCollectorConfigDTO.getConfigJson()); - return iSchCollectorConfigDao.edit(schCollectorConfig); - } - - /** - * 批量删除 - * - * @param deleteSchCollectorConfigDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectorConfigDTO deleteSchCollectorConfigDTO) { - return iSchCollectorConfigDao.delete(deleteSchCollectorConfigDTO.getIds()); - } - - /** - * 更新采集器配置文件 - */ - @Override - public void updateCollectorConfig() { - List publicConfig = iSchCollectorConfigDao.findBy("configType", ConfigTypeEnum.PUBLIC_CONFIG); - List privateConfig = iSchCollectorConfigDao.findBy("configType", ConfigTypeEnum.PRIVATE_CONFIG); - - List publicConfigVO = SchCollectorConfigConvert.INSTANCE.convertTcpVOList(publicConfig); - List privateConfigVO = SchCollectorConfigConvert.INSTANCE.convertTcpVOList(privateConfig); - - TcpSchCollectorConfigContentVO tcpSchCollectorConfigVO = TcpSchCollectorConfigContentVO.builder() - .publicConfigList(publicConfigVO) - .privateConfigList(privateConfigVO) - .build(); - - CommMsgDTO commMsgDTO = CommMsgDTO.builder() - .content(JSON.toJSON(tcpSchCollectorConfigVO)) - .messageType(MsgConstants.UPDATE_COLLECTOR_CONFIG) - .build(); - - iCommMsgService.clientsCommand(commMsgDTO); - } -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectorServiceImpl.java b/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectorServiceImpl.java deleted file mode 100644 index 185a7d6..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectorServiceImpl.java +++ /dev/null @@ -1,160 +0,0 @@ -package com.docus.server.service.impl; - -import com.docus.core.util.Func; -import com.docus.core.util.ListUtils; -import com.docus.core.util.property.Setters; -import com.docus.infrastructure.redis.service.IdService; -import com.docus.infrastructure.web.exception.ApiException; -import com.docus.infrastructure.web.exception.ExceptionCode; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.log.annotation.TrackGroup; -import com.docus.server.common.process.TcpProcessor; -import com.docus.server.convert.SchCollectorConvert; -import com.docus.server.dto.scheduling.management.schcollector.AddSchCollectorDTO; -import com.docus.server.dto.scheduling.management.schcollector.DeleteSchCollectorDTO; -import com.docus.server.dto.scheduling.management.schcollector.EditSchCollectorDTO; -import com.docus.server.dto.scheduling.management.schcollector.UpdateSchCollectorDTO; -import com.docus.server.entity.scheduling.management.SchCollector; -import com.docus.server.entity.scheduling.management.SchSystemParams; -import com.docus.server.infrastructure.dao.ISchCollectorDao; -import com.docus.server.service.ISchCollectorService; -import com.docus.server.service.ISchSystemParamsService; -import com.docus.server.vo.scheduling.management.schcollector.SchCollectorVO; -import org.springframework.stereotype.Service; -import org.springframework.transaction.annotation.Transactional; -import org.springframework.util.CollectionUtils; - -import javax.annotation.Resource; -import java.util.Date; -import java.util.Map; - -/** - * 采集器管理 服务实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Service -public class SchCollectorServiceImpl implements ISchCollectorService { - @Resource - private ISchCollectorDao iSchCollectorDao; - @Resource - private ISchSystemParamsService iSchSystemParamsService; - @Resource - private IdService idService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectorVO findById(String id) { - return SchCollectorConvert.INSTANCE.convertVO(iSchCollectorDao.findById(id)); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - PageResult result = SchCollectorConvert.INSTANCE.convertVO(iSchCollectorDao.search(searchDTO)); - - if (CollectionUtils.isEmpty(result.getList())) { - return new PageResult<>(); - } - - Map map = iSchSystemParamsService.find(ListUtils.distinctSelect(result.getList(), SchCollectorVO::getCollectorId)); - - Setters.instance().list(result.getList()).cycleSetProperties(p -> { - String collectorId = String.valueOf(p.getCollectorId()); - if (map.containsKey(collectorId)) { - p.setCollectorName(map.get(collectorId).getParamName()); - } - }); - - return result; - } - - /** - * 选为当前版本并更新 - * - * @return 成功或失败 - */ - @TrackGroup(group = "SchCollectorServiceImpl", processor = TcpProcessor.class) - @Transactional(rollbackFor = Exception.class) - @Override - public boolean updateVersion(UpdateSchCollectorDTO updateDTO) { - SchCollector schCollector = iSchCollectorDao.findOneBy("collectorId", updateDTO.getCollectorId()); - schCollector.setCollectorVersionId(updateDTO.getCollectorVersionId()); - return iSchCollectorDao.updateById(schCollector); - } - - @Override - public SchCollector findByCollectorId(String collectorId) { - return iSchCollectorDao.findOneBy("collectorId", collectorId); - } - - /** - * 新增 - * - * @param addSchCollectorDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchCollectorDTO addSchCollectorDTO) { - - Long collectorId = addSchCollectorDTO.getCollectorId(); - - SchCollector schCollectorDO = iSchCollectorDao.findOneBy("collectorId", collectorId); - - if (Func.notNull(schCollectorDO)) { - throw new ApiException(ExceptionCode.ParamIllegal.getCode(), "采集器类型已经存在"); - } - - SchCollector schCollector = SchCollectorConvert.INSTANCE.convertDO(addSchCollectorDTO); - schCollector.setId(idService.getDateSeq()); - return iSchCollectorDao.add(schCollector); - } - - /** - * 编辑 - * - * @param editSchCollectorDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchCollectorDTO editSchCollectorDTO) { - - Long id = editSchCollectorDTO.getId(); - - SchCollector schCollector = iSchCollectorDao.findById(id); - - if (Func.isNull(schCollector)) { - throw new ApiException(ExceptionCode.ParamIllegal.getCode(), "采集器不存在,无法更新"); - } - - schCollector.setCollectLanguage(editSchCollectorDTO.getCollectLanguage()); - schCollector.setStartMode(editSchCollectorDTO.getStartMode()); - schCollector.setTaskTimeout(editSchCollectorDTO.getTaskTimeout()); - schCollector.setUpdateTime(new Date()); - return iSchCollectorDao.edit(schCollector); - } - - /** - * 批量删除 - * - * @param deleteSchCollectorDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectorDTO deleteSchCollectorDTO) { - return iSchCollectorDao.delete(deleteSchCollectorDTO.getIds()); - } -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectorVersionFileServiceImpl.java b/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectorVersionFileServiceImpl.java deleted file mode 100644 index c6599fd..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectorVersionFileServiceImpl.java +++ /dev/null @@ -1,136 +0,0 @@ -package com.docus.server.service.impl; - -import com.docus.infrastructure.redis.service.IdService; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.convert.SchCollectorVersionFileConvert; -import com.docus.server.dto.scheduling.management.schcollectorversionfile.AddSchCollectorVersionFileDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionfile.DeleteSchCollectorVersionFileDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionfile.EditSchCollectorVersionFileDTO; -import com.docus.server.entity.scheduling.management.SchCollectorVersion; -import com.docus.server.entity.scheduling.management.SchCollectorVersionFile; -import com.docus.server.enums.CancelEnum; -import com.docus.server.infrastructure.dao.ISchCollectorVersionDao; -import com.docus.server.infrastructure.dao.ISchCollectorVersionFileDao; -import com.docus.server.service.IFileUploadService; -import com.docus.server.service.ISchCollectorVersionFileService; -import com.docus.server.vo.scheduling.management.schcollectorversionfile.SchCollectorVersionFileVO; -import com.docus.server.vo.scheduling.management.schcollectorversionfile.UploadFileVO; -import com.google.common.collect.Lists; -import org.springframework.stereotype.Service; -import org.springframework.transaction.annotation.Transactional; -import org.springframework.web.multipart.MultipartFile; - -import javax.annotation.Resource; -import java.util.List; - -/** - * 采集器版本列表更新包管理 服务实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Service -public class SchCollectorVersionFileServiceImpl implements ISchCollectorVersionFileService { - @Resource - private ISchCollectorVersionFileDao iSchCollectorVersionFileDao; - @Resource - private ISchCollectorVersionDao iSchCollectorVersionDao; - @Resource - private IdService idService; - @Resource - private IFileUploadService iFileUploadService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectorVersionFileVO findById(String id) { - return SchCollectorVersionFileConvert.INSTANCE.convertVO(iSchCollectorVersionFileDao.findById(id)); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return SchCollectorVersionFileConvert.INSTANCE.convertVO(iSchCollectorVersionFileDao.search(searchDTO)); - } - - @Transactional(rollbackFor = Exception.class) - @Override - public void addVersionAndFile(AddSchCollectorVersionFileDTO addDTO, MultipartFile[] multipartFiles) throws Exception { - List uploadFileVOList = iFileUploadService.uploadFile(multipartFiles, null); - - SchCollectorVersion schCollectorVersion = new SchCollectorVersion(); - schCollectorVersion.setId(idService.getDateSeq()); - schCollectorVersion.setCollectorId(addDTO.getCollectorId()); - schCollectorVersion.setCollectVersion(addDTO.getCollectorVersionNo()); - iSchCollectorVersionDao.save(schCollectorVersion); - - List schCollectorVersionFiles = Lists.newArrayList(); - - uploadFileVOList.forEach(p -> { - SchCollectorVersionFile schCollectorVersionFile = new SchCollectorVersionFile(); - schCollectorVersionFile.setId(idService.getDateSeq()); - schCollectorVersionFile.setCollectorId(addDTO.getCollectorId()); - schCollectorVersionFile.setCollectorVersionId(schCollectorVersion.getId()); - schCollectorVersionFile.setFileTitle(p.getFileTitle()); - schCollectorVersionFile.setFilePath(p.getFilePath()); - schCollectorVersionFile.setFileName(p.getFileName()); - schCollectorVersionFile.setFileSize(p.getFileSize()); - schCollectorVersionFile.setFileType(p.getFileType()); - schCollectorVersionFile.setState(CancelEnum.NO_CANCEL); - schCollectorVersionFiles.add(schCollectorVersionFile); - }); - - iSchCollectorVersionFileDao.saveBatch(schCollectorVersionFiles, 500); - } - - @Override - public SchCollectorVersionFile findByCollectorIdAndVersionId(Long collectorId, Long collectorVersionId) { - return iSchCollectorVersionFileDao.findByVersionIdAndCollectorId(collectorId, collectorVersionId); - } - - /** - * 新增 - * - * @param addSchCollectorVersionFileDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchCollectorVersionFileDTO addSchCollectorVersionFileDTO) { - SchCollectorVersionFile schCollectorVersionFile = SchCollectorVersionFileConvert.INSTANCE.convertDO(addSchCollectorVersionFileDTO); - return iSchCollectorVersionFileDao.add(schCollectorVersionFile); - } - - /** - * 编辑 - * - * @param editSchCollectorVersionFileDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchCollectorVersionFileDTO editSchCollectorVersionFileDTO) { - SchCollectorVersionFile schCollectorVersionFile = SchCollectorVersionFileConvert.INSTANCE.convertDO(editSchCollectorVersionFileDTO); - return iSchCollectorVersionFileDao.edit(schCollectorVersionFile); - } - - /** - * 批量删除 - * - * @param deleteSchCollectorVersionFileDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectorVersionFileDTO deleteSchCollectorVersionFileDTO) { - return iSchCollectorVersionFileDao.delete(deleteSchCollectorVersionFileDTO.getIds()); - } -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectorVersionLogServiceImpl.java b/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectorVersionLogServiceImpl.java deleted file mode 100644 index 5347328..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectorVersionLogServiceImpl.java +++ /dev/null @@ -1,85 +0,0 @@ -package com.docus.server.service.impl; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.convert.SchCollectorVersionLogConvert; -import com.docus.server.dto.scheduling.management.schcollectorversionlog.AddSchCollectorVersionLogDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionlog.DeleteSchCollectorVersionLogDTO; -import com.docus.server.dto.scheduling.management.schcollectorversionlog.EditSchCollectorVersionLogDTO; -import com.docus.server.entity.scheduling.management.SchCollectorVersionLog; -import com.docus.server.infrastructure.dao.ISchCollectorVersionLogDao; -import com.docus.server.service.ISchCollectorVersionLogService; -import com.docus.server.vo.scheduling.management.schcollectorversionlog.SchCollectorVersionLogVO; -import org.springframework.stereotype.Service; - -import javax.annotation.Resource; - -/** - * 采集器版本更新日志管理 服务实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Service -public class SchCollectorVersionLogServiceImpl implements ISchCollectorVersionLogService { - @Resource - private ISchCollectorVersionLogDao iSchCollectorVersionLogDao; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectorVersionLogVO findById(String id) { - return SchCollectorVersionLogConvert.INSTANCE.convertVO(iSchCollectorVersionLogDao.findById(id)); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return SchCollectorVersionLogConvert.INSTANCE.convertVO(iSchCollectorVersionLogDao.search(searchDTO)); - } - - /** - * 新增 - * - * @param addSchCollectorVersionLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchCollectorVersionLogDTO addSchCollectorVersionLogDTO) { - SchCollectorVersionLog schCollectorVersionLog = SchCollectorVersionLogConvert.INSTANCE.convertDO(addSchCollectorVersionLogDTO); - return iSchCollectorVersionLogDao.add(schCollectorVersionLog); - } - - /** - * 编辑 - * - * @param editSchCollectorVersionLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchCollectorVersionLogDTO editSchCollectorVersionLogDTO) { - SchCollectorVersionLog schCollectorVersionLog = SchCollectorVersionLogConvert.INSTANCE.convertDO(editSchCollectorVersionLogDTO); - return iSchCollectorVersionLogDao.edit(schCollectorVersionLog); - } - - /** - * 批量删除 - * - * @param deleteSchCollectorVersionLogDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectorVersionLogDTO deleteSchCollectorVersionLogDTO) { - return iSchCollectorVersionLogDao.delete(deleteSchCollectorVersionLogDTO.getIds()); - } -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectorVersionServiceImpl.java b/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectorVersionServiceImpl.java deleted file mode 100644 index 79b9d1e..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchCollectorVersionServiceImpl.java +++ /dev/null @@ -1,118 +0,0 @@ -package com.docus.server.service.impl; - -import com.docus.core.util.ListUtils; -import com.docus.core.util.property.Setters; -import com.docus.infrastructure.redis.service.IdService; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.convert.SchCollectorVersionConvert; -import com.docus.server.dto.scheduling.management.schcollectorversion.AddSchCollectorVersionDTO; -import com.docus.server.dto.scheduling.management.schcollectorversion.DeleteSchCollectorVersionDTO; -import com.docus.server.dto.scheduling.management.schcollectorversion.EditSchCollectorVersionDTO; -import com.docus.server.entity.scheduling.management.SchCollectorVersion; -import com.docus.server.entity.scheduling.management.SchSystemParams; -import com.docus.server.infrastructure.dao.ISchCollectorVersionDao; -import com.docus.server.service.ISchCollectorVersionService; -import com.docus.server.service.ISchSystemParamsService; -import com.docus.server.vo.scheduling.management.schcollectorversion.SchCollectorVersionVO; -import org.springframework.stereotype.Service; -import org.springframework.util.CollectionUtils; - -import javax.annotation.Resource; -import java.util.Map; - -/** - * 采集器版本列表管理 服务实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Service -public class SchCollectorVersionServiceImpl implements ISchCollectorVersionService { - @Resource - private ISchCollectorVersionDao iSchCollectorVersionDao; - @Resource - private ISchSystemParamsService iSchSystemParamsService; - @Resource - private IdService idService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchCollectorVersionVO findById(String id) { - return SchCollectorVersionConvert.INSTANCE.convertVO(iSchCollectorVersionDao.findById(id)); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - - PageResult result = SchCollectorVersionConvert.INSTANCE.convertVO(iSchCollectorVersionDao.search(searchDTO)); - - if (CollectionUtils.isEmpty(result.getList())) { - return new PageResult<>(); - } - - Map map = iSchSystemParamsService.find(ListUtils.distinctSelect(result.getList(), SchCollectorVersionVO::getCollectorId)); - - Setters.instance().list(result.getList()).cycleSetProperties(p -> { - String collectorId = String.valueOf(p.getCollectorId()); - if (map.containsKey(collectorId)) { - p.setCollectorName(map.get(collectorId).getParamName()); - } - }); - - return result; - } - - @Override - public SchCollectorVersion findByVersion(Long collectorId, String collectorVersionNo) { - return iSchCollectorVersionDao.findByVersion(collectorId, collectorVersionNo); - } - - /** - * 新增 - * - * @param addSchCollectorVersionDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchCollectorVersionDTO addSchCollectorVersionDTO) { - SchCollectorVersion schCollectorVersion = SchCollectorVersionConvert.INSTANCE.convertDO(addSchCollectorVersionDTO); - schCollectorVersion.setId(idService.getDateSeq()); - return iSchCollectorVersionDao.add(schCollectorVersion); - } - - /** - * 编辑 - * - * @param editSchCollectorVersionDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchCollectorVersionDTO editSchCollectorVersionDTO) { - SchCollectorVersion schCollectorVersion = SchCollectorVersionConvert.INSTANCE.convertDO(editSchCollectorVersionDTO); - return iSchCollectorVersionDao.edit(schCollectorVersion); - } - - /** - * 批量删除 - * - * @param deleteSchCollectorVersionDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchCollectorVersionDTO deleteSchCollectorVersionDTO) { - return iSchCollectorVersionDao.delete(deleteSchCollectorVersionDTO.getIds()); - } -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchOperationLogServiceImpl.java b/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchOperationLogServiceImpl.java deleted file mode 100644 index 8c7248a..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchOperationLogServiceImpl.java +++ /dev/null @@ -1,85 +0,0 @@ -package com.docus.server.service.impl; - -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.convert.SchOperationLogConvert; -import com.docus.server.dto.scheduling.management.schoperationlog.AddSchOperationLogDTO; -import com.docus.server.dto.scheduling.management.schoperationlog.DeleteSchOperationLogDTO; -import com.docus.server.dto.scheduling.management.schoperationlog.EditSchOperationLogDTO; -import com.docus.server.entity.scheduling.management.SchOperationLog; -import com.docus.server.infrastructure.dao.ISchOperationLogDao; -import com.docus.server.service.ISchOperationLogService; -import com.docus.server.vo.scheduling.management.schoperationlog.SchOperationLogVO; -import org.springframework.stereotype.Service; - -import javax.annotation.Resource; - -/** - * 采集调度器操作日志 服务实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Service -public class SchOperationLogServiceImpl implements ISchOperationLogService { - @Resource - private ISchOperationLogDao iSchOperationLogDao; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchOperationLogVO findById(String id) { - return SchOperationLogConvert.INSTANCE.convertVO(iSchOperationLogDao.findById(id)); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return SchOperationLogConvert.INSTANCE.convertVO(iSchOperationLogDao.search(searchDTO)); - } - - /** - * 新增 - * - * @param addSchOperationLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchOperationLogDTO addSchOperationLogDTO) { - SchOperationLog schOperationLog = SchOperationLogConvert.INSTANCE.convertDO(addSchOperationLogDTO); - return iSchOperationLogDao.add(schOperationLog); - } - - /** - * 编辑 - * - * @param editSchOperationLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchOperationLogDTO editSchOperationLogDTO) { - SchOperationLog schOperationLog = SchOperationLogConvert.INSTANCE.convertDO(editSchOperationLogDTO); - return iSchOperationLogDao.edit(schOperationLog); - } - - /** - * 批量删除 - * - * @param deleteSchOperationLogDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchOperationLogDTO deleteSchOperationLogDTO) { - return iSchOperationLogDao.delete(deleteSchOperationLogDTO.getIds()); - } -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchSystemParamsServiceImpl.java b/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchSystemParamsServiceImpl.java deleted file mode 100644 index 837f456..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchSystemParamsServiceImpl.java +++ /dev/null @@ -1,95 +0,0 @@ -package com.docus.server.service.impl; - -import com.docus.core.util.ListUtils; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.convert.SchSystemParamsConvert; -import com.docus.server.dto.scheduling.management.schsystemparams.AddSchSystemParamsDTO; -import com.docus.server.dto.scheduling.management.schsystemparams.DeleteSchSystemParamsDTO; -import com.docus.server.dto.scheduling.management.schsystemparams.EditSchSystemParamsDTO; -import com.docus.server.entity.scheduling.management.SchSystemParams; -import com.docus.server.infrastructure.dao.ISchSystemParamsDao; -import com.docus.server.service.ISchSystemParamsService; -import com.docus.server.vo.scheduling.management.schsystemparams.SchSystemParamsVO; -import org.springframework.stereotype.Service; - -import javax.annotation.Resource; -import java.util.List; -import java.util.Map; - -/** - * 系统参数表 服务实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Service -public class SchSystemParamsServiceImpl implements ISchSystemParamsService { - @Resource - private ISchSystemParamsDao iSchSystemParamsDao; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchSystemParamsVO findById(String id) { - return SchSystemParamsConvert.INSTANCE.convertVO(iSchSystemParamsDao.findById(id)); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return SchSystemParamsConvert.INSTANCE.convertVO(iSchSystemParamsDao.search(searchDTO)); - } - - /** - * 新增 - * - * @param addSchSystemParamsDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchSystemParamsDTO addSchSystemParamsDTO) { - SchSystemParams schSystemParams = SchSystemParamsConvert.INSTANCE.convertDO(addSchSystemParamsDTO); - return iSchSystemParamsDao.add(schSystemParams); - } - - /** - * 编辑 - * - * @param editSchSystemParamsDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchSystemParamsDTO editSchSystemParamsDTO) { - SchSystemParams schSystemParams = SchSystemParamsConvert.INSTANCE.convertDO(editSchSystemParamsDTO); - return iSchSystemParamsDao.edit(schSystemParams); - } - - /** - * 批量删除 - * - * @param deleteSchSystemParamsDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchSystemParamsDTO deleteSchSystemParamsDTO) { - return iSchSystemParamsDao.delete(deleteSchSystemParamsDTO.getIds()); - } - - @Override - public Map find(List paramValueIds) { - List schSystemParams = iSchSystemParamsDao.findBy("paramValue", paramValueIds); - return ListUtils.toMap(schSystemParams, SchSystemParams::getParamValue); - } - -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchTerminatorServiceImpl.java b/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchTerminatorServiceImpl.java deleted file mode 100644 index 4421e83..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchTerminatorServiceImpl.java +++ /dev/null @@ -1,136 +0,0 @@ -package com.docus.server.service.impl; - -import com.docus.core.util.Func; -import com.docus.infrastructure.redis.service.IdService; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.convert.SchTerminatorConvert; -import com.docus.server.dto.scheduling.management.schterminator.AddSchTerminatorDTO; -import com.docus.server.dto.scheduling.management.schterminator.DeleteSchTerminatorDTO; -import com.docus.server.dto.scheduling.management.schterminator.EditSchTerminatorDTO; -import com.docus.server.dto.scheduling.management.schterminator.NettyTerminatorDTO; -import com.docus.server.entity.scheduling.management.SchTerminator; -import com.docus.server.enums.BusyStateEnum; -import com.docus.server.infrastructure.dao.ISchTerminatorDao; -import com.docus.server.service.ISchTerminatorService; -import com.docus.server.vo.scheduling.management.schterminator.SchTerminatorVO; -import org.springframework.stereotype.Service; - -import javax.annotation.Resource; -import java.util.Date; -import java.util.List; - -/** - * 执行管理器 服务实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Service -public class SchTerminatorServiceImpl implements ISchTerminatorService { - @Resource - private ISchTerminatorDao iSchTerminatorDao; - @Resource - private IdService idService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchTerminatorVO findById(String id) { - return SchTerminatorConvert.INSTANCE.convertVO(iSchTerminatorDao.findById(id)); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return SchTerminatorConvert.INSTANCE.convertVO(iSchTerminatorDao.search(searchDTO)); - } - - @Override - public SchTerminatorVO saveOrUpdate(String terminatorIp, NettyTerminatorDTO nettyTerminatorDTO) { - - SchTerminator schTerminator = iSchTerminatorDao.findOneBy("terminatorIp", terminatorIp); - - //新增 - if (Func.isNull(schTerminator)) { - SchTerminator schTerminatorDO = new SchTerminator(); - - schTerminatorDO.setId(idService.getDateSeq()); - schTerminatorDO.setTerminatorIp(terminatorIp); - schTerminatorDO.setTerminatorName(terminatorIp); - schTerminatorDO.setOnlineState(nettyTerminatorDTO.getOnlineState()); - schTerminatorDO.setBusyState(BusyStateEnum.IDLE); - - iSchTerminatorDao.save(schTerminatorDO); - - return SchTerminatorConvert.INSTANCE.convertVO(schTerminatorDO); - } else { - //更新 - schTerminator.setBusyState(nettyTerminatorDTO.getBusyState()); - schTerminator.setOnlineState(nettyTerminatorDTO.getOnlineState()); - schTerminator.setUpdateTime(new Date()); - - iSchTerminatorDao.updateById(schTerminator); - - return SchTerminatorConvert.INSTANCE.convertVO(schTerminator); - } - - } - - @Override - public List findAll() { - return iSchTerminatorDao.findAll(); - } - - @Override - public void batchUpdate(List terminators) { - iSchTerminatorDao.updateBatchById(terminators, 20); - } - - /** - * 新增 - * - * @param addSchTerminatorDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchTerminatorDTO addSchTerminatorDTO) { - SchTerminator schTerminator = SchTerminatorConvert.INSTANCE.convertDO(addSchTerminatorDTO); - return iSchTerminatorDao.add(schTerminator); - } - - /** - * 编辑 - * - * @param editSchTerminatorDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchTerminatorDTO editSchTerminatorDTO) { - Long id = editSchTerminatorDTO.getId(); - SchTerminator schTerminatorDO = iSchTerminatorDao.findById(id); - SchTerminator schTerminator = SchTerminatorConvert.INSTANCE.convertDO(editSchTerminatorDTO, schTerminatorDO); - return iSchTerminatorDao.edit(schTerminator); - } - - /** - * 批量删除 - * - * @param deleteSchTerminatorDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchTerminatorDTO deleteSchTerminatorDTO) { - return iSchTerminatorDao.delete(deleteSchTerminatorDTO.getIds()); - } -} - diff --git a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchVirtualLogServiceImpl.java b/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchVirtualLogServiceImpl.java deleted file mode 100644 index 92ceaa5..0000000 --- a/collector-terminal-management/src/main/java/com/docus/server/service/impl/SchVirtualLogServiceImpl.java +++ /dev/null @@ -1,89 +0,0 @@ -package com.docus.server.service.impl; - -import com.docus.infrastructure.redis.service.IdService; -import com.docus.infrastructure.web.request.SearchDTO; -import com.docus.infrastructure.web.response.PageResult; -import com.docus.server.convert.SchVirtualLogConvert; -import com.docus.server.dto.scheduling.management.schvirtuallog.AddSchVirtualLogDTO; -import com.docus.server.dto.scheduling.management.schvirtuallog.DeleteSchVirtualLogDTO; -import com.docus.server.dto.scheduling.management.schvirtuallog.EditSchVirtualLogDTO; -import com.docus.server.entity.scheduling.management.SchVirtualLog; -import com.docus.server.infrastructure.dao.ISchVirtualLogDao; -import com.docus.server.service.ISchVirtualLogService; -import com.docus.server.vo.scheduling.management.schvirtuallog.SchVirtualLogVO; -import org.springframework.stereotype.Service; - -import javax.annotation.Resource; - -/** - * 虚拟机使用情况 服务实现类 - * - * @author AutoGenerator - * @since 2023-07-15 - */ -@Service -public class SchVirtualLogServiceImpl implements ISchVirtualLogService { - @Resource - private ISchVirtualLogDao iSchVirtualLogDao; - @Resource - private IdService idService; - - /** - * 按主键查询 - * - * @param id 主键Id - * @return 实体 - */ - @Override - public SchVirtualLogVO findById(String id) { - return SchVirtualLogConvert.INSTANCE.convertVO(iSchVirtualLogDao.findById(id)); - } - - /** - * 关键字搜索 - * - * @param searchDTO 搜索参数 - * @return 分页列表 - */ - @Override - public PageResult search(SearchDTO searchDTO) { - return SchVirtualLogConvert.INSTANCE.convertVO(iSchVirtualLogDao.search(searchDTO)); - } - - /** - * 新增 - * - * @param addSchVirtualLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean add(AddSchVirtualLogDTO addSchVirtualLogDTO) { - SchVirtualLog schVirtualLog = SchVirtualLogConvert.INSTANCE.convertDO(addSchVirtualLogDTO); - schVirtualLog.setId(idService.getDateSeq()); - return iSchVirtualLogDao.add(schVirtualLog); - } - - /** - * 编辑 - * - * @param editSchVirtualLogDTO 编辑参数 - * @return 成功或失败 - */ - @Override - public boolean edit(EditSchVirtualLogDTO editSchVirtualLogDTO) { - SchVirtualLog schVirtualLog = SchVirtualLogConvert.INSTANCE.convertDO(editSchVirtualLogDTO); - return iSchVirtualLogDao.edit(schVirtualLog); - } - - /** - * 批量删除 - * - * @param deleteSchVirtualLogDTO 删除参数 - * @return 成功或失败 - */ - @Override - public int delete(DeleteSchVirtualLogDTO deleteSchVirtualLogDTO) { - return iSchVirtualLogDao.delete(deleteSchVirtualLogDTO.getIds()); - } -} - diff --git a/collector-terminal-management/src/test/java/com/docus/server/Example.java b/collector-terminal-management/src/test/java/com/docus/server/Example.java new file mode 100644 index 0000000..5a836ed --- /dev/null +++ b/collector-terminal-management/src/test/java/com/docus/server/Example.java @@ -0,0 +1,56 @@ +package com.docus.server; + +import oshi.SystemInfo; +import oshi.hardware.CentralProcessor; +import oshi.hardware.GlobalMemory; +import oshi.hardware.HardwareAbstractionLayer; +import oshi.hardware.NetworkIF; +import oshi.software.os.FileSystem; +import oshi.software.os.OSFileStore; + +import java.util.Arrays; +import java.util.List; + +public class Example { + public static void main(String[] args) { + SystemInfo systemInfo = new SystemInfo(); + CentralProcessor processor = systemInfo.getHardware().getProcessor(); + int logicalProcessorCount = processor.getLogicalProcessorCount(); + String cpuModel = processor.getProcessorIdentifier().getName(); + long[] systemCpuLoadTicks = processor.getSystemCpuLoadTicks(); + + System.out.println(logicalProcessorCount); + System.out.println(cpuModel); + System.out.println(Arrays.asList(systemCpuLoadTicks)); + + GlobalMemory memory = systemInfo.getHardware().getMemory(); + long totalMemorySize = memory.getTotal(); + long availableMemorySize = memory.getAvailable(); + double memoryUsage = (totalMemorySize - availableMemorySize) * 100.0 / totalMemorySize; + System.out.println(totalMemorySize); + System.out.println(availableMemorySize); + System.out.println(memoryUsage); + + HardwareAbstractionLayer hal = systemInfo.getHardware(); + FileSystem fileSystem = systemInfo.getOperatingSystem().getFileSystem(); + List fileStores = fileSystem.getFileStores(); + for (OSFileStore store : fileStores) { + long totalSpace = store.getTotalSpace(); + long usableSpace = store.getUsableSpace(); + double usage = (totalSpace - usableSpace) * 100.0 / totalSpace; + System.out.println(totalSpace); + System.out.println(usableSpace); + System.out.println(usage); + } + + List networkIFs = systemInfo.getHardware().getNetworkIFs(); + for (NetworkIF networkIF : networkIFs) { + String name = networkIF.getName(); + long receiveBytes = networkIF.getBytesRecv(); + long transmitBytes = networkIF.getBytesSent(); + System.out.println(name); + System.out.println(receiveBytes); + System.out.println(transmitBytes); + } + } +} diff --git a/collector-terminal-management/src/test/java/com/docus/server/SystemInfoUtils.java b/collector-terminal-management/src/test/java/com/docus/server/SystemInfoUtils.java new file mode 100644 index 0000000..a3f2ceb --- /dev/null +++ b/collector-terminal-management/src/test/java/com/docus/server/SystemInfoUtils.java @@ -0,0 +1,313 @@ +package com.docus.server; + +import com.alibaba.fastjson.JSONArray; +import com.alibaba.fastjson.JSONObject; +import oshi.SystemInfo; +import oshi.hardware.CentralProcessor; +import oshi.hardware.GlobalMemory; +import oshi.hardware.HardwareAbstractionLayer; +import oshi.hardware.NetworkIF; +import oshi.software.os.FileSystem; +import oshi.software.os.OSFileStore; +import oshi.software.os.OperatingSystem; +import oshi.util.Util; + +import java.io.BufferedReader; +import java.io.IOException; +import java.io.InputStreamReader; +import java.net.InetAddress; +import java.net.UnknownHostException; +import java.text.DecimalFormat; +import java.util.Formatter; +import java.util.HashMap; +import java.util.List; +import java.util.Map; +import java.util.Optional; +import java.util.Properties; +import java.util.StringTokenizer; + +/** + * 系统消息工具类 + **/ +public class SystemInfoUtils { + + private static final int OSHI_WAIT_SECOND = 1000; + private static final int SLEEP_TIME = 2 * 1000; + private static SystemInfo systemInfo = new SystemInfo(); + private static HardwareAbstractionLayer hardware = systemInfo.getHardware(); + private static OperatingSystem operatingSystem = systemInfo.getOperatingSystem(); + + public static void main(String[] args) throws Exception { + JSONObject info = getInfo(); + System.out.println(info); + } + + public static JSONObject getCpuInfo() { + JSONObject cpuInfo = new JSONObject(); + CentralProcessor processor = hardware.getProcessor(); + // CPU信息 + long[] prevTicks = processor.getSystemCpuLoadTicks(); + Util.sleep(OSHI_WAIT_SECOND); + long[] ticks = processor.getSystemCpuLoadTicks(); + long nice = ticks[CentralProcessor.TickType.NICE.getIndex()] - prevTicks[CentralProcessor.TickType.NICE.getIndex()]; + long irq = ticks[CentralProcessor.TickType.IRQ.getIndex()] - prevTicks[CentralProcessor.TickType.IRQ.getIndex()]; + long softirq = ticks[CentralProcessor.TickType.SOFTIRQ.getIndex()] - prevTicks[CentralProcessor.TickType.SOFTIRQ.getIndex()]; + long steal = ticks[CentralProcessor.TickType.STEAL.getIndex()] - prevTicks[CentralProcessor.TickType.STEAL.getIndex()]; + long cSys = ticks[CentralProcessor.TickType.SYSTEM.getIndex()] - prevTicks[CentralProcessor.TickType.SYSTEM.getIndex()]; + long user = ticks[CentralProcessor.TickType.USER.getIndex()] - prevTicks[CentralProcessor.TickType.USER.getIndex()]; + long iowait = ticks[CentralProcessor.TickType.IOWAIT.getIndex()] - prevTicks[CentralProcessor.TickType.IOWAIT.getIndex()]; + long idle = ticks[CentralProcessor.TickType.IDLE.getIndex()] - prevTicks[CentralProcessor.TickType.IDLE.getIndex()]; + long totalCpu = user + nice + cSys + idle + iowait + irq + softirq + steal; + //cpu核数 + cpuInfo.put("cpuNum", processor.getLogicalProcessorCount()); + //cpu系统使用率 + cpuInfo.put("cSys", new DecimalFormat("#.##%").format(cSys * 1.0 / totalCpu)); + //cpu用户使用率 + cpuInfo.put("user", new DecimalFormat("#.##%").format(user * 1.0 / totalCpu)); + //cpu当前等待率 + cpuInfo.put("iowait", new DecimalFormat("#.##%").format(iowait * 1.0 / totalCpu)); + //cpu当前使用率 + cpuInfo.put("idle", new DecimalFormat("#.##%").format(1.0 - (idle * 1.0 / totalCpu))); + return cpuInfo; + } + + /** + * 系统jvm信息 + */ + public static JSONObject getJvmInfo() { + JSONObject cpuInfo = new JSONObject(); + Properties props = System.getProperties(); + Runtime runtime = Runtime.getRuntime(); + long jvmTotalMemoryByte = runtime.totalMemory(); + long freeMemoryByte = runtime.freeMemory(); + //jvm总内存 + cpuInfo.put("total", formatByte(runtime.totalMemory())); + //空闲空间 + cpuInfo.put("free", formatByte(runtime.freeMemory())); + //jvm最大可申请 + cpuInfo.put("max", formatByte(runtime.maxMemory())); + //vm已使用内存 + cpuInfo.put("user", formatByte(jvmTotalMemoryByte - freeMemoryByte)); + //jvm内存使用率 + cpuInfo.put("usageRate", new DecimalFormat("#.##%").format((jvmTotalMemoryByte - freeMemoryByte) * 1.0 / jvmTotalMemoryByte)); + //jdk版本 + cpuInfo.put("jdkVersion", props.getProperty("java.version")); + //jdk路径 + cpuInfo.put("jdkHome", props.getProperty("java.home")); + return cpuInfo; + } + + /** + * 系统内存信息 + */ + public static JSONObject getMemInfo() { + JSONObject cpuInfo = new JSONObject(); + GlobalMemory memory = systemInfo.getHardware().getMemory(); + //总内存 + long totalByte = memory.getTotal(); + //剩余 + long acaliableByte = memory.getAvailable(); + //总内存 + cpuInfo.put("total", formatByte(totalByte)); + //使用 + cpuInfo.put("used", formatByte(totalByte - acaliableByte)); + //剩余内存 + cpuInfo.put("free", formatByte(acaliableByte)); + //使用率 + cpuInfo.put("usageRate", new DecimalFormat("#.##%").format((totalByte - acaliableByte) * 1.0 / totalByte)); + return cpuInfo; + } + + /** + * 带宽 + */ + public static JSONArray networkIFs() throws Exception { + JSONObject cpuInfo; + JSONArray sysFiles = new JSONArray(); + + List networkIFs = systemInfo.getHardware().getNetworkIFs(); + for (NetworkIF networkIF : networkIFs) { + String name = networkIF.getName(); + long receiveBytes = networkIF.getBytesRecv(); + long transmitBytes = networkIF.getBytesSent(); + + cpuInfo = new JSONObject(); + //名称 + cpuInfo.put("name", name); + //网络接收 + cpuInfo.put("receiveBytes", formatNumber(receiveBytes / (1024.0 * (2 * 1000 / 1000)))); + //网络发送 + cpuInfo.put("transmitBytes", formatNumber(transmitBytes / (1024.0 * (2 * 1000 / 1000)))); + + sysFiles.add(cpuInfo); + } + return sysFiles; + } + + public static JSONObject getNetWork() { + JSONObject networkInfo = new JSONObject(); + Properties props = System.getProperties(); + String os = props.getProperty("os.name").toLowerCase(); + os = os.startsWith("win") ? "windows" : "linux"; + Map result = new HashMap<>(); + Process pro = null; + Runtime r = Runtime.getRuntime(); + BufferedReader input = null; + try { + String command = "windows".equals(os) ? "netstat -e" : "ifconfig"; + pro = r.exec(command); + input = new BufferedReader(new InputStreamReader(pro.getInputStream())); + long result1[] = readInLine(input, os); + Thread.sleep(SLEEP_TIME); + pro.destroy(); + input.close(); + pro = r.exec(command); + input = new BufferedReader(new InputStreamReader(pro.getInputStream())); + long result2[] = readInLine(input, os); + String rxPercent = formatNumber((result2[0] - result1[0]) / (1024.0 * (SLEEP_TIME / 1000)));// 下行速率(kB/s) + String txPercent = formatNumber((result2[1] - result1[1]) / (1024.0 * (SLEEP_TIME / 1000)));// 上行速率(kB/s) + networkInfo.put("rxPercent", rxPercent); + networkInfo.put("txPercent", txPercent); + } catch (Exception e) { + e.printStackTrace(); + } finally { + if (input != null) { + try { + input.close(); + } catch (IOException e) { + e.printStackTrace(); + } + } + Optional.ofNullable(pro).ifPresent(p -> p.destroy()); + } + return networkInfo; + } + + private static long[] readInLine(BufferedReader input, String osType) { + long arr[] = new long[2]; + StringTokenizer tokenStat = null; + try { + if (osType.equals("linux")) { // 获取linux环境下的网口上下行速率 + long rx = 0, tx = 0; + String line = null; + //RX packets:4171603 errors:0 dropped:0 overruns:0 frame:0 + //TX packets:4171603 errors:0 dropped:0 overruns:0 carrier:0 + while ((line = input.readLine()) != null) { + if (line.indexOf("RX packets") >= 0) { + rx += Long.parseLong(line.substring(line.indexOf("RX packets") + 11, line.indexOf(" ", line.indexOf("RX packets") + 11))); + } else if (line.indexOf("TX packets") >= 0) { + tx += Long.parseLong(line.substring(line.indexOf("TX packets") + 11, line.indexOf(" ", line.indexOf("TX packets") + 11))); + } + } + arr[0] = rx; + arr[1] = tx; + } else { // 获取windows环境下的网口上下行速率 + input.readLine(); + input.readLine(); + input.readLine(); + input.readLine(); + tokenStat = new StringTokenizer(input.readLine()); + tokenStat.nextToken(); + arr[0] = Long.parseLong(tokenStat.nextToken()); + arr[1] = Long.parseLong(tokenStat.nextToken()); + } + } catch (Exception e) { + e.printStackTrace(); + } + return arr; + } + + + private static String formatNumber(double f) { + return new Formatter().format("%.2f", f).toString(); + } + + /** + * 系统盘符信息 + */ + public static JSONArray getSysFileInfo() { + JSONObject cpuInfo; + JSONArray sysFiles = new JSONArray(); + FileSystem fileSystem = operatingSystem.getFileSystem(); + List fsArray = fileSystem.getFileStores(); + for (OSFileStore fs : fsArray) { + cpuInfo = new JSONObject(); + //盘符路径 + cpuInfo.put("dirName", fs.getMount()); + //盘符类型 + cpuInfo.put("sysTypeName", fs.getType()); + //文件类型 + cpuInfo.put("typeName", fs.getName()); + //总大小 + cpuInfo.put("total", formatByte(fs.getTotalSpace())); + //剩余大小 + cpuInfo.put("free", formatByte(fs.getUsableSpace())); + //已经使用量 + cpuInfo.put("used", formatByte(fs.getTotalSpace() - fs.getUsableSpace())); + if (fs.getTotalSpace() == 0) { + //资源的使用率 + cpuInfo.put("usage", 0); + } else { + cpuInfo.put("usage", new DecimalFormat("#.##%").format((fs.getTotalSpace() - fs.getUsableSpace()) * 1.0 / fs.getTotalSpace())); + } + sysFiles.add(cpuInfo); + } + return sysFiles; + } + + /** + * 系统信息 + */ + public static JSONObject getSysInfo() throws UnknownHostException { + JSONObject cpuInfo = new JSONObject(); + Properties props = System.getProperties(); + //操作系统名 + cpuInfo.put("osName", props.getProperty("os.name")); + //系统架构 + cpuInfo.put("osArch", props.getProperty("os.arch")); + //服务器名称 + cpuInfo.put("computerName", InetAddress.getLocalHost().getHostName()); + //服务器Ip + cpuInfo.put("computerIp", InetAddress.getLocalHost().getHostAddress()); + //项目路径 + cpuInfo.put("userDir", props.getProperty("user.dir")); + return cpuInfo; + } + + + /** + * 所有系统信息 + */ + public static JSONObject getInfo() throws Exception { + JSONObject info = new JSONObject(); + info.put("cpuInfo", getCpuInfo()); + info.put("jvmInfo", getJvmInfo()); + info.put("memInfo", getMemInfo()); + info.put("sysInfo", getSysInfo()); + info.put("sysFileInfo", getSysFileInfo()); + info.put("networkInfo", getNetWork()); + return info; + } + + /** + * 单位转换 + */ + private static String formatByte(long byteNumber) { + //换算单位 + double FORMAT = 1024.0; + double kbNumber = byteNumber / FORMAT; + if (kbNumber < FORMAT) { + return new DecimalFormat("#.##KB").format(kbNumber); + } + double mbNumber = kbNumber / FORMAT; + if (mbNumber < FORMAT) { + return new DecimalFormat("#.##MB").format(mbNumber); + } + double gbNumber = mbNumber / FORMAT; + if (gbNumber < FORMAT) { + return new DecimalFormat("#.##GB").format(gbNumber); + } + double tbNumber = gbNumber / FORMAT; + return new DecimalFormat("#.##TB").format(tbNumber); + } +} diff --git a/pom.xml b/pom.xml index 12e66ee..ba3e05e 100644 --- a/pom.xml +++ b/pom.xml @@ -244,6 +244,12 @@ 1.0-SNAPSHOT + + com.github.oshi + oshi-core + 5.7.4 + +