完善日志功能

This commit is contained in:
wulin 2023-08-15 15:29:34 +08:00
parent 7e3bb4fdee
commit f5388b7790
16 changed files with 3652933 additions and 2792 deletions

View File

@ -16,7 +16,7 @@ import java.util.Date;
@Comment("设备信息表")
@Table(name = "device_info")
@EnableEntityEvent
public class DeviceInfoEntity extends GenericEntity<Long> {
public class DeviceInfoEntity extends GenericEntity<Long> {
@Comment("id")
@Column(name = "id", length = 11, nullable = false, unique = true)
private Long id;

View File

@ -0,0 +1,70 @@
package com.qiuguo.iot.admin.http.api.filter;
import lombok.extern.slf4j.Slf4j;
import org.reactivestreams.Subscription;
import org.slf4j.MDC;
import org.springframework.context.annotation.Configuration;
import reactor.core.CoreSubscriber;
import reactor.core.publisher.Hooks;
import reactor.core.publisher.Operators;
import reactor.util.context.Context;
import javax.annotation.PostConstruct;
import javax.annotation.PreDestroy;
@Configuration
@Slf4j
public class LogMdcConfiguration {
public static String PRINT_LOG_ID = "logid";
@PostConstruct
public void contextOperatorHook() {
Hooks.onEachOperator(PRINT_LOG_ID, Operators.lift((r, c) ->{
Context ctx = c.currentContext();
if(ctx.hasKey(PRINT_LOG_ID)){
MDC.put(PRINT_LOG_ID, ctx.get(PRINT_LOG_ID));
}
return new MdcContextSubscriber(c);
}));
}
@PreDestroy
public void cleanupHook() {
Hooks.resetOnEachOperator(PRINT_LOG_ID);
}
class MdcContextSubscriber<T> implements CoreSubscriber<T> {
private CoreSubscriber<T> coreSubscriber;
public MdcContextSubscriber(CoreSubscriber<T> c){
coreSubscriber = c;
}
@Override
public void onComplete() {
coreSubscriber.onComplete();
MDC.remove(PRINT_LOG_ID);
}
@Override
public void onError(Throwable throwable) {
coreSubscriber.onError(throwable);
MDC.remove(PRINT_LOG_ID);
}
@Override
public void onSubscribe(Subscription subscription) {
coreSubscriber.onSubscribe(subscription);
}
@Override
public void onNext(T t) {
coreSubscriber.onNext(t);
}
@Override
public Context currentContext() {
return coreSubscriber.currentContext();
}
}
}

View File

@ -33,7 +33,7 @@ public class LogWebFilter implements WebFilter {
long startTime = System.currentTimeMillis();
ServerHttpRequest request = exchange.getRequest();
String requestId = request.getId();
MDC.put("logid", requestId);
MDC.put(LogMdcConfiguration.PRINT_LOG_ID, requestId);
String ip = request.getRemoteAddress().getAddress().getHostAddress();//.getHostName();
String m = request.getMethod().toString();
@ -55,9 +55,9 @@ public class LogWebFilter implements WebFilter {
}
return chain.filter(ex.build()).doFinally(signalType -> {
long endTime = System.currentTimeMillis();
MDC.put(LogMdcConfiguration.PRINT_LOG_ID, requestId);
log.info("api end time:{}, total time:{}", endTime, endTime - startTime);
MDC.remove("logid");
//ThreadContext.clearAll();
MDC.remove(LogMdcConfiguration.PRINT_LOG_ID);
});
}
@ -80,7 +80,6 @@ public class LogWebFilter implements WebFilter {
return new ServerHttpResponseDecorator(response){
@Override
public Mono<Void> writeWith(Publisher<? extends DataBuffer> body){
MDC.put("logid", requestId);
if (body instanceof Flux) {
Flux<? extends DataBuffer> fluxBody = Flux.from(body);
return super.writeWith(fluxBody.buffer().map(dataBuffers -> {
@ -91,14 +90,12 @@ public class LogWebFilter implements WebFilter {
DataBufferUtils.release(joinBuffer);
String returnStr = new String(returnContent, StandardCharsets.UTF_8);
log.info("response:{}", returnStr);
MDC.remove("logid");
return response.bufferFactory().wrap(returnContent);
}));
}else if(body instanceof Mono){
Mono<DataBuffer> monoBody = Mono.from(body);
return super.writeWith(monoBody.map(dataBuffer -> {
log.info("response:{}", dataBuffer.toString(StandardCharsets.UTF_8));
MDC.remove("logid");
return response.bufferFactory().wrap(dataBuffer.toString(StandardCharsets.UTF_8).getBytes());
}));
}

View File

@ -44,6 +44,7 @@ logging:
level:
org.hswebframework: debug
org.hswebframework.expands: error
com.qiuguo.iot.data: debug #可以开启sql的日志打印
hsweb:
cors:
enable: true

View File

@ -1,14 +1,18 @@
package com.qiuguo.iot.box.websocket.api.cmd;
import com.qiuguo.iot.box.websocket.api.protobuf.MsgProtocol;
import io.netty.buffer.ByteBuf;
import io.netty.buffer.ByteBufUtil;
import lombok.Data;
import com.qiuguo.iot.box.websocket.api.protobuf.MsgProtocol;
import org.springframework.core.io.buffer.DataBuffer;
import org.springframework.core.io.buffer.DataBufferFactory;
import org.springframework.data.redis.util.ByteUtils;
import org.springframework.web.reactive.socket.WebSocketMessage;
import org.springframework.web.reactive.socket.WebSocketSession;
import reactor.core.publisher.FluxSink;
import reactor.core.publisher.Mono;
import java.nio.ByteBuffer;
import java.util.function.Function;
@Data
@ -27,22 +31,13 @@ public class UserInfo {
MsgProtocol.User user;
public void sendData(MsgProtocol.Msg data) {
/*ByteBufAllocator allocator = new PooledByteBufAllocator();
DataBufferFactory factory = new NettyDataBufferFactory(allocator);
DataBuffer dataBuffer = factory.wrap(data.toByteArray());*/
WebSocketMessage webSocketMessage = session.binaryMessage(new Function<DataBufferFactory, DataBuffer>() {
@Override
public DataBuffer apply(DataBufferFactory dataBufferFactory) {
return dataBufferFactory.wrap(data.toByteArray());
}
WebSocketMessage webSocketMessage =session.binaryMessage(dataBufferFactory ->{
return dataBufferFactory.wrap(data.toByteArray());
});
//session.textMessage("");
if(session.isOpen()){
session.send(Mono.just(webSocketMessage)).subscribe();
sink.next(webSocketMessage);
}
//WebSocketMessage webSocketMessage = new WebSocketMessage(WebSocketMessage.Type.BINARY, dataBuffer);
//sink.next(webSocketMessage);
}
public void sendData(WebSocketMessage webSocketMessage) {
sink.next(webSocketMessage);

View File

@ -20,6 +20,7 @@ import reactor.core.publisher.*;
import reactor.core.scheduler.Schedulers;
import java.util.concurrent.ConcurrentHashMap;
import java.util.concurrent.CountDownLatch;
@Component
@WebSocketMapping("/box")
@ -27,18 +28,25 @@ import java.util.concurrent.ConcurrentHashMap;
public class BoxWebSocketHandler implements WebSocketHandler {
@Value("${device.tokenkey}")
private String devceTokenKey;
public static ConcurrentHashMap<Long, UserInfo> group = new ConcurrentHashMap<>();
//CountDownLatch countDownLatch = new CountDownLatch(5);
/**
* 所有websocket连接管理容器
**/
public static ConcurrentHashMap<Long, UserInfo> group = new ConcurrentHashMap<>();
FluxBatchRunner<MsgProtocol.Msg> batchRunner = new FluxBatchRunner<>(20, data -> {
log.info("begin:: thread={} 大小:{}", Thread.currentThread().getName(), data.size());
//log.info("begin:: thread={} 大小:{}", Thread.currentThread().getName(), data.size());
for (MsgProtocol.Msg msg:data
) {
for (UserInfo info:group.values()
) {
//info.sendData(info.getSession().textMessage(""));
info.sendData(msg);
//log.info("发送");
}
}
@ -71,7 +79,9 @@ public class BoxWebSocketHandler implements WebSocketHandler {
userInfo.setSession(session);
group.put(userId, userInfo);
}else{
userInfo = group.get(userId);
userInfo.setSession(session);//这里防止未检测到断链的情况
}
Mono<Void> input = session.receive().map(webSocketMessage ->{
try {
@ -85,29 +95,30 @@ public class BoxWebSocketHandler implements WebSocketHandler {
if(reqMsg.getCmdId().getNumber() == MsgProtocol.Msg.CmdId.SEND_STATUS_REQ_VALUE){
MsgProtocol.Msg reqMsg1 = reqMsg.toBuilder().setCmdId(MsgProtocol.Msg.CmdId.SYNC_STATUS_RSP).build();
/*for (UserInfo info:group.values()
) {
//info.sendData(info.getSession().textMessage(""));
info.sendData(reqMsg1);
}*/
batchRunner.add(reqMsg1);
batchRunner.add(reqMsg1);
//batchRunner.doFinal();
//countDownLatch.await();
return Mono.empty();//session.textMessage("");
}
} catch (InvalidProtocolBufferException e) {
} catch (Exception e) {
throw new RuntimeException(e);
}
return Mono.empty();
}).then();
UserInfo finalUserInfo = userInfo;
Mono<Void> output = session.send(Flux.create(sink -> finalUserInfo.setSink(sink)));
Mono<Void> output = session.send(Flux.create(sink -> finalUserInfo.setSink(sink))).then();
/**
* Mono.zip() 会将多个 Mono 合并为一个新的 Mono任何一个 Mono 产生 error complete 都会导致合并后的 Mono
* 也随之产生 error complete此时其它的 Mono 则会被执行取消操作
*/
return Mono.zip(input, output).then();
return Mono.zip(input, output).doFinally(signalType -> {
group.remove(finalUserInfo.getUser().getUserId());
log.info("断开连接{}", finalUserInfo.getUser().getUserId());
}).then();
}
public MsgProtocol.Msg getMsg(DataBuffer data) throws InvalidProtocolBufferException {
@ -125,55 +136,5 @@ public class BoxWebSocketHandler implements WebSocketHandler {
return msg;
}
private Boolean setUserLocationCheck(MsgProtocol.UserLocation location, UserInfo user){
if(location.getPos() != null && user.getUser().getLocation().getPos() != null &&
location.getRotation() != null && user.getUser().getLocation().getRotation() != null &&
Double.compare(location.getPos().getX(), user.getUser().getLocation().getPos().getX()) != 0 &&
Double.compare(location.getPos().getY(), user.getUser().getLocation().getPos().getY()) != 0 &&
Double.compare(location.getPos().getZ(), user.getUser().getLocation().getPos().getZ()) != 0 &&
Double.compare(location.getRotation().getX(), user.getUser().getLocation().getRotation().getX()) != 0 &&
Double.compare(location.getRotation().getY(), user.getUser().getLocation().getRotation().getY()) != 0 &&
Double.compare(location.getRotation().getZ(), user.getUser().getLocation().getRotation().getZ()) != 0){//判断位置是否变化
user.setUser(user.getUser().toBuilder().setLocation(location).build());//更新自己的位置在user里
return true;
}
return false;
}
public static void main(String[] args) throws InterruptedException {
FluxProcessor<WebSocketMessage, WebSocketMessage> fluxProcessor = EmitterProcessor.<WebSocketMessage>create().serialize();
FluxSink messageSink = fluxProcessor.sink();
fluxProcessor.doOnNext(
BoxWebSocketHandler::onMessage
)
.publishOn(Schedulers.parallel())
.subscribeOn(Schedulers.parallel())
//.bufferTimeout(5, Duration.ofSeconds(3))
.onErrorContinue((throwable, obj) -> {
})
.subscribe(msgList -> {
try {
log.info("批量处理{}", msgList);
} catch (Exception e) {
log.info("批量异常处理{}", e);
}
});
int i =0;
while (true){
i++;
Thread.sleep(1000L);
ByteBufAllocator allocator = new PooledByteBufAllocator();
DataBufferFactory factory = new NettyDataBufferFactory(allocator);
DataBuffer dataBuffer = factory.wrap(("xiaoxi" + i).getBytes());
//DataBuffer dataBuffer = factory.allocateBuffer();
WebSocketMessage webSocketMessage = new WebSocketMessage(WebSocketMessage.Type.TEXT, dataBuffer);
//webSocketMessage.setMessageId(i+"");
messageSink.next(webSocketMessage);
log.info("发送完成");
}
}
private static void onMessage(WebSocketMessage webSocketMessage) {
log.info("xiao xi lai l {}", webSocketMessage.getPayloadAsText());
}
}

View File

@ -1,8 +1,9 @@
package com.qiuguo.iot.customer.http.api.filter;
import lombok.extern.slf4j.Slf4j;
import org.apache.logging.log4j.ThreadContext;
import org.hswebframework.web.logger.ReactiveLogger;
import org.reactivestreams.Publisher;
import org.slf4j.MDC;
import org.springframework.context.annotation.Configuration;
import org.springframework.core.io.buffer.DataBuffer;
import org.springframework.core.io.buffer.DataBufferFactory;
@ -20,17 +21,19 @@ import reactor.core.publisher.Flux;
import reactor.core.publisher.Mono;
import java.nio.charset.StandardCharsets;
import java.util.UUID;
@Configuration
@Slf4j
public class LogWebFilter implements WebFilter {
private static final String CONTEXT_KEY = ReactiveLogger.class.getName();
@Override
public Mono<Void> filter(ServerWebExchange exchange, WebFilterChain chain) {
long startTime = System.currentTimeMillis();
ThreadContext.put("logid", UUID.randomUUID().toString());
ServerHttpRequest request = exchange.getRequest();
String ip = request.getRemoteAddress().getHostName();
String requestId = request.getId();
MDC.put("logid", requestId);
String ip = request.getRemoteAddress().getAddress().getHostAddress();//.getHostName();
String m = request.getMethod().toString();
log.info("api start time:{} ip:{} method:{} url:{} param:{} headers:{}",
@ -42,7 +45,8 @@ public class LogWebFilter implements WebFilter {
request.getHeaders());
ServerWebExchange.Builder ex = exchange.mutate();
ex.response(getResponse(exchange));
ex.response(getResponse(exchange, requestId));
if(!request.getMethod().equals(HttpMethod.GET) && !request.getMethod().equals(HttpMethod.DELETE)){
ex.request(getRequest(exchange));
@ -50,7 +54,8 @@ public class LogWebFilter implements WebFilter {
return chain.filter(ex.build()).doFinally(signalType -> {
long endTime = System.currentTimeMillis();
log.info("api end time:{}, total time:{}", endTime, endTime - startTime);
ThreadContext.clearAll();
MDC.remove("logid");
//ThreadContext.clearAll();
});
}
@ -68,11 +73,12 @@ public class LogWebFilter implements WebFilter {
};
}
private ServerHttpResponse getResponse(ServerWebExchange exchange){
private ServerHttpResponse getResponse(ServerWebExchange exchange, String requestId){
ServerHttpResponse response = exchange.getResponse();
return new ServerHttpResponseDecorator(response){
@Override
public Mono<Void> writeWith(Publisher<? extends DataBuffer> body){
MDC.put("logid", requestId);
if (body instanceof Flux) {
Flux<? extends DataBuffer> fluxBody = Flux.from(body);
return super.writeWith(fluxBody.buffer().map(dataBuffers -> {
@ -83,12 +89,14 @@ public class LogWebFilter implements WebFilter {
DataBufferUtils.release(joinBuffer);
String returnStr = new String(returnContent, StandardCharsets.UTF_8);
log.info("response:{}", returnStr);
MDC.remove("logid");
return response.bufferFactory().wrap(returnContent);
}));
}else if(body instanceof Mono){
Mono<DataBuffer> monoBody = Mono.from(body);
return super.writeWith(monoBody.map(dataBuffer -> {
log.info("response:{}", dataBuffer.toString(StandardCharsets.UTF_8));
MDC.remove("logid");
return response.bufferFactory().wrap(dataBuffer.toString(StandardCharsets.UTF_8).getBytes());
}));
}

View File

@ -241,7 +241,7 @@ public class MysqlUtilTable2Bean {
content += "@Data\n@Comment(\"" + tableBean.getComment() + "\")\n";
content += "@Table(name = \"" + tableBean.getTableName() + "\")\n@EnableEntityEvent\n";
//content += "@ApiModel(value = \"" + tableBean.getComment() + "\")\n";
content += "public class " + realName + "Entity extends GenericEntity<Long> {\n" + bf.toString();
content += "public class " + realName + "Entity extends GenericEntity<Long> {\n" + bf.toString();
//content += sb.toString();
content += "}";

View File

@ -65,3 +65,207 @@
2023-09:38:53.390 [reactor-tcp-nio-2] DEBUG o.h.w.s.j.CustomJackson2jsonEncoder - [debug,127] []- [71453297-1] Encoding [org.hswebframework.web.crud.web.ResponseMessage@69edc3de]
2023-09:38:53.398 [reactor-tcp-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$writeWith$1,100] [71453297-1]- response:{"message":"success","result":{"id":1,"isDelete":0,"createTime":"2023-08-09T06:47:57.000+00:00","modifyTime":"2023-08-09T06:47:57.000+00:00","batchId":1,"name":"果Box","sn":"SN234","btMac":"mac","wifiMac":"wifi","firmwareVersion":"1.0","deviceType":0,"onLine":null,"lastOnLineTime":null,"protocolType":0,"runMode":0,"marketMode":0,"otaType":0,"otaStartTime":null,"otaEndTime":null,"factoryTime":"2023-08-09T06:47:57.000+00:00","saleTime":null},"status":200,"timestamp":1691631533388}
2023-09:38:53.404 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$filter$0,58] [71453297-1]- api end time:1691631533404, total time:140
2023-14:27:21.079 [background-preinit] INFO o.h.v.i.util.Version - [<clinit>,21] []- HV000001: Hibernate Validator 6.2.5.Final
2023-14:27:22.024 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStartupProfileInfo,637] []- The following 1 profile is active: "dev"
2023-14:27:22.365 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:27:22.366 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data R2DBC repositories in DEFAULT mode.
2023-14:27:22.371 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 2 ms. Found 0 R2DBC repository interfaces.
2023-14:27:22.378 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:27:22.379 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data Redis repositories in DEFAULT mode.
2023-14:27:22.385 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 0 ms. Found 0 Redis repository interfaces.
2023-14:27:22.482 [main] INFO o.s.c.c.s.GenericScope - [setSerializationId,283] []- BeanFactory id=55b765e8-874f-3936-96a0-683b41b36bc6
2023-14:27:22.553 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$$EnhancerBySpringCGLIB$$24749ac9] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.560 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration' of type [org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.561 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.562 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'loadBalancerClientsDefaultsMappingsProvider' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration$$Lambda$427/936261188] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.562 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'defaultsBindHandlerAdvisor' of type [org.springframework.cloud.commons.config.DefaultsBindHandlerAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.564 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'expressionDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.ExpressionDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.565 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'annotationDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.AnnotationDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.566 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'alwaysNoMatchStrategyMatcher' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$1] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.567 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'switcherMethodMatcherPointcutAdvisor' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$SwitcherMethodMatcherPointcutAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.568 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration' of type [org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration$$EnhancerBySpringCGLIB$$7f16cadb] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.587 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'easyorm-org.hswebframework.web.crud.configuration.EasyormProperties' of type [org.hswebframework.web.crud.configuration.EasyormProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.587 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.EasyormConfiguration' of type [org.hswebframework.web.crud.configuration.EasyormConfiguration$$EnhancerBySpringCGLIB$$4e0399f7] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.590 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration' of type [org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration$$EnhancerBySpringCGLIB$$4e90b965] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.597 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration' of type [org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.599 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'spring.r2dbc-org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties' of type [org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.634 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'connectionFactory' of type [io.r2dbc.pool.ConnectionPool] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.635 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'reactiveSqlExecutor' of type [org.hswebframework.web.crud.sql.DefaultR2dbcExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.697 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'syncSqlExecutor' of type [org.hswebframework.ezorm.rdb.executor.reactive.ReactiveSyncSqlExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.719 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'databaseMetadata' of type [org.hswebframework.ezorm.rdb.metadata.RDBDatabaseMetadata] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.726 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration' of type [org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration$$EnhancerBySpringCGLIB$$f2fed4cd] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:23.008 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_en.properties -> messages
2023-14:27:23.009 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_zh.properties -> messages
2023-14:27:23.009 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_en.properties -> messages
2023-14:27:23.009 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_zh.properties -> messages
2023-14:27:23.009 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_en.properties -> messages
2023-14:27:23.009 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_zh.properties -> messages
2023-14:27:26.205 [main] INFO o.s.b.w.e.n.NettyWebServer - [start,111] []- Netty started on port 8091
2023-14:27:27.375 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStarted,61] []- Started IotAdminHttpApiApplication in 7.159 seconds (JVM running for 8.516)
2023-14:27:27.378 [main] DEBUG o.h.e.c.m.AbstractSchemaMetadata - [lambda$loadMetadata$2,94] []- load table metadata s_system ,use parser:MysqlTableMetadataParser
2023-14:27:27.713 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select count(1) as 'total' from information_schema.`TABLES` where table_schema=? and table_name=?
2023-14:27:27.714 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:27:27.714 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select count(1) as 'total' from information_schema.`TABLES` where table_schema='qiuguo_iot' and table_name='s_system'
2023-14:27:27.796 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema=? and table_name like ?
2023-14:27:27.797 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:27:27.797 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:27:27.880 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema=? and table_name like ?
2023-14:27:27.880 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:27:27.880 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:27:27.954 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = ? and TABLE_NAME like ?
2023-14:27:27.955 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:27:27.955 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = 'qiuguo_iot' and TABLE_NAME like 's_system'
2023-14:27:28.045 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = ? limit ?,?
2023-14:27:28.045 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: default(String),0(Integer),1(Integer)
2023-14:27:28.046 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = 'default' limit 0,1
2023-14:27:28.258 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: update qiuguo_iot.s_system set `framework_version` = ? , `website` = ? , `major_version` = ? , `name` = ? , `revision_version` = ? , `dependencies` = ? , `minor_version` = ? where `name` = ?
2023-14:27:28.258 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: {"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}(String),(String),1(Integer),default(String),0(Integer),[](String),0(Integer),default(String)
2023-14:27:28.258 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: update qiuguo_iot.s_system set `framework_version` = '{"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}' , `website` = '' , `major_version` = 1 , `name` = 'default' , `revision_version` = 0 , `dependencies` = '[]' , `minor_version` = 0 where `name` = 'default'
2023-14:27:28.272 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [lambda$null$7,130] []- ==> Updated: 1
2023-14:27:30.612 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [filter,41] [f5fdb5b3-1]- api start time:1691648850612 ip:192.168.8.246 method:GET url:/demo/device/1 param:{} headers:[Host:"192.168.8.175:8091", User-Agent:"Mozilla/5.0 (Macintosh; Intel Mac OS X 10_15_7) AppleWebKit/537.36 (KHTML, like Gecko) Chrome/115.0.0.0 Safari/537.36 Edg/115.0.1901.200", Accept:"text/html,application/xhtml+xml,application/xml;q=0.9,image/webp,image/apng,*/*;q=0.8,application/signed-exchange;v=b3;q=0.7", Accept-Encoding:"gzip, deflate", Accept-Language:"zh-CN,zh;q=0.9,en;q=0.8,en-GB;q=0.7,en-US;q=0.6", Cache-Control:"max-age=0", Connection:"close", Upgrade-Insecure-Requests:"1"]
2023-14:27:30.656 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [selectMediaType,161] [f5fdb5b3-1]- [f5fdb5b3-1] Using 'application/json' given [text/html, application/xhtml+xml, image/webp, image/apng, application/xml;q=0.9, application/signed-exchange;v=b3;q=0.7, */*;q=0.8] and supported [application/json, application/*+json, application/x-ndjson, text/event-stream]
2023-14:27:30.656 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [writeBody,174] [f5fdb5b3-1]- [f5fdb5b3-1] 0..1 [org.hswebframework.web.crud.web.ResponseMessage<?>]
2023-14:27:30.689 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,39] []- ==> Preparing: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = ? and device_info.`id` = ? limit ?,?
2023-14:27:30.689 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,41] []- ==> Parameters: 0(Integer),1(Long),0(Integer),1(Integer)
2023-14:27:30.689 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,43] []- ==> Native: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = 0 and device_info.`id` = 1 limit 0,1
2023-14:27:30.736 [reactor-tcp-nio-2] DEBUG o.h.w.s.j.CustomJackson2jsonEncoder - [debug,127] []- [f5fdb5b3-1] Encoding [org.hswebframework.web.crud.web.ResponseMessage@2901b387]
2023-14:27:30.744 [reactor-tcp-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$writeWith$1,100] [f5fdb5b3-1]- response:{"message":"success","result":{"id":1,"isDelete":0,"createTime":"2023-08-09T06:47:57.000+00:00","modifyTime":"2023-08-09T06:47:57.000+00:00","batchId":1,"name":"果Box","sn":"SN234","btMac":"mac","wifiMac":"wifi","firmwareVersion":"1.0","deviceType":0,"onLine":null,"lastOnLineTime":null,"protocolType":0,"runMode":0,"marketMode":0,"otaType":0,"otaStartTime":null,"otaEndTime":null,"factoryTime":"2023-08-09T06:47:57.000+00:00","saleTime":null},"status":200,"timestamp":1691648850733}
2023-14:27:30.751 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$filter$0,58] [f5fdb5b3-1]- api end time:1691648850751, total time:139
2023-14:29:18.767 [background-preinit] INFO o.h.v.i.util.Version - [<clinit>,21] []- HV000001: Hibernate Validator 6.2.5.Final
2023-14:29:19.799 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStartupProfileInfo,637] []- The following 1 profile is active: "dev"
2023-14:29:20.164 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:29:20.165 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data R2DBC repositories in DEFAULT mode.
2023-14:29:20.170 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 2 ms. Found 0 R2DBC repository interfaces.
2023-14:29:20.177 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:29:20.178 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data Redis repositories in DEFAULT mode.
2023-14:29:20.184 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 0 ms. Found 0 Redis repository interfaces.
2023-14:29:20.284 [main] INFO o.s.c.c.s.GenericScope - [setSerializationId,283] []- BeanFactory id=55b765e8-874f-3936-96a0-683b41b36bc6
2023-14:29:20.364 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$$EnhancerBySpringCGLIB$$8cef4f2e] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.372 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration' of type [org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.373 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.374 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'loadBalancerClientsDefaultsMappingsProvider' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration$$Lambda$427/454424866] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.375 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'defaultsBindHandlerAdvisor' of type [org.springframework.cloud.commons.config.DefaultsBindHandlerAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.376 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'expressionDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.ExpressionDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.377 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'annotationDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.AnnotationDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.378 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'alwaysNoMatchStrategyMatcher' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$1] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.379 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'switcherMethodMatcherPointcutAdvisor' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$SwitcherMethodMatcherPointcutAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.380 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration' of type [org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration$$EnhancerBySpringCGLIB$$e7917f40] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.399 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'easyorm-org.hswebframework.web.crud.configuration.EasyormProperties' of type [org.hswebframework.web.crud.configuration.EasyormProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.400 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.EasyormConfiguration' of type [org.hswebframework.web.crud.configuration.EasyormConfiguration$$EnhancerBySpringCGLIB$$b67e4e5c] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.402 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration' of type [org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration$$EnhancerBySpringCGLIB$$b70b6dca] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.409 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration' of type [org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.411 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'spring.r2dbc-org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties' of type [org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.445 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'connectionFactory' of type [io.r2dbc.pool.ConnectionPool] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.447 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'reactiveSqlExecutor' of type [org.hswebframework.web.crud.sql.DefaultR2dbcExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.507 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'syncSqlExecutor' of type [org.hswebframework.ezorm.rdb.executor.reactive.ReactiveSyncSqlExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.530 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'databaseMetadata' of type [org.hswebframework.ezorm.rdb.metadata.RDBDatabaseMetadata] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.536 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration' of type [org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration$$EnhancerBySpringCGLIB$$5b798932] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.784 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_en.properties -> messages
2023-14:29:20.785 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_zh.properties -> messages
2023-14:29:20.785 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_en.properties -> messages
2023-14:29:20.785 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_zh.properties -> messages
2023-14:29:20.785 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_en.properties -> messages
2023-14:29:20.786 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_zh.properties -> messages
2023-14:29:23.687 [main] INFO o.s.b.w.e.n.NettyWebServer - [start,111] []- Netty started on port 8091
2023-14:29:24.825 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStarted,61] []- Started IotAdminHttpApiApplication in 6.958 seconds (JVM running for 8.261)
2023-14:29:24.828 [main] DEBUG o.h.e.c.m.AbstractSchemaMetadata - [lambda$loadMetadata$2,94] []- load table metadata s_system ,use parser:MysqlTableMetadataParser
2023-14:29:25.172 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select count(1) as 'total' from information_schema.`TABLES` where table_schema=? and table_name=?
2023-14:29:25.173 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:25.173 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select count(1) as 'total' from information_schema.`TABLES` where table_schema='qiuguo_iot' and table_name='s_system'
2023-14:29:25.256 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema=? and table_name like ?
2023-14:29:25.256 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:25.256 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:29:25.328 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema=? and table_name like ?
2023-14:29:25.329 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:25.329 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:29:25.394 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = ? and TABLE_NAME like ?
2023-14:29:25.394 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:25.394 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = 'qiuguo_iot' and TABLE_NAME like 's_system'
2023-14:29:25.484 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = ? limit ?,?
2023-14:29:25.484 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: default(String),0(Integer),1(Integer)
2023-14:29:25.484 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = 'default' limit 0,1
2023-14:29:25.677 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: update qiuguo_iot.s_system set `framework_version` = ? , `website` = ? , `major_version` = ? , `name` = ? , `revision_version` = ? , `dependencies` = ? , `minor_version` = ? where `name` = ?
2023-14:29:25.677 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: {"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}(String),(String),1(Integer),default(String),0(Integer),[](String),0(Integer),default(String)
2023-14:29:25.678 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: update qiuguo_iot.s_system set `framework_version` = '{"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}' , `website` = '' , `major_version` = 1 , `name` = 'default' , `revision_version` = 0 , `dependencies` = '[]' , `minor_version` = 0 where `name` = 'default'
2023-14:29:25.691 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [lambda$null$7,130] []- ==> Updated: 1
2023-14:29:27.158 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [filter,41] [babb4f9b-1]- api start time:1691648967158 ip:192.168.8.246 method:GET url:/demo/device/1 param:{} headers:[Host:"192.168.8.175:8091", User-Agent:"Mozilla/5.0 (Macintosh; Intel Mac OS X 10_15_7) AppleWebKit/537.36 (KHTML, like Gecko) Chrome/115.0.0.0 Safari/537.36 Edg/115.0.1901.200", Accept:"text/html,application/xhtml+xml,application/xml;q=0.9,image/webp,image/apng,*/*;q=0.8,application/signed-exchange;v=b3;q=0.7", Accept-Encoding:"gzip, deflate", Accept-Language:"zh-CN,zh;q=0.9,en;q=0.8,en-GB;q=0.7,en-US;q=0.6", Cache-Control:"max-age=0", Connection:"close", Upgrade-Insecure-Requests:"1"]
2023-14:29:27.200 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [selectMediaType,161] [babb4f9b-1]- [babb4f9b-1] Using 'application/json' given [text/html, application/xhtml+xml, image/webp, image/apng, application/xml;q=0.9, application/signed-exchange;v=b3;q=0.7, */*;q=0.8] and supported [application/json, application/*+json, application/x-ndjson, text/event-stream]
2023-14:29:27.201 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [writeBody,174] [babb4f9b-1]- [babb4f9b-1] 0..1 [org.hswebframework.web.crud.web.ResponseMessage<?>]
2023-14:29:27.276 [reactor-tcp-nio-2] DEBUG o.h.w.s.j.CustomJackson2jsonEncoder - [debug,127] []- [babb4f9b-1] Encoding [org.hswebframework.web.crud.web.ResponseMessage@7f818213]
2023-14:29:27.283 [reactor-tcp-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$writeWith$1,100] [babb4f9b-1]- response:{"message":"success","result":{"id":1,"isDelete":0,"createTime":"2023-08-09T06:47:57.000+00:00","modifyTime":"2023-08-09T06:47:57.000+00:00","batchId":1,"name":"果Box","sn":"SN234","btMac":"mac","wifiMac":"wifi","firmwareVersion":"1.0","deviceType":0,"onLine":null,"lastOnLineTime":null,"protocolType":0,"runMode":0,"marketMode":0,"otaType":0,"otaStartTime":null,"otaEndTime":null,"factoryTime":"2023-08-09T06:47:57.000+00:00","saleTime":null},"status":200,"timestamp":1691648967274}
2023-14:29:27.289 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$filter$0,58] [babb4f9b-1]- api end time:1691648967289, total time:131
2023-14:29:50.776 [background-preinit] INFO o.h.v.i.util.Version - [<clinit>,21] []- HV000001: Hibernate Validator 6.2.5.Final
2023-14:29:51.592 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStartupProfileInfo,637] []- The following 1 profile is active: "dev"
2023-14:29:51.952 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:29:51.953 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data R2DBC repositories in DEFAULT mode.
2023-14:29:51.959 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 2 ms. Found 0 R2DBC repository interfaces.
2023-14:29:51.967 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:29:51.968 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data Redis repositories in DEFAULT mode.
2023-14:29:51.974 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 0 ms. Found 0 Redis repository interfaces.
2023-14:29:52.074 [main] INFO o.s.c.c.s.GenericScope - [setSerializationId,283] []- BeanFactory id=55b765e8-874f-3936-96a0-683b41b36bc6
2023-14:29:52.149 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$$EnhancerBySpringCGLIB$$1e209f28] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.158 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration' of type [org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.159 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.159 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'loadBalancerClientsDefaultsMappingsProvider' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration$$Lambda$427/1267110705] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.160 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'defaultsBindHandlerAdvisor' of type [org.springframework.cloud.commons.config.DefaultsBindHandlerAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.162 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'expressionDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.ExpressionDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.163 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'annotationDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.AnnotationDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.164 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'alwaysNoMatchStrategyMatcher' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$1] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.165 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'switcherMethodMatcherPointcutAdvisor' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$SwitcherMethodMatcherPointcutAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.167 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration' of type [org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration$$EnhancerBySpringCGLIB$$78c2cf3a] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.188 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'easyorm-org.hswebframework.web.crud.configuration.EasyormProperties' of type [org.hswebframework.web.crud.configuration.EasyormProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.189 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.EasyormConfiguration' of type [org.hswebframework.web.crud.configuration.EasyormConfiguration$$EnhancerBySpringCGLIB$$47af9e56] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.192 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration' of type [org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration$$EnhancerBySpringCGLIB$$483cbdc4] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.199 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration' of type [org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.201 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'spring.r2dbc-org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties' of type [org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.236 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'connectionFactory' of type [io.r2dbc.pool.ConnectionPool] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.238 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'reactiveSqlExecutor' of type [org.hswebframework.web.crud.sql.DefaultR2dbcExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.301 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'syncSqlExecutor' of type [org.hswebframework.ezorm.rdb.executor.reactive.ReactiveSyncSqlExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.324 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'databaseMetadata' of type [org.hswebframework.ezorm.rdb.metadata.RDBDatabaseMetadata] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.330 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration' of type [org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration$$EnhancerBySpringCGLIB$$ecaad92c] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.580 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_en.properties -> messages
2023-14:29:52.581 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_zh.properties -> messages
2023-14:29:52.581 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_en.properties -> messages
2023-14:29:52.581 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_zh.properties -> messages
2023-14:29:52.581 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_en.properties -> messages
2023-14:29:52.581 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_zh.properties -> messages
2023-14:29:55.648 [main] INFO o.s.b.w.e.n.NettyWebServer - [start,111] []- Netty started on port 8091
2023-14:29:56.780 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStarted,61] []- Started IotAdminHttpApiApplication in 6.863 seconds (JVM running for 8.186)
2023-14:29:56.782 [main] DEBUG o.h.e.c.m.AbstractSchemaMetadata - [lambda$loadMetadata$2,94] []- load table metadata s_system ,use parser:MysqlTableMetadataParser
2023-14:29:56.863 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [filter,41] [a281b6fe-1]- api start time:1691648996862 ip:192.168.8.246 method:GET url:/demo/device/1 param:{} headers:[Host:"192.168.8.175:8091", User-Agent:"Mozilla/5.0 (Macintosh; Intel Mac OS X 10_15_7) AppleWebKit/537.36 (KHTML, like Gecko) Chrome/115.0.0.0 Safari/537.36 Edg/115.0.1901.200", Accept:"text/html,application/xhtml+xml,application/xml;q=0.9,image/webp,image/apng,*/*;q=0.8,application/signed-exchange;v=b3;q=0.7", Accept-Encoding:"gzip, deflate", Accept-Language:"zh-CN,zh;q=0.9,en;q=0.8,en-GB;q=0.7,en-US;q=0.6", Cache-Control:"max-age=0", Connection:"close", Upgrade-Insecure-Requests:"1"]
2023-14:29:57.044 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [selectMediaType,161] [a281b6fe-1]- [a281b6fe-1] Using 'application/json' given [text/html, application/xhtml+xml, image/webp, image/apng, application/xml;q=0.9, application/signed-exchange;v=b3;q=0.7, */*;q=0.8] and supported [application/json, application/*+json, application/x-ndjson, text/event-stream]
2023-14:29:57.045 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [writeBody,174] [a281b6fe-1]- [a281b6fe-1] 0..1 [org.hswebframework.web.crud.web.ResponseMessage<?>]
2023-14:29:57.108 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select count(1) as 'total' from information_schema.`TABLES` where table_schema=? and table_name=?
2023-14:29:57.109 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:57.109 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select count(1) as 'total' from information_schema.`TABLES` where table_schema='qiuguo_iot' and table_name='s_system'
2023-14:29:57.190 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,39] []- ==> Preparing: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = ? and device_info.`id` = ? limit ?,?
2023-14:29:57.190 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,41] []- ==> Parameters: 0(Integer),1(Long),0(Integer),1(Integer)
2023-14:29:57.190 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,43] []- ==> Native: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = 0 and device_info.`id` = 1 limit 0,1
2023-14:29:57.191 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema=? and table_name like ?
2023-14:29:57.192 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:57.192 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:29:57.236 [reactor-tcp-nio-2] DEBUG o.h.w.s.j.CustomJackson2jsonEncoder - [debug,127] []- [a281b6fe-1] Encoding [org.hswebframework.web.crud.web.ResponseMessage@167fd4ba]
2023-14:29:57.245 [reactor-tcp-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$writeWith$1,100] [a281b6fe-1]- response:{"message":"success","result":{"id":1,"isDelete":0,"createTime":"2023-08-09T06:47:57.000+00:00","modifyTime":"2023-08-09T06:47:57.000+00:00","batchId":1,"name":"果Box","sn":"SN234","btMac":"mac","wifiMac":"wifi","firmwareVersion":"1.0","deviceType":0,"onLine":null,"lastOnLineTime":null,"protocolType":0,"runMode":0,"marketMode":0,"otaType":0,"otaStartTime":null,"otaEndTime":null,"factoryTime":"2023-08-09T06:47:57.000+00:00","saleTime":null},"status":200,"timestamp":1691648997233}
2023-14:29:57.253 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$filter$0,58] [a281b6fe-1]- api end time:1691648997253, total time:391
2023-14:29:57.277 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema=? and table_name like ?
2023-14:29:57.277 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:57.278 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:29:57.342 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = ? and TABLE_NAME like ?
2023-14:29:57.343 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:57.343 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = 'qiuguo_iot' and TABLE_NAME like 's_system'
2023-14:29:57.421 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = ? limit ?,?
2023-14:29:57.421 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: default(String),0(Integer),1(Integer)
2023-14:29:57.421 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = 'default' limit 0,1
2023-14:29:57.585 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: update qiuguo_iot.s_system set `framework_version` = ? , `website` = ? , `major_version` = ? , `name` = ? , `revision_version` = ? , `dependencies` = ? , `minor_version` = ? where `name` = ?
2023-14:29:57.585 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: {"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}(String),(String),1(Integer),default(String),0(Integer),[](String),0(Integer),default(String)
2023-14:29:57.585 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: update qiuguo_iot.s_system set `framework_version` = '{"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}' , `website` = '' , `major_version` = 1 , `name` = 'default' , `revision_version` = 0 , `dependencies` = '[]' , `minor_version` = 0 where `name` = 'default'
2023-14:29:57.599 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [lambda$null$7,130] []- ==> Updated: 1
2023-14:30:08.395 [reactor-http-nio-3] INFO c.q.i.a.h.a.f.LogWebFilter - [filter,41] [135e5771-2]- api start time:1691649008395 ip:192.168.8.246 method:GET url:/demo/device/1 param:{} headers:[Host:"192.168.8.175:8091", User-Agent:"Mozilla/5.0 (Macintosh; Intel Mac OS X 10_15_7) AppleWebKit/537.36 (KHTML, like Gecko) Chrome/115.0.0.0 Safari/537.36 Edg/115.0.1901.200", Accept:"text/html,application/xhtml+xml,application/xml;q=0.9,image/webp,image/apng,*/*;q=0.8,application/signed-exchange;v=b3;q=0.7", Accept-Encoding:"gzip, deflate", Accept-Language:"zh-CN,zh;q=0.9,en;q=0.8,en-GB;q=0.7,en-US;q=0.6", Cache-Control:"max-age=0", Connection:"close", Upgrade-Insecure-Requests:"1"]
2023-14:30:08.397 [reactor-http-nio-3] DEBUG o.h.w.c.w.ResponseMessageWrapper - [selectMediaType,161] [135e5771-2]- [135e5771-2] Using 'application/json' given [text/html, application/xhtml+xml, image/webp, image/apng, application/xml;q=0.9, application/signed-exchange;v=b3;q=0.7, */*;q=0.8] and supported [application/json, application/*+json, application/x-ndjson, text/event-stream]
2023-14:30:08.398 [reactor-http-nio-3] DEBUG o.h.w.c.w.ResponseMessageWrapper - [writeBody,174] [135e5771-2]- [135e5771-2] 0..1 [org.hswebframework.web.crud.web.ResponseMessage<?>]
2023-14:30:08.426 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,39] []- ==> Preparing: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = ? and device_info.`id` = ? limit ?,?
2023-14:30:08.426 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,41] []- ==> Parameters: 0(Integer),1(Long),0(Integer),1(Integer)
2023-14:30:08.426 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,43] []- ==> Native: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = 0 and device_info.`id` = 1 limit 0,1
2023-14:30:08.472 [reactor-tcp-nio-2] DEBUG o.h.w.s.j.CustomJackson2jsonEncoder - [debug,127] []- [135e5771-2] Encoding [org.hswebframework.web.crud.web.ResponseMessage@20ceb433]
2023-14:30:08.472 [reactor-tcp-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$writeWith$1,100] [135e5771-2]- response:{"message":"success","result":{"id":1,"isDelete":0,"createTime":"2023-08-09T06:47:57.000+00:00","modifyTime":"2023-08-09T06:47:57.000+00:00","batchId":1,"name":"果Box","sn":"SN234","btMac":"mac","wifiMac":"wifi","firmwareVersion":"1.0","deviceType":0,"onLine":null,"lastOnLineTime":null,"protocolType":0,"runMode":0,"marketMode":0,"otaType":0,"otaStartTime":null,"otaEndTime":null,"factoryTime":"2023-08-09T06:47:57.000+00:00","saleTime":null},"status":200,"timestamp":1691649008472}
2023-14:30:08.473 [reactor-http-nio-3] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$filter$0,58] [135e5771-2]- api end time:1691649008473, total time:78

View File

@ -65,3 +65,207 @@
2023-09:38:53.390 [reactor-tcp-nio-2] DEBUG o.h.w.s.j.CustomJackson2jsonEncoder - [debug,127] []- [71453297-1] Encoding [org.hswebframework.web.crud.web.ResponseMessage@69edc3de]
2023-09:38:53.398 [reactor-tcp-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$writeWith$1,100] [71453297-1]- response:{"message":"success","result":{"id":1,"isDelete":0,"createTime":"2023-08-09T06:47:57.000+00:00","modifyTime":"2023-08-09T06:47:57.000+00:00","batchId":1,"name":"果Box","sn":"SN234","btMac":"mac","wifiMac":"wifi","firmwareVersion":"1.0","deviceType":0,"onLine":null,"lastOnLineTime":null,"protocolType":0,"runMode":0,"marketMode":0,"otaType":0,"otaStartTime":null,"otaEndTime":null,"factoryTime":"2023-08-09T06:47:57.000+00:00","saleTime":null},"status":200,"timestamp":1691631533388}
2023-09:38:53.404 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$filter$0,58] [71453297-1]- api end time:1691631533404, total time:140
2023-14:27:21.079 [background-preinit] INFO o.h.v.i.util.Version - [<clinit>,21] []- HV000001: Hibernate Validator 6.2.5.Final
2023-14:27:22.024 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStartupProfileInfo,637] []- The following 1 profile is active: "dev"
2023-14:27:22.365 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:27:22.366 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data R2DBC repositories in DEFAULT mode.
2023-14:27:22.371 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 2 ms. Found 0 R2DBC repository interfaces.
2023-14:27:22.378 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:27:22.379 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data Redis repositories in DEFAULT mode.
2023-14:27:22.385 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 0 ms. Found 0 Redis repository interfaces.
2023-14:27:22.482 [main] INFO o.s.c.c.s.GenericScope - [setSerializationId,283] []- BeanFactory id=55b765e8-874f-3936-96a0-683b41b36bc6
2023-14:27:22.553 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$$EnhancerBySpringCGLIB$$24749ac9] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.560 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration' of type [org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.561 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.562 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'loadBalancerClientsDefaultsMappingsProvider' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration$$Lambda$427/936261188] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.562 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'defaultsBindHandlerAdvisor' of type [org.springframework.cloud.commons.config.DefaultsBindHandlerAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.564 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'expressionDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.ExpressionDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.565 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'annotationDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.AnnotationDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.566 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'alwaysNoMatchStrategyMatcher' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$1] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.567 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'switcherMethodMatcherPointcutAdvisor' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$SwitcherMethodMatcherPointcutAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.568 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration' of type [org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration$$EnhancerBySpringCGLIB$$7f16cadb] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.587 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'easyorm-org.hswebframework.web.crud.configuration.EasyormProperties' of type [org.hswebframework.web.crud.configuration.EasyormProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.587 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.EasyormConfiguration' of type [org.hswebframework.web.crud.configuration.EasyormConfiguration$$EnhancerBySpringCGLIB$$4e0399f7] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.590 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration' of type [org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration$$EnhancerBySpringCGLIB$$4e90b965] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.597 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration' of type [org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.599 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'spring.r2dbc-org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties' of type [org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.634 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'connectionFactory' of type [io.r2dbc.pool.ConnectionPool] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.635 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'reactiveSqlExecutor' of type [org.hswebframework.web.crud.sql.DefaultR2dbcExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.697 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'syncSqlExecutor' of type [org.hswebframework.ezorm.rdb.executor.reactive.ReactiveSyncSqlExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.719 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'databaseMetadata' of type [org.hswebframework.ezorm.rdb.metadata.RDBDatabaseMetadata] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.726 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration' of type [org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration$$EnhancerBySpringCGLIB$$f2fed4cd] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:23.008 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_en.properties -> messages
2023-14:27:23.009 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_zh.properties -> messages
2023-14:27:23.009 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_en.properties -> messages
2023-14:27:23.009 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_zh.properties -> messages
2023-14:27:23.009 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_en.properties -> messages
2023-14:27:23.009 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_zh.properties -> messages
2023-14:27:26.205 [main] INFO o.s.b.w.e.n.NettyWebServer - [start,111] []- Netty started on port 8091
2023-14:27:27.375 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStarted,61] []- Started IotAdminHttpApiApplication in 7.159 seconds (JVM running for 8.516)
2023-14:27:27.378 [main] DEBUG o.h.e.c.m.AbstractSchemaMetadata - [lambda$loadMetadata$2,94] []- load table metadata s_system ,use parser:MysqlTableMetadataParser
2023-14:27:27.713 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select count(1) as 'total' from information_schema.`TABLES` where table_schema=? and table_name=?
2023-14:27:27.714 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:27:27.714 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select count(1) as 'total' from information_schema.`TABLES` where table_schema='qiuguo_iot' and table_name='s_system'
2023-14:27:27.796 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema=? and table_name like ?
2023-14:27:27.797 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:27:27.797 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:27:27.880 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema=? and table_name like ?
2023-14:27:27.880 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:27:27.880 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:27:27.954 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = ? and TABLE_NAME like ?
2023-14:27:27.955 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:27:27.955 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = 'qiuguo_iot' and TABLE_NAME like 's_system'
2023-14:27:28.045 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = ? limit ?,?
2023-14:27:28.045 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: default(String),0(Integer),1(Integer)
2023-14:27:28.046 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = 'default' limit 0,1
2023-14:27:28.258 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: update qiuguo_iot.s_system set `framework_version` = ? , `website` = ? , `major_version` = ? , `name` = ? , `revision_version` = ? , `dependencies` = ? , `minor_version` = ? where `name` = ?
2023-14:27:28.258 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: {"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}(String),(String),1(Integer),default(String),0(Integer),[](String),0(Integer),default(String)
2023-14:27:28.258 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: update qiuguo_iot.s_system set `framework_version` = '{"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}' , `website` = '' , `major_version` = 1 , `name` = 'default' , `revision_version` = 0 , `dependencies` = '[]' , `minor_version` = 0 where `name` = 'default'
2023-14:27:28.272 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [lambda$null$7,130] []- ==> Updated: 1
2023-14:27:30.612 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [filter,41] [f5fdb5b3-1]- api start time:1691648850612 ip:192.168.8.246 method:GET url:/demo/device/1 param:{} headers:[Host:"192.168.8.175:8091", User-Agent:"Mozilla/5.0 (Macintosh; Intel Mac OS X 10_15_7) AppleWebKit/537.36 (KHTML, like Gecko) Chrome/115.0.0.0 Safari/537.36 Edg/115.0.1901.200", Accept:"text/html,application/xhtml+xml,application/xml;q=0.9,image/webp,image/apng,*/*;q=0.8,application/signed-exchange;v=b3;q=0.7", Accept-Encoding:"gzip, deflate", Accept-Language:"zh-CN,zh;q=0.9,en;q=0.8,en-GB;q=0.7,en-US;q=0.6", Cache-Control:"max-age=0", Connection:"close", Upgrade-Insecure-Requests:"1"]
2023-14:27:30.656 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [selectMediaType,161] [f5fdb5b3-1]- [f5fdb5b3-1] Using 'application/json' given [text/html, application/xhtml+xml, image/webp, image/apng, application/xml;q=0.9, application/signed-exchange;v=b3;q=0.7, */*;q=0.8] and supported [application/json, application/*+json, application/x-ndjson, text/event-stream]
2023-14:27:30.656 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [writeBody,174] [f5fdb5b3-1]- [f5fdb5b3-1] 0..1 [org.hswebframework.web.crud.web.ResponseMessage<?>]
2023-14:27:30.689 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,39] []- ==> Preparing: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = ? and device_info.`id` = ? limit ?,?
2023-14:27:30.689 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,41] []- ==> Parameters: 0(Integer),1(Long),0(Integer),1(Integer)
2023-14:27:30.689 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,43] []- ==> Native: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = 0 and device_info.`id` = 1 limit 0,1
2023-14:27:30.736 [reactor-tcp-nio-2] DEBUG o.h.w.s.j.CustomJackson2jsonEncoder - [debug,127] []- [f5fdb5b3-1] Encoding [org.hswebframework.web.crud.web.ResponseMessage@2901b387]
2023-14:27:30.744 [reactor-tcp-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$writeWith$1,100] [f5fdb5b3-1]- response:{"message":"success","result":{"id":1,"isDelete":0,"createTime":"2023-08-09T06:47:57.000+00:00","modifyTime":"2023-08-09T06:47:57.000+00:00","batchId":1,"name":"果Box","sn":"SN234","btMac":"mac","wifiMac":"wifi","firmwareVersion":"1.0","deviceType":0,"onLine":null,"lastOnLineTime":null,"protocolType":0,"runMode":0,"marketMode":0,"otaType":0,"otaStartTime":null,"otaEndTime":null,"factoryTime":"2023-08-09T06:47:57.000+00:00","saleTime":null},"status":200,"timestamp":1691648850733}
2023-14:27:30.751 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$filter$0,58] [f5fdb5b3-1]- api end time:1691648850751, total time:139
2023-14:29:18.767 [background-preinit] INFO o.h.v.i.util.Version - [<clinit>,21] []- HV000001: Hibernate Validator 6.2.5.Final
2023-14:29:19.799 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStartupProfileInfo,637] []- The following 1 profile is active: "dev"
2023-14:29:20.164 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:29:20.165 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data R2DBC repositories in DEFAULT mode.
2023-14:29:20.170 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 2 ms. Found 0 R2DBC repository interfaces.
2023-14:29:20.177 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:29:20.178 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data Redis repositories in DEFAULT mode.
2023-14:29:20.184 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 0 ms. Found 0 Redis repository interfaces.
2023-14:29:20.284 [main] INFO o.s.c.c.s.GenericScope - [setSerializationId,283] []- BeanFactory id=55b765e8-874f-3936-96a0-683b41b36bc6
2023-14:29:20.364 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$$EnhancerBySpringCGLIB$$8cef4f2e] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.372 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration' of type [org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.373 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.374 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'loadBalancerClientsDefaultsMappingsProvider' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration$$Lambda$427/454424866] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.375 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'defaultsBindHandlerAdvisor' of type [org.springframework.cloud.commons.config.DefaultsBindHandlerAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.376 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'expressionDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.ExpressionDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.377 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'annotationDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.AnnotationDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.378 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'alwaysNoMatchStrategyMatcher' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$1] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.379 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'switcherMethodMatcherPointcutAdvisor' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$SwitcherMethodMatcherPointcutAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.380 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration' of type [org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration$$EnhancerBySpringCGLIB$$e7917f40] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.399 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'easyorm-org.hswebframework.web.crud.configuration.EasyormProperties' of type [org.hswebframework.web.crud.configuration.EasyormProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.400 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.EasyormConfiguration' of type [org.hswebframework.web.crud.configuration.EasyormConfiguration$$EnhancerBySpringCGLIB$$b67e4e5c] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.402 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration' of type [org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration$$EnhancerBySpringCGLIB$$b70b6dca] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.409 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration' of type [org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.411 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'spring.r2dbc-org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties' of type [org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.445 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'connectionFactory' of type [io.r2dbc.pool.ConnectionPool] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.447 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'reactiveSqlExecutor' of type [org.hswebframework.web.crud.sql.DefaultR2dbcExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.507 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'syncSqlExecutor' of type [org.hswebframework.ezorm.rdb.executor.reactive.ReactiveSyncSqlExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.530 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'databaseMetadata' of type [org.hswebframework.ezorm.rdb.metadata.RDBDatabaseMetadata] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.536 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration' of type [org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration$$EnhancerBySpringCGLIB$$5b798932] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.784 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_en.properties -> messages
2023-14:29:20.785 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_zh.properties -> messages
2023-14:29:20.785 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_en.properties -> messages
2023-14:29:20.785 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_zh.properties -> messages
2023-14:29:20.785 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_en.properties -> messages
2023-14:29:20.786 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_zh.properties -> messages
2023-14:29:23.687 [main] INFO o.s.b.w.e.n.NettyWebServer - [start,111] []- Netty started on port 8091
2023-14:29:24.825 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStarted,61] []- Started IotAdminHttpApiApplication in 6.958 seconds (JVM running for 8.261)
2023-14:29:24.828 [main] DEBUG o.h.e.c.m.AbstractSchemaMetadata - [lambda$loadMetadata$2,94] []- load table metadata s_system ,use parser:MysqlTableMetadataParser
2023-14:29:25.172 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select count(1) as 'total' from information_schema.`TABLES` where table_schema=? and table_name=?
2023-14:29:25.173 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:25.173 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select count(1) as 'total' from information_schema.`TABLES` where table_schema='qiuguo_iot' and table_name='s_system'
2023-14:29:25.256 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema=? and table_name like ?
2023-14:29:25.256 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:25.256 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:29:25.328 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema=? and table_name like ?
2023-14:29:25.329 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:25.329 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:29:25.394 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = ? and TABLE_NAME like ?
2023-14:29:25.394 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:25.394 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = 'qiuguo_iot' and TABLE_NAME like 's_system'
2023-14:29:25.484 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = ? limit ?,?
2023-14:29:25.484 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: default(String),0(Integer),1(Integer)
2023-14:29:25.484 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = 'default' limit 0,1
2023-14:29:25.677 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: update qiuguo_iot.s_system set `framework_version` = ? , `website` = ? , `major_version` = ? , `name` = ? , `revision_version` = ? , `dependencies` = ? , `minor_version` = ? where `name` = ?
2023-14:29:25.677 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: {"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}(String),(String),1(Integer),default(String),0(Integer),[](String),0(Integer),default(String)
2023-14:29:25.678 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: update qiuguo_iot.s_system set `framework_version` = '{"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}' , `website` = '' , `major_version` = 1 , `name` = 'default' , `revision_version` = 0 , `dependencies` = '[]' , `minor_version` = 0 where `name` = 'default'
2023-14:29:25.691 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [lambda$null$7,130] []- ==> Updated: 1
2023-14:29:27.158 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [filter,41] [babb4f9b-1]- api start time:1691648967158 ip:192.168.8.246 method:GET url:/demo/device/1 param:{} headers:[Host:"192.168.8.175:8091", User-Agent:"Mozilla/5.0 (Macintosh; Intel Mac OS X 10_15_7) AppleWebKit/537.36 (KHTML, like Gecko) Chrome/115.0.0.0 Safari/537.36 Edg/115.0.1901.200", Accept:"text/html,application/xhtml+xml,application/xml;q=0.9,image/webp,image/apng,*/*;q=0.8,application/signed-exchange;v=b3;q=0.7", Accept-Encoding:"gzip, deflate", Accept-Language:"zh-CN,zh;q=0.9,en;q=0.8,en-GB;q=0.7,en-US;q=0.6", Cache-Control:"max-age=0", Connection:"close", Upgrade-Insecure-Requests:"1"]
2023-14:29:27.200 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [selectMediaType,161] [babb4f9b-1]- [babb4f9b-1] Using 'application/json' given [text/html, application/xhtml+xml, image/webp, image/apng, application/xml;q=0.9, application/signed-exchange;v=b3;q=0.7, */*;q=0.8] and supported [application/json, application/*+json, application/x-ndjson, text/event-stream]
2023-14:29:27.201 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [writeBody,174] [babb4f9b-1]- [babb4f9b-1] 0..1 [org.hswebframework.web.crud.web.ResponseMessage<?>]
2023-14:29:27.276 [reactor-tcp-nio-2] DEBUG o.h.w.s.j.CustomJackson2jsonEncoder - [debug,127] []- [babb4f9b-1] Encoding [org.hswebframework.web.crud.web.ResponseMessage@7f818213]
2023-14:29:27.283 [reactor-tcp-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$writeWith$1,100] [babb4f9b-1]- response:{"message":"success","result":{"id":1,"isDelete":0,"createTime":"2023-08-09T06:47:57.000+00:00","modifyTime":"2023-08-09T06:47:57.000+00:00","batchId":1,"name":"果Box","sn":"SN234","btMac":"mac","wifiMac":"wifi","firmwareVersion":"1.0","deviceType":0,"onLine":null,"lastOnLineTime":null,"protocolType":0,"runMode":0,"marketMode":0,"otaType":0,"otaStartTime":null,"otaEndTime":null,"factoryTime":"2023-08-09T06:47:57.000+00:00","saleTime":null},"status":200,"timestamp":1691648967274}
2023-14:29:27.289 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$filter$0,58] [babb4f9b-1]- api end time:1691648967289, total time:131
2023-14:29:50.776 [background-preinit] INFO o.h.v.i.util.Version - [<clinit>,21] []- HV000001: Hibernate Validator 6.2.5.Final
2023-14:29:51.592 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStartupProfileInfo,637] []- The following 1 profile is active: "dev"
2023-14:29:51.952 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:29:51.953 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data R2DBC repositories in DEFAULT mode.
2023-14:29:51.959 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 2 ms. Found 0 R2DBC repository interfaces.
2023-14:29:51.967 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:29:51.968 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data Redis repositories in DEFAULT mode.
2023-14:29:51.974 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 0 ms. Found 0 Redis repository interfaces.
2023-14:29:52.074 [main] INFO o.s.c.c.s.GenericScope - [setSerializationId,283] []- BeanFactory id=55b765e8-874f-3936-96a0-683b41b36bc6
2023-14:29:52.149 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$$EnhancerBySpringCGLIB$$1e209f28] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.158 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration' of type [org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.159 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.159 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'loadBalancerClientsDefaultsMappingsProvider' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration$$Lambda$427/1267110705] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.160 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'defaultsBindHandlerAdvisor' of type [org.springframework.cloud.commons.config.DefaultsBindHandlerAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.162 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'expressionDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.ExpressionDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.163 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'annotationDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.AnnotationDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.164 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'alwaysNoMatchStrategyMatcher' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$1] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.165 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'switcherMethodMatcherPointcutAdvisor' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$SwitcherMethodMatcherPointcutAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.167 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration' of type [org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration$$EnhancerBySpringCGLIB$$78c2cf3a] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.188 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'easyorm-org.hswebframework.web.crud.configuration.EasyormProperties' of type [org.hswebframework.web.crud.configuration.EasyormProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.189 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.EasyormConfiguration' of type [org.hswebframework.web.crud.configuration.EasyormConfiguration$$EnhancerBySpringCGLIB$$47af9e56] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.192 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration' of type [org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration$$EnhancerBySpringCGLIB$$483cbdc4] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.199 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration' of type [org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.201 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'spring.r2dbc-org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties' of type [org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.236 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'connectionFactory' of type [io.r2dbc.pool.ConnectionPool] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.238 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'reactiveSqlExecutor' of type [org.hswebframework.web.crud.sql.DefaultR2dbcExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.301 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'syncSqlExecutor' of type [org.hswebframework.ezorm.rdb.executor.reactive.ReactiveSyncSqlExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.324 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'databaseMetadata' of type [org.hswebframework.ezorm.rdb.metadata.RDBDatabaseMetadata] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.330 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration' of type [org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration$$EnhancerBySpringCGLIB$$ecaad92c] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.580 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_en.properties -> messages
2023-14:29:52.581 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_zh.properties -> messages
2023-14:29:52.581 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_en.properties -> messages
2023-14:29:52.581 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_zh.properties -> messages
2023-14:29:52.581 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_en.properties -> messages
2023-14:29:52.581 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_zh.properties -> messages
2023-14:29:55.648 [main] INFO o.s.b.w.e.n.NettyWebServer - [start,111] []- Netty started on port 8091
2023-14:29:56.780 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStarted,61] []- Started IotAdminHttpApiApplication in 6.863 seconds (JVM running for 8.186)
2023-14:29:56.782 [main] DEBUG o.h.e.c.m.AbstractSchemaMetadata - [lambda$loadMetadata$2,94] []- load table metadata s_system ,use parser:MysqlTableMetadataParser
2023-14:29:56.863 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [filter,41] [a281b6fe-1]- api start time:1691648996862 ip:192.168.8.246 method:GET url:/demo/device/1 param:{} headers:[Host:"192.168.8.175:8091", User-Agent:"Mozilla/5.0 (Macintosh; Intel Mac OS X 10_15_7) AppleWebKit/537.36 (KHTML, like Gecko) Chrome/115.0.0.0 Safari/537.36 Edg/115.0.1901.200", Accept:"text/html,application/xhtml+xml,application/xml;q=0.9,image/webp,image/apng,*/*;q=0.8,application/signed-exchange;v=b3;q=0.7", Accept-Encoding:"gzip, deflate", Accept-Language:"zh-CN,zh;q=0.9,en;q=0.8,en-GB;q=0.7,en-US;q=0.6", Cache-Control:"max-age=0", Connection:"close", Upgrade-Insecure-Requests:"1"]
2023-14:29:57.044 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [selectMediaType,161] [a281b6fe-1]- [a281b6fe-1] Using 'application/json' given [text/html, application/xhtml+xml, image/webp, image/apng, application/xml;q=0.9, application/signed-exchange;v=b3;q=0.7, */*;q=0.8] and supported [application/json, application/*+json, application/x-ndjson, text/event-stream]
2023-14:29:57.045 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [writeBody,174] [a281b6fe-1]- [a281b6fe-1] 0..1 [org.hswebframework.web.crud.web.ResponseMessage<?>]
2023-14:29:57.108 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select count(1) as 'total' from information_schema.`TABLES` where table_schema=? and table_name=?
2023-14:29:57.109 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:57.109 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select count(1) as 'total' from information_schema.`TABLES` where table_schema='qiuguo_iot' and table_name='s_system'
2023-14:29:57.190 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,39] []- ==> Preparing: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = ? and device_info.`id` = ? limit ?,?
2023-14:29:57.190 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,41] []- ==> Parameters: 0(Integer),1(Long),0(Integer),1(Integer)
2023-14:29:57.190 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,43] []- ==> Native: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = 0 and device_info.`id` = 1 limit 0,1
2023-14:29:57.191 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema=? and table_name like ?
2023-14:29:57.192 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:57.192 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:29:57.236 [reactor-tcp-nio-2] DEBUG o.h.w.s.j.CustomJackson2jsonEncoder - [debug,127] []- [a281b6fe-1] Encoding [org.hswebframework.web.crud.web.ResponseMessage@167fd4ba]
2023-14:29:57.245 [reactor-tcp-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$writeWith$1,100] [a281b6fe-1]- response:{"message":"success","result":{"id":1,"isDelete":0,"createTime":"2023-08-09T06:47:57.000+00:00","modifyTime":"2023-08-09T06:47:57.000+00:00","batchId":1,"name":"果Box","sn":"SN234","btMac":"mac","wifiMac":"wifi","firmwareVersion":"1.0","deviceType":0,"onLine":null,"lastOnLineTime":null,"protocolType":0,"runMode":0,"marketMode":0,"otaType":0,"otaStartTime":null,"otaEndTime":null,"factoryTime":"2023-08-09T06:47:57.000+00:00","saleTime":null},"status":200,"timestamp":1691648997233}
2023-14:29:57.253 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$filter$0,58] [a281b6fe-1]- api end time:1691648997253, total time:391
2023-14:29:57.277 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema=? and table_name like ?
2023-14:29:57.277 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:57.278 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:29:57.342 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = ? and TABLE_NAME like ?
2023-14:29:57.343 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:57.343 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = 'qiuguo_iot' and TABLE_NAME like 's_system'
2023-14:29:57.421 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = ? limit ?,?
2023-14:29:57.421 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: default(String),0(Integer),1(Integer)
2023-14:29:57.421 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = 'default' limit 0,1
2023-14:29:57.585 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: update qiuguo_iot.s_system set `framework_version` = ? , `website` = ? , `major_version` = ? , `name` = ? , `revision_version` = ? , `dependencies` = ? , `minor_version` = ? where `name` = ?
2023-14:29:57.585 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: {"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}(String),(String),1(Integer),default(String),0(Integer),[](String),0(Integer),default(String)
2023-14:29:57.585 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: update qiuguo_iot.s_system set `framework_version` = '{"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}' , `website` = '' , `major_version` = 1 , `name` = 'default' , `revision_version` = 0 , `dependencies` = '[]' , `minor_version` = 0 where `name` = 'default'
2023-14:29:57.599 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [lambda$null$7,130] []- ==> Updated: 1
2023-14:30:08.395 [reactor-http-nio-3] INFO c.q.i.a.h.a.f.LogWebFilter - [filter,41] [135e5771-2]- api start time:1691649008395 ip:192.168.8.246 method:GET url:/demo/device/1 param:{} headers:[Host:"192.168.8.175:8091", User-Agent:"Mozilla/5.0 (Macintosh; Intel Mac OS X 10_15_7) AppleWebKit/537.36 (KHTML, like Gecko) Chrome/115.0.0.0 Safari/537.36 Edg/115.0.1901.200", Accept:"text/html,application/xhtml+xml,application/xml;q=0.9,image/webp,image/apng,*/*;q=0.8,application/signed-exchange;v=b3;q=0.7", Accept-Encoding:"gzip, deflate", Accept-Language:"zh-CN,zh;q=0.9,en;q=0.8,en-GB;q=0.7,en-US;q=0.6", Cache-Control:"max-age=0", Connection:"close", Upgrade-Insecure-Requests:"1"]
2023-14:30:08.397 [reactor-http-nio-3] DEBUG o.h.w.c.w.ResponseMessageWrapper - [selectMediaType,161] [135e5771-2]- [135e5771-2] Using 'application/json' given [text/html, application/xhtml+xml, image/webp, image/apng, application/xml;q=0.9, application/signed-exchange;v=b3;q=0.7, */*;q=0.8] and supported [application/json, application/*+json, application/x-ndjson, text/event-stream]
2023-14:30:08.398 [reactor-http-nio-3] DEBUG o.h.w.c.w.ResponseMessageWrapper - [writeBody,174] [135e5771-2]- [135e5771-2] 0..1 [org.hswebframework.web.crud.web.ResponseMessage<?>]
2023-14:30:08.426 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,39] []- ==> Preparing: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = ? and device_info.`id` = ? limit ?,?
2023-14:30:08.426 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,41] []- ==> Parameters: 0(Integer),1(Long),0(Integer),1(Integer)
2023-14:30:08.426 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,43] []- ==> Native: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = 0 and device_info.`id` = 1 limit 0,1
2023-14:30:08.472 [reactor-tcp-nio-2] DEBUG o.h.w.s.j.CustomJackson2jsonEncoder - [debug,127] []- [135e5771-2] Encoding [org.hswebframework.web.crud.web.ResponseMessage@20ceb433]
2023-14:30:08.472 [reactor-tcp-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$writeWith$1,100] [135e5771-2]- response:{"message":"success","result":{"id":1,"isDelete":0,"createTime":"2023-08-09T06:47:57.000+00:00","modifyTime":"2023-08-09T06:47:57.000+00:00","batchId":1,"name":"果Box","sn":"SN234","btMac":"mac","wifiMac":"wifi","firmwareVersion":"1.0","deviceType":0,"onLine":null,"lastOnLineTime":null,"protocolType":0,"runMode":0,"marketMode":0,"otaType":0,"otaStartTime":null,"otaEndTime":null,"factoryTime":"2023-08-09T06:47:57.000+00:00","saleTime":null},"status":200,"timestamp":1691649008472}
2023-14:30:08.473 [reactor-http-nio-3] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$filter$0,58] [135e5771-2]- api end time:1691649008473, total time:78

View File

@ -65,3 +65,207 @@
2023-09:38:53.390 [reactor-tcp-nio-2] DEBUG o.h.w.s.j.CustomJackson2jsonEncoder - [debug,127] []- [71453297-1] Encoding [org.hswebframework.web.crud.web.ResponseMessage@69edc3de]
2023-09:38:53.398 [reactor-tcp-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$writeWith$1,100] [71453297-1]- response:{"message":"success","result":{"id":1,"isDelete":0,"createTime":"2023-08-09T06:47:57.000+00:00","modifyTime":"2023-08-09T06:47:57.000+00:00","batchId":1,"name":"果Box","sn":"SN234","btMac":"mac","wifiMac":"wifi","firmwareVersion":"1.0","deviceType":0,"onLine":null,"lastOnLineTime":null,"protocolType":0,"runMode":0,"marketMode":0,"otaType":0,"otaStartTime":null,"otaEndTime":null,"factoryTime":"2023-08-09T06:47:57.000+00:00","saleTime":null},"status":200,"timestamp":1691631533388}
2023-09:38:53.404 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$filter$0,58] [71453297-1]- api end time:1691631533404, total time:140
2023-14:27:21.079 [background-preinit] INFO o.h.v.i.util.Version - [<clinit>,21] []- HV000001: Hibernate Validator 6.2.5.Final
2023-14:27:22.024 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStartupProfileInfo,637] []- The following 1 profile is active: "dev"
2023-14:27:22.365 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:27:22.366 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data R2DBC repositories in DEFAULT mode.
2023-14:27:22.371 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 2 ms. Found 0 R2DBC repository interfaces.
2023-14:27:22.378 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:27:22.379 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data Redis repositories in DEFAULT mode.
2023-14:27:22.385 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 0 ms. Found 0 Redis repository interfaces.
2023-14:27:22.482 [main] INFO o.s.c.c.s.GenericScope - [setSerializationId,283] []- BeanFactory id=55b765e8-874f-3936-96a0-683b41b36bc6
2023-14:27:22.553 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$$EnhancerBySpringCGLIB$$24749ac9] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.560 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration' of type [org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.561 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.562 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'loadBalancerClientsDefaultsMappingsProvider' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration$$Lambda$427/936261188] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.562 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'defaultsBindHandlerAdvisor' of type [org.springframework.cloud.commons.config.DefaultsBindHandlerAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.564 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'expressionDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.ExpressionDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.565 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'annotationDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.AnnotationDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.566 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'alwaysNoMatchStrategyMatcher' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$1] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.567 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'switcherMethodMatcherPointcutAdvisor' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$SwitcherMethodMatcherPointcutAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.568 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration' of type [org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration$$EnhancerBySpringCGLIB$$7f16cadb] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.587 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'easyorm-org.hswebframework.web.crud.configuration.EasyormProperties' of type [org.hswebframework.web.crud.configuration.EasyormProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.587 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.EasyormConfiguration' of type [org.hswebframework.web.crud.configuration.EasyormConfiguration$$EnhancerBySpringCGLIB$$4e0399f7] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.590 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration' of type [org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration$$EnhancerBySpringCGLIB$$4e90b965] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.597 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration' of type [org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.599 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'spring.r2dbc-org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties' of type [org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.634 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'connectionFactory' of type [io.r2dbc.pool.ConnectionPool] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.635 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'reactiveSqlExecutor' of type [org.hswebframework.web.crud.sql.DefaultR2dbcExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.697 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'syncSqlExecutor' of type [org.hswebframework.ezorm.rdb.executor.reactive.ReactiveSyncSqlExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.719 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'databaseMetadata' of type [org.hswebframework.ezorm.rdb.metadata.RDBDatabaseMetadata] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:22.726 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration' of type [org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration$$EnhancerBySpringCGLIB$$f2fed4cd] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:27:23.008 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_en.properties -> messages
2023-14:27:23.009 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_zh.properties -> messages
2023-14:27:23.009 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_en.properties -> messages
2023-14:27:23.009 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_zh.properties -> messages
2023-14:27:23.009 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_en.properties -> messages
2023-14:27:23.009 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_zh.properties -> messages
2023-14:27:26.205 [main] INFO o.s.b.w.e.n.NettyWebServer - [start,111] []- Netty started on port 8091
2023-14:27:27.375 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStarted,61] []- Started IotAdminHttpApiApplication in 7.159 seconds (JVM running for 8.516)
2023-14:27:27.378 [main] DEBUG o.h.e.c.m.AbstractSchemaMetadata - [lambda$loadMetadata$2,94] []- load table metadata s_system ,use parser:MysqlTableMetadataParser
2023-14:27:27.713 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select count(1) as 'total' from information_schema.`TABLES` where table_schema=? and table_name=?
2023-14:27:27.714 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:27:27.714 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select count(1) as 'total' from information_schema.`TABLES` where table_schema='qiuguo_iot' and table_name='s_system'
2023-14:27:27.796 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema=? and table_name like ?
2023-14:27:27.797 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:27:27.797 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:27:27.880 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema=? and table_name like ?
2023-14:27:27.880 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:27:27.880 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:27:27.954 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = ? and TABLE_NAME like ?
2023-14:27:27.955 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:27:27.955 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = 'qiuguo_iot' and TABLE_NAME like 's_system'
2023-14:27:28.045 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = ? limit ?,?
2023-14:27:28.045 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: default(String),0(Integer),1(Integer)
2023-14:27:28.046 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = 'default' limit 0,1
2023-14:27:28.258 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: update qiuguo_iot.s_system set `framework_version` = ? , `website` = ? , `major_version` = ? , `name` = ? , `revision_version` = ? , `dependencies` = ? , `minor_version` = ? where `name` = ?
2023-14:27:28.258 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: {"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}(String),(String),1(Integer),default(String),0(Integer),[](String),0(Integer),default(String)
2023-14:27:28.258 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: update qiuguo_iot.s_system set `framework_version` = '{"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}' , `website` = '' , `major_version` = 1 , `name` = 'default' , `revision_version` = 0 , `dependencies` = '[]' , `minor_version` = 0 where `name` = 'default'
2023-14:27:28.272 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [lambda$null$7,130] []- ==> Updated: 1
2023-14:27:30.612 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [filter,41] [f5fdb5b3-1]- api start time:1691648850612 ip:192.168.8.246 method:GET url:/demo/device/1 param:{} headers:[Host:"192.168.8.175:8091", User-Agent:"Mozilla/5.0 (Macintosh; Intel Mac OS X 10_15_7) AppleWebKit/537.36 (KHTML, like Gecko) Chrome/115.0.0.0 Safari/537.36 Edg/115.0.1901.200", Accept:"text/html,application/xhtml+xml,application/xml;q=0.9,image/webp,image/apng,*/*;q=0.8,application/signed-exchange;v=b3;q=0.7", Accept-Encoding:"gzip, deflate", Accept-Language:"zh-CN,zh;q=0.9,en;q=0.8,en-GB;q=0.7,en-US;q=0.6", Cache-Control:"max-age=0", Connection:"close", Upgrade-Insecure-Requests:"1"]
2023-14:27:30.656 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [selectMediaType,161] [f5fdb5b3-1]- [f5fdb5b3-1] Using 'application/json' given [text/html, application/xhtml+xml, image/webp, image/apng, application/xml;q=0.9, application/signed-exchange;v=b3;q=0.7, */*;q=0.8] and supported [application/json, application/*+json, application/x-ndjson, text/event-stream]
2023-14:27:30.656 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [writeBody,174] [f5fdb5b3-1]- [f5fdb5b3-1] 0..1 [org.hswebframework.web.crud.web.ResponseMessage<?>]
2023-14:27:30.689 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,39] []- ==> Preparing: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = ? and device_info.`id` = ? limit ?,?
2023-14:27:30.689 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,41] []- ==> Parameters: 0(Integer),1(Long),0(Integer),1(Integer)
2023-14:27:30.689 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,43] []- ==> Native: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = 0 and device_info.`id` = 1 limit 0,1
2023-14:27:30.736 [reactor-tcp-nio-2] DEBUG o.h.w.s.j.CustomJackson2jsonEncoder - [debug,127] []- [f5fdb5b3-1] Encoding [org.hswebframework.web.crud.web.ResponseMessage@2901b387]
2023-14:27:30.744 [reactor-tcp-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$writeWith$1,100] [f5fdb5b3-1]- response:{"message":"success","result":{"id":1,"isDelete":0,"createTime":"2023-08-09T06:47:57.000+00:00","modifyTime":"2023-08-09T06:47:57.000+00:00","batchId":1,"name":"果Box","sn":"SN234","btMac":"mac","wifiMac":"wifi","firmwareVersion":"1.0","deviceType":0,"onLine":null,"lastOnLineTime":null,"protocolType":0,"runMode":0,"marketMode":0,"otaType":0,"otaStartTime":null,"otaEndTime":null,"factoryTime":"2023-08-09T06:47:57.000+00:00","saleTime":null},"status":200,"timestamp":1691648850733}
2023-14:27:30.751 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$filter$0,58] [f5fdb5b3-1]- api end time:1691648850751, total time:139
2023-14:29:18.767 [background-preinit] INFO o.h.v.i.util.Version - [<clinit>,21] []- HV000001: Hibernate Validator 6.2.5.Final
2023-14:29:19.799 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStartupProfileInfo,637] []- The following 1 profile is active: "dev"
2023-14:29:20.164 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:29:20.165 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data R2DBC repositories in DEFAULT mode.
2023-14:29:20.170 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 2 ms. Found 0 R2DBC repository interfaces.
2023-14:29:20.177 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:29:20.178 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data Redis repositories in DEFAULT mode.
2023-14:29:20.184 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 0 ms. Found 0 Redis repository interfaces.
2023-14:29:20.284 [main] INFO o.s.c.c.s.GenericScope - [setSerializationId,283] []- BeanFactory id=55b765e8-874f-3936-96a0-683b41b36bc6
2023-14:29:20.364 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$$EnhancerBySpringCGLIB$$8cef4f2e] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.372 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration' of type [org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.373 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.374 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'loadBalancerClientsDefaultsMappingsProvider' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration$$Lambda$427/454424866] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.375 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'defaultsBindHandlerAdvisor' of type [org.springframework.cloud.commons.config.DefaultsBindHandlerAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.376 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'expressionDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.ExpressionDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.377 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'annotationDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.AnnotationDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.378 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'alwaysNoMatchStrategyMatcher' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$1] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.379 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'switcherMethodMatcherPointcutAdvisor' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$SwitcherMethodMatcherPointcutAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.380 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration' of type [org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration$$EnhancerBySpringCGLIB$$e7917f40] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.399 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'easyorm-org.hswebframework.web.crud.configuration.EasyormProperties' of type [org.hswebframework.web.crud.configuration.EasyormProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.400 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.EasyormConfiguration' of type [org.hswebframework.web.crud.configuration.EasyormConfiguration$$EnhancerBySpringCGLIB$$b67e4e5c] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.402 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration' of type [org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration$$EnhancerBySpringCGLIB$$b70b6dca] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.409 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration' of type [org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.411 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'spring.r2dbc-org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties' of type [org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.445 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'connectionFactory' of type [io.r2dbc.pool.ConnectionPool] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.447 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'reactiveSqlExecutor' of type [org.hswebframework.web.crud.sql.DefaultR2dbcExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.507 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'syncSqlExecutor' of type [org.hswebframework.ezorm.rdb.executor.reactive.ReactiveSyncSqlExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.530 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'databaseMetadata' of type [org.hswebframework.ezorm.rdb.metadata.RDBDatabaseMetadata] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.536 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration' of type [org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration$$EnhancerBySpringCGLIB$$5b798932] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:20.784 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_en.properties -> messages
2023-14:29:20.785 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_zh.properties -> messages
2023-14:29:20.785 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_en.properties -> messages
2023-14:29:20.785 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_zh.properties -> messages
2023-14:29:20.785 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_en.properties -> messages
2023-14:29:20.786 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_zh.properties -> messages
2023-14:29:23.687 [main] INFO o.s.b.w.e.n.NettyWebServer - [start,111] []- Netty started on port 8091
2023-14:29:24.825 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStarted,61] []- Started IotAdminHttpApiApplication in 6.958 seconds (JVM running for 8.261)
2023-14:29:24.828 [main] DEBUG o.h.e.c.m.AbstractSchemaMetadata - [lambda$loadMetadata$2,94] []- load table metadata s_system ,use parser:MysqlTableMetadataParser
2023-14:29:25.172 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select count(1) as 'total' from information_schema.`TABLES` where table_schema=? and table_name=?
2023-14:29:25.173 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:25.173 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select count(1) as 'total' from information_schema.`TABLES` where table_schema='qiuguo_iot' and table_name='s_system'
2023-14:29:25.256 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema=? and table_name like ?
2023-14:29:25.256 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:25.256 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:29:25.328 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema=? and table_name like ?
2023-14:29:25.329 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:25.329 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:29:25.394 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = ? and TABLE_NAME like ?
2023-14:29:25.394 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:25.394 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = 'qiuguo_iot' and TABLE_NAME like 's_system'
2023-14:29:25.484 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = ? limit ?,?
2023-14:29:25.484 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: default(String),0(Integer),1(Integer)
2023-14:29:25.484 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = 'default' limit 0,1
2023-14:29:25.677 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: update qiuguo_iot.s_system set `framework_version` = ? , `website` = ? , `major_version` = ? , `name` = ? , `revision_version` = ? , `dependencies` = ? , `minor_version` = ? where `name` = ?
2023-14:29:25.677 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: {"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}(String),(String),1(Integer),default(String),0(Integer),[](String),0(Integer),default(String)
2023-14:29:25.678 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: update qiuguo_iot.s_system set `framework_version` = '{"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}' , `website` = '' , `major_version` = 1 , `name` = 'default' , `revision_version` = 0 , `dependencies` = '[]' , `minor_version` = 0 where `name` = 'default'
2023-14:29:25.691 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [lambda$null$7,130] []- ==> Updated: 1
2023-14:29:27.158 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [filter,41] [babb4f9b-1]- api start time:1691648967158 ip:192.168.8.246 method:GET url:/demo/device/1 param:{} headers:[Host:"192.168.8.175:8091", User-Agent:"Mozilla/5.0 (Macintosh; Intel Mac OS X 10_15_7) AppleWebKit/537.36 (KHTML, like Gecko) Chrome/115.0.0.0 Safari/537.36 Edg/115.0.1901.200", Accept:"text/html,application/xhtml+xml,application/xml;q=0.9,image/webp,image/apng,*/*;q=0.8,application/signed-exchange;v=b3;q=0.7", Accept-Encoding:"gzip, deflate", Accept-Language:"zh-CN,zh;q=0.9,en;q=0.8,en-GB;q=0.7,en-US;q=0.6", Cache-Control:"max-age=0", Connection:"close", Upgrade-Insecure-Requests:"1"]
2023-14:29:27.200 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [selectMediaType,161] [babb4f9b-1]- [babb4f9b-1] Using 'application/json' given [text/html, application/xhtml+xml, image/webp, image/apng, application/xml;q=0.9, application/signed-exchange;v=b3;q=0.7, */*;q=0.8] and supported [application/json, application/*+json, application/x-ndjson, text/event-stream]
2023-14:29:27.201 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [writeBody,174] [babb4f9b-1]- [babb4f9b-1] 0..1 [org.hswebframework.web.crud.web.ResponseMessage<?>]
2023-14:29:27.276 [reactor-tcp-nio-2] DEBUG o.h.w.s.j.CustomJackson2jsonEncoder - [debug,127] []- [babb4f9b-1] Encoding [org.hswebframework.web.crud.web.ResponseMessage@7f818213]
2023-14:29:27.283 [reactor-tcp-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$writeWith$1,100] [babb4f9b-1]- response:{"message":"success","result":{"id":1,"isDelete":0,"createTime":"2023-08-09T06:47:57.000+00:00","modifyTime":"2023-08-09T06:47:57.000+00:00","batchId":1,"name":"果Box","sn":"SN234","btMac":"mac","wifiMac":"wifi","firmwareVersion":"1.0","deviceType":0,"onLine":null,"lastOnLineTime":null,"protocolType":0,"runMode":0,"marketMode":0,"otaType":0,"otaStartTime":null,"otaEndTime":null,"factoryTime":"2023-08-09T06:47:57.000+00:00","saleTime":null},"status":200,"timestamp":1691648967274}
2023-14:29:27.289 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$filter$0,58] [babb4f9b-1]- api end time:1691648967289, total time:131
2023-14:29:50.776 [background-preinit] INFO o.h.v.i.util.Version - [<clinit>,21] []- HV000001: Hibernate Validator 6.2.5.Final
2023-14:29:51.592 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStartupProfileInfo,637] []- The following 1 profile is active: "dev"
2023-14:29:51.952 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:29:51.953 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data R2DBC repositories in DEFAULT mode.
2023-14:29:51.959 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 2 ms. Found 0 R2DBC repository interfaces.
2023-14:29:51.967 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [multipleStoresDetected,262] []- Multiple Spring Data modules found, entering strict repository configuration mode
2023-14:29:51.968 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,132] []- Bootstrapping Spring Data Redis repositories in DEFAULT mode.
2023-14:29:51.974 [main] INFO o.s.d.r.c.RepositoryConfigurationDelegate - [registerRepositoriesIn,201] []- Finished Spring Data repository scanning in 0 ms. Found 0 Redis repository interfaces.
2023-14:29:52.074 [main] INFO o.s.c.c.s.GenericScope - [setSerializationId,283] []- BeanFactory id=55b765e8-874f-3936-96a0-683b41b36bc6
2023-14:29:52.149 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$$EnhancerBySpringCGLIB$$1e209f28] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.158 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration' of type [org.springframework.cloud.commons.config.CommonsConfigAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.159 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.159 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'loadBalancerClientsDefaultsMappingsProvider' of type [org.springframework.cloud.client.loadbalancer.LoadBalancerDefaultMappingsProviderAutoConfiguration$$Lambda$427/1267110705] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.160 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'defaultsBindHandlerAdvisor' of type [org.springframework.cloud.commons.config.DefaultsBindHandlerAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.162 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'expressionDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.ExpressionDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.163 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'annotationDataSourceSwitchStrategyMatcher' of type [org.hswebframework.web.datasource.strategy.AnnotationDataSourceSwitchStrategyMatcher] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.164 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'alwaysNoMatchStrategyMatcher' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$1] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.165 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'switcherMethodMatcherPointcutAdvisor' of type [org.hswebframework.web.datasource.AopDataSourceSwitcherAutoConfiguration$SwitcherMethodMatcherPointcutAdvisor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.167 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration' of type [org.hswebframework.web.authorization.simple.DefaultAuthorizationAutoConfiguration$$EnhancerBySpringCGLIB$$78c2cf3a] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.188 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'easyorm-org.hswebframework.web.crud.configuration.EasyormProperties' of type [org.hswebframework.web.crud.configuration.EasyormProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.189 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.EasyormConfiguration' of type [org.hswebframework.web.crud.configuration.EasyormConfiguration$$EnhancerBySpringCGLIB$$47af9e56] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.192 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration' of type [org.hswebframework.web.crud.configuration.R2dbcSqlExecutorConfiguration$$EnhancerBySpringCGLIB$$483cbdc4] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.199 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration' of type [org.springframework.boot.autoconfigure.r2dbc.ConnectionFactoryConfigurations$PoolConfiguration$PooledConnectionFactoryConfiguration] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.201 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'spring.r2dbc-org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties' of type [org.springframework.boot.autoconfigure.r2dbc.R2dbcProperties] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.236 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'connectionFactory' of type [io.r2dbc.pool.ConnectionPool] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.238 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'reactiveSqlExecutor' of type [org.hswebframework.web.crud.sql.DefaultR2dbcExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.301 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'syncSqlExecutor' of type [org.hswebframework.ezorm.rdb.executor.reactive.ReactiveSyncSqlExecutor] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.324 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'databaseMetadata' of type [org.hswebframework.ezorm.rdb.metadata.RDBDatabaseMetadata] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.330 [main] INFO o.s.c.s.PostProcessorRegistrationDelegate$BeanPostProcessorChecker - [postProcessAfterInitialization,376] []- Bean 'org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration' of type [org.hswebframework.web.datasource.DynamicDataSourceAutoConfiguration$$EnhancerBySpringCGLIB$$ecaad92c] is not eligible for getting processed by all BeanPostProcessors (for example: not eligible for auto-proxying)
2023-14:29:52.580 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_en.properties -> messages
2023-14:29:52.581 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/commons/messages_zh.properties -> messages
2023-14:29:52.581 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_en.properties -> messages
2023-14:29:52.581 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/authentication/messages_zh.properties -> messages
2023-14:29:52.581 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_en.properties -> messages
2023-14:29:52.581 [main] INFO o.h.w.s.i.I18nConfiguration - [autoResolveI18nMessageSource,42] []- register i18n message resource i18n/core/messages_zh.properties -> messages
2023-14:29:55.648 [main] INFO o.s.b.w.e.n.NettyWebServer - [start,111] []- Netty started on port 8091
2023-14:29:56.780 [main] INFO c.q.i.a.h.a.IotAdminHttpApiApplication - [logStarted,61] []- Started IotAdminHttpApiApplication in 6.863 seconds (JVM running for 8.186)
2023-14:29:56.782 [main] DEBUG o.h.e.c.m.AbstractSchemaMetadata - [lambda$loadMetadata$2,94] []- load table metadata s_system ,use parser:MysqlTableMetadataParser
2023-14:29:56.863 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [filter,41] [a281b6fe-1]- api start time:1691648996862 ip:192.168.8.246 method:GET url:/demo/device/1 param:{} headers:[Host:"192.168.8.175:8091", User-Agent:"Mozilla/5.0 (Macintosh; Intel Mac OS X 10_15_7) AppleWebKit/537.36 (KHTML, like Gecko) Chrome/115.0.0.0 Safari/537.36 Edg/115.0.1901.200", Accept:"text/html,application/xhtml+xml,application/xml;q=0.9,image/webp,image/apng,*/*;q=0.8,application/signed-exchange;v=b3;q=0.7", Accept-Encoding:"gzip, deflate", Accept-Language:"zh-CN,zh;q=0.9,en;q=0.8,en-GB;q=0.7,en-US;q=0.6", Cache-Control:"max-age=0", Connection:"close", Upgrade-Insecure-Requests:"1"]
2023-14:29:57.044 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [selectMediaType,161] [a281b6fe-1]- [a281b6fe-1] Using 'application/json' given [text/html, application/xhtml+xml, image/webp, image/apng, application/xml;q=0.9, application/signed-exchange;v=b3;q=0.7, */*;q=0.8] and supported [application/json, application/*+json, application/x-ndjson, text/event-stream]
2023-14:29:57.045 [reactor-http-nio-2] DEBUG o.h.w.c.w.ResponseMessageWrapper - [writeBody,174] [a281b6fe-1]- [a281b6fe-1] 0..1 [org.hswebframework.web.crud.web.ResponseMessage<?>]
2023-14:29:57.108 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select count(1) as 'total' from information_schema.`TABLES` where table_schema=? and table_name=?
2023-14:29:57.109 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:57.109 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select count(1) as 'total' from information_schema.`TABLES` where table_schema='qiuguo_iot' and table_name='s_system'
2023-14:29:57.190 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,39] []- ==> Preparing: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = ? and device_info.`id` = ? limit ?,?
2023-14:29:57.190 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,41] []- ==> Parameters: 0(Integer),1(Long),0(Integer),1(Integer)
2023-14:29:57.190 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,43] []- ==> Native: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = 0 and device_info.`id` = 1 limit 0,1
2023-14:29:57.191 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema=? and table_name like ?
2023-14:29:57.192 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:57.192 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select column_name as `name`, data_type as `data_type`, character_maximum_length as `data_length`, numeric_precision as `data_precision`, numeric_scale as `data_scale`, column_comment as `comment`, table_name as `table_name`, case when is_nullable='YES' then 0 else 1 end as 'not_null' from information_schema.columns where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:29:57.236 [reactor-tcp-nio-2] DEBUG o.h.w.s.j.CustomJackson2jsonEncoder - [debug,127] []- [a281b6fe-1] Encoding [org.hswebframework.web.crud.web.ResponseMessage@167fd4ba]
2023-14:29:57.245 [reactor-tcp-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$writeWith$1,100] [a281b6fe-1]- response:{"message":"success","result":{"id":1,"isDelete":0,"createTime":"2023-08-09T06:47:57.000+00:00","modifyTime":"2023-08-09T06:47:57.000+00:00","batchId":1,"name":"果Box","sn":"SN234","btMac":"mac","wifiMac":"wifi","firmwareVersion":"1.0","deviceType":0,"onLine":null,"lastOnLineTime":null,"protocolType":0,"runMode":0,"marketMode":0,"otaType":0,"otaStartTime":null,"otaEndTime":null,"factoryTime":"2023-08-09T06:47:57.000+00:00","saleTime":null},"status":200,"timestamp":1691648997233}
2023-14:29:57.253 [reactor-http-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$filter$0,58] [a281b6fe-1]- api end time:1691648997253, total time:391
2023-14:29:57.277 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema=? and table_name like ?
2023-14:29:57.277 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:57.278 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select table_comment as `comment` ,table_name as `table_name` from information_schema.tables where table_schema='qiuguo_iot' and table_name like 's_system'
2023-14:29:57.342 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = ? and TABLE_NAME like ?
2023-14:29:57.343 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: qiuguo_iot(String),s_system(String)
2023-14:29:57.343 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: SELECT * FROM INFORMATION_SCHEMA.STATISTICS WHERE TABLE_SCHEMA = 'qiuguo_iot' and TABLE_NAME like 's_system'
2023-14:29:57.421 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = ? limit ?,?
2023-14:29:57.421 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: default(String),0(Integer),1(Integer)
2023-14:29:57.421 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: select s_system.`framework_version` as `frameworkVersion` , s_system.`website` as `website` , s_system.`major_version` as `majorVersion` , s_system.`name` as `name` , s_system.`revision_version` as `revisionVersion` , s_system.`comment` as `comment` , s_system.`dependencies` as `dependencies` , s_system.`minor_version` as `minorVersion` from qiuguo_iot.s_system s_system where s_system.`name` = 'default' limit 0,1
2023-14:29:57.585 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,39] []- ==> Preparing: update qiuguo_iot.s_system set `framework_version` = ? , `website` = ? , `major_version` = ? , `name` = ? , `revision_version` = ? , `dependencies` = ? , `minor_version` = ? where `name` = ?
2023-14:29:57.585 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,41] []- ==> Parameters: {"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}(String),(String),1(Integer),default(String),0(Integer),[](String),0(Integer),default(String)
2023-14:29:57.585 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [printSql,43] []- ==> Native: update qiuguo_iot.s_system set `framework_version` = '{"name":"hsweb framework","comment":"","website":"http://www.hsweb.io","majorVersion":4,"minorVersion":0,"revisionVersion":0,"snapshot":true}' , `website` = '' , `major_version` = 1 , `name` = 'default' , `revision_version` = 0 , `dependencies` = '[]' , `minor_version` = 0 where `name` = 'default'
2023-14:29:57.599 [reactor-tcp-nio-2] DEBUG o.h.e.r.e.r.r.R2dbcReactiveSqlExecutor - [lambda$null$7,130] []- ==> Updated: 1
2023-14:30:08.395 [reactor-http-nio-3] INFO c.q.i.a.h.a.f.LogWebFilter - [filter,41] [135e5771-2]- api start time:1691649008395 ip:192.168.8.246 method:GET url:/demo/device/1 param:{} headers:[Host:"192.168.8.175:8091", User-Agent:"Mozilla/5.0 (Macintosh; Intel Mac OS X 10_15_7) AppleWebKit/537.36 (KHTML, like Gecko) Chrome/115.0.0.0 Safari/537.36 Edg/115.0.1901.200", Accept:"text/html,application/xhtml+xml,application/xml;q=0.9,image/webp,image/apng,*/*;q=0.8,application/signed-exchange;v=b3;q=0.7", Accept-Encoding:"gzip, deflate", Accept-Language:"zh-CN,zh;q=0.9,en;q=0.8,en-GB;q=0.7,en-US;q=0.6", Cache-Control:"max-age=0", Connection:"close", Upgrade-Insecure-Requests:"1"]
2023-14:30:08.397 [reactor-http-nio-3] DEBUG o.h.w.c.w.ResponseMessageWrapper - [selectMediaType,161] [135e5771-2]- [135e5771-2] Using 'application/json' given [text/html, application/xhtml+xml, image/webp, image/apng, application/xml;q=0.9, application/signed-exchange;v=b3;q=0.7, */*;q=0.8] and supported [application/json, application/*+json, application/x-ndjson, text/event-stream]
2023-14:30:08.398 [reactor-http-nio-3] DEBUG o.h.w.c.w.ResponseMessageWrapper - [writeBody,174] [135e5771-2]- [135e5771-2] 0..1 [org.hswebframework.web.crud.web.ResponseMessage<?>]
2023-14:30:08.426 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,39] []- ==> Preparing: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = ? and device_info.`id` = ? limit ?,?
2023-14:30:08.426 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,41] []- ==> Parameters: 0(Integer),1(Long),0(Integer),1(Integer)
2023-14:30:08.426 [reactor-tcp-nio-2] DEBUG c.q.i.d.e.d.DeviceInfoEntity - [printSql,43] []- ==> Native: select device_info.`id` as `id` , device_info.`is_delete` as `isDelete` , device_info.`create_time` as `createTime` , device_info.`modify_time` as `modifyTime` , device_info.`batch_id` as `batchId` , device_info.`name` as `name` , device_info.`sn` as `sn` , device_info.`bt_mac` as `btMac` , device_info.`wifi_mac` as `wifiMac` , device_info.`firmware_version` as `firmwareVersion` , device_info.`device_type` as `deviceType` , device_info.`on_line` as `onLine` , device_info.`last_on_line_time` as `lastOnLineTime` , device_info.`protocol_type` as `protocolType` , device_info.`run_mode` as `runMode` , device_info.`market_mode` as `marketMode` , device_info.`ota_type` as `otaType` , device_info.`ota_start_time` as `otaStartTime` , device_info.`ota_end_time` as `otaEndTime` , device_info.`factory_time` as `factoryTime` , device_info.`sale_time` as `saleTime` from qiuguo_iot.device_info device_info where device_info.`is_delete` = 0 and device_info.`id` = 1 limit 0,1
2023-14:30:08.472 [reactor-tcp-nio-2] DEBUG o.h.w.s.j.CustomJackson2jsonEncoder - [debug,127] []- [135e5771-2] Encoding [org.hswebframework.web.crud.web.ResponseMessage@20ceb433]
2023-14:30:08.472 [reactor-tcp-nio-2] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$writeWith$1,100] [135e5771-2]- response:{"message":"success","result":{"id":1,"isDelete":0,"createTime":"2023-08-09T06:47:57.000+00:00","modifyTime":"2023-08-09T06:47:57.000+00:00","batchId":1,"name":"果Box","sn":"SN234","btMac":"mac","wifiMac":"wifi","firmwareVersion":"1.0","deviceType":0,"onLine":null,"lastOnLineTime":null,"protocolType":0,"runMode":0,"marketMode":0,"otaType":0,"otaStartTime":null,"otaEndTime":null,"factoryTime":"2023-08-09T06:47:57.000+00:00","saleTime":null},"status":200,"timestamp":1691649008472}
2023-14:30:08.473 [reactor-http-nio-3] INFO c.q.i.a.h.a.f.LogWebFilter - [lambda$filter$0,58] [135e5771-2]- api end time:1691649008473, total time:78

View File

@ -0,0 +1,93 @@
14:52:39.689 [main] ERROR o.h.w.c.c.AutoDDLProcessor - [lambda$afterPropertiesSet$3,88] []- unsupported feature reactiveSqlExecutor
java.lang.UnsupportedOperationException: unsupported feature reactiveSqlExecutor
at org.hswebframework.ezorm.core.meta.FeatureSupportedMetadata.lambda$findFeatureNow$2(FeatureSupportedMetadata.java:82)
at org.hswebframework.ezorm.core.meta.FeatureSupportedMetadata.getFeatureOrElse(FeatureSupportedMetadata.java:98)
at org.hswebframework.ezorm.core.meta.FeatureSupportedMetadata.findFeatureOrElse(FeatureSupportedMetadata.java:77)
at org.hswebframework.ezorm.core.meta.AbstractSchemaMetadata.findFeatureOrElse(AbstractSchemaMetadata.java:191)
at org.hswebframework.ezorm.core.meta.FeatureSupportedMetadata.findFeatureNow(FeatureSupportedMetadata.java:81)
at org.hswebframework.ezorm.core.meta.FeatureSupportedMetadata.findFeatureNow(FeatureSupportedMetadata.java:65)
at org.hswebframework.ezorm.rdb.operator.ddl.DefaultTableBuilder$1.reactive(DefaultTableBuilder.java:180)
at org.hswebframework.web.crud.configuration.AutoDDLProcessor.lambda$afterPropertiesSet$2(AutoDDLProcessor.java:85)
at reactor.core.publisher.FluxFlatMap$FlatMapMain.onNext(FluxFlatMap.java:386)
at reactor.core.publisher.FluxMapFuseable$MapFuseableSubscriber.onNext(FluxMapFuseable.java:129)
at reactor.core.publisher.FluxPeekFuseable$PeekFuseableSubscriber.onNext(FluxPeekFuseable.java:210)
at reactor.core.publisher.FluxIterable$IterableSubscription.slowPath(FluxIterable.java:335)
at reactor.core.publisher.FluxIterable$IterableSubscription.request(FluxIterable.java:294)
at reactor.core.publisher.FluxPeekFuseable$PeekFuseableSubscriber.request(FluxPeekFuseable.java:144)
at reactor.core.publisher.FluxMapFuseable$MapFuseableSubscriber.request(FluxMapFuseable.java:171)
at reactor.core.publisher.FluxFlatMap$FlatMapMain.onSubscribe(FluxFlatMap.java:371)
at reactor.core.publisher.FluxMapFuseable$MapFuseableSubscriber.onSubscribe(FluxMapFuseable.java:96)
at reactor.core.publisher.FluxPeekFuseable$PeekFuseableSubscriber.onSubscribe(FluxPeekFuseable.java:178)
at reactor.core.publisher.FluxIterable.subscribe(FluxIterable.java:201)
at reactor.core.publisher.FluxIterable.subscribe(FluxIterable.java:83)
at reactor.core.publisher.Mono.subscribe(Mono.java:4490)
at reactor.core.publisher.Mono.block(Mono.java:1765)
at org.hswebframework.web.crud.configuration.AutoDDLProcessor.afterPropertiesSet(AutoDDLProcessor.java:90)
at org.springframework.beans.factory.support.AbstractAutowireCapableBeanFactory.invokeInitMethods(AbstractAutowireCapableBeanFactory.java:1863)
at org.springframework.beans.factory.support.AbstractAutowireCapableBeanFactory.initializeBean(AbstractAutowireCapableBeanFactory.java:1800)
at org.springframework.beans.factory.support.AbstractAutowireCapableBeanFactory.doCreateBean(AbstractAutowireCapableBeanFactory.java:620)
at org.springframework.beans.factory.support.AbstractAutowireCapableBeanFactory.createBean(AbstractAutowireCapableBeanFactory.java:542)
at org.springframework.beans.factory.support.AbstractBeanFactory.lambda$doGetBean$0(AbstractBeanFactory.java:335)
at org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.getSingleton(DefaultSingletonBeanRegistry.java:234)
at org.springframework.beans.factory.support.AbstractBeanFactory.doGetBean(AbstractBeanFactory.java:333)
at org.springframework.beans.factory.support.AbstractBeanFactory.getBean(AbstractBeanFactory.java:208)
at org.springframework.beans.factory.support.DefaultListableBeanFactory.preInstantiateSingletons(DefaultListableBeanFactory.java:955)
at org.springframework.context.support.AbstractApplicationContext.finishBeanFactoryInitialization(AbstractApplicationContext.java:921)
at org.springframework.context.support.AbstractApplicationContext.refresh(AbstractApplicationContext.java:583)
at org.springframework.boot.web.reactive.context.ReactiveWebServerApplicationContext.refresh(ReactiveWebServerApplicationContext.java:66)
at org.springframework.boot.SpringApplication.refresh(SpringApplication.java:731)
at org.springframework.boot.SpringApplication.refreshContext(SpringApplication.java:408)
at org.springframework.boot.SpringApplication.run(SpringApplication.java:307)
at org.springframework.boot.SpringApplication.run(SpringApplication.java:1303)
at org.springframework.boot.SpringApplication.run(SpringApplication.java:1292)
at com.qiuguo.iot.box.websocket.api.IotBoxWebsocketApplication.main(IotBoxWebsocketApplication.java:13)
14:52:39.711 [main] ERROR o.s.b.SpringApplication - [reportFailure,821] []- Application run failed
org.springframework.beans.factory.BeanCreationException: Error creating bean with name 'org.hswebframework.web.crud.configuration.AutoDDLProcessor_1': Invocation of init method failed; nested exception is java.lang.UnsupportedOperationException: unsupported feature reactiveSqlExecutor
at org.springframework.beans.factory.support.AbstractAutowireCapableBeanFactory.initializeBean(AbstractAutowireCapableBeanFactory.java:1804)
at org.springframework.beans.factory.support.AbstractAutowireCapableBeanFactory.doCreateBean(AbstractAutowireCapableBeanFactory.java:620)
at org.springframework.beans.factory.support.AbstractAutowireCapableBeanFactory.createBean(AbstractAutowireCapableBeanFactory.java:542)
at org.springframework.beans.factory.support.AbstractBeanFactory.lambda$doGetBean$0(AbstractBeanFactory.java:335)
at org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.getSingleton(DefaultSingletonBeanRegistry.java:234)
at org.springframework.beans.factory.support.AbstractBeanFactory.doGetBean(AbstractBeanFactory.java:333)
at org.springframework.beans.factory.support.AbstractBeanFactory.getBean(AbstractBeanFactory.java:208)
at org.springframework.beans.factory.support.DefaultListableBeanFactory.preInstantiateSingletons(DefaultListableBeanFactory.java:955)
at org.springframework.context.support.AbstractApplicationContext.finishBeanFactoryInitialization(AbstractApplicationContext.java:921)
at org.springframework.context.support.AbstractApplicationContext.refresh(AbstractApplicationContext.java:583)
at org.springframework.boot.web.reactive.context.ReactiveWebServerApplicationContext.refresh(ReactiveWebServerApplicationContext.java:66)
at org.springframework.boot.SpringApplication.refresh(SpringApplication.java:731)
at org.springframework.boot.SpringApplication.refreshContext(SpringApplication.java:408)
at org.springframework.boot.SpringApplication.run(SpringApplication.java:307)
at org.springframework.boot.SpringApplication.run(SpringApplication.java:1303)
at org.springframework.boot.SpringApplication.run(SpringApplication.java:1292)
at com.qiuguo.iot.box.websocket.api.IotBoxWebsocketApplication.main(IotBoxWebsocketApplication.java:13)
Caused by: java.lang.UnsupportedOperationException: unsupported feature reactiveSqlExecutor
at org.hswebframework.ezorm.core.meta.FeatureSupportedMetadata.lambda$findFeatureNow$2(FeatureSupportedMetadata.java:82)
at org.hswebframework.ezorm.core.meta.FeatureSupportedMetadata.getFeatureOrElse(FeatureSupportedMetadata.java:98)
at org.hswebframework.ezorm.core.meta.FeatureSupportedMetadata.findFeatureOrElse(FeatureSupportedMetadata.java:77)
at org.hswebframework.ezorm.core.meta.AbstractSchemaMetadata.findFeatureOrElse(AbstractSchemaMetadata.java:191)
at org.hswebframework.ezorm.core.meta.FeatureSupportedMetadata.findFeatureNow(FeatureSupportedMetadata.java:81)
at org.hswebframework.ezorm.core.meta.FeatureSupportedMetadata.findFeatureNow(FeatureSupportedMetadata.java:65)
at org.hswebframework.ezorm.rdb.operator.ddl.DefaultTableBuilder$1.reactive(DefaultTableBuilder.java:180)
at org.hswebframework.web.crud.configuration.AutoDDLProcessor.lambda$afterPropertiesSet$2(AutoDDLProcessor.java:85)
at reactor.core.publisher.FluxFlatMap$FlatMapMain.onNext(FluxFlatMap.java:386)
at reactor.core.publisher.FluxMapFuseable$MapFuseableSubscriber.onNext(FluxMapFuseable.java:129)
at reactor.core.publisher.FluxPeekFuseable$PeekFuseableSubscriber.onNext(FluxPeekFuseable.java:210)
at reactor.core.publisher.FluxIterable$IterableSubscription.slowPath(FluxIterable.java:335)
at reactor.core.publisher.FluxIterable$IterableSubscription.request(FluxIterable.java:294)
at reactor.core.publisher.FluxPeekFuseable$PeekFuseableSubscriber.request(FluxPeekFuseable.java:144)
at reactor.core.publisher.FluxMapFuseable$MapFuseableSubscriber.request(FluxMapFuseable.java:171)
at reactor.core.publisher.FluxFlatMap$FlatMapMain.onSubscribe(FluxFlatMap.java:371)
at reactor.core.publisher.FluxMapFuseable$MapFuseableSubscriber.onSubscribe(FluxMapFuseable.java:96)
at reactor.core.publisher.FluxPeekFuseable$PeekFuseableSubscriber.onSubscribe(FluxPeekFuseable.java:178)
at reactor.core.publisher.FluxIterable.subscribe(FluxIterable.java:201)
at reactor.core.publisher.FluxIterable.subscribe(FluxIterable.java:83)
at reactor.core.publisher.Mono.subscribe(Mono.java:4490)
at reactor.core.publisher.Mono.block(Mono.java:1765)
at org.hswebframework.web.crud.configuration.AutoDDLProcessor.afterPropertiesSet(AutoDDLProcessor.java:90)
at org.springframework.beans.factory.support.AbstractAutowireCapableBeanFactory.invokeInitMethods(AbstractAutowireCapableBeanFactory.java:1863)
at org.springframework.beans.factory.support.AbstractAutowireCapableBeanFactory.initializeBean(AbstractAutowireCapableBeanFactory.java:1800)
... 16 common frames omitted
Suppressed: java.lang.Exception: #block terminated with an error
at reactor.core.publisher.BlockingSingleSubscriber.blockingGet(BlockingSingleSubscriber.java:141)
at reactor.core.publisher.Mono.block(Mono.java:1766)
... 19 common frames omitted

File diff suppressed because it is too large Load Diff

File diff suppressed because it is too large Load Diff

File diff suppressed because it is too large Load Diff

File diff suppressed because it is too large Load Diff