Re: [PR] Pipe: Support `"source.history.loose-range" = "path"` in iotdb-source [iotdb]

2024-06-12 Thread via GitHub


SteveYurongSu merged PR #12651:
URL: https://github.com/apache/iotdb/pull/12651


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] ISSUE#12499 Reject query with massive time span in limited memroy [iotdb]

2024-06-12 Thread via GitHub


ycycse opened a new pull request, #12725:
URL: https://github.com/apache/iotdb/pull/12725

   When querying with GROUP BY, if endTime is massive will result in huge 
number of time slots leading to Java Heap Space (see in #12499)
   This PR  would reject the query which may lead to above problems in advance 
to avoid system crash.
   Relating document: 
https://apache-iotdb.feishu.cn/docx/IMUWdQZ4CounhEx5Z2UcdXzGnAe


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Pipe: Fixed the bug that schema events can not report & delete data event may fail to mark at schema metrics [iotdb]

2024-06-12 Thread via GitHub


SteveYurongSu merged PR #12722:
URL: https://github.com/apache/iotdb/pull/12722


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] 1、修改了apache官网底部版权信息 2、修改“安装包获取文件名(IoTDB-Get ->IoTDB-Package) 3、修改“资源优化”内容 [iotdb-docs]

2024-06-12 Thread via GitHub


qiaojialin merged PR #245:
URL: https://github.com/apache/iotdb-docs/pull/245


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] Subscription: adapt pipe completion signal for automatically drop subscription [iotdb]

2024-06-12 Thread via GitHub


VGalaxies opened a new pull request, #12724:
URL: https://github.com/apache/iotdb/pull/12724

   reopen #12647...


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Subscription: adapt pipe completion signal for automatically drop subscription [iotdb]

2024-06-12 Thread via GitHub


VGalaxies closed pull request #12647: Subscription: adapt pipe completion 
signal for automatically drop subscription
URL: https://github.com/apache/iotdb/pull/12647


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] PipeConsensus: add metrics and fix some bugs for pipeConsensus [iotdb]

2024-06-12 Thread via GitHub


Pengzna commented on code in PR #12723:
URL: https://github.com/apache/iotdb/pull/12723#discussion_r1636310198


##
iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/service/metric/enums/Metric.java:
##
@@ -53,6 +53,10 @@ public enum Metric {
   // consensus related
   STAGE("stage"),
   IOT_CONSENSUS("iot_consensus"),
+  PIPE_CONSENSUS("pipe_consensus"),

Review Comment:
   fixed



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] PipeConsensus: add metrics and fix some bugs for pipeConsensus [iotdb]

2024-06-12 Thread via GitHub


Pengzna commented on code in PR #12723:
URL: https://github.com/apache/iotdb/pull/12723#discussion_r1636310896


##
iotdb-core/consensus/src/main/java/org/apache/iotdb/consensus/pipe/PipeConsensusServerImpl.java:
##
@@ -129,6 +136,7 @@ public PipeConsensusServerImpl(
 
   public synchronized void start(boolean startConsensusPipes) throws 
IOException {
 stateMachine.start();
+MetricService.getInstance().addMetricSet(this.pipeConsensusServerMetrics);

Review Comment:
   fixed



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] PipeConsensus: add metrics and fix some bugs for pipeConsensus [iotdb]

2024-06-12 Thread via GitHub


Pengzna commented on code in PR #12723:
URL: https://github.com/apache/iotdb/pull/12723#discussion_r1636308725


##
iotdb-core/consensus/src/main/java/org/apache/iotdb/consensus/pipe/consensuspipe/ConsensusPipeConnector.java:
##
@@ -0,0 +1,25 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+package org.apache.iotdb.consensus.pipe.consensuspipe;
+
+public interface ConsensusPipeConnector {

Review Comment:
   Maybe sender?



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] 1、修改了apache官网底部版权信息 2、修改“安装包获取文件名(IoTDB-Get ->IoTDB-Package) 3、修改“资源优化”内容 [iotdb-docs]

2024-06-12 Thread via GitHub


StefanieZhao7 commented on code in PR #245:
URL: https://github.com/apache/iotdb-docs/pull/245#discussion_r1636185062


##
src/.vuepress/sidebar_timecho/V1.3.x/zh.ts:
##
@@ -66,6 +66,8 @@ export const zhSidebar = {
   prefix: 'Deployment-and-Maintenance/',
   // children: 'structure',
   children: [
+{ text: '安装包获取', link: 'IoTDB-Get_timecho' },

Review Comment:
   文件名没改



##
src/.vuepress/sidebar_timecho/V1.3.x/en.ts:
##
@@ -66,6 +66,8 @@ export const enSidebar = {
   prefix: 'Deployment-and-Maintenance/',
   // children: 'structure',
   children: [
+{ text: 'Package acquisition', link: 'IoTDB-Package' },
+{ text: 'Resource-Plan', link: 'Resource-Plan' },

Review Comment:
   资源规划:Database Resources



##
src/.vuepress/sidebar_timecho/V1.3.x/zh.ts:
##
@@ -66,6 +66,8 @@ export const zhSidebar = {
   prefix: 'Deployment-and-Maintenance/',
   // children: 'structure',
   children: [
+{ text: '安装包获取', link: 'IoTDB-Get_timecho' },

Review Comment:
   缺少英文版sidebar



##
src/UserGuide/Master/Deployment-and-Maintenance/IoTDB-Package_timecho.md:
##
@@ -0,0 +1,42 @@
+
+# IoTDB-Package
+## TimechoDB version acquisition method

Review Comment:
   How to obtain TimechoDB



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Subscription: improve parsing logic when using JAVA SDK client & refactor subscription IT & intro `getSubscribedTopicNames` API [iotdb]

2024-06-12 Thread via GitHub


SteveYurongSu merged PR #12721:
URL: https://github.com/apache/iotdb/pull/12721


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] PipeConsensus: add metrics and fix some bugs for pipeConsensus [iotdb]

2024-06-12 Thread via GitHub


Caideyipi commented on code in PR #12723:
URL: https://github.com/apache/iotdb/pull/12723#discussion_r1636190217


##
iotdb-core/consensus/src/main/java/org/apache/iotdb/consensus/pipe/PipeConsensusServerImpl.java:
##
@@ -274,21 +282,45 @@ public synchronized void 
checkConsensusPipe(Map e
 
   public TSStatus write(IConsensusRequest request) {
 try {
+  long consensusWriteStartTime = System.nanoTime();
   stateMachineLock.lock();
+  long getStateMachineLockTime = System.nanoTime();
+  // statistic the time of acquiring stateMachine lock
+  pipeConsensusServerMetrics.recordGetStateMachineLockTime(
+  getStateMachineLockTime - consensusWriteStartTime);
   if (request instanceof ComparableConsensusRequest) {
 ((ComparableConsensusRequest) request)
 
.setProgressIndex(progressIndexManager.assignProgressIndex(thisNode.getGroupId()));
   }
-  return stateMachine.write(request);
+
+  long writeToStateMachineStartTime = System.nanoTime();
+  TSStatus result = stateMachine.write(request);
+  long writeToStateMachineEndTime = System.nanoTime();
+  // statistic the time of writing request into stateMachine
+  pipeConsensusServerMetrics.recordWriteStateMachineTime(
+  writeToStateMachineEndTime - writeToStateMachineStartTime);
+  return result;
 } finally {
   stateMachineLock.unlock();
 }
   }
 
   public TSStatus writeOnFollowerReplica(IConsensusRequest request) {
 try {
+  long consensusWriteStartTime = System.nanoTime();
   stateMachineLock.lock();
-  return stateMachine.write(request);
+  long getStateMachineLockTime = System.nanoTime();
+  // statistic the time of acquiring stateMachine lock
+  pipeConsensusServerMetrics.recordGetStateMachineLockTime(
+  getStateMachineLockTime - consensusWriteStartTime);
+
+  long writeToStateMachineStartTime = System.nanoTime();
+  TSStatus result = stateMachine.write(request);
+  long writeToStateMachineEndTime = System.nanoTime();
+  // statistic the time of writing request into stateMachine
+  pipeConsensusServerMetrics.recordWriteStateMachineTime(

Review Comment:
   Same as above.



##
iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/service/metric/enums/Metric.java:
##
@@ -53,6 +53,10 @@ public enum Metric {
   // consensus related
   STAGE("stage"),
   IOT_CONSENSUS("iot_consensus"),
+  PIPE_CONSENSUS("pipe_consensus"),

Review Comment:
   Better place these after "IOT_RECEIVE_LOG"



##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/connector/protocol/pipeconsensus/PipeConsensusAsyncConnector.java:
##
@@ -521,4 +551,25 @@ public int getTransferBufferSize() {
   public int getRetryBufferSize() {
 return retryEventQueue.size();
   }
+
+  @Override
+  public long getLocalUserWriteProgress() {
+PipeStaticMeta staticMeta = 
PipeAgent.task().getPipeStaticMeta(consensusPipeName);

Review Comment:
   Better not expose the "staticMeta" in PipeDataNodeTaskAgent only... There 
may be potential altering to it. It's better to add a "getCreationTime" in it.



##
iotdb-core/consensus/src/main/java/org/apache/iotdb/consensus/pipe/consensuspipe/ConsensusPipeConnector.java:
##
@@ -0,0 +1,25 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+package org.apache.iotdb.consensus.pipe.consensuspipe;
+
+public interface ConsensusPipeConnector {

Review Comment:
   Better not use "connector" since it's a component of pipe.. A better name 
may be "reporter"...



##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/pipe/connector/protocol/pipeconsensus/PipeConsensusAsyncConnector.java:
##
@@ -478,6 +500,13 @@ public synchronized void clearRetryEventsReferenceCount() {
 }
   }
 
+  public synchronized void clearTransferBufferReferenceCount() {

Review Comment:
   There may still be some events added into the "transferBuffer" even if this 
function has finished.. Can use "synchronized" or the similar handling logic to 
"addFailureEventToRetryQueue".



##

Re: [PR] load-tsfile script: disable redirection & load: handle exceptions using the Analysis objects instead of throwing exceptions & pipe: handle SYSTEM_READ_ONLY correctly on receiver side [iotdb]

2024-06-12 Thread via GitHub


SteveYurongSu merged PR #12716:
URL: https://github.com/apache/iotdb/pull/12716


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Support WAL Compression [iotdb]

2024-06-12 Thread via GitHub


jt2594838 commented on code in PR #12476:
URL: https://github.com/apache/iotdb/pull/12476#discussion_r1636207336


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/wal/io/WALInputStream.java:
##
@@ -190,33 +204,43 @@ private void loadNextSegmentV1() throws IOException {
   }
 
   private void loadNextSegmentV2() throws IOException {
-headerBuffer.clear();
-if (channel.read(headerBuffer) != Integer.BYTES + 1) {
-  throw new IOException("Unexpected end of file");
-}
-// compressionType originalSize compressedSize
-headerBuffer.flip();
-CompressionType compressionType = 
CompressionType.deserialize(headerBuffer.get());
-int dataBufferSize = headerBuffer.getInt();
-if (compressionType != CompressionType.UNCOMPRESSED) {
-  compressedHeader.clear();
-  if (channel.read(compressedHeader) != Integer.BYTES) {
-throw new IOException("Unexpected end of file");
+SegmentInfo segmentInfo = getNextSegmentInfo();
+if (segmentInfo.compressionType != CompressionType.UNCOMPRESSED) {
+  // A compressed segment
+  if (Objects.isNull(dataBuffer)
+  || dataBuffer.capacity() < segmentInfo.uncompressedSize
+  || dataBuffer.capacity() > segmentInfo.uncompressedSize * 2) {
+dataBuffer = ByteBuffer.allocateDirect(segmentInfo.uncompressedSize);

Review Comment:
   If the previous buffer is not null, it should be manually released through 
`MmapUtil.clean`—the same for the below.



##
iotdb-core/datanode/src/test/java/org/apache/iotdb/db/storageengine/dataregion/wal/compression/WALCompressionTest.java:
##
@@ -18,37 +18,392 @@
  */
 package org.apache.iotdb.db.storageengine.dataregion.wal.compression;
 
+import org.apache.iotdb.commons.exception.IllegalPathException;
+import org.apache.iotdb.db.conf.IoTDBDescriptor;
+import org.apache.iotdb.db.exception.query.QueryProcessException;
+import 
org.apache.iotdb.db.queryengine.plan.planner.plan.node.write.InsertRowNode;
+import org.apache.iotdb.db.storageengine.dataregion.wal.WALTestUtils;
+import org.apache.iotdb.db.storageengine.dataregion.wal.buffer.WALBuffer;
+import org.apache.iotdb.db.storageengine.dataregion.wal.buffer.WALEntry;
+import org.apache.iotdb.db.storageengine.dataregion.wal.buffer.WALEntryType;
+import org.apache.iotdb.db.storageengine.dataregion.wal.buffer.WALInfoEntry;
+import org.apache.iotdb.db.storageengine.dataregion.wal.buffer.WALSignalEntry;
+import org.apache.iotdb.db.storageengine.dataregion.wal.io.LogWriter;
+import org.apache.iotdb.db.storageengine.dataregion.wal.io.WALByteBufReader;
+import org.apache.iotdb.db.storageengine.dataregion.wal.io.WALInputStream;
+import org.apache.iotdb.db.storageengine.dataregion.wal.io.WALReader;
+import org.apache.iotdb.db.storageengine.dataregion.wal.io.WALWriter;
 import org.apache.iotdb.db.storageengine.dataregion.wal.utils.WALFileStatus;
 import org.apache.iotdb.db.storageengine.dataregion.wal.utils.WALFileUtils;
 import org.apache.iotdb.db.utils.constant.TestConstant;
 
+import org.apache.commons.io.FileUtils;
+import org.apache.tsfile.compress.ICompressor;
+import org.apache.tsfile.compress.IUnCompressor;
+import org.apache.tsfile.file.metadata.enums.CompressionType;
+import org.apache.tsfile.utils.Pair;
+import org.apache.tsfile.utils.PublicBAOS;
 import org.junit.After;
+import org.junit.Assert;
 import org.junit.Before;
+import org.junit.Test;
 
+import java.io.BufferedInputStream;
+import java.io.DataInputStream;
+import java.io.DataOutputStream;
 import java.io.File;
 import java.io.IOException;
+import java.nio.ByteBuffer;
 import java.nio.file.Files;
+import java.util.ArrayList;
+import java.util.List;
 
 public class WALCompressionTest {
   private final File walFile =
   new File(
   TestConstant.BASE_OUTPUT_PATH.concat(
   WALFileUtils.getLogFileName(0, 0, 
WALFileStatus.CONTAINS_SEARCH_INDEX)));
 
+  private final String compressionDir =
+  TestConstant.OUTPUT_DATA_DIR.concat(File.separator + "wal-compression");
+
+  private final String devicePath = "root.sg.d1";
+  long originalMinCompressionSize;
+  CompressionType originCompressionType =
+  IoTDBDescriptor.getInstance().getConfig().getWALCompressionAlgorithm();
+
   @Before
-  public void setUp() throws IOException {
-if (walFile.getParentFile().exists()) {
-  Files.delete(walFile.getParentFile().toPath());
+  public void setUp()
+  throws IOException, NoSuchFieldException, ClassNotFoundException, 
IllegalAccessException {
+if (walFile.exists()) {
+  FileUtils.delete(walFile);
+}
+originalMinCompressionSize = WALTestUtils.getMinCompressionSize();
+if (new File(compressionDir).exists()) {
+  FileUtils.forceDelete(new File(compressionDir));
 }
-Files.createDirectory(walFile.getParentFile().toPath());
   }
 
   @After
-  public void tearDown() throws IOException {
-if (walFile.getParentFile().exists()) {
-  

Re: [PR] Support WAL Compression [iotdb]

2024-06-12 Thread via GitHub


jt2594838 commented on code in PR #12476:
URL: https://github.com/apache/iotdb/pull/12476#discussion_r1636200265


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/wal/io/WALInputStream.java:
##
@@ -250,10 +250,14 @@ public void skipToGivenPosition(long pos) throws 
IOException {
 buffer.clear();
 channel.read(buffer);
 buffer.flip();
-buffer.get();
+CompressionType type = CompressionType.deserialize(buffer.get());
 currSegmentSize = buffer.getInt();
 if (posRemain >= currSegmentSize) {
   posRemain -= currSegmentSize;
+  channel.position(
+  channel.position()
+  + currSegmentSize
+  + (type == CompressionType.UNCOMPRESSED ? 0 : 
Integer.BYTES));

Review Comment:
   This should be clarified by comments or better variable names; try it.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Replenish effective mode in iotdb-system.properties [iotdb]

2024-06-12 Thread via GitHub


OneSizeFitsQuorum merged PR #12706:
URL: https://github.com/apache/iotdb/pull/12706


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Support WAL Compression [iotdb]

2024-06-12 Thread via GitHub


jt2594838 commented on code in PR #12476:
URL: https://github.com/apache/iotdb/pull/12476#discussion_r1636194330


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/wal/utils/WALEntryPosition.java:
##
@@ -100,11 +101,11 @@ ByteBuffer read() throws IOException {
 if (!canRead()) {
   throw new IOException("Target file hasn't been specified.");
 }
-try (FileChannel channel = openReadFileChannel()) {
+try (WALInputStream is = openReadFileStream()) {
+  is.skipToGivenPosition(position);
   ByteBuffer buffer = ByteBuffer.allocate(size);
-  channel.position(position);
-  channel.read(buffer);
-  buffer.clear();
+  is.read(buffer);
+  buffer.flip();
   return buffer;
 }

Review Comment:
   Just leave a TODO here, then.



##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/wal/utils/WALEntryPosition.java:
##
@@ -135,6 +136,26 @@ public FileChannel openReadFileChannel() throws 
IOException {
 }
   }
 
+  public WALInputStream openReadFileStream() throws IOException {
+if (isInSealedFile()) {
+  walFile = walNode.getWALFile(walFileVersionId);
+  return new WALInputStream(walFile);
+} else {
+  try {
+walFile = walNode.getWALFile(walFileVersionId);
+return new WALInputStream(walFile);
+  } catch (IOException e) {
+// unsealed file may be renamed after sealed, so we should try again
+if (isInSealedFile()) {
+  walFile = walNode.getWALFile(walFileVersionId);
+  return new WALInputStream(walFile);
+} else {
+  throw e;
+}
+  }
+}

Review Comment:
   Just leave a TODO here, then.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Support WAL Compression [iotdb]

2024-06-12 Thread via GitHub


jt2594838 commented on code in PR #12476:
URL: https://github.com/apache/iotdb/pull/12476#discussion_r1636194330


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/wal/utils/WALEntryPosition.java:
##
@@ -100,11 +101,11 @@ ByteBuffer read() throws IOException {
 if (!canRead()) {
   throw new IOException("Target file hasn't been specified.");
 }
-try (FileChannel channel = openReadFileChannel()) {
+try (WALInputStream is = openReadFileStream()) {
+  is.skipToGivenPosition(position);
   ByteBuffer buffer = ByteBuffer.allocate(size);
-  channel.position(position);
-  channel.read(buffer);
-  buffer.clear();
+  is.read(buffer);
+  buffer.flip();
   return buffer;
 }

Review Comment:
   Just leave a TODO here.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Support WAL Compression [iotdb]

2024-06-12 Thread via GitHub


jt2594838 commented on code in PR #12476:
URL: https://github.com/apache/iotdb/pull/12476#discussion_r1636186517


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/wal/io/WALInputStream.java:
##
@@ -0,0 +1,284 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+package org.apache.iotdb.db.storageengine.dataregion.wal.io;
+
+import org.apache.tsfile.compress.IUnCompressor;
+import org.apache.tsfile.file.metadata.enums.CompressionType;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import java.io.File;
+import java.io.IOException;
+import java.io.InputStream;
+import java.nio.ByteBuffer;
+import java.nio.channels.FileChannel;
+import java.util.Objects;
+
+public class WALInputStream extends InputStream implements AutoCloseable {
+
+  private static final Logger logger = 
LoggerFactory.getLogger(WALInputStream.class);
+  private final FileChannel channel;
+  private final ByteBuffer headerBuffer = ByteBuffer.allocate(Integer.BYTES + 
1);
+  private final ByteBuffer compressedHeader = 
ByteBuffer.allocate(Integer.BYTES);
+  private ByteBuffer dataBuffer = null;
+  private long fileSize;
+  File logFile;
+  private long endOffset = -1;
+
+  enum FileVersion {
+V1,
+V2,
+UNKNOWN
+  };
+
+  FileVersion version;
+
+  public WALInputStream(File logFile) throws IOException {
+channel = FileChannel.open(logFile.toPath());
+fileSize = channel.size();
+analyzeFileVersion();
+getEndOffset();
+this.logFile = logFile;
+  }
+
+  private void getEndOffset() throws IOException {
+if (channel.size() < WALWriter.MAGIC_STRING_BYTES + Integer.BYTES) {
+  endOffset = channel.size();
+  return;
+}
+ByteBuffer metadataSizeBuf = ByteBuffer.allocate(Integer.BYTES);
+long position;
+try {
+  if (version == FileVersion.V2) {
+ByteBuffer magicStringBuffer = 
ByteBuffer.allocate(WALWriter.MAGIC_STRING_BYTES);
+channel.read(magicStringBuffer, channel.size() - 
WALWriter.MAGIC_STRING_BYTES);
+magicStringBuffer.flip();
+if (!new 
String(magicStringBuffer.array()).equals(WALWriter.MAGIC_STRING)) {
+  // this is a broken wal file
+  endOffset = channel.size();
+  return;
+}
+position = channel.size() - WALWriter.MAGIC_STRING_BYTES - 
Integer.BYTES;
+  } else {
+ByteBuffer magicStringBuffer =
+ByteBuffer.allocate(WALWriter.MAGIC_STRING_V1.getBytes().length);
+channel.read(
+magicStringBuffer, channel.size() - 
WALWriter.MAGIC_STRING_V1.getBytes().length);
+magicStringBuffer.flip();
+if (!new 
String(magicStringBuffer.array()).equals(WALWriter.MAGIC_STRING_V1)) {
+  // this is a broken wal file
+  endOffset = channel.size();
+  return;
+}
+position = channel.size() - 
WALWriter.MAGIC_STRING_V1.getBytes().length - Integer.BYTES;
+  }
+  channel.read(metadataSizeBuf, position);
+  metadataSizeBuf.flip();
+  int metadataSize = metadataSizeBuf.getInt();
+  endOffset = channel.size() - WALWriter.MAGIC_STRING_BYTES - 
Integer.BYTES - metadataSize - 1;
+} finally {
+  channel.position(WALWriter.MAGIC_STRING_BYTES);
+}
+  }
+
+  private void analyzeFileVersion() throws IOException {
+if (channel.size() < WALWriter.MAGIC_STRING_BYTES) {
+  version = FileVersion.UNKNOWN;
+  return;
+}
+if (isCurrentVersion()) {
+  this.version = FileVersion.V2;
+  return;
+}
+this.version = FileVersion.V1;
+  }
+
+  private boolean isCurrentVersion() throws IOException {
+channel.position(0);
+ByteBuffer buffer = ByteBuffer.allocate(WALWriter.MAGIC_STRING_BYTES);
+channel.read(buffer);
+return new String(buffer.array()).equals(WALWriter.MAGIC_STRING);

Review Comment:
   We have already encountered bugs due to inconsistent default String 
encodings when recovering TsFileResource. The same issue should be avoided here.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: 

Re: [PR] Support WAL Compression [iotdb]

2024-06-12 Thread via GitHub


jt2594838 commented on code in PR #12476:
URL: https://github.com/apache/iotdb/pull/12476#discussion_r1636185249


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/wal/io/WALByteBufReader.java:
##
@@ -64,8 +67,12 @@ public boolean hasNext() {
   public ByteBuffer next() throws IOException {
 int size = sizeIterator.next();
 ByteBuffer buffer = ByteBuffer.allocate(size);

Review Comment:
   Just adding a TODO here is enough.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Support WAL Compression [iotdb]

2024-06-12 Thread via GitHub


jt2594838 commented on code in PR #12476:
URL: https://github.com/apache/iotdb/pull/12476#discussion_r1636184029


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/storageengine/dataregion/wal/buffer/WALBuffer.java:
##
@@ -535,12 +535,13 @@ public void run() {
   memTableIdsOfWal
   .computeIfAbsent(currentWALFileVersion, memTableIds -> new 
HashSet<>())
   .addAll(info.metaData.getMemTablesId());
-  
checkpointManager.updateCostOfActiveMemTables(info.memTableId2WalDiskUsage);
+  
checkpointManager.updateCostOfActiveMemTables(info.memTableId2WalDiskUsage, 
compressionRate);
 
   boolean forceSuccess = false;
   // try to roll log writer
   if (info.rollWALFileWriterListener != null
-  || (forceFlag && currentWALFileWriter.size() >= 
config.getWalFileSizeThresholdInByte())) {
+  || (forceFlag
+  && currentWALFileWriter.originalSize() >= 
config.getWalFileSizeThresholdInByte())) {

Review Comment:
   Ok, then, please leave a TODO here.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [I] 分组查询时,时间跨度过大会导致服务器崩溃 [iotdb]

2024-06-12 Thread via GitHub


ycycse commented on issue #12499:
URL: https://github.com/apache/iotdb/issues/12499#issuecomment-2162526996

   Hi, for each time period, a corresponding TTimePartitionSlot object is 
generated. When too many objects occupy memory, there will be an issue of 
insufficient JVM memory. I can add a memory check at the planning stage to 
avoid this problem.
   
![image](https://github.com/apache/iotdb/assets/51467236/fc984716-5e80-49d9-b983-f0febfa2e9b5)
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] Pipe: Fixed the bug that schema events can not report & delete data event may fail to bind [iotdb]

2024-06-12 Thread via GitHub


Caideyipi opened a new pull request, #12722:
URL: https://github.com/apache/iotdb/pull/12722

   ## Description
   As the title said.
   
   
   
   
   
   
   
   
   
   
   
   
   This PR has:
   - [ ] been self-reviewed.
   - [ ] concurrent read
   - [ ] concurrent write
   - [ ] concurrent read and write 
   - [ ] added documentation for new or modified features or behaviors.
   - [ ] added Javadocs for most classes and all non-trivial methods. 
   - [ ] added or updated version, __license__, or notice information
   - [ ] added comments explaining the "why" and the intent of the code 
wherever would not be obvious 
 for an unfamiliar reader.
   - [ ] added unit tests or modified existing tests to cover new code paths, 
ensuring the threshold 
 for code coverage.
   - [ ] added integration tests.
   - [ ] been tested in a test IoTDB cluster.
   
   
   
   
   
   # Key changed/added classes (or packages if there are too many classes) 
in this PR
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Fix memory calculate error when insertRecords with both aligned and non-aligned devices [iotdb]

2024-06-12 Thread via GitHub


codecov[bot] commented on PR #12720:
URL: https://github.com/apache/iotdb/pull/12720#issuecomment-2162474432

   ## 
[Codecov](https://app.codecov.io/gh/apache/iotdb/pull/12720?dropdown=coverage=pr=h1_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 Report
   Attention: Patch coverage is `94.38202%` with `5 lines` in your changes 
missing coverage. Please review.
   > Project coverage is 42.09%. Comparing base 
[(`a9d1401`)](https://app.codecov.io/gh/apache/iotdb/commit/a9d1401881231ed2e6fe6482b48c829b2237d5c6?dropdown=coverage=desc_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 to head 
[(`459db93`)](https://app.codecov.io/gh/apache/iotdb/commit/459db93fa925af74bc189bdf59729be02406d988?dropdown=coverage=desc_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   > Report is 4 commits behind head on master.
   
   | 
[Files](https://app.codecov.io/gh/apache/iotdb/pull/12720?dropdown=coverage=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 | Patch % | Lines |
   |---|---|---|
   | 
[...ageengine/dataregion/memtable/TsFileProcessor.java](https://app.codecov.io/gh/apache/iotdb/pull/12720?src=pr=tree=iotdb-core%2Fdatanode%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fiotdb%2Fdb%2Fstorageengine%2Fdataregion%2Fmemtable%2FTsFileProcessor.java_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache#diff-aW90ZGItY29yZS9kYXRhbm9kZS9zcmMvbWFpbi9qYXZhL29yZy9hcGFjaGUvaW90ZGIvZGIvc3RvcmFnZWVuZ2luZS9kYXRhcmVnaW9uL21lbXRhYmxlL1RzRmlsZVByb2Nlc3Nvci5qYXZh)
 | 94.38% | [5 Missing :warning: 
](https://app.codecov.io/gh/apache/iotdb/pull/12720?src=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 |
   
   Additional details and impacted files
   
   
   ```diff
   @@ Coverage Diff  @@
   ## master   #12720  +/-   ##
   
   - Coverage 42.09%   42.09%   -0.01% 
 Complexity   71   71  
   
 Files  3260 3260  
 Lines205703   205709   +6 
 Branches  2452524524   -1 
   
   - Hits  8659986592   -7 
   - Misses   119104   119117  +13 
   ```
   
   
   
   
   
   [:umbrella: View full report in Codecov by 
Sentry](https://app.codecov.io/gh/apache/iotdb/pull/12720?dropdown=coverage=pr=continue_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   
   :loudspeaker: Have feedback on the report? [Share it 
here](https://about.codecov.io/codecov-pr-comment-feedback/?utm_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] load-tsfile script: disable redirection & load: handle exceptions using the Analysis objects instead of throwing exceptions [iotdb]

2024-06-12 Thread via GitHub


codecov[bot] commented on PR #12716:
URL: https://github.com/apache/iotdb/pull/12716#issuecomment-2162460079

   ## 
[Codecov](https://app.codecov.io/gh/apache/iotdb/pull/12716?dropdown=coverage=pr=h1_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 Report
   Attention: Patch coverage is `3.92157%` with `49 lines` in your changes 
missing coverage. Please review.
   > Project coverage is 42.09%. Comparing base 
[(`ab9347b`)](https://app.codecov.io/gh/apache/iotdb/commit/ab9347bfde9053d574466303f298273ecd1cb5b8?dropdown=coverage=desc_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 to head 
[(`c538fe1`)](https://app.codecov.io/gh/apache/iotdb/commit/c538fe1eb221f3ac7b5ddcb12057a9821fe29621?dropdown=coverage=desc_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   > Report is 11 commits behind head on master.
   
   | 
[Files](https://app.codecov.io/gh/apache/iotdb/pull/12716?dropdown=coverage=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 | Patch % | Lines |
   |---|---|---|
   | 
[...b/queryengine/plan/analyze/LoadTsfileAnalyzer.java](https://app.codecov.io/gh/apache/iotdb/pull/12716?src=pr=tree=iotdb-core%2Fdatanode%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fiotdb%2Fdb%2Fqueryengine%2Fplan%2Fanalyze%2FLoadTsfileAnalyzer.java_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache#diff-aW90ZGItY29yZS9kYXRhbm9kZS9zcmMvbWFpbi9qYXZhL29yZy9hcGFjaGUvaW90ZGIvZGIvcXVlcnllbmdpbmUvcGxhbi9hbmFseXplL0xvYWRUc2ZpbGVBbmFseXplci5qYXZh)
 | 0.00% | [17 Missing :warning: 
](https://app.codecov.io/gh/apache/iotdb/pull/12716?src=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 |
   | 
[...receiver/visitor/PipeStatementTSStatusVisitor.java](https://app.codecov.io/gh/apache/iotdb/pull/12716?src=pr=tree=iotdb-core%2Fdatanode%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fiotdb%2Fdb%2Fpipe%2Freceiver%2Fvisitor%2FPipeStatementTSStatusVisitor.java_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache#diff-aW90ZGItY29yZS9kYXRhbm9kZS9zcmMvbWFpbi9qYXZhL29yZy9hcGFjaGUvaW90ZGIvZGIvcGlwZS9yZWNlaXZlci92aXNpdG9yL1BpcGVTdGF0ZW1lbnRUU1N0YXR1c1Zpc2l0b3IuamF2YQ==)
 | 0.00% | [13 Missing :warning: 
](https://app.codecov.io/gh/apache/iotdb/pull/12716?src=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 |
   | 
[...db/db/queryengine/plan/analyze/AnalyzeVisitor.java](https://app.codecov.io/gh/apache/iotdb/pull/12716?src=pr=tree=iotdb-core%2Fdatanode%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fiotdb%2Fdb%2Fqueryengine%2Fplan%2Fanalyze%2FAnalyzeVisitor.java_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache#diff-aW90ZGItY29yZS9kYXRhbm9kZS9zcmMvbWFpbi9qYXZhL29yZy9hcGFjaGUvaW90ZGIvZGIvcXVlcnllbmdpbmUvcGxhbi9hbmFseXplL0FuYWx5emVWaXNpdG9yLmphdmE=)
 | 0.00% | [10 Missing :warning: 
](https://app.codecov.io/gh/apache/iotdb/pull/12716?src=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 |
   | 
[...ueryengine/plan/planner/LocalExecutionPlanner.java](https://app.codecov.io/gh/apache/iotdb/pull/12716?src=pr=tree=iotdb-core%2Fdatanode%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fiotdb%2Fdb%2Fqueryengine%2Fplan%2Fplanner%2FLocalExecutionPlanner.java_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache#diff-aW90ZGItY29yZS9kYXRhbm9kZS9zcmMvbWFpbi9qYXZhL29yZy9hcGFjaGUvaW90ZGIvZGIvcXVlcnllbmdpbmUvcGxhbi9wbGFubmVyL0xvY2FsRXhlY3V0aW9uUGxhbm5lci5qYXZh)
 | 33.33% | [4 Missing :warning: 
](https://app.codecov.io/gh/apache/iotdb/pull/12716?src=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 |
   | 
[.../main/java/org/apache/iotdb/tool/ImportTsFile.java](https://app.codecov.io/gh/apache/iotdb/pull/12716?src=pr=tree=iotdb-client%2Fcli%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fiotdb%2Ftool%2FImportTsFile.java_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache#diff-aW90ZGItY2xpZW50L2NsaS9zcmMvbWFpbi9qYXZhL29yZy9hcGFjaGUvaW90ZGIvdG9vbC9JbXBvcnRUc0ZpbGUuamF2YQ==)
 | 0.00% | [2 Missing :warning: 
](https://app.codecov.io/gh/apache/iotdb/pull/12716?src=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 |
   | 
[...b/db/queryengine/load/LoadTsFileMemoryManager.java](https://app.codecov.io/gh/apache/iotdb/pull/12716?src=pr=tree=iotdb-core%2Fdatanode%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fiotdb%2Fdb%2Fqueryengine%2Fload%2FLoadTsFileMemoryManager.java_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache#diff-aW90ZGItY29yZS9kYXRhbm9kZS9zcmMvbWFpbi9qYXZhL29yZy9hcGFjaGUvaW90ZGIvZGIvcXVlcnllbmdpbmUvbG9hZC9Mb2FkVHNGaWxlTWVtb3J5TWFuYWdlci5qYXZh)
 | 0.00% | [2 Missing :warning: 
](https://app.codecov.io/gh/apache/iotdb/pull/12716?src=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 |
   | 

[PR] Subscription: improve parsing logic when using JAVA SDK client & refactor subscription IT & intro getSubscribedTopicNames API [iotdb]

2024-06-12 Thread via GitHub


VGalaxies opened a new pull request, #12721:
URL: https://github.com/apache/iotdb/pull/12721

   As title with some minor improvements.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Fix NumberFormatException when upgrade from old version [iotdb]

2024-06-12 Thread via GitHub


OneSizeFitsQuorum merged PR #12719:
URL: https://github.com/apache/iotdb/pull/12719


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Rename IoTV2Consensus to IoTConsensusV2 [iotdb]

2024-06-12 Thread via GitHub


OneSizeFitsQuorum merged PR #12715:
URL: https://github.com/apache/iotdb/pull/12715


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [I] [Bug] Error WALBuffer....WAL-Recover Fail to allocate wal node....OutOfMemoryError: Cannot reserve 16777216 bytes of direct buffer memory (allocated: 469771426, limit: 471859200) [iotdb]

2024-06-12 Thread via GitHub


HTHou commented on issue #12714:
URL: https://github.com/apache/iotdb/issues/12714#issuecomment-2162420179

   It may happen when too many databases created. A limitation added in v1.3.2 
can avoid this issue.
   https://github.com/apache/iotdb/pull/12431 


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Fix memory calculate error when insertRecords with both aligned and non-aligned devices [iotdb]

2024-06-12 Thread via GitHub


sonarcloud[bot] commented on PR #12720:
URL: https://github.com/apache/iotdb/pull/12720#issuecomment-2162388539

   ## [![Quality Gate 
Failed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-failed-20px.png
 'Quality Gate 
Failed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12720) 
**Quality Gate failed**  
   Failed conditions  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/failed-16px.png
 '') [0.0% Coverage on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12720=new_coverage=list)
 (required ≥ 80%)  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12720)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Verify connection && Refactor async connection framework [iotdb]

2024-06-12 Thread via GitHub


liyuheng5 commented on code in PR #12667:
URL: https://github.com/apache/iotdb/pull/12667#discussion_r1636000528


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/protocol/client/cn/AsyncConfigNodeRequestRPCHandler.java:
##
@@ -0,0 +1,80 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.iotdb.db.protocol.client.cn;
+
+import org.apache.iotdb.common.rpc.thrift.TConfigNodeLocation;
+import org.apache.iotdb.common.rpc.thrift.TSStatus;
+import org.apache.iotdb.commons.client.request.AsyncRequestContext;
+import org.apache.iotdb.commons.client.request.AsyncRequestRPCHandler;
+
+import java.util.Map;
+import java.util.concurrent.CountDownLatch;
+
+// TODO: ConfigNodeRequestType可抽
+public abstract class AsyncConfigNodeRequestRPCHandler

Review Comment:
   rename to ConfigNodeAsyncRequestRPCHandler



##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/protocol/client/cn/AsyncConfigNodeTSStatusRPCHandler.java:
##
@@ -0,0 +1,95 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.iotdb.db.protocol.client.cn;
+
+import org.apache.iotdb.common.rpc.thrift.TConfigNodeLocation;
+import org.apache.iotdb.common.rpc.thrift.TSStatus;
+import org.apache.iotdb.rpc.RpcUtils;
+import org.apache.iotdb.rpc.TSStatusCode;
+
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import java.util.Map;
+import java.util.concurrent.CountDownLatch;
+
+/** General RPC handler for TSStatus response type. */
+public class AsyncConfigNodeTSStatusRPCHandler extends 
AsyncConfigNodeRequestRPCHandler {

Review Comment:
   rename



##
iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/client/async/AsyncDataNodeExternalServiceClient.java:
##


Review Comment:
   maybe extract some code



##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/protocol/client/dn/AsyncDataNodeRPCHandler.java:
##
@@ -0,0 +1,83 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.iotdb.db.protocol.client.dn;
+
+import org.apache.iotdb.common.rpc.thrift.TDataNodeLocation;
+import org.apache.iotdb.common.rpc.thrift.TSStatus;
+import org.apache.iotdb.commons.client.request.AsyncRequestContext;
+import org.apache.iotdb.commons.client.request.AsyncRequestRPCHandler;
+
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import java.util.Map;
+import java.util.concurrent.CountDownLatch;
+
+public abstract class AsyncDataNodeRPCHandler

Review Comment:
   rename



##
iotdb-protocol/thrift-datanode/src/main/thrift/client.thrift:
##
@@ -659,4 +659,10 @@ service IClientRPCService {
   

Re: [PR] load-tsfile script: disable redirection & load: handle exceptions using the Analysis objects instead of throwing exceptions [iotdb]

2024-06-12 Thread via GitHub


sonarcloud[bot] commented on PR #12716:
URL: https://github.com/apache/iotdb/pull/12716#issuecomment-2162375387

   ## [![Quality Gate 
Failed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-failed-20px.png
 'Quality Gate 
Failed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12716) 
**Quality Gate failed**  
   Failed conditions  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/failed-16px.png
 '') [0.0% Coverage on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12716=new_coverage=list)
 (required ≥ 80%)  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12716)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] Fix memory calculate error when insertRecords with both aligned and non-aligned devices [iotdb]

2024-06-12 Thread via GitHub


HTHou opened a new pull request, #12720:
URL: https://github.com/apache/iotdb/pull/12720

   ## Description
   
   For an InsertRowsNode, we cannot ensure it only contains one alignment type 
of InsertRowNodes. 


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] Fix NumberFormatException when upgrade from old version [iotdb]

2024-06-12 Thread via GitHub


shuwenwei opened a new pull request, #12719:
URL: https://github.com/apache/iotdb/pull/12719

   ## Description
   When upgrading from an older version, if only sbin is updated without 
simultaneously updating the env script in the conf directory, a 
NumberFormatException may occur.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] load-tsfile script: disable redirection & load: handle exceptions using the Analysis objects instead of throwing exceptions [iotdb]

2024-06-12 Thread via GitHub


sonarcloud[bot] commented on PR #12716:
URL: https://github.com/apache/iotdb/pull/12716#issuecomment-2162347628

   ## [![Quality Gate 
Failed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-failed-20px.png
 'Quality Gate 
Failed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12716) 
**Quality Gate failed**  
   Failed conditions  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/failed-16px.png
 '') [0.0% Coverage on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12716=new_coverage=list)
 (required ≥ 80%)  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12716)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] Support active schema query [iotdb]

2024-06-12 Thread via GitHub


Cpaulyz opened a new pull request, #12718:
URL: https://github.com/apache/iotdb/pull/12718

   ## Description
   
   draft


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Rename IoTV2Consensus to IoTConsensusV2 [iotdb]

2024-06-12 Thread via GitHub


sonarcloud[bot] commented on PR #12715:
URL: https://github.com/apache/iotdb/pull/12715#issuecomment-2162313484

   ## [![Quality Gate 
Passed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-passed-20px.png
 'Quality Gate 
Passed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12715) 
**Quality Gate passed**  
   Issues  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0 New 
issues](https://sonarcloud.io/project/issues?id=apache_iotdb=12715=false=true)
  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/accepted-16px.png
 '') [0 Accepted 
issues](https://sonarcloud.io/project/issues?id=apache_iotdb=12715=WONTFIX)
   
   Measures  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0 Security 
Hotspots](https://sonarcloud.io/project/security_hotspots?id=apache_iotdb=12715=false=true)
  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0.0% Coverage on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12715=new_coverage=list)
  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0.0% Duplication on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12715=new_duplicated_lines_density=list)
  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12715)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] [Table Model] Implement table column extension [iotdb]

2024-06-12 Thread via GitHub


MarcosZyk opened a new pull request, #12717:
URL: https://github.com/apache/iotdb/pull/12717

   ## Description
   
   
   ### Content1 ...
   
   ### Content2 ...
   
   ### Content3 ...
   
   
   
   
   
   
   
   
   
   
   
   
   This PR has:
   - [ ] been self-reviewed.
   - [ ] concurrent read
   - [ ] concurrent write
   - [ ] concurrent read and write 
   - [ ] added documentation for new or modified features or behaviors.
   - [ ] added Javadocs for most classes and all non-trivial methods. 
   - [ ] added or updated version, __license__, or notice information
   - [ ] added comments explaining the "why" and the intent of the code 
wherever would not be obvious 
 for an unfamiliar reader.
   - [ ] added unit tests or modified existing tests to cover new code paths, 
ensuring the threshold 
 for code coverage.
   - [ ] added integration tests.
   - [ ] been tested in a test IoTDB cluster.
   
   
   
   
   
   # Key changed/added classes (or packages if there are too many classes) 
in this PR
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] load-tsfile script: disable redirection & load: handle exceptions using the Analysis objects instead of throwing exceptions [iotdb]

2024-06-12 Thread via GitHub


sonarcloud[bot] commented on PR #12716:
URL: https://github.com/apache/iotdb/pull/12716#issuecomment-2162288442

   ## [![Quality Gate 
Failed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-failed-20px.png
 'Quality Gate 
Failed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12716) 
**Quality Gate failed**  
   Failed conditions  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/failed-16px.png
 '') [0.0% Coverage on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12716=new_coverage=list)
 (required ≥ 80%)  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12716)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Bump org.jetbrains.kotlin:kotlin-stdlib-jdk8 from 1.9.10 to 1.9.24 [iotdb]

2024-06-12 Thread via GitHub


dependabot[bot] closed pull request #12633: Bump 
org.jetbrains.kotlin:kotlin-stdlib-jdk8 from 1.9.10 to 1.9.24
URL: https://github.com/apache/iotdb/pull/12633


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Bump org.jetbrains.kotlin:kotlin-stdlib-jdk8 from 1.9.10 to 1.9.24 [iotdb]

2024-06-12 Thread via GitHub


dependabot[bot] commented on PR #12633:
URL: https://github.com/apache/iotdb/pull/12633#issuecomment-2162285165

   Looks like org.jetbrains.kotlin:kotlin-stdlib-jdk8 is no longer a 
dependency, so this is no longer needed.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Update pom.xml to fix security issue [iotdb]

2024-06-12 Thread via GitHub


HTHou merged PR #12705:
URL: https://github.com/apache/iotdb/pull/12705


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Update pom.xml to fix security issue [iotdb]

2024-06-12 Thread via GitHub


chrisdutz commented on PR #12705:
URL: https://github.com/apache/iotdb/pull/12705#issuecomment-2162280765

   Yeah ... I first thought it needed that update but then I thought: I bet 
there's a lot more ... so I took the changes I had in my private fork of IoTDB 
(Wehre I migrated everything to Java 11 and Jakarta) ... turns out there was a 
lot more that could go.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] load-tsfile script: disable redirection & load: handle exceptions using the Analysis objects instead of throwing exceptions [iotdb]

2024-06-12 Thread via GitHub


SteveYurongSu opened a new pull request, #12716:
URL: https://github.com/apache/iotdb/pull/12716

   As title.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Rename IoTV2Consensus to IoTConsensusV2 [iotdb]

2024-06-12 Thread via GitHub


codecov[bot] commented on PR #12715:
URL: https://github.com/apache/iotdb/pull/12715#issuecomment-2162263701

   ## 
[Codecov](https://app.codecov.io/gh/apache/iotdb/pull/12715?dropdown=coverage=pr=h1_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 Report
   Attention: Patch coverage is `50.0%` with `2 lines` in your changes 
missing coverage. Please review.
   > Project coverage is 42.09%. Comparing base 
[(`a64dc4c`)](https://app.codecov.io/gh/apache/iotdb/commit/a64dc4c530d8826b04097c4fb765a16237e7b4ff?dropdown=coverage=desc_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 to head 
[(`ddeccdf`)](https://app.codecov.io/gh/apache/iotdb/commit/ddeccdfc6ec0df69a0f19c1b6ca7e7cb1016809d?dropdown=coverage=desc_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   > Report is 10 commits behind head on master.
   
   | 
[Files](https://app.codecov.io/gh/apache/iotdb/pull/12715?dropdown=coverage=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 | Patch % | Lines |
   |---|---|---|
   | 
[.../iotdb/confignode/conf/ConfigNodeStartupCheck.java](https://app.codecov.io/gh/apache/iotdb/pull/12715?src=pr=tree=iotdb-core%2Fconfignode%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fiotdb%2Fconfignode%2Fconf%2FConfigNodeStartupCheck.java_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache#diff-aW90ZGItY29yZS9jb25maWdub2RlL3NyYy9tYWluL2phdmEvb3JnL2FwYWNoZS9pb3RkYi9jb25maWdub2RlL2NvbmYvQ29uZmlnTm9kZVN0YXJ0dXBDaGVjay5qYXZh)
 | 0.00% | [1 Missing :warning: 
](https://app.codecov.io/gh/apache/iotdb/pull/12715?src=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 |
   | 
[...onfignode/manager/load/balancer/RouteBalancer.java](https://app.codecov.io/gh/apache/iotdb/pull/12715?src=pr=tree=iotdb-core%2Fconfignode%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fiotdb%2Fconfignode%2Fmanager%2Fload%2Fbalancer%2FRouteBalancer.java_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache#diff-aW90ZGItY29yZS9jb25maWdub2RlL3NyYy9tYWluL2phdmEvb3JnL2FwYWNoZS9pb3RkYi9jb25maWdub2RlL21hbmFnZXIvbG9hZC9iYWxhbmNlci9Sb3V0ZUJhbGFuY2VyLmphdmE=)
 | 0.00% | [1 Missing :warning: 
](https://app.codecov.io/gh/apache/iotdb/pull/12715?src=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 |
   
   Additional details and impacted files
   
   
   ```diff
   @@ Coverage Diff  @@
   ## master   #12715  +/-   ##
   
   - Coverage 42.09%   42.09%   -0.01% 
 Complexity   71   71  
   
 Files  3261 3260   -1 
 Lines205664   205703  +39 
 Branches  2452224525   +3 
   
   + Hits  8658086593  +13 
   - Misses   119084   119110  +26 
   ```
   
   
   
   
   
   [:umbrella: View full report in Codecov by 
Sentry](https://app.codecov.io/gh/apache/iotdb/pull/12715?dropdown=coverage=pr=continue_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   
   :loudspeaker: Have feedback on the report? [Share it 
here](https://about.codecov.io/codecov-pr-comment-feedback/?utm_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Subscription: skip on setup and cluster failure when running subscription restart IT & fix some bugs in SubscriptionExecutorServiceManager [iotdb]

2024-06-12 Thread via GitHub


SteveYurongSu merged PR #12710:
URL: https://github.com/apache/iotdb/pull/12710


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Rename IoTV2Consensus to IoTConsensusV2 [iotdb]

2024-06-12 Thread via GitHub


sonarcloud[bot] commented on PR #12715:
URL: https://github.com/apache/iotdb/pull/12715#issuecomment-2162193037

   ## [![Quality Gate 
Passed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-passed-20px.png
 'Quality Gate 
Passed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12715) 
**Quality Gate passed**  
   Issues  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0 New 
issues](https://sonarcloud.io/project/issues?id=apache_iotdb=12715=false=true)
  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/accepted-16px.png
 '') [0 Accepted 
issues](https://sonarcloud.io/project/issues?id=apache_iotdb=12715=WONTFIX)
   
   Measures  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0 Security 
Hotspots](https://sonarcloud.io/project/security_hotspots?id=apache_iotdb=12715=false=true)
  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0.0% Coverage on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12715=new_coverage=list)
  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0.0% Duplication on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12715=new_duplicated_lines_density=list)
  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12715)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] Rename IoTV2Consensus to IoTConsensusV2 [iotdb]

2024-06-12 Thread via GitHub


OneSizeFitsQuorum opened a new pull request, #12715:
URL: https://github.com/apache/iotdb/pull/12715

   as title said


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Support WAL Compression [iotdb]

2024-06-11 Thread via GitHub


sonarcloud[bot] commented on PR #12476:
URL: https://github.com/apache/iotdb/pull/12476#issuecomment-2162153346

   ## [![Quality Gate 
Failed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-failed-20px.png
 'Quality Gate 
Failed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12476) 
**Quality Gate failed**  
   Failed conditions  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/failed-16px.png
 '') [0.0% Coverage on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12476=new_coverage=list)
 (required ≥ 80%)  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12476)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[I] [Bug] Error WALBuffer....WAL-Recover Fail to allocate wal node....OutOfMemoryError: Cannot reserve 16777216 bytes of direct buffer memory (allocated: 469771426, limit: 471859200) [iotdb]

2024-06-11 Thread via GitHub


automatous opened a new issue, #12714:
URL: https://github.com/apache/iotdb/issues/12714

   ### Search before asking
   
   - [X] I searched in the [issues](https://github.com/apache/iotdb/issues) and 
found nothing similar.
   
   
   ### Version
   
   1.3.0
   3C3D
   
   ### Describe the bug and provide the minimal reproduce step
   
   https://github.com/apache/iotdb/assets/71641872/ab143627-9abf-4bff-9f58-2f3a8644a7d3;>
   
   We upped the JVM memory and still reported this error
   
   ### What did you expect to see?
   
   Cluster running properly
   
   ### What did you see instead?
   
   We can expand the memory
   
   ### Anything else?
   
   _No response_
   
   ### Are you willing to submit a PR?
   
   - [X] I'm willing to submit a PR!


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Replenish effective mode in iotdb-system.properties [iotdb]

2024-06-11 Thread via GitHub


HTHou commented on code in PR #12706:
URL: https://github.com/apache/iotdb/pull/12706#discussion_r1635801454


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/utils/TypeInferenceUtils.java:
##
@@ -40,6 +41,7 @@
 
 public class TypeInferenceUtils {
 
+  private static final IoTDBConfig CONF = 
IoTDBDescriptor.getInstance().getConfig();
   private static final TSDataType booleanStringInferType =
   IoTDBDescriptor.getInstance().getConfig().getBooleanStringInferType();

Review Comment:
   It can be removed.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Replenish effective mode in iotdb-system.properties [iotdb]

2024-06-11 Thread via GitHub


HTHou commented on code in PR #12706:
URL: https://github.com/apache/iotdb/pull/12706#discussion_r1635801009


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/utils/TypeInferenceUtils.java:
##
@@ -40,6 +41,7 @@
 
 public class TypeInferenceUtils {
 
+  private static final IoTDBConfig CONF = 
IoTDBDescriptor.getInstance().getConfig();
   private static final TSDataType booleanStringInferType =
   IoTDBDescriptor.getInstance().getConfig().getBooleanStringInferType();

Review Comment:
   It can be removed.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Replenish effective mode in iotdb-system.properties [iotdb]

2024-06-11 Thread via GitHub


shuwenwei commented on code in PR #12706:
URL: https://github.com/apache/iotdb/pull/12706#discussion_r1635722965


##
iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/conf/ConfigurationFileUtils.java:
##
@@ -158,7 +160,7 @@ public static String readConfigurationTemplateFile() throws 
IOException {
 BufferedReader reader = new BufferedReader(isr)) {
   String line;
   while ((line = reader.readLine()) != null) {
-content.append(line).append(System.lineSeparator());
+content.append(line).append("\n");

Review Comment:
   In order to be compatible with some scripts, the newline characters in the 
configuration file need to be used uniformly '\n'



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] update import and export tsfile description [iotdb]

2024-06-11 Thread via GitHub


HTHou merged PR #12684:
URL: https://github.com/apache/iotdb/pull/12684


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Update pom.xml to fix security issue [iotdb]

2024-06-11 Thread via GitHub


HTHou commented on PR #12705:
URL: https://github.com/apache/iotdb/pull/12705#issuecomment-2161897940

   Thank you Chris, I saw you already updated this PR! 
   So is it ready to merge?


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Replenish effective mode in iotdb-system.properties [iotdb]

2024-06-11 Thread via GitHub


OneSizeFitsQuorum commented on code in PR #12706:
URL: https://github.com/apache/iotdb/pull/12706#discussion_r1635649474


##
iotdb-core/node-commons/src/main/java/org/apache/iotdb/commons/conf/ConfigurationFileUtils.java:
##
@@ -158,7 +160,7 @@ public static String readConfigurationTemplateFile() throws 
IOException {
 BufferedReader reader = new BufferedReader(isr)) {
   String line;
   while ((line = reader.readLine()) != null) {
-content.append(line).append(System.lineSeparator());
+content.append(line).append("\n");

Review Comment:
   why change this?
   https://github.com/apache/iotdb/assets/32640567/3a038ed1-e17a-4d63-a05f-70deec3d9cb1;>
   



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Fix missing of linux memory metrics [iotdb]

2024-06-11 Thread via GitHub


OneSizeFitsQuorum merged PR #12713:
URL: https://github.com/apache/iotdb/pull/12713


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] [Table Model] Schema Validation Interface [iotdb]

2024-06-11 Thread via GitHub


JackieTien97 merged PR #12707:
URL: https://github.com/apache/iotdb/pull/12707


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Update pom.xml to fix security issue [iotdb]

2024-06-11 Thread via GitHub


sonarcloud[bot] commented on PR #12705:
URL: https://github.com/apache/iotdb/pull/12705#issuecomment-2161312671

   ## [![Quality Gate 
Passed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-passed-20px.png
 'Quality Gate 
Passed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12705) 
**Quality Gate passed**  
   Issues  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0 New 
issues](https://sonarcloud.io/project/issues?id=apache_iotdb=12705=false=true)
  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/accepted-16px.png
 '') [0 Accepted 
issues](https://sonarcloud.io/project/issues?id=apache_iotdb=12705=WONTFIX)
   
   Measures  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0 Security 
Hotspots](https://sonarcloud.io/project/security_hotspots?id=apache_iotdb=12705=false=true)
  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/no-data-16px.png
 '') No data about Coverage  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/no-data-16px.png
 '') No data about Duplication  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12705)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Update pom.xml to fix security issue [iotdb]

2024-06-11 Thread via GitHub


sonarcloud[bot] commented on PR #12705:
URL: https://github.com/apache/iotdb/pull/12705#issuecomment-2161297279

   ## [![Quality Gate 
Passed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-passed-20px.png
 'Quality Gate 
Passed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12705) 
**Quality Gate passed**  
   Issues  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0 New 
issues](https://sonarcloud.io/project/issues?id=apache_iotdb=12705=false=true)
  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/accepted-16px.png
 '') [0 Accepted 
issues](https://sonarcloud.io/project/issues?id=apache_iotdb=12705=WONTFIX)
   
   Measures  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0 Security 
Hotspots](https://sonarcloud.io/project/security_hotspots?id=apache_iotdb=12705=false=true)
  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/no-data-16px.png
 '') No data about Coverage  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/no-data-16px.png
 '') No data about Duplication  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12705)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Update pom.xml to fix security issue [iotdb]

2024-06-11 Thread via GitHub


chrisdutz commented on PR #12705:
URL: https://github.com/apache/iotdb/pull/12705#issuecomment-2161288773

   I took the liberty to actually go through all dependencies and clean up the 
dependencyManagement as well as the properties.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Fix missing of linux memory metrics [iotdb]

2024-06-11 Thread via GitHub


codecov[bot] commented on PR #12713:
URL: https://github.com/apache/iotdb/pull/12713#issuecomment-2161178994

   ## 
[Codecov](https://app.codecov.io/gh/apache/iotdb/pull/12713?dropdown=coverage=pr=h1_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 Report
   Attention: Patch coverage is `0%` with `2 lines` in your changes missing 
coverage. Please review.
   > Project coverage is 42.09%. Comparing base 
[(`ab9347b`)](https://app.codecov.io/gh/apache/iotdb/commit/ab9347bfde9053d574466303f298273ecd1cb5b8?dropdown=coverage=desc_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 to head 
[(`01d99a7`)](https://app.codecov.io/gh/apache/iotdb/commit/01d99a72d366530d9c7b9f2e264872656ddf80f8?dropdown=coverage=desc_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   > Report is 5 commits behind head on master.
   
   | 
[Files](https://app.codecov.io/gh/apache/iotdb/pull/12713?dropdown=coverage=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 | Patch % | Lines |
   |---|---|---|
   | 
[...iotdb/metrics/metricsets/system/SystemMetrics.java](https://app.codecov.io/gh/apache/iotdb/pull/12713?src=pr=tree=iotdb-core%2Fmetrics%2Finterface%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fiotdb%2Fmetrics%2Fmetricsets%2Fsystem%2FSystemMetrics.java_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache#diff-aW90ZGItY29yZS9tZXRyaWNzL2ludGVyZmFjZS9zcmMvbWFpbi9qYXZhL29yZy9hcGFjaGUvaW90ZGIvbWV0cmljcy9tZXRyaWNzZXRzL3N5c3RlbS9TeXN0ZW1NZXRyaWNzLmphdmE=)
 | 0.00% | [2 Missing :warning: 
](https://app.codecov.io/gh/apache/iotdb/pull/12713?src=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 |
   
   Additional details and impacted files
   
   
   ```diff
   @@ Coverage Diff  @@
   ## master   #12713  +/-   ##
   
   - Coverage 42.10%   42.09%   -0.01% 
 Complexity   71   71  
   
 Files  3261 3260   -1 
 Lines205655   205703  +48 
 Branches  2452124525   +4 
   
   + Hits  8658386591   +8 
   - Misses   119072   119112  +40 
   ```
   
   
   
   
   
   [:umbrella: View full report in Codecov by 
Sentry](https://app.codecov.io/gh/apache/iotdb/pull/12713?dropdown=coverage=pr=continue_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   
   :loudspeaker: Have feedback on the report? [Share it 
here](https://about.codecov.io/codecov-pr-comment-feedback/?utm_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Fix missing of linux memory metrics [iotdb]

2024-06-11 Thread via GitHub


sonarcloud[bot] commented on PR #12713:
URL: https://github.com/apache/iotdb/pull/12713#issuecomment-2161095273

   ## [![Quality Gate 
Passed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-passed-20px.png
 'Quality Gate 
Passed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12713) 
**Quality Gate passed**  
   Issues  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0 New 
issues](https://sonarcloud.io/project/issues?id=apache_iotdb=12713=false=true)
  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/accepted-16px.png
 '') [0 Accepted 
issues](https://sonarcloud.io/project/issues?id=apache_iotdb=12713=WONTFIX)
   
   Measures  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0 Security 
Hotspots](https://sonarcloud.io/project/security_hotspots?id=apache_iotdb=12713=false=true)
  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0.0% Coverage on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12713=new_coverage=list)
  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0.0% Duplication on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12713=new_duplicated_lines_density=list)
  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12713)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] Fix missing of linux memory metrics [iotdb]

2024-06-11 Thread via GitHub


SpriCoder opened a new pull request, #12713:
URL: https://github.com/apache/iotdb/pull/12713

   Fix missing of linux memory metrics: 
   https://github.com/apache/iotdb/assets/46039728/66869bcb-31fc-4a22-9f60-21367546df75;>
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Procedure: Fix ProcedureInfo on CN leader may decrease its procId [iotdb]

2024-06-11 Thread via GitHub


SteveYurongSu merged PR #12711:
URL: https://github.com/apache/iotdb/pull/12711


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Pipe: Fixed NPE in schema pattern parsing & Improved connector subtask retry logic and logs & Fixed the executor used by consensus pipe [iotdb]

2024-06-11 Thread via GitHub


SteveYurongSu merged PR #12704:
URL: https://github.com/apache/iotdb/pull/12704


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Load: Update loadTsFileDirs after all newLoadTsFileDirs are generated to avoid undefined behavior [iotdb]

2024-06-11 Thread via GitHub


sonarcloud[bot] commented on PR #12712:
URL: https://github.com/apache/iotdb/pull/12712#issuecomment-2160704890

   ## [![Quality Gate 
Failed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-failed-20px.png
 'Quality Gate 
Failed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12712) 
**Quality Gate failed**  
   Failed conditions  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/failed-16px.png
 '') [0.0% Coverage on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12712=new_coverage=list)
 (required ≥ 80%)  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/failed-16px.png
 '') [30.4% Duplication on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12712=new_duplicated_lines_density=list)
 (required ≤ 3%)  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12712)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Load: Update loadTsFileDirs after all newLoadTsFileDirs are generated to avoid undefined behavior [iotdb]

2024-06-11 Thread via GitHub


SteveYurongSu merged PR #12712:
URL: https://github.com/apache/iotdb/pull/12712


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] Load: Update loadTsFileDirs after all newLoadTsFileDirs are generated to avoid undefined behavior [iotdb]

2024-06-11 Thread via GitHub


SteveYurongSu opened a new pull request, #12712:
URL: https://github.com/apache/iotdb/pull/12712

   (no comment)


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Pipe: add decompressed length in RPC compression payload to avoid potential OOM on receiver [iotdb]

2024-06-11 Thread via GitHub


SteveYurongSu merged PR #12701:
URL: https://github.com/apache/iotdb/pull/12701


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] add Table auth. [iotdb-docs]

2024-06-11 Thread via GitHub


JackieTien97 merged PR #246:
URL: https://github.com/apache/iotdb-docs/pull/246


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] add Table auth. [iotdb-docs]

2024-06-11 Thread via GitHub


ColinLeeo opened a new pull request, #246:
URL: https://github.com/apache/iotdb-docs/pull/246

   (no comment)


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] Fixed the bug that leader procedureInfo may decrease its procedureId [iotdb]

2024-06-11 Thread via GitHub


Caideyipi opened a new pull request, #12711:
URL: https://github.com/apache/iotdb/pull/12711

   ## Description
   As the title said.
   
   
   
   
   
   
   
   
   
   
   
   
   This PR has:
   - [ ] been self-reviewed.
   - [ ] concurrent read
   - [ ] concurrent write
   - [ ] concurrent read and write 
   - [ ] added documentation for new or modified features or behaviors.
   - [ ] added Javadocs for most classes and all non-trivial methods. 
   - [ ] added or updated version, __license__, or notice information
   - [ ] added comments explaining the "why" and the intent of the code 
wherever would not be obvious 
 for an unfamiliar reader.
   - [ ] added unit tests or modified existing tests to cover new code paths, 
ensuring the threshold 
 for code coverage.
   - [ ] added integration tests.
   - [ ] been tested in a test IoTDB cluster.
   
   
   
   
   
   # Key changed/added classes (or packages if there are too many classes) 
in this PR
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Load: Support storing piecenode in multiple folders during 2nd phase [iotdb]

2024-06-11 Thread via GitHub


SteveYurongSu merged PR #12675:
URL: https://github.com/apache/iotdb/pull/12675


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Merge master0611 [iotdb]

2024-06-11 Thread via GitHub


JackieTien97 merged PR #12703:
URL: https://github.com/apache/iotdb/pull/12703


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Optimize UT/IT of rest api [iotdb]

2024-06-11 Thread via GitHub


codecov[bot] commented on PR #12708:
URL: https://github.com/apache/iotdb/pull/12708#issuecomment-2160481010

   ## 
[Codecov](https://app.codecov.io/gh/apache/iotdb/pull/12708?dropdown=coverage=pr=h1_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 Report
   Attention: Patch coverage is `26.92308%` with `76 lines` in your changes 
missing coverage. Please review.
   > Project coverage is 42.13%. Comparing base 
[(`3846563`)](https://app.codecov.io/gh/apache/iotdb/commit/38465631d492a32fb6c1d52f27fdacbd4d1c9dca?dropdown=coverage=desc_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 to head 
[(`1614f90`)](https://app.codecov.io/gh/apache/iotdb/commit/1614f9097520af18e1148f0e369f64899b5d0f95?dropdown=coverage=desc_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   > Report is 4 commits behind head on master.
   
   | 
[Files](https://app.codecov.io/gh/apache/iotdb/pull/12708?dropdown=coverage=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 | Patch % | Lines |
   |---|---|---|
   | 
[.../db/protocol/rest/utils/InsertTabletDataUtils.java](https://app.codecov.io/gh/apache/iotdb/pull/12708?src=pr=tree=iotdb-core%2Fdatanode%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fiotdb%2Fdb%2Fprotocol%2Frest%2Futils%2FInsertTabletDataUtils.java_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache#diff-aW90ZGItY29yZS9kYXRhbm9kZS9zcmMvbWFpbi9qYXZhL29yZy9hcGFjaGUvaW90ZGIvZGIvcHJvdG9jb2wvcmVzdC91dGlscy9JbnNlcnRUYWJsZXREYXRhVXRpbHMuamF2YQ==)
 | 27.05% | [62 Missing :warning: 
](https://app.codecov.io/gh/apache/iotdb/pull/12708?src=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 |
   | 
[.../rest/v1/handler/StatementConstructionHandler.java](https://app.codecov.io/gh/apache/iotdb/pull/12708?src=pr=tree=iotdb-core%2Fdatanode%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fiotdb%2Fdb%2Fprotocol%2Frest%2Fv1%2Fhandler%2FStatementConstructionHandler.java_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache#diff-aW90ZGItY29yZS9kYXRhbm9kZS9zcmMvbWFpbi9qYXZhL29yZy9hcGFjaGUvaW90ZGIvZGIvcHJvdG9jb2wvcmVzdC92MS9oYW5kbGVyL1N0YXRlbWVudENvbnN0cnVjdGlvbkhhbmRsZXIuamF2YQ==)
 | 0.00% | [8 Missing :warning: 
](https://app.codecov.io/gh/apache/iotdb/pull/12708?src=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 |
   | 
[...b/db/protocol/rest/v1/impl/RestApiServiceImpl.java](https://app.codecov.io/gh/apache/iotdb/pull/12708?src=pr=tree=iotdb-core%2Fdatanode%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fiotdb%2Fdb%2Fprotocol%2Frest%2Fv1%2Fimpl%2FRestApiServiceImpl.java_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache#diff-aW90ZGItY29yZS9kYXRhbm9kZS9zcmMvbWFpbi9qYXZhL29yZy9hcGFjaGUvaW90ZGIvZGIvcHJvdG9jb2wvcmVzdC92MS9pbXBsL1Jlc3RBcGlTZXJ2aWNlSW1wbC5qYXZh)
 | 0.00% | [3 Missing :warning: 
](https://app.codecov.io/gh/apache/iotdb/pull/12708?src=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 |
   | 
[...b/db/protocol/rest/v2/impl/RestApiServiceImpl.java](https://app.codecov.io/gh/apache/iotdb/pull/12708?src=pr=tree=iotdb-core%2Fdatanode%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fiotdb%2Fdb%2Fprotocol%2Frest%2Fv2%2Fimpl%2FRestApiServiceImpl.java_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache#diff-aW90ZGItY29yZS9kYXRhbm9kZS9zcmMvbWFpbi9qYXZhL29yZy9hcGFjaGUvaW90ZGIvZGIvcHJvdG9jb2wvcmVzdC92Mi9pbXBsL1Jlc3RBcGlTZXJ2aWNlSW1wbC5qYXZh)
 | 0.00% | [3 Missing :warning: 
](https://app.codecov.io/gh/apache/iotdb/pull/12708?src=pr=tree_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 |
   
   Additional details and impacted files
   
   
   ```diff
   @@ Coverage Diff  @@
   ## master   #12708  +/-   ##
   
   + Coverage 42.09%   42.13%   +0.04% 
 Complexity   71   71  
   
 Files  3261 3261  
 Lines205659   205597  -62 
 Branches  2452224502  -20 
   
   + Hits  8656286621  +59 
   + Misses   119097   118976 -121 
   ```
   
   
   
   
   
   [:umbrella: View full report in Codecov by 
Sentry](https://app.codecov.io/gh/apache/iotdb/pull/12708?dropdown=coverage=pr=continue_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   
   :loudspeaker: Have feedback on the report? [Share it 
here](https://about.codecov.io/codecov-pr-comment-feedback/?utm_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to 

[PR] [DO NOT MERGE] SUBSCRIPTION IT TEST [iotdb]

2024-06-11 Thread via GitHub


VGalaxies opened a new pull request, #12710:
URL: https://github.com/apache/iotdb/pull/12710

   (no comment)


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] Support show device ttl on path pattern [iotdb]

2024-06-11 Thread via GitHub


choubenson opened a new pull request, #12709:
URL: https://github.com/apache/iotdb/pull/12709

   Support `show ttl on pathPattern`.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Optimize UT/IT of rest api [iotdb]

2024-06-11 Thread via GitHub


sonarcloud[bot] commented on PR #12708:
URL: https://github.com/apache/iotdb/pull/12708#issuecomment-2160397522

   ## [![Quality Gate 
Failed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-failed-20px.png
 'Quality Gate 
Failed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12708) 
**Quality Gate failed**  
   Failed conditions  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/failed-16px.png
 '') [0.0% Coverage on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12708=new_coverage=list)
 (required ≥ 80%)  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12708)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] [Table Model] Schema Validation Interface [iotdb]

2024-06-11 Thread via GitHub


JackieTien97 commented on code in PR #12707:
URL: https://github.com/apache/iotdb/pull/12707#discussion_r1634588513


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/Metadata.java:
##
@@ -67,4 +68,29 @@ List indexScan(
   QualifiedObjectName tableName,
   List expressionList,
   List attributeColumns);
+
+  /**
+   * This method is used for table column validation and should be invoked 
before device validation.
+   *
+   * This method return all the existing column schemas in the target table.
+   *
+   * When table or column is missing, this method will execute auto 
creation.
+   *
+   * When using SQL, the columnSchemaList could be null and there won't be 
any validation.
+   *
+   * When the input dataType or category of one column is null, the column 
cannot be auto
+   * created.
+   */
+  TableSchema validateTableHeaderSchema(
+  String database, TableSchema tableSchema, MPPQueryContext context);
+
+  /**
+   * This method is used for table device validation and should be invoked 
after column validation.
+   *
+   * When device id is missing, this method will execute auto creation.
+   *
+   * When device attribute is missing or different from that stored in 
IoTDB, the attribute will
+   * be auto upsert.
+   */
+  void validateDeviceSchema(ITableDeviceSchemaValidation schemaValidation, 
MPPQueryContext context);

Review Comment:
   After confirmation with @jt2594838 and @qiaojialin , auto create won't 
affect device creation, so the creation for device won't failed because of 
auto_create is false, but there may be other reasons.
   
   If your current implementation will throw some specific exception if any 
device creation failed, it's ok but you need add that exception in java doc and 
make your interface more clear.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Support WAL Compression [iotdb]

2024-06-11 Thread via GitHub


sonarcloud[bot] commented on PR #12476:
URL: https://github.com/apache/iotdb/pull/12476#issuecomment-2160316097

   ## [![Quality Gate 
Failed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-failed-20px.png
 'Quality Gate 
Failed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12476) 
**Quality Gate failed**  
   Failed conditions  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/failed-16px.png
 '') [0.0% Coverage on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12476=new_coverage=list)
 (required ≥ 80%)  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12476)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] [Table Model] Schema Validation Interface [iotdb]

2024-06-11 Thread via GitHub


MarcosZyk commented on code in PR #12707:
URL: https://github.com/apache/iotdb/pull/12707#discussion_r1634547400


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/Metadata.java:
##
@@ -67,4 +68,29 @@ List indexScan(
   QualifiedObjectName tableName,
   List expressionList,
   List attributeColumns);
+
+  /**
+   * This method is used for table column validation and should be invoked 
before device validation.
+   *
+   * This method return all the existing column schemas in the target table.
+   *
+   * When table or column is missing, this method will execute auto 
creation.
+   *
+   * When using SQL, the columnSchemaList could be null and there won't be 
any validation.
+   *
+   * When the input dataType or category of one column is null, the column 
cannot be auto
+   * created.
+   */
+  TableSchema validateTableHeaderSchema(
+  String database, TableSchema tableSchema, MPPQueryContext context);
+
+  /**
+   * This method is used for table device validation and should be invoked 
after column validation.
+   *
+   * When device id is missing, this method will execute auto creation.
+   *
+   * When device attribute is missing or different from that stored in 
IoTDB, the attribute will
+   * be auto upsert.
+   */
+  void validateDeviceSchema(ITableDeviceSchemaValidation schemaValidation, 
MPPQueryContext context);

Review Comment:
   First, We haven't define what is "partial insert" in table model. Device 
level or series level?  Second, to support partial insert, another interface 
"markFailed(int index)" shall be added to the ITableDeviceSchemaValidation and 
will be recalled during validation process. 
   
   For "auto create succeed or this device already exists before", no exception 
or info should be return in current stage. Id column data type may be should be 
returned if we support device id values with different data type.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] [Table Model] Schema Validation Interface [iotdb]

2024-06-11 Thread via GitHub


MarcosZyk commented on code in PR #12707:
URL: https://github.com/apache/iotdb/pull/12707#discussion_r1634539054


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/Metadata.java:
##
@@ -67,4 +68,29 @@ List indexScan(
   QualifiedObjectName tableName,
   List expressionList,
   List attributeColumns);
+
+  /**
+   * This method is used for table column validation and should be invoked 
before device validation.
+   *
+   * This method return all the existing column schemas in the target table.
+   *
+   * When table or column is missing, this method will execute auto 
creation.
+   *
+   * When using SQL, the columnSchemaList could be null and there won't be 
any validation.
+   *
+   * When the input dataType or category of one column is null, the column 
cannot be auto
+   * created.
+   */
+  TableSchema validateTableHeaderSchema(

Review Comment:
   Throw SemanticException



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] [Table Model] Schema Validation Interface [iotdb]

2024-06-11 Thread via GitHub


MarcosZyk commented on code in PR #12707:
URL: https://github.com/apache/iotdb/pull/12707#discussion_r1634537352


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/ITableDeviceSchemaValidation.java:
##
@@ -0,0 +1,39 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.iotdb.db.queryengine.plan.relational.metadata;
+
+import java.util.List;
+
+/**
+ * This class acts as a request for device schema validation and defines the 
necessary information
+ * interfaces.
+ */
+public interface ITableDeviceSchemaValidation {
+
+  String getDatabase();
+
+  String getTableName();
+
+  List getDeviceIdList();

Review Comment:
   Row-based. Already update the interface.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] [Table Model] Schema Validation Interface [iotdb]

2024-06-11 Thread via GitHub


MarcosZyk commented on code in PR #12707:
URL: https://github.com/apache/iotdb/pull/12707#discussion_r1634534923


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/ITableDeviceSchemaValidation.java:
##
@@ -0,0 +1,39 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.iotdb.db.queryengine.plan.relational.metadata;
+
+import java.util.List;
+
+/**
+ * This class acts as a request for device schema validation and defines the 
necessary information
+ * interfaces.
+ */
+public interface ITableDeviceSchemaValidation {

Review Comment:
   Added.



##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/ITableDeviceSchemaValidation.java:
##
@@ -0,0 +1,39 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.iotdb.db.queryengine.plan.relational.metadata;
+
+import java.util.List;
+
+/**
+ * This class acts as a request for device schema validation and defines the 
necessary information
+ * interfaces.
+ */
+public interface ITableDeviceSchemaValidation {
+
+  String getDatabase();
+
+  String getTableName();
+
+  List getDeviceIdList();
+
+  List getAttributeColumnNameList();
+
+  List> getAttributeValue();

Review Comment:
   Fixed.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] [Table Model] Schema Validation Interface [iotdb]

2024-06-11 Thread via GitHub


MarcosZyk commented on code in PR #12707:
URL: https://github.com/apache/iotdb/pull/12707#discussion_r1634535757


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/ITableDeviceSchemaValidation.java:
##
@@ -0,0 +1,39 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.iotdb.db.queryengine.plan.relational.metadata;
+
+import java.util.List;
+
+/**
+ * This class acts as a request for device schema validation and defines the 
necessary information
+ * interfaces.
+ */
+public interface ITableDeviceSchemaValidation {
+
+  String getDatabase();
+
+  String getTableName();
+
+  List getDeviceIdList();
+
+  List getAttributeColumnNameList();
+
+  List> getAttributeValue();

Review Comment:
   Row based.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] [Table Model] Schema Validation Interface [iotdb]

2024-06-11 Thread via GitHub


JackieTien97 commented on code in PR #12707:
URL: https://github.com/apache/iotdb/pull/12707#discussion_r1634514022


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/Metadata.java:
##
@@ -67,4 +68,29 @@ List indexScan(
   QualifiedObjectName tableName,
   List expressionList,
   List attributeColumns);
+
+  /**
+   * This method is used for table column validation and should be invoked 
before device validation.
+   *
+   * This method return all the existing column schemas in the target table.
+   *
+   * When table or column is missing, this method will execute auto 
creation.
+   *
+   * When using SQL, the columnSchemaList could be null and there won't be 
any validation.
+   *
+   * When the input dataType or category of one column is null, the column 
cannot be auto
+   * created.
+   */
+  TableSchema validateTableHeaderSchema(
+  String database, TableSchema tableSchema, MPPQueryContext context);
+
+  /**
+   * This method is used for table device validation and should be invoked 
after column validation.
+   *
+   * When device id is missing, this method will execute auto creation.
+   *
+   * When device attribute is missing or different from that stored in 
IoTDB, the attribute will
+   * be auto upsert.
+   */
+  void validateDeviceSchema(ITableDeviceSchemaValidation schemaValidation, 
MPPQueryContext context);

Review Comment:
   think about partial insert, how to return info to caller about:
   1. auto create failed(because auto_create is false or other reasons like 
exceed device limit)
   2. auto create succeed or this device already exists before.



##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/Metadata.java:
##
@@ -67,4 +68,29 @@ List indexScan(
   QualifiedObjectName tableName,
   List expressionList,
   List attributeColumns);
+
+  /**
+   * This method is used for table column validation and should be invoked 
before device validation.
+   *
+   * This method return all the existing column schemas in the target table.
+   *
+   * When table or column is missing, this method will execute auto 
creation.
+   *
+   * When using SQL, the columnSchemaList could be null and there won't be 
any validation.
+   *
+   * When the input dataType or category of one column is null, the column 
cannot be auto
+   * created.
+   */
+  TableSchema validateTableHeaderSchema(

Review Comment:
   what if schema validation failed? dataType miss match? throw what kind of 
exception?



##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/Metadata.java:
##
@@ -67,4 +68,29 @@ List indexScan(
   QualifiedObjectName tableName,
   List expressionList,
   List attributeColumns);
+
+  /**
+   * This method is used for table column validation and should be invoked 
before device validation.
+   *
+   * This method return all the existing column schemas in the target table.
+   *
+   * When table or column is missing, this method will execute auto 
creation.
+   *
+   * When using SQL, the columnSchemaList could be null and there won't be 
any validation.
+   *
+   * When the input dataType or category of one column is null, the column 
cannot be auto
+   * created.
+   */
+  TableSchema validateTableHeaderSchema(

Review Comment:
   What if auto create is false? So I think should return 
Optional, if we cannot auto craete this table we just return 
Optinal.empty()



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Update pom.xml to fix security issue [iotdb]

2024-06-11 Thread via GitHub


codecov[bot] commented on PR #12705:
URL: https://github.com/apache/iotdb/pull/12705#issuecomment-2160218071

   ## 
[Codecov](https://app.codecov.io/gh/apache/iotdb/pull/12705?dropdown=coverage=pr=h1_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 Report
   All modified and coverable lines are covered by tests :white_check_mark:
   > Project coverage is 42.09%. Comparing base 
[(`ab9347b`)](https://app.codecov.io/gh/apache/iotdb/commit/ab9347bfde9053d574466303f298273ecd1cb5b8?dropdown=coverage=desc_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache)
 to head 
[(`4bd0a8b`)](https://app.codecov.io/gh/apache/iotdb/commit/4bd0a8b50ee437a21d2cb3f64a8edbb207f7ac49?dropdown=coverage=desc_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   
   
   Additional details and impacted files
   
   
   ```diff
   @@ Coverage Diff  @@
   ## master   #12705  +/-   ##
   
   - Coverage 42.10%   42.09%   -0.01% 
 Complexity   71   71  
   
 Files  3261 3261  
 Lines205655   205655  
 Branches  2452124521  
   
   - Hits  8658386578   -5 
   - Misses   119072   119077   +5 
   ```
   
   
   
   
   
   [:umbrella: View full report in Codecov by 
Sentry](https://app.codecov.io/gh/apache/iotdb/pull/12705?dropdown=coverage=pr=continue_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   
   :loudspeaker: Have feedback on the report? [Share it 
here](https://about.codecov.io/codecov-pr-comment-feedback/?utm_medium=referral_source=github_content=comment_campaign=pr+comments_term=apache).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] [Table Model] Schema Validation Interface [iotdb]

2024-06-11 Thread via GitHub


JackieTien97 commented on code in PR #12707:
URL: https://github.com/apache/iotdb/pull/12707#discussion_r1634495465


##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/ITableDeviceSchemaValidation.java:
##
@@ -0,0 +1,39 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.iotdb.db.queryengine.plan.relational.metadata;
+
+import java.util.List;
+
+/**
+ * This class acts as a request for device schema validation and defines the 
necessary information
+ * interfaces.
+ */
+public interface ITableDeviceSchemaValidation {
+
+  String getDatabase();
+
+  String getTableName();
+
+  List getDeviceIdList();
+
+  List getAttributeColumnNameList();
+
+  List> getAttributeValue();

Review Comment:
   column-based or row-based?



##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/ITableDeviceSchemaValidation.java:
##
@@ -0,0 +1,39 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.iotdb.db.queryengine.plan.relational.metadata;
+
+import java.util.List;
+
+/**
+ * This class acts as a request for device schema validation and defines the 
necessary information
+ * interfaces.
+ */
+public interface ITableDeviceSchemaValidation {

Review Comment:
   add java doc for each method and examples



##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/ITableDeviceSchemaValidation.java:
##
@@ -0,0 +1,39 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.iotdb.db.queryengine.plan.relational.metadata;
+
+import java.util.List;
+
+/**
+ * This class acts as a request for device schema validation and defines the 
necessary information
+ * interfaces.
+ */
+public interface ITableDeviceSchemaValidation {
+
+  String getDatabase();
+
+  String getTableName();
+
+  List getDeviceIdList();

Review Comment:
   List will be better? If we extend idcolumns to allow other types.



##
iotdb-core/datanode/src/main/java/org/apache/iotdb/db/queryengine/plan/relational/metadata/ITableDeviceSchemaValidation.java:
##
@@ -0,0 +1,39 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * 

Re: [PR] Support WAL Compression [iotdb]

2024-06-11 Thread via GitHub


sonarcloud[bot] commented on PR #12476:
URL: https://github.com/apache/iotdb/pull/12476#issuecomment-2160197201

   ## [![Quality Gate 
Failed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-failed-20px.png
 'Quality Gate 
Failed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12476) 
**Quality Gate failed**  
   Failed conditions  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/failed-16px.png
 '') [0.0% Coverage on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12476=new_coverage=list)
 (required ≥ 80%)  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12476)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] [Table Model] Schema Validation Interface [iotdb]

2024-06-11 Thread via GitHub


MarcosZyk opened a new pull request, #12707:
URL: https://github.com/apache/iotdb/pull/12707

   ## Description
   
   
   ### Content1 ...
   
   ### Content2 ...
   
   ### Content3 ...
   
   
   
   
   
   
   
   
   
   
   
   
   This PR has:
   - [ ] been self-reviewed.
   - [ ] concurrent read
   - [ ] concurrent write
   - [ ] concurrent read and write 
   - [ ] added documentation for new or modified features or behaviors.
   - [ ] added Javadocs for most classes and all non-trivial methods. 
   - [ ] added or updated version, __license__, or notice information
   - [ ] added comments explaining the "why" and the intent of the code 
wherever would not be obvious 
 for an unfamiliar reader.
   - [ ] added unit tests or modified existing tests to cover new code paths, 
ensuring the threshold 
 for code coverage.
   - [ ] added integration tests.
   - [ ] been tested in a test IoTDB cluster.
   
   
   
   
   
   # Key changed/added classes (or packages if there are too many classes) 
in this PR
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Support WAL Compression [iotdb]

2024-06-11 Thread via GitHub


sonarcloud[bot] commented on PR #12476:
URL: https://github.com/apache/iotdb/pull/12476#issuecomment-2160172454

   ## [![Quality Gate 
Failed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-failed-20px.png
 'Quality Gate 
Failed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12476) 
**Quality Gate failed**  
   Failed conditions  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/failed-16px.png
 '') [0.0% Coverage on New 
Code](https://sonarcloud.io/component_measures?id=apache_iotdb=12476=new_coverage=list)
 (required ≥ 80%)  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12476)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] Replenish effective mode in iotdb-system.properties [iotdb]

2024-06-11 Thread via GitHub


shuwenwei opened a new pull request, #12706:
URL: https://github.com/apache/iotdb/pull/12706

   ## Description
   1. Replenish effective mode in iotdb-system.properties
   2. Remove '\r' in iotdb-system.properties


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] [Table Model] Implement table device cache [iotdb]

2024-06-11 Thread via GitHub


MarcosZyk merged PR #12702:
URL: https://github.com/apache/iotdb/pull/12702


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Update pom.xml to fix security issue [iotdb]

2024-06-11 Thread via GitHub


sonarcloud[bot] commented on PR #12705:
URL: https://github.com/apache/iotdb/pull/12705#issuecomment-2160126628

   ## [![Quality Gate 
Passed](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/checks/QualityGateBadge/qg-passed-20px.png
 'Quality Gate 
Passed')](https://sonarcloud.io/dashboard?id=apache_iotdb=12705) 
**Quality Gate passed**  
   Issues  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0 New 
issues](https://sonarcloud.io/project/issues?id=apache_iotdb=12705=false=true)
  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/accepted-16px.png
 '') [0 Accepted 
issues](https://sonarcloud.io/project/issues?id=apache_iotdb=12705=WONTFIX)
   
   Measures  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/passed-16px.png
 '') [0 Security 
Hotspots](https://sonarcloud.io/project/security_hotspots?id=apache_iotdb=12705=false=true)
  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/no-data-16px.png
 '') No data about Coverage  
   
![](https://sonarsource.github.io/sonarcloud-github-static-resources/v2/common/no-data-16px.png
 '') No data about Duplication  
 
   [See analysis details on 
SonarCloud](https://sonarcloud.io/dashboard?id=apache_iotdb=12705)
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] 1、修改了apache官网底部版权信息 2、修改“安装包获取文件名(IoTDB-Get ->IoTDB-Package) 3、修改“资源优化”内容 [iotdb-docs]

2024-06-11 Thread via GitHub


mal117 opened a new pull request, #245:
URL: https://github.com/apache/iotdb-docs/pull/245

   (no comment)


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] Update pom.xml to fix security issue [iotdb]

2024-06-11 Thread via GitHub


HTHou opened a new pull request, #12705:
URL: https://github.com/apache/iotdb/pull/12705

   ## Description
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] Pipe: Fixed NPE in pattern parsing & added logs in reportable subtask's intermediate attempts [iotdb]

2024-06-11 Thread via GitHub


Caideyipi opened a new pull request, #12704:
URL: https://github.com/apache/iotdb/pull/12704

   ## Description
   As the title said.
   
   
   
   
   
   
   
   
   
   
   
   
   This PR has:
   - [ ] been self-reviewed.
   - [ ] concurrent read
   - [ ] concurrent write
   - [ ] concurrent read and write 
   - [ ] added documentation for new or modified features or behaviors.
   - [ ] added Javadocs for most classes and all non-trivial methods. 
   - [ ] added or updated version, __license__, or notice information
   - [ ] added comments explaining the "why" and the intent of the code 
wherever would not be obvious 
 for an unfamiliar reader.
   - [ ] added unit tests or modified existing tests to cover new code paths, 
ensuring the threshold 
 for code coverage.
   - [ ] added integration tests.
   - [ ] been tested in a test IoTDB cluster.
   
   
   
   
   
   # Key changed/added classes (or packages if there are too many classes) 
in this PR
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] Perfect methods of IAnalysis to adapt the write process of table model [iotdb]

2024-06-11 Thread via GitHub


JackieTien97 merged PR #12698:
URL: https://github.com/apache/iotdb/pull/12698


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] [Table Model] Implement table device cache [iotdb]

2024-06-11 Thread via GitHub


MarcosZyk opened a new pull request, #12702:
URL: https://github.com/apache/iotdb/pull/12702

   ## Description
   
   Implement table device cache based on DualKeyCache with db.table as first 
key and device id as second key and device attribute as cache value.
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: reviews-unsubscr...@iotdb.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



  1   2   3   4   5   6   7   8   9   10   >