Re: [PR] [docker] [regression] update routine load p0 cases [doris]

2023-12-13 Thread via GitHub


XuJianxu commented on PR #28292:
URL: https://github.com/apache/doris/pull/28292#issuecomment-1853431012

   run p0


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](user) Avoid throw unknown UserProperty after FE rollback version [doris]

2023-12-13 Thread via GitHub


xinyiZzz merged PR #28325:
URL: https://github.com/apache/doris/pull/28325


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



(doris) branch master updated: [fix](user) Avoid throw unknown UserProperty after FE rollback version (#28325)

2023-12-13 Thread zouxinyi
This is an automated email from the ASF dual-hosted git repository.

zouxinyi pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/doris.git


The following commit(s) were added to refs/heads/master by this push:
 new 2005fee4303 [fix](user) Avoid throw unknown UserProperty after FE 
rollback version (#28325)
2005fee4303 is described below

commit 2005fee4303246b00f48e12969a83dc98fcd4b06
Author: Xinyi Zou 
AuthorDate: Wed Dec 13 16:00:04 2023 +0800

[fix](user) Avoid throw unknown UserProperty after FE rollback version 
(#28325)

After using SET PROPERTY to modify the user property, if FE rolls back to a 
version without this property, `Unknown user property` error will be reported 
when replay EditLog, just ignore it.
---
 .../java/org/apache/doris/mysql/privilege/Auth.java  |  2 +-
 .../apache/doris/mysql/privilege/UserProperty.java   | 20 +++-
 .../doris/mysql/privilege/UserPropertyMgr.java   |  5 +++--
 3 files changed, 23 insertions(+), 4 deletions(-)

diff --git 
a/fe/fe-core/src/main/java/org/apache/doris/mysql/privilege/Auth.java 
b/fe/fe-core/src/main/java/org/apache/doris/mysql/privilege/Auth.java
index 4a5400629ed..b503a5e69e0 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/mysql/privilege/Auth.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/mysql/privilege/Auth.java
@@ -954,7 +954,7 @@ public class Auth implements Writable {
 throws UserException {
 writeLock();
 try {
-propertyMgr.updateUserProperty(user, properties);
+propertyMgr.updateUserProperty(user, properties, isReplay);
 if (!isReplay) {
 UserPropertyInfo propertyInfo = new UserPropertyInfo(user, 
properties);
 
Env.getCurrentEnv().getEditLog().logUpdateUserProperty(propertyInfo);
diff --git 
a/fe/fe-core/src/main/java/org/apache/doris/mysql/privilege/UserProperty.java 
b/fe/fe-core/src/main/java/org/apache/doris/mysql/privilege/UserProperty.java
index 021bdeb3263..2ee8bc1e82c 100644
--- 
a/fe/fe-core/src/main/java/org/apache/doris/mysql/privilege/UserProperty.java
+++ 
b/fe/fe-core/src/main/java/org/apache/doris/mysql/privilege/UserProperty.java
@@ -37,6 +37,8 @@ import com.google.common.collect.Lists;
 import com.google.common.collect.Maps;
 import com.google.common.collect.Sets;
 import org.apache.commons.lang3.StringUtils;
+import org.apache.logging.log4j.LogManager;
+import org.apache.logging.log4j.Logger;
 
 import java.io.DataInput;
 import java.io.DataOutput;
@@ -51,8 +53,13 @@ import java.util.regex.Pattern;
 /*
  * UserProperty contains properties set for a user
  * This user is just qualified by cluster name, not host which it connected 
from.
+ *
+ * If UserProperty and SessionVeriable have the same name, UserProperty has a 
higher priority than SessionVeriable.
+ * This usually means that the cluster administrator force user restrictions.
+ * Users cannot modify these SessionVeriables with the same name.
  */
 public class UserProperty implements Writable {
+private static final Logger LOG = LogManager.getLogger(UserProperty.class);
 // advanced properties
 private static final String PROP_MAX_USER_CONNECTIONS = 
"max_user_connections";
 private static final String PROP_MAX_QUERY_INSTANCES = 
"max_query_instances";
@@ -173,6 +180,10 @@ public class UserProperty implements Writable {
 }
 
 public void update(List> properties) throws 
UserException {
+update(properties, false);
+}
+
+public void update(List> properties, boolean 
isReplay) throws UserException {
 // copy
 long newMaxConn = this.commonProperties.getMaxConn();
 long newMaxQueryInstances = 
this.commonProperties.getMaxQueryInstances();
@@ -312,7 +323,14 @@ public class UserProperty implements Writable {
 }
 workloadGroup = value;
 } else {
-throw new DdlException("Unknown user property(" + key + ")");
+if (isReplay) {
+// After using SET PROPERTY to modify the user property, 
if FE rolls back to a version without
+// this property, `Unknown user property` error will be 
reported when replay EditLog,
+// just ignore it.
+LOG.warn("Unknown user property(" + key + "), maybe FE 
rolled back version, Ignore it");
+} else {
+throw new DdlException("Unknown user property(" + key + 
")");
+}
 }
 }
 
diff --git 
a/fe/fe-core/src/main/java/org/apache/doris/mysql/privilege/UserPropertyMgr.java
 
b/fe/fe-core/src/main/java/org/apache/doris/mysql/privilege/UserPropertyMgr.java
index 46f900f655a..d4d34af2538 100644
--- 
a/fe/fe-core/src/main/java/org/apache/doris/mysql/privilege/UserPropertyMgr.java
+++ 
b/fe/fe-core/src/main/java/org/apache/doris/mysql/privilege/UserPropertyMgr.java
@@ -73,13 +73,14 @@ public class Us

Error while running github feature from .asf.yaml in doris!

2023-12-13 Thread Apache Infrastructure


An error occurred while running github feature in .asf.yaml!:
You can only have a maximum of 10 external triage collaborators, please contact 
vp-in...@apache.org to request an exception.


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] investigate 2.0 ckb [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28334:
URL: https://github.com/apache/doris/pull/28334#issuecomment-1853431556

   (From new machine)TeamCity pipeline, clickbench performance test result:
the sum of best hot time: 49.92 seconds
stream load tsv:  571 seconds loaded 74807831229 Bytes, about 124 
MB/s
stream load json: 19 seconds loaded 2358488459 Bytes, about 118 MB/s
stream load orc:  66 seconds loaded 1101869774 Bytes, about 15 MB/s
stream load parquet:  32 seconds loaded 861443392 Bytes, about 25 
MB/s
insert into select:  30.3 seconds inserted 1000 Rows, about 
330K ops/s
storage size: 17162684428 Bytes


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix] Fix map type mapping to doris type error [doris-flink-connector]

2023-12-13 Thread via GitHub


vinlee19 commented on code in PR #267:
URL: 
https://github.com/apache/doris-flink-connector/pull/267#discussion_r1424979092


##
flink-doris-connector/src/main/java/org/apache/doris/flink/deserialization/converter/DorisRowConverter.java:
##
@@ -357,17 +357,22 @@ private static Object convertMapData(MapData map, 
LogicalType type) {
 if (map instanceof BinaryMapData) {
 BinaryMapData bMap = (BinaryMapData)map;
 LogicalType valueType = ((MapType)type).getValueType();
+LogicalType keyType = ((MapType) type).getKeyType();
 Map javaMap = bMap.toJavaMap(((MapType) type).getKeyType(), 
valueType);
 for (Map.Entry entry : javaMap.entrySet()) {
 String key = entry.getKey().toString();
 if (LogicalTypeRoot.MAP.equals(valueType.getTypeRoot())) {
 result.put(key, convertMapData((MapData)entry.getValue(), 
valueType));
 }else if 
(LogicalTypeRoot.DATE.equals(valueType.getTypeRoot())) {
-result.put(key, 
Date.valueOf(LocalDate.ofEpochDay((Integer)entry.getValue())).toString());
+if (LogicalTypeRoot.DATE.equals(keyType.getTypeRoot())){
+
result.put(Date.valueOf(LocalDate.ofEpochDay((Integer)entry.getKey())).toString(),
 Date.valueOf(LocalDate.ofEpochDay((Integer)entry.getValue())).toString());
+}else {
+result.put(key, 
Date.valueOf(LocalDate.ofEpochDay((Integer)entry.getValue())).toString());
+}
 }else if 
(LogicalTypeRoot.ARRAY.equals(valueType.getTypeRoot())) {
 result.put(key, 
convertArrayData((ArrayData)entry.getValue(), valueType));
 }else if(entry.getValue() instanceof TimestampData){
-result.put(key, 
((TimestampData)entry.getValue()).toTimestamp().toString());
+result.put(key, 
((TimestampData)entry.getValue()).toString());
 }else{
 result.put(key, entry.getValue().toString());
 }

Review Comment:
   Yeah, i will do it.



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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [enhancement](stats) audit for stats collection [doris]

2023-12-13 Thread via GitHub


zhiqiang- commented on code in PR #24074:
URL: https://github.com/apache/doris/pull/24074#discussion_r1424980768


##
fe/fe-core/src/main/java/org/apache/doris/qe/AuditLogHelper.java:
##
@@ -0,0 +1,120 @@
+// 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.doris.qe;
+
+import org.apache.doris.analysis.InsertStmt;
+import org.apache.doris.analysis.Queriable;
+import org.apache.doris.analysis.StatementBase;
+import org.apache.doris.catalog.Env;
+import org.apache.doris.cluster.ClusterNamespace;
+import org.apache.doris.common.Config;
+import org.apache.doris.common.util.DebugUtil;
+import org.apache.doris.metric.MetricRepo;
+import org.apache.doris.plugin.AuditEvent.EventType;
+import org.apache.doris.qe.QueryState.MysqlStateType;
+import org.apache.doris.service.FrontendOptions;
+
+import io.opentelemetry.api.trace.Span;
+import io.opentelemetry.api.trace.SpanContext;
+import io.opentelemetry.context.Context;
+import org.apache.commons.codec.digest.DigestUtils;
+
+public class AuditLogHelper {
+
+public static void logAuditLog(ConnectContext ctx, String origStmt, 
StatementBase parsedStmt,
+org.apache.doris.proto.Data.PQueryStatistics statistics, boolean 
printFuzzyVariables) {
+origStmt = origStmt.replace("\n", " ");
+// slow query
+long endTime = System.currentTimeMillis();
+long elapseMs = endTime - ctx.getStartTime();
+SpanContext spanContext = 
Span.fromContext(Context.current()).getSpanContext();
+
+ctx.getAuditEventBuilder().setEventType(EventType.AFTER_QUERY)
+.setDb(ClusterNamespace.getNameFromFullName(ctx.getDatabase()))
+.setState(ctx.getState().toString())
+.setErrorCode(ctx.getState().getErrorCode() == null ? 0 : 
ctx.getState().getErrorCode().getCode())
+.setErrorMessage((ctx.getState().getErrorMessage() == null ? 
"" :
+ctx.getState().getErrorMessage().replace("\n", " 
").replace("\t", " ")))
+.setQueryTime(elapseMs)
+.setScanBytes(statistics == null ? 0 : 
statistics.getScanBytes())
+.setScanRows(statistics == null ? 0 : statistics.getScanRows())
+.setCpuTimeMs(statistics == null ? 0 : statistics.getCpuMs())
+.setPeakMemoryBytes(statistics == null ? 0 : 
statistics.getMaxPeakMemoryBytes())
+.setReturnRows(ctx.getReturnRows())
+.setStmtId(ctx.getStmtId())
+.setQueryId(ctx.queryId() == null ? "NaN" : 
DebugUtil.printId(ctx.queryId()))
+.setTraceId(spanContext.isValid() ? spanContext.getTraceId() : 
"")
+.setWorkloadGroup(ctx.getWorkloadGroupName())
+.setFuzzyVariables(!printFuzzyVariables ? "" : 
ctx.getSessionVariable().printFuzzyVariables());
+
+if (ctx.getState().isQuery()) {
+MetricRepo.COUNTER_QUERY_ALL.increase(1L);
+
MetricRepo.USER_COUNTER_QUERY_ALL.getOrAdd(ctx.getQualifiedUser()).increase(1L);
+if (ctx.getState().getStateType() == MysqlStateType.ERR
+&& ctx.getState().getErrType() != 
QueryState.ErrType.ANALYSIS_ERR) {
+// err query
+MetricRepo.COUNTER_QUERY_ERR.increase(1L);
+
MetricRepo.USER_COUNTER_QUERY_ERR.getOrAdd(ctx.getQualifiedUser()).increase(1L);
+} else if (ctx.getState().getStateType() == MysqlStateType.OK
+|| ctx.getState().getStateType() == MysqlStateType.EOF) {
+// ok query
+MetricRepo.HISTO_QUERY_LATENCY.update(elapseMs);
+
MetricRepo.USER_HISTO_QUERY_LATENCY.getOrAdd(ctx.getQualifiedUser()).update(elapseMs);
+
+if (elapseMs > Config.qe_slow_log_ms) {

Review Comment:
   Why just record sqlDigest of Slowquery?



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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-

Re: [PR] [docker] [regression] update routine load p0 cases [doris]

2023-12-13 Thread via GitHub


XuJianxu commented on PR #28292:
URL: https://github.com/apache/doris/pull/28292#issuecomment-1853437132

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



[PR] [Bug](fix) fix close order maybe cause use after free [doris]

2023-12-13 Thread via GitHub


HappenLee opened a new pull request, #28339:
URL: https://github.com/apache/doris/pull/28339

   ## Proposed changes
   
   Issue Number: close #xxx
   
   
   
   ## Further comments
   
   If this is a relatively large or complex change, kick off the discussion at 
[d...@doris.apache.org](mailto:d...@doris.apache.org) by explaining why you 
chose the solution you did and what alternatives you considered, etc...
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [feature](merge-on-write) enable merge-on-write by default again [doris]

2023-12-13 Thread via GitHub


bobhan1 commented on PR #28105:
URL: https://github.com/apache/doris/pull/28105#issuecomment-1853440570

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [opt](regression test) use select count from tablet api [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28327:
URL: https://github.com/apache/doris/pull/28327#issuecomment-1853440436

   PR approved by anyone and no changes requested.


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] test [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28249:
URL: https://github.com/apache/doris/pull/28249#issuecomment-1853441325

   (From new machine)TeamCity pipeline, clickbench performance test result:
the sum of best hot time: 44.85 seconds
stream load tsv:  577 seconds loaded 74807831229 Bytes, about 123 
MB/s
stream load json: 19 seconds loaded 2358488459 Bytes, about 118 MB/s
stream load orc:  66 seconds loaded 1101869774 Bytes, about 15 MB/s
stream load parquet:  31 seconds loaded 861443392 Bytes, about 26 
MB/s
insert into select:  28.8 seconds inserted 1000 Rows, about 
347K ops/s
storage size: 17222896952 Bytes


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [opt](regression test) use select count from tablet api [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28327:
URL: https://github.com/apache/doris/pull/28327#issuecomment-1853445919

   PR approved by at least one committer and no changes requested.


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



(doris) branch master updated: [opt](regression test) use select count from tablet api (#28327)

2023-12-13 Thread jianliangqi
This is an automated email from the ASF dual-hosted git repository.

jianliangqi pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/doris.git


The following commit(s) were added to refs/heads/master by this push:
 new 3e08bec27f3 [opt](regression test) use select count from tablet api 
(#28327)
3e08bec27f3 is described below

commit 3e08bec27f304cd618f1917260b3140d2f478638
Author: qiye 
AuthorDate: Wed Dec 13 16:12:56 2023 +0800

[opt](regression test) use select count from tablet api (#28327)
---
 .../stream_load/test_load_to_single_tablet.groovy  | 205 +++--
 1 file changed, 65 insertions(+), 140 deletions(-)

diff --git 
a/regression-test/suites/load_p0/stream_load/test_load_to_single_tablet.groovy 
b/regression-test/suites/load_p0/stream_load/test_load_to_single_tablet.groovy
index 867601f5dc1..c35500267b9 100644
--- 
a/regression-test/suites/load_p0/stream_load/test_load_to_single_tablet.groovy
+++ 
b/regression-test/suites/load_p0/stream_load/test_load_to_single_tablet.groovy
@@ -17,17 +17,6 @@
 
 import groovy.json.JsonSlurper
 
-/**
- *   @Params url is "/xxx"
- *   @Return response body
- */
-def http_get(url) {
-def conn = new URL(url).openConnection()
-conn.setRequestMethod("GET")
-//token for root
-return conn.getInputStream().getText()
-}
-
 suite("test_load_to_single_tablet", "p0") {
 sql "show tables"
 
@@ -67,23 +56,16 @@ suite("test_load_to_single_tablet", "p0") {
 def totalCount = sql "select count() from ${tableName}"
 assertEquals(10, totalCount[0][0])
 def res = sql "show tablets from ${tableName}"
-def tabletMetaUrl1 = res[0][17]
-def tabletMetaUrl2 = res[1][17]
-def tabletMetaUrl3 = res[2][17]
-def tabletMetaRes1 = http_get(tabletMetaUrl1)
-def tabletMetaRes2 = http_get(tabletMetaUrl2)
-def tabletMetaRes3 = http_get(tabletMetaUrl3)
-
-def obj1 = new JsonSlurper().parseText(tabletMetaRes1)
-def obj2 = new JsonSlurper().parseText(tabletMetaRes2)
-def obj3 = new JsonSlurper().parseText(tabletMetaRes3)
-def rowCount1 = obj1.rs_metas[0].num_rows + obj1.rs_metas[1].num_rows
-def rowCount2 = obj2.rs_metas[0].num_rows + obj2.rs_metas[1].num_rows
-def rowCount3 = obj3.rs_metas[0].num_rows + obj3.rs_metas[1].num_rows
-
-assertEquals(10, rowCount1)
-assertEquals(0, rowCount2)
-assertEquals(0, rowCount3)
+def tablet1 = res[0][0]
+def tablet2 = res[1][0]
+def tablet3 = res[2][0]
+def rowCount1 = sql "select count() from ${tableName} tablet(${tablet1})"
+def rowCount2 = sql "select count() from ${tableName} tablet(${tablet2})"
+def rowCount3 = sql "select count() from ${tableName} tablet(${tablet3})"
+
+assertEquals(10, rowCount1[0][0])
+assertEquals(0, rowCount2[0][0])
+assertEquals(0, rowCount3[0][0])
 
 
 // load second time
@@ -99,21 +81,13 @@ suite("test_load_to_single_tablet", "p0") {
 }
 sql "sync"
 totalCount = sql "select count() from ${tableName}"
+rowCount1 = sql "select count() from ${tableName} tablet(${tablet1})"
+rowCount2 = sql "select count() from ${tableName} tablet(${tablet2})"
+rowCount3 = sql "select count() from ${tableName} tablet(${tablet3})"
 assertEquals(20, totalCount[0][0])
-tabletMetaRes1 = http_get(tabletMetaUrl1)
-tabletMetaRes2 = http_get(tabletMetaUrl2)
-tabletMetaRes3 = http_get(tabletMetaUrl3)
-
-obj1 = new JsonSlurper().parseText(tabletMetaRes1)
-obj2 = new JsonSlurper().parseText(tabletMetaRes2)
-obj3 = new JsonSlurper().parseText(tabletMetaRes3)
-
-rowCount1 = obj1.rs_metas[0].num_rows + obj1.rs_metas[1].num_rows + 
obj1.rs_metas[2].num_rows
-rowCount2 = obj2.rs_metas[0].num_rows + obj2.rs_metas[1].num_rows + 
obj2.rs_metas[2].num_rows
-rowCount3 = obj3.rs_metas[0].num_rows + obj3.rs_metas[1].num_rows + 
obj3.rs_metas[2].num_rows
-assertEquals(10, rowCount1)
-assertEquals(10, rowCount2)
-assertEquals(0, rowCount3)
+assertEquals(10, rowCount1[0][0])
+assertEquals(10, rowCount2[0][0])
+assertEquals(0, rowCount3[0][0])
 
 // load third time
 streamLoad {
@@ -128,21 +102,13 @@ suite("test_load_to_single_tablet", "p0") {
 }
 sql "sync"
 totalCount = sql "select count() from ${tableName}"
+rowCount1 = sql "select count() from ${tableName} tablet(${tablet1})"
+rowCount2 = sql "select count() from ${tableName} tablet(${tablet2})"
+rowCount3 = sql "select count() from ${tableName} tablet(${tablet3})"
 assertEquals(30, totalCount[0][0])
-tabletMetaRes1 = http_get(tabletMetaUrl1)
-tabletMetaRes2 = http_get(tabletMetaUrl2)
-tabletMetaRes3 = http_get(tabletMetaUrl3)
-
-obj1 = new JsonSlurper().parseText(tabletMetaRes1)
-obj2 = new JsonSlurper().parseText(tabletMetaRes2)
-obj3 = new JsonSlurper().parseText(tabletMetaRes3)
-
-rowCount1 = obj1.rs_metas[0].num_rows + obj1.rs_metas[1].num_rows + 
obj1.rs_metas[2].num_rows + obj1.rs_metas[3

Re: [PR] [opt](regression test) use select count from tablet api [doris]

2023-12-13 Thread via GitHub


qidaye merged PR #28327:
URL: https://github.com/apache/doris/pull/28327


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [Bug](fix) fix close order maybe cause use after free [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28339:
URL: https://github.com/apache/doris/pull/28339#issuecomment-1853447205

   clang-tidy review says "All clean, LGTM! :+1:"


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



(doris) branch master updated (3e08bec27f3 -> 8ac52aeda7a)

2023-12-13 Thread morrysnow
This is an automated email from the ASF dual-hosted git repository.

morrysnow pushed a change to branch master
in repository https://gitbox.apache.org/repos/asf/doris.git


from 3e08bec27f3 [opt](regression test) use select count from tablet api 
(#28327)
 add 8ac52aeda7a [fix](nereids) wrong result when simplify int compare with 
decimal literal (#28195)

No new revisions were added by this update.

Summary of changes:
 .../rules/expression/rules/SimplifyComparisonPredicate.java  | 9 +
 .../test_simplify_comparison.out}| 4 ++--
 .../suites/nereids_syntax_p0/test_simplify_comparison.groovy | 3 +++
 3 files changed, 10 insertions(+), 6 deletions(-)
 copy 
regression-test/data/{correctness/test_exceed_max_pushdown_conditions_per_column.out
 => nereids_syntax_p0/test_simplify_comparison.out} (78%)


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Error while running github feature from .asf.yaml in doris!

2023-12-13 Thread Apache Infrastructure


An error occurred while running github feature in .asf.yaml!:
You can only have a maximum of 10 external triage collaborators, please contact 
vp-in...@apache.org to request an exception.


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](nereids)SimplifyComparisonPredicate rule create wrong result when simplify int compare with decimal literal [doris]

2023-12-13 Thread via GitHub


morrySnow merged PR #28195:
URL: https://github.com/apache/doris/pull/28195


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Error while running github feature from .asf.yaml in doris!

2023-12-13 Thread Apache Infrastructure


An error occurred while running github feature in .asf.yaml!:
You can only have a maximum of 10 external triage collaborators, please contact 
vp-in...@apache.org to request an exception.


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [pipelineX](local shuffle) Support parallel execution despite of tablet number [doris]

2023-12-13 Thread via GitHub


Gabriel39 commented on PR #28266:
URL: https://github.com/apache/doris/pull/28266#issuecomment-1853457562

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](group commit) Fix some group commit problems [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28319:
URL: https://github.com/apache/doris/pull/28319#issuecomment-1853463669

   PR approved by at least one committer and no changes requested.


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](group commit) Fix some group commit problems [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28319:
URL: https://github.com/apache/doris/pull/28319#issuecomment-1853463753

   PR approved by anyone and no changes requested.


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](decimal) fix decimal overflow caused by null value (#28260) [doris]

2023-12-13 Thread via GitHub


yiguolei merged PR #28289:
URL: https://github.com/apache/doris/pull/28289


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



(doris) branch branch-2.0 updated: [fix](decimal) fix decimal overflow caused by null value (#28289)

2023-12-13 Thread yiguolei
This is an automated email from the ASF dual-hosted git repository.

yiguolei pushed a commit to branch branch-2.0
in repository https://gitbox.apache.org/repos/asf/doris.git


The following commit(s) were added to refs/heads/branch-2.0 by this push:
 new 39ed609ffdd [fix](decimal) fix decimal overflow caused by null value 
(#28289)
39ed609ffdd is described below

commit 39ed609ffddbedc519e5457975b1cd4a8f94d2d8
Author: TengJianPing <18241664+jackte...@users.noreply.github.com>
AuthorDate: Wed Dec 13 16:28:19 2023 +0800

[fix](decimal) fix decimal overflow caused by null value (#28289)
---
 be/src/vec/columns/column_nullable.cpp |  9 +++
 be/src/vec/columns/column_nullable.h   |  2 +
 be/src/vec/functions/function.cpp  | 17 -
 .../data/datatype_p0/decimalv3/fix-overflow.out|  4 ++
 .../datatype_p0/decimalv3/fix-overflow.groovy  | 73 ++
 5 files changed, 103 insertions(+), 2 deletions(-)

diff --git a/be/src/vec/columns/column_nullable.cpp 
b/be/src/vec/columns/column_nullable.cpp
index 342da451185..8364c1626a4 100644
--- a/be/src/vec/columns/column_nullable.cpp
+++ b/be/src/vec/columns/column_nullable.cpp
@@ -60,6 +60,15 @@ ColumnNullable::ColumnNullable(MutableColumnPtr&& 
nested_column_, MutableColumnP
 _need_update_has_null = true;
 }
 
+void ColumnNullable::update_null_data() {
+const auto& null_map_data = _get_null_map_data();
+auto s = size();
+for (size_t i = 0; i < s; ++i) {
+if (null_map_data[i]) {
+nested_column->replace_column_data_default(i);
+}
+}
+}
 MutableColumnPtr ColumnNullable::get_shrinked_column() {
 return 
ColumnNullable::create(get_nested_column_ptr()->get_shrinked_column(),
   get_null_map_column_ptr());
diff --git a/be/src/vec/columns/column_nullable.h 
b/be/src/vec/columns/column_nullable.h
index d183ce03853..8b0ff21c9f7 100644
--- a/be/src/vec/columns/column_nullable.h
+++ b/be/src/vec/columns/column_nullable.h
@@ -93,6 +93,8 @@ public:
 return Base::create(std::forward(args)...);
 }
 
+void update_null_data();
+
 MutableColumnPtr get_shrinked_column() override;
 
 const char* get_family_name() const override { return "Nullable"; }
diff --git a/be/src/vec/functions/function.cpp 
b/be/src/vec/functions/function.cpp
index 031b8e755b4..b92f5453bfe 100644
--- a/be/src/vec/functions/function.cpp
+++ b/be/src/vec/functions/function.cpp
@@ -99,8 +99,21 @@ ColumnPtr wrap_in_nullable(const ColumnPtr& src, const 
Block& block, const Colum
 return ColumnNullable::create(src, 
ColumnUInt8::create(input_rows_count, 0));
 }
 
-return 
ColumnNullable::create(src_not_nullable->convert_to_full_column_if_const(),
-  result_null_map_column);
+bool update_null_data = false;
+auto full_column = src_not_nullable->convert_to_full_column_if_const();
+if (const auto* nullable = check_and_get_column(full_column.get())) {
+const auto& nested_column = nullable->get_nested_column();
+update_null_data = nested_column.is_numeric() || 
nested_column.is_column_decimal();
+} else {
+update_null_data = full_column->is_numeric() || 
full_column->is_column_decimal();
+}
+auto result_column = ColumnNullable::create(full_column, 
result_null_map_column);
+if (update_null_data) {
+auto* res_nullable_column =
+
assert_cast(std::move(*result_column).mutate().get());
+res_nullable_column->update_null_data();
+}
+return result_column;
 }
 
 NullPresence get_null_presence(const Block& block, const ColumnNumbers& args) {
diff --git a/regression-test/data/datatype_p0/decimalv3/fix-overflow.out 
b/regression-test/data/datatype_p0/decimalv3/fix-overflow.out
index 4bd52d46e49..ba2250c9b72 100644
--- a/regression-test/data/datatype_p0/decimalv3/fix-overflow.out
+++ b/regression-test/data/datatype_p0/decimalv3/fix-overflow.out
@@ -2,3 +2,7 @@
 -- !sql --
 1.1\N  \N
 
+-- !select_insert --
+a  \N
+b  0.00
+
diff --git a/regression-test/suites/datatype_p0/decimalv3/fix-overflow.groovy 
b/regression-test/suites/datatype_p0/decimalv3/fix-overflow.groovy
index 7b8ef17007d..fd9350ab250 100644
--- a/regression-test/suites/datatype_p0/decimalv3/fix-overflow.groovy
+++ b/regression-test/suites/datatype_p0/decimalv3/fix-overflow.groovy
@@ -31,4 +31,77 @@ suite("fix-overflow") {
 qt_sql """
 select l.k1, r.k1, l.k1 * r.k1 from fix_overflow_l l left join 
fix_overflow_r r on l.k1=r.k1;
 """
+
+sql """
+drop TABLE if exists `fix_overflow_null1`;
+"""
+sql """
+CREATE TABLE `fix_overflow_null1`
+(
+`country` varchar(20),
+`financing_amount`decimalv3(20, 2)
+) 
+DISTRIBUTED BY HASH(`country`) BUCKETS 10
+PROPERTIES (
+"replication_num" = "1"
+);
+"""
+sql """
+insert

Re: [PR] [pipelineX](local shuffle) Support parallel execution despite of tablet number [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28266:
URL: https://github.com/apache/doris/pull/28266#issuecomment-1853470357

   clang-tidy review says "All clean, LGTM! :+1:"


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](regression) mow cases should use assertEquals not assertTrue [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28338:
URL: https://github.com/apache/doris/pull/28338#issuecomment-1853471738

   PR approved by at least one committer and no changes requested.


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](regression) mow cases should use assertEquals not assertTrue [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28338:
URL: https://github.com/apache/doris/pull/28338#issuecomment-1853471794

   PR approved by anyone and no changes requested.


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [pipelineX](local shuffle) Support parallel execution despite of tablet number [doris]

2023-12-13 Thread via GitHub


Gabriel39 commented on PR #28266:
URL: https://github.com/apache/doris/pull/28266#issuecomment-1853473287

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [pipelineX](local shuffle) Support parallel execution despite of tablet number [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28266:
URL: https://github.com/apache/doris/pull/28266#issuecomment-1853476139

   clang-tidy review says "All clean, LGTM! :+1:"


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [doc](auditlog) update description of field sql_digest [doris]

2023-12-13 Thread via GitHub


zhiqiang- commented on PR #28340:
URL: https://github.com/apache/doris/pull/28340#issuecomment-1853476471

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



[PR] [doc](auditlog) update description of field sql_digest [doris]

2023-12-13 Thread via GitHub


zhiqiang- opened a new pull request, #28340:
URL: https://github.com/apache/doris/pull/28340

   emphasize sql_digest will be empty is query is not slow query.


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](Nereids) could not do partition prunning when predicates is NULL [doris]

2023-12-13 Thread via GitHub


morrySnow commented on PR #28294:
URL: https://github.com/apache/doris/pull/28294#issuecomment-1853476929

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [refactor](Nereids) let create table compatible with legacy planner [doris]

2023-12-13 Thread via GitHub


morrySnow merged PR #28078:
URL: https://github.com/apache/doris/pull/28078


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



(doris) branch master updated: [refactor](Nereids) let create table compatible with legacy planner (#28078)

2023-12-13 Thread morrysnow
This is an automated email from the ASF dual-hosted git repository.

morrysnow pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/doris.git


The following commit(s) were added to refs/heads/master by this push:
 new dee89d2c4ad [refactor](Nereids) let create table compatible with 
legacy planner (#28078)
dee89d2c4ad is described below

commit dee89d2c4ada85648233d8619dc68ea0644b7f2e
Author: starocean999 <40539150+starocean...@users.noreply.github.com>
AuthorDate: Wed Dec 13 16:35:40 2023 +0800

[refactor](Nereids) let create table compatible with legacy planner (#28078)
---
 .../antlr4/org/apache/doris/nereids/DorisParser.g4 |  40 +-
 .../org/apache/doris/analysis/CreateMTMVStmt.java  |   2 +-
 .../org/apache/doris/analysis/CreateTableStmt.java |   2 +
 .../java/org/apache/doris/analysis/KeysDesc.java   |   6 +
 .../main/java/org/apache/doris/catalog/Column.java |  11 +
 .../doris/nereids/parser/LogicalPlanBuilder.java   |  77 +-
 .../parser/spark/SparkSql3LogicalPlanBuilder.java  |   4 +-
 .../plans/commands/info/ColumnDefinition.java  | 146 +++-
 .../trees/plans/commands/info/CreateMTMVInfo.java  |   2 +-
 .../trees/plans/commands/info/CreateTableInfo.java | 794 -
 .../commands/info/DistributionDescriptor.java  |  10 +-
 .../plans/commands/info/FixedRangePartition.java   |  17 +-
 .../trees/plans/commands/info/InPartition.java |   5 +
 .../trees/plans/commands/info/IndexDefinition.java | 179 -
 .../jdbc/test_doris_jdbc_catalog.out   |  30 +-
 .../data/insert_p0/insert_with_null.out|   9 +-
 .../unique/test_unique_table_auto_inc.groovy   |   2 +-
 .../suites/ddl_p0/test_create_table_like.groovy|   2 +-
 .../external_table_p0/tvf/test_s3_tvf.groovy   |   2 +-
 .../suites/index_p0/test_index_meta.groovy |  12 +-
 .../load_p0/stream_load/test_csv_split_line.groovy |   2 +-
 .../cast_function/test_cast_map_function.groovy|   2 +-
 .../session_variable/test_default_limit.groovy |   4 +-
 .../test_multi_column_partition.groovy |  30 +-
 regression-test/suites/point_query_p0/load.groovy  |  19 +
 .../cast_function/test_cast_map_function.groovy|   2 +-
 .../test_alter_table_drop_column.groovy|   2 +-
 .../test_alter_table_modify_column.groovy  |   4 +-
 .../cluster_key/test_create_table.groovy   |  58 +-
 29 files changed, 1159 insertions(+), 316 deletions(-)

diff --git a/fe/fe-core/src/main/antlr4/org/apache/doris/nereids/DorisParser.g4 
b/fe/fe-core/src/main/antlr4/org/apache/doris/nereids/DorisParser.g4
index ed81a277429..e88773c56b7 100644
--- a/fe/fe-core/src/main/antlr4/org/apache/doris/nereids/DorisParser.g4
+++ b/fe/fe-core/src/main/antlr4/org/apache/doris/nereids/DorisParser.g4
@@ -40,15 +40,17 @@ statement
 AS type=(RESTRICTIVE | PERMISSIVE)
 TO (user=userIdentify | ROLE roleName=identifier)
 USING LEFT_PAREN booleanExpression RIGHT_PAREN 
#createRowPolicy
-| CREATE TABLE (IF NOT EXISTS)? name=multipartIdentifier
-((ctasCols=identifierList)? | (LEFT_PAREN columnDefs indexDefs? 
RIGHT_PAREN))
+| CREATE (EXTERNAL)? TABLE (IF NOT EXISTS)? name=multipartIdentifier
+((ctasCols=identifierList)? | (LEFT_PAREN columnDefs (COMMA 
indexDefs)? RIGHT_PAREN))
 (ENGINE EQ engine=identifier)?
-((AGGREGATE | UNIQUE | DUPLICATE) KEY keys=identifierList)?
+((AGGREGATE | UNIQUE | DUPLICATE) KEY keys=identifierList (CLUSTER BY 
clusterKeys=identifierList)?)?
 (COMMENT STRING_LITERAL)?
-(PARTITION BY (RANGE | LIST) partitionKeys=identifierList LEFT_PAREN 
partitions=partitionsDef RIGHT_PAREN)?
-(DISTRIBUTED BY (HASH hashKeys=identifierList | RANDOM) (BUCKETS 
INTEGER_VALUE | AUTO)?)?
+((autoPartition=AUTO)? PARTITION BY (RANGE | LIST) 
(partitionKeys=identifierList | partitionExpr=functionCallExpression)
+  LEFT_PAREN (partitions=partitionsDef)? RIGHT_PAREN)?
+(DISTRIBUTED BY (HASH hashKeys=identifierList | RANDOM) (BUCKETS 
(INTEGER_VALUE | autoBucket=AUTO))?)?
 (ROLLUP LEFT_PAREN rollupDefs RIGHT_PAREN)?
-propertyClause?
+properties=propertyClause?
+(BROKER extProperties=propertyClause)?
 (AS query)?
#createTable
 | explain? INSERT (INTO | OVERWRITE TABLE)
 (tableName=multipartIdentifier | DORIS_INTERNAL_TABLE_ID LEFT_PAREN 
tableId=INTEGER_VALUE RIGHT_PAREN)
@@ -482,7 +484,7 @@ columnDefs
 
 columnDef
 : colName=identifier type=dataType
-KEY? (aggType=aggTypeDef)? ((NOT NULL) | NULL)?
+KEY? (aggType=aggTypeDef)? ((NOT NULL) | NULL)? (AUTO_INCREMENT)?
 (DEFAULT (nullValue=NULL | INTEGER_VALUE | stringValue=STRING_LITERAL
 | CURRENT_TIMESTAMP (LEFT_PAREN defaultValuePrecision=number 
RIGHT_PAREN)?))?
 (ON UPDATE CURRENT_TIMESTAMP (LEFT_PAREN onUpdateValuePrecision=n

Error while running github feature from .asf.yaml in doris!

2023-12-13 Thread Apache Infrastructure


An error occurred while running github feature in .asf.yaml!:
You can only have a maximum of 10 external triage collaborators, please contact 
vp-in...@apache.org to request an exception.


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [bugfix](jdbc catalog) refresh catalog close jdbcclient [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28300:
URL: https://github.com/apache/doris/pull/28300#issuecomment-1853478499

   
   
   TPC-H test result on machine: 
'aliyun_ecs.c7a.8xlarge_32C64G'
   
   ```
   Tpch sf100 test result on commit c79714b4a07d36734bbe12e505ac552ed55e1b2a, 
data reload: false
   
   run tpch-sf100 query with default conf and session variables
   q1   51476   31831   31843   31831
   q2   368 135 143 135
   q3   1533123912181218
   q4   1106929 875 875
   q5   3471320432433204
   q6   259 145 149 145
   q7   984 502 494 494
   q8   2153220122012201
   q9   6887694468726872
   q10  3252330132873287
   q11  335 213 212 212
   q12  348 208 205 205
   q13  4574385137863786
   q14  433 327 319 319
   q15  765 130413271304
   q16  440 391 388 388
   q17  1025596 573 573
   q18  7570822769026902
   q19  1529128014801280
   q20  588 301 321 301
   q21  3094264326322632
   q22  354 276 285 276
   Total cold run time: 92544 ms
   Total hot run time: 68440 ms
   
   run tpch-sf100 query with default conf and set session variable 
runtime_filter_mode=off
   q1   30832   31833   31803   31803
   q2   278 173 173 173
   q3   3655362236203620
   q4   2390237523702370
   q5   5800582658275826
   q6   241 137 131 131
   q7   3060338933823382
   q8   3522353835353535
   q9   9216916091679160
   q10  3966404440604044
   q11  790 940 1334940
   q12  775 611 601 601
   q13  4291354135493541
   q14  504 425 438 425
   q15  1141134313231323
   q16  495 486 472 472
   q17  1887186218401840
   q18  8804834083048304
   q19  1755179618151796
   q20  2945260426922604
   q21  6539615361646153
   q22  508 409 429 409
   Total cold run time: 93394 ms
   Total hot run time: 92452 ms
   ```
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](partial update) Fix session variable `enable_unique_key_partial_update` will affect the behavior of insert statement when the target table is not unique table [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28321:
URL: https://github.com/apache/doris/pull/28321#issuecomment-1853478652

   PR approved by at least one committer and no changes requested.


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](partial update) Fix session variable `enable_unique_key_partial_update` will affect the behavior of insert statement when the target table is not unique table [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28321:
URL: https://github.com/apache/doris/pull/28321#issuecomment-1853478717

   PR approved by anyone and no changes requested.


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [feture](Nereids) support delete from without using [doris]

2023-12-13 Thread via GitHub


morrySnow commented on PR #28083:
URL: https://github.com/apache/doris/pull/28083#issuecomment-1853480510

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [regression](memtable) add case for memtable flush error status handle [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28285:
URL: https://github.com/apache/doris/pull/28285#issuecomment-1853486277

   PR approved by at least one committer and no changes requested.


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [regression](memtable) add case for memtable flush error status handle [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28285:
URL: https://github.com/apache/doris/pull/28285#issuecomment-1853486336

   PR approved by anyone and no changes requested.


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [pipelineX](local shuffle) Support parallel execution despite of tablet number [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28266:
URL: https://github.com/apache/doris/pull/28266#issuecomment-1853486374

   clang-tidy review says "All clean, LGTM! :+1:"


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



[PR] [fix](nereids)SimplifyComparisonPredicate rule create wrong result when simplify int compare with decimal literal [doris]

2023-12-13 Thread via GitHub


starocean999 opened a new pull request, #28341:
URL: https://github.com/apache/doris/pull/28341

   
   
   pick from master https://github.com/apache/doris/pull/28195
   
   Issue Number: close #xxx
   
   
   
   ## Further comments
   
   If this is a relatively large or complex change, kick off the discussion at 
[d...@doris.apache.org](mailto:d...@doris.apache.org) by explaining why you 
chose the solution you did and what alternatives you considered, etc...
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](nereids)SimplifyComparisonPredicate rule create wrong result when simplify int compare with decimal literal [doris]

2023-12-13 Thread via GitHub


starocean999 commented on PR #28341:
URL: https://github.com/apache/doris/pull/28341#issuecomment-1853488498

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [feture](Nereids) support delete from without using [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28083:
URL: https://github.com/apache/doris/pull/28083#issuecomment-1853490644

   clang-tidy review says "All clean, LGTM! :+1:"


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] investigate master tpch [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28330:
URL: https://github.com/apache/doris/pull/28330#issuecomment-1853492550

   
   
   TPC-H test result on machine: 
'aliyun_ecs.c7a.8xlarge_32C64G'
   
   ```
   Tpch sf100 test result on commit 75db69e24abadfe7b40616f71093b741970f6a9e, 
data reload: false
   
   run tpch-sf100 query with default conf and session variables
   q1   48128   31820   31842   31820
   q2   379 135 138 135
   q3   1552125711831183
   q4   1113937 873 873
   q5   3207341132013201
   q6   266 149 140 140
   q7   977 508 488 488
   q8   2188226822022202
   q9   6938694470346944
   q10  3277333832963296
   q11  331 212 222 212
   q12  355 212 206 206
   q13  4599390038993899
   q14  421 319 320 319
   q15  779 130613251306
   q16  448 389 394 389
   q17  1028559 552 552
   q18  8143706569796979
   q19  1514131514901315
   q20  558 935 284 284
   q21  3111269026852685
   q22  354 292 291 291
   Total cold run time: 89666 ms
   Total hot run time: 68719 ms
   
   run tpch-sf100 query with default conf and set session variable 
runtime_filter_mode=off
   q1   30797   31847   31818   31818
   q2   271 168 177 168
   q3   3660364736363636
   q4   2409238323792379
   q5   5811579658295796
   q6   243 133 131 131
   q7   3041340333823382
   q8   3539355835523552
   q9   9259921091249124
   q10  3969407340714071
   q11  804 926 1358926
   q12  772 602 596 596
   q13  4316355635643556
   q14  505 441 445 441
   q15  1101134413271327
   q16  514 473 476 473
   q17  1872185519331855
   q18  8912809082528090
   q19  1775176917761769
   q20  2931257126242571
   q21  6614621962216219
   q22  506 428 434 428
   Total cold run time: 93621 ms
   Total hot run time: 92308 ms
   ```
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [bugfix](jdbc catalog) refresh catalog close jdbcclient [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28300:
URL: https://github.com/apache/doris/pull/28300#issuecomment-1853497706

   (From new machine)TeamCity pipeline, clickbench performance test result:
the sum of best hot time: 45.69 seconds
stream load tsv:  588 seconds loaded 74807831229 Bytes, about 121 
MB/s
stream load json: 19 seconds loaded 2358488459 Bytes, about 118 MB/s
stream load orc:  67 seconds loaded 1101869774 Bytes, about 15 MB/s
stream load parquet:  32 seconds loaded 861443392 Bytes, about 25 
MB/s
insert into select:  29.0 seconds inserted 1000 Rows, about 
344K ops/s
storage size: 17222076810 Bytes


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] investigate master tpch [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28330:
URL: https://github.com/apache/doris/pull/28330#issuecomment-1853498357

   (From new machine)TeamCity pipeline, clickbench performance test result:
the sum of best hot time: 45.13 seconds
stream load tsv:  586 seconds loaded 74807831229 Bytes, about 121 
MB/s
stream load json: 19 seconds loaded 2358488459 Bytes, about 118 MB/s
stream load orc:  66 seconds loaded 1101869774 Bytes, about 15 MB/s
stream load parquet:  31 seconds loaded 861443392 Bytes, about 26 
MB/s
insert into select:  29.4 seconds inserted 1000 Rows, about 
340K ops/s
storage size: 17224246264 Bytes


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](memory_leak) fix memory leak on vrow_distribution [doris]

2023-12-13 Thread via GitHub


yiguolei commented on PR #28336:
URL: https://github.com/apache/doris/pull/28336#issuecomment-1853499652

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] investigate 2.0 ckb [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28334:
URL: https://github.com/apache/doris/pull/28334#issuecomment-1853500208

   (From new machine)TeamCity pipeline, clickbench performance test result:
the sum of best hot time: 49.26 seconds
stream load tsv:  564 seconds loaded 74807831229 Bytes, about 126 
MB/s
stream load json: 19 seconds loaded 2358488459 Bytes, about 118 MB/s
stream load orc:  65 seconds loaded 1101869774 Bytes, about 16 MB/s
stream load parquet:  32 seconds loaded 861443392 Bytes, about 25 
MB/s
insert into select:  29.5 seconds inserted 1000 Rows, about 
338K ops/s
storage size: 17162798462 Bytes


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](sequence column) fix update fail on nereids planner [doris]

2023-12-13 Thread via GitHub


zhannngchen commented on PR #28031:
URL: https://github.com/apache/doris/pull/28031#issuecomment-1853501340

   run clickbench-new


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [Enhancement](Wal)Support dynamic wal space limit [doris]

2023-12-13 Thread via GitHub


mymeiyi commented on code in PR #27726:
URL: https://github.com/apache/doris/pull/27726#discussion_r1425036466


##
be/src/http/action/http_stream.cpp:
##
@@ -182,12 +183,22 @@ int HttpStreamAction::on_header(HttpRequest* req) {
 if (!group_commit_mode.empty() || 
config::wait_internal_group_commit_finish) {
 ctx->group_commit = load_size_smaller_than_wal_limit(req);
 if (!ctx->group_commit) {
-LOG(WARNING) << "The data size for this http load("
- << std::stol(req->header(HttpHeaders::CONTENT_LENGTH))
- << " Bytes) exceeds the WAL (Write-Ahead Log) limit ("
- << config::wal_max_disk_size * 0.8
- << " Bytes). Please set this load to \"group 
commit\"=false.";
-st = Status::InternalError("Http load size too large.");
+std::stringstream err_msg;
+const auto& map = 
ExecEnv::GetInstance()->wal_mgr()->get_wal_dir_to_max_limit_map();
+err_msg << "When enable group commit, the data size can't be too 
large. The data size "
+   "for this http load("
+<< (req->header(HttpHeaders::CONTENT_LENGTH).empty()
+? 0
+: 
std::stol(req->header(HttpHeaders::CONTENT_LENGTH)))
+<< " Bytes) exceeds the WAL (Write-Ahead Log) limit ("
+<< std::max_element(map.begin(), map.end(),

Review Comment:
   It's better to abstract a function to get the max limit wal dir



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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



[PR] [typo](doc) optimization show processlist [doris]

2023-12-13 Thread via GitHub


caoliang-web opened a new pull request, #28342:
URL: https://github.com/apache/doris/pull/28342

   ## Proposed changes
   
   Issue Number: close #xxx
   
   
   
   ## Further comments
   
   If this is a relatively large or complex change, kick off the discussion at 
[d...@doris.apache.org](mailto:d...@doris.apache.org) by explaining why you 
chose the solution you did and what alternatives you considered, etc...
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] investigate master tpch [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28331:
URL: https://github.com/apache/doris/pull/28331#issuecomment-1853508698

   
   
   TPC-H test result on machine: 
'aliyun_ecs.c7a.8xlarge_32C64G'
   
   ```
   Tpch sf100 test result on commit d7a78d684469fb4c12cb0af95a15b89edd247731, 
data reload: false
   
   run tpch-sf100 query with default conf and session variables
   q1   49834   31811   31835   31811
   q2   377 137 137 137
   q3   1527124212241224
   q4   1113935 887 887
   q5   3196320931743174
   q6   258 145 140 140
   q7   989 496 484 484
   q8   2163221322002200
   q9   6937685968436843
   q10  3256330233033302
   q11  333 213 201 201
   q12  354 208 207 207
   q13  4543383237903790
   q14  426 315 319 315
   q15  779 131313111311
   q16  441 384 393 384
   q17  1031578 544 544
   q18  7298816370497049
   q19  1530131414571314
   q20  598 309 293 293
   q21  3074260626832606
   q22  353 293 285 285
   Total cold run time: 90410 ms
   Total hot run time: 68501 ms
   
   run tpch-sf100 query with default conf and set session variable 
runtime_filter_mode=off
   q1   30794   31817   31802   31802
   q2   275 167 169 167
   q3   3643362835973597
   q4   2400238723852385
   q5   5776578757835783
   q6   240 133 138 133
   q7   3075340433743374
   q8   3537354735353535
   q9   9307913892129138
   q10  3963407240514051
   q11  816 936 1332936
   q12  765 612 610 610
   q13  4287355535413541
   q14  504 444 452 444
   q15  1125131813321318
   q16  502 460 470 460
   q17  1914183418601834
   q18  8878933682808280
   q19  1726178517661766
   q20  2884259626412596
   q21  6551615761476147
   q22  516 420 429 420
   Total cold run time: 93478 ms
   Total hot run time: 92317 ms
   ```
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](memory_leak) fix memory leak on vrow_distribution [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28336:
URL: https://github.com/apache/doris/pull/28336#issuecomment-1853509266

   clang-tidy review says "All clean, LGTM! :+1:"


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



(doris) branch master updated (dee89d2c4ad -> e6e86321671)

2023-12-13 Thread zhangchen
This is an automated email from the ASF dual-hosted git repository.

zhangchen pushed a change to branch master
in repository https://gitbox.apache.org/repos/asf/doris.git


from dee89d2c4ad [refactor](Nereids) let create table compatible with 
legacy planner (#28078)
 add e6e86321671 [improvement](merge-on-write) Optimize publish when there 
are missing versions (#28012)

No new revisions were added by this update.

Summary of changes:
 be/src/agent/task_worker_pool.cpp|   5 +
 be/src/common/config.cpp |   3 +
 be/src/common/config.h   |   3 +
 be/src/olap/olap_server.cpp  | 120 ++-
 be/src/olap/storage_engine.h |   5 +-
 be/src/olap/task/engine_publish_version_task.cpp |  13 ++-
 be/test/olap/storage_engine_test.cpp | 104 ++--
 7 files changed, 195 insertions(+), 58 deletions(-)


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [improvement](merge-on-write) Optimize publish when there are missing versions [doris]

2023-12-13 Thread via GitHub


zhannngchen merged PR #28012:
URL: https://github.com/apache/doris/pull/28012


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Error while running github feature from .asf.yaml in doris!

2023-12-13 Thread Apache Infrastructure


An error occurred while running github feature in .asf.yaml!:
You can only have a maximum of 10 external triage collaborators, please contact 
vp-in...@apache.org to request an exception.


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [Bug](fix) fix close order maybe cause use after free [doris]

2023-12-13 Thread via GitHub


yiguolei commented on PR #28339:
URL: https://github.com/apache/doris/pull/28339#issuecomment-1853514747

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [Bug](fix) fix close order maybe cause use after free [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28339:
URL: https://github.com/apache/doris/pull/28339#issuecomment-1853516274

   PR approved by anyone and no changes requested.


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [Bug](fix) fix close order maybe cause use after free [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28339:
URL: https://github.com/apache/doris/pull/28339#issuecomment-1853516212

   PR approved by at least one committer and no changes requested.


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [refactor](cluster)(step-4) remove cluster related to Database [doris]

2023-12-13 Thread via GitHub


morningman commented on PR #27861:
URL: https://github.com/apache/doris/pull/27861#issuecomment-1853520284

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](sequence column) fix update fail on nereids planner [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28031:
URL: https://github.com/apache/doris/pull/28031#issuecomment-1853523186

   
   
   TPC-H test result on machine: 
'aliyun_ecs.c7a.8xlarge_32C64G'
   
   ```
   Tpch sf100 test result on commit 10e66c33cb70873d2787f6e56bf87fd9c4336380, 
data reload: false
   
   run tpch-sf100 query with default conf and session variables
   q1   50152   31845   31781   31781
   q2   389 141 137 137
   q3   1566129111821182
   q4   1120935 897 897
   q5   3185346331723172
   q6   267 142 141 141
   q7   977 489 496 489
   q8   2162221022032203
   q9   6944692168906890
   q10  3265330532893289
   q11  346 221 218 218
   q12  346 198 205 198
   q13  4574380938273809
   q14  377 325 316 316
   q15  815 131113251311
   q16  445 393 394 393
   q17  1029611 545 545
   q18  7467704769606960
   q19  1529140214491402
   q20  584 306 307 306
   q21  3096265126462646
   q22  356 278 284 278
   Total cold run time: 90991 ms
   Total hot run time: 68563 ms
   
   run tpch-sf100 query with default conf and set session variable 
runtime_filter_mode=off
   q1   30775   31820   31807   31807
   q2   276 163 173 163
   q3   3686363936173617
   q4   2396236123582358
   q5   5779586657905790
   q6   242 131 128 128
   q7   3063340033843384
   q8   3540354235363536
   q9   9234918491119111
   q10  3956405340414041
   q11  817 918 1350918
   q12  805 669 588 588
   q13  4282356035763560
   q14  528 438 480 438
   q15  1032133113301330
   q16  535 439 467 439
   q17  1873184418531844
   q18  8901842284528422
   q19  1759176817421742
   q20  2902259425522552
   q21  6542618661336133
   q22  506 413 413 413
   Total cold run time: 93429 ms
   Total hot run time: 92314 ms
   ```
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



[PR] [fix](Variant Type) Fixes the desc failure [doris]

2023-12-13 Thread via GitHub


csun5285 opened a new pull request, #28343:
URL: https://github.com/apache/doris/pull/28343

   ## Proposed changes
   
   Issue Number: close #xxx
   
   fix the desc failure when there is no decomposition of columns in the 
variant column.
   
   
   ## Further comments
   
   If this is a relatively large or complex change, kick off the discussion at 
[d...@doris.apache.org](mailto:d...@doris.apache.org) by explaining why you 
chose the solution you did and what alternatives you considered, etc...
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](Variant Type) Fixes the desc failure [doris]

2023-12-13 Thread via GitHub


csun5285 commented on PR #28343:
URL: https://github.com/apache/doris/pull/28343#issuecomment-1853530457

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [enhancement](compaction) Add support for limiting low priority compaction scheduling [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #27648:
URL: https://github.com/apache/doris/pull/27648#issuecomment-1853534467

   (From new machine)TeamCity pipeline, clickbench performance test result:
the sum of best hot time: 44.65 seconds
stream load tsv:  591 seconds loaded 74807831229 Bytes, about 120 
MB/s
stream load json: 19 seconds loaded 2358488459 Bytes, about 118 MB/s
stream load orc:  67 seconds loaded 1101869774 Bytes, about 15 MB/s
stream load parquet:  32 seconds loaded 861443392 Bytes, about 25 
MB/s
insert into select:  29.0 seconds inserted 1000 Rows, about 
344K ops/s
storage size: 17221050180 Bytes


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](partial update) Fix session variable `enable_unique_key_partial_update` will affect the behavior of insert statement when the target table is not unique table [doris]

2023-12-13 Thread via GitHub


dataroaring merged PR #28321:
URL: https://github.com/apache/doris/pull/28321


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



(doris) branch master updated (e6e86321671 -> ac262fa176e)

2023-12-13 Thread dataroaring
This is an automated email from the ASF dual-hosted git repository.

dataroaring pushed a change to branch master
in repository https://gitbox.apache.org/repos/asf/doris.git


from e6e86321671 [improvement](merge-on-write) Optimize publish when there 
are missing versions (#28012)
 add ac262fa176e [fix](partial update) Fix session variable 
`enable_unique_key_partial_update` will affect the behavior of insert statement 
when the target table is not unique table (#28321)

No new revisions were added by this update.

Summary of changes:
 .../apache/doris/analysis/NativeInsertStmt.java| 25 +++---
 .../doris/nereids/rules/analysis/BindSink.java |  5 +-
 .../test_partial_update_native_insert_stmt.out | 16 
 .../test_partial_update_native_insert_stmt.groovy  | 92 ++
 4 files changed, 126 insertions(+), 12 deletions(-)


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Error while running github feature from .asf.yaml in doris!

2023-12-13 Thread Apache Infrastructure


An error occurred while running github feature in .asf.yaml!:
You can only have a maximum of 10 external triage collaborators, please contact 
vp-in...@apache.org to request an exception.


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



[PR] [fix](doriswriter)Fix multiple concurrent import label duplication issues [doris]

2023-12-13 Thread via GitHub


caoliang-web opened a new pull request, #28344:
URL: https://github.com/apache/doris/pull/28344

   ## Proposed changes
   
   Issue Number: close #xxx
   
   Fix multiple concurrent import label duplication issues
   
   ## Further comments
   
   If this is a relatively large or complex change, kick off the discussion at 
[d...@doris.apache.org](mailto:d...@doris.apache.org) by explaining why you 
chose the solution you did and what alternatives you considered, etc...
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](Nereids) could not do partition prunning when predicates is NULL [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28294:
URL: https://github.com/apache/doris/pull/28294#issuecomment-1853534838

   (From new machine)TeamCity pipeline, clickbench performance test result:
the sum of best hot time: 44.3 seconds
stream load tsv:  600 seconds loaded 74807831229 Bytes, about 118 
MB/s
stream load json: 19 seconds loaded 2358488459 Bytes, about 118 MB/s
stream load orc:  67 seconds loaded 1101869774 Bytes, about 15 MB/s
stream load parquet:  32 seconds loaded 861443392 Bytes, about 25 
MB/s
insert into select:  28.6 seconds inserted 1000 Rows, about 
349K ops/s
storage size: 17222597524 Bytes


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](test) fix index change testcases [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28298:
URL: https://github.com/apache/doris/pull/28298#issuecomment-1853539432

   PR approved by at least one committer and no changes requested.


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [feature](merge-on-write) enable merge-on-write by default again [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28105:
URL: https://github.com/apache/doris/pull/28105#issuecomment-1853538350

   
   
   TPC-H test result on machine: 
'aliyun_ecs.c7a.8xlarge_32C64G'
   
   ```
   Tpch sf100 test result on commit 5a5a56ec390dab5811dea41a1974fb2d87a6ed87, 
data reload: false
   
   run tpch-sf100 query with default conf and session variables
   q1   49798   31837   31804   31804
   q2   381 142 140 140
   q3   1485123511941194
   q4   1108942 927 927
   q5   3280323132813231
   q6   264 150 137 137
   q7   1017494 488 488
   q8   2152215921872159
   q9   6981729869346934
   q10  3251329332893289
   q11  332 214 213 213
   q12  357 215 205 205
   q13  4541380838713808
   q14  444 321 335 321
   q15  756 131113381311
   q16  443 387 387 387
   q17  1016524 546 524
   q18  7451714169096909
   q19  1517128014871280
   q20  569 299 310 299
   q21  3062265926912659
   q22  349 288 291 288
   Total cold run time: 90554 ms
   Total hot run time: 68507 ms
   
   run tpch-sf100 query with default conf and set session variable 
runtime_filter_mode=off
   q1   30806   31868   31815   31815
   q2   288 165 184 165
   q3   3693370336133613
   q4   2393237723622362
   q5   5786578457855784
   q6   241 137 137 137
   q7   3056341933703370
   q8   3564353535423535
   q9   9273921391749174
   q10  3985407440514051
   q11  852 885 1343885
   q12  757 607 590 590
   q13  4310355435873554
   q14  479 450 454 450
   q15  1115131213341312
   q16  515 463 467 463
   q17  1881186618371837
   q18  8800847486238474
   q19  1769178717891787
   q20  2910268126362636
   q21  6542620661326132
   q22  510 443 446 443
   Total cold run time: 93525 ms
   Total hot run time: 92569 ms
   ```
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](test) fix index change testcases [doris]

2023-12-13 Thread via GitHub


github-actions[bot] commented on PR #28298:
URL: https://github.com/apache/doris/pull/28298#issuecomment-1853539520

   PR approved by anyone and no changes requested.


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



[PR] delete external table docs [doris]

2023-12-13 Thread via GitHub


ixzc opened a new pull request, #28345:
URL: https://github.com/apache/doris/pull/28345

   ## Proposed changes
   
   Issue Number: close #xxx
   
   
   
   ## Further comments
   
   If this is a relatively large or complex change, kick off the discussion at 
[d...@doris.apache.org](mailto:d...@doris.apache.org) by explaining why you 
chose the solution you did and what alternatives you considered, etc...
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



[PR] [bug](fix) show create table show comment error [doris]

2023-12-13 Thread via GitHub


LemonLiTree opened a new pull request, #28346:
URL: https://github.com/apache/doris/pull/28346

   ## Proposed changes
   
   Issue Number: close #xxx
   
   
   
   ## Further comments
   
   If this is a relatively large or complex change, kick off the discussion at 
[d...@doris.apache.org](mailto:d...@doris.apache.org) by explaining why you 
chose the solution you did and what alternatives you considered, etc...
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [Bug](fix) fix close order maybe cause use after free [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28339:
URL: https://github.com/apache/doris/pull/28339#issuecomment-1853552125

   TeamCity be ut coverage result:
Function Coverage: 37.84% (7991/21119) 
Line Coverage: 29.52% (64831/219649)
Region Coverage: 28.98% (33350/115082)
Branch Coverage: 24.87% (17118/68824)
Coverage Report: 
http://coverage.selectdb-in.cc/coverage/a588ace84794633ecf76e29450b563832edc9c23_a588ace84794633ecf76e29450b563832edc9c23/report/index.html


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](Nereids) could not do partition prunning when predicates is NULL [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28294:
URL: https://github.com/apache/doris/pull/28294#issuecomment-1853554486

   
   
   TPC-H test result on machine: 
'aliyun_ecs.c7a.8xlarge_32C64G'
   
   ```
   Tpch sf100 test result on commit 20f3b6748361154a8bbe94316d9a784b140c4d6a, 
data reload: false
   
   run tpch-sf100 query with default conf and session variables
   q1   51553   31840   31827   31827
   q2   382 141 139 139
   q3   1599125612091209
   q4   1126909 900 900
   q5   3253322032693220
   q6   270 142 139 139
   q7   1013500 500 500
   q8   2169222622102210
   q9   6934689068806880
   q10  3271332333383323
   q11  347 213 200 200
   q12  355 203 204 203
   q13  5014379138063791
   q14  427 323 318 318
   q15  774 130313331303
   q16  433 385 389 385
   q17  1030587 585 585
   q18  7663735669566956
   q19  1525130014481300
   q20  569 320 329 320
   q21  3094268426872684
   q22  349 291 291 291
   Total cold run time: 93150 ms
   Total hot run time: 68683 ms
   
   run tpch-sf100 query with default conf and set session variable 
runtime_filter_mode=off
   q1   30830   31829   31811   31811
   q2   278 162 170 162
   q3   3659360536263605
   q4   2381236223532353
   q5   5796577058045770
   q6   241 129 131 129
   q7   3042339733763376
   q8   3532353935413539
   q9   9214916791689167
   q10  3980404440514044
   q11  818 883 1366883
   q12  765 586 585 585
   q13  4276357635393539
   q14  533 447 448 447
   q15  1085132913221322
   q16  505 442 476 442
   q17  1873185818761858
   q18  8929866182518251
   q19  1755178617811781
   q20  2904257326952573
   q21  6542614661346134
   q22  519 416 434 416
   Total cold run time: 93457 ms
   Total hot run time: 92187 ms
   ```
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



[PR] [docs] Update docs about Debug Points [doris]

2023-12-13 Thread via GitHub


HowardQin opened a new pull request, #28347:
URL: https://github.com/apache/doris/pull/28347

   Update docs about Debug Points
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [feture](Nereids) support delete from without using [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28083:
URL: https://github.com/apache/doris/pull/28083#issuecomment-1853555476

   (From new machine)TeamCity pipeline, clickbench performance test result:
the sum of best hot time: 44.55 seconds
stream load tsv:  589 seconds loaded 74807831229 Bytes, about 121 
MB/s
stream load json: 19 seconds loaded 2358488459 Bytes, about 118 MB/s
stream load orc:  66 seconds loaded 1101869774 Bytes, about 15 MB/s
stream load parquet:  31 seconds loaded 861443392 Bytes, about 26 
MB/s
insert into select:  28.4 seconds inserted 1000 Rows, about 
352K ops/s
storage size: 17219553876 Bytes


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [pipelineX](local shuffle) Support parallel execution despite of tablet number [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28266:
URL: https://github.com/apache/doris/pull/28266#issuecomment-1853555937

   (From new machine)TeamCity pipeline, clickbench performance test result:
the sum of best hot time: 45.28 seconds
stream load tsv:  587 seconds loaded 74807831229 Bytes, about 121 
MB/s
stream load json: 19 seconds loaded 2358488459 Bytes, about 118 MB/s
stream load orc:  67 seconds loaded 1101869774 Bytes, about 15 MB/s
stream load parquet:  31 seconds loaded 861443392 Bytes, about 26 
MB/s
insert into select:  29.0 seconds inserted 1000 Rows, about 
344K ops/s
storage size: 17219625311 Bytes


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](Variant Type) Fixes the desc failure [doris]

2023-12-13 Thread via GitHub


eldenmoon commented on PR #28343:
URL: https://github.com/apache/doris/pull/28343#issuecomment-1853557034

   add case


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [I] [Bug] show create table result doesn't match ddl when use three single-quota (''') [doris]

2023-12-13 Thread via GitHub


LemonLiTree commented on issue #28284:
URL: https://github.com/apache/doris/issues/28284#issuecomment-1853559855

   Mysql does not add escape characters, but keeps the same comment, and doris 
should be the same
   https://github.com/apache/doris/assets/109049295/01587707-9175-4ec7-9e22-503a01c37dce";>
   like this
   https://github.com/apache/doris/assets/109049295/f85af0f0-05de-4024-b286-d23adbd4aa1d";>
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



[PR] [feature](Nereids): put or expansion rule in cost base rewrite job [doris]

2023-12-13 Thread via GitHub


XieJiann opened a new pull request, #28348:
URL: https://github.com/apache/doris/pull/28348

   ## Proposed changes
   put or expansion rule in cost base rewrite job
   
   ## Further comments
   
   If this is a relatively large or complex change, kick off the discussion at 
[d...@doris.apache.org](mailto:d...@doris.apache.org) by explaining why you 
chose the solution you did and what alternatives you considered, etc...
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [Enhancement](Wal)Support dynamic wal space limit [doris]

2023-12-13 Thread via GitHub


mymeiyi commented on code in PR #27726:
URL: https://github.com/apache/doris/pull/27726#discussion_r1425088339


##
be/src/olap/wal_writer.h:
##
@@ -34,34 +34,28 @@ extern const uint32_t k_wal_magic_length;
 
 class WalWriter {
 public:
-explicit WalWriter(const std::string& file_name,
-   const std::shared_ptr& 
all_wal_disk_bytes,
-   const std::shared_ptr& cv);
+explicit WalWriter(const std::string& file_name);
 ~WalWriter();
 
 Status init();
 Status finalize();
 
 Status append_blocks(const PBlockArray& blocks);
-size_t disk_bytes() const { return 
_disk_bytes.load(std::memory_order_relaxed); };
 Status append_header(uint32_t version, std::string col_ids);
 
 std::string file_name() { return _file_name; };
+static std::string get_base_path(const std::string& wal_path);

Review Comment:
   Is this function unused?



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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [feature](merge-on-write) enable merge-on-write by default again [doris]

2023-12-13 Thread via GitHub


bobhan1 commented on PR #28105:
URL: https://github.com/apache/doris/pull/28105#issuecomment-1853569119

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [enhancement](compaction) Add support for limiting low priority compaction scheduling [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #27648:
URL: https://github.com/apache/doris/pull/27648#issuecomment-1853570299

   
   
   TPC-H test result on machine: 
'aliyun_ecs.c7a.8xlarge_32C64G'
   
   ```
   Tpch sf100 test result on commit 1be25552477fb12be3a8ec32a7eacd10de6e, 
data reload: false
   
   run tpch-sf100 query with default conf and session variables
   q1   50062   31808   31820   31808
   q2   377 134 137 134
   q3   1562125413191254
   q4   1106930 911 911
   q5   3202328432273227
   q6   261 155 142 142
   q7   1024493 478 478
   q8   2169220722032203
   q9   6973699769176917
   q10  3240328833073288
   q11  346 214 208 208
   q12  358 206 212 206
   q13  4585379737853785
   q14  429 327 322 322
   q15  762 131313241313
   q16  445 386 393 386
   q17  1026559 576 559
   q18  7677707272837072
   q19  1528130714761307
   q20  578 305 288 288
   q21  3037268826272627
   q22  344 278 279 278
   Total cold run time: 91091 ms
   Total hot run time: 68713 ms
   
   run tpch-sf100 query with default conf and set session variable 
runtime_filter_mode=off
   q1   30794   31828   31808   31808
   q2   277 164 175 164
   q3   3673364936563649
   q4   2403238423742374
   q5   5798578758025787
   q6   239 130 142 130
   q7   3067339433723372
   q8   3545353035333530
   q9   9211916691309130
   q10  3966407140674067
   q11  824 901 1366901
   q12  777 597 604 597
   q13  4298356835643564
   q14  528 444 444 444
   q15  1109130513481305
   q16  506 463 457 457
   q17  1883189018511851
   q18  8901830483858304
   q19  1741179017471747
   q20  2947261227172612
   q21  6516613561266126
   q22  507 409 406 406
   Total cold run time: 93510 ms
   Total hot run time: 92325 ms
   ```
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [Enhancement](Wal)Support dynamic wal space limit [doris]

2023-12-13 Thread via GitHub


mymeiyi commented on code in PR #27726:
URL: https://github.com/apache/doris/pull/27726#discussion_r1425092838


##
be/src/vec/sink/group_commit_block_sink.cpp:
##
@@ -200,9 +200,31 @@ Status GroupCommitBlockSink::_add_blocks() {
 load_id.__set_lo(_load_id.lo);
 if (_load_block_queue == nullptr) {
 if (_state->exec_env()->wal_mgr()->is_running()) {
+std::string wal_dir;
+auto* wal_mgr = ExecEnv::GetInstance()->wal_mgr();
+{
+std::unique_lock l(lock);
+auto map = wal_mgr->get_wal_dir_to_disk_usage_map();
+wal_dir = map.size() == 1

Review Comment:
   Abstract the select wal_dir to a method.
   Is it better to move this method into the while loop?



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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] investigate master tpch [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28331:
URL: https://github.com/apache/doris/pull/28331#issuecomment-1853583683

   (From new machine)TeamCity pipeline, clickbench performance test result:
the sum of best hot time: 44.77 seconds
stream load tsv:  581 seconds loaded 74807831229 Bytes, about 122 
MB/s
stream load json: 19 seconds loaded 2358488459 Bytes, about 118 MB/s
stream load orc:  66 seconds loaded 1101869774 Bytes, about 15 MB/s
stream load parquet:  32 seconds loaded 861443392 Bytes, about 25 
MB/s
insert into select:  28.6 seconds inserted 1000 Rows, about 
349K ops/s
storage size: 17220991494 Bytes


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](nereids)DOUBLE acos (DOUBLE x) returns the inverse cosine value of x… [doris]

2023-12-13 Thread via GitHub


penglele commented on code in PR #27403:
URL: https://github.com/apache/doris/pull/27403#discussion_r1425101767


##
fe/fe-core/src/main/java/org/apache/doris/common/util/LiteralUtils.java:
##
@@ -32,7 +32,9 @@
 public class LiteralUtils {
 
 public static String getStringValue(FloatLiteral literal) {
-if (literal.getType() == Type.TIME || literal.getType() == 
Type.TIMEV2) {
+if (Double.isNaN(literal.getValue())) {
+return "nan";

Review Comment:
   @morrySnow Do I change it as above, or do you change it?



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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [feture](Nereids) support delete from without using [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28083:
URL: https://github.com/apache/doris/pull/28083#issuecomment-1853586060

   
   
   TPC-H test result on machine: 
'aliyun_ecs.c7a.8xlarge_32C64G'
   
   ```
   Tpch sf100 test result on commit 5577d648a159a2db5b0343220265d87e6aac5338, 
data reload: false
   
   run tpch-sf100 query with default conf and session variables
   q1   50214   31819   31842   31819
   q2   371 136 143 136
   q3   1536122112011201
   q4   1110908 918 908
   q5   3232322532893225
   q6   262 145 149 145
   q7   1010500 483 483
   q8   2143221921812181
   q9   6948689769026897
   q10  3247329533053295
   q11  343 209 199 199
   q12  348 205 206 205
   q13  4552382237813781
   q14  437 317 327 317
   q15  763 130613421306
   q16  434 397 383 383
   q17  1012568 609 568
   q18  7374729269336933
   q19  2693131814441318
   q20  1425346 306 306
   q21  3065267226662666
   q22  350 284 291 284
   Total cold run time: 92869 ms
   Total hot run time: 68556 ms
   
   run tpch-sf100 query with default conf and set session variable 
runtime_filter_mode=off
   q1   30825   31854   31806   31806
   q2   276 164 175 164
   q3   3691362035943594
   q4   2376236123502350
   q5   5780579557935793
   q6   239 142 129 129
   q7   3049341633653365
   q8   3536352135263521
   q9   9184913891729138
   q10  3979406940504050
   q11  840 887 1378887
   q12  774 585 599 585
   q13  4328357835653565
   q14  487 454 458 454
   q15  1107134313271327
   q16  512 456 466 456
   q17  1874183418431834
   q18  8963897982448244
   q19  1758176117451745
   q20  2938260027142600
   q21  6545614361396139
   q22  501 415 427 415
   Total cold run time: 93562 ms
   Total hot run time: 92161 ms
   ```
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



[PR] [fix](Nereids) multi_distinct_sum should inherit NullableAggregateFunction [doris]

2023-12-13 Thread via GitHub


morrySnow opened a new pull request, #28349:
URL: https://github.com/apache/doris/pull/28349

   ## Proposed changes
   
   Issue Number: close #xxx
   
   
   
   ## Further comments
   
   If this is a relatively large or complex change, kick off the discussion at 
[d...@doris.apache.org](mailto:d...@doris.apache.org) by explaining why you 
chose the solution you did and what alternatives you considered, etc...
   
   


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [bug](fix) show create table show comment error [doris]

2023-12-13 Thread via GitHub


LemonLiTree commented on PR #28346:
URL: https://github.com/apache/doris/pull/28346#issuecomment-1853586983

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](Nereids) multi_distinct_sum should inherit NullableAggregateFunction [doris]

2023-12-13 Thread via GitHub


morrySnow commented on PR #28349:
URL: https://github.com/apache/doris/pull/28349#issuecomment-1853587060

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] investigate master tpch [doris]

2023-12-13 Thread via GitHub


doris-robot commented on PR #28330:
URL: https://github.com/apache/doris/pull/28330#issuecomment-1853590514

   (From new machine)TeamCity pipeline, clickbench performance test result:
the sum of best hot time: 45.69 seconds
stream load tsv:  580 seconds loaded 74807831229 Bytes, about 123 
MB/s
stream load json: 19 seconds loaded 2358488459 Bytes, about 118 MB/s
stream load orc:  66 seconds loaded 1101869774 Bytes, about 15 MB/s
stream load parquet:  31 seconds loaded 861443392 Bytes, about 26 
MB/s
insert into select:  29.1 seconds inserted 1000 Rows, about 
343K ops/s
storage size: 17219779267 Bytes


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] Update cron-deploy-website.yml [doris-website]

2023-12-13 Thread via GitHub


jeffreys-cat closed pull request #253: Update cron-deploy-website.yml
URL: https://github.com/apache/doris-website/pull/253


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Re: [PR] [fix](Variant Type) Fixes the desc failure [doris]

2023-12-13 Thread via GitHub


csun5285 commented on PR #28343:
URL: https://github.com/apache/doris/pull/28343#issuecomment-1853594285

   run buildall


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

To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org

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


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



(doris) branch master updated (ac262fa176e -> 62859f38c13)

2023-12-13 Thread kxiao
This is an automated email from the ASF dual-hosted git repository.

kxiao pushed a change to branch master
in repository https://gitbox.apache.org/repos/asf/doris.git


from ac262fa176e [fix](partial update) Fix session variable 
`enable_unique_key_partial_update` will affect the behavior of insert statement 
when the target table is not unique table (#28321)
 add 62859f38c13 [fix](nereids)cast string to integer type use wrong 
datatype's valueOf method (#28174)

No new revisions were added by this update.

Summary of changes:
 .../doris/nereids/trees/expressions/literal/Literal.java  |  6 +++---
 .../doris/nereids/rules/expression/FoldConstantTest.java  |  4 ++--
 .../sql_functions/cast_function/test_cast_function.out| 15 ---
 .../sql_functions/cast_function/test_cast_function.groovy |  5 -
 4 files changed, 21 insertions(+), 9 deletions(-)


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



Error while running github feature from .asf.yaml in doris!

2023-12-13 Thread Apache Infrastructure


An error occurred while running github feature in .asf.yaml!:
You can only have a maximum of 10 external triage collaborators, please contact 
vp-in...@apache.org to request an exception.


-
To unsubscribe, e-mail: commits-unsubscr...@doris.apache.org
For additional commands, e-mail: commits-h...@doris.apache.org



  1   2   3   4   5   6   7   8   >