mirror of
https://gitee.com/wujiawei1207537021/wu-lazy-cloud-network.git
synced 2025-06-06 13:27:55 +08:00
【fix】端口池类型添加 服务端内网穿透、服务端内网渗透、客户端渗透服务端、客户端渗透客户端
This commit is contained in:
parent
ee6cafa8f2
commit
5852aad88a
@ -0,0 +1,35 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.common;
|
||||
|
||||
import lombok.Builder;
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
|
||||
/**
|
||||
* describe 内网穿透映射 真实服务端
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2023/12/29 05:21 下午
|
||||
**/
|
||||
@Builder
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
public class InternalNetworkPermeateRealServer {
|
||||
|
||||
|
||||
|
||||
/**
|
||||
* 客户端目标地址
|
||||
*/
|
||||
private String clientTargetIp;
|
||||
|
||||
/**
|
||||
* 客户端目标端口
|
||||
*/
|
||||
private Integer clientTargetPort;
|
||||
|
||||
|
||||
/**
|
||||
* 访问端口
|
||||
*/
|
||||
private Integer visitorPort;
|
||||
}
|
@ -0,0 +1,26 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.netty.filter;
|
||||
|
||||
import io.netty.channel.ChannelPipeline;
|
||||
import io.netty.channel.socket.SocketChannel;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.decoder.TransferDecoder;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.encoder.TransferEncoder;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.filter.DebugChannelInitializer;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.netty.handler.PermeateClientRealHandler;
|
||||
|
||||
public class PermeateClientRealFilter extends DebugChannelInitializer<SocketChannel> {
|
||||
/**
|
||||
* This method will be called once the {@link Channel} was registered. After the method returns this instance
|
||||
* will be removed from the {@link ChannelPipeline} of the {@link Channel}.
|
||||
*
|
||||
* @param ch the {@link Channel} which was registered.
|
||||
*/
|
||||
@Override
|
||||
protected void initChannel0(SocketChannel ch) {
|
||||
ChannelPipeline pipeline = ch.pipeline();
|
||||
// 解码、编码
|
||||
pipeline.addLast(new TransferDecoder(Integer.MAX_VALUE, 1024 * 1024*10));
|
||||
pipeline.addLast(new TransferEncoder());
|
||||
pipeline.addLast(new PermeateClientRealHandler());
|
||||
|
||||
}
|
||||
}
|
@ -0,0 +1,39 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.netty.filter;
|
||||
|
||||
import io.netty.channel.Channel;
|
||||
import io.netty.channel.ChannelDuplexHandler;
|
||||
import io.netty.channel.ChannelHandlerContext;
|
||||
import io.netty.channel.ChannelPipeline;
|
||||
import io.netty.channel.socket.SocketChannel;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.InternalNetworkPenetrationRealClient;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.InternalNetworkPermeateRealServer;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.adapter.ChannelFlowAdapter;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.filter.DebugChannelInitializer;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.netty.handler.PermeateVisitorHandler;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.netty.handler.VisitorHandler;
|
||||
|
||||
public class PermeateVisitorFilter extends DebugChannelInitializer<SocketChannel> {
|
||||
private final InternalNetworkPermeateRealServer internalNetworkPermeateRealServer;
|
||||
private final ChannelFlowAdapter channelFlowAdapter;
|
||||
|
||||
public PermeateVisitorFilter(InternalNetworkPermeateRealServer internalNetworkPermeateRealServer, ChannelFlowAdapter channelFlowAdapter) {
|
||||
this.internalNetworkPermeateRealServer = internalNetworkPermeateRealServer;
|
||||
this.channelFlowAdapter = channelFlowAdapter;
|
||||
}
|
||||
|
||||
/**
|
||||
* This method will be called once the {@link Channel} was registered. After the method returns this instance
|
||||
* will be removed from the {@link ChannelPipeline} of the {@link Channel}.
|
||||
*
|
||||
* @param ch the {@link Channel} which was registered.
|
||||
* @throws Exception is thrown if an error occurs. In that case it will be handled by
|
||||
* {@link #exceptionCaught(ChannelHandlerContext, Throwable)} which will by default connectionClose
|
||||
* the {@link Channel}.
|
||||
*/
|
||||
@Override
|
||||
protected void initChannel0(SocketChannel ch) throws Exception {
|
||||
ChannelPipeline pipeline = ch.pipeline();
|
||||
pipeline.addLast(new ChannelDuplexHandler());
|
||||
pipeline.addLast(new PermeateVisitorHandler(internalNetworkPermeateRealServer, channelFlowAdapter));
|
||||
}
|
||||
}
|
@ -0,0 +1,74 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.netty.handler;
|
||||
|
||||
|
||||
import io.netty.channel.Channel;
|
||||
import io.netty.channel.ChannelHandlerContext;
|
||||
import io.netty.channel.ChannelOption;
|
||||
import io.netty.channel.SimpleChannelInboundHandler;
|
||||
import lombok.extern.slf4j.Slf4j;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.MessageType;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.NettyByteBuf;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.NettyCommunicationIdContext;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.NettyProxyMsg;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.utils.ChannelAttributeKeyUtils;
|
||||
import org.wu.framework.core.utils.ObjectUtils;
|
||||
|
||||
/**
|
||||
* 来自客户端 真实服务器返回的数据请求
|
||||
*/
|
||||
@Slf4j
|
||||
public class PermeateClientRealHandler extends SimpleChannelInboundHandler<NettyByteBuf> {
|
||||
|
||||
@Override
|
||||
public void channelActive(ChannelHandlerContext ctx) throws Exception {
|
||||
// 根据访客ID 确认真实通道 读写打开
|
||||
Channel channel = ctx.channel();
|
||||
Channel nextChannel = ChannelAttributeKeyUtils.getNextChannel(channel);
|
||||
nextChannel.config().setOption(ChannelOption.AUTO_READ, true);
|
||||
super.channelActive(ctx);
|
||||
}
|
||||
|
||||
|
||||
|
||||
@Override
|
||||
public void channelRead0(ChannelHandlerContext ctx,NettyByteBuf nettyByteBuf) {
|
||||
|
||||
byte[] bytes = nettyByteBuf.getData();
|
||||
log.debug("bytes.length:{}",bytes.length);
|
||||
log.debug("接收客户端真实服务数据:{}", new String(bytes));
|
||||
Channel nextChannel = ChannelAttributeKeyUtils.getNextChannel(ctx.channel());
|
||||
nextChannel.writeAndFlush(bytes);
|
||||
}
|
||||
|
||||
|
||||
|
||||
@Override
|
||||
public void channelInactive(ChannelHandlerContext ctx) throws Exception {
|
||||
// 客户端真实通信通道
|
||||
Channel nextChannel = ChannelAttributeKeyUtils.getNextChannel(ctx.channel());
|
||||
if (nextChannel != null) {
|
||||
// 上报关闭这个客户端的访客通道
|
||||
nextChannel.close();
|
||||
}
|
||||
|
||||
super.channelInactive(ctx);
|
||||
}
|
||||
|
||||
@Override
|
||||
public void channelWritabilityChanged(ChannelHandlerContext ctx) throws Exception {
|
||||
|
||||
|
||||
// 获取访客的传输通道
|
||||
Channel nextChannel = ChannelAttributeKeyUtils.getNextChannel(ctx.channel());
|
||||
if (nextChannel != null) {
|
||||
log.debug("transfer AUTO_READ:{} ",ctx.channel().isWritable());
|
||||
nextChannel.config().setOption(ChannelOption.AUTO_READ, ctx.channel().isWritable());
|
||||
}
|
||||
|
||||
}
|
||||
|
||||
@Override
|
||||
public void exceptionCaught(ChannelHandlerContext ctx, Throwable cause) throws Exception {
|
||||
super.exceptionCaught(ctx, cause);
|
||||
}
|
||||
}
|
@ -0,0 +1,135 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.netty.handler;
|
||||
|
||||
|
||||
import io.netty.buffer.ByteBuf;
|
||||
import io.netty.channel.Channel;
|
||||
import io.netty.channel.ChannelHandlerContext;
|
||||
import io.netty.channel.ChannelOption;
|
||||
import io.netty.channel.SimpleChannelInboundHandler;
|
||||
import lombok.extern.slf4j.Slf4j;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.InternalNetworkPermeateRealServer;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.adapter.ChannelFlowAdapter;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.enums.ChannelFlowEnum;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.utils.ChannelAttributeKeyUtils;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.netty.flow.ServerChannelFlow;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.netty.socket.NettyPermeateClientRealSocket;
|
||||
|
||||
import java.util.UUID;
|
||||
|
||||
@Slf4j
|
||||
public class PermeateVisitorHandler extends SimpleChannelInboundHandler<ByteBuf> {
|
||||
private final InternalNetworkPermeateRealServer internalNetworkPermeateRealServer;
|
||||
private final ChannelFlowAdapter channelFlowAdapter;// 流量适配器
|
||||
// private final NettyChannelPool nettyChannelPool = new DefaultNettyChannelPool(10);
|
||||
|
||||
public PermeateVisitorHandler(InternalNetworkPermeateRealServer internalNetworkPermeateRealServer, ChannelFlowAdapter channelFlowAdapter) {
|
||||
this.internalNetworkPermeateRealServer = internalNetworkPermeateRealServer;
|
||||
this.channelFlowAdapter = channelFlowAdapter;
|
||||
}
|
||||
|
||||
@Override
|
||||
public void channelActive(ChannelHandlerContext ctx) throws Exception {
|
||||
// 访客连接上代理服务器了
|
||||
Channel visitorChannel = ctx.channel();
|
||||
// 先不读取访客数据
|
||||
visitorChannel.config().setOption(ChannelOption.AUTO_READ, false);
|
||||
|
||||
|
||||
// 生成访客ID
|
||||
String visitorId = UUID.randomUUID().toString();
|
||||
// 当前通道绑定访客ID
|
||||
ChannelAttributeKeyUtils.buildVisitorId(visitorChannel, visitorId);
|
||||
|
||||
// 判断是否有可用的通道 如果没有创建新的通道
|
||||
|
||||
// 创建这是客户端通道池
|
||||
NettyPermeateClientRealSocket.buildRealServer(internalNetworkPermeateRealServer, visitorChannel, visitorId);
|
||||
|
||||
|
||||
Channel nextChannel = ChannelAttributeKeyUtils.getNextChannel(visitorChannel);
|
||||
if (nextChannel != null) {
|
||||
// 绑定 访客
|
||||
ChannelAttributeKeyUtils.buildVisitorId(nextChannel, visitorId);
|
||||
nextChannel.config().setOption(ChannelOption.AUTO_READ, true);
|
||||
} else {
|
||||
log.error("服务端内网渗透失败,无法连接到服务端访客");
|
||||
}
|
||||
|
||||
log.info("内网渗透 服务端访客端口连接成功了");
|
||||
super.channelActive(ctx);
|
||||
}
|
||||
|
||||
@Override
|
||||
public void channelRead0(ChannelHandlerContext ctx, ByteBuf buf) {
|
||||
|
||||
// 访客通道
|
||||
Channel visitorChannel = ctx.channel();
|
||||
Integer visitorPort = internalNetworkPermeateRealServer.getVisitorPort();
|
||||
byte[] bytes = new byte[buf.readableBytes()];
|
||||
buf.readBytes(bytes);
|
||||
// 获取客户端通道,而后进行数据下发
|
||||
log.debug("【服务端】访客端口成功接收数据:{}", new String(bytes));
|
||||
|
||||
// 使用访客的通信通道
|
||||
|
||||
Channel nextChannel = ChannelAttributeKeyUtils.getNextChannel(visitorChannel);
|
||||
// 绑定数据流量
|
||||
ChannelAttributeKeyUtils.buildInFlow(nextChannel, bytes.length);
|
||||
nextChannel.writeAndFlush(bytes);
|
||||
|
||||
// 处理访客流量
|
||||
ServerChannelFlow serverChannelFlow = ServerChannelFlow
|
||||
.builder()
|
||||
.channelFlowEnum(ChannelFlowEnum.IN_FLOW)
|
||||
.port(visitorPort)
|
||||
.flow(bytes.length)
|
||||
.build();
|
||||
channelFlowAdapter.asyncHandler(visitorChannel, serverChannelFlow);
|
||||
log.debug("服务端访客端口成功发送数据了");
|
||||
}
|
||||
|
||||
@Override
|
||||
public void channelInactive(ChannelHandlerContext ctx) throws Exception {
|
||||
|
||||
// 通信通道自动读写打开 ,然后关闭通信通道
|
||||
Channel nextChannel = ChannelAttributeKeyUtils.getNextChannel(ctx.channel());
|
||||
if (nextChannel != null && nextChannel.isActive()) {
|
||||
|
||||
nextChannel.config().setOption(ChannelOption.AUTO_READ, true);
|
||||
// 通知服务端 关闭访问通道、真实通道
|
||||
nextChannel.close();
|
||||
}
|
||||
log.warn("服务端访客端口断开连接");
|
||||
super.channelInactive(ctx);
|
||||
}
|
||||
|
||||
@Override
|
||||
public void channelWritabilityChanged(ChannelHandlerContext ctx) throws Exception {
|
||||
Channel nextChannel = ChannelAttributeKeyUtils.getNextChannel(ctx.channel());
|
||||
if (nextChannel != null) {
|
||||
log.debug("transfer AUTO_READ:{} ", ctx.channel().isWritable());
|
||||
nextChannel.config().setOption(ChannelOption.AUTO_READ, ctx.channel().isWritable());
|
||||
}
|
||||
if (ctx.channel().isWritable()) {
|
||||
log.debug("Channel is writable again");
|
||||
// 恢复之前暂停的操作,如写入数据
|
||||
} else {
|
||||
log.debug("Channel is not writable");
|
||||
// 暂停写入操作,等待可写状态
|
||||
}
|
||||
log.info("visitorId:{} channelWritabilityChanged!");
|
||||
}
|
||||
|
||||
@Override
|
||||
public void exceptionCaught(ChannelHandlerContext ctx, Throwable cause) throws Exception {
|
||||
log.error("exceptionCaught");
|
||||
// 使用通信通道 下发关闭访客
|
||||
Channel nextChannel = ChannelAttributeKeyUtils.getNextChannel(ctx.channel());
|
||||
if (nextChannel != null) {
|
||||
// 下发关闭访客
|
||||
nextChannel.close();
|
||||
}
|
||||
|
||||
ctx.close();
|
||||
}
|
||||
}
|
@ -0,0 +1,85 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.netty.socket;
|
||||
|
||||
|
||||
import io.netty.bootstrap.Bootstrap;
|
||||
import io.netty.channel.*;
|
||||
import io.netty.channel.nio.NioEventLoopGroup;
|
||||
import io.netty.channel.socket.nio.NioSocketChannel;
|
||||
import lombok.extern.slf4j.Slf4j;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.InternalNetworkPermeateRealServer;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.NettyVisitorPortContext;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.utils.ChannelAttributeKeyUtils;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.netty.filter.PermeateClientRealFilter;
|
||||
|
||||
/**
|
||||
* 客户端连接真实服务
|
||||
*/
|
||||
@Slf4j
|
||||
public class NettyPermeateClientRealSocket {
|
||||
private static final EventLoopGroup eventLoopGroup = new NioEventLoopGroup();
|
||||
|
||||
/**
|
||||
* 连接真实服务
|
||||
*
|
||||
* @param internalNetworkPermeateRealServer 访客信息
|
||||
*/
|
||||
public static void buildRealServer(InternalNetworkPermeateRealServer internalNetworkPermeateRealServer,Channel visitorChannel ,String visitorId) {
|
||||
|
||||
buildNewRealServer(internalNetworkPermeateRealServer,visitorChannel,visitorId);
|
||||
|
||||
}
|
||||
|
||||
/**
|
||||
* @param internalNetworkPermeateRealServer 访客信息
|
||||
* @param visitorChannel
|
||||
* @param visitorId
|
||||
*/
|
||||
private static void buildNewRealServer(InternalNetworkPermeateRealServer internalNetworkPermeateRealServer, Channel visitorChannel, String visitorId) {
|
||||
try {
|
||||
String clientTargetIp = internalNetworkPermeateRealServer.getClientTargetIp();
|
||||
Integer clientTargetPort = internalNetworkPermeateRealServer.getClientTargetPort();
|
||||
Integer visitorPort = internalNetworkPermeateRealServer.getVisitorPort();
|
||||
Bootstrap bootstrap = new Bootstrap();
|
||||
bootstrap.group(eventLoopGroup).channel(NioSocketChannel.class)
|
||||
// 设置读缓冲区为2M
|
||||
.option(ChannelOption.SO_RCVBUF, 2048 * 1024)
|
||||
// 设置写缓冲区为1M
|
||||
.option(ChannelOption.SO_SNDBUF, 1024 * 1024)
|
||||
// .option(ChannelOption.TCP_NODELAY, false)
|
||||
.option(ChannelOption.CONNECT_TIMEOUT_MILLIS, 1000 * 60)//连接超时时间设置为 60 秒
|
||||
// .option(ChannelOption.SO_BACKLOG, 128)//务端接受连接的队列长度 默认128
|
||||
// .option(ChannelOption.RCVBUF_ALLOCATOR, new NettyRecvByteBufAllocator(1024 * 1024))//用于Channel分配接受Buffer的分配器 默认AdaptiveRecvByteBufAllocator.DEFAULT
|
||||
.option(ChannelOption.WRITE_BUFFER_WATER_MARK, new WriteBufferWaterMark(1024 * 1024, 1024 * 1024 * 2))
|
||||
.handler(new PermeateClientRealFilter())
|
||||
|
||||
;
|
||||
|
||||
|
||||
bootstrap.connect(clientTargetIp, clientTargetPort).addListener((ChannelFutureListener) future -> {
|
||||
if (future.isSuccess()) {
|
||||
// 客户端链接真实服务成功 设置自动读写false 等待访客连接成功后设置成true
|
||||
Channel realChannel = future.channel();
|
||||
realChannel.config().setOption(ChannelOption.AUTO_READ, false);
|
||||
|
||||
log.info("服务端内网渗透通过,绑定本地服务,IP:{},端口:{} 新建通道成功", clientTargetIp, clientTargetPort);
|
||||
ChannelAttributeKeyUtils.buildVisitorPort(realChannel, visitorPort);
|
||||
// 缓存当前端口对应的通道、通道池
|
||||
ChannelAttributeKeyUtils.buildNextChannel(realChannel, visitorChannel);
|
||||
ChannelAttributeKeyUtils.buildNextChannel(visitorChannel, realChannel);
|
||||
|
||||
ChannelAttributeKeyUtils.buildVisitorId(realChannel, visitorId);
|
||||
|
||||
} else {
|
||||
log.error("服务端内网渗透 无法连接当前网络内的目标IP:【{}】,目标端口:【{}】", clientTargetIp, clientTargetPort);
|
||||
// future.channel().eventLoop().schedule(() -> {
|
||||
// buildNewRealServer(internalNetworkPermeateRealServer);
|
||||
// }, 2, TimeUnit.SECONDS);
|
||||
}
|
||||
});
|
||||
} catch (Exception e) {
|
||||
e.printStackTrace();
|
||||
}
|
||||
}
|
||||
|
||||
|
||||
}
|
@ -0,0 +1,221 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.netty.socket;
|
||||
|
||||
|
||||
import io.netty.bootstrap.ServerBootstrap;
|
||||
import io.netty.channel.*;
|
||||
import io.netty.channel.nio.NioEventLoopGroup;
|
||||
import io.netty.channel.socket.nio.NioServerSocketChannel;
|
||||
import lombok.Getter;
|
||||
import lombok.extern.slf4j.Slf4j;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.InternalNetworkPermeateRealServer;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.NettyVisitorPortContext;
|
||||
import org.framework.lazy.cloud.network.heartbeat.common.adapter.ChannelFlowAdapter;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.netty.filter.PermeateVisitorFilter;
|
||||
|
||||
import java.io.IOException;
|
||||
|
||||
/**
|
||||
* 服务端渗透访客端口
|
||||
*/
|
||||
@Slf4j
|
||||
public class NettyPermeateVisitorSocket {
|
||||
private final EventLoopGroup bossGroup = new NioEventLoopGroup();
|
||||
private final EventLoopGroup workerGroup = new NioEventLoopGroup();
|
||||
private final PermeateVisitorFilter permeateVisitorFilter;
|
||||
|
||||
@Getter
|
||||
private final int visitorPort;
|
||||
|
||||
private final InternalNetworkPermeateRealServer internalNetworkPermeateRealServer;
|
||||
|
||||
public NettyPermeateVisitorSocket(PermeateVisitorFilter permeateVisitorFilter,
|
||||
InternalNetworkPermeateRealServer internalNetworkPermeateRealServer ,
|
||||
int visitorPort) {
|
||||
this.permeateVisitorFilter = permeateVisitorFilter;
|
||||
this.visitorPort = visitorPort;
|
||||
this.internalNetworkPermeateRealServer = internalNetworkPermeateRealServer;
|
||||
}
|
||||
|
||||
|
||||
/**
|
||||
* 启动服务代理
|
||||
*
|
||||
* @throws Exception
|
||||
*/
|
||||
public void start() throws Exception {
|
||||
|
||||
Channel visitor = NettyVisitorPortContext.getVisitor(visitorPort);
|
||||
if (visitor == null) {
|
||||
ServerBootstrap bootstrap = new ServerBootstrap();
|
||||
bootstrap
|
||||
.group(bossGroup, workerGroup)
|
||||
.channel(NioServerSocketChannel.class)
|
||||
|
||||
|
||||
// 设置读缓冲区为2M
|
||||
.childOption(ChannelOption.SO_RCVBUF, 2048 * 1024)
|
||||
// 设置写缓冲区为1M
|
||||
.childOption(ChannelOption.SO_SNDBUF, 1024 * 1024)
|
||||
|
||||
|
||||
.childOption(ChannelOption.SO_KEEPALIVE, true)
|
||||
// .childOption(ChannelOption.TCP_NODELAY, false)
|
||||
.childOption(ChannelOption.CONNECT_TIMEOUT_MILLIS, 1000 * 60)//连接超时时间设置为 60 秒
|
||||
// .childOption(ChannelOption.RCVBUF_ALLOCATOR, new NettyRecvByteBufAllocator(1024 * 1024))//用于Channel分配接受Buffer的分配器 默认 AdaptiveRecvByteBufAllocator.DEFAULT
|
||||
.childOption(ChannelOption.WRITE_BUFFER_WATER_MARK, new WriteBufferWaterMark(1024 * 1024, 1024 * 1024 * 2))
|
||||
|
||||
|
||||
.childHandler(permeateVisitorFilter);
|
||||
ChannelFuture sync = bootstrap.bind(visitorPort).sync();
|
||||
sync.addListener((ChannelFutureListener) future -> {
|
||||
if (future.isSuccess()) {
|
||||
// 这里时异步处理
|
||||
log.info("内网渗透服务端端口:[{}] 开启", visitorPort);
|
||||
NettyVisitorPortContext.pushVisitor(visitorPort, future.channel());
|
||||
|
||||
} else {
|
||||
log.error("内网渗透服务端端口:[{}] 开启失败", visitorPort);
|
||||
}
|
||||
});
|
||||
|
||||
} else {
|
||||
log.warn("内网渗透服务端端口:[{}] 重复启动", visitorPort);
|
||||
}
|
||||
|
||||
}
|
||||
|
||||
public void close() throws IOException, InterruptedException {
|
||||
if (!bossGroup.isShutdown()) {
|
||||
bossGroup.shutdownGracefully();
|
||||
}
|
||||
if (!workerGroup.isShutdown()) {
|
||||
workerGroup.shutdownGracefully();
|
||||
}
|
||||
Channel visitor = NettyVisitorPortContext.getVisitor(visitorPort);
|
||||
if (visitor != null) {
|
||||
|
||||
// close channel
|
||||
visitor.close();
|
||||
// remove visitor
|
||||
NettyVisitorPortContext.removeVisitor(visitorPort);
|
||||
|
||||
// log.warn("关闭客户端 :【{}】 访客户端口:【{}】", clientId, visitorPort);
|
||||
} else {
|
||||
log.warn("关闭内网渗透端口失败 渗透端口:【{}】", visitorPort);
|
||||
}
|
||||
}
|
||||
|
||||
|
||||
public static final class NettyVisitorSocketBuilder {
|
||||
|
||||
|
||||
/**
|
||||
* 客户端目标地址
|
||||
*/
|
||||
private String clientTargetIp;
|
||||
|
||||
/**
|
||||
* 客户端目标端口
|
||||
*/
|
||||
private Integer clientTargetPort;
|
||||
|
||||
|
||||
/**
|
||||
* 访问端口
|
||||
*/
|
||||
private Integer permeateVisitorPort;
|
||||
/**
|
||||
* 访客ID
|
||||
*/
|
||||
private String visitorId;
|
||||
|
||||
/**
|
||||
* 流量适配器
|
||||
*/
|
||||
private ChannelFlowAdapter channelFlowAdapter;
|
||||
|
||||
public static NettyPermeateVisitorSocket.NettyVisitorSocketBuilder builder() {
|
||||
return new NettyPermeateVisitorSocket.NettyVisitorSocketBuilder();
|
||||
}
|
||||
|
||||
/**
|
||||
* 绑定客户端目标IP
|
||||
*
|
||||
* @param clientTargetIp 客户端目标IP
|
||||
* @return 当前对象
|
||||
*/
|
||||
public NettyPermeateVisitorSocket.NettyVisitorSocketBuilder builderClientTargetIp(String clientTargetIp) {
|
||||
this.clientTargetIp = clientTargetIp;
|
||||
return this;
|
||||
}
|
||||
|
||||
/**
|
||||
* 绑定客户端目标端口
|
||||
*
|
||||
* @param clientTargetPort 客户端目标端口
|
||||
* @return 当前对象
|
||||
*/
|
||||
public NettyPermeateVisitorSocket.NettyVisitorSocketBuilder builderClientTargetPort(Integer clientTargetPort) {
|
||||
this.clientTargetPort = clientTargetPort;
|
||||
return this;
|
||||
}
|
||||
|
||||
/**
|
||||
* 绑定访客端口
|
||||
*
|
||||
* @param permeateVisitorPort 访客端口
|
||||
* @return 当前对象
|
||||
*/
|
||||
public NettyPermeateVisitorSocket.NettyVisitorSocketBuilder builderVisitorPort(Integer permeateVisitorPort) {
|
||||
this.permeateVisitorPort = permeateVisitorPort;
|
||||
return this;
|
||||
}
|
||||
|
||||
/**
|
||||
* 绑定流量适配器
|
||||
*
|
||||
* @param channelFlowAdapter 流量适配器
|
||||
* @return 当前对象
|
||||
*/
|
||||
public NettyPermeateVisitorSocket.NettyVisitorSocketBuilder builderChannelFlowAdapter(ChannelFlowAdapter channelFlowAdapter) {
|
||||
this.channelFlowAdapter = channelFlowAdapter;
|
||||
return this;
|
||||
}
|
||||
|
||||
/**
|
||||
* 绑定访客ID
|
||||
*
|
||||
* @param visitorId 访客ID
|
||||
* @return 当前对象
|
||||
*/
|
||||
public NettyPermeateVisitorSocket.NettyVisitorSocketBuilder builderVisitorId(String visitorId) {
|
||||
this.visitorId = visitorId;
|
||||
return this;
|
||||
}
|
||||
|
||||
public NettyPermeateVisitorSocket build() {
|
||||
|
||||
if (clientTargetIp == null) {
|
||||
throw new IllegalArgumentException("clientTargetIp must not null");
|
||||
}
|
||||
if (clientTargetPort == null) {
|
||||
throw new IllegalArgumentException("clientTargetPort must not null");
|
||||
}
|
||||
if (permeateVisitorPort == null) {
|
||||
throw new IllegalArgumentException("visitorPort must not null");
|
||||
}
|
||||
InternalNetworkPermeateRealServer internalNetworkPermeateRealServer = InternalNetworkPermeateRealServer
|
||||
.builder()
|
||||
.clientTargetIp(clientTargetIp)
|
||||
.clientTargetPort(clientTargetPort)
|
||||
.visitorPort(permeateVisitorPort)
|
||||
.build();
|
||||
|
||||
PermeateVisitorFilter permeateVisitorFilter = new PermeateVisitorFilter(internalNetworkPermeateRealServer, channelFlowAdapter);
|
||||
return new NettyPermeateVisitorSocket(permeateVisitorFilter,internalNetworkPermeateRealServer, permeateVisitorPort);
|
||||
}
|
||||
|
||||
|
||||
}
|
||||
|
||||
}
|
@ -16,7 +16,7 @@ import org.framework.lazy.cloud.network.heartbeat.server.netty.filter.VisitorFil
|
||||
import java.io.IOException;
|
||||
|
||||
/**
|
||||
* 访客链接socket
|
||||
* 内网穿透服务端访客通道
|
||||
*
|
||||
* @see NettyVisitorPortContext
|
||||
* @see NettyClientVisitorContext
|
||||
|
@ -0,0 +1,109 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application;
|
||||
|
||||
import org.wu.framework.web.response.Result;
|
||||
import org.wu.framework.web.response.ResultFactory;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPool;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolRemoveCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolStoryCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolUpdateCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolQueryListCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolQueryOneCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.dto.LazyNettyClientPermeatePortPoolDTO;
|
||||
import java.util.List;
|
||||
import org.wu.framework.lazy.orm.database.lambda.domain.LazyPage;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyApplication
|
||||
**/
|
||||
|
||||
public interface LazyNettyClientPermeatePortPoolApplication {
|
||||
|
||||
|
||||
/**
|
||||
* describe 新增客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolStoryCommand 新增客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPool>} 客户端内网渗透端口池新增后领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyNettyClientPermeatePortPool> story(LazyNettyClientPermeatePortPoolStoryCommand lazyNettyClientPermeatePortPoolStoryCommand);
|
||||
|
||||
/**
|
||||
* describe 批量新增客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolStoryCommandList 批量新增客户端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyClientPermeatePortPool>>} 客户端内网渗透端口池新增后领域对象集合
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<List<LazyNettyClientPermeatePortPool>> batchStory(List<LazyNettyClientPermeatePortPoolStoryCommand> lazyNettyClientPermeatePortPoolStoryCommandList);
|
||||
|
||||
/**
|
||||
* describe 更新客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolUpdateCommand 更新客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPool>} 客户端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyNettyClientPermeatePortPool> updateOne(LazyNettyClientPermeatePortPoolUpdateCommand lazyNettyClientPermeatePortPoolUpdateCommand);
|
||||
|
||||
/**
|
||||
* describe 查询单个客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolQueryOneCommand 查询单个客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPoolDTO>} 客户端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyNettyClientPermeatePortPoolDTO> findOne(LazyNettyClientPermeatePortPoolQueryOneCommand lazyNettyClientPermeatePortPoolQueryOneCommand);
|
||||
|
||||
/**
|
||||
* describe 查询多个客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolQueryListCommand 查询多个客户端内网渗透端口池
|
||||
* @return {@link Result <List<LazyNettyClientPermeatePortPoolDTO>>} 客户端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result <List<LazyNettyClientPermeatePortPoolDTO>> findList(LazyNettyClientPermeatePortPoolQueryListCommand lazyNettyClientPermeatePortPoolQueryListCommand);
|
||||
|
||||
/**
|
||||
* describe 分页查询多个客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolQueryListCommand 分页查询多个客户端内网渗透端口池
|
||||
* @return {@link Result <LazyPage<LazyNettyClientPermeatePortPoolDTO>>} 分页客户端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result <LazyPage<LazyNettyClientPermeatePortPoolDTO>> findPage(int size,int current,LazyNettyClientPermeatePortPoolQueryListCommand lazyNettyClientPermeatePortPoolQueryListCommand);
|
||||
|
||||
/**
|
||||
* describe 删除客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolRemoveCommand 删除客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPool>} 客户端内网渗透端口池
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyNettyClientPermeatePortPool> remove(LazyNettyClientPermeatePortPoolRemoveCommand lazyNettyClientPermeatePortPoolRemoveCommand);
|
||||
|
||||
}
|
@ -0,0 +1,109 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application;
|
||||
|
||||
import org.wu.framework.web.response.Result;
|
||||
import org.wu.framework.web.response.ResultFactory;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPool;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolRemoveCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolStoryCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolUpdateCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolQueryListCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolQueryOneCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.dto.LazyNettyServerPermeatePortPoolDTO;
|
||||
import java.util.List;
|
||||
import org.wu.framework.lazy.orm.database.lambda.domain.LazyPage;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyApplication
|
||||
**/
|
||||
|
||||
public interface LazyNettyServerPermeatePortPoolApplication {
|
||||
|
||||
|
||||
/**
|
||||
* describe 新增服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolStoryCommand 新增服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPool>} 服务端内网渗透端口池新增后领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyNettyServerPermeatePortPool> story(LazyNettyServerPermeatePortPoolStoryCommand lazyNettyServerPermeatePortPoolStoryCommand);
|
||||
|
||||
/**
|
||||
* describe 批量新增服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolStoryCommandList 批量新增服务端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyServerPermeatePortPool>>} 服务端内网渗透端口池新增后领域对象集合
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<List<LazyNettyServerPermeatePortPool>> batchStory(List<LazyNettyServerPermeatePortPoolStoryCommand> lazyNettyServerPermeatePortPoolStoryCommandList);
|
||||
|
||||
/**
|
||||
* describe 更新服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolUpdateCommand 更新服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPool>} 服务端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyNettyServerPermeatePortPool> updateOne(LazyNettyServerPermeatePortPoolUpdateCommand lazyNettyServerPermeatePortPoolUpdateCommand);
|
||||
|
||||
/**
|
||||
* describe 查询单个服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolQueryOneCommand 查询单个服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPoolDTO>} 服务端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyNettyServerPermeatePortPoolDTO> findOne(LazyNettyServerPermeatePortPoolQueryOneCommand lazyNettyServerPermeatePortPoolQueryOneCommand);
|
||||
|
||||
/**
|
||||
* describe 查询多个服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolQueryListCommand 查询多个服务端内网渗透端口池
|
||||
* @return {@link Result <List<LazyNettyServerPermeatePortPoolDTO>>} 服务端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result <List<LazyNettyServerPermeatePortPoolDTO>> findList(LazyNettyServerPermeatePortPoolQueryListCommand lazyNettyServerPermeatePortPoolQueryListCommand);
|
||||
|
||||
/**
|
||||
* describe 分页查询多个服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolQueryListCommand 分页查询多个服务端内网渗透端口池
|
||||
* @return {@link Result <LazyPage<LazyNettyServerPermeatePortPoolDTO>>} 分页服务端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result <LazyPage<LazyNettyServerPermeatePortPoolDTO>> findPage(int size,int current,LazyNettyServerPermeatePortPoolQueryListCommand lazyNettyServerPermeatePortPoolQueryListCommand);
|
||||
|
||||
/**
|
||||
* describe 删除服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolRemoveCommand 删除服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPool>} 服务端内网渗透端口池
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyNettyServerPermeatePortPool> remove(LazyNettyServerPermeatePortPoolRemoveCommand lazyNettyServerPermeatePortPoolRemoveCommand);
|
||||
|
||||
}
|
@ -0,0 +1,93 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.assembler;
|
||||
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPool;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolRemoveCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolStoryCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolUpdateCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolQueryListCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolQueryOneCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.dto.LazyNettyClientPermeatePortPoolDTO;
|
||||
import org.mapstruct.factory.Mappers;
|
||||
import org.mapstruct.Mapper;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyAssembler
|
||||
**/
|
||||
@Mapper
|
||||
public interface LazyNettyClientPermeatePortPoolDTOAssembler {
|
||||
|
||||
|
||||
/**
|
||||
* describe MapStruct 创建的代理对象
|
||||
*
|
||||
|
||||
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyClientPermeatePortPoolDTOAssembler INSTANCE = Mappers.getMapper(LazyNettyClientPermeatePortPoolDTOAssembler.class);
|
||||
/**
|
||||
* describe 应用层存储入参转换成 领域对象
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolStoryCommand 保存客户端内网渗透端口池对象
|
||||
* @return {@link LazyNettyClientPermeatePortPool} 客户端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyClientPermeatePortPool toLazyNettyClientPermeatePortPool(LazyNettyClientPermeatePortPoolStoryCommand lazyNettyClientPermeatePortPoolStoryCommand);
|
||||
/**
|
||||
* describe 应用层更新入参转换成 领域对象
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolUpdateCommand 更新客户端内网渗透端口池对象
|
||||
* @return {@link LazyNettyClientPermeatePortPool} 客户端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyClientPermeatePortPool toLazyNettyClientPermeatePortPool(LazyNettyClientPermeatePortPoolUpdateCommand lazyNettyClientPermeatePortPoolUpdateCommand);
|
||||
/**
|
||||
* describe 应用层查询入参转换成 领域对象
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolQueryOneCommand 查询单个客户端内网渗透端口池对象参数
|
||||
* @return {@link LazyNettyClientPermeatePortPool} 客户端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyClientPermeatePortPool toLazyNettyClientPermeatePortPool(LazyNettyClientPermeatePortPoolQueryOneCommand lazyNettyClientPermeatePortPoolQueryOneCommand);
|
||||
/**
|
||||
* describe 应用层查询入参转换成 领域对象
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolQueryListCommand 查询集合客户端内网渗透端口池对象参数
|
||||
* @return {@link LazyNettyClientPermeatePortPool} 客户端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyClientPermeatePortPool toLazyNettyClientPermeatePortPool(LazyNettyClientPermeatePortPoolQueryListCommand lazyNettyClientPermeatePortPoolQueryListCommand);
|
||||
/**
|
||||
* describe 应用层删除入参转换成 领域对象
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolRemoveCommand 删除客户端内网渗透端口池对象参数
|
||||
* @return {@link LazyNettyClientPermeatePortPool} 客户端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyClientPermeatePortPool toLazyNettyClientPermeatePortPool(LazyNettyClientPermeatePortPoolRemoveCommand lazyNettyClientPermeatePortPoolRemoveCommand);
|
||||
/**
|
||||
* describe 持久层领域对象转换成DTO对象
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPool 客户端内网渗透端口池领域对象
|
||||
* @return {@link LazyNettyClientPermeatePortPoolDTO} 客户端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyClientPermeatePortPoolDTO fromLazyNettyClientPermeatePortPool(LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool);
|
||||
}
|
@ -0,0 +1,93 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.assembler;
|
||||
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPool;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolRemoveCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolStoryCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolUpdateCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolQueryListCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolQueryOneCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.dto.LazyNettyServerPermeatePortPoolDTO;
|
||||
import org.mapstruct.factory.Mappers;
|
||||
import org.mapstruct.Mapper;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyAssembler
|
||||
**/
|
||||
@Mapper
|
||||
public interface LazyNettyServerPermeatePortPoolDTOAssembler {
|
||||
|
||||
|
||||
/**
|
||||
* describe MapStruct 创建的代理对象
|
||||
*
|
||||
|
||||
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyServerPermeatePortPoolDTOAssembler INSTANCE = Mappers.getMapper(LazyNettyServerPermeatePortPoolDTOAssembler.class);
|
||||
/**
|
||||
* describe 应用层存储入参转换成 领域对象
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolStoryCommand 保存服务端内网渗透端口池对象
|
||||
* @return {@link LazyNettyServerPermeatePortPool} 服务端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyServerPermeatePortPool toLazyNettyServerPermeatePortPool(LazyNettyServerPermeatePortPoolStoryCommand lazyNettyServerPermeatePortPoolStoryCommand);
|
||||
/**
|
||||
* describe 应用层更新入参转换成 领域对象
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolUpdateCommand 更新服务端内网渗透端口池对象
|
||||
* @return {@link LazyNettyServerPermeatePortPool} 服务端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyServerPermeatePortPool toLazyNettyServerPermeatePortPool(LazyNettyServerPermeatePortPoolUpdateCommand lazyNettyServerPermeatePortPoolUpdateCommand);
|
||||
/**
|
||||
* describe 应用层查询入参转换成 领域对象
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolQueryOneCommand 查询单个服务端内网渗透端口池对象参数
|
||||
* @return {@link LazyNettyServerPermeatePortPool} 服务端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyServerPermeatePortPool toLazyNettyServerPermeatePortPool(LazyNettyServerPermeatePortPoolQueryOneCommand lazyNettyServerPermeatePortPoolQueryOneCommand);
|
||||
/**
|
||||
* describe 应用层查询入参转换成 领域对象
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolQueryListCommand 查询集合服务端内网渗透端口池对象参数
|
||||
* @return {@link LazyNettyServerPermeatePortPool} 服务端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyServerPermeatePortPool toLazyNettyServerPermeatePortPool(LazyNettyServerPermeatePortPoolQueryListCommand lazyNettyServerPermeatePortPoolQueryListCommand);
|
||||
/**
|
||||
* describe 应用层删除入参转换成 领域对象
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolRemoveCommand 删除服务端内网渗透端口池对象参数
|
||||
* @return {@link LazyNettyServerPermeatePortPool} 服务端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyServerPermeatePortPool toLazyNettyServerPermeatePortPool(LazyNettyServerPermeatePortPoolRemoveCommand lazyNettyServerPermeatePortPoolRemoveCommand);
|
||||
/**
|
||||
* describe 持久层领域对象转换成DTO对象
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPool 服务端内网渗透端口池领域对象
|
||||
* @return {@link LazyNettyServerPermeatePortPoolDTO} 服务端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyServerPermeatePortPoolDTO fromLazyNettyServerPermeatePortPool(LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool);
|
||||
}
|
@ -0,0 +1,87 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyQueryListCommand
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@Schema(title = "lazy_netty_client_permeate_port_pool_query_List_command",description = "客户端内网渗透端口池")
|
||||
public class LazyNettyClientPermeatePortPoolQueryListCommand {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -0,0 +1,87 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyQueryOneCommand
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@Schema(title = "lazy_netty_client_permeate_port_pool_query_one_command",description = "客户端内网渗透端口池")
|
||||
public class LazyNettyClientPermeatePortPoolQueryOneCommand {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -0,0 +1,87 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyRemoveCommand
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@Schema(title = "lazy_netty_client_permeate_port_pool_remove_command",description = "客户端内网渗透端口池")
|
||||
public class LazyNettyClientPermeatePortPoolRemoveCommand {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -0,0 +1,87 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyStoryCommand
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@Schema(title = "lazy_netty_client_permeate_port_pool_story_command",description = "客户端内网渗透端口池")
|
||||
public class LazyNettyClientPermeatePortPoolStoryCommand {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -0,0 +1,87 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyUpdateCommand
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@Schema(title = "lazy_netty_client_permeate_port_pool_update_command",description = "客户端内网渗透端口池")
|
||||
public class LazyNettyClientPermeatePortPoolUpdateCommand {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -0,0 +1,94 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyQueryListCommand
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@Schema(title = "lazy_netty_server_permeate_port_pool_query_List_command",description = "服务端内网渗透端口池")
|
||||
public class LazyNettyServerPermeatePortPoolQueryListCommand {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 服务端ID
|
||||
*/
|
||||
@Schema(description ="服务端ID",name ="serverId",example = "")
|
||||
private String serverId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -0,0 +1,94 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyQueryOneCommand
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@Schema(title = "lazy_netty_server_permeate_port_pool_query_one_command",description = "服务端内网渗透端口池")
|
||||
public class LazyNettyServerPermeatePortPoolQueryOneCommand {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 服务端ID
|
||||
*/
|
||||
@Schema(description ="服务端ID",name ="serverId",example = "")
|
||||
private String serverId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -0,0 +1,94 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyRemoveCommand
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@Schema(title = "lazy_netty_server_permeate_port_pool_remove_command",description = "服务端内网渗透端口池")
|
||||
public class LazyNettyServerPermeatePortPoolRemoveCommand {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 服务端ID
|
||||
*/
|
||||
@Schema(description ="服务端ID",name ="serverId",example = "")
|
||||
private String serverId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -0,0 +1,94 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyStoryCommand
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@Schema(title = "lazy_netty_server_permeate_port_pool_story_command",description = "服务端内网渗透端口池")
|
||||
public class LazyNettyServerPermeatePortPoolStoryCommand {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 服务端ID
|
||||
*/
|
||||
@Schema(description ="服务端ID",name ="serverId",example = "")
|
||||
private String serverId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -0,0 +1,94 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyUpdateCommand
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@Schema(title = "lazy_netty_server_permeate_port_pool_update_command",description = "服务端内网渗透端口池")
|
||||
public class LazyNettyServerPermeatePortPoolUpdateCommand {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 服务端ID
|
||||
*/
|
||||
@Schema(description ="服务端ID",name ="serverId",example = "")
|
||||
private String serverId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -0,0 +1,87 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.dto;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyDTO
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@Schema(title = "lazy_netty_client_permeate_port_pool_command_dto",description = "客户端内网渗透端口池")
|
||||
public class LazyNettyClientPermeatePortPoolDTO {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -0,0 +1,94 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.dto;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyDTO
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@Schema(title = "lazy_netty_server_permeate_port_pool_command_dto",description = "服务端内网渗透端口池")
|
||||
public class LazyNettyServerPermeatePortPoolDTO {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 服务端ID
|
||||
*/
|
||||
@Schema(description ="服务端ID",name ="serverId",example = "")
|
||||
private String serverId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -65,5 +65,10 @@ public class LazyNettyServerVisitorDTO {
|
||||
*/
|
||||
@Schema(description = "服务端ID", name = "serverId", example = "")
|
||||
private String serverId;
|
||||
/**
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description = "是否被占用", name = "isUsed", example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
}
|
@ -0,0 +1,144 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.impl;
|
||||
|
||||
import org.wu.framework.database.lazy.web.plus.stereotype.LazyApplication;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.LazyNettyClientPermeatePortPoolApplication;
|
||||
import org.springframework.web.bind.annotation.*;
|
||||
import org.wu.framework.web.response.Result;
|
||||
import org.wu.framework.web.response.ResultFactory;
|
||||
import org.springframework.beans.factory.annotation.Autowired;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPool;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolRemoveCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolStoryCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolUpdateCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolQueryListCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolQueryOneCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.assembler.LazyNettyClientPermeatePortPoolDTOAssembler;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.dto.LazyNettyClientPermeatePortPoolDTO;
|
||||
import java.util.stream.Collectors;
|
||||
import jakarta.annotation.Resource;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolRepository;
|
||||
import java.util.List;
|
||||
import org.wu.framework.lazy.orm.database.lambda.domain.LazyPage;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyApplicationImpl
|
||||
**/
|
||||
@LazyApplication
|
||||
public class LazyNettyClientPermeatePortPoolApplicationImpl implements LazyNettyClientPermeatePortPoolApplication {
|
||||
|
||||
@Resource
|
||||
LazyNettyClientPermeatePortPoolRepository lazyNettyClientPermeatePortPoolRepository;
|
||||
/**
|
||||
* describe 新增客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolStoryCommand 新增客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPool>} 客户端内网渗透端口池新增后领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyNettyClientPermeatePortPool> story(LazyNettyClientPermeatePortPoolStoryCommand lazyNettyClientPermeatePortPoolStoryCommand) {
|
||||
LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool = LazyNettyClientPermeatePortPoolDTOAssembler.INSTANCE.toLazyNettyClientPermeatePortPool(lazyNettyClientPermeatePortPoolStoryCommand);
|
||||
return lazyNettyClientPermeatePortPoolRepository.story(lazyNettyClientPermeatePortPool);
|
||||
}
|
||||
/**
|
||||
* describe 批量新增客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolStoryCommandList 批量新增客户端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyClientPermeatePortPool>>} 客户端内网渗透端口池新增后领域对象集合
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<List<LazyNettyClientPermeatePortPool>> batchStory(List<LazyNettyClientPermeatePortPoolStoryCommand> lazyNettyClientPermeatePortPoolStoryCommandList) {
|
||||
List<LazyNettyClientPermeatePortPool> lazyNettyClientPermeatePortPoolList = lazyNettyClientPermeatePortPoolStoryCommandList.stream().map( LazyNettyClientPermeatePortPoolDTOAssembler.INSTANCE::toLazyNettyClientPermeatePortPool).collect(Collectors.toList());
|
||||
return lazyNettyClientPermeatePortPoolRepository.batchStory(lazyNettyClientPermeatePortPoolList);
|
||||
}
|
||||
/**
|
||||
* describe 更新客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolUpdateCommand 更新客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPool>} 客户端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyNettyClientPermeatePortPool> updateOne(LazyNettyClientPermeatePortPoolUpdateCommand lazyNettyClientPermeatePortPoolUpdateCommand) {
|
||||
LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool = LazyNettyClientPermeatePortPoolDTOAssembler.INSTANCE.toLazyNettyClientPermeatePortPool(lazyNettyClientPermeatePortPoolUpdateCommand);
|
||||
return lazyNettyClientPermeatePortPoolRepository.story(lazyNettyClientPermeatePortPool);
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 查询单个客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolQueryOneCommand 查询单个客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPoolDTO>} 客户端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyNettyClientPermeatePortPoolDTO> findOne(LazyNettyClientPermeatePortPoolQueryOneCommand lazyNettyClientPermeatePortPoolQueryOneCommand) {
|
||||
LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool = LazyNettyClientPermeatePortPoolDTOAssembler.INSTANCE.toLazyNettyClientPermeatePortPool(lazyNettyClientPermeatePortPoolQueryOneCommand);
|
||||
return lazyNettyClientPermeatePortPoolRepository.findOne(lazyNettyClientPermeatePortPool).convert(LazyNettyClientPermeatePortPoolDTOAssembler.INSTANCE::fromLazyNettyClientPermeatePortPool);
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 查询多个客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolQueryListCommand 查询多个客户端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyClientPermeatePortPoolDTO>>} 客户端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<List<LazyNettyClientPermeatePortPoolDTO>> findList(LazyNettyClientPermeatePortPoolQueryListCommand lazyNettyClientPermeatePortPoolQueryListCommand) {
|
||||
LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool = LazyNettyClientPermeatePortPoolDTOAssembler.INSTANCE.toLazyNettyClientPermeatePortPool(lazyNettyClientPermeatePortPoolQueryListCommand);
|
||||
return lazyNettyClientPermeatePortPoolRepository.findList(lazyNettyClientPermeatePortPool) .convert(lazyNettyClientPermeatePortPools -> lazyNettyClientPermeatePortPools.stream().map(LazyNettyClientPermeatePortPoolDTOAssembler.INSTANCE::fromLazyNettyClientPermeatePortPool).collect(Collectors.toList())) ;
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 分页查询多个客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolQueryListCommand 分页查询多个客户端内网渗透端口池
|
||||
* @return {@link Result<LazyPage<LazyNettyClientPermeatePortPoolDTO>>} 分页客户端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyPage<LazyNettyClientPermeatePortPoolDTO>> findPage(int size,int current,LazyNettyClientPermeatePortPoolQueryListCommand lazyNettyClientPermeatePortPoolQueryListCommand) {
|
||||
LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool = LazyNettyClientPermeatePortPoolDTOAssembler.INSTANCE.toLazyNettyClientPermeatePortPool(lazyNettyClientPermeatePortPoolQueryListCommand);
|
||||
return lazyNettyClientPermeatePortPoolRepository.findPage(size,current,lazyNettyClientPermeatePortPool) .convert(page -> page.convert(LazyNettyClientPermeatePortPoolDTOAssembler.INSTANCE::fromLazyNettyClientPermeatePortPool)) ;
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 删除客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolRemoveCommand 删除客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPool>} 客户端内网渗透端口池
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyNettyClientPermeatePortPool> remove(LazyNettyClientPermeatePortPoolRemoveCommand lazyNettyClientPermeatePortPoolRemoveCommand) {
|
||||
LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool = LazyNettyClientPermeatePortPoolDTOAssembler.INSTANCE.toLazyNettyClientPermeatePortPool(lazyNettyClientPermeatePortPoolRemoveCommand);
|
||||
return lazyNettyClientPermeatePortPoolRepository.remove(lazyNettyClientPermeatePortPool);
|
||||
}
|
||||
|
||||
}
|
@ -0,0 +1,144 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.application.impl;
|
||||
|
||||
import org.wu.framework.database.lazy.web.plus.stereotype.LazyApplication;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.LazyNettyServerPermeatePortPoolApplication;
|
||||
import org.springframework.web.bind.annotation.*;
|
||||
import org.wu.framework.web.response.Result;
|
||||
import org.wu.framework.web.response.ResultFactory;
|
||||
import org.springframework.beans.factory.annotation.Autowired;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPool;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolRemoveCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolStoryCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolUpdateCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolQueryListCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolQueryOneCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.assembler.LazyNettyServerPermeatePortPoolDTOAssembler;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.dto.LazyNettyServerPermeatePortPoolDTO;
|
||||
import java.util.stream.Collectors;
|
||||
import jakarta.annotation.Resource;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolRepository;
|
||||
import java.util.List;
|
||||
import org.wu.framework.lazy.orm.database.lambda.domain.LazyPage;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyApplicationImpl
|
||||
**/
|
||||
@LazyApplication
|
||||
public class LazyNettyServerPermeatePortPoolApplicationImpl implements LazyNettyServerPermeatePortPoolApplication {
|
||||
|
||||
@Resource
|
||||
LazyNettyServerPermeatePortPoolRepository lazyNettyServerPermeatePortPoolRepository;
|
||||
/**
|
||||
* describe 新增服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolStoryCommand 新增服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPool>} 服务端内网渗透端口池新增后领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyNettyServerPermeatePortPool> story(LazyNettyServerPermeatePortPoolStoryCommand lazyNettyServerPermeatePortPoolStoryCommand) {
|
||||
LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool = LazyNettyServerPermeatePortPoolDTOAssembler.INSTANCE.toLazyNettyServerPermeatePortPool(lazyNettyServerPermeatePortPoolStoryCommand);
|
||||
return lazyNettyServerPermeatePortPoolRepository.story(lazyNettyServerPermeatePortPool);
|
||||
}
|
||||
/**
|
||||
* describe 批量新增服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolStoryCommandList 批量新增服务端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyServerPermeatePortPool>>} 服务端内网渗透端口池新增后领域对象集合
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<List<LazyNettyServerPermeatePortPool>> batchStory(List<LazyNettyServerPermeatePortPoolStoryCommand> lazyNettyServerPermeatePortPoolStoryCommandList) {
|
||||
List<LazyNettyServerPermeatePortPool> lazyNettyServerPermeatePortPoolList = lazyNettyServerPermeatePortPoolStoryCommandList.stream().map( LazyNettyServerPermeatePortPoolDTOAssembler.INSTANCE::toLazyNettyServerPermeatePortPool).collect(Collectors.toList());
|
||||
return lazyNettyServerPermeatePortPoolRepository.batchStory(lazyNettyServerPermeatePortPoolList);
|
||||
}
|
||||
/**
|
||||
* describe 更新服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolUpdateCommand 更新服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPool>} 服务端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyNettyServerPermeatePortPool> updateOne(LazyNettyServerPermeatePortPoolUpdateCommand lazyNettyServerPermeatePortPoolUpdateCommand) {
|
||||
LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool = LazyNettyServerPermeatePortPoolDTOAssembler.INSTANCE.toLazyNettyServerPermeatePortPool(lazyNettyServerPermeatePortPoolUpdateCommand);
|
||||
return lazyNettyServerPermeatePortPoolRepository.story(lazyNettyServerPermeatePortPool);
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 查询单个服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolQueryOneCommand 查询单个服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPoolDTO>} 服务端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyNettyServerPermeatePortPoolDTO> findOne(LazyNettyServerPermeatePortPoolQueryOneCommand lazyNettyServerPermeatePortPoolQueryOneCommand) {
|
||||
LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool = LazyNettyServerPermeatePortPoolDTOAssembler.INSTANCE.toLazyNettyServerPermeatePortPool(lazyNettyServerPermeatePortPoolQueryOneCommand);
|
||||
return lazyNettyServerPermeatePortPoolRepository.findOne(lazyNettyServerPermeatePortPool).convert(LazyNettyServerPermeatePortPoolDTOAssembler.INSTANCE::fromLazyNettyServerPermeatePortPool);
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 查询多个服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolQueryListCommand 查询多个服务端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyServerPermeatePortPoolDTO>>} 服务端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<List<LazyNettyServerPermeatePortPoolDTO>> findList(LazyNettyServerPermeatePortPoolQueryListCommand lazyNettyServerPermeatePortPoolQueryListCommand) {
|
||||
LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool = LazyNettyServerPermeatePortPoolDTOAssembler.INSTANCE.toLazyNettyServerPermeatePortPool(lazyNettyServerPermeatePortPoolQueryListCommand);
|
||||
return lazyNettyServerPermeatePortPoolRepository.findList(lazyNettyServerPermeatePortPool) .convert(lazyNettyServerPermeatePortPools -> lazyNettyServerPermeatePortPools.stream().map(LazyNettyServerPermeatePortPoolDTOAssembler.INSTANCE::fromLazyNettyServerPermeatePortPool).collect(Collectors.toList())) ;
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 分页查询多个服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolQueryListCommand 分页查询多个服务端内网渗透端口池
|
||||
* @return {@link Result<LazyPage<LazyNettyServerPermeatePortPoolDTO>>} 分页服务端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyPage<LazyNettyServerPermeatePortPoolDTO>> findPage(int size,int current,LazyNettyServerPermeatePortPoolQueryListCommand lazyNettyServerPermeatePortPoolQueryListCommand) {
|
||||
LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool = LazyNettyServerPermeatePortPoolDTOAssembler.INSTANCE.toLazyNettyServerPermeatePortPool(lazyNettyServerPermeatePortPoolQueryListCommand);
|
||||
return lazyNettyServerPermeatePortPoolRepository.findPage(size,current,lazyNettyServerPermeatePortPool) .convert(page -> page.convert(LazyNettyServerPermeatePortPoolDTOAssembler.INSTANCE::fromLazyNettyServerPermeatePortPool)) ;
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 删除服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolRemoveCommand 删除服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPool>} 服务端内网渗透端口池
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyNettyServerPermeatePortPool> remove(LazyNettyServerPermeatePortPoolRemoveCommand lazyNettyServerPermeatePortPoolRemoveCommand) {
|
||||
LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool = LazyNettyServerPermeatePortPoolDTOAssembler.INSTANCE.toLazyNettyServerPermeatePortPool(lazyNettyServerPermeatePortPoolRemoveCommand);
|
||||
return lazyNettyServerPermeatePortPoolRepository.remove(lazyNettyServerPermeatePortPool);
|
||||
}
|
||||
|
||||
}
|
@ -0,0 +1,142 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.controller;
|
||||
|
||||
import io.swagger.v3.oas.annotations.tags.Tag;
|
||||
import io.swagger.v3.oas.annotations.Operation;
|
||||
import io.swagger.v3.oas.annotations.Parameter;
|
||||
import org.wu.framework.web.spring.EasyController;
|
||||
import org.springframework.web.bind.annotation.*;
|
||||
import org.wu.framework.web.response.Result;
|
||||
import org.wu.framework.web.response.ResultFactory;
|
||||
import org.springframework.beans.factory.annotation.Autowired;
|
||||
import jakarta.annotation.Resource;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPool;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolRemoveCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolStoryCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolUpdateCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolQueryListCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolQueryOneCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.LazyNettyClientPermeatePortPoolApplication;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.dto.LazyNettyClientPermeatePortPoolDTO;
|
||||
import java.util.List;
|
||||
import org.wu.framework.lazy.orm.database.lambda.domain.LazyPage;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyController
|
||||
**/
|
||||
@Tag(name = "客户端内网渗透端口池提供者")
|
||||
@EasyController("/lazy/netty/client/permeate/port/pool")
|
||||
public class LazyNettyClientPermeatePortPoolProvider {
|
||||
|
||||
@Resource
|
||||
private LazyNettyClientPermeatePortPoolApplication lazyNettyClientPermeatePortPoolApplication;
|
||||
|
||||
/**
|
||||
* describe 新增客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolStoryCommand 新增客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPool>} 客户端内网渗透端口池新增后领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Operation(summary = "新增客户端内网渗透端口池")
|
||||
@PostMapping("/story")
|
||||
public Result<LazyNettyClientPermeatePortPool> story(@RequestBody LazyNettyClientPermeatePortPoolStoryCommand lazyNettyClientPermeatePortPoolStoryCommand){
|
||||
return lazyNettyClientPermeatePortPoolApplication.story(lazyNettyClientPermeatePortPoolStoryCommand);
|
||||
}
|
||||
/**
|
||||
* describe 批量新增客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolStoryCommandList 批量新增客户端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyClientPermeatePortPool>>} 客户端内网渗透端口池新增后领域对象集合
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Operation(summary = "批量新增客户端内网渗透端口池")
|
||||
@PostMapping("/batchStory")
|
||||
public Result<List<LazyNettyClientPermeatePortPool>> batchStory(@RequestBody List<LazyNettyClientPermeatePortPoolStoryCommand> lazyNettyClientPermeatePortPoolStoryCommandList){
|
||||
return lazyNettyClientPermeatePortPoolApplication.batchStory(lazyNettyClientPermeatePortPoolStoryCommandList);
|
||||
}
|
||||
/**
|
||||
* describe 更新客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolUpdateCommand 更新客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPool>} 客户端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Operation(summary = "更新客户端内网渗透端口池")
|
||||
@PutMapping("/updateOne")
|
||||
public Result<LazyNettyClientPermeatePortPool> updateOne(@RequestBody LazyNettyClientPermeatePortPoolUpdateCommand lazyNettyClientPermeatePortPoolUpdateCommand){
|
||||
return lazyNettyClientPermeatePortPoolApplication.updateOne(lazyNettyClientPermeatePortPoolUpdateCommand);
|
||||
}
|
||||
/**
|
||||
* describe 查询单个客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolQueryOneCommand 查询单个客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPoolDTO>} 客户端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Operation(summary = "查询单个客户端内网渗透端口池")
|
||||
@GetMapping("/findOne")
|
||||
public Result<LazyNettyClientPermeatePortPoolDTO> findOne(@ModelAttribute LazyNettyClientPermeatePortPoolQueryOneCommand lazyNettyClientPermeatePortPoolQueryOneCommand){
|
||||
return lazyNettyClientPermeatePortPoolApplication.findOne(lazyNettyClientPermeatePortPoolQueryOneCommand);
|
||||
}
|
||||
/**
|
||||
* describe 查询多个客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolQueryListCommand 查询多个客户端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyClientPermeatePortPoolDTO>>} 客户端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Operation(summary = "查询多个客户端内网渗透端口池")
|
||||
@GetMapping("/findList")
|
||||
public Result<List<LazyNettyClientPermeatePortPoolDTO>> findList(@ModelAttribute LazyNettyClientPermeatePortPoolQueryListCommand lazyNettyClientPermeatePortPoolQueryListCommand){
|
||||
return lazyNettyClientPermeatePortPoolApplication.findList(lazyNettyClientPermeatePortPoolQueryListCommand);
|
||||
}
|
||||
/**
|
||||
* describe 分页查询多个客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolQueryListCommand 分页查询多个客户端内网渗透端口池
|
||||
* @return {@link Result<LazyPage<LazyNettyClientPermeatePortPoolDTO>>} 分页客户端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Operation(summary = "分页查询多个客户端内网渗透端口池")
|
||||
@GetMapping("/findPage")
|
||||
public Result<LazyPage<LazyNettyClientPermeatePortPoolDTO>> findPage(@Parameter(description ="分页大小") @RequestParam(defaultValue = "10", value = "size") int size,
|
||||
@Parameter(description ="当前页数") @RequestParam(defaultValue = "1", value = "current") int current,@ModelAttribute LazyNettyClientPermeatePortPoolQueryListCommand lazyNettyClientPermeatePortPoolQueryListCommand){
|
||||
return lazyNettyClientPermeatePortPoolApplication.findPage(size,current,lazyNettyClientPermeatePortPoolQueryListCommand);
|
||||
}
|
||||
/**
|
||||
* describe 删除客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolRemoveCommand 删除客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPool>} 客户端内网渗透端口池
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Operation(summary = "删除客户端内网渗透端口池")
|
||||
@DeleteMapping("/remove")
|
||||
public Result<LazyNettyClientPermeatePortPool> remove(@ModelAttribute LazyNettyClientPermeatePortPoolRemoveCommand lazyNettyClientPermeatePortPoolRemoveCommand){
|
||||
return lazyNettyClientPermeatePortPoolApplication.remove(lazyNettyClientPermeatePortPoolRemoveCommand);
|
||||
}
|
||||
}
|
@ -0,0 +1,142 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.controller;
|
||||
|
||||
import io.swagger.v3.oas.annotations.tags.Tag;
|
||||
import io.swagger.v3.oas.annotations.Operation;
|
||||
import io.swagger.v3.oas.annotations.Parameter;
|
||||
import org.wu.framework.web.spring.EasyController;
|
||||
import org.springframework.web.bind.annotation.*;
|
||||
import org.wu.framework.web.response.Result;
|
||||
import org.wu.framework.web.response.ResultFactory;
|
||||
import org.springframework.beans.factory.annotation.Autowired;
|
||||
import jakarta.annotation.Resource;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPool;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolRemoveCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolStoryCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolUpdateCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolQueryListCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.command.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolQueryOneCommand;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.LazyNettyServerPermeatePortPoolApplication;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.application.dto.LazyNettyServerPermeatePortPoolDTO;
|
||||
import java.util.List;
|
||||
import org.wu.framework.lazy.orm.database.lambda.domain.LazyPage;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyController
|
||||
**/
|
||||
@Tag(name = "服务端内网渗透端口池提供者")
|
||||
@EasyController("/lazy/netty/server/permeate/port/pool")
|
||||
public class LazyNettyServerPermeatePortPoolProvider {
|
||||
|
||||
@Resource
|
||||
private LazyNettyServerPermeatePortPoolApplication lazyNettyServerPermeatePortPoolApplication;
|
||||
|
||||
/**
|
||||
* describe 新增服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolStoryCommand 新增服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPool>} 服务端内网渗透端口池新增后领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Operation(summary = "新增服务端内网渗透端口池")
|
||||
@PostMapping("/story")
|
||||
public Result<LazyNettyServerPermeatePortPool> story(@RequestBody LazyNettyServerPermeatePortPoolStoryCommand lazyNettyServerPermeatePortPoolStoryCommand){
|
||||
return lazyNettyServerPermeatePortPoolApplication.story(lazyNettyServerPermeatePortPoolStoryCommand);
|
||||
}
|
||||
/**
|
||||
* describe 批量新增服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolStoryCommandList 批量新增服务端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyServerPermeatePortPool>>} 服务端内网渗透端口池新增后领域对象集合
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Operation(summary = "批量新增服务端内网渗透端口池")
|
||||
@PostMapping("/batchStory")
|
||||
public Result<List<LazyNettyServerPermeatePortPool>> batchStory(@RequestBody List<LazyNettyServerPermeatePortPoolStoryCommand> lazyNettyServerPermeatePortPoolStoryCommandList){
|
||||
return lazyNettyServerPermeatePortPoolApplication.batchStory(lazyNettyServerPermeatePortPoolStoryCommandList);
|
||||
}
|
||||
/**
|
||||
* describe 更新服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolUpdateCommand 更新服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPool>} 服务端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Operation(summary = "更新服务端内网渗透端口池")
|
||||
@PutMapping("/updateOne")
|
||||
public Result<LazyNettyServerPermeatePortPool> updateOne(@RequestBody LazyNettyServerPermeatePortPoolUpdateCommand lazyNettyServerPermeatePortPoolUpdateCommand){
|
||||
return lazyNettyServerPermeatePortPoolApplication.updateOne(lazyNettyServerPermeatePortPoolUpdateCommand);
|
||||
}
|
||||
/**
|
||||
* describe 查询单个服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolQueryOneCommand 查询单个服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPoolDTO>} 服务端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Operation(summary = "查询单个服务端内网渗透端口池")
|
||||
@GetMapping("/findOne")
|
||||
public Result<LazyNettyServerPermeatePortPoolDTO> findOne(@ModelAttribute LazyNettyServerPermeatePortPoolQueryOneCommand lazyNettyServerPermeatePortPoolQueryOneCommand){
|
||||
return lazyNettyServerPermeatePortPoolApplication.findOne(lazyNettyServerPermeatePortPoolQueryOneCommand);
|
||||
}
|
||||
/**
|
||||
* describe 查询多个服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolQueryListCommand 查询多个服务端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyServerPermeatePortPoolDTO>>} 服务端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Operation(summary = "查询多个服务端内网渗透端口池")
|
||||
@GetMapping("/findList")
|
||||
public Result<List<LazyNettyServerPermeatePortPoolDTO>> findList(@ModelAttribute LazyNettyServerPermeatePortPoolQueryListCommand lazyNettyServerPermeatePortPoolQueryListCommand){
|
||||
return lazyNettyServerPermeatePortPoolApplication.findList(lazyNettyServerPermeatePortPoolQueryListCommand);
|
||||
}
|
||||
/**
|
||||
* describe 分页查询多个服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolQueryListCommand 分页查询多个服务端内网渗透端口池
|
||||
* @return {@link Result<LazyPage<LazyNettyServerPermeatePortPoolDTO>>} 分页服务端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Operation(summary = "分页查询多个服务端内网渗透端口池")
|
||||
@GetMapping("/findPage")
|
||||
public Result<LazyPage<LazyNettyServerPermeatePortPoolDTO>> findPage(@Parameter(description ="分页大小") @RequestParam(defaultValue = "10", value = "size") int size,
|
||||
@Parameter(description ="当前页数") @RequestParam(defaultValue = "1", value = "current") int current,@ModelAttribute LazyNettyServerPermeatePortPoolQueryListCommand lazyNettyServerPermeatePortPoolQueryListCommand){
|
||||
return lazyNettyServerPermeatePortPoolApplication.findPage(size,current,lazyNettyServerPermeatePortPoolQueryListCommand);
|
||||
}
|
||||
/**
|
||||
* describe 删除服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolRemoveCommand 删除服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPool>} 服务端内网渗透端口池
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Operation(summary = "删除服务端内网渗透端口池")
|
||||
@DeleteMapping("/remove")
|
||||
public Result<LazyNettyServerPermeatePortPool> remove(@ModelAttribute LazyNettyServerPermeatePortPoolRemoveCommand lazyNettyServerPermeatePortPoolRemoveCommand){
|
||||
return lazyNettyServerPermeatePortPoolApplication.remove(lazyNettyServerPermeatePortPoolRemoveCommand);
|
||||
}
|
||||
}
|
@ -0,0 +1,87 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.client.permeate.port.pool;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyDomain
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@Schema(title = "lazy_netty_client_permeate_port_pool",description = "客户端内网渗透端口池")
|
||||
public class LazyNettyClientPermeatePortPool {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -0,0 +1,106 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.client.permeate.port.pool;
|
||||
|
||||
import org.wu.framework.web.response.Result;
|
||||
import org.wu.framework.web.response.ResultFactory;
|
||||
import org.springframework.beans.factory.annotation.Autowired;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPool;
|
||||
import java.util.List;
|
||||
import org.wu.framework.lazy.orm.database.lambda.domain.LazyPage;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyDomainRepository
|
||||
**/
|
||||
|
||||
public interface LazyNettyClientPermeatePortPoolRepository {
|
||||
|
||||
|
||||
/**
|
||||
* describe 新增客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPool 新增客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPool>} 客户端内网渗透端口池新增后领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyNettyClientPermeatePortPool> story(LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool);
|
||||
|
||||
/**
|
||||
* describe 批量新增客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolList 批量新增客户端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyClientPermeatePortPool>>} 客户端内网渗透端口池新增后领域对象集合
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<List<LazyNettyClientPermeatePortPool>> batchStory(List<LazyNettyClientPermeatePortPool> lazyNettyClientPermeatePortPoolList);
|
||||
|
||||
/**
|
||||
* describe 查询单个客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPool 查询单个客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPool>} 客户端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyNettyClientPermeatePortPool> findOne(LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool);
|
||||
|
||||
/**
|
||||
* describe 查询多个客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPool 查询多个客户端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyClientPermeatePortPool>>} 客户端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<List<LazyNettyClientPermeatePortPool>> findList(LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool);
|
||||
|
||||
/**
|
||||
* describe 分页查询多个客户端内网渗透端口池
|
||||
*
|
||||
* @param size 当前页数
|
||||
* @param current 当前页
|
||||
* @param lazyNettyClientPermeatePortPool 分页查询多个客户端内网渗透端口池
|
||||
* @return {@link Result<LazyPage<LazyNettyClientPermeatePortPool>>} 分页客户端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyPage<LazyNettyClientPermeatePortPool>> findPage(int size,int current,LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool);
|
||||
|
||||
/**
|
||||
* describe 删除客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPool 删除客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPool>} 客户端内网渗透端口池
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyNettyClientPermeatePortPool> remove(LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool);
|
||||
|
||||
/**
|
||||
* describe 是否存在客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPool 是否存在客户端内网渗透端口池
|
||||
* @return {@link Result<Boolean>} 客户端内网渗透端口池是否存在
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<Boolean> exists(LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool);
|
||||
|
||||
}
|
@ -0,0 +1,94 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.server.permeate.port.pool;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyDomain
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@Schema(title = "lazy_netty_server_permeate_port_pool",description = "服务端内网渗透端口池")
|
||||
public class LazyNettyServerPermeatePortPool {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 服务端ID
|
||||
*/
|
||||
@Schema(description ="服务端ID",name ="serverId",example = "")
|
||||
private String serverId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -0,0 +1,106 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.server.permeate.port.pool;
|
||||
|
||||
import org.wu.framework.web.response.Result;
|
||||
import org.wu.framework.web.response.ResultFactory;
|
||||
import org.springframework.beans.factory.annotation.Autowired;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPool;
|
||||
import java.util.List;
|
||||
import org.wu.framework.lazy.orm.database.lambda.domain.LazyPage;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyDomainRepository
|
||||
**/
|
||||
|
||||
public interface LazyNettyServerPermeatePortPoolRepository {
|
||||
|
||||
|
||||
/**
|
||||
* describe 新增服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPool 新增服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPool>} 服务端内网渗透端口池新增后领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyNettyServerPermeatePortPool> story(LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool);
|
||||
|
||||
/**
|
||||
* describe 批量新增服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolList 批量新增服务端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyServerPermeatePortPool>>} 服务端内网渗透端口池新增后领域对象集合
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<List<LazyNettyServerPermeatePortPool>> batchStory(List<LazyNettyServerPermeatePortPool> lazyNettyServerPermeatePortPoolList);
|
||||
|
||||
/**
|
||||
* describe 查询单个服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPool 查询单个服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPool>} 服务端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyNettyServerPermeatePortPool> findOne(LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool);
|
||||
|
||||
/**
|
||||
* describe 查询多个服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPool 查询多个服务端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyServerPermeatePortPool>>} 服务端内网渗透端口池DTO对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<List<LazyNettyServerPermeatePortPool>> findList(LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool);
|
||||
|
||||
/**
|
||||
* describe 分页查询多个服务端内网渗透端口池
|
||||
*
|
||||
* @param size 当前页数
|
||||
* @param current 当前页
|
||||
* @param lazyNettyServerPermeatePortPool 分页查询多个服务端内网渗透端口池
|
||||
* @return {@link Result<LazyPage<LazyNettyServerPermeatePortPool>>} 分页服务端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyPage<LazyNettyServerPermeatePortPool>> findPage(int size,int current,LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool);
|
||||
|
||||
/**
|
||||
* describe 删除服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPool 删除服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPool>} 服务端内网渗透端口池
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<LazyNettyServerPermeatePortPool> remove(LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool);
|
||||
|
||||
/**
|
||||
* describe 是否存在服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPool 是否存在服务端内网渗透端口池
|
||||
* @return {@link Result<Boolean>} 服务端内网渗透端口池是否存在
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
Result<Boolean> exists(LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool);
|
||||
|
||||
}
|
@ -4,6 +4,7 @@ import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyDomain;
|
||||
import org.wu.framework.lazy.orm.core.stereotype.LazyTableField;
|
||||
import org.wu.framework.lazy.orm.core.stereotype.LazyTableFieldUnique;
|
||||
|
||||
import java.time.LocalDateTime;
|
||||
@ -67,4 +68,11 @@ public class LazyNettyServerVisitor {
|
||||
@Schema(description = "服务端ID", name = "serverId", example = "")
|
||||
private String serverId;
|
||||
|
||||
|
||||
/**
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description = "是否被占用", name = "isUsed", example = "")
|
||||
private Boolean isUsed;
|
||||
|
||||
}
|
@ -0,0 +1,48 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.converter;
|
||||
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPool;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.entity.LazyNettyClientPermeatePortPoolDO;
|
||||
import org.mapstruct.factory.Mappers;
|
||||
import org.mapstruct.Mapper;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyInfrastructureConverter
|
||||
**/
|
||||
@Mapper
|
||||
public interface LazyNettyClientPermeatePortPoolConverter {
|
||||
|
||||
|
||||
/**
|
||||
* describe MapStruct 创建的代理对象
|
||||
*
|
||||
|
||||
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyClientPermeatePortPoolConverter INSTANCE = Mappers.getMapper(LazyNettyClientPermeatePortPoolConverter.class);
|
||||
/**
|
||||
* describe 实体对象 转换成领域对象
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolDO 客户端内网渗透端口池实体对象
|
||||
* @return {@link LazyNettyClientPermeatePortPool} 客户端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyClientPermeatePortPool toLazyNettyClientPermeatePortPool(LazyNettyClientPermeatePortPoolDO lazyNettyClientPermeatePortPoolDO);
|
||||
/**
|
||||
* describe 领域对象 转换成实体对象
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPool 客户端内网渗透端口池领域对象
|
||||
* @return {@link LazyNettyClientPermeatePortPoolDO} 客户端内网渗透端口池实体对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyClientPermeatePortPoolDO fromLazyNettyClientPermeatePortPool(LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool);
|
||||
}
|
@ -0,0 +1,48 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.converter;
|
||||
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPool;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.entity.LazyNettyServerPermeatePortPoolDO;
|
||||
import org.mapstruct.factory.Mappers;
|
||||
import org.mapstruct.Mapper;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyInfrastructureConverter
|
||||
**/
|
||||
@Mapper
|
||||
public interface LazyNettyServerPermeatePortPoolConverter {
|
||||
|
||||
|
||||
/**
|
||||
* describe MapStruct 创建的代理对象
|
||||
*
|
||||
|
||||
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyServerPermeatePortPoolConverter INSTANCE = Mappers.getMapper(LazyNettyServerPermeatePortPoolConverter.class);
|
||||
/**
|
||||
* describe 实体对象 转换成领域对象
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolDO 服务端内网渗透端口池实体对象
|
||||
* @return {@link LazyNettyServerPermeatePortPool} 服务端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyServerPermeatePortPool toLazyNettyServerPermeatePortPool(LazyNettyServerPermeatePortPoolDO lazyNettyServerPermeatePortPoolDO);
|
||||
/**
|
||||
* describe 领域对象 转换成实体对象
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPool 服务端内网渗透端口池领域对象
|
||||
* @return {@link LazyNettyServerPermeatePortPoolDO} 服务端内网渗透端口池实体对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
LazyNettyServerPermeatePortPoolDO fromLazyNettyServerPermeatePortPool(LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool);
|
||||
}
|
@ -0,0 +1,102 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.entity;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import org.wu.framework.lazy.orm.core.stereotype.LazyTable;
|
||||
import org.wu.framework.lazy.orm.core.stereotype.LazyTableField;
|
||||
import org.wu.framework.lazy.orm.core.stereotype.*;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import org.wu.framework.lazy.orm.core.stereotype.LazyTableFieldId;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyInfrastructureEntity
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@LazyTable(tableName = "lazy_netty_client_permeate_port_pool",comment = "客户端内网渗透端口池")
|
||||
@Schema(title = "lazy_netty_client_permeate_port_pool",description = "客户端内网渗透端口池")
|
||||
public class LazyNettyClientPermeatePortPoolDO {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
@LazyTableField(name="client_id",comment="客户端ID",notNull=true,columnType="varchar(255)")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
@LazyTableField(name="create_time",comment="创建时间",defaultValue="CURRENT_TIMESTAMP",upsertStrategy = LazyFieldStrategy.NEVER,columnType="datetime",extra=" on update CURRENT_TIMESTAMP")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
@LazyTableField(name="describe",comment="描述",columnType="varchar(255)")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
@LazyTableFieldId(name = "id", comment = "用户ID")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
@LazyTableField(name="is_deleted",comment="是否删除",columnType="tinyint(1)")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
@LazyTableField(name="is_used",comment="是否被占用",columnType="tinyint(1)")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
@LazyTableField(name="pool_size",comment="访客端口池大小",defaultValue="'20'",upsertStrategy = LazyFieldStrategy.NEVER,columnType="int")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
@LazyTableField(name="update_time",comment="更新时间",defaultValue="CURRENT_TIMESTAMP",upsertStrategy = LazyFieldStrategy.NEVER,columnType="datetime",extra=" on update CURRENT_TIMESTAMP")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
@LazyTableField(name="visitor_port",comment="访客端口",columnType="int")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -0,0 +1,113 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.entity;
|
||||
|
||||
import lombok.Data;
|
||||
import lombok.experimental.Accessors;
|
||||
import org.wu.framework.lazy.orm.core.stereotype.LazyTableIndex;
|
||||
import org.wu.framework.core.stereotype.LayerField;
|
||||
import org.wu.framework.core.stereotype.LayerField.LayerFieldType;
|
||||
import org.wu.framework.lazy.orm.core.stereotype.LazyTable;
|
||||
import org.wu.framework.lazy.orm.core.stereotype.LazyTableField;
|
||||
import org.wu.framework.lazy.orm.core.stereotype.*;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import io.swagger.v3.oas.annotations.media.Schema;
|
||||
import java.lang.String;
|
||||
import java.time.LocalDateTime;
|
||||
import org.wu.framework.lazy.orm.core.stereotype.LazyTableFieldId;
|
||||
import java.lang.Long;
|
||||
import java.lang.Boolean;
|
||||
import java.lang.Integer;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyInfrastructureEntity
|
||||
**/
|
||||
@Data
|
||||
@Accessors(chain = true)
|
||||
@LazyTable(tableName = "lazy_netty_server_permeate_port_pool",comment = "服务端内网渗透端口池")
|
||||
@Schema(title = "lazy_netty_server_permeate_port_pool",description = "服务端内网渗透端口池")
|
||||
public class LazyNettyServerPermeatePortPoolDO {
|
||||
|
||||
|
||||
/**
|
||||
*
|
||||
* 客户端ID
|
||||
*/
|
||||
@Schema(description ="客户端ID",name ="clientId",example = "")
|
||||
@LazyTableField(name="client_id",comment="客户端ID",notNull=true,columnType="varchar(255)")
|
||||
private String clientId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 创建时间
|
||||
*/
|
||||
@Schema(description ="创建时间",name ="createTime",example = "")
|
||||
@LazyTableField(name="create_time",comment="创建时间",defaultValue="CURRENT_TIMESTAMP",upsertStrategy = LazyFieldStrategy.NEVER,columnType="datetime",extra=" on update CURRENT_TIMESTAMP")
|
||||
private LocalDateTime createTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 描述
|
||||
*/
|
||||
@Schema(description ="描述",name ="describe",example = "")
|
||||
@LazyTableField(name="describe",comment="描述",columnType="varchar(255)")
|
||||
private String describe;
|
||||
|
||||
/**
|
||||
*
|
||||
* 用户ID
|
||||
*/
|
||||
@Schema(description ="用户ID",name ="id",example = "")
|
||||
@LazyTableFieldId(name = "id", comment = "用户ID")
|
||||
private Long id;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否删除
|
||||
*/
|
||||
@Schema(description ="是否删除",name ="isDeleted",example = "")
|
||||
@LazyTableField(name="is_deleted",comment="是否删除",columnType="tinyint(1)")
|
||||
private Boolean isDeleted;
|
||||
|
||||
/**
|
||||
*
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description ="是否被占用",name ="isUsed",example = "")
|
||||
@LazyTableField(name="is_used",comment="是否被占用",columnType="tinyint(1)")
|
||||
private Boolean isUsed;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口池大小
|
||||
*/
|
||||
@Schema(description ="访客端口池大小",name ="poolSize",example = "")
|
||||
@LazyTableField(name="pool_size",comment="访客端口池大小",defaultValue="'20'",upsertStrategy = LazyFieldStrategy.NEVER,columnType="int")
|
||||
private Integer poolSize;
|
||||
|
||||
/**
|
||||
*
|
||||
* 服务端ID
|
||||
*/
|
||||
@Schema(description ="服务端ID",name ="serverId",example = "")
|
||||
@LazyTableField(name="server_id",comment="服务端ID",notNull=true,columnType="varchar(255)")
|
||||
private String serverId;
|
||||
|
||||
/**
|
||||
*
|
||||
* 更新时间
|
||||
*/
|
||||
@Schema(description ="更新时间",name ="updateTime",example = "")
|
||||
@LazyTableField(name="update_time",comment="更新时间",defaultValue="CURRENT_TIMESTAMP",upsertStrategy = LazyFieldStrategy.NEVER,columnType="datetime",extra=" on update CURRENT_TIMESTAMP")
|
||||
private LocalDateTime updateTime;
|
||||
|
||||
/**
|
||||
*
|
||||
* 访客端口
|
||||
*/
|
||||
@Schema(description ="访客端口",name ="visitorPort",example = "")
|
||||
@LazyTableField(name="visitor_port",comment="访客端口",columnType="int")
|
||||
private Integer visitorPort;
|
||||
|
||||
}
|
@ -77,4 +77,18 @@ public class LazyNettyServerVisitorDO {
|
||||
@LazyTableFieldUnique(name = "server_id", comment = "服务端ID",notNull = true)
|
||||
@Schema(description = "服务端ID", name = "serverId", example = "")
|
||||
private String serverId;
|
||||
|
||||
|
||||
/**
|
||||
* 类型:服务端内网穿透、服务端内网渗透、客户端渗透服务端、客户端渗透客户端
|
||||
*/
|
||||
|
||||
/**
|
||||
* 是否被占用
|
||||
*/
|
||||
@Schema(description = "是否被占用", name = "isUsed", example = "")
|
||||
@LazyTableField(name = "is_used", comment = "是否被占用")
|
||||
private Boolean isUsed;
|
||||
|
||||
|
||||
}
|
@ -0,0 +1,18 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.jpa.lazy;
|
||||
|
||||
import org.wu.framework.lazy.orm.database.jpa.repository.LazyJpaRepository;
|
||||
import org.wu.framework.lazy.orm.database.jpa.repository.annotation.*;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.entity.LazyNettyClientPermeatePortPoolDO;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyInfrastructureLazyJpa
|
||||
**/
|
||||
@LazyRepository
|
||||
public interface LazyNettyClientPermeatePortPoolLazyJpaRepository extends LazyJpaRepository<LazyNettyClientPermeatePortPoolDO,Long> {
|
||||
|
||||
|
||||
|
||||
}
|
@ -0,0 +1,18 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.jpa.lazy;
|
||||
|
||||
import org.wu.framework.lazy.orm.database.jpa.repository.LazyJpaRepository;
|
||||
import org.wu.framework.lazy.orm.database.jpa.repository.annotation.*;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.entity.LazyNettyServerPermeatePortPoolDO;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyInfrastructureLazyJpa
|
||||
**/
|
||||
@LazyRepository
|
||||
public interface LazyNettyServerPermeatePortPoolLazyJpaRepository extends LazyJpaRepository<LazyNettyServerPermeatePortPoolDO,Long> {
|
||||
|
||||
|
||||
|
||||
}
|
@ -0,0 +1,15 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.mapper;
|
||||
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyInfrastructureMapper
|
||||
**/
|
||||
|
||||
public interface LazyNettyClientPermeatePortPoolMapper {
|
||||
|
||||
|
||||
|
||||
}
|
@ -0,0 +1,15 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.mapper;
|
||||
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyInfrastructureMapper
|
||||
**/
|
||||
|
||||
public interface LazyNettyServerPermeatePortPoolMapper {
|
||||
|
||||
|
||||
|
||||
}
|
@ -0,0 +1,152 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.persistence;
|
||||
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.entity.LazyNettyClientPermeatePortPoolDO;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.converter.LazyNettyClientPermeatePortPoolConverter;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.mapper.LazyNettyClientPermeatePortPoolMapper;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPoolRepository;
|
||||
import org.springframework.stereotype.Repository;
|
||||
import java.util.stream.Collectors;
|
||||
import org.wu.framework.lazy.orm.database.lambda.stream.wrapper.LazyWrappers;
|
||||
import org.wu.framework.web.response.Result;
|
||||
import org.wu.framework.web.response.ResultFactory;
|
||||
import jakarta.annotation.Resource;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.client.permeate.port.pool.LazyNettyClientPermeatePortPool;
|
||||
import org.wu.framework.lazy.orm.database.lambda.stream.lambda.LazyLambdaStream;
|
||||
import java.util.List;
|
||||
import org.wu.framework.lazy.orm.database.lambda.domain.LazyPage;
|
||||
/**
|
||||
* describe 客户端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyInfrastructurePersistence
|
||||
**/
|
||||
@Repository
|
||||
public class LazyNettyClientPermeatePortPoolRepositoryImpl implements LazyNettyClientPermeatePortPoolRepository {
|
||||
|
||||
@Resource
|
||||
LazyLambdaStream lazyLambdaStream;
|
||||
|
||||
/**
|
||||
* describe 新增客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPool 新增客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPool>} 客户端内网渗透端口池新增后领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyNettyClientPermeatePortPool> story(LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool) {
|
||||
LazyNettyClientPermeatePortPoolDO lazyNettyClientPermeatePortPoolDO = LazyNettyClientPermeatePortPoolConverter.INSTANCE.fromLazyNettyClientPermeatePortPool(lazyNettyClientPermeatePortPool);
|
||||
lazyLambdaStream.upsert(lazyNettyClientPermeatePortPoolDO);
|
||||
return ResultFactory.successOf();
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 批量新增客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPoolList 批量新增客户端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyClientPermeatePortPool>>} 客户端内网渗透端口池新增后领域对象集合
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<List<LazyNettyClientPermeatePortPool>> batchStory(List<LazyNettyClientPermeatePortPool> lazyNettyClientPermeatePortPoolList) {
|
||||
List<LazyNettyClientPermeatePortPoolDO> lazyNettyClientPermeatePortPoolDOList = lazyNettyClientPermeatePortPoolList.stream().map(LazyNettyClientPermeatePortPoolConverter.INSTANCE::fromLazyNettyClientPermeatePortPool).collect(Collectors.toList());
|
||||
lazyLambdaStream.upsert(lazyNettyClientPermeatePortPoolDOList);
|
||||
return ResultFactory.successOf();
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 查询单个客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPool 查询单个客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPool>} 客户端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyNettyClientPermeatePortPool> findOne(LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool) {
|
||||
LazyNettyClientPermeatePortPoolDO lazyNettyClientPermeatePortPoolDO = LazyNettyClientPermeatePortPoolConverter.INSTANCE.fromLazyNettyClientPermeatePortPool(lazyNettyClientPermeatePortPool);
|
||||
LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPoolOne = lazyLambdaStream.selectOne(LazyWrappers.lambdaWrapperBean(lazyNettyClientPermeatePortPoolDO), LazyNettyClientPermeatePortPool.class);
|
||||
return ResultFactory.successOf(lazyNettyClientPermeatePortPoolOne);
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 查询多个客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPool 查询多个客户端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyClientPermeatePortPool>>} 客户端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<List<LazyNettyClientPermeatePortPool>> findList(LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool) {
|
||||
LazyNettyClientPermeatePortPoolDO lazyNettyClientPermeatePortPoolDO = LazyNettyClientPermeatePortPoolConverter.INSTANCE.fromLazyNettyClientPermeatePortPool(lazyNettyClientPermeatePortPool);
|
||||
List<LazyNettyClientPermeatePortPool> lazyNettyClientPermeatePortPoolList = lazyLambdaStream.selectList(LazyWrappers.lambdaWrapperBean(lazyNettyClientPermeatePortPoolDO), LazyNettyClientPermeatePortPool.class);
|
||||
return ResultFactory.successOf(lazyNettyClientPermeatePortPoolList);
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 分页查询多个客户端内网渗透端口池
|
||||
*
|
||||
* @param size 当前页数
|
||||
* @param current 当前页
|
||||
* @param lazyNettyClientPermeatePortPool 分页查询多个客户端内网渗透端口池
|
||||
* @return {@link Result<LazyPage<LazyNettyClientPermeatePortPool>>} 分页客户端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyPage<LazyNettyClientPermeatePortPool>> findPage(int size,int current,LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool) {
|
||||
LazyNettyClientPermeatePortPoolDO lazyNettyClientPermeatePortPoolDO = LazyNettyClientPermeatePortPoolConverter.INSTANCE.fromLazyNettyClientPermeatePortPool(lazyNettyClientPermeatePortPool);
|
||||
LazyPage<LazyNettyClientPermeatePortPool> lazyPage = new LazyPage<>(current,size);
|
||||
LazyPage<LazyNettyClientPermeatePortPool> lazyNettyClientPermeatePortPoolLazyPage = lazyLambdaStream.selectPage(LazyWrappers.lambdaWrapperBean(lazyNettyClientPermeatePortPoolDO),lazyPage, LazyNettyClientPermeatePortPool.class);
|
||||
return ResultFactory.successOf(lazyNettyClientPermeatePortPoolLazyPage);
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 删除客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPool 删除客户端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyClientPermeatePortPool>} 客户端内网渗透端口池
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyNettyClientPermeatePortPool> remove(LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool) {
|
||||
LazyNettyClientPermeatePortPoolDO lazyNettyClientPermeatePortPoolDO = LazyNettyClientPermeatePortPoolConverter.INSTANCE.fromLazyNettyClientPermeatePortPool(lazyNettyClientPermeatePortPool);
|
||||
// lazyLambdaStream.delete(LazyWrappers.lambdaWrapperBean(lazyNettyClientPermeatePortPoolDO));
|
||||
return ResultFactory.successOf();
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 是否存在客户端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyClientPermeatePortPool 客户端内网渗透端口池领域对象
|
||||
* @return {@link Result<Boolean>} 是否存在 true 存在,false 不存在
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<Boolean> exists(LazyNettyClientPermeatePortPool lazyNettyClientPermeatePortPool) {
|
||||
LazyNettyClientPermeatePortPoolDO lazyNettyClientPermeatePortPoolDO = LazyNettyClientPermeatePortPoolConverter.INSTANCE.fromLazyNettyClientPermeatePortPool(lazyNettyClientPermeatePortPool);
|
||||
Boolean exists=lazyLambdaStream.exists(LazyWrappers.lambdaWrapperBean(lazyNettyClientPermeatePortPoolDO));
|
||||
return ResultFactory.successOf(exists);
|
||||
}
|
||||
|
||||
}
|
@ -0,0 +1,152 @@
|
||||
package org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.persistence;
|
||||
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.entity.LazyNettyServerPermeatePortPoolDO;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.converter.LazyNettyServerPermeatePortPoolConverter;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.mapper.LazyNettyServerPermeatePortPoolMapper;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPoolRepository;
|
||||
import org.springframework.stereotype.Repository;
|
||||
import java.util.stream.Collectors;
|
||||
import org.wu.framework.lazy.orm.database.lambda.stream.wrapper.LazyWrappers;
|
||||
import org.wu.framework.web.response.Result;
|
||||
import org.wu.framework.web.response.ResultFactory;
|
||||
import jakarta.annotation.Resource;
|
||||
import org.framework.lazy.cloud.network.heartbeat.server.standalone.domain.model.lazy.netty.server.permeate.port.pool.LazyNettyServerPermeatePortPool;
|
||||
import org.wu.framework.lazy.orm.database.lambda.stream.lambda.LazyLambdaStream;
|
||||
import java.util.List;
|
||||
import org.wu.framework.lazy.orm.database.lambda.domain.LazyPage;
|
||||
/**
|
||||
* describe 服务端内网渗透端口池
|
||||
*
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
* @see org.wu.framework.lazy.orm.core.persistence.reverse.lazy.ddd.DefaultDDDLazyInfrastructurePersistence
|
||||
**/
|
||||
@Repository
|
||||
public class LazyNettyServerPermeatePortPoolRepositoryImpl implements LazyNettyServerPermeatePortPoolRepository {
|
||||
|
||||
@Resource
|
||||
LazyLambdaStream lazyLambdaStream;
|
||||
|
||||
/**
|
||||
* describe 新增服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPool 新增服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPool>} 服务端内网渗透端口池新增后领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyNettyServerPermeatePortPool> story(LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool) {
|
||||
LazyNettyServerPermeatePortPoolDO lazyNettyServerPermeatePortPoolDO = LazyNettyServerPermeatePortPoolConverter.INSTANCE.fromLazyNettyServerPermeatePortPool(lazyNettyServerPermeatePortPool);
|
||||
lazyLambdaStream.upsert(lazyNettyServerPermeatePortPoolDO);
|
||||
return ResultFactory.successOf();
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 批量新增服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPoolList 批量新增服务端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyServerPermeatePortPool>>} 服务端内网渗透端口池新增后领域对象集合
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<List<LazyNettyServerPermeatePortPool>> batchStory(List<LazyNettyServerPermeatePortPool> lazyNettyServerPermeatePortPoolList) {
|
||||
List<LazyNettyServerPermeatePortPoolDO> lazyNettyServerPermeatePortPoolDOList = lazyNettyServerPermeatePortPoolList.stream().map(LazyNettyServerPermeatePortPoolConverter.INSTANCE::fromLazyNettyServerPermeatePortPool).collect(Collectors.toList());
|
||||
lazyLambdaStream.upsert(lazyNettyServerPermeatePortPoolDOList);
|
||||
return ResultFactory.successOf();
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 查询单个服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPool 查询单个服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPool>} 服务端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyNettyServerPermeatePortPool> findOne(LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool) {
|
||||
LazyNettyServerPermeatePortPoolDO lazyNettyServerPermeatePortPoolDO = LazyNettyServerPermeatePortPoolConverter.INSTANCE.fromLazyNettyServerPermeatePortPool(lazyNettyServerPermeatePortPool);
|
||||
LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPoolOne = lazyLambdaStream.selectOne(LazyWrappers.lambdaWrapperBean(lazyNettyServerPermeatePortPoolDO), LazyNettyServerPermeatePortPool.class);
|
||||
return ResultFactory.successOf(lazyNettyServerPermeatePortPoolOne);
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 查询多个服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPool 查询多个服务端内网渗透端口池
|
||||
* @return {@link Result<List<LazyNettyServerPermeatePortPool>>} 服务端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<List<LazyNettyServerPermeatePortPool>> findList(LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool) {
|
||||
LazyNettyServerPermeatePortPoolDO lazyNettyServerPermeatePortPoolDO = LazyNettyServerPermeatePortPoolConverter.INSTANCE.fromLazyNettyServerPermeatePortPool(lazyNettyServerPermeatePortPool);
|
||||
List<LazyNettyServerPermeatePortPool> lazyNettyServerPermeatePortPoolList = lazyLambdaStream.selectList(LazyWrappers.lambdaWrapperBean(lazyNettyServerPermeatePortPoolDO), LazyNettyServerPermeatePortPool.class);
|
||||
return ResultFactory.successOf(lazyNettyServerPermeatePortPoolList);
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 分页查询多个服务端内网渗透端口池
|
||||
*
|
||||
* @param size 当前页数
|
||||
* @param current 当前页
|
||||
* @param lazyNettyServerPermeatePortPool 分页查询多个服务端内网渗透端口池
|
||||
* @return {@link Result<LazyPage<LazyNettyServerPermeatePortPool>>} 分页服务端内网渗透端口池领域对象
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyPage<LazyNettyServerPermeatePortPool>> findPage(int size,int current,LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool) {
|
||||
LazyNettyServerPermeatePortPoolDO lazyNettyServerPermeatePortPoolDO = LazyNettyServerPermeatePortPoolConverter.INSTANCE.fromLazyNettyServerPermeatePortPool(lazyNettyServerPermeatePortPool);
|
||||
LazyPage<LazyNettyServerPermeatePortPool> lazyPage = new LazyPage<>(current,size);
|
||||
LazyPage<LazyNettyServerPermeatePortPool> lazyNettyServerPermeatePortPoolLazyPage = lazyLambdaStream.selectPage(LazyWrappers.lambdaWrapperBean(lazyNettyServerPermeatePortPoolDO),lazyPage, LazyNettyServerPermeatePortPool.class);
|
||||
return ResultFactory.successOf(lazyNettyServerPermeatePortPoolLazyPage);
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 删除服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPool 删除服务端内网渗透端口池
|
||||
* @return {@link Result<LazyNettyServerPermeatePortPool>} 服务端内网渗透端口池
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<LazyNettyServerPermeatePortPool> remove(LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool) {
|
||||
LazyNettyServerPermeatePortPoolDO lazyNettyServerPermeatePortPoolDO = LazyNettyServerPermeatePortPoolConverter.INSTANCE.fromLazyNettyServerPermeatePortPool(lazyNettyServerPermeatePortPool);
|
||||
// lazyLambdaStream.delete(LazyWrappers.lambdaWrapperBean(lazyNettyServerPermeatePortPoolDO));
|
||||
return ResultFactory.successOf();
|
||||
}
|
||||
|
||||
/**
|
||||
* describe 是否存在服务端内网渗透端口池
|
||||
*
|
||||
* @param lazyNettyServerPermeatePortPool 服务端内网渗透端口池领域对象
|
||||
* @return {@link Result<Boolean>} 是否存在 true 存在,false 不存在
|
||||
|
||||
* @author Jia wei Wu
|
||||
* @date 2024/09/17 01:26 夜间
|
||||
**/
|
||||
|
||||
@Override
|
||||
public Result<Boolean> exists(LazyNettyServerPermeatePortPool lazyNettyServerPermeatePortPool) {
|
||||
LazyNettyServerPermeatePortPoolDO lazyNettyServerPermeatePortPoolDO = LazyNettyServerPermeatePortPoolConverter.INSTANCE.fromLazyNettyServerPermeatePortPool(lazyNettyServerPermeatePortPool);
|
||||
Boolean exists=lazyLambdaStream.exists(LazyWrappers.lambdaWrapperBean(lazyNettyServerPermeatePortPoolDO));
|
||||
return ResultFactory.successOf(exists);
|
||||
}
|
||||
|
||||
}
|
@ -0,0 +1,17 @@
|
||||
|
||||
<?xml version="1.0" encoding="UTF-8"?>
|
||||
<!DOCTYPE mapper PUBLIC "-//mybatis.org//DTD Mapper 3.0//EN" "http://mybatis.org/dtd/mybatis-3-mapper.dtd">
|
||||
<mapper namespace="org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.mapper.LazyNettyClientPermeatePortPoolMapper">
|
||||
<resultMap id="BaseResultMap" type="org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.entity.LazyNettyClientPermeatePortPoolDO">
|
||||
<result column="client_id" property="clientId" />
|
||||
<result column="create_time" property="createTime" />
|
||||
<result column="`describe`" property="describe" />
|
||||
<id column="id" property="id" />
|
||||
<result column="is_deleted" property="isDeleted" />
|
||||
<result column="is_used" property="isUsed" />
|
||||
<result column="pool_size" property="poolSize" />
|
||||
<result column="update_time" property="updateTime" />
|
||||
<result column="visitor_port" property="visitorPort" />
|
||||
</resultMap>
|
||||
|
||||
</mapper>
|
@ -0,0 +1,18 @@
|
||||
|
||||
<?xml version="1.0" encoding="UTF-8"?>
|
||||
<!DOCTYPE mapper PUBLIC "-//mybatis.org//DTD Mapper 3.0//EN" "http://mybatis.org/dtd/mybatis-3-mapper.dtd">
|
||||
<mapper namespace="org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.mapper.LazyNettyServerPermeatePortPoolMapper">
|
||||
<resultMap id="BaseResultMap" type="org.framework.lazy.cloud.network.heartbeat.server.standalone.infrastructure.entity.LazyNettyServerPermeatePortPoolDO">
|
||||
<result column="client_id" property="clientId" />
|
||||
<result column="create_time" property="createTime" />
|
||||
<result column="`describe`" property="describe" />
|
||||
<id column="id" property="id" />
|
||||
<result column="is_deleted" property="isDeleted" />
|
||||
<result column="is_used" property="isUsed" />
|
||||
<result column="pool_size" property="poolSize" />
|
||||
<result column="server_id" property="serverId" />
|
||||
<result column="update_time" property="updateTime" />
|
||||
<result column="visitor_port" property="visitorPort" />
|
||||
</resultMap>
|
||||
|
||||
</mapper>
|
@ -2,14 +2,10 @@ spring:
|
||||
lazy:
|
||||
netty:
|
||||
client:
|
||||
# inet-host: 124.222.48.62
|
||||
# inet-port: 32647
|
||||
inet-host: 124.222.152.160
|
||||
inet-port: 30560
|
||||
# inet-host: 127.0.0.1
|
||||
# inet-port: 7001
|
||||
inet-host: 124.222.48.62
|
||||
inet-port: 30676
|
||||
inet-path: wu-lazy-cloud-heartbeat-server
|
||||
client-id: wujiawei # 客户端ID
|
||||
client-id: wujiawei-acw # 客户端ID
|
||||
# inet-host: 124.222.48.62 # 服务端地址
|
||||
# inet-port: 30676 #服务端端口
|
||||
# # inet-path: wu-lazy-cloud-heartbeat-server
|
||||
|
Loading…
x
Reference in New Issue
Block a user