You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iotdb.apache.org by le...@apache.org on 2022/02/14 05:18:57 UTC

[iotdb] branch research/M4-visualization updated: add

This is an automated email from the ASF dual-hosted git repository.

leirui pushed a commit to branch research/M4-visualization
in repository https://gitbox.apache.org/repos/asf/iotdb.git


The following commit(s) were added to refs/heads/research/M4-visualization by this push:
     new 8cfec5a  add
8cfec5a is described below

commit 8cfec5ab2fb7482061942131aaf8e73206f71fd4
Author: Lei Rui <10...@qq.com>
AuthorDate: Mon Feb 14 13:06:30 2022 +0800

    add
---
 .gitignore                                         |       2 +-
 .../org/apache/iotdb/DataMigrationExample.java     |     186 -
 .../src/main/java/org/apache/iotdb/README.md       |      35 +
 .../org/apache/iotdb/SessionConcurrentExample.java |     198 -
 .../main/java/org/apache/iotdb/SessionExample.java |     674 -
 .../java/org/apache/iotdb/SessionPoolExample.java  |     121 -
 .../org/apache/iotdb/bash/run-BallSpeed-exp.sh     |    1573 +
 .../main/java/org/apache/iotdb/bash/run-KOB-exp.sh |    1579 +
 .../java/org/apache/iotdb/bash/run-MF03-exp.sh     |    1572 +
 .../java/org/apache/iotdb/bash/run-RcvTime-exp.sh  |    1571 +
 .../java/org/apache/iotdb/datasets/BallSpeed.csv   | 1200000 ++++++++++
 .../main/java/org/apache/iotdb/datasets/KOB.csv    | 1943180 +++++++++++++++++
 .../main/java/org/apache/iotdb/datasets/MF03.csv   | 1076102 +++++++++
 .../java/org/apache/iotdb/datasets/RcvTime.csv     | 1330764 +++++++++++
 .../org/apache/iotdb/queryExp/QueryBallSpeed.java  |     111 +
 .../java/org/apache/iotdb/queryExp/QueryKOB.java   |     111 +
 .../java/org/apache/iotdb/queryExp/QueryMF03.java  |     111 +
 .../org/apache/iotdb/queryExp/QueryRcvTime.java    |     111 +
 .../apache/iotdb/tools/AnalyzeChunkInTsFile.java   |      39 +
 .../java/org/apache/iotdb/tools/ProcessResult.java |      77 +
 .../apache/iotdb/tools/QueryBallSpeed-0.12.4.jar   |     Bin 0 -> 23907294 bytes
 .../org/apache/iotdb/tools/QueryKOB-0.12.4.jar     |     Bin 0 -> 23907239 bytes
 .../org/apache/iotdb/tools/QueryMF03-0.12.4.jar    |     Bin 0 -> 23907249 bytes
 .../org/apache/iotdb/tools/QueryRcvTime-0.12.4.jar |     Bin 0 -> 23907277 bytes
 .../org/apache/iotdb/tools/SumResultUnify.java     |      36 +
 .../apache/iotdb/tools/WriteBallSpeed-0.12.4.jar   |     Bin 0 -> 23907291 bytes
 .../org/apache/iotdb/tools/WriteKOB-0.12.4.jar     |     Bin 0 -> 23907239 bytes
 .../org/apache/iotdb/tools/WriteMF03-0.12.4.jar    |     Bin 0 -> 23907245 bytes
 .../org/apache/iotdb/tools/WriteRcvTime-0.12.4.jar |     Bin 0 -> 23907276 bytes
 .../iotdb/tools/iotdb-engine-example.properties    |     740 +
 .../org/apache/iotdb/tools/query_experiment.sh     |      12 +
 .../src/main/java/org/apache/iotdb/tools/tool.sh   |      12 +
 .../iotdb/writeData/ExtractBallSpeedData.java      |      59 +
 .../org/apache/iotdb/writeData/ExtractKOBData.java |      46 +
 .../apache/iotdb/writeData/ExtractMF03Data.java    |     117 +
 .../apache/iotdb/writeData/ExtractRcvTimeData.java |      84 +
 .../apache/iotdb/writeData/OverlapGenerator.java   |     104 +
 .../org/apache/iotdb/writeData/WriteBallSpeed.java |     120 +
 .../java/org/apache/iotdb/writeData/WriteKOB.java  |     113 +
 .../java/org/apache/iotdb/writeData/WriteMF03.java |     112 +
 .../org/apache/iotdb/writeData/WriteRcvTime.java   |     113 +
 41 files changed, 5558605 insertions(+), 1180 deletions(-)

diff --git a/.gitignore b/.gitignore
index d8e8b76..61879ee 100644
--- a/.gitignore
+++ b/.gitignore
@@ -43,7 +43,7 @@ tsfile-jdbc/src/main/resources/output/queryRes.csv
 #src/test/resources/logback.xml
 
 ### CSV ###
-*.csv
+# *.csv
 ### Maven ###
 grafana/target/
 !grafana/.mvn/wrapper/maven-wrapper.jar
diff --git a/example/session/src/main/java/org/apache/iotdb/DataMigrationExample.java b/example/session/src/main/java/org/apache/iotdb/DataMigrationExample.java
deleted file mode 100644
index e880ba9..0000000
--- a/example/session/src/main/java/org/apache/iotdb/DataMigrationExample.java
+++ /dev/null
@@ -1,186 +0,0 @@
-/*
- * 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;
-
-import org.apache.iotdb.rpc.IoTDBConnectionException;
-import org.apache.iotdb.rpc.StatementExecutionException;
-import org.apache.iotdb.session.SessionDataSet.DataIterator;
-import org.apache.iotdb.session.pool.SessionDataSetWrapper;
-import org.apache.iotdb.session.pool.SessionPool;
-import org.apache.iotdb.tsfile.file.metadata.enums.TSDataType;
-import org.apache.iotdb.tsfile.read.common.Path;
-import org.apache.iotdb.tsfile.utils.Binary;
-import org.apache.iotdb.tsfile.write.record.Tablet;
-import org.apache.iotdb.tsfile.write.schema.MeasurementSchema;
-
-import java.util.ArrayList;
-import java.util.List;
-import java.util.concurrent.Callable;
-import java.util.concurrent.ExecutionException;
-import java.util.concurrent.ExecutorService;
-import java.util.concurrent.Executors;
-import java.util.concurrent.Future;
-
-/**
- * Migrate all data belongs to a path from one IoTDB to another IoTDB Each thread migrate one
- * series, the concurrent thread can be configured by concurrency
- *
- * <p>This example is migrating all timeseries from a local IoTDB with 6667 port to a local IoTDB
- * with 6668 port
- */
-public class DataMigrationExample {
-
-  // used to read data from the source IoTDB
-  private static SessionPool readerPool;
-  // used to write data into the destination IoTDB
-  private static SessionPool writerPool;
-  // concurrent thread of loading timeseries data
-  private static int concurrency = 5;
-
-  public static void main(String[] args)
-      throws IoTDBConnectionException, StatementExecutionException, ExecutionException,
-          InterruptedException {
-
-    ExecutorService executorService = Executors.newFixedThreadPool(2 * concurrency + 1);
-
-    String path = "root";
-
-    if (args.length != 0) {
-      path = args[0];
-    }
-
-    readerPool = new SessionPool("127.0.0.1", 6667, "root", "root", concurrency);
-    writerPool = new SessionPool("127.0.0.1", 6668, "root", "root", concurrency);
-
-    SessionDataSetWrapper schemaDataSet =
-        readerPool.executeQueryStatement("count timeseries " + path);
-    DataIterator schemaIter = schemaDataSet.iterator();
-    int total;
-    if (schemaIter.next()) {
-      total = schemaIter.getInt(1);
-      System.out.println("Total timeseries: " + total);
-    } else {
-      System.out.println("Can not get timeseries schema");
-      System.exit(1);
-    }
-    readerPool.closeResultSet(schemaDataSet);
-
-    schemaDataSet = readerPool.executeQueryStatement("show timeseries " + path);
-    schemaIter = schemaDataSet.iterator();
-
-    List<Future> futureList = new ArrayList<>();
-    int count = 0;
-    while (schemaIter.next()) {
-      count++;
-      Path currentPath = new Path(schemaIter.getString("timeseries"), true);
-      Future future =
-          executorService.submit(
-              new LoadThread(
-                  count, currentPath, TSDataType.valueOf(schemaIter.getString("dataType"))));
-      futureList.add(future);
-    }
-    readerPool.closeResultSet(schemaDataSet);
-
-    for (Future future : futureList) {
-      future.get();
-    }
-    executorService.shutdown();
-
-    readerPool.close();
-    writerPool.close();
-  }
-
-  static class LoadThread implements Callable<Void> {
-
-    String device;
-    String measurement;
-    Path series;
-    TSDataType dataType;
-    Tablet tablet;
-    int i;
-
-    public LoadThread(int i, Path series, TSDataType dataType) {
-      this.i = i;
-      this.device = series.getDevice();
-      this.measurement = series.getMeasurement();
-      this.dataType = dataType;
-      this.series = series;
-    }
-
-    @Override
-    public Void call() {
-
-      List<MeasurementSchema> schemaList = new ArrayList<>();
-      schemaList.add(new MeasurementSchema(measurement, dataType));
-      tablet = new Tablet(device, schemaList, 300000);
-      SessionDataSetWrapper dataSet = null;
-
-      try {
-
-        dataSet =
-            readerPool.executeQueryStatement(
-                String.format("select %s from %s", measurement, device));
-
-        DataIterator dataIter = dataSet.iterator();
-        while (dataIter.next()) {
-          int row = tablet.rowSize++;
-          tablet.timestamps[row] = dataIter.getLong(1);
-          switch (dataType) {
-            case BOOLEAN:
-              ((boolean[]) tablet.values[0])[row] = dataIter.getBoolean(2);
-              break;
-            case INT32:
-              ((int[]) tablet.values[0])[row] = dataIter.getInt(2);
-              break;
-            case INT64:
-              ((long[]) tablet.values[0])[row] = dataIter.getLong(2);
-              break;
-            case FLOAT:
-              ((float[]) tablet.values[0])[row] = dataIter.getFloat(2);
-              break;
-            case DOUBLE:
-              ((double[]) tablet.values[0])[row] = dataIter.getDouble(2);
-              break;
-            case TEXT:
-              ((Binary[]) tablet.values[0])[row] = new Binary(dataIter.getString(2));
-              break;
-          }
-          if (tablet.rowSize == tablet.getMaxRowNumber()) {
-            writerPool.insertTablet(tablet, true);
-            tablet.reset();
-          }
-        }
-        if (tablet.rowSize != 0) {
-          writerPool.insertTablet(tablet);
-          tablet.reset();
-        }
-
-      } catch (Exception e) {
-        System.out.println(
-            "Loading the " + i + "-th timeseries: " + series + " failed " + e.getMessage());
-        return null;
-      } finally {
-        readerPool.closeResultSet(dataSet);
-      }
-
-      System.out.println("Loading the " + i + "-th timeseries: " + series + " success");
-      return null;
-    }
-  }
-}
diff --git a/example/session/src/main/java/org/apache/iotdb/README.md b/example/session/src/main/java/org/apache/iotdb/README.md
new file mode 100644
index 0000000..0452767
--- /dev/null
+++ b/example/session/src/main/java/org/apache/iotdb/README.md
@@ -0,0 +1,35 @@
+# Experiment Guidance
+Take the BallSpeed experiment as an example.
+
+Before running `run-BallSpeed-exp.sh`, prepare the workspace as follows:
+```
+/data3/raw_data/rl
+---- BallSpeed
+---- ---- BallSpeed.csv
+---- ---- OverlapGenerator.class
+---- ---- OverlapGenerator.java
+/data3/ruilei/rl/dataSpace
+/data3/ruilei/rl/iotdb-server-0.12.4
+/data3/ruilei/rl/iotdb-engine-example.properties
+/data3/ruilei/rl/tool.sh
+/data3/ruilei/rl/ProcessResult.class
+/data3/ruilei/rl/ProcessResult.java
+/data3/ruilei/rl/SumResultUnify.class
+/data3/ruilei/rl/SumResultUnify.java
+/data3/ruilei/rl/BallSpeed_testspace
+---- WriteBallSpeed-0.12.4.jar
+---- QueryBallSpeed-0.12.4.jar
+---- query_experiment.sh [make sure updated the Query jar path]
+```
+
+And then you can run `run-BallSpeed-exp.sh` to perform the BallSpeed experiment.
+
+The results are in:
+```
+FOR EXP1: BallSpeed_testspace/O_10_10_D_0_0/vary_w/result.csv
+FOR EPX2: BallSpeed_testspace/O_10_10_D_0_0/vary_tqe/result.csv
+FOR EXP3: BallSpeed_testspace/exp3.csv
+FOR EXP4: BallSpeed_testspace/exp4.csv
+FOR EXP5: BallSpeed_testspace/exp5.csv
+```
+
diff --git a/example/session/src/main/java/org/apache/iotdb/SessionConcurrentExample.java b/example/session/src/main/java/org/apache/iotdb/SessionConcurrentExample.java
deleted file mode 100644
index fb0f793..0000000
--- a/example/session/src/main/java/org/apache/iotdb/SessionConcurrentExample.java
+++ /dev/null
@@ -1,198 +0,0 @@
-/*
- * 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;
-
-import org.apache.iotdb.rpc.IoTDBConnectionException;
-import org.apache.iotdb.rpc.StatementExecutionException;
-import org.apache.iotdb.session.Session;
-import org.apache.iotdb.tsfile.file.metadata.enums.CompressionType;
-import org.apache.iotdb.tsfile.file.metadata.enums.TSDataType;
-import org.apache.iotdb.tsfile.file.metadata.enums.TSEncoding;
-import org.apache.iotdb.tsfile.write.record.Tablet;
-import org.apache.iotdb.tsfile.write.schema.MeasurementSchema;
-
-import java.util.ArrayList;
-import java.util.Collections;
-import java.util.List;
-import java.util.Random;
-import java.util.concurrent.CountDownLatch;
-import java.util.concurrent.ExecutorService;
-import java.util.concurrent.Executors;
-
-public class SessionConcurrentExample {
-
-  private static final int sgNum = 20;
-  private static final int deviceNum = 100;
-  private static final int parallelDegreeForOneSG = 3;
-
-  public static void main(String[] args)
-      throws IoTDBConnectionException, StatementExecutionException {
-
-    Session session = new Session("127.0.0.1", 6667, "root", "root");
-    session.open(false);
-    createTemplate(session);
-    session.close();
-
-    CountDownLatch latch = new CountDownLatch(sgNum * parallelDegreeForOneSG);
-    ExecutorService es = Executors.newFixedThreadPool(sgNum * parallelDegreeForOneSG);
-
-    for (int i = 0; i < sgNum * parallelDegreeForOneSG; i++) {
-      int currentIndex = i;
-      es.execute(() -> concurrentOperation(latch, currentIndex));
-    }
-
-    es.shutdown();
-
-    try {
-      latch.await();
-    } catch (InterruptedException e) {
-      e.printStackTrace();
-    }
-  }
-
-  private static void concurrentOperation(CountDownLatch latch, int currentIndex) {
-
-    Session tmpSession = new Session("127.0.0.1", 6667, "root", "root");
-    try {
-      tmpSession.open(false);
-    } catch (IoTDBConnectionException e) {
-      e.printStackTrace();
-    }
-
-    for (int j = 0; j < deviceNum; j++) {
-      try {
-        insertTablet(
-            tmpSession, String.format("root.sg_%d.d_%d", currentIndex / parallelDegreeForOneSG, j));
-      } catch (IoTDBConnectionException | StatementExecutionException e) {
-        e.printStackTrace();
-      }
-    }
-
-    try {
-      tmpSession.close();
-    } catch (IoTDBConnectionException e) {
-      e.printStackTrace();
-    }
-
-    latch.countDown();
-  }
-
-  private static void createTemplate(Session session)
-      throws IoTDBConnectionException, StatementExecutionException {
-    List<List<String>> measurementList = new ArrayList<>();
-    measurementList.add(Collections.singletonList("s1"));
-    measurementList.add(Collections.singletonList("s2"));
-    measurementList.add(Collections.singletonList("s3"));
-
-    List<List<TSDataType>> dataTypeList = new ArrayList<>();
-    dataTypeList.add(Collections.singletonList(TSDataType.INT64));
-    dataTypeList.add(Collections.singletonList(TSDataType.INT64));
-    dataTypeList.add(Collections.singletonList(TSDataType.INT64));
-
-    List<List<TSEncoding>> encodingList = new ArrayList<>();
-    encodingList.add(Collections.singletonList(TSEncoding.RLE));
-    encodingList.add(Collections.singletonList(TSEncoding.RLE));
-    encodingList.add(Collections.singletonList(TSEncoding.RLE));
-
-    List<CompressionType> compressionTypes = new ArrayList<>();
-    for (int i = 0; i < 3; i++) {
-      compressionTypes.add(CompressionType.SNAPPY);
-    }
-    List<String> schemaNames = new ArrayList<>();
-    schemaNames.add("s1");
-    schemaNames.add("s2");
-    schemaNames.add("s3");
-
-    session.createSchemaTemplate(
-        "template1", schemaNames, measurementList, dataTypeList, encodingList, compressionTypes);
-    for (int i = 0; i < sgNum; i++) {
-      session.setSchemaTemplate("template1", "root.sg_" + i);
-    }
-  }
-
-  /**
-   * insert the data of a device. For each timestamp, the number of measurements is the same.
-   *
-   * <p>Users need to control the count of Tablet and write a batch when it reaches the maxBatchSize
-   */
-  private static void insertTablet(Session session, String deviceId)
-      throws IoTDBConnectionException, StatementExecutionException {
-    /*
-     * A Tablet example:
-     *      device1
-     * time s1, s2, s3
-     * 1,   1,  1,  1
-     * 2,   2,  2,  2
-     * 3,   3,  3,  3
-     */
-    // The schema of measurements of one device
-    // only measurementId and data type in MeasurementSchema take effects in Tablet
-    List<MeasurementSchema> schemaList = new ArrayList<>();
-    schemaList.add(new MeasurementSchema("s1", TSDataType.INT64));
-    schemaList.add(new MeasurementSchema("s2", TSDataType.INT64));
-    schemaList.add(new MeasurementSchema("s3", TSDataType.INT64));
-
-    Tablet tablet = new Tablet(deviceId, schemaList, 100);
-
-    // Method 1 to add tablet data
-    long timestamp = System.currentTimeMillis();
-
-    for (long row = 0; row < 100; row++) {
-      int rowIndex = tablet.rowSize++;
-      tablet.addTimestamp(rowIndex, timestamp);
-      for (int s = 0; s < 3; s++) {
-        long value = new Random().nextLong();
-        tablet.addValue(schemaList.get(s).getMeasurementId(), rowIndex, value);
-      }
-      if (tablet.rowSize == tablet.getMaxRowNumber()) {
-        session.insertTablet(tablet, true);
-        tablet.reset();
-      }
-      timestamp++;
-    }
-
-    if (tablet.rowSize != 0) {
-      session.insertTablet(tablet);
-      tablet.reset();
-    }
-
-    // Method 2 to add tablet data
-    long[] timestamps = tablet.timestamps;
-    Object[] values = tablet.values;
-
-    for (long time = 0; time < 100; time++) {
-      int row = tablet.rowSize++;
-      timestamps[row] = time;
-      for (int i = 0; i < 3; i++) {
-        long[] sensor = (long[]) values[i];
-        sensor[row] = i;
-      }
-      if (tablet.rowSize == tablet.getMaxRowNumber()) {
-        session.insertTablet(tablet, true);
-        tablet.reset();
-      }
-    }
-
-    if (tablet.rowSize != 0) {
-      session.insertTablet(tablet);
-      tablet.reset();
-    }
-  }
-}
diff --git a/example/session/src/main/java/org/apache/iotdb/SessionExample.java b/example/session/src/main/java/org/apache/iotdb/SessionExample.java
deleted file mode 100644
index 623f813..0000000
--- a/example/session/src/main/java/org/apache/iotdb/SessionExample.java
+++ /dev/null
@@ -1,674 +0,0 @@
-/*
- * 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;
-
-import org.apache.iotdb.rpc.IoTDBConnectionException;
-import org.apache.iotdb.rpc.StatementExecutionException;
-import org.apache.iotdb.rpc.TSStatusCode;
-import org.apache.iotdb.session.Session;
-import org.apache.iotdb.session.SessionDataSet;
-import org.apache.iotdb.session.SessionDataSet.DataIterator;
-import org.apache.iotdb.tsfile.file.metadata.enums.CompressionType;
-import org.apache.iotdb.tsfile.file.metadata.enums.TSDataType;
-import org.apache.iotdb.tsfile.file.metadata.enums.TSEncoding;
-import org.apache.iotdb.tsfile.write.record.Tablet;
-import org.apache.iotdb.tsfile.write.schema.MeasurementSchema;
-
-import java.util.ArrayList;
-import java.util.Collections;
-import java.util.HashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.Random;
-
-@SuppressWarnings("squid:S106")
-public class SessionExample {
-
-  private static Session session;
-  private static Session sessionEnableRedirect;
-  private static final String ROOT_SG1_D1_S1 = "root.sg1.d1.s1";
-  private static final String ROOT_SG1_D1_S2 = "root.sg1.d1.s2";
-  private static final String ROOT_SG1_D1_S3 = "root.sg1.d1.s3";
-  private static final String ROOT_SG1_D1_S4 = "root.sg1.d1.s4";
-  private static final String ROOT_SG1_D1_S5 = "root.sg1.d1.s5";
-  private static final String ROOT_SG1_D1 = "root.sg1.d1";
-  private static final String LOCAL_HOST = "127.0.0.1";
-
-  public static void main(String[] args)
-      throws IoTDBConnectionException, StatementExecutionException {
-    session = new Session(LOCAL_HOST, 6667, "root", "root");
-    session.open(false);
-
-    // set session fetchSize
-    session.setFetchSize(10000);
-
-    try {
-      session.setStorageGroup("root.sg1");
-    } catch (StatementExecutionException e) {
-      if (e.getStatusCode() != TSStatusCode.PATH_ALREADY_EXIST_ERROR.getStatusCode()) {
-        throw e;
-      }
-    }
-
-    // createTemplate();
-    createTimeseries();
-    createMultiTimeseries();
-    insertRecord();
-    insertTablet();
-    insertTablets();
-    insertRecords();
-    nonQuery();
-    query();
-    queryWithTimeout();
-    rawDataQuery();
-    queryByIterator();
-    deleteData();
-    deleteTimeseries();
-    setTimeout();
-
-    sessionEnableRedirect = new Session(LOCAL_HOST, 6667, "root", "root");
-    sessionEnableRedirect.setEnableQueryRedirection(true);
-    sessionEnableRedirect.open(false);
-
-    // set session fetchSize
-    sessionEnableRedirect.setFetchSize(10000);
-
-    insertRecord4Redirect();
-    query4Redirect();
-    sessionEnableRedirect.close();
-    session.close();
-  }
-
-  private static void createTimeseries()
-      throws IoTDBConnectionException, StatementExecutionException {
-
-    if (!session.checkTimeseriesExists(ROOT_SG1_D1_S1)) {
-      session.createTimeseries(
-          ROOT_SG1_D1_S1, TSDataType.INT64, TSEncoding.RLE, CompressionType.SNAPPY);
-    }
-    if (!session.checkTimeseriesExists(ROOT_SG1_D1_S2)) {
-      session.createTimeseries(
-          ROOT_SG1_D1_S2, TSDataType.INT64, TSEncoding.RLE, CompressionType.SNAPPY);
-    }
-    if (!session.checkTimeseriesExists(ROOT_SG1_D1_S3)) {
-      session.createTimeseries(
-          ROOT_SG1_D1_S3, TSDataType.INT64, TSEncoding.RLE, CompressionType.SNAPPY);
-    }
-
-    // create timeseries with tags and attributes
-    if (!session.checkTimeseriesExists(ROOT_SG1_D1_S4)) {
-      Map<String, String> tags = new HashMap<>();
-      tags.put("tag1", "v1");
-      Map<String, String> attributes = new HashMap<>();
-      tags.put("description", "v1");
-      session.createTimeseries(
-          ROOT_SG1_D1_S4,
-          TSDataType.INT64,
-          TSEncoding.RLE,
-          CompressionType.SNAPPY,
-          null,
-          tags,
-          attributes,
-          "temperature");
-    }
-
-    // create timeseries with SDT property, SDT will take place when flushing
-    if (!session.checkTimeseriesExists(ROOT_SG1_D1_S5)) {
-      // COMPDEV is required
-      // COMPMAXTIME and COMPMINTIME are optional and their unit is ms
-      Map<String, String> props = new HashMap<>();
-      props.put("LOSS", "sdt");
-      props.put("COMPDEV", "0.01");
-      props.put("COMPMINTIME", "2");
-      props.put("COMPMAXTIME", "10");
-      session.createTimeseries(
-          ROOT_SG1_D1_S5,
-          TSDataType.INT64,
-          TSEncoding.RLE,
-          CompressionType.SNAPPY,
-          props,
-          null,
-          null,
-          null);
-    }
-  }
-
-  private static void createMultiTimeseries()
-      throws IoTDBConnectionException, StatementExecutionException {
-
-    if (!session.checkTimeseriesExists("root.sg1.d2.s1")
-        && !session.checkTimeseriesExists("root.sg1.d2.s2")) {
-      List<String> paths = new ArrayList<>();
-      paths.add("root.sg1.d2.s1");
-      paths.add("root.sg1.d2.s2");
-      List<TSDataType> tsDataTypes = new ArrayList<>();
-      tsDataTypes.add(TSDataType.INT64);
-      tsDataTypes.add(TSDataType.INT64);
-      List<TSEncoding> tsEncodings = new ArrayList<>();
-      tsEncodings.add(TSEncoding.RLE);
-      tsEncodings.add(TSEncoding.RLE);
-      List<CompressionType> compressionTypes = new ArrayList<>();
-      compressionTypes.add(CompressionType.SNAPPY);
-      compressionTypes.add(CompressionType.SNAPPY);
-
-      List<Map<String, String>> tagsList = new ArrayList<>();
-      Map<String, String> tags = new HashMap<>();
-      tags.put("unit", "kg");
-      tagsList.add(tags);
-      tagsList.add(tags);
-
-      List<Map<String, String>> attributesList = new ArrayList<>();
-      Map<String, String> attributes = new HashMap<>();
-      attributes.put("minValue", "1");
-      attributes.put("maxValue", "100");
-      attributesList.add(attributes);
-      attributesList.add(attributes);
-
-      List<String> alias = new ArrayList<>();
-      alias.add("weight1");
-      alias.add("weight2");
-
-      session.createMultiTimeseries(
-          paths, tsDataTypes, tsEncodings, compressionTypes, null, tagsList, attributesList, alias);
-    }
-  }
-
-  private static void createTemplate()
-      throws IoTDBConnectionException, StatementExecutionException {
-    List<List<String>> measurementList = new ArrayList<>();
-    measurementList.add(Collections.singletonList("s1"));
-    measurementList.add(Collections.singletonList("s2"));
-    measurementList.add(Collections.singletonList("s3"));
-
-    List<List<TSDataType>> dataTypeList = new ArrayList<>();
-    dataTypeList.add(Collections.singletonList(TSDataType.INT64));
-    dataTypeList.add(Collections.singletonList(TSDataType.INT64));
-    dataTypeList.add(Collections.singletonList(TSDataType.INT64));
-
-    List<List<TSEncoding>> encodingList = new ArrayList<>();
-    encodingList.add(Collections.singletonList(TSEncoding.RLE));
-    encodingList.add(Collections.singletonList(TSEncoding.RLE));
-    encodingList.add(Collections.singletonList(TSEncoding.RLE));
-
-    List<CompressionType> compressionTypes = new ArrayList<>();
-    for (int i = 0; i < 3; i++) {
-      compressionTypes.add(CompressionType.SNAPPY);
-    }
-    List<String> schemaNames = new ArrayList<>();
-    schemaNames.add("s1");
-    schemaNames.add("s2");
-    schemaNames.add("s3");
-
-    session.createSchemaTemplate(
-        "template1", schemaNames, measurementList, dataTypeList, encodingList, compressionTypes);
-    session.setSchemaTemplate("template1", "root.sg1");
-  }
-
-  private static void insertRecord() throws IoTDBConnectionException, StatementExecutionException {
-    String deviceId = ROOT_SG1_D1;
-    List<String> measurements = new ArrayList<>();
-    List<TSDataType> types = new ArrayList<>();
-    measurements.add("s1");
-    measurements.add("s2");
-    measurements.add("s3");
-    types.add(TSDataType.INT64);
-    types.add(TSDataType.INT64);
-    types.add(TSDataType.INT64);
-
-    for (long time = 0; time < 100; time++) {
-      List<Object> values = new ArrayList<>();
-      values.add(1L);
-      values.add(2L);
-      values.add(3L);
-      session.insertRecord(deviceId, time, measurements, types, values);
-    }
-  }
-
-  private static void insertRecord4Redirect()
-      throws IoTDBConnectionException, StatementExecutionException {
-    for (int i = 0; i < 6; i++) {
-      for (int j = 0; j < 2; j++) {
-        String deviceId = "root.redirect" + i + ".d" + j;
-        List<String> measurements = new ArrayList<>();
-        measurements.add("s1");
-        measurements.add("s2");
-        measurements.add("s3");
-        List<TSDataType> types = new ArrayList<>();
-        types.add(TSDataType.INT64);
-        types.add(TSDataType.INT64);
-        types.add(TSDataType.INT64);
-
-        for (long time = 0; time < 5; time++) {
-          List<Object> values = new ArrayList<>();
-          values.add(1L + time);
-          values.add(2L + time);
-          values.add(3L + time);
-          session.insertRecord(deviceId, time, measurements, types, values);
-        }
-      }
-    }
-  }
-
-  private static void insertStrRecord()
-      throws IoTDBConnectionException, StatementExecutionException {
-    String deviceId = ROOT_SG1_D1;
-    List<String> measurements = new ArrayList<>();
-    measurements.add("s1");
-    measurements.add("s2");
-    measurements.add("s3");
-
-    for (long time = 0; time < 10; time++) {
-      List<String> values = new ArrayList<>();
-      values.add("1");
-      values.add("2");
-      values.add("3");
-      session.insertRecord(deviceId, time, measurements, values);
-    }
-  }
-
-  private static void insertRecordInObject()
-      throws IoTDBConnectionException, StatementExecutionException {
-    String deviceId = ROOT_SG1_D1;
-    List<String> measurements = new ArrayList<>();
-    List<TSDataType> types = new ArrayList<>();
-    measurements.add("s1");
-    measurements.add("s2");
-    measurements.add("s3");
-    types.add(TSDataType.INT64);
-    types.add(TSDataType.INT64);
-    types.add(TSDataType.INT64);
-
-    for (long time = 0; time < 100; time++) {
-      session.insertRecord(deviceId, time, measurements, types, 1L, 1L, 1L);
-    }
-  }
-
-  private static void insertRecords() throws IoTDBConnectionException, StatementExecutionException {
-    String deviceId = ROOT_SG1_D1;
-    List<String> measurements = new ArrayList<>();
-    measurements.add("s1");
-    measurements.add("s2");
-    measurements.add("s3");
-    List<String> deviceIds = new ArrayList<>();
-    List<List<String>> measurementsList = new ArrayList<>();
-    List<List<Object>> valuesList = new ArrayList<>();
-    List<Long> timestamps = new ArrayList<>();
-    List<List<TSDataType>> typesList = new ArrayList<>();
-
-    for (long time = 0; time < 500; time++) {
-      List<Object> values = new ArrayList<>();
-      List<TSDataType> types = new ArrayList<>();
-      values.add(1L);
-      values.add(2L);
-      values.add(3L);
-      types.add(TSDataType.INT64);
-      types.add(TSDataType.INT64);
-      types.add(TSDataType.INT64);
-
-      deviceIds.add(deviceId);
-      measurementsList.add(measurements);
-      valuesList.add(values);
-      typesList.add(types);
-      timestamps.add(time);
-      if (time != 0 && time % 100 == 0) {
-        session.insertRecords(deviceIds, timestamps, measurementsList, typesList, valuesList);
-        deviceIds.clear();
-        measurementsList.clear();
-        valuesList.clear();
-        typesList.clear();
-        timestamps.clear();
-      }
-    }
-
-    session.insertRecords(deviceIds, timestamps, measurementsList, typesList, valuesList);
-  }
-
-  /**
-   * insert the data of a device. For each timestamp, the number of measurements is the same.
-   *
-   * <p>Users need to control the count of Tablet and write a batch when it reaches the maxBatchSize
-   */
-  private static void insertTablet() throws IoTDBConnectionException, StatementExecutionException {
-    /*
-     * A Tablet example:
-     *      device1
-     * time s1, s2, s3
-     * 1,   1,  1,  1
-     * 2,   2,  2,  2
-     * 3,   3,  3,  3
-     */
-    // The schema of measurements of one device
-    // only measurementId and data type in MeasurementSchema take effects in Tablet
-    List<MeasurementSchema> schemaList = new ArrayList<>();
-    schemaList.add(new MeasurementSchema("s1", TSDataType.INT64));
-    schemaList.add(new MeasurementSchema("s2", TSDataType.INT64));
-    schemaList.add(new MeasurementSchema("s3", TSDataType.INT64));
-
-    Tablet tablet = new Tablet(ROOT_SG1_D1, schemaList, 100);
-
-    // Method 1 to add tablet data
-    long timestamp = System.currentTimeMillis();
-
-    for (long row = 0; row < 100; row++) {
-      int rowIndex = tablet.rowSize++;
-      tablet.addTimestamp(rowIndex, timestamp);
-      for (int s = 0; s < 3; s++) {
-        long value = new Random().nextLong();
-        tablet.addValue(schemaList.get(s).getMeasurementId(), rowIndex, value);
-      }
-      if (tablet.rowSize == tablet.getMaxRowNumber()) {
-        session.insertTablet(tablet, true);
-        tablet.reset();
-      }
-      timestamp++;
-    }
-
-    if (tablet.rowSize != 0) {
-      session.insertTablet(tablet);
-      tablet.reset();
-    }
-
-    // Method 2 to add tablet data
-    long[] timestamps = tablet.timestamps;
-    Object[] values = tablet.values;
-
-    for (long time = 0; time < 100; time++) {
-      int row = tablet.rowSize++;
-      timestamps[row] = time;
-      for (int i = 0; i < 3; i++) {
-        long[] sensor = (long[]) values[i];
-        sensor[row] = i;
-      }
-      if (tablet.rowSize == tablet.getMaxRowNumber()) {
-        session.insertTablet(tablet, true);
-        tablet.reset();
-      }
-    }
-
-    if (tablet.rowSize != 0) {
-      session.insertTablet(tablet);
-      tablet.reset();
-    }
-  }
-
-  private static void insertTablets() throws IoTDBConnectionException, StatementExecutionException {
-    // The schema of measurements of one device
-    // only measurementId and data type in MeasurementSchema take effects in Tablet
-    List<MeasurementSchema> schemaList = new ArrayList<>();
-    schemaList.add(new MeasurementSchema("s1", TSDataType.INT64));
-    schemaList.add(new MeasurementSchema("s2", TSDataType.INT64));
-    schemaList.add(new MeasurementSchema("s3", TSDataType.INT64));
-
-    Tablet tablet1 = new Tablet(ROOT_SG1_D1, schemaList, 100);
-    Tablet tablet2 = new Tablet("root.sg1.d2", schemaList, 100);
-    Tablet tablet3 = new Tablet("root.sg1.d3", schemaList, 100);
-
-    Map<String, Tablet> tabletMap = new HashMap<>();
-    tabletMap.put(ROOT_SG1_D1, tablet1);
-    tabletMap.put("root.sg1.d2", tablet2);
-    tabletMap.put("root.sg1.d3", tablet3);
-
-    // Method 1 to add tablet data
-    long timestamp = System.currentTimeMillis();
-    for (long row = 0; row < 100; row++) {
-      int row1 = tablet1.rowSize++;
-      int row2 = tablet2.rowSize++;
-      int row3 = tablet3.rowSize++;
-      tablet1.addTimestamp(row1, timestamp);
-      tablet2.addTimestamp(row2, timestamp);
-      tablet3.addTimestamp(row3, timestamp);
-      for (int i = 0; i < 3; i++) {
-        long value = new Random().nextLong();
-        tablet1.addValue(schemaList.get(i).getMeasurementId(), row1, value);
-        tablet2.addValue(schemaList.get(i).getMeasurementId(), row2, value);
-        tablet3.addValue(schemaList.get(i).getMeasurementId(), row3, value);
-      }
-      if (tablet1.rowSize == tablet1.getMaxRowNumber()) {
-        session.insertTablets(tabletMap, true);
-        tablet1.reset();
-        tablet2.reset();
-        tablet3.reset();
-      }
-      timestamp++;
-    }
-
-    if (tablet1.rowSize != 0) {
-      session.insertTablets(tabletMap, true);
-      tablet1.reset();
-      tablet2.reset();
-      tablet3.reset();
-    }
-
-    // Method 2 to add tablet data
-    long[] timestamps1 = tablet1.timestamps;
-    Object[] values1 = tablet1.values;
-    long[] timestamps2 = tablet2.timestamps;
-    Object[] values2 = tablet2.values;
-    long[] timestamps3 = tablet3.timestamps;
-    Object[] values3 = tablet3.values;
-
-    for (long time = 0; time < 100; time++) {
-      int row1 = tablet1.rowSize++;
-      int row2 = tablet2.rowSize++;
-      int row3 = tablet3.rowSize++;
-      timestamps1[row1] = time;
-      timestamps2[row2] = time;
-      timestamps3[row3] = time;
-      for (int i = 0; i < 3; i++) {
-        long[] sensor1 = (long[]) values1[i];
-        sensor1[row1] = i;
-        long[] sensor2 = (long[]) values2[i];
-        sensor2[row2] = i;
-        long[] sensor3 = (long[]) values3[i];
-        sensor3[row3] = i;
-      }
-      if (tablet1.rowSize == tablet1.getMaxRowNumber()) {
-        session.insertTablets(tabletMap, true);
-
-        tablet1.reset();
-        tablet2.reset();
-        tablet3.reset();
-      }
-    }
-
-    if (tablet1.rowSize != 0) {
-      session.insertTablets(tabletMap, true);
-      tablet1.reset();
-      tablet2.reset();
-      tablet3.reset();
-    }
-  }
-
-  private static void deleteData() throws IoTDBConnectionException, StatementExecutionException {
-    String path = ROOT_SG1_D1_S1;
-    long deleteTime = 99;
-    session.deleteData(path, deleteTime);
-  }
-
-  private static void deleteTimeseries()
-      throws IoTDBConnectionException, StatementExecutionException {
-    List<String> paths = new ArrayList<>();
-    paths.add(ROOT_SG1_D1_S1);
-    paths.add(ROOT_SG1_D1_S2);
-    paths.add(ROOT_SG1_D1_S3);
-    session.deleteTimeseries(paths);
-  }
-
-  private static void query() throws IoTDBConnectionException, StatementExecutionException {
-    SessionDataSet dataSet = session.executeQueryStatement("select * from root.sg1.d1");
-    System.out.println(dataSet.getColumnNames());
-    dataSet.setFetchSize(1024); // default is 10000
-    while (dataSet.hasNext()) {
-      System.out.println(dataSet.next());
-    }
-
-    dataSet.closeOperationHandle();
-  }
-
-  private static void query4Redirect()
-      throws IoTDBConnectionException, StatementExecutionException {
-    String selectPrefix = "select * from root.redirect";
-    for (int i = 0; i < 6; i++) {
-      SessionDataSet dataSet =
-          sessionEnableRedirect.executeQueryStatement(selectPrefix + i + ".d1");
-      System.out.println(dataSet.getColumnNames());
-      dataSet.setFetchSize(1024); // default is 10000
-      while (dataSet.hasNext()) {
-        System.out.println(dataSet.next());
-      }
-
-      dataSet.closeOperationHandle();
-    }
-
-    for (int i = 0; i < 6; i++) {
-      SessionDataSet dataSet =
-          sessionEnableRedirect.executeQueryStatement(
-              selectPrefix + i + ".d1 where time >= 1 and time < 10");
-      System.out.println(dataSet.getColumnNames());
-      dataSet.setFetchSize(1024); // default is 10000
-      while (dataSet.hasNext()) {
-        System.out.println(dataSet.next());
-      }
-
-      dataSet.closeOperationHandle();
-    }
-
-    for (int i = 0; i < 6; i++) {
-      SessionDataSet dataSet =
-          sessionEnableRedirect.executeQueryStatement(
-              selectPrefix + i + ".d1 where time >= 1 and time < 10 align by device");
-      System.out.println(dataSet.getColumnNames());
-      dataSet.setFetchSize(1024); // default is 10000
-      while (dataSet.hasNext()) {
-        System.out.println(dataSet.next());
-      }
-
-      dataSet.closeOperationHandle();
-    }
-
-    for (int i = 0; i < 6; i++) {
-      SessionDataSet dataSet =
-          sessionEnableRedirect.executeQueryStatement(
-              selectPrefix
-                  + i
-                  + ".d1 where time >= 1 and time < 10 and root.redirect"
-                  + i
-                  + ".d1.s1 > 1");
-      System.out.println(dataSet.getColumnNames());
-      dataSet.setFetchSize(1024); // default is 10000
-      while (dataSet.hasNext()) {
-        System.out.println(dataSet.next());
-      }
-
-      dataSet.closeOperationHandle();
-    }
-  }
-
-  private static void queryWithTimeout()
-      throws IoTDBConnectionException, StatementExecutionException {
-    SessionDataSet dataSet = session.executeQueryStatement("select * from root.sg1.d1", 2000);
-    System.out.println(dataSet.getColumnNames());
-    dataSet.setFetchSize(1024); // default is 10000
-    while (dataSet.hasNext()) {
-      System.out.println(dataSet.next());
-    }
-
-    dataSet.closeOperationHandle();
-  }
-
-  private static void rawDataQuery() throws IoTDBConnectionException, StatementExecutionException {
-    List<String> paths = new ArrayList<>();
-    paths.add(ROOT_SG1_D1_S1);
-    paths.add(ROOT_SG1_D1_S2);
-    paths.add(ROOT_SG1_D1_S3);
-    long startTime = 10L;
-    long endTime = 200L;
-
-    SessionDataSet dataSet = session.executeRawDataQuery(paths, startTime, endTime);
-    System.out.println(dataSet.getColumnNames());
-    dataSet.setFetchSize(1024);
-    while (dataSet.hasNext()) {
-      System.out.println(dataSet.next());
-    }
-    dataSet.closeOperationHandle();
-  }
-
-  private static void queryByIterator()
-      throws IoTDBConnectionException, StatementExecutionException {
-    SessionDataSet dataSet = session.executeQueryStatement("select * from root.sg1.d1");
-    DataIterator iterator = dataSet.iterator();
-    System.out.println(dataSet.getColumnNames());
-    dataSet.setFetchSize(1024); // default is 10000
-    while (iterator.next()) {
-      StringBuilder builder = new StringBuilder();
-      // get time
-      builder.append(iterator.getLong(1)).append(",");
-      // get second column
-      if (!iterator.isNull(2)) {
-        builder.append(iterator.getLong(2)).append(",");
-      } else {
-        builder.append("null").append(",");
-      }
-
-      // get third column
-      if (!iterator.isNull(ROOT_SG1_D1_S2)) {
-        builder.append(iterator.getLong(ROOT_SG1_D1_S2)).append(",");
-      } else {
-        builder.append("null").append(",");
-      }
-
-      // get forth column
-      if (!iterator.isNull(4)) {
-        builder.append(iterator.getLong(4)).append(",");
-      } else {
-        builder.append("null").append(",");
-      }
-
-      // get fifth column
-      if (!iterator.isNull(ROOT_SG1_D1_S4)) {
-        builder.append(iterator.getObject(ROOT_SG1_D1_S4));
-      } else {
-        builder.append("null");
-      }
-
-      System.out.println(builder);
-    }
-
-    dataSet.closeOperationHandle();
-  }
-
-  private static void nonQuery() throws IoTDBConnectionException, StatementExecutionException {
-    session.executeNonQueryStatement("insert into root.sg1.d1(timestamp,s1) values(200, 1)");
-  }
-
-  private static void setTimeout() throws StatementExecutionException {
-    Session tempSession = new Session(LOCAL_HOST, 6667, "root", "root", 10000, 20000);
-    tempSession.setQueryTimeout(60000);
-  }
-
-  private static void createClusterSession() throws IoTDBConnectionException {
-    ArrayList<String> nodeList = new ArrayList<>();
-    nodeList.add("127.0.0.1:6669");
-    nodeList.add("127.0.0.1:6667");
-    nodeList.add("127.0.0.1:6668");
-    Session clusterSession = new Session(nodeList, "root", "root");
-    clusterSession.open();
-    clusterSession.close();
-  }
-}
diff --git a/example/session/src/main/java/org/apache/iotdb/SessionPoolExample.java b/example/session/src/main/java/org/apache/iotdb/SessionPoolExample.java
deleted file mode 100644
index d2e4977..0000000
--- a/example/session/src/main/java/org/apache/iotdb/SessionPoolExample.java
+++ /dev/null
@@ -1,121 +0,0 @@
-/*
- * 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;
-
-import org.apache.iotdb.rpc.IoTDBConnectionException;
-import org.apache.iotdb.rpc.StatementExecutionException;
-import org.apache.iotdb.session.SessionDataSet.DataIterator;
-import org.apache.iotdb.session.pool.SessionDataSetWrapper;
-import org.apache.iotdb.session.pool.SessionPool;
-import org.apache.iotdb.tsfile.file.metadata.enums.TSDataType;
-
-import java.util.ArrayList;
-import java.util.List;
-import java.util.concurrent.ExecutorService;
-import java.util.concurrent.Executors;
-
-public class SessionPoolExample {
-
-  private static SessionPool pool;
-  private static ExecutorService service;
-
-  public static void main(String[] args)
-      throws StatementExecutionException, IoTDBConnectionException, InterruptedException {
-    pool = new SessionPool("127.0.0.1", 6667, "root", "root", 3);
-    service = Executors.newFixedThreadPool(10);
-
-    insertRecord();
-    queryByRowRecord();
-    Thread.sleep(1000);
-    queryByIterator();
-    pool.close();
-    service.shutdown();
-  }
-
-  // more insert example, see SessionExample.java
-  private static void insertRecord() throws StatementExecutionException, IoTDBConnectionException {
-    String deviceId = "root.sg1.d1";
-    List<String> measurements = new ArrayList<>();
-    List<TSDataType> types = new ArrayList<>();
-    measurements.add("s1");
-    measurements.add("s2");
-    measurements.add("s3");
-    types.add(TSDataType.INT64);
-    types.add(TSDataType.INT64);
-    types.add(TSDataType.INT64);
-
-    for (long time = 0; time < 10; time++) {
-      List<Object> values = new ArrayList<>();
-      values.add(1L);
-      values.add(2L);
-      values.add(3L);
-      pool.insertRecord(deviceId, time, measurements, types, values);
-    }
-  }
-
-  private static void queryByRowRecord() {
-    for (int i = 0; i < 1; i++) {
-      service.submit(
-          () -> {
-            SessionDataSetWrapper wrapper = null;
-            try {
-              wrapper = pool.executeQueryStatement("select * from root.sg1.d1");
-              System.out.println(wrapper.getColumnNames());
-              System.out.println(wrapper.getColumnTypes());
-              while (wrapper.hasNext()) {
-                System.out.println(wrapper.next());
-              }
-            } catch (IoTDBConnectionException | StatementExecutionException e) {
-              e.printStackTrace();
-            } finally {
-              // remember to close data set finally!
-              pool.closeResultSet(wrapper);
-            }
-          });
-    }
-  }
-
-  private static void queryByIterator() {
-    for (int i = 0; i < 1; i++) {
-      service.submit(
-          () -> {
-            SessionDataSetWrapper wrapper = null;
-            try {
-              wrapper = pool.executeQueryStatement("select * from root.sg1.d1");
-              // get DataIterator like JDBC
-              DataIterator dataIterator = wrapper.iterator();
-              System.out.println(wrapper.getColumnNames());
-              System.out.println(wrapper.getColumnTypes());
-              while (dataIterator.next()) {
-                StringBuilder builder = new StringBuilder();
-                for (String columnName : wrapper.getColumnNames()) {
-                  builder.append(dataIterator.getString(columnName) + " ");
-                }
-                System.out.println(builder);
-              }
-            } catch (IoTDBConnectionException | StatementExecutionException e) {
-              e.printStackTrace();
-            } finally {
-              // remember to close data set finally!
-              pool.closeResultSet(wrapper);
-            }
-          });
-    }
-  }
-}
diff --git a/example/session/src/main/java/org/apache/iotdb/bash/run-BallSpeed-exp.sh b/example/session/src/main/java/org/apache/iotdb/bash/run-BallSpeed-exp.sh
new file mode 100644
index 0000000..122d5a3
--- /dev/null
+++ b/example/session/src/main/java/org/apache/iotdb/bash/run-BallSpeed-exp.sh
@@ -0,0 +1,1573 @@
+#!/bin/bash
+
+############################
+# extract small data for fast exp
+# java ExtractBallSpeedData inPath outPath timeIdx valueIdx lineNum
+# lineNum=-1 means extracting total lines
+############################
+cd /data3/raw_data/rl/BallSpeed
+# java ExtractBallSpeedData /data3/raw_data/data/full-game BallSpeed.csv 1 5 8 2000000 3200000
+
+
+############################
+# generate out-of-order source data
+# java OverlapGenerator inPath outPath timeIdx valueIdx overlapPercentage overlapDepth
+# overlapPercentage [0,100]
+# overlapDepth [0,50]
+############################
+cp BallSpeed.csv BallSpeed-O_0_0
+
+java OverlapGenerator BallSpeed.csv BallSpeed-O_10_10 0 1 10 10
+java OverlapGenerator BallSpeed.csv BallSpeed-O_30_10 0 1 30 10
+java OverlapGenerator BallSpeed.csv BallSpeed-O_50_10 0 1 50 10
+java OverlapGenerator BallSpeed.csv BallSpeed-O_70_10 0 1 70 10
+java OverlapGenerator BallSpeed.csv BallSpeed-O_90_10 0 1 90 10
+
+
+############################
+# /data3/raw_data/rl
+# ---- BallSpeed
+# /data3/ruilei/rl/dataSpace2
+# /data3/ruilei/rl/iotdb-server-0.12.4
+# /data3/ruilei/rl/iotdb-engine-example.properties
+# /data3/ruilei/rl/tool.sh
+# /data3/ruilei/rl/ProcessResult.class
+# /data3/ruilei/rl/ProcessResult.java
+# /data3/ruilei/rl/SumResultUnify.class
+# /data3/ruilei/rl/SumResultUnify.java
+# /data3/ruilei/rl/BallSpeed_testspace
+# ---- WriteBallSpeed-0.12.4.jar [make sure updated][time ns ms value long float type][device measurement path]
+# ---- QueryBallSpeed-0.12.4.jar [make sure updated][time ns ms value long float type][device measurement path]
+# ---- query_experiment.sh [make sure updated][call jar name]
+# [EXP1 EXP2]
+# ---- O_10_10_D_0_0:
+# ---- ---- iotdb-engine-enableCPVtrue.properties
+# ---- ---- iotdb-engine-enableCPVfalse.properties
+# ---- ---- write_data.sh
+# ---- ---- vary_w
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- vary_tqe
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# [EXP3]
+# ---- O_0_0_D_0_0:
+# ---- ---- iotdb-engine-enableCPVtrue.properties
+# ---- ---- iotdb-engine-enableCPVfalse.properties
+# ---- ---- write_data.sh
+# ---- ---- fix
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- O_30_10_D_0_0
+# ---- O_50_10_D_0_0
+# ---- O_70_10_D_0_0
+# ---- O_90_10_D_0_0
+# [EXP4]
+# ---- O_10_10_D_9_10
+# ---- O_10_10_D_29_10
+# ---- O_10_10_D_49_10
+# ---- O_10_10_D_69_10
+# ---- O_10_10_D_89_10
+# [EXP5]
+# ---- O_10_10_D_9_30
+# ---- O_10_10_D_9_50
+# ---- O_10_10_D_9_70
+# ---- O_10_10_D_9_90
+
+############################
+
+############################
+# [EXP1]
+############################
+
+cd /data3/ruilei/rl/BallSpeed_testspace
+mkdir O_10_10_D_0_0
+cd O_10_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar /data3/raw_data/rl/BallSpeed/BallSpeed-O_10_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_0_0
+mkdir vary_w
+cd vary_w
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 1 2 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMOC.csv
+./../../../query_experiment.sh 617426057627 2 2 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMOC.csv
+./../../../query_experiment.sh 617426057627 5 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+./../../../query_experiment.sh 617426057627 10 2 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMOC.csv
+./../../../query_experiment.sh 617426057627 20 2 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMOC.csv
+./../../../query_experiment.sh 617426057627 50 2 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMOC.csv
+./../../../query_experiment.sh 617426057627 100 2 >> result_7.txt
+java ProcessResult result_7.txt result_7.out ../sumResultMOC.csv
+./../../../query_experiment.sh 617426057627 200 2 >> result_8.txt
+java ProcessResult result_8.txt result_8.out ../sumResultMOC.csv
+./../../../query_experiment.sh 617426057627 500 2 >> result_9.txt
+java ProcessResult result_9.txt result_9.out ../sumResultMOC.csv
+./../../../query_experiment.sh 617426057627 1000 2 >> result_10.txt
+java ProcessResult result_10.txt result_10.out ../sumResultMOC.csv
+./../../../query_experiment.sh 617426057627 2000 2 >> result_11.txt
+java ProcessResult result_11.txt result_11.out ../sumResultMOC.csv
+./../../../query_experiment.sh 617426057627 4000 2 >> result_12.txt
+java ProcessResult result_12.txt result_12.out ../sumResultMOC.csv
+./../../../query_experiment.sh 617426057627 8000 2 >> result_13.txt
+java ProcessResult result_13.txt result_13.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 1 1 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMAC.csv
+./../../../query_experiment.sh 617426057627 2 1 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMAC.csv
+./../../../query_experiment.sh 617426057627 5 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+./../../../query_experiment.sh 617426057627 10 1 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMAC.csv
+./../../../query_experiment.sh 617426057627 20 1 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMAC.csv
+./../../../query_experiment.sh 617426057627 50 1 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMAC.csv
+./../../../query_experiment.sh 617426057627 100 1 >> result_7.txt
+java ProcessResult result_7.txt result_7.out ../sumResultMAC.csv
+./../../../query_experiment.sh 617426057627 200 1 >> result_8.txt
+java ProcessResult result_8.txt result_8.out ../sumResultMAC.csv
+./../../../query_experiment.sh 617426057627 500 1 >> result_9.txt
+java ProcessResult result_9.txt result_9.out ../sumResultMAC.csv
+./../../../query_experiment.sh 617426057627 1000 1 >> result_10.txt
+java ProcessResult result_10.txt result_10.out ../sumResultMAC.csv
+./../../../query_experiment.sh 617426057627 2000 1 >> result_11.txt
+java ProcessResult result_11.txt result_11.out ../sumResultMAC.csv
+./../../../query_experiment.sh 617426057627 4000 1 >> result_12.txt
+java ProcessResult result_12.txt result_12.out ../sumResultMAC.csv
+./../../../query_experiment.sh 617426057627 8000 1 >> result_13.txt
+java ProcessResult result_13.txt result_13.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 1 3 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultCPV.csv
+./../../../query_experiment.sh 617426057627 2 3 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultCPV.csv
+./../../../query_experiment.sh 617426057627 5 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+./../../../query_experiment.sh 617426057627 10 3 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultCPV.csv
+./../../../query_experiment.sh 617426057627 20 3 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultCPV.csv
+./../../../query_experiment.sh 617426057627 50 3 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultCPV.csv
+./../../../query_experiment.sh 617426057627 100 3 >> result_7.txt
+java ProcessResult result_7.txt result_7.out ../sumResultCPV.csv
+./../../../query_experiment.sh 617426057627 200 3 >> result_8.txt
+java ProcessResult result_8.txt result_8.out ../sumResultCPV.csv
+./../../../query_experiment.sh 617426057627 500 3 >> result_9.txt
+java ProcessResult result_9.txt result_9.out ../sumResultCPV.csv
+./../../../query_experiment.sh 617426057627 1000 3 >> result_10.txt
+java ProcessResult result_10.txt result_10.out ../sumResultCPV.csv
+./../../../query_experiment.sh 617426057627 2000 3 >> result_11.txt
+java ProcessResult result_11.txt result_11.out ../sumResultCPV.csv
+./../../../query_experiment.sh 617426057627 4000 3 >> result_12.txt
+java ProcessResult result_12.txt result_12.out ../sumResultCPV.csv
+./../../../query_experiment.sh 617426057627 8000 3 >> result_13.txt
+java ProcessResult result_13.txt result_13.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# [EXP2]
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_0_0
+mkdir vary_tqe
+cd vary_tqe
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 13096043655 100 2 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMOC.csv
+./../../../query_experiment.sh 26192087310 100 2 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMOC.csv
+./../../../query_experiment.sh 52384174620 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+./../../../query_experiment.sh 130960436550 100 2 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMOC.csv
+./../../../query_experiment.sh 261920873100 100 2 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMOC.csv
+./../../../query_experiment.sh 617426057627 100 2 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 13096043655 100 1 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMAC.csv
+./../../../query_experiment.sh 26192087310 100 1 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMAC.csv
+./../../../query_experiment.sh 52384174620 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+./../../../query_experiment.sh 130960436550 100 1 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMAC.csv
+./../../../query_experiment.sh 261920873100 100 1 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMAC.csv
+./../../../query_experiment.sh 617426057627 100 1 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 13096043655 100 3 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultCPV.csv
+./../../../query_experiment.sh 26192087310 100 3 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultCPV.csv
+./../../../query_experiment.sh 52384174620 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+./../../../query_experiment.sh 130960436550 100 3 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultCPV.csv
+./../../../query_experiment.sh 261920873100 100 3 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultCPV.csv
+./../../../query_experiment.sh 617426057627 100 3 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+# [EXP3]
+# ---- O_0_0_D_0_0:
+# ---- ---- iotdb-engine-enableCPVtrue.properties
+# ---- ---- iotdb-engine-enableCPVfalse.properties
+# ---- ---- write_data.sh
+# ---- ---- fix
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- O_30_10_D_0_0
+# ---- O_50_10_D_0_0
+# ---- O_70_10_D_0_0
+# ---- O_90_10_D_0_0
+
+############################
+# O_0_0_D_0_0
+############################
+
+cd /data3/ruilei/rl/BallSpeed_testspace
+mkdir O_0_0_D_0_0
+cd O_0_0_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_0_0_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/BallSpeed_O_0_0_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_0_0_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar /data3/raw_data/rl/BallSpeed/BallSpeed-O_0_0 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_0_0_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_30_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/BallSpeed_testspace
+mkdir O_30_10_D_0_0
+cd O_30_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_30_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/BallSpeed_O_30_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_30_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar /data3/raw_data/rl/BallSpeed/BallSpeed-O_30_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_30_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_50_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/BallSpeed_testspace
+mkdir O_50_10_D_0_0
+cd O_50_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_50_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/BallSpeed_O_50_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_50_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar /data3/raw_data/rl/BallSpeed/BallSpeed-O_50_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_50_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_50_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/BallSpeed_testspace
+mkdir O_70_10_D_0_0
+cd O_70_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_70_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/BallSpeed_O_70_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_70_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar /data3/raw_data/rl/BallSpeed/BallSpeed-O_70_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_70_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_90_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/BallSpeed_testspace
+mkdir O_90_10_D_0_0
+cd O_90_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_90_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/BallSpeed_O_90_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_90_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar /data3/raw_data/rl/BallSpeed/BallSpeed-O_90_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_90_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+# [EXP4]
+# ---- O_10_10_D_0_0
+# ---- O_10_10_D_9_10
+# ---- O_10_10_D_29_10
+# ---- O_10_10_D_49_10
+# ---- O_10_10_D_69_10
+# ---- O_10_10_D_89_10
+
+############################
+# O_10_10_D_9_10
+############################
+
+cd /data3/ruilei/rl/BallSpeed_testspace
+mkdir O_10_10_D_9_10
+cd O_10_10_D_9_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_9_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_9_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_9_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar /data3/raw_data/rl/BallSpeed/BallSpeed-O_10_10 9 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_9_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_29_10
+############################
+
+cd /data3/ruilei/rl/BallSpeed_testspace
+mkdir O_10_10_D_29_10
+cd O_10_10_D_29_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_29_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_29_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_29_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar /data3/raw_data/rl/BallSpeed/BallSpeed-O_10_10 29 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_29_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_49_10
+############################
+
+cd /data3/ruilei/rl/BallSpeed_testspace
+mkdir O_10_10_D_49_10
+cd O_10_10_D_49_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_49_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_49_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_49_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar /data3/raw_data/rl/BallSpeed/BallSpeed-O_10_10 49 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_49_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_69_10
+############################
+
+cd /data3/ruilei/rl/BallSpeed_testspace
+mkdir O_10_10_D_69_10
+cd O_10_10_D_69_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_69_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_69_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_69_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar /data3/raw_data/rl/BallSpeed/BallSpeed-O_10_10 69 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_69_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_89_10
+############################
+
+cd /data3/ruilei/rl/BallSpeed_testspace
+mkdir O_10_10_D_89_10
+cd O_10_10_D_89_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_89_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_89_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_89_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar /data3/raw_data/rl/BallSpeed/BallSpeed-O_10_10 89 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_89_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+# [EXP5-2]
+# ---- O_10_10_D_49_30
+# ---- O_10_10_D_49_50
+# ---- O_10_10_D_49_70
+# ---- O_10_10_D_49_90
+
+############################
+# O_10_10_D_49_30
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace
+mkdir O_10_10_D_49_30
+cd O_10_10_D_49_30
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_49_30/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_49_30/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_49_30/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar /data3/raw_data/rl/BallSpeed/BallSpeed-O_10_10 49 30 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_49_30
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_49_50
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace
+mkdir O_10_10_D_49_50
+cd O_10_10_D_49_50
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_49_50/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_49_50/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_49_50/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar /data3/raw_data/rl/BallSpeed/BallSpeed-O_10_10 49 50 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_49_50
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_9_50
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace
+mkdir O_10_10_D_49_70
+cd O_10_10_D_49_70
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_49_70/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_49_70/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_49_70/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar /data3/raw_data/rl/BallSpeed/BallSpeed-O_10_10 49 70 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_49_70
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_49_90
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace
+mkdir O_10_10_D_49_90
+cd O_10_10_D_49_90
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_49_90/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_49_90/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/BallSpeed_O_10_10_D_49_90/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/BallSpeed_testspace/WriteBallSpeed-0.12.4.jar /data3/raw_data/rl/BallSpeed/BallSpeed-O_10_10 49 90 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_49_90
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 617426057627 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+#########################
+# sum results
+# [EXP3]
+# ---- O_0_0_D_0_0
+# ---- O_30_10_D_0_0
+# ---- O_50_10_D_0_0
+# ---- O_70_10_D_0_0
+# ---- O_90_10_D_0_0
+# [EXP4]
+# ---- O_10_10_D_9_10
+# ---- O_10_10_D_29_10
+# ---- O_10_10_D_49_10
+# ---- O_10_10_D_69_10
+# ---- O_10_10_D_89_10
+# [EXP5]
+# ---- O_10_10_D_49_30
+# ---- O_10_10_D_49_50
+# ---- O_10_10_D_49_70
+# ---- O_10_10_D_49_90
+#########################
+# [EXP3]
+cd /data3/ruilei/rl/BallSpeed_testspace/O_0_0_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/BallSpeed_testspace/exp3.csv
+
+cd /data3/ruilei/rl/BallSpeed_testspace/O_30_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/BallSpeed_testspace/exp3.csv
+
+cd /data3/ruilei/rl/BallSpeed_testspace/O_50_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/BallSpeed_testspace/exp3.csv
+
+cd /data3/ruilei/rl/BallSpeed_testspace/O_70_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/BallSpeed_testspace/exp3.csv
+
+cd /data3/ruilei/rl/BallSpeed_testspace/O_90_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/BallSpeed_testspace/exp3.csv
+
+# [EXP4]
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_9_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/BallSpeed_testspace/exp4.csv
+
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_29_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/BallSpeed_testspace/exp4.csv
+
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_49_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/BallSpeed_testspace/exp4.csv
+
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_69_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/BallSpeed_testspace/exp4.csv
+
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_89_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/BallSpeed_testspace/exp4.csv
+
+# [EXP5]
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_49_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/BallSpeed_testspace/exp5.csv
+
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_49_30
+cd fix
+cat result.csv >>/data3/ruilei/rl/BallSpeed_testspace/exp5.csv
+
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_49_50
+cd fix
+cat result.csv >>/data3/ruilei/rl/BallSpeed_testspace/exp5.csv
+
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_49_70
+cd fix
+cat result.csv >>/data3/ruilei/rl/BallSpeed_testspace/exp5.csv
+
+cd /data3/ruilei/rl/BallSpeed_testspace/O_10_10_D_49_90
+cd fix
+cat result.csv >>/data3/ruilei/rl/BallSpeed_testspace/exp5.csv
diff --git a/example/session/src/main/java/org/apache/iotdb/bash/run-KOB-exp.sh b/example/session/src/main/java/org/apache/iotdb/bash/run-KOB-exp.sh
new file mode 100644
index 0000000..cd1589b
--- /dev/null
+++ b/example/session/src/main/java/org/apache/iotdb/bash/run-KOB-exp.sh
@@ -0,0 +1,1579 @@
+#!/bin/bash
+
+############################
+# extract small data for fast exp
+# java ExtractBallSpeedData inPath outPath timeIdx valueIdx lineNum
+# lineNum=-1 means extracting total lines
+############################
+cd /data3/raw_data/rl/KOB
+# java ExtractKOB /data3/raw_data/data/KOB/root.kobelco.trans.03.1090001603.2401604.KOB_0002_00_67.csv KOB.csv 0 1
+
+############################
+# generate out-of-order source data
+# java OverlapGenerator inPath outPath timeIdx valueIdx overlapPercentage overlapDepth
+# overlapPercentage [0,100]
+# overlapDepth [0,50]
+############################
+cp KOB.csv KOB-O_0_0
+
+java OverlapGenerator KOB.csv KOB-O_10_10 0 1 10 10
+java OverlapGenerator KOB.csv KOB-O_30_10 0 1 30 10
+java OverlapGenerator KOB.csv KOB-O_50_10 0 1 50 10
+java OverlapGenerator KOB.csv KOB-O_70_10 0 1 70 10
+java OverlapGenerator KOB.csv KOB-O_90_10 0 1 90 10
+
+
+############################
+# /data3/raw_data/rl
+# ---- KOB
+# /data3/ruilei/rl/dataSpace2
+# /data3/ruilei/rl/iotdb-server-0.12.4
+# /data3/ruilei/rl/iotdb-engine-example.properties
+# /data3/ruilei/rl/tool.sh
+# /data3/ruilei/rl/ProcessResult.class
+# /data3/ruilei/rl/ProcessResult.java
+# /data3/ruilei/rl/SumResultUnify.class
+# /data3/ruilei/rl/SumResultUnify.java
+# /data3/ruilei/rl/KOB_testspace
+# ---- WriteKOB-0.12.4.jar
+# ---- QueryKOB-0.12.4.jar
+# ---- query_experiment.sh [make sure updated]
+# [EXP1 EXP2]
+# ---- O_10_10_D_0_0:
+# ---- ---- iotdb-engine-enableCPVtrue.properties
+# ---- ---- iotdb-engine-enableCPVfalse.properties
+# ---- ---- write_data.sh
+# ---- ---- vary_w
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- vary_tqe
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# [EXP3]
+# ---- O_0_0_D_0_0:
+# ---- ---- iotdb-engine-enableCPVtrue.properties
+# ---- ---- iotdb-engine-enableCPVfalse.properties
+# ---- ---- write_data.sh
+# ---- ---- fix
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- O_30_10_D_0_0
+# ---- O_50_10_D_0_0
+# ---- O_70_10_D_0_0
+# ---- O_90_10_D_0_0
+# [EXP4]
+# ---- O_10_10_D_9_10
+# ---- O_10_10_D_29_10
+# ---- O_10_10_D_49_10
+# ---- O_10_10_D_69_10
+# ---- O_10_10_D_89_10
+# [EXP5]
+# ---- O_10_10_D_49_30
+# ---- O_10_10_D_49_50
+# ---- O_10_10_D_49_70
+# ---- O_10_10_D_49_90
+
+############################
+
+############################
+# [EXP1]
+############################
+
+cd /data3/ruilei/rl/KOB_testspace
+mkdir O_10_10_D_0_0
+cd O_10_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar /data3/raw_data/rl/KOB/KOB-O_10_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_0_0
+mkdir vary_w
+cd vary_w
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 1 2 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10575803591 2 2 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10575803591 5 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10575803591 10 2 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10575803591 20 2 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10575803591 50 2 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10575803591 100 2 >> result_7.txt
+java ProcessResult result_7.txt result_7.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10575803591 200 2 >> result_8.txt
+java ProcessResult result_8.txt result_8.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10575803591 500 2 >> result_9.txt
+java ProcessResult result_9.txt result_9.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10575803591 1000 2 >> result_10.txt
+java ProcessResult result_10.txt result_10.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10575803591 2000 2 >> result_11.txt
+java ProcessResult result_11.txt result_11.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10575803591 4000 2 >> result_12.txt
+java ProcessResult result_12.txt result_12.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10575803591 8000 2 >> result_13.txt
+java ProcessResult result_13.txt result_13.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 1 1 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10575803591 2 1 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10575803591 5 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10575803591 10 1 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10575803591 20 1 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10575803591 50 1 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10575803591 100 1 >> result_7.txt
+java ProcessResult result_7.txt result_7.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10575803591 200 1 >> result_8.txt
+java ProcessResult result_8.txt result_8.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10575803591 500 1 >> result_9.txt
+java ProcessResult result_9.txt result_9.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10575803591 1000 1 >> result_10.txt
+java ProcessResult result_10.txt result_10.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10575803591 2000 1 >> result_11.txt
+java ProcessResult result_11.txt result_11.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10575803591 4000 1 >> result_12.txt
+java ProcessResult result_12.txt result_12.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10575803591 8000 1 >> result_13.txt
+java ProcessResult result_13.txt result_13.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 1 3 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10575803591 2 3 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10575803591 5 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10575803591 10 3 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10575803591 20 3 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10575803591 50 3 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10575803591 100 3 >> result_7.txt
+java ProcessResult result_7.txt result_7.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10575803591 200 3 >> result_8.txt
+java ProcessResult result_8.txt result_8.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10575803591 500 3 >> result_9.txt
+java ProcessResult result_9.txt result_9.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10575803591 1000 3 >> result_10.txt
+java ProcessResult result_10.txt result_10.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10575803591 2000 3 >> result_11.txt
+java ProcessResult result_11.txt result_11.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10575803591 4000 3 >> result_12.txt
+java ProcessResult result_12.txt result_12.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10575803591 8000 3 >> result_13.txt
+java ProcessResult result_13.txt result_13.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# [EXP2]
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_0_0
+mkdir vary_tqe
+cd vary_tqe
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 139565502 100 2 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMOC.csv
+./../../../query_experiment.sh 279131005 100 2 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMOC.csv
+./../../../query_experiment.sh 558262010 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+./../../../query_experiment.sh 1395655025 100 2 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMOC.csv
+./../../../query_experiment.sh 2791310050 100 2 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMOC.csv
+./../../../query_experiment.sh 5582620100 100 2 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10575803591 100 2 >> result_7.txt
+java ProcessResult result_7.txt result_7.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 139565502 100 1 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMAC.csv
+./../../../query_experiment.sh 279131005 100 1 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMAC.csv
+./../../../query_experiment.sh 558262010 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+./../../../query_experiment.sh 1395655025 100 1 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMAC.csv
+./../../../query_experiment.sh 2791310050 100 1 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMAC.csv
+./../../../query_experiment.sh 5582620100 100 1 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10575803591 100 1 >> result_7.txt
+java ProcessResult result_7.txt result_7.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 139565502 100 3 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultCPV.csv
+./../../../query_experiment.sh 279131005 100 3 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultCPV.csv
+./../../../query_experiment.sh 558262010 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+./../../../query_experiment.sh 1395655025 100 3 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultCPV.csv
+./../../../query_experiment.sh 2791310050 100 3 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultCPV.csv
+./../../../query_experiment.sh 5582620100 100 3 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10575803591 100 3 >> result_7.txt
+java ProcessResult result_7.txt result_7.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+# [EXP3]
+# ---- O_0_0_D_0_0:
+# ---- ---- iotdb-engine-enableCPVtrue.properties
+# ---- ---- iotdb-engine-enableCPVfalse.properties
+# ---- ---- write_data.sh
+# ---- ---- fix
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- O_30_10_D_0_0
+# ---- O_50_10_D_0_0
+# ---- O_70_10_D_0_0
+# ---- O_90_10_D_0_0
+
+############################
+# O_0_0_D_0_0
+############################
+
+cd /data3/ruilei/rl/KOB_testspace
+mkdir O_0_0_D_0_0
+cd O_0_0_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/KOB_O_0_0_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/KOB_O_0_0_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/KOB_O_0_0_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar /data3/raw_data/rl/KOB/KOB-O_0_0 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_0_0_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_30_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/KOB_testspace
+mkdir O_30_10_D_0_0
+cd O_30_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/KOB_O_30_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/KOB_O_30_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/KOB_O_30_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar /data3/raw_data/rl/KOB/KOB-O_30_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_30_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_50_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/KOB_testspace
+mkdir O_50_10_D_0_0
+cd O_50_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/KOB_O_50_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/KOB_O_50_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/KOB_O_50_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar /data3/raw_data/rl/KOB/KOB-O_50_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_50_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_70_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/KOB_testspace
+mkdir O_70_10_D_0_0
+cd O_70_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/KOB_O_70_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/KOB_O_70_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/KOB_O_70_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar /data3/raw_data/rl/KOB/KOB-O_70_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_70_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_90_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/KOB_testspace
+mkdir O_90_10_D_0_0
+cd O_90_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/KOB_O_90_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/KOB_O_90_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/KOB_O_90_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar /data3/raw_data/rl/KOB/KOB-O_90_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_90_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+# [EXP4]
+# ---- O_10_10_D_0_0
+# ---- O_10_10_D_9_10
+# ---- O_10_10_D_29_10
+# ---- O_10_10_D_49_10
+# ---- O_10_10_D_69_10
+# ---- O_10_10_D_89_10
+
+############################
+# O_10_10_D_9_10
+############################
+
+cd /data3/ruilei/rl/KOB_testspace
+mkdir O_10_10_D_9_10
+cd O_10_10_D_9_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_9_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_9_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_9_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar /data3/raw_data/rl/KOB/KOB-O_10_10 9 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_9_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_29_10
+############################
+
+cd /data3/ruilei/rl/KOB_testspace
+mkdir O_10_10_D_29_10
+cd O_10_10_D_29_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_29_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_29_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_29_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar /data3/raw_data/rl/KOB/KOB-O_10_10 29 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_29_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_49_10
+############################
+
+cd /data3/ruilei/rl/KOB_testspace
+mkdir O_10_10_D_49_10
+cd O_10_10_D_49_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_49_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_49_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_49_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar /data3/raw_data/rl/KOB/KOB-O_10_10 49 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_49_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_69_10
+############################
+
+cd /data3/ruilei/rl/KOB_testspace
+mkdir O_10_10_D_69_10
+cd O_10_10_D_69_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_69_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_69_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_69_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar /data3/raw_data/rl/KOB/KOB-O_10_10 69 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_69_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_89_10
+############################
+
+cd /data3/ruilei/rl/KOB_testspace
+mkdir O_10_10_D_89_10
+cd O_10_10_D_89_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_89_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_89_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_89_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar /data3/raw_data/rl/KOB/KOB-O_10_10 89 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_89_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+# [EXP5]
+# ---- O_10_10_D_49_30
+# ---- O_10_10_D_49_50
+# ---- O_10_10_D_49_70
+# ---- O_10_10_D_49_90
+
+############################
+# O_10_10_D_49_30
+############################
+cd /data3/ruilei/rl/KOB_testspace
+mkdir O_10_10_D_49_30
+cd O_10_10_D_49_30
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_49_30/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_49_30/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_49_30/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar /data3/raw_data/rl/KOB/KOB-O_10_10 49 30 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_49_30
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_49_50
+############################
+cd /data3/ruilei/rl/KOB_testspace
+mkdir O_10_10_D_49_50
+cd O_10_10_D_49_50
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_49_50/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_49_50/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_49_50/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar /data3/raw_data/rl/KOB/KOB-O_10_10 49 50 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_49_50
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_49_70
+############################
+cd /data3/ruilei/rl/KOB_testspace
+mkdir O_10_10_D_49_70
+cd O_10_10_D_49_70
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_49_70/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_49_70/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_49_70/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar /data3/raw_data/rl/KOB/KOB-O_10_10 49 70 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_49_70
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_49_90
+############################
+cd /data3/ruilei/rl/KOB_testspace
+mkdir O_10_10_D_49_90
+cd O_10_10_D_49_90
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_49_90/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_49_90/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/KOB_O_10_10_D_49_90/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/KOB_testspace/WriteKOB-0.12.4.jar /data3/raw_data/rl/KOB/KOB-O_10_10 49 90 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_49_90
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10575803591 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+#########################
+# sum results
+# [EXP3]
+# ---- O_0_0_D_0_0
+# ---- O_30_10_D_0_0
+# ---- O_50_10_D_0_0
+# ---- O_70_10_D_0_0
+# ---- O_90_10_D_0_0
+# [EXP4]
+# ---- O_10_10_D_9_10
+# ---- O_10_10_D_29_10
+# ---- O_10_10_D_49_10
+# ---- O_10_10_D_69_10
+# ---- O_10_10_D_89_10
+# [EXP5]
+# ---- O_10_10_D_49_10
+# ---- O_10_10_D_49_30
+# ---- O_10_10_D_49_50
+# ---- O_10_10_D_49_70
+# ---- O_10_10_D_49_90
+#########################
+# [EXP3]
+cd /data3/ruilei/rl/KOB_testspace/O_0_0_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/KOB_testspace/exp3.csv
+
+cd /data3/ruilei/rl/KOB_testspace/O_30_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/KOB_testspace/exp3.csv
+
+cd /data3/ruilei/rl/KOB_testspace/O_50_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/KOB_testspace/exp3.csv
+
+cd /data3/ruilei/rl/KOB_testspace/O_70_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/KOB_testspace/exp3.csv
+
+cd /data3/ruilei/rl/KOB_testspace/O_90_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/KOB_testspace/exp3.csv
+
+# [EXP4]
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_9_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/KOB_testspace/exp4.csv
+
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_29_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/KOB_testspace/exp4.csv
+
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_49_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/KOB_testspace/exp4.csv
+
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_69_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/KOB_testspace/exp4.csv
+
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_89_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/KOB_testspace/exp4.csv
+
+# [EXP5]
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_49_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/KOB_testspace/exp5.csv
+
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_49_30
+cd fix
+cat result.csv >>/data3/ruilei/rl/KOB_testspace/exp5.csv
+
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_49_50
+cd fix
+cat result.csv >>/data3/ruilei/rl/KOB_testspace/exp5.csv
+
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_49_70
+cd fix
+cat result.csv >>/data3/ruilei/rl/KOB_testspace/exp5.csv
+
+cd /data3/ruilei/rl/KOB_testspace/O_10_10_D_49_90
+cd fix
+cat result.csv >>/data3/ruilei/rl/KOB_testspace/exp5.csv
diff --git a/example/session/src/main/java/org/apache/iotdb/bash/run-MF03-exp.sh b/example/session/src/main/java/org/apache/iotdb/bash/run-MF03-exp.sh
new file mode 100644
index 0000000..5f55f14
--- /dev/null
+++ b/example/session/src/main/java/org/apache/iotdb/bash/run-MF03-exp.sh
@@ -0,0 +1,1572 @@
+#!/bin/bash
+
+############################
+# extract small data for fast exp
+# java ExtractMF03Data inPath outPath timeIdx valueIdx lineNum
+# lineNum=-1 means extracting total lines
+############################
+cd /data3/raw_data/rl/MF03
+# java ExtractMF03Data /data3/raw_data/data/MF03/allData.txt MF03.csv 0 4 1329955200000000000 1329966000000000000
+
+############################
+# generate out-of-order source data
+# java OverlapGenerator inPath outPath timeIdx valueIdx overlapPercentage overlapDepth
+# overlapPercentage [0,100]
+# overlapDepth [0,50]
+############################
+cp MF03.csv MF03-O_0_0
+
+java OverlapGenerator MF03.csv MF03-O_10_10 0 1 10 10
+java OverlapGenerator MF03.csv MF03-O_30_10 0 1 30 10
+java OverlapGenerator MF03.csv MF03-O_50_10 0 1 50 10
+java OverlapGenerator MF03.csv MF03-O_70_10 0 1 70 10
+java OverlapGenerator MF03.csv MF03-O_90_10 0 1 90 10
+
+############################
+# /data3/raw_data/rl
+# ---- MF03
+# /data3/ruilei/rl/dataSpace2
+# /data3/ruilei/rl/iotdb-server-0.12.4
+# /data3/ruilei/rl/iotdb-engine-example.properties
+# /data3/ruilei/rl/tool.sh
+# /data3/ruilei/rl/ProcessResult.class
+# /data3/ruilei/rl/ProcessResult.java
+# /data3/ruilei/rl/SumResultUnify.class
+# /data3/ruilei/rl/SumResultUnify.java
+# /data3/ruilei/rl/MF03_testspace
+# ---- WriteMF03-0.12.4.jar [make sure updated][time ns ms value long float type][device measurement path]
+# ---- QueryMF03-0.12.4.jar [make sure updated][time ns ms value long float type][device measurement path]
+# ---- query_experiment.sh [make sure updated][call jar name]
+# [EXP1 EXP2]
+# ---- O_10_10_D_0_0:
+# ---- ---- iotdb-engine-enableCPVtrue.properties
+# ---- ---- iotdb-engine-enableCPVfalse.properties
+# ---- ---- write_data.sh
+# ---- ---- vary_w
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- vary_tqe
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# [EXP3]
+# ---- O_0_0_D_0_0:
+# ---- ---- iotdb-engine-enableCPVtrue.properties
+# ---- ---- iotdb-engine-enableCPVfalse.properties
+# ---- ---- write_data.sh
+# ---- ---- fix
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- O_30_10_D_0_0
+# ---- O_50_10_D_0_0
+# ---- O_70_10_D_0_0
+# ---- O_90_10_D_0_0
+# [EXP4]
+# ---- O_10_10_D_9_10
+# ---- O_10_10_D_29_10
+# ---- O_10_10_D_49_10
+# ---- O_10_10_D_69_10
+# ---- O_10_10_D_89_10
+# [EXP5]
+# ---- O_10_10_D_10_30
+# ---- O_10_10_D_10_50
+# ---- O_10_10_D_10_70
+# ---- O_10_10_D_10_90
+
+############################
+
+############################
+# [EXP1]
+############################
+
+cd /data3/ruilei/rl/MF03_testspace
+mkdir O_10_10_D_0_0
+cd O_10_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar /data3/raw_data/rl/MF03/MF03-O_10_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_0_0
+mkdir vary_w
+cd vary_w
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 1 2 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10799982233001 2 2 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10799982233001 5 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10799982233001 10 2 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10799982233001 20 2 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10799982233001 50 2 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10799982233001 100 2 >> result_7.txt
+java ProcessResult result_7.txt result_7.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10799982233001 200 2 >> result_8.txt
+java ProcessResult result_8.txt result_8.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10799982233001 500 2 >> result_9.txt
+java ProcessResult result_9.txt result_9.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10799982233001 1000 2 >> result_10.txt
+java ProcessResult result_10.txt result_10.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10799982233001 2000 2 >> result_11.txt
+java ProcessResult result_11.txt result_11.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10799982233001 4000 2 >> result_12.txt
+java ProcessResult result_12.txt result_12.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10799982233001 8000 2 >> result_13.txt
+java ProcessResult result_13.txt result_13.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 1 1 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10799982233001 2 1 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10799982233001 5 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10799982233001 10 1 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10799982233001 20 1 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10799982233001 50 1 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10799982233001 100 1 >> result_7.txt
+java ProcessResult result_7.txt result_7.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10799982233001 200 1 >> result_8.txt
+java ProcessResult result_8.txt result_8.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10799982233001 500 1 >> result_9.txt
+java ProcessResult result_9.txt result_9.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10799982233001 1000 1 >> result_10.txt
+java ProcessResult result_10.txt result_10.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10799982233001 2000 1 >> result_11.txt
+java ProcessResult result_11.txt result_11.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10799982233001 4000 1 >> result_12.txt
+java ProcessResult result_12.txt result_12.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10799982233001 8000 1 >> result_13.txt
+java ProcessResult result_13.txt result_13.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 1 3 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10799982233001 2 3 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10799982233001 5 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10799982233001 10 3 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10799982233001 20 3 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10799982233001 50 3 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10799982233001 100 3 >> result_7.txt
+java ProcessResult result_7.txt result_7.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10799982233001 200 3 >> result_8.txt
+java ProcessResult result_8.txt result_8.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10799982233001 500 3 >> result_9.txt
+java ProcessResult result_9.txt result_9.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10799982233001 1000 3 >> result_10.txt
+java ProcessResult result_10.txt result_10.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10799982233001 2000 3 >> result_11.txt
+java ProcessResult result_11.txt result_11.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10799982233001 4000 3 >> result_12.txt
+java ProcessResult result_12.txt result_12.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10799982233001 8000 3 >> result_13.txt
+java ProcessResult result_13.txt result_13.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# [EXP2]
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_0_0
+mkdir vary_tqe
+cd vary_tqe
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 255534297777 100 2 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMOC.csv
+./../../../query_experiment.sh 511068595555 100 2 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMOC.csv
+./../../../query_experiment.sh 1022137191110 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+./../../../query_experiment.sh 2555342977775 100 2 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMOC.csv
+./../../../query_experiment.sh 5110685955550 100 2 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10799982233001 100 2 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 255534297777 100 1 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMAC.csv
+./../../../query_experiment.sh 511068595555 100 1 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMAC.csv
+./../../../query_experiment.sh 1022137191110 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+./../../../query_experiment.sh 2555342977775 100 1 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMAC.csv
+./../../../query_experiment.sh 5110685955550 100 1 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10799982233001 100 1 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 255534297777 100 3 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultCPV.csv
+./../../../query_experiment.sh 511068595555 100 3 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultCPV.csv
+./../../../query_experiment.sh 1022137191110 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+./../../../query_experiment.sh 2555342977775 100 3 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultCPV.csv
+./../../../query_experiment.sh 5110685955550 100 3 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10799982233001 100 3 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+# [EXP3]
+# ---- O_0_0_D_0_0:
+# ---- ---- iotdb-engine-enableCPVtrue.properties
+# ---- ---- iotdb-engine-enableCPVfalse.properties
+# ---- ---- write_data.sh
+# ---- ---- fix
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- O_30_10_D_0_0
+# ---- O_50_10_D_0_0
+# ---- O_70_10_D_0_0
+# ---- O_90_10_D_0_0
+
+############################
+# O_0_0_D_0_0
+############################
+
+cd /data3/ruilei/rl/MF03_testspace
+mkdir O_0_0_D_0_0
+cd O_0_0_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/MF03_O_0_0_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/MF03_O_0_0_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/MF03_O_0_0_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar /data3/raw_data/rl/MF03/MF03-O_0_0 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_0_0_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_30_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/MF03_testspace
+mkdir O_30_10_D_0_0
+cd O_30_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/MF03_O_30_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/MF03_O_30_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/MF03_O_30_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar /data3/raw_data/rl/MF03/MF03-O_30_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_30_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_50_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/MF03_testspace
+mkdir O_50_10_D_0_0
+cd O_50_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/MF03_O_50_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/MF03_O_50_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/MF03_O_50_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar /data3/raw_data/rl/MF03/MF03-O_50_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_50_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_70_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/MF03_testspace
+mkdir O_70_10_D_0_0
+cd O_70_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/MF03_O_70_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/MF03_O_70_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/MF03_O_70_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar /data3/raw_data/rl/MF03/MF03-O_70_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_70_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_90_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/MF03_testspace
+mkdir O_90_10_D_0_0
+cd O_90_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/MF03_O_90_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/MF03_O_90_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/MF03_O_90_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar /data3/raw_data/rl/MF03/MF03-O_90_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_90_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+# [EXP4]
+# ---- O_10_10_D_0_0
+# ---- O_10_10_D_9_10
+# ---- O_10_10_D_29_10
+# ---- O_10_10_D_49_10
+# ---- O_10_10_D_69_10
+# ---- O_10_10_D_89_10
+
+############################
+# O_10_10_D_9_10
+############################
+
+cd /data3/ruilei/rl/MF03_testspace
+mkdir O_10_10_D_9_10
+cd O_10_10_D_9_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_9_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_9_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_9_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar /data3/raw_data/rl/MF03/MF03-O_10_10 9 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_9_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_29_10
+############################
+
+cd /data3/ruilei/rl/MF03_testspace
+mkdir O_10_10_D_29_10
+cd O_10_10_D_29_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_29_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_29_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_29_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar /data3/raw_data/rl/MF03/MF03-O_10_10 29 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_29_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_49_10
+############################
+
+cd /data3/ruilei/rl/MF03_testspace
+mkdir O_10_10_D_49_10
+cd O_10_10_D_49_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_49_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_49_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_49_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar /data3/raw_data/rl/MF03/MF03-O_10_10 49 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_49_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_69_10
+############################
+
+cd /data3/ruilei/rl/MF03_testspace
+mkdir O_10_10_D_69_10
+cd O_10_10_D_69_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_69_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_69_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_69_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar /data3/raw_data/rl/MF03/MF03-O_10_10 69 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_69_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_89_10
+############################
+
+cd /data3/ruilei/rl/MF03_testspace
+mkdir O_10_10_D_89_10
+cd O_10_10_D_89_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_89_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_89_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_89_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar /data3/raw_data/rl/MF03/MF03-O_10_10 89 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_89_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+# [EXP5]
+# ---- O_10_10_D_49_30
+# ---- O_10_10_D_49_50
+# ---- O_10_10_D_49_70
+# ---- O_10_10_D_49_90
+
+############################
+# O_10_10_D_49_30
+############################
+cd /data3/ruilei/rl/MF03_testspace
+mkdir O_10_10_D_49_30
+cd O_10_10_D_49_30
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_49_30/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_49_30/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_49_30/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar /data3/raw_data/rl/MF03/MF03-O_10_10 49 30 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_49_30
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_49_50
+############################
+cd /data3/ruilei/rl/MF03_testspace
+mkdir O_10_10_D_49_50
+cd O_10_10_D_49_50
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_49_50/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_49_50/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_49_50/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar /data3/raw_data/rl/MF03/MF03-O_10_10 49 50 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_49_50
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_49_70
+############################
+cd /data3/ruilei/rl/MF03_testspace
+mkdir O_10_10_D_49_70
+cd O_10_10_D_49_70
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_49_70/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_49_70/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_49_70/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar /data3/raw_data/rl/MF03/MF03-O_10_10 49 70 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_49_70
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_49_90
+############################
+cd /data3/ruilei/rl/MF03_testspace
+mkdir O_10_10_D_49_90
+cd O_10_10_D_49_90
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_49_90/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_49_90/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/MF03_O_10_10_D_49_90/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ns ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/MF03_testspace/WriteMF03-0.12.4.jar /data3/raw_data/rl/MF03/MF03-O_10_10 49 90 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_49_90
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 10799982233001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+#########################
+# sum results
+# [EXP3]
+# ---- O_0_0_D_0_0
+# ---- O_30_10_D_0_0
+# ---- O_50_10_D_0_0
+# ---- O_70_10_D_0_0
+# ---- O_90_10_D_0_0
+# [EXP4]
+# ---- O_10_10_D_9_10
+# ---- O_10_10_D_29_10
+# ---- O_10_10_D_49_10
+# ---- O_10_10_D_69_10
+# ---- O_10_10_D_89_10
+# [EXP5]
+# ---- O_10_10_D_49_30
+# ---- O_10_10_D_49_50
+# ---- O_10_10_D_49_70
+# ---- O_10_10_D_49_90
+#########################
+# [EXP3]
+cd /data3/ruilei/rl/MF03_testspace/O_0_0_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/MF03_testspace/exp3.csv
+
+cd /data3/ruilei/rl/MF03_testspace/O_30_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/MF03_testspace/exp3.csv
+
+cd /data3/ruilei/rl/MF03_testspace/O_50_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/MF03_testspace/exp3.csv
+
+cd /data3/ruilei/rl/MF03_testspace/O_70_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/MF03_testspace/exp3.csv
+
+cd /data3/ruilei/rl/MF03_testspace/O_90_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/MF03_testspace/exp3.csv
+
+# [EXP4]
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_9_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/MF03_testspace/exp4.csv
+
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_29_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/MF03_testspace/exp4.csv
+
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_49_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/MF03_testspace/exp4.csv
+
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_69_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/MF03_testspace/exp4.csv
+
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_89_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/MF03_testspace/exp4.csv
+
+# [EXP5]
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_49_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/MF03_testspace/exp5.csv
+
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_49_30
+cd fix
+cat result.csv >>/data3/ruilei/rl/MF03_testspace/exp5.csv
+
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_49_50
+cd fix
+cat result.csv >>/data3/ruilei/rl/MF03_testspace/exp5.csv
+
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_49_70
+cd fix
+cat result.csv >>/data3/ruilei/rl/MF03_testspace/exp5.csv
+
+cd /data3/ruilei/rl/MF03_testspace/O_10_10_D_49_90
+cd fix
+cat result.csv >>/data3/ruilei/rl/MF03_testspace/exp5.csv
diff --git a/example/session/src/main/java/org/apache/iotdb/bash/run-RcvTime-exp.sh b/example/session/src/main/java/org/apache/iotdb/bash/run-RcvTime-exp.sh
new file mode 100644
index 0000000..789986a
--- /dev/null
+++ b/example/session/src/main/java/org/apache/iotdb/bash/run-RcvTime-exp.sh
@@ -0,0 +1,1571 @@
+#!/bin/bash
+
+############################
+# extract small data for fast exp
+# java ExtractFullGameData inPath outPath timeIdx valueIdx lineNum
+# lineNum=-1 means extracting total lines
+############################
+cd /data3/raw_data/rl/RcvTime
+
+############################
+# generate out-of-order source data
+# java OverlapGenerator inPath outPath timeIdx valueIdx overlapPercentage overlapDepth
+# overlapPercentage [0,100]
+# overlapDepth [0,50]
+############################
+cp RcvTime.csv RcvTime-O_0_0
+
+java OverlapGenerator RcvTime.csv RcvTime-O_10_10 0 1 10 10
+java OverlapGenerator RcvTime.csv RcvTime-O_30_10 0 1 30 10
+java OverlapGenerator RcvTime.csv RcvTime-O_50_10 0 1 50 10
+java OverlapGenerator RcvTime.csv RcvTime-O_70_10 0 1 70 10
+java OverlapGenerator RcvTime.csv RcvTime-O_90_10 0 1 90 10
+
+############################
+# /data3/raw_data/rl
+# ---- RcvTime
+# /data3/ruilei/rl/dataSpace2
+# /data3/ruilei/rl/iotdb-server-0.12.4
+# /data3/ruilei/rl/iotdb-engine-example.properties
+# /data3/ruilei/rl/tool.sh
+# /data3/ruilei/rl/ProcessResult.class
+# /data3/ruilei/rl/ProcessResult.java
+# /data3/ruilei/rl/SumResultUnify.class
+# /data3/ruilei/rl/SumResultUnify.java
+# /data3/ruilei/rl/RcvTime_testspace
+# ---- WriteRcvTime-0.12.4.jar [make sure updated][time ms ms value long float type][device measurement path]
+# ---- QueryFullGame-0.12.4.jar [make sure updated][time ms ms value long float type][device measurement path]
+# ---- query_experiment.sh [make sure updated][call jar name]
+# [EXP1 EXP2]
+# ---- O_10_10_D_0_0:
+# ---- ---- iotdb-engine-enableCPVtrue.properties
+# ---- ---- iotdb-engine-enableCPVfalse.properties
+# ---- ---- write_data.sh
+# ---- ---- vary_w
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- vary_tqe
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# [EXP3]
+# ---- O_0_0_D_0_0:
+# ---- ---- iotdb-engine-enableCPVtrue.properties
+# ---- ---- iotdb-engine-enableCPVfalse.properties
+# ---- ---- write_data.sh
+# ---- ---- fix
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- O_30_10_D_0_0
+# ---- O_50_10_D_0_0
+# ---- O_70_10_D_0_0
+# ---- O_90_10_D_0_0
+# [EXP4]
+# ---- O_10_10_D_9_10
+# ---- O_10_10_D_29_10
+# ---- O_10_10_D_49_10
+# ---- O_10_10_D_69_10
+# ---- O_10_10_D_89_10
+# [EXP5]
+# ---- O_10_10_D_9_30
+# ---- O_10_10_D_9_50
+# ---- O_10_10_D_9_70
+# ---- O_10_10_D_9_90
+
+############################
+
+############################
+# [EXP1]
+############################
+
+cd /data3/ruilei/rl/RcvTime_testspace
+mkdir O_10_10_D_0_0
+cd O_10_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar /data3/raw_data/rl/RcvTime/RcvTime-O_10_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_0_0
+mkdir vary_w
+cd vary_w
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 1 2 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMOC.csv
+./../../../query_experiment.sh 26461736001 2 2 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMOC.csv
+./../../../query_experiment.sh 26461736001 5 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+./../../../query_experiment.sh 26461736001 10 2 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMOC.csv
+./../../../query_experiment.sh 26461736001 20 2 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMOC.csv
+./../../../query_experiment.sh 26461736001 50 2 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMOC.csv
+./../../../query_experiment.sh 26461736001 100 2 >> result_7.txt
+java ProcessResult result_7.txt result_7.out ../sumResultMOC.csv
+./../../../query_experiment.sh 26461736001 200 2 >> result_8.txt
+java ProcessResult result_8.txt result_8.out ../sumResultMOC.csv
+./../../../query_experiment.sh 26461736001 500 2 >> result_9.txt
+java ProcessResult result_9.txt result_9.out ../sumResultMOC.csv
+./../../../query_experiment.sh 26461736001 1000 2 >> result_10.txt
+java ProcessResult result_10.txt result_10.out ../sumResultMOC.csv
+./../../../query_experiment.sh 26461736001 2000 2 >> result_11.txt
+java ProcessResult result_11.txt result_11.out ../sumResultMOC.csv
+./../../../query_experiment.sh 26461736001 4000 2 >> result_12.txt
+java ProcessResult result_12.txt result_12.out ../sumResultMOC.csv
+./../../../query_experiment.sh 26461736001 8000 2 >> result_13.txt
+java ProcessResult result_13.txt result_13.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 1 1 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMAC.csv
+./../../../query_experiment.sh 26461736001 2 1 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMAC.csv
+./../../../query_experiment.sh 26461736001 5 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+./../../../query_experiment.sh 26461736001 10 1 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMAC.csv
+./../../../query_experiment.sh 26461736001 20 1 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMAC.csv
+./../../../query_experiment.sh 26461736001 50 1 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMAC.csv
+./../../../query_experiment.sh 26461736001 100 1 >> result_7.txt
+java ProcessResult result_7.txt result_7.out ../sumResultMAC.csv
+./../../../query_experiment.sh 26461736001 200 1 >> result_8.txt
+java ProcessResult result_8.txt result_8.out ../sumResultMAC.csv
+./../../../query_experiment.sh 26461736001 500 1 >> result_9.txt
+java ProcessResult result_9.txt result_9.out ../sumResultMAC.csv
+./../../../query_experiment.sh 26461736001 1000 1 >> result_10.txt
+java ProcessResult result_10.txt result_10.out ../sumResultMAC.csv
+./../../../query_experiment.sh 26461736001 2000 1 >> result_11.txt
+java ProcessResult result_11.txt result_11.out ../sumResultMAC.csv
+./../../../query_experiment.sh 26461736001 4000 1 >> result_12.txt
+java ProcessResult result_12.txt result_12.out ../sumResultMAC.csv
+./../../../query_experiment.sh 26461736001 8000 1 >> result_13.txt
+java ProcessResult result_13.txt result_13.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 1 3 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultCPV.csv
+./../../../query_experiment.sh 26461736001 2 3 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultCPV.csv
+./../../../query_experiment.sh 26461736001 5 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+./../../../query_experiment.sh 26461736001 10 3 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultCPV.csv
+./../../../query_experiment.sh 26461736001 20 3 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultCPV.csv
+./../../../query_experiment.sh 26461736001 50 3 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultCPV.csv
+./../../../query_experiment.sh 26461736001 100 3 >> result_7.txt
+java ProcessResult result_7.txt result_7.out ../sumResultCPV.csv
+./../../../query_experiment.sh 26461736001 200 3 >> result_8.txt
+java ProcessResult result_8.txt result_8.out ../sumResultCPV.csv
+./../../../query_experiment.sh 26461736001 500 3 >> result_9.txt
+java ProcessResult result_9.txt result_9.out ../sumResultCPV.csv
+./../../../query_experiment.sh 26461736001 1000 3 >> result_10.txt
+java ProcessResult result_10.txt result_10.out ../sumResultCPV.csv
+./../../../query_experiment.sh 26461736001 2000 3 >> result_11.txt
+java ProcessResult result_11.txt result_11.out ../sumResultCPV.csv
+./../../../query_experiment.sh 26461736001 4000 3 >> result_12.txt
+java ProcessResult result_12.txt result_12.out ../sumResultCPV.csv
+./../../../query_experiment.sh 26461736001 8000 3 >> result_13.txt
+java ProcessResult result_13.txt result_13.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# [EXP2]
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_0_0
+mkdir vary_tqe
+cd vary_tqe
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 509033300 100 2 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMOC.csv
+./../../../query_experiment.sh 1018066600 100 2 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMOC.csv
+./../../../query_experiment.sh 2036133200 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+./../../../query_experiment.sh 5090333000 100 2 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMOC.csv
+./../../../query_experiment.sh 10180666000 100 2 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMOC.csv
+./../../../query_experiment.sh 26461736001 100 2 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 509033300 100 1 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultMAC.csv
+./../../../query_experiment.sh 1018066600 100 1 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultMAC.csv
+./../../../query_experiment.sh 2036133200 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+./../../../query_experiment.sh 5090333000 100 1 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultMAC.csv
+./../../../query_experiment.sh 10180666000 100 1 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultMAC.csv
+./../../../query_experiment.sh 26461736001 100 1 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 509033300 100 3 >> result_1.txt
+java ProcessResult result_1.txt result_1.out ../sumResultCPV.csv
+./../../../query_experiment.sh 1018066600 100 3 >> result_2.txt
+java ProcessResult result_2.txt result_2.out ../sumResultCPV.csv
+./../../../query_experiment.sh 2036133200 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+./../../../query_experiment.sh 5090333000 100 3 >> result_4.txt
+java ProcessResult result_4.txt result_4.out ../sumResultCPV.csv
+./../../../query_experiment.sh 10180666000 100 3 >> result_5.txt
+java ProcessResult result_5.txt result_5.out ../sumResultCPV.csv
+./../../../query_experiment.sh 26461736001 100 3 >> result_6.txt
+java ProcessResult result_6.txt result_6.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+# [EXP3]
+# ---- O_0_0_D_0_0:
+# ---- ---- iotdb-engine-enableCPVtrue.properties
+# ---- ---- iotdb-engine-enableCPVfalse.properties
+# ---- ---- write_data.sh
+# ---- ---- fix
+# ---- ---- ---- moc
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- mac
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- ---- ---- cpv
+# ---- ---- ---- ---- change_interval_experiments.sh
+# ---- ---- ---- ---- ProcessResult.class
+# ---- ---- ---- ---- ProcessResult.java
+# ---- O_30_10_D_0_0
+# ---- O_50_10_D_0_0
+# ---- O_70_10_D_0_0
+# ---- O_90_10_D_0_0
+
+############################
+# O_0_0_D_0_0
+############################
+
+cd /data3/ruilei/rl/RcvTime_testspace
+mkdir O_0_0_D_0_0
+cd O_0_0_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_0_0_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/RcvTime_O_0_0_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_0_0_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar /data3/raw_data/rl/RcvTime/RcvTime-O_0_0 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_0_0_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_30_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/RcvTime_testspace
+mkdir O_30_10_D_0_0
+cd O_30_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_30_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/RcvTime_O_30_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_30_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar /data3/raw_data/rl/RcvTime/RcvTime-O_30_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_30_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_50_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/RcvTime_testspace
+mkdir O_50_10_D_0_0
+cd O_50_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_50_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/RcvTime_O_50_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_50_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar /data3/raw_data/rl/RcvTime/RcvTime-O_50_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_50_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_70_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/RcvTime_testspace
+mkdir O_70_10_D_0_0
+cd O_70_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_70_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/RcvTime_O_70_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_70_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar /data3/raw_data/rl/RcvTime/RcvTime-O_70_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_70_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_90_10_D_0_0
+############################
+
+cd /data3/ruilei/rl/RcvTime_testspace
+mkdir O_90_10_D_0_0
+cd O_90_10_D_0_0
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_90_10_D_0_0/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/RcvTime_O_90_10_D_0_0/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_90_10_D_0_0/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar /data3/raw_data/rl/RcvTime/RcvTime-O_90_10 0 0 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_90_10_D_0_0
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+# [EXP4]
+# ---- O_10_10_D_0_0
+# ---- O_10_10_D_9_10
+# ---- O_10_10_D_29_10
+# ---- O_10_10_D_49_10
+# ---- O_10_10_D_69_10
+# ---- O_10_10_D_89_10
+
+############################
+# O_10_10_D_9_10
+############################
+
+cd /data3/ruilei/rl/RcvTime_testspace
+mkdir O_10_10_D_9_10
+cd O_10_10_D_9_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_9_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_9_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_9_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar /data3/raw_data/rl/RcvTime/RcvTime-O_10_10 9 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_9_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_29_10
+############################
+
+cd /data3/ruilei/rl/RcvTime_testspace
+mkdir O_10_10_D_29_10
+cd O_10_10_D_29_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_29_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_29_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_29_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar /data3/raw_data/rl/RcvTime/RcvTime-O_10_10 29 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_29_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_49_10
+############################
+
+cd /data3/ruilei/rl/RcvTime_testspace
+mkdir O_10_10_D_49_10
+cd O_10_10_D_49_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_49_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_49_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_49_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar /data3/raw_data/rl/RcvTime/RcvTime-O_10_10 49 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_49_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_69_10
+############################
+
+cd /data3/ruilei/rl/RcvTime_testspace
+mkdir O_10_10_D_69_10
+cd O_10_10_D_69_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_69_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_69_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_69_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar /data3/raw_data/rl/RcvTime/RcvTime-O_10_10 69 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_69_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_89_10
+############################
+
+cd /data3/ruilei/rl/RcvTime_testspace
+mkdir O_10_10_D_89_10
+cd O_10_10_D_89_10
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_89_10/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_89_10/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_89_10/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar /data3/raw_data/rl/RcvTime/RcvTime-O_10_10 89 10 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_89_10
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+# [EXP5]
+# ---- O_10_10_D_49_30
+# ---- O_10_10_D_49_50
+# ---- O_10_10_D_49_70
+# ---- O_10_10_D_49_90
+
+############################
+# O_10_10_D_49_30
+############################
+cd /data3/ruilei/rl/RcvTime_testspace
+mkdir O_10_10_D_49_30
+cd O_10_10_D_49_30
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_49_30/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_49_30/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_49_30/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar /data3/raw_data/rl/RcvTime/RcvTime-O_10_10 49 30 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_49_30
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_49_50
+############################
+cd /data3/ruilei/rl/RcvTime_testspace
+mkdir O_10_10_D_49_50
+cd O_10_10_D_49_50
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_49_50/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_49_50/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_49_50/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar /data3/raw_data/rl/RcvTime/RcvTime-O_10_10 49 50 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_49_50
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_49_70
+############################
+cd /data3/ruilei/rl/RcvTime_testspace
+mkdir O_10_10_D_49_70
+cd O_10_10_D_49_70
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_49_70/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_49_70/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_49_70/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar /data3/raw_data/rl/RcvTime/RcvTime-O_10_10 49 70 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_49_70
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+############################
+# O_10_10_D_49_90
+############################
+cd /data3/ruilei/rl/RcvTime_testspace
+mkdir O_10_10_D_49_90
+cd O_10_10_D_49_90
+
+############################
+# prepare iotdb-engine-enableCPVtrue.properties and iotdb-engine-enableCPVfalse.properties
+############################
+./../../tool.sh enable_CPV true ../../iotdb-engine-example.properties
+./../../tool.sh system_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_49_90/system ../../iotdb-engine-example.properties
+./../../tool.sh data_dirs /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_49_90/data ../../iotdb-engine-example.properties
+./../../tool.sh wal_dir /data3/ruilei/rl/dataSpace2/RcvTime_O_10_10_D_49_90/wal ../../iotdb-engine-example.properties
+./../../tool.sh timestamp_precision ms ../../iotdb-engine-example.properties
+
+./../../tool.sh unseq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh seq_tsfile_size 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh avg_series_point_number_threshold 1000 ../../iotdb-engine-example.properties
+./../../tool.sh compaction_strategy NO_COMPACTION ../../iotdb-engine-example.properties
+./../../tool.sh enable_unseq_compaction false ../../iotdb-engine-example.properties
+./../../tool.sh page_size_in_byte 1073741824 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_address 0.0.0.0 ../../iotdb-engine-example.properties
+./../../tool.sh rpc_port 6667 ../../iotdb-engine-example.properties
+
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVtrue.properties
+
+./../../tool.sh enable_CPV false ../../iotdb-engine-example.properties
+cp ../../iotdb-engine-example.properties iotdb-engine-enableCPVfalse.properties
+
+############################
+# run write_data.sh
+# java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar filePath deleteFreq deleteLen timeIdx valueIdx
+############################
+cp iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+cd /data3/ruilei/rl/iotdb-server-0.12.4/sbin
+./start-server.sh &
+sleep 3s
+java -jar /data3/ruilei/rl/RcvTime_testspace/WriteRcvTime-0.12.4.jar /data3/raw_data/rl/RcvTime/RcvTime-O_10_10 49 90 0 1
+sleep 3s
+./stop-server.sh
+sleep 3s
+echo 3 | sudo tee /proc/sys/vm/drop_caches
+
+
+############################
+# run change_interval_experiments.sh for each approach
+# ./../../../query_experiment.sh tqe w approach
+############################
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_49_90
+mkdir fix
+cd fix
+
+mkdir moc
+cd moc
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 2 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMOC.csv
+
+cd ..
+mkdir mac
+cd mac
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVfalse.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 1 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultMAC.csv
+
+cd ..
+mkdir cpv
+cd cpv
+cp /data3/ruilei/rl/ProcessResult.* .
+cp ../../iotdb-engine-enableCPVtrue.properties /data3/ruilei/rl/iotdb-server-0.12.4/conf/iotdb-engine.properties
+./../../../query_experiment.sh 26461736001 100 3 >> result_3.txt
+java ProcessResult result_3.txt result_3.out ../sumResultCPV.csv
+
+cd ..
+cp /data3/ruilei/rl/SumResultUnify.* .
+java SumResultUnify sumResultMOC.csv sumResultMAC.csv sumResultCPV.csv result.csv
+
+#########################
+# sum results
+# [EXP3]
+# ---- O_0_0_D_0_0
+# ---- O_30_10_D_0_0
+# ---- O_50_10_D_0_0
+# ---- O_70_10_D_0_0
+# ---- O_90_10_D_0_0
+# [EXP4]
+# ---- O_10_10_D_9_10
+# ---- O_10_10_D_29_10
+# ---- O_10_10_D_49_10
+# ---- O_10_10_D_69_10
+# ---- O_10_10_D_89_10
+# [EXP5]
+# ---- O_10_10_D_49_30
+# ---- O_10_10_D_49_50
+# ---- O_10_10_D_49_70
+# ---- O_10_10_D_49_90
+#########################
+# [EXP3]
+cd /data3/ruilei/rl/RcvTime_testspace/O_0_0_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/RcvTime_testspace/exp3.csv
+
+cd /data3/ruilei/rl/RcvTime_testspace/O_30_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/RcvTime_testspace/exp3.csv
+
+cd /data3/ruilei/rl/RcvTime_testspace/O_50_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/RcvTime_testspace/exp3.csv
+
+cd /data3/ruilei/rl/RcvTime_testspace/O_70_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/RcvTime_testspace/exp3.csv
+
+cd /data3/ruilei/rl/RcvTime_testspace/O_90_10_D_0_0
+cd fix
+cat result.csv >>/data3/ruilei/rl/RcvTime_testspace/exp3.csv
+
+# [EXP4]
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_9_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/RcvTime_testspace/exp4.csv
+
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_29_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/RcvTime_testspace/exp4.csv
+
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_49_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/RcvTime_testspace/exp4.csv
+
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_69_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/RcvTime_testspace/exp4.csv
+
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_89_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/RcvTime_testspace/exp4.csv
+
+# [EXP5]
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_49_10
+cd fix
+cat result.csv >>/data3/ruilei/rl/RcvTime_testspace/exp5.csv
+
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_49_30
+cd fix
+cat result.csv >>/data3/ruilei/rl/RcvTime_testspace/exp5.csv
+
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_49_50
+cd fix
+cat result.csv >>/data3/ruilei/rl/RcvTime_testspace/exp5.csv
+
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_49_70
+cd fix
+cat result.csv >>/data3/ruilei/rl/RcvTime_testspace/exp5.csv
+
+cd /data3/ruilei/rl/RcvTime_testspace/O_10_10_D_49_90
+cd fix
+cat result.csv >>/data3/ruilei/rl/RcvTime_testspace/exp5.csv
diff --git a/example/session/src/main/java/org/apache/iotdb/datasets/BallSpeed.csv b/example/session/src/main/java/org/apache/iotdb/datasets/BallSpeed.csv
new file mode 100644
index 0000000..7a01bbf
--- /dev/null
+++ b/example/session/src/main/java/org/apache/iotdb/datasets/BallSpeed.csv
@@ -0,0 +1,1200000 @@
+11660272484457846,14398944
+11660272996453563,14382611
+11660273508449807,14343104
+11660274020445854,14343326
+11660274532441709,14360021
+11660275044437861,14367404
+11660275556433638,14323245
+11660276068429548,14368469
+11660276580425844,14402777
+11660277092421260,14425259
+11660277604417363,14424364
+11660278116413440,14392969
+11660278628409373,14410893
+11660279140405430,14413365
+11660279652401452,14388530
+11660280164397658,14379080
+11660280676392979,14398677
+11660281188389248,14461902
+11660281700385358,14491373
+11660282212381586,14472465
+11660282724377099,14399021
+11660283236373177,14374292
+11660283748368894,14404733
+11660284260365186,14448942
+11660284772361161,14387138
+11660285284356861,14325127
+11660285796353023,14356712
+11660286308348778,14380557
+11660286820345025,14401145
+11660287332341477,14412252
+11660287844336991,14384133
+11660288356332777,14392752
+11660288868328519,14414212
+11660289380324907,14382181
+11660289892320754,14408878
+11660290404317356,14482526
+11660290916312688,14573103
+11660291428308317,14563836
+11660291940304732,14536662
+11660292452300899,14521988
+11660292964296488,14519203
+11660293476292515,14522051
+11660293988288501,14593067
+11660294500284432,14667153
+11660295012280546,14678306
+11660295524276780,14714548
+11660296036272591,14725758
+11660296548268503,14715539
+11660297060264809,14672523
+11660297572260312,14592434
+11660298084256286,14533653
+11660298596252450,14563154
+11660299108248018,14569646
+11660299620244751,14522249
+11660300132239865,14542092
+11660300644235555,14589845
+11660301156232041,14557811
+11660301668228604,14569112
+11660302180224504,14507588
+11660302692220178,14503091
+11660303204216123,14544464
+11660303716212016,14597060
+11660304228208310,14458491
+11660304740203986,14283321
+11660305252199732,14270424
+11660305764195990,14303884
+11660306276191760,14335257
+11660306788187982,14320367
+11660307300183899,14292599
+11660307812179990,14295440
+11660308324175936,14312516
+11660308836171081,14283531
+11660309348167847,14324126
+11660309860163829,14429804
+11660310372159367,14360944
+11660310884155220,14331538
+11660311396151143,14327379
+11660311908147570,14344902
+11660312420143305,14396727
+11660312932139656,14356431
+11660313444135495,14369058
+11660313956131341,14397236
+11660314468127285,14369846
+11660314980123577,14401902
+11660315492119898,14427986
+11660316004115055,14457895
+11660316516110842,14494628
+11660317028106828,14442647
+11660317540102871,14385639
+11660318052098828,14444968
+11660318564094755,14466761
+11660319076090810,14435756
+11660319588086771,14372920
+11660320100082884,14438913
+11660320612078379,14468615
+11660321124074562,14461529
+11660321636070661,14470252
+11660322148066801,14648786
+11660322660062629,14814047
+11660323172058475,14782156
+11660323684054410,14679839
+11660324196050394,14604356
+11660324708046372,14584502
+11660325220042182,14569440
+11660325732038028,14551733
+11660326244034272,14533158
+11660326756030208,14542155
+11660327268025949,14515648
+11660327780022090,14533850
+11660328292017895,14531505
+11660328804013800,14534931
+11660329316010147,14492104
+11660329828006017,14485344
+11660330340002072,14471989
+11660330851997642,14387648
+11660331363993737,14437104
+11660331875989491,14530833
+11660332387985997,14744493
+11660332899981512,14897111
+11660333411977815,14901787
+11660333923973521,14879063
+11660334435969165,14908701
+11660334947965585,14929151
+11660335459961314,14860246
+11660335971957569,14819126
+11660336483953300,14800806
+11660336995949065,14695826
+11660337507945103,14626221
+11660338019941530,14621750
+11660338531937187,14685280
+11660339043933060,14744124
+11660339555929036,14797166
+11660340067925145,14930747
+11660340579920872,14938063
+11660341091917060,14890404
+11660341603912889,14854311
+11660342115908663,14818377
+11660342627904921,14768374
+11660343139900850,14762856
+11660343651896536,14787595
+11660344163892731,14708168
+11660344675888693,14730140
+11660345187884603,14780513
+11660345699880692,14832706
+11660346211876449,14876385
+11660346723872445,14868713
+11660347235868619,14852158
+11660347747864483,14772113
+11660348259860373,14738874
+11660348771856290,14743902
+11660349283852512,14676412
+11660349795848228,14588226
+11660350307844508,14484214
+11660350819840319,14454869
+11660351331836221,14537072
+11660351843832429,14675228
+11660352355828110,14791631
+11660352867824132,14807535
+11660353379820095,14773787
+11660353891815771,14770793
+11660354403812028,14736087
+11660354915808018,14758361
+11660355427803768,14636880
+11660355939799891,14529510
+11660356451795781,14607674
+11660356963791691,14614656
+11660357475787402,14573103
+11660357987783266,14641339
+11660358499779462,14605917
+11660359011775497,14494866
+11660359523771361,14437171
+11660360035767359,14422949
+11660360547763642,14586213
+11660361059759269,14576438
+11660361571755411,14578392
+11660362083751073,14760924
+11660362595747113,14718161
+11660363107743051,14754282
+11660363619739153,14873271
+11660364131735010,14586797
+11660364643731037,14494964
+11660365155727148,14528281
+11660365667723019,14438814
+11660366179718932,14370813
+11660366691714859,14398139
+11660367203711393,14418220
+11660367715706698,14420889
+11660368227702838,14430295
+11660368739698599,14433446
+11660369251694495,14479457
+11660369763690799,14502819
+11660370275686497,14472653
+11660370787682689,14490456
+11660371299678329,14634779
+11660371811674411,14788807
+11660372323670469,14817298
+11660372835666467,14822835
+11660373347662787,14848305
+11660373859658289,14875945
+11660374371654112,14895127
+11660374883650250,14858541
+11660375395646332,14903146
+11660375907642238,14921694
+11660376419638065,14867835
+11660376931634176,14698626
+11660377443629990,14630935
+11660377955626158,14774217
+11660378467621789,14806788
+11660378979618076,14807884
+11660379491613960,14664284
+11660380003610031,14583289
+11660380515605746,14528884
+11660381027601679,14556000
+11660381539597902,14594466
+11660382051593741,14593456
+11660382563589855,14602370
+11660383075585666,14724777
+11660383587581543,14867233
+11660384099577582,14902667
+11660384611573624,14847021
+11660385123569529,14878841
+11660385635565618,14817793
+11660386147561605,14750641
+11660386659557417,14701310
+11660387171553182,14566426
+11660387683549131,14573169
+11660388195545181,14652517
+11660388707541124,14634840
+11660389219537319,14630856
+11660389731532998,14699116
+11660390243529154,14736431
+11660390755525276,14766963
+11660391267520907,14880686
+11660391779517099,15028090
+11660392291512865,15033364
+11660392803508890,14973519
+11660393315505107,14983645
+11660393827501060,15025861
+11660394339496601,15044546
+11660394851492841,14973270
+11660395363488864,14803573
+11660395875484858,14739620
+11660396387480583,14615127
+11660396899476857,14497433
+11660397411472675,14618794
+11660397923468578,14753185
+11660398435464529,14861704
+11660398947460301,14877923
+11660399459456361,14813647
+11660399971452423,14662124
+11660400483448256,14592738
+11660400995444139,14562887
+11660401507440512,14496773
+11660402019436297,14520377
+11660402531432245,14561587
+11660403043428190,14614226
+11660403555424379,14601385
+11660404067420264,14537115
+11660404579416410,14493630
+11660405091412060,14502215
+11660405603407937,14554924
+11660406115403731,14587077
+11660406627399798,14675110
+11660407139395982,14770596
+11660407651391802,14787561
+11660408163387775,14793884
+11660408675383985,14712912
+11660409187379965,14635540
+11660409699375809,14558773
+11660410211371475,14518441
+11660410723367898,14556042
+11660411235363503,14680588
+11660411747359656,14785188
+11660412259355449,14944966
+11660412771351278,14896787
+11660413283347254,14919337
+11660413795343457,14907231
+11660414307339517,14836462
+11660414819335605,14880699
+11660415331331441,14942701
+11660415843327444,14913448
+11660416355323301,14836517
+11660416867319164,14686496
+11660417379315064,14531146
+11660417891311038,14533666
+11660418403307263,14548809
+11660418915303152,14642570
+11660419427298634,14765836
+11660419939295091,14813371
+11660420451291004,14831522
+11660420963286799,14821419
+11660421475282948,14785811
+11660421987278961,14633315
+11660422499274965,14563021
+11660423011270706,14674738
+11660423523266970,14731581
+11660424035262757,14768535
+11660424547258649,14831602
+11660425059254655,14787802
+11660425571250440,14773389
+11660426083246308,14701590
+11660426595242431,14608760
+11660427107238837,14586905
+11660427619234312,14499585
+11660428131230341,14402391
+11660428643226416,14435997
+11660429155222232,14535770
+11660429667218158,14607868
+11660430179214241,14630588
+11660430691210100,14600291
+11660431203206147,14463731
+11660431715202164,14383343
+11660432227197976,14409227
+11660432739193979,14541675
+11660433251190082,14687687
+11660433763186070,14848787
+11660434275182027,14786937
+11660434787177888,14714723
+11660435299173822,14654084
+11660435811169337,14542784
+11660436323165571,14461406
+11660436835161783,14470013
+11660437347157664,14473949
+11660437859153755,14505279
+11660438371149776,14497287
+11660438883145733,14572024
+11660439395141854,14624573
+11660439907137677,14623790
+11660440419133412,14686742
+11660440931129578,14688359
+11660441443125239,14694377
+11660441955121271,14684281
+11660442467117314,14624297
+11660442979113643,14594671
+11660443491108993,14562330
+11660444003106003,14542125
+11660444515101066,14539144
+11660445027096949,14593014
+11660445539092908,14616250
+11660446051088754,14670379
+11660446563085068,14684992
+11660447075081338,14612312
+11660447587077077,14607309
+11660448099072983,14588617
+11660448611069189,14476343
+11660449123065123,14426589
+11660449635061255,14440826
+11660450147056767,14500948
+11660450659053048,14573492
+11660451171049085,14696171
+11660451683044870,14823097
+11660452195041033,14885715
+11660452707036980,14851978
+11660453219032595,14728728
+11660453731028648,14657059
+11660454243024691,14631387
+11660454755020496,14528692
+11660455267016531,14488246
+11660455779012416,14478333
+11660456291008473,14503026
+11660456803004131,14473169
+11660457315000301,14396807
+11660457826996286,14332020
+11660458338992454,14212496
+11660458850988395,14160406
+11660459362984343,14179939
+11660459874980075,14242003
+11660460386976274,14333908
+11660460898972231,14356905
+11660461410967973,14407695
+11660461922963880,14354612
+11660462434960063,14274314
+11660462946955665,14189918
+11660463458951913,14128297
+11660463970947834,14130925
+11660464482943476,14158481
+11660464994939677,14248311
+11660465506935431,14368184
+11660466018931628,14385461
+11660466530927341,14262107
+11660467042923473,14159835
+11660467554919320,14136053
+11660468066915615,14098871
+11660468578911697,14064770
+11660469090907249,14053903
+11660469602903417,14040695
+11660470114899088,14124041
+11660470626894877,14223172
+11660471138890954,14249023
+11660471650886913,14278851
+11660472162882925,14371284
+11660472674879161,14471972
+11660473186875045,14453108
+11660473698871162,14393763
+11660474210867143,14313726
+11660474722863297,14316499
+11660475234858793,14276702
+11660475746854798,14160672
+11660476258850888,14121956
+11660476770846884,14059151
+11660477282843051,14020974
+11660477794838857,14026377
+11660478306834803,13988218
+11660478818830932,13846233
+11660479330826912,13794908
+11660479842822717,13847746
+11660480354818583,13919191
+11660480866814506,13918006
+11660481378810770,13940135
+11660481890806600,13974646
+11660482402802632,13985211
+11660482914798423,13887586
+11660483426794531,13725323
+11660483938790600,13778753
+11660484450786596,13751630
+11660484962782825,13688530
+11660485474779118,13632283
+11660485986774606,13458747
+11660486498770563,13333959
+11660487010766259,13307973
+11660487522762386,13266395
+11660488034758356,13170110
+11660488546753973,13065980
+11660489058750300,12946798
+11660489570746063,12722737
+11660490082742272,12670803
+11660490594737595,12629953
+11660491106734000,12658409
+11660491618730086,12786986
+11660492130725859,12920391
+11660492642721762,12919051
+11660493154717778,12743348
+11660493666713901,12621396
+11660494178709771,12607199
+11660494690705844,12596597
+11660495202701684,12600491
+11660495714697431,12687565
+11660496226693223,12825466
+11660496738689425,12833713
+11660497250685160,12840239
+11660497762681047,12780328
+11660498274677328,12659367
+11660498786673438,12577076
+11660499298669327,12439263
+11660499810665410,12391920
+11660500322661578,12377399
+11660500834657013,12418644
+11660501346653288,12449030
+11660501858649515,12451559
+11660502370645428,12487640
+11660502882640953,12464263
+11660503394636841,12428210
+11660503906632813,12413859
+11660504418628866,12448966
+11660504930625230,12485173
+11660505442621067,12423640
+11660505954616543,12303280
+11660506466612593,12307092
+11660506978608256,12321068
+11660507490604475,12309434
+11660508002600392,12292765
+11660508514596077,12234664
+11660509026592476,12162132
+11660509538588825,12195890
+11660510050584582,12187531
+11660510562580616,12174832
+11660511074576504,12244464
+11660511586572521,12251002
+11660512098568291,12328934
+11660512610564429,12447510
+11660513122560087,12489826
+11660513634556120,12484748
+11660514146551997,12427012
+11660514658547851,12481246
+11660515170543875,12559783
+11660515682540041,12578513
+11660516194536078,12628958
+11660516706531846,12667005
+11660517218527974,12690892
+11660517730523658,12669533
+11660518242519440,12654176
+11660518754516192,12607970
+11660519266512191,12524378
+11660519778508058,12525539
+11660520290503971,12545709
+11660520802500027,12544655
+11660521314496291,12568164
+11660521826491704,12547395
+11660522338487769,12420711
+11660522850483583,12426674
+11660523362479422,12480807
+11660523874475659,12469333
+11660524386471403,12465338
+11660524898467372,12548527
+11660525410463398,12465846
+11660525922459410,12422451
+11660526434455427,12396766
+11660526946451130,12329087
+11660527458447365,12259881
+11660527970442824,12207383
+11660528482439105,12196813
+11660528994434709,12202820
+11660529506430527,12177645
+11660530018426735,12150998
+11660530530422817,12090927
+11660531042418394,12102749
+11660531554414654,12060551
+11660532066410841,12093086
+11660532578406450,12235877
+11660533090403021,12328886
+11660533602398735,12258776
+11660534114394412,12194248
+11660534626390635,12245167
+11660535138386436,12275256
+11660535650382260,12296139
+11660536162378564,12394412
+11660536674374267,12353084
+11660537186370146,12300817
+11660537698366387,12362146
+11660538210362636,12422966
+11660538722358841,12442751
+11660539234354383,12431435
+11660539746350340,12364145
+11660540258346132,12321265
+11660540770342315,12293213
+11660541282338063,12262566
+11660541794334468,12394758
+11660542306329892,12398069
+11660542818325907,12412500
+11660543330322155,12499953
+11660543842318279,12531952
+11660544354314082,12482114
+11660544866310103,12471489
+11660545378306091,12455395
+11660545890302018,12444176
+11660546402298169,12517034
+11660546914293728,12501411
+11660547426289712,12522883
+11660547938285733,12577986
+11660548450281625,12549713
+11660548962277910,12529878
+11660549474273895,12511076
+11660549986269572,12537900
+11660550498265676,12590804
+11660551010261746,12592288
+11660551522257730,12599912
+11660552034253683,12531715
+11660552546249886,12545416
+11660553058245531,12578996
+11660553570241661,12600109
+11660554082237670,12640667
+11660554594233447,12670764
+11660555106229502,12723516
+11660555618225336,12636089
+11660556130221292,12519253
+11660556642217276,12452156
+11660557154213347,12449978
+11660557666209078,12463154
+11660558178205076,12457799
+11660558690201189,12499949
+11660559202197184,12510585
+11660559714192952,12503333
+11660560226188784,12532566
+11660560738184898,12541308
+11660561250180251,12522861
+11660561762176832,12482937
+11660562274172641,12470455
+11660562786168559,12449214
+11660563298164679,12464222
+11660563810160609,12564259
+11660564322156502,12685463
+11660564834152656,12687535
+11660565346148361,12612121
+11660565858144443,12674948
+11660566370140090,12737773
+11660566882136283,12609654
+11660567394132107,12545500
+11660567906128354,12597361
+11660568418124309,12682411
+11660568930120442,12677443
+11660569442116033,12655524
+11660569954112163,12672175
+11660570466108035,12685798
+11660570978104084,12588119
+11660571490100278,12494470
+11660572002095845,12460590
+11660572514092115,12494984
+11660573026087982,12475337
+11660573538084071,12465741
+11660574050079729,12491486
+11660574562075802,12570713
+11660575074071858,12565942
+11660575586067866,12523502
+11660576098063802,12537300
+11660576610059697,12566315
+11660577122055751,12632293
+11660577634051418,12648244
+11660578146047309,12618404
+11660578658043282,12616440
+11660579170039746,12591908
+11660579682035052,12558264
+11660580194031013,12601339
+11660580706027049,12514944
+11660581218023103,12464582
+11660581730018982,12468094
+11660582242015064,12502967
+11660582754011057,12512404
+11660583266006975,12486871
+11660583778002872,12563654
+11660584289999099,12703389
+11660584801994918,12758712
+11660585313990743,12764532
+11660585825986697,12722375
+11660586337982501,12652329
+11660586849978329,12620287
+11660587361974578,12646094
+11660587873970368,12698542
+11660588385966603,12723616
+11660588897962221,12793173
+11660589409958222,12834113
+11660589921954180,12803656
+11660590433950135,12805766
+11660590945946393,12746887
+11660591457942210,12674200
+11660591969938130,12632728
+11660592481934000,12621333
+11660592993930072,12621018
+11660593505925762,12628002
+11660594017921949,12692467
+11660594529917874,12743696
+11660595041913970,12767655
+11660595553909810,12753998
+11660596065906314,12719301
+11660596577901870,12687024
+11660597089897782,12758441
+11660597601893681,12814721
+11660598113889192,12802884
+11660598625885847,12828645
+11660599137881506,12961753
+11660599649877653,13058592
+11660600161873485,13038006
+11660600673869534,12891600
+11660601185865459,12786657
+11660601697861476,12755634
+11660602209857257,12789106
+11660602721853418,12794340
+11660603233849704,12793138
+11660603745845074,12852343
+11660604257841120,12945217
+11660604769837052,13027141
+11660605281833057,13020694
+11660605793829140,12953352
+11660606305825173,12867697
+11660606817820904,12849514
+11660607329817599,12866864
+11660607841813080,12923875
+11660608353808801,12920087
+11660608865804815,12915382
+11660609377800937,12972819
+11660609889796708,12990477
+11660610401792876,12992395
+11660610913788789,12964199
+11660611425785171,12892895
+11660611937781157,12823755
+11660612449776839,12831386
+11660612961772783,12834737
+11660613473768869,12865570
+11660613985764537,12938943
+11660614497760738,12985864
+11660615009756375,13055695
+11660615521752276,12973786
+11660616033748091,12875844
+11660616545744503,12808292
+11660617057740322,12803908
+11660617569736633,12868004
+11660618081732016,12828935
+11660618593727887,12796504
+11660619105723862,12855622
+11660619617719859,12907126
+11660620129715908,12933446
+11660620641711750,12895874
+11660621153707813,12837140
+11660621665703893,12766784
+11660622177700016,12774828
+11660622689695912,12836917
+11660623201692182,12819687
+11660623713687716,12830702
+11660624225684255,12894844
+11660624737679920,12904166
+11660625249675733,12928642
+11660625761671720,12930496
+11660626273667756,12923371
+11660626785663300,12890051
+11660627297659331,12873781
+11660627809655496,12891476
+11660628321651352,12889181
+11660628833647887,12903196
+11660629345643427,12945074
+11660629857639243,12915544
+11660630369635119,12996732
+11660630881631182,13097929
+11660631393627065,13059770
+11660631905622732,13017066
+11660632417618920,12957699
+11660632929614943,12930513
+11660633441610720,12915382
+11660633953607113,12902155
+11660634465603114,12883748
+11660634977599064,12854847
+11660635489594924,12890024
+11660636001591007,12939307
+11660636513587391,12934839
+11660637025583018,12903566
+11660637537578908,12892922
+11660638049574906,12881599
+11660638561570802,12901257
+11660639073566645,12890514
+11660639585562560,12896175
+11660640097558566,12915562
+11660640609554464,12891259
+11660641121550429,12860821
+11660641633546274,12807946
+11660642145542399,12796756
+11660642657538492,12788501
+11660643169534416,12735301
+11660643681530316,12720050
+11660644193526285,12773797
+11660644705522222,12771460
+11660645217517925,12681152
+11660645729514205,12668627
+11660646241509963,12663647
+11660646753506228,12631508
+11660647265501902,12625594
+11660647777498049,12675046
+11660648289494239,12675116
+11660648801490195,12682828
+11660649313485977,12608296
+11660649825482213,12541004
+11660650337477870,12571477
+11660650849474093,12585864
+11660651361469950,12623566
+11660651873465651,12608504
+11660652385461494,12499148
+11660652897457712,12445760
+11660653409453617,12480036
+11660653921450237,12481576
+11660654433445688,12504987
+11660654945441648,12512953
+11660655457437718,12503876
+11660655969433509,12488932
+11660656481429399,12510220
+11660656993425348,12545406
+11660657505421425,12533829
+11660658017417125,12497510
+11660658529413313,12465610
+11660659041408807,12455546
+11660659553405339,12452348
+11660660065401406,12424191
+11660660577396958,12430441
+11660661089392788,12434476
+11660661601388869,12454653
+11660662113384994,12425895
+11660662625380719,12387451
+11660663137377017,12411482
+11660663649372985,12410940
+11660664161368893,12432105
+11660664673364939,12447841
+11660665185361042,12433213
+11660665697356503,12438176
+11660666209352912,12480891
+11660666721349011,12476139
+11660667233344721,12481518
+11660667745340702,12490273
+11660668257336483,12517320
+11660668769332788,12509889
+11660669281328404,12493713
+11660669793324349,12478846
+11660670305320162,12432912
+11660670817316363,12431884
+11660671329312135,12416583
+11660671841308178,12394990
+11660672353304405,12381415
+11660672865300313,12371962
+11660673377296339,12395170
+11660673889292264,12381147
+11660674401288128,12343098
+11660674913284343,12358999
+11660675425279926,12435703
+11660675937276227,12426987
+11660676449271902,12389012
+11660676961267688,12430688
+11660677473263879,12394858
+11660677985259949,12409876
+11660678497255773,12458871
+11660679009252739,12442951
+11660679521247488,12409851
+11660680033243572,12457117
+11660680545239495,12457597
+11660681057235505,12458937
+11660681569231497,12506324
+11660682081227452,12488586
+11660682593223576,12486829
+11660683105219474,12434414
+11660683617215567,12403124
+11660684129211481,12417775
+11660684641207319,12410787
+11660685153203305,12400276
+11660685665199338,12361279
+11660686177195283,12356582
+11660686689191194,12402164
+11660687201187021,12391430
+11660687713183339,12318393
+11660688225179011,12315710
+11660688737174905,12314187
+11660689249171165,12280347
+11660689761166950,12277889
+11660690273163045,12267955
+11660690785158968,12205377
+11660691297155243,12181824
+11660691809151175,12202835
+11660692321146964,12192070
+11660692833143070,12143635
+11660693345138753,12106382
+11660693857134728,12132467
+11660694369130958,12149440
+11660694881126601,12183897
+11660695393122415,12132201
+11660695905118535,12074902
+11660696417114433,12109642
+11660696929110338,12148160
+11660697441106550,12123470
+11660697953102599,12022157
+11660698465098341,12010434
+11660698977094479,12011382
+11660699489090630,11996197
+11660700001086416,11981726
+11660700513082177,12039174
+11660701025078397,12052027
+11660701537074101,12048347
+11660702049070315,12062000
+11660702561066227,12039828
+11660703073062196,12009078
+11660703585058398,11990623
+11660704097054103,11993410
+11660704609050010,11987230
+11660705121045705,11988238
+11660705633041728,12058557
+11660706145037430,12041243
+11660706657033421,11956032
+11660707169029811,11978027
+11660707681025396,11928271
+11660708193021645,11844155
+11660708705017492,11828634
+11660709217014036,11802759
+11660709729009247,11810243
+11660710241005135,11870824
+11660710753001565,11844211
+11660711264997364,11894628
+11660711776993778,11861015
+11660712288990052,11835845
+11660712800985531,11873415
+11660713312981593,11850630
+11660713824977651,11856467
+11660714336973487,11855568
+11660714848968970,11816106
+11660715360965387,11714197
+11660715872961430,11679135
+11660716384956730,11706167
+11660716896953125,11713643
+11660717408949350,11671263
+11660717920945349,11691252
+11660718432940734,11710887
+11660718944937491,11875130
+11660719456933468,11881670
+11660719968929330,11842990
+11660720480925074,11811856
+11660720992920893,11841812
+11660721504916906,11899638
+11660722016912996,11925698
+11660722528908798,11905921
+11660723040904679,11838022
+11660723552900589,11895275
+11660724064896631,11960953
+11660724576892680,11934700
+11660725088888354,11917818
+11660725600884452,11972502
+11660726112880271,12086095
+11660726624876372,12098415
+11660727136872322,12093865
+11660727648868342,12093466
+11660728160864396,12132300
+11660728672860549,12192609
+11660729184856289,12140005
+11660729696852222,12102092
+11660730208848214,12142700
+11660730720843755,12166205
+11660731232840093,12191256
+11660731744835929,12198952
+11660732256831986,12277293
+11660732768827881,12343653
+11660733280823989,12317857
+11660733792820127,12282966
+11660734304815948,12296723
+11660734816811911,12324630
+11660735328807793,12330527
+11660735840803726,12353405
+11660736352799777,12326907
+11660736864795660,12306536
+11660737376791776,12317451
+11660737888787675,12301722
+11660738400783315,12321538
+11660738912779548,12333008
+11660739424775417,12342981
+11660739936771327,12370986
+11660740448767446,12398988
+11660740960763469,12418916
+11660741472759339,12376355
+11660741984755426,12345995
+11660742496751407,12346466
+11660743008747500,12379374
+11660743520742982,12437012
+11660744032739205,12528956
+11660744544734998,12560640
+11660745056731055,12500100
+11660745568726953,12567423
+11660746080723072,12543094
+11660746592719060,12345881
+11660747104714894,12284965
+11660747616710816,12265557
+11660748128707022,12309314
+11660748640702935,12397645
+11660749152698603,12357832
+11660749664694570,12362876
+11660750176690471,12450515
+11660750688686326,12462542
+11660751200682714,12447727
+11660751712678614,12398669
+11660752224674512,12372321
+11660752736670296,12399882
+11660753248666841,12454445
+11660753760662330,12485358
+11660754272658374,12473219
+11660754784654606,12422999
+11660755296650436,12430118
+11660755808646365,12482713
+11660756320642203,12483329
+11660756832637779,12458754
+11660757344634242,12462226
+11660757856630110,12468698
+11660758368626000,12492525
+11660758880622576,12522759
+11660759392617935,12533641
+11660759904613655,12522054
+11660760416609987,12504069
+11660760928605762,12480510
+11660761440601389,12496586
+11660761952597588,12515831
+11660762464593822,12532834
+11660762976589468,12523618
+11660763488585530,12515646
+11660764000581401,12557295
+11660764512577532,12569601
+11660765024573023,12565882
+11660765536569322,12590473
+11660766048565529,12613285
+11660766560561146,12594306
+11660767072557050,12565275
+11660767584553349,12601206
+11660768096549155,12645038
+11660768608545378,12662371
+11660769120541025,12667992
+11660769632537054,12684478
+11660770144533061,12688564
+11660770656528968,12685749
+11660771168525047,12738260
+11660771680520966,12756602
+11660772192516822,12792775
+11660772704512640,12837501
+11660773216508654,12809678
+11660773728504380,12760689
+11660774240500634,12735413
+11660774752496524,12732719
+11660775264492401,12714356
+11660775776488531,12742521
+11660776288484405,12777691
+11660776800480213,12790312
+11660777312476666,12775707
+11660777824472425,12755730
+11660778336468211,12782578
+11660778848464362,12803926
+11660779360460375,12762932
+11660779872456193,12764354
+11660780384451862,12795525
+11660780896448127,12781573
+11660781408443861,12736606
+11660781920440390,12716740
+11660782432435837,12714582
+11660782944431813,12725743
+11660783456427985,12714558
+11660783968423949,12685099
+11660784480419904,12651080
+11660784992415632,12743432
+11660785504411930,12849163
+11660786016407674,12704224
+11660786528403645,12543714
+11660787040399492,12512093
+11660787552395486,12483301
+11660788064391438,12513491
+11660788576387238,12563812
+11660789088383710,12528750
+11660789600379371,12423609
+11660790112375360,12392226
+11660790624371155,12385487
+11660791136367433,12365563
+11660791648363009,12379008
+11660792160358936,12426672
+11660792672354989,12410331
+11660793184351167,12325506
+11660793696346773,12301432
+11660794208342986,12296063
+11660794720338834,12229838
+11660795232334767,12198245
+11660795744331265,12176487
+11660796256326643,12126803
+11660796768322575,12160683
+11660797280318454,12246144
+11660797792314422,12320960
+11660798304310450,12414432
+11660798816306095,12424092
+11660799328302120,12319170
+11660799840298451,12209071
+11660800352294479,12097834
+11660800864290533,12064523
+11660801376286647,12048855
+11660801888282656,12020485
+11660802400278390,11969597
+11660802912274326,11945439
+11660803424270599,11934028
+11660803936266342,11884560
+11660804448261987,11847461
+11660804960258013,11856477
+11660805472254114,11867421
+11660805984250231,11889757
+11660806496246118,12023287
+11660807008242329,12302742
+11660807520238270,12409713
+11660808032234429,12355768
+11660808544230077,12280830
+11660809056226004,12217884
+11660809568221983,12243069
+11660810080217914,12362924
+11660810592214083,12406257
+11660811104209977,12418774
+11660811616206040,12450891
+11660812128202448,12486630
+11660812640198168,12459211
+11660813152193971,12298006
+11660813664189504,12098956
+11660814176185575,11977636
+11660814688181605,11873390
+11660815200177560,11846015
+11660815712173993,11804504
+11660816224169369,11784298
+11660816736165870,11801886
+11660817248161396,11686494
+11660817760157360,11552212
+11660818272153478,11433578
+11660818784149326,11382805
+11660819296145052,11340010
+11660819808141134,11320524
+11660820320137115,11316592
+11660820832133268,11225381
+11660821344129292,11153243
+11660821856125388,11149718
+11660822368120967,11121639
+11660822880117191,11127556
+11660823392113138,11133243
+11660823904108913,11170545
+11660824416105041,11220443
+11660824928100818,11246219
+11660825440096677,11259850
+11660825952092983,11292951
+11660826464088848,11264958
+11660826976084773,11213657
+11660827488080653,11217586
+11660828000076686,11252776
+11660828512073060,11256364
+11660829024068723,11294158
+11660829536064586,11361284
+11660830048060593,11284138
+11660830560056468,11205104
+11660831072052583,11163417
+11660831584048084,11116200
+11660832096044228,11060237
+11660832608040911,11047439
+11660833120036139,11049715
+11660833632032080,11061491
+11660834144028426,11069604
+11660834656024136,11113733
+11660835168019987,11042992
+11660835680015891,10970545
+11660836192011969,10940418
+11660836704007891,10936982
+11660837216004075,10938724
+11660837728000033,10960194
+11660838239996062,11004460
+11660838751991961,11034946
+11660839263987675,11087306
+11660839775983806,11039466
+11660840287979755,10916931
+11660840799975767,10857981
+11660841311971586,10879636
+11660841823967755,10890331
+11660842335963703,10869512
+11660842847959882,10845552
+11660843359955417,10804832
+11660843871951692,10903544
+11660844383947634,10874548
+11660844895943496,10840058
+11660845407939425,10867128
+11660845919935198,10989624
+11660846431931174,11105919
+11660846943927089,11097388
+11660847455923106,11068029
+11660847967918354,11065418
+11660848479915238,11020851
+11660848991910818,10918311
+11660849503907172,10913495
+11660850015902750,10864795
+11660850527898892,10843413
+11660851039894886,10899915
+11660851551890789,10908533
+11660852063886638,10890883
+11660852575882688,10895944
+11660853087878945,10884525
+11660853599875014,10834579
+11660854111870844,10776827
+11660854623866795,10804088
+11660855135862767,10836255
+11660855647858607,10857393
+11660856159854763,10913840
+11660856671850751,10976462
+11660857183846594,10974418
+11660857695842727,10872331
+11660858207838914,10864651
+11660858719834643,10842284
+11660859231830621,10821900
+11660859743826600,10838735
+11660860255822506,10863125
+11660860767818492,10880375
+11660861279814346,10885038
+11660861791810539,10838329
+11660862303806378,10767935
+11660862815802566,10736991
+11660863327798466,10742970
+11660863839794251,10750775
+11660864351790426,10795024
+11660864863786425,10824508
+11660865375782035,10881587
+11660865887778348,10968038
+11660866399774442,10977274
+11660866911769868,10954814
+11660867423766128,10955921
+11660867935762215,10972886
+11660868447758172,11010162
+11660868959754131,10914223
+11660869471749915,10859841
+11660869983745847,10880200
+11660870495741783,10969488
+11660871007737988,10992844
+11660871519733778,11045632
+11660872031729803,11144526
+11660872543725813,11048997
+11660873055721588,11023372
+11660873567717897,11129196
+11660874079713964,11092279
+11660874591709519,10980214
+11660875103705567,10976835
+11660875615701532,10872044
+11660876127697369,10751549
+11660876639693228,10761077
+11660877151689351,10776466
+11660877663685318,10872957
+11660878175681148,10928070
+11660878687677278,10867975
+11660879199672972,10884320
+11660879711669070,10933586
+11660880223665192,10935007
+11660880735660780,10936059
+11660881247657163,10867411
+11660881759652821,10745065
+11660882271648818,10671494
+11660882783644878,10657380
+11660883295640555,10685825
+11660883807636723,10588857
+11660884319632452,10405656
+11660884831628814,10430671
+11660885343624465,10447793
+11660885855620425,10540210
+11660886367616728,10594398
+11660886879612435,10651155
+11660887391608077,10762975
+11660887903604338,10729130
+11660888415600153,10575400
+11660888927596379,10377831
+11660889439592191,10326756
+11660889951588222,10346938
+11660890463584313,10480952
+11660890975580014,10522952
+11660891487576134,10426739
+11660891999572106,10484613
+11660892511568078,10566004
+11660893023564081,10638096
+11660893535560114,10652883
+11660894047556044,10561370
+11660894559552278,10555917
+11660895071548210,10599575
+11660895583543850,10796217
+11660896095539713,10949469
+11660896607535612,10927686
+11660897119531479,10898856
+11660897631527665,10918350
+11660898143523321,10953174
+11660898655519228,10897004
+11660899167515628,10728631
+11660899679511228,10655568
+11660900191507963,10696343
+11660900703503132,10798647
+11660901215499099,11068156
+11660901727495095,11212363
+11660902239491266,11210196
+11660902751486898,11125406
+11660903263482786,11082807
+11660903775478964,10993738
+11660904287474752,10834126
+11660904799470571,10773213
+11660905311466784,10791772
+11660905823462739,10793434
+11660906335458724,10870960
+11660906847454702,11041244
+11660907359450700,11130236
+11660907871446579,11155541
+11660908383442617,11081596
+11660908895438741,11034257
+11660909407434544,11037158
+11660909919430496,11042059
+11660910431426584,11103345
+11660910943422441,11181058
+11660911455418574,11248534
+11660911967414485,11160189
+11660912479410319,11169355
+11660912991406276,11158211
+11660913503402264,11046040
+11660914015398146,11011928
+11660914527394516,11037234
+11660915039389905,11067307
+11660915551386126,11186643
+11660916063381778,11252513
+11660916575377993,11239078
+11660917087373243,11230747
+11660917599369906,11275468
+11660918111365787,11292002
+11660918623361771,11325165
+11660919135357801,11430196
+11660919647353512,11412764
+11660920159349643,11319483
+11660920671345693,11308260
+11660921183341554,11336227
+11660921695337353,11436312
+11660922207333300,11465338
+11660922719329731,11444062
+11660923231325499,11462254
+11660923743321463,11467345
+11660924255317449,11466491
+11660924767313611,11459279
+11660925279309390,11369667
+11660925791305254,11376572
+11660926303301366,11439654
+11660926815297188,11537671
+11660927327293012,11530051
+11660927839288870,11535795
+11660928351284699,11535054
+11660928863281247,11567511
+11660929375276818,11499320
+11660929887272616,11342756
+11660930399268791,11323472
+11660930911264728,11397680
+11660931423260774,11575856
+11660931935256751,11753431
+11660932447252918,11855214
+11660932959248711,11842888
+11660933471244798,11773811
+11660933983241063,11729124
+11660934495236856,11629998
+11660935007232583,11605319
+11660935519228377,11582997
+11660936031224703,11602664
+11660936543220774,11631750
+11660937055216333,11538760
+11660937567212317,11490150
+11660938079208270,11548724
+11660938591204107,11516088
+11660939103200256,11468168
+11660939615196384,11498759
+11660940127192429,11512181
+11660940639188342,11468916
+11660941151184409,11644785
+11660941663180296,11727763
+11660942175176248,11655897
+11660942687172320,11561208
+11660943199168195,11357441
+11660943711163663,11252878
+11660944223159721,11209716
+11660944735155627,11187800
+11660945247151663,11106626
+11660945759147663,11017085
+11660946271143725,11049687
+11660946783139710,11275240
+11660947295135873,11333669
+11660947807131597,11245676
+11660948319127518,11068003
+11660948831123543,10907124
+11660949343119453,10837147
+11660949855115275,10785257
+11660950367111328,10757465
+11660950879107550,10752652
+11660951391103387,10720884
+11660951903099178,10703238
+11660952415095206,10661728
+11660952927091110,10641504
+11660953439087321,10621507
+11660953951083547,10641121
+11660954463079341,10656382
+11660954975075102,10584653
+11660955487071090,10521402
+11660955999067054,10529936
+11660956511063067,10534880
+11660957023059172,10574857
+11660957535054956,10555214
+11660958047050967,10447158
+11660958559047052,10382602
+11660959071042823,10330494
+11660959583038777,10425819
+11660960095034543,10514015
+11660960607030848,10518431
+11660961119026824,10526021
+11660961631022565,10605871
+11660962143018512,10657283
+11660962655014540,10595099
+11660963167010487,10603065
+11660963679006411,10588960
+11660964191002171,10506300
+11660964702998336,10520408
+11660965214994282,10517344
+11660965726990309,10497794
+11660966238986248,10467252
+11660966750982293,10427382
+11660967262978305,10441565
+11660967774974433,10439308
+11660968286969740,10504079
+11660968798966060,10517653
+11660969310961820,10409101
+11660969822957858,10310899
+11660970334953718,10273552
+11660970846949599,10228897
+11660971358945205,10186189
+11660971870942249,10210721
+11660972382937941,10260287
+11660972894933963,10334306
+11660973406929596,10421597
+11660973918925879,10521774
+11660974430921303,10497198
+11660974942917691,10363125
+11660975454913676,10219804
+11660975966909343,10094743
+11660976478905610,10045376
+11660976990901245,9966356
+11660977502897255,9924616
+11660978014892878,9954808
+11660978526888549,9984834
+11660979038885084,10027399
+11660979550880674,9958268
+11660980062876941,10003306
+11660980574873026,10074196
+11660981086868987,10076831
+11660981598865193,10029351
+11660982110861066,9993392
+11660982622857026,10044193
+11660983134853321,10057493
+11660983646849052,9983106
+11660984158844876,9904565
+11660984670841493,9916605
+11660985182837186,9879420
+11660985694833208,9865286
+11660986206828890,9893028
+11660986718825007,9930057
+11660987230820737,9969640
+11660987742816743,10033244
+11660988254813027,10035491
+11660988766808567,10068406
+11660989278804689,10130456
+11660989790800689,10202063
+11660990302796433,10253606
+11660990814792343,10207632
+11660991326788582,10179161
+11660991838784556,10218624
+11660992350780213,10222238
+11660992862776518,10280786
+11660993374772362,10397062
+11660993886768342,10431424
+11660994398764391,10480405
+11660994910760523,10594221
+11660995422756291,10655294
+11660995934752403,10505005
+11660996446748403,10358904
+11660996958744087,10322670
+11660997470740142,10334840
+11660997982736181,10350416
+11660998494732014,10421276
+11660999006727882,10534999
+11660999518724408,10565940
+11661000030719637,10591622
+11661000542715520,10540735
+11661001054711468,10557745
+11661001566707509,10579784
+11661002078703259,10569640
+11661002590699743,10566114
+11661003102695835,10601751
+11661003614691719,10699311
+11661004126687782,10715669
+11661004638683638,10688282
+11661005150679260,10644959
+11661005662675639,10633290
+11661006174671727,10614578
+11661006686668292,10583516
+11661007198663914,10572749
+11661007710659506,10606219
+11661008222655377,10714043
+11661008734651190,10838776
+11661009246647121,10966217
+11661009758643405,11002617
+11661010270639184,11010673
+11661010782635011,10875447
+11661011294631219,10796767
+11661011806627247,10774368
+11661012318622941,10673599
+11661012830618842,10578206
+11661013342615212,10541517
+11661013854610786,10572613
+11661014366606832,10717533
+11661014878602957,10771903
+11661015390598789,10751221
+11661015902594676,10665894
+11661016414590623,10638816
+11661016926586375,10656305
+11661017438582835,10668485
+11661017950578453,10779525
+11661018462574608,10846235
+11661018974570271,11020724
+11661019486566118,11058615
+11661019998562690,11040855
+11661020510558257,11126747
+11661021022554443,11131936
+11661021534550203,11067192
+11661022046546017,10904420
+11661022558542051,10779823
+11661023070537651,10792596
+11661023582533645,10804878
+11661024094529726,10800796
+11661024606525668,10802241
+11661025118521629,10884750
+11661025630517498,10899607
+11661026142513451,10814628
+11661026654509547,10784379
+11661027166505606,10758476
+11661027678501396,10727107
+11661028190497343,10676878
+11661028702493106,10709354
+11661029214489202,10775248
+11661029726484857,10818212
+11661030238480993,10768200
+11661030750477241,10718380
+11661031262472649,10585930
+11661031774469204,10542273
+11661032286465067,10526263
+11661032798460984,10481268
+11661033310457018,10482692
+11661033822453094,10574801
+11661034334449051,10723152
+11661034846444910,10803399
+11661035358440815,10801125
+11661035870436631,10670582
+11661036382432657,10533171
+11661036894428784,10483996
+11661037406424182,10434605
+11661037918420405,10408055
+11661038430416258,10444209
+11661038942412010,10538370
+11661039454407869,10687323
+11661039966403799,10774636
+11661040478399933,10772603
+11661040990396423,10741336
+11661041502391990,10671822
+11661042014388019,10532073
+11661042526384085,10430560
+11661043038380200,10391396
+11661043550376399,10444364
+11661044062372344,10603204
+11661044574368247,10587061
+11661045086364277,10478481
+11661045598359840,10396920
+11661046110355738,10274850
+11661046622351764,10241770
+11661047134347623,10131220
+11661047646343291,10066866
+11661048158339224,10113092
+11661048670335725,10081819
+11661049182331534,10150049
+11661049694327310,10212746
+11661050206323259,10127451
+11661050718319372,9978791
+11661051230315650,9895573
+11661051742311573,9842537
+11661052254307817,9830178
+11661052766303351,9900384
+11661053278299501,9894134
+11661053790295122,9897112
+11661054302291485,9869127
+11661054814287379,9851396
+11661055326283365,9864354
+11661055838279050,9833298
+11661056350275250,9780729
+11661056862270776,9810269
+11661057374267482,9854458
+11661057886263120,9838991
+11661058398258983,9703304
+11661058910255258,9718111
+11661059422251146,9722598
+11661059934247082,9774474
+11661060446242935,9750483
+11661060958239068,9675945
+11661061470234847,9524809
+11661061982230896,9454305
+11661062494226567,9451419
+11661063006222516,9416810
+11661063518218628,9383970
+11661064030215004,9377499
+11661064542210493,9460170
+11661065054206711,9535952
+11661065566202858,9371379
+11661066078198984,9223433
+11661066590195616,9151898
+11661067102190971,9097425
+11661067614186746,9092861
+11661068126182746,9105046
+11661068638178805,9116827
+11661069150176112,9094838
+11661069662170692,9311309
+11661070174166497,9493717
+11661070686162584,9494130
+11661071198158428,9394028
+11661071710154098,9373504
+11661072222149954,9376096
+11661072734146103,9419314
+11661073246142208,9409690
+11661073758137977,9398695
+11661074270133907,9358734
+11661074782130110,9350724
+11661075294125867,9330276
+11661075806121913,9263399
+11661076318117956,9204343
+11661076830113947,9107104
+11661077342110106,9039123
+11661077854105897,9025682
+11661078366101730,9100069
+11661078878097714,9168797
+11661079390093811,9182208
+11661079902089678,9206490
+11661080414085622,9283443
+11661080926081342,9301186
+11661081438077578,9289056
+11661081950073455,9240710
+11661082462069350,9215046
+11661082974065661,9207723
+11661083486061247,9157505
+11661083998056925,9127188
+11661084510053033,9102856
+11661085022049277,9060048
+11661085534044860,9006570
+11661086046041613,8974077
+11661086558036919,8938750
+11661087070033084,8924269
+11661087582028809,8885452
+11661088094024816,8816729
+11661088606020671,8798595
+11661089118016630,8846031
+11661089630012598,8855129
+11661090142009061,8801905
+11661090654004977,8780111
+11661091166000311,8786932
+11661091677996907,8814436
+11661092189993174,8873363
+11661092701989521,8846610
+11661093213985266,8836000
+11661093725981175,8843886
+11661094237976682,8799681
+11661094749972740,8815863
+11661095261968921,8800317
+11661095773964749,8711643
+11661096285960212,8535509
+11661096797956702,8470986
+11661097309952533,8410235
+11661097821948532,8329674
+11661098333944409,8298402
+11661098845940082,8198412
+11661099357936282,8082027
+11661099869932068,7852804
+11661100381928142,7703157
+11661100893924059,7486560
+11661101405920133,7075925
+11661101917916191,6638260
+11661102429911987,6320656
+11661102941908408,6214785
+11661103453903394,5979413
+11661103965899499,5861074
+11661104477896018,5391752
+11661104989891734,5154426
+11661105501887851,4870907
+11661106013883639,4530376
+11661106525879710,4233003
+11661107037875644,4036921
+11661107549871648,3891367
+11661108061867709,3780940
+11661108573863413,3712526
+11661109085859534,3577307
+11661109597855605,3461942
+11661110109851218,3363721
+11661110621847118,3299146
+11661111133843238,3194851
+11661111645838978,3099204
+11661112157835035,3011139
+11661112669830769,2960075
+11661113181826939,2916028
+11661113693822805,2830673
+11661114205818717,2779013
+11661114717814742,2788002
+11661115229810669,2779161
+11661115741806874,2722945
+11661116253802624,2734665
+11661116765798318,2741502
+11661117277794118,2753081
+11661117789790480,2780809
+11661118301786397,2825647
+11661118813782890,2856010
+11661119325778108,2864996
+11661119837774327,2851210
+11661120349769926,2907981
+11661120861766329,3004389
+11661121373762117,3108491
+11661121885758125,3204378
+11661122397754475,3228134
+11661122909750145,3299311
+11661123421746218,3333985
+11661123933742132,3416039
+11661124445738182,3410032
+11661124957734045,3441897
+11661125469729797,3533782
+11661125981726133,3626088
+11661126493721608,3671626
+11661127005717735,3677413
+11661127517714031,3733541
+11661128029709775,3730989
+11661128541706131,3779481
+11661129053701574,3859106
+11661129565697488,3877310
+11661130077693333,3903091
+11661130589689421,3901629
+11661131101685245,3969971
+11661131613681333,3991815
+11661132125677403,3999264
+11661132637673396,3989616
+11661133149669264,3989321
+11661133661665369,3996183
+11661134173661285,4027513
+11661134685656804,3986869
+11661135197652997,3994088
+11661135709649022,3891823
+11661136221644778,3838484
+11661136733640203,3846587
+11661137245636803,3818876
+11661137757632870,3783287
+11661138269628919,3712158
+11661138781624347,3600383
+11661139293620519,3471401
+11661139805616420,3438204
+11661140317612580,3381331
+11661140829608341,3316193
+11661141341604404,3288671
+11661141853600591,3247247
+11661142365596221,3186290
+11661142877592496,3158898
+11661143389588347,3202013
+11661143901584342,3146384
+11661144413580345,3132745
+11661144925576402,3178266
+11661145437571858,3184951
+11661145949568416,3213849
+11661146461564309,3211722
+11661146973560300,3213632
+11661147485556094,3254280
+11661147997551979,3249396
+11661148509548019,3276358
+11661149021544100,3324045
+11661149533540058,3317202
+11661150045535846,3344683
+11661150557531816,3370228
+11661151069527835,3351752
+11661151581523728,3350799
+11661152093519720,3342375
+11661152605515707,3306482
+11661153117511680,3295274
+11661153629507593,3295272
+11661154141503386,3299295
+11661154653499416,3345240
+11661155165495298,3304525
+11661155677491191,3279471
+11661156189486981,3304432
+11661156701483089,3301477
+11661157213479274,3275330
+11661157725474772,3270883
+11661158237471036,3268520
+11661158749466993,3264054
+11661159261462639,3238620
+11661159773458758,3232896
+11661160285454562,3266302
+11661160797450722,3276328
+11661161309446508,3273525
+11661161821442564,3257591
+11661162333438521,3214852
+11661162845434577,3187845
+11661163357431045,3217218
+11661163869426355,3216448
+11661164381422485,3169431
+11661164893418341,3145953
+11661165405414308,3119018
+11661165917410382,3160000
+11661166429406133,3155037
+11661166941402300,3145116
+11661167453398049,3176971
+11661167965394160,3197671
+11661168477390254,3211261
+11661168989385865,3223817
+11661169501381758,3228292
+11661170013377944,3231002
+11661170525373544,3241073
+11661171037369690,3249807
+11661171549365725,3198450
+11661172061361619,3253071
+11661172573357606,3264295
+11661173085353360,3228528
+11661173597349445,3201566
+11661174109345477,3222369
+11661174621341392,3234903
+11661175133337400,3225115
+11661175645333504,3221014
+11661176157329064,3221868
+11661176669325115,3211748
+11661177181321148,3229049
+11661177693317166,3253466
+11661178205313308,3230302
+11661178717309888,3226262
+11661179229305089,3239770
+11661179741301486,3237200
+11661180253297153,3210954
+11661180765293124,3199717
+11661181277289171,3224608
+11661181789285134,3226858
+11661182301281023,3227553
+11661182813277235,3231696
+11661183325273609,3255184
+11661183837269091,3254628
+11661184349265014,3234555
+11661184861261215,3237118
+11661185373256972,3219785
+11661185885253077,3193845
+11661186397248941,3194638
+11661186909244910,3193472
+11661187421241082,3192118
+11661187933236950,3223727
+11661188445232862,3278228
+11661188957228858,3265446
+11661189469224793,3265584
+11661189981220918,3258625
+11661190493217308,3253828
+11661191005212501,3248062
+11661191517208603,3243016
+11661192029204604,3239867
+11661192541200787,3228741
+11661193053196451,3211557
+11661193565192330,3204867
+11661194077188178,3217328
+11661194589184480,3240016
+11661195101180238,3226860
+11661195613176356,3195710
+11661196125171984,3206887
+11661196637167889,3192189
+11661197149164212,3193147
+11661197661160461,3203362
+11661198173155985,3223499
+11661198685151826,3300444
+11661199197147690,3270446
+11661199709143751,3282978
+11661200221139828,3340430
+11661200733135924,3375357
+11661201245131678,3295978
+11661201757127705,3276673
+11661202269123883,3300009
+11661202781119616,3382884
+11661203293115983,3387785
+11661203805111436,3349813
+11661204317107623,3370665
+11661204829103610,3374228
+11661205341099963,3345525
+11661205853095049,3335280
+11661206365091296,3245952
+11661206877087116,3236972
+11661207389082946,3275642
+11661207901079226,3285134
+11661208413074970,3305468
+11661208925070852,3351496
+11661209437067115,3337885
+11661209949062957,3315548
+11661210461059031,3334597
+11661210973055023,3335992
+11661211485050923,3318877
+11661211997046962,3355162
+11661212509043000,3370313
+11661213021038956,3347110
+11661213533034823,3326365
+11661214045030725,3314926
+11661214557026626,3322711
+11661215069022605,3316373
+11661215581018655,3241978
+11661216093014490,3218207
+11661216605010733,3203871
+11661217117006619,3193658
+11661217629002305,3196289
+11661218140998298,3203383
+11661218652994515,3192323
+11661219164990260,3134166
+11661219676986353,3178449
+11661220188982074,3224995
+11661220700978319,3138663
+11661221212974714,3140035
+11661221724970087,3131282
+11661222236965889,3104182
+11661222748962112,3120035
+11661223260958087,3127965
+11661223772954159,3088662
+11661224284950042,3057382
+11661224796946087,3060768
+11661225308941752,3044145
+11661225820937690,3043777
+11661226332933786,3021697
+11661226844929547,2983759
+11661227356925450,3000810
+11661227868922141,2997402
+11661228380917478,2961584
+11661228892913442,2967236
+11661229404909453,2993726
+11661229916905762,2973992
+11661230428901433,3000152
+11661230940897123,2980477
+11661231452893068,2969696
+11661231964889318,2995324
+11661232476885315,2989853
+11661232988881804,3015955
+11661233500877592,2997459
+11661234012872889,2992415
+11661234524869016,3049243
+11661235036865569,3059728
+11661235548861464,3029241
+11661236060857617,3041289
+11661236572853565,3112554
+11661237084849124,3143404
+11661237596845339,3097080
+11661238108841978,3097248
+11661238620837104,3101514
+11661239132832814,3075499
+11661239644828913,3110802
+11661240156825000,3166200
+11661240668821098,3139577
+11661241180817091,3088345
+11661241692812961,3078256
+11661242204809085,3094410
+11661242716804997,3114278
+11661243228800788,3116902
+11661243740796804,3121444
+11661244252792723,3143113
+11661244764788766,3163152
+11661245276784559,3176896
+11661245788780680,3194131
+11661246300776646,3174260
+11661246812772623,3159098
+11661247324768347,3162594
+11661247836764231,3170014
+11661248348760620,3212971
+11661248860756436,3249654
+11661249372752300,3214173
+11661249884747810,3186285
+11661250396744412,3206292
+11661250908740280,3230811
+11661251420735964,3231137
+11661251932731911,3218752
+11661252444728288,3186752
+11661252956724003,3183704
+11661253468720192,3218652
+11661253980715698,3207728
+11661254492711939,3185422
+11661255004708621,3203992
+11661255516703629,3201186
+11661256028699935,3184613
+11661256540695758,3217647
+11661257052691844,3240022
+11661257564687805,3198907
+11661258076683591,3157553
+11661258588679604,3133192
+11661259100675689,3161752
+11661259612671417,3188625
+11661260124667615,3153191
+11661260636663446,3191311
+11661261148659222,3214085
+11661261660655288,3215393
+11661262172651402,3214436
+11661262684647154,3176033
+11661263196643127,3131258
+11661263708639234,3128500
+11661264220635118,3179723
+11661264732630987,3206628
+11661265244627015,3217667
+11661265756623200,3233440
+11661266268619209,3224473
+11661266780615159,3200020
+11661267292611186,3225256
+11661267804606921,3276232
+11661268316603044,3305854
+11661268828599145,3309280
+11661269340594975,3287570
+11661269852591050,3288215
+11661270364586891,3315727
+11661270876582654,3292558
+11661271388578741,3329286
+11661271900575296,3345832
+11661272412571082,3301912
+11661272924567122,3274385
+11661273436562952,3298681
+11661273948558535,3370656
+11661274460554481,3405141
+11661274972550771,3379799
+11661275484546611,3358662
+11661275996542658,3349226
+11661276508538604,3337679
+11661277020534378,3361448
+11661277532530506,3440287
+11661278044526237,3427186
+11661278556522208,3311505
+11661279068518676,3323653
+11661279580514060,3363724
+11661280092510312,3290882
+11661280604506033,3303750
+11661281116501836,3286886
+11661281628497984,3285510
+11661282140493732,3324849
+11661282652490027,3333622
+11661283164485721,3431691
+11661283676482075,3391791
+11661284188477566,3354745
+11661284700473846,3284652
+11661285212470175,3302312
+11661285724465830,3344262
+11661286236461631,3269079
+11661286748457539,3272527
+11661287260453504,3298210
+11661287772449305,3390595
+11661288284445408,3441438
+11661288796441731,3429182
+11661289308437453,3456864
+11661289820433528,3501767
+11661290332429611,3471853
+11661290844425217,3421957
+11661291356421576,3430767
+11661291868417497,3490236
+11661292380413278,3471047
+11661292892409407,3482352
+11661293404405246,3506719
+11661293916401093,3541505
+11661294428397555,3550096
+11661294940393495,3557848
+11661295452389155,3552898
+11661295964385229,3553606
+11661296476380948,3543489
+11661296988377036,3573784
+11661297500373197,3641021
+11661298012369082,3643159
+11661298524365005,3643829
+11661299036361089,3661833
+11661299548357095,3634939
+11661300060352874,3561402
+11661300572348995,3524199
+11661301084344751,3564190
+11661301596340974,3576605
+11661302108336700,3574973
+11661302620332729,3594614
+11661303132328764,3595209
+11661303644324870,3594131
+11661304156320721,3592281
+11661304668316692,3583627
+11661305180312652,3541240
+11661305692308561,3532515
+11661306204304507,3546070
+11661306716300429,3603205
+11661307228296289,3569085
+11661307740292378,3520728
+11661308252288423,3487026
+11661308764284161,3482299
+11661309276280167,3532107
+11661309788276187,3579852
+11661310300272184,3584654
+11661310812268274,3532329
+11661311324264237,3511592
+11661311836259966,3504659
+11661312348255993,3479961
+11661312860252083,3447701
+11661313372248091,3499847
+11661313884243800,3523868
+11661314396240203,3533942
+11661314908235847,3485613
+11661315420232090,3466049
+11661315932227695,3465729
+11661316444223793,3464168
+11661316956219729,3434879
+11661317468215858,3391019
+11661317980211926,3402278
+11661318492207808,3411408
+11661319004203767,3333149
+11661319516199507,3294562
+11661320028195422,3324808
+11661320540191579,3317063
+11661321052187083,3277319
+11661321564183923,3283823
+11661322076179256,3327086
+11661322588175670,3344452
+11661323100170876,3394565
+11661323612166919,3377796
+11661324124163379,3330812
+11661324636158902,3310006
+11661325148154928,3271508
+11661325660151039,3267327
+11661326172146809,3262406
+11661326684142842,3260255
+11661327196138630,3239044
+11661327708134821,3203045
+11661328220130850,3159353
+11661328732126627,3149679
+11661329244122733,3170678
+11661329756118743,3136056
+11661330268114674,3147519
+11661330780110590,3150883
+11661331292106396,3096098
+11661331804102469,3055818
+11661332316098385,3024945
+11661332828094566,3047747
+11661333340090506,3027414
+11661333852086487,3011771
+11661334364082215,3106124
+11661334876078142,3048888
+11661335388074161,3051363
+11661335900070098,3075882
+11661336412066220,3048537
+11661336924062031,3022205
+11661337436058387,2969735
+11661337948054084,2907454
+11661338460050047,2950430
+11661338972046084,2997013
+11661339484042487,2974989
+11661339996037815,2916395
+11661340508033700,2918569
+11661341020029854,2900081
+11661341532025814,2854673
+11661342044021848,2894885
+11661342556017634,2982981
+11661343068013427,2956175
+11661343580009346,2921216
+11661344092005768,2896874
+11661344604001346,2880120
+11661345115997446,2891589
+11661345627993306,2897630
+11661346139989258,2863524
+11661346651985434,2832097
+11661347163981345,2838214
+11661347675977147,2856390
+11661348187973037,2841175
+11661348699968995,2842779
+11661349211965012,2875488
+11661349723961090,2866764
+11661350235957213,2869190
+11661350747952917,2907756
+11661351259949102,2921650
+11661351771944954,2922609
+11661352283940731,2921891
+11661352795936790,2947934
+11661353307932689,2952648
+11661353819928615,2932617
+11661354331924982,2948637
+11661354843920593,2924733
+11661355355916898,2958063
+11661355867912414,2997902
+11661356379908757,2999895
+11661356891904509,2997055
+11661357403900440,3000990
+11661357915896247,3024387
+11661358427892295,3013470
+11661358939888719,3027644
+11661359451884404,3027212
+11661359963880417,3034914
+11661360475876298,3163048
+11661360987872162,3188904
+11661361499868294,3113926
+11661362011864202,3057227
+11661362523859906,3063803
+11661363035856132,3108974
+11661363547851829,3100922
+11661364059847759,3074001
+11661364571843772,3076428
+11661365083839806,3071077
+11661365595835708,3155199
+11661366107831609,3291399
+11661366619827588,3254381
+11661367131823570,3191168
+11661367643819624,3190375
+11661368155815618,3135955
+11661368667811450,3134308
+11661369179807295,3172662
+11661369691803413,3133122
+11661370203799331,3141964
+11661370715795261,3106196
+11661371227791159,3075539
+11661371739787158,3113225
+11661372251782960,3093390
+11661372763779206,3085913
+11661373275774867,3101973
+11661373787770871,3102606
+11661374299767021,3034670
+11661374811762998,3033941
+11661375323758939,3080765
+11661375835754947,3079993
+11661376347750692,3079626
+11661376859746885,3133145
+11661377371742630,3145695
+11661377883738617,3129068
+11661378395734687,3124576
+11661378907730631,3086769
+11661379419726720,3101757
+11661379931722560,3148136
+11661380443718792,3162765
+11661380955714591,3136012
+11661381467710594,3103122
+11661381979706304,3120605
+11661382491702370,3094358
+11661383003698427,3089003
+11661383515694603,3093014
+11661384027690264,3115726
+11661384539686063,3134568
+11661385051682294,3116640
+11661385563678326,3108806
+11661386075674013,3104995
+11661386587670155,3092303
+11661387099666389,3091592
+11661387611661873,3169983
+11661388123657875,3195203
+11661388635653985,3191406
+11661389147649945,3180120
+11661389659645867,3165569
+11661390171642250,3153419
+11661390683637781,3150755
+11661391195633600,3220008
+11661391707629692,3208449
+11661392219625709,3190954
+11661392731621552,3216241
+11661393243617352,3213032
+11661393755613315,3128189
+11661394267609324,3121657
+11661394779605306,3115445
+11661395291601447,3121486
+11661395803597453,3119979
+11661396315593131,3118171
+11661396827589095,3168068
+11661397339584888,3158067
+11661397851581063,3124627
+11661398363576881,3137085
+11661398875573037,3178411
+11661399387569116,3237143
+11661399899565203,3172285
+11661400411560994,3055799
+11661400923557141,3055224
+11661401435552449,3087798
+11661401947548833,3061991
+11661402459544676,2961966
+11661402971540902,2955961
+11661403483536561,2946116
+11661403995532537,2931944
+11661404507528656,2988752
+11661405019524703,2990723
+11661405531520631,2996112
+11661406043516188,3046636
+11661406555512004,3058791
+11661407067508275,3038453
+11661407579504318,3021359
+11661408091500075,3051215
+11661408603495876,3078138
+11661409115491896,3068094
+11661409627488070,3066979
+11661410139483767,3114711
+11661410651479964,3247654
+11661411163475849,3266615
+11661411675471632,3272766
+11661412187467774,3261679
+11661412699463772,3215058
+11661413211459664,3210418
+11661413723455634,3200615
+11661414235451701,3238556
+11661414747447697,3269042
+11661415259443633,3213443
+11661415771439234,3217325
+11661416283435575,3267994
+11661416795431709,3260636
+11661417307427454,3273312
+11661417819423169,3327267
+11661418331419234,3297063
+11661418843415225,3322000
+11661419355411120,3356338
+11661419867407054,3268329
+11661420379403027,3242323
+11661420891398778,3236827
+11661421403394873,3193757
+11661421915391784,3183897
+11661422427386739,3164128
+11661422939382634,3182109
+11661423451378431,3198437
+11661423963375047,3203239
+11661424475370764,3212594
+11661424987367086,3169557
+11661425499362583,3125366
+11661426011357983,3138687
+11661426523355518,3129311
+11661427035351963,3108252
+11661427547346317,3129775
+11661428059342649,3253279
+11661428571338169,3242163
+11661429083334747,3235282
+11661429595329719,3157465
+11661430107326435,3123351
+11661430619322572,3136034
+11661431131318469,3113333
+11661431643314200,3066208
+11661432155310360,3081033
+11661432667306082,3065834
+11661433179301780,3043700
+11661433691298256,3039933
+11661434203293949,3008990
+11661434715290027,2926653
+11661435227285746,2911707
+11661435739281861,2913722
+11661436251277805,2913905
+11661436763273800,2914407
+11661437275269764,2902008
+11661437787265821,2914342
+11661438299261679,2968655
+11661438811257659,2998471
+11661439323253598,2988890
+11661439835249386,2967635
+11661440347245487,2980341
+11661440859241645,2974778
+11661441371237361,2982822
+11661441883233723,2995748
+11661442395229389,3007447
+11661442907225503,3002477
+11661443419221466,2984598
+11661443931217406,2971490
+11661444443213490,2924234
+11661444955209528,2912575
+11661445467205480,3041152
+11661445979201643,3063107
+11661446491197002,3092617
+11661447003193175,3071250
+11661447515189930,3061075
+11661448027185738,3071938
+11661448539181191,3047689
+11661449051177203,3074988
+11661449563173030,3039595
+11661450075169113,3050117
+11661450587165131,3018395
+11661451099161086,3031094
+11661451611156904,3075307
+11661452123152950,3080964
+11661452635148903,3099187
+11661453147145026,3136642
+11661453659140879,3174886
+11661454171136800,3206520
+11661454683132762,3188309
+11661455195128860,3153909
+11661455707124898,3136726
+11661456219120731,3141967
+11661456731116618,3183441
+11661457243112704,3204220
+11661457755108680,3195049
+11661458267104431,3175147
+11661458779100675,3218170
+11661459291096522,3263036
+11661459803092464,3244318
+11661460315088335,3246668
+11661460827084200,3249563
+11661461339080438,3235299
+11661461851076213,3201978
+11661462363072257,3184186
+11661462875068247,3207806
+11661463387064191,3207532
+11661463899060218,3163219
+11661464411056264,3167856
+11661464923051864,3184859
+11661465435047966,3158884
+11661465947044026,3156929
+11661466459040142,3157701
+11661466971035871,3132818
+11661467483031728,3122641
+11661467995027929,3142169
+11661468507024104,3120968
+11661469019020049,3130449
+11661469531015602,3128878
+11661470043011683,3108128
+11661470555007658,3087938
+11661471067003865,3098305
+11661471578999679,3086116
+11661472090995574,3089550
+11661472602991600,3099818
+11661473114987432,3100697
+11661473626983405,3125781
+11661474138979597,3082617
+11661474650975281,3044249
+11661475162971171,3066158
+11661475674967246,3102622
+11661476186963088,3065836
+11661476698959027,3062030
+11661477210955015,3099629
+11661477722950977,3094335
+11661478234946890,3048985
+11661478746943059,3016563
+11661479258938797,3006341
+11661479770934870,2996376
+11661480282930774,3046431
+11661480794927125,3065552
+11661481306922864,3031029
+11661481818919043,3040956
+11661482330914734,3037330
+11661482842910992,3064187
... 5550073 lines suppressed ...