[GitHub] [doris] 924060929 commented on a diff in pull request #11454: [feature](nereids) Convert subqueries into algebraic expressions and …

2022-08-03 Thread GitBox


924060929 commented on code in PR #11454:
URL: https://github.com/apache/doris/pull/11454#discussion_r936235006


##
fe/fe-core/src/main/java/org/apache/doris/nereids/rules/analysis/AnalyzeSubquery.java:
##
@@ -0,0 +1,172 @@
+// 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.nereids.rules.analysis;
+
+import org.apache.doris.nereids.PlannerContext;
+import org.apache.doris.nereids.rules.Rule;
+import org.apache.doris.nereids.rules.RuleType;
+import org.apache.doris.nereids.trees.expressions.BooleanLiteral;
+import org.apache.doris.nereids.trees.expressions.Exists;
+import org.apache.doris.nereids.trees.expressions.Expression;
+import org.apache.doris.nereids.trees.expressions.InSubquery;
+import org.apache.doris.nereids.trees.expressions.ScalarSubquery;
+import org.apache.doris.nereids.trees.expressions.Slot;
+import org.apache.doris.nereids.trees.expressions.SubqueryExpr;
+import org.apache.doris.nereids.trees.plans.GroupPlan;
+import org.apache.doris.nereids.trees.plans.JoinType;
+import org.apache.doris.nereids.trees.plans.logical.LogicalAggregate;
+import org.apache.doris.nereids.trees.plans.logical.LogicalApply;
+import org.apache.doris.nereids.trees.plans.logical.LogicalCorrelatedJoin;
+import org.apache.doris.nereids.trees.plans.logical.LogicalEnforceSingleRow;
+import org.apache.doris.nereids.trees.plans.logical.LogicalFilter;
+import org.apache.doris.nereids.trees.plans.logical.LogicalPlan;
+import org.apache.doris.nereids.trees.plans.logical.LogicalProject;
+import org.apache.doris.nereids.trees.plans.logical.LogicalSort;
+
+import com.google.common.collect.ImmutableList;
+import com.google.common.collect.ImmutableList.Builder;
+
+import java.util.ArrayList;
+import java.util.List;
+import java.util.Optional;
+
+/**
+ * AnalyzeSubquery. translate from subquery to apply/correlatedJoin.
+ */
+public class AnalyzeSubquery implements AnalysisRuleFactory {
+@Override
+public List buildRules() {
+return ImmutableList.of(
+RuleType.ANALYZE_PROJECT_SUBQUERY.build(
+logicalProject().thenApply(ctx -> {
+LogicalProject project = ctx.root;
+List subqueryExprs = new 
ArrayList<>();
+project.getProjects()
+.forEach(expr -> 
subqueryExprs.addAll(extractSubquery(expr)));
+if (subqueryExprs.size() == 0) {
+return project;
+}
+return new LogicalProject(project.getProjects(),
+analyzedSubquery(subqueryExprs,
+project.child(), 
ctx.plannerContext));
+})
+),
+RuleType.ANALYZE_FILTER_SUBQUERY.build(
+logicalFilter().thenApply(ctx -> {
+LogicalFilter filter = ctx.root;
+List subqueryExprs = 
extractSubquery(filter.getPredicates());
+if (subqueryExprs.size() == 0) {
+return filter;
+}
+return new LogicalFilter<>(filter.getPredicates(),
+analyzedSubquery(subqueryExprs,
+filter.child(), 
ctx.plannerContext));
+})
+),
+RuleType.ANALYZE_AGGREGATE_SUBQUERY.build(
+logicalAggregate().thenApply(ctx -> {
+LogicalAggregate agg = ctx.root;
+List subqueryExprs = new 
ArrayList<>();
+agg.getGroupByExpressions().forEach(expr -> 
subqueryExprs.addAll(extractSubquery(expr)));
+agg.getOutputExpressions().forEach(expr -> 
subqueryExprs.addAll(extractSubquery(expr)));
+if (subqueryExprs.size() == 0) {
+return agg;
+}
+return new 
LogicalAggregate<>(

[GitHub] [doris] 924060929 commented on a diff in pull request #11454: [feature](nereids) Convert subqueries into algebraic expressions and …

2022-08-03 Thread GitBox


924060929 commented on code in PR #11454:
URL: https://github.com/apache/doris/pull/11454#discussion_r936309072


##
fe/fe-core/src/main/java/org/apache/doris/nereids/rules/analysis/Scope.java:
##
@@ -50,6 +55,15 @@ public Optional getOuterScope() {
 return outerScope;
 }
 
+public boolean hasSlot(Slot slot) {
+return checkSlots.contains(slot);
+}
+
+public void addSlot(Slot slot) {

Review Comment:
   and checkSlots can rename to slotSet



-- 
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



[GitHub] [doris] 924060929 commented on a diff in pull request #11454: [feature](nereids) Convert subqueries into algebraic expressions and …

2022-08-03 Thread GitBox


924060929 commented on code in PR #11454:
URL: https://github.com/apache/doris/pull/11454#discussion_r936235006


##
fe/fe-core/src/main/java/org/apache/doris/nereids/rules/analysis/AnalyzeSubquery.java:
##
@@ -0,0 +1,172 @@
+// 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.nereids.rules.analysis;
+
+import org.apache.doris.nereids.PlannerContext;
+import org.apache.doris.nereids.rules.Rule;
+import org.apache.doris.nereids.rules.RuleType;
+import org.apache.doris.nereids.trees.expressions.BooleanLiteral;
+import org.apache.doris.nereids.trees.expressions.Exists;
+import org.apache.doris.nereids.trees.expressions.Expression;
+import org.apache.doris.nereids.trees.expressions.InSubquery;
+import org.apache.doris.nereids.trees.expressions.ScalarSubquery;
+import org.apache.doris.nereids.trees.expressions.Slot;
+import org.apache.doris.nereids.trees.expressions.SubqueryExpr;
+import org.apache.doris.nereids.trees.plans.GroupPlan;
+import org.apache.doris.nereids.trees.plans.JoinType;
+import org.apache.doris.nereids.trees.plans.logical.LogicalAggregate;
+import org.apache.doris.nereids.trees.plans.logical.LogicalApply;
+import org.apache.doris.nereids.trees.plans.logical.LogicalCorrelatedJoin;
+import org.apache.doris.nereids.trees.plans.logical.LogicalEnforceSingleRow;
+import org.apache.doris.nereids.trees.plans.logical.LogicalFilter;
+import org.apache.doris.nereids.trees.plans.logical.LogicalPlan;
+import org.apache.doris.nereids.trees.plans.logical.LogicalProject;
+import org.apache.doris.nereids.trees.plans.logical.LogicalSort;
+
+import com.google.common.collect.ImmutableList;
+import com.google.common.collect.ImmutableList.Builder;
+
+import java.util.ArrayList;
+import java.util.List;
+import java.util.Optional;
+
+/**
+ * AnalyzeSubquery. translate from subquery to apply/correlatedJoin.
+ */
+public class AnalyzeSubquery implements AnalysisRuleFactory {
+@Override
+public List buildRules() {
+return ImmutableList.of(
+RuleType.ANALYZE_PROJECT_SUBQUERY.build(
+logicalProject().thenApply(ctx -> {
+LogicalProject project = ctx.root;
+List subqueryExprs = new 
ArrayList<>();
+project.getProjects()
+.forEach(expr -> 
subqueryExprs.addAll(extractSubquery(expr)));
+if (subqueryExprs.size() == 0) {
+return project;
+}
+return new LogicalProject(project.getProjects(),
+analyzedSubquery(subqueryExprs,
+project.child(), 
ctx.plannerContext));
+})
+),
+RuleType.ANALYZE_FILTER_SUBQUERY.build(
+logicalFilter().thenApply(ctx -> {
+LogicalFilter filter = ctx.root;
+List subqueryExprs = 
extractSubquery(filter.getPredicates());
+if (subqueryExprs.size() == 0) {
+return filter;
+}
+return new LogicalFilter<>(filter.getPredicates(),
+analyzedSubquery(subqueryExprs,
+filter.child(), 
ctx.plannerContext));
+})
+),
+RuleType.ANALYZE_AGGREGATE_SUBQUERY.build(
+logicalAggregate().thenApply(ctx -> {
+LogicalAggregate agg = ctx.root;
+List subqueryExprs = new 
ArrayList<>();
+agg.getGroupByExpressions().forEach(expr -> 
subqueryExprs.addAll(extractSubquery(expr)));
+agg.getOutputExpressions().forEach(expr -> 
subqueryExprs.addAll(extractSubquery(expr)));
+if (subqueryExprs.size() == 0) {
+return agg;
+}
+return new 
LogicalAggregate<>(

[GitHub] [doris] weizuo93 opened a new pull request, #11457: [Bug] Fix bug that http server should not be stoped when destruction if it not running

2022-08-03 Thread GitBox


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

   # Proposed changes
   
   Issue Number: close #xxx
   
   ## Problem summary
   
   Http server should not be stoped when destruction if it not running .
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [x] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [ ] No
   - [x] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [ ] No
   - [x] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [x] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [x] No
   
   


-- 
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



[GitHub] [doris] 924060929 commented on a diff in pull request #11454: [feature](nereids) Convert subqueries into algebraic expressions and …

2022-08-03 Thread GitBox


924060929 commented on code in PR #11454:
URL: https://github.com/apache/doris/pull/11454#discussion_r936291379


##
fe/fe-core/src/main/java/org/apache/doris/nereids/rules/analysis/BindSlotReference.java:
##
@@ -156,7 +179,12 @@ public Expression visitUnboundAlias(UnboundAlias 
unboundAlias, Void context) {
 }
 
 @Override
-public Slot visitUnboundSlot(UnboundSlot unboundSlot, Void context) {
+public Slot visitUnboundSlot(UnboundSlot unboundSlot, PlannerContext 
context) {
+List tmpBound = bindSlot(unboundSlot, getScope().getSlots());
+boolean hasCorrelate = false;
+if (tmpBound.size() == 0) {
+hasCorrelate = true;
+}
 Optional> boundedOpt = getScope()

Review Comment:
   why compute bind slot in thisScope again, I think it should be
   ```java
   if (!foundInThisScope && getScope.getOuterScope().isPresent()) {
  Optional> boundedOpt = getScope()
   .getParentScope()
   .get()
   .toScopeLink()
   .stream()
   ...
   }
   ```



##
fe/fe-core/src/main/java/org/apache/doris/nereids/rules/analysis/BindSlotReference.java:
##
@@ -156,7 +179,12 @@ public Expression visitUnboundAlias(UnboundAlias 
unboundAlias, Void context) {
 }
 
 @Override
-public Slot visitUnboundSlot(UnboundSlot unboundSlot, Void context) {
+public Slot visitUnboundSlot(UnboundSlot unboundSlot, PlannerContext 
context) {
+List tmpBound = bindSlot(unboundSlot, getScope().getSlots());
+boolean hasCorrelate = false;
+if (tmpBound.size() == 0) {
+hasCorrelate = true;
+}
 Optional> boundedOpt = getScope()

Review Comment:
   why compute bind slot in thisScope again, I think it should be
   ```java
   if (!foundInThisScope && getScope.getOuterScope().isPresent()) {
  Optional> boundedOpt = getScope()
   .getOuterScope()
   .get()
   .toScopeLink()
   .stream()
   ...
   }
   ```



-- 
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



[GitHub] [doris] github-actions[bot] commented on pull request #11246: [WIP](optional) using hash set to distinct single value

2022-08-03 Thread GitBox


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

   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



[GitHub] [doris] github-actions[bot] commented on pull request #11456: [doc](schema change) Correct Schema Change error description

2022-08-03 Thread GitBox


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

   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



[GitHub] [doris] luozenglin opened a new pull request, #11458: [enhancement](tracing) append the profile counter to trace.

2022-08-03 Thread GitBox


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

   1. append the profile counter and infos to span attributes.
   2. output traceid to audit log.
   
   # Proposed changes
   
   Issue Number: close #xxx
   DSIP: 
https://cwiki.apache.org/confluence/display/DORIS/DSIP-012%3A+Introduce+opentelemetry
   
   ## Problem summary
   
   Describe your changes.
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [x] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [ ] No
   - [x] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [x] No
   - [ ] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [x] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [x] No
   
   ## 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



[GitHub] [doris] morrySnow opened a new pull request, #11459: [enhancement](Nereids)set default join type to CROSS_JOIN

2022-08-03 Thread GitBox


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

   # Proposed changes
   
   set default join type to CROSS_JOIN on join that has no equal on condition 
when parse sql string.
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [x] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [ ] No
   - [x] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [x] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [x] No
   
   ## 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



[GitHub] [doris] HappenLee commented on pull request #10792: [Feature][Materialized-View] support materialized view on vectorized engine

2022-08-03 Thread GitBox


HappenLee commented on PR #10792:
URL: https://github.com/apache/doris/pull/10792#issuecomment-1203622387

   LGTM


-- 
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



[GitHub] [doris] github-actions[bot] commented on pull request #10792: [Feature][Materialized-View] support materialized view on vectorized engine

2022-08-03 Thread GitBox


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

   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



[GitHub] [doris] github-actions[bot] commented on pull request #10792: [Feature][Materialized-View] support materialized view on vectorized engine

2022-08-03 Thread GitBox


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

   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



[GitHub] [doris] starocean999 opened a new pull request, #11461: [improvement](agg)limit the output of agg node

2022-08-03 Thread GitBox


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

   # Proposed changes
   
   Issue Number: close #xxx
   
   ## Problem summary
   The limit operation can be done at agg node instead of last topN node. This 
can reduce the time cost to 1/3 of the old one. The sql is as bellow:
   SELECT UserID, SearchPhrase, COUNT(*) FROM hits GROUP BY UserID, 
SearchPhrase LIMIT 10;
   
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [ ] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [ ] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [ ] No
   
   ## 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



[GitHub] [doris] BiteTheDDDDt opened a new issue, #11462: [Bug] window function meet failed analysis after expr substitution

2022-08-03 Thread GitBox


BiteThet opened a new issue, #11462:
URL: https://github.com/apache/doris/issues/11462

   ### Search before asking
   
   - [X] I had searched in the 
[issues](https://github.com/apache/incubator-doris/issues?q=is%3Aissue) and 
found no similar issues.
   
   
   ### Version
   
   master
   
   ### What's Wrong?
   
   ```sql
   select k6, k3, first_value(k3) over (partition by k6 order by k3 range   
  between current row and unbounded following) from baseall order by k6, k3;
   ```
   
   ```java
   java.lang.IllegalStateException: Failed analysis after expr substitution.
at org.apache.doris.analysis.Expr.substituteList(Expr.java:748) 
~[doris-fe.jar:1.0-SNAPSHOT]
at 
org.apache.doris.analysis.AnalyticInfo.materializeRequiredSlots(AnalyticInfo.java:172)
 ~[doris-fe.jar:1.0-SNAPSHOT]
at 
org.apache.doris.analysis.SelectStmt.materializeRequiredSlots(SelectStmt.java:694)
 ~[doris-fe.jar:1.0-SNAPSHOT]
at 
org.apache.doris.planner.SingleNodePlanner.createSelectPlan(SingleNodePlanner.java:963)
 ~[doris-fe.jar:1.0-SNAPSHOT]
at 
org.apache.doris.planner.SingleNodePlanner.createQueryPlan(SingleNodePlanner.java:240)
 ~[doris-fe.jar:1.0-SNAPSHOT]
at 
org.apache.doris.planner.SingleNodePlanner.createSingleNodePlan(SingleNodePlanner.java:169)
 ~[doris-fe.jar:1.0-SNAPSHOT]
at 
org.apache.doris.planner.OriginalPlanner.createPlanFragments(OriginalPlanner.java:142)
 ~[doris-fe.jar:1.0-SNAPSHOT]
at 
org.apache.doris.planner.OriginalPlanner.plan(OriginalPlanner.java:85) 
~[doris-fe.jar:1.0-SNAPSHOT]
at 
org.apache.doris.qe.StmtExecutor.analyzeAndGenerateQueryPlan(StmtExecutor.java:786)
 ~[doris-fe.jar:1.0-SNAPSHOT]
at org.apache.doris.qe.StmtExecutor.analyze(StmtExecutor.java:636) 
~[doris-fe.jar:1.0-SNAPSHOT]
at org.apache.doris.qe.StmtExecutor.execute(StmtExecutor.java:368) 
~[doris-fe.jar:1.0-SNAPSHOT]
at org.apache.doris.qe.StmtExecutor.execute(StmtExecutor.java:334) 
~[doris-fe.jar:1.0-SNAPSHOT]
at 
org.apache.doris.qe.ConnectProcessor.handleQuery(ConnectProcessor.java:227) 
~[doris-fe.jar:1.0-SNAPSHOT]
at 
org.apache.doris.qe.ConnectProcessor.dispatch(ConnectProcessor.java:361) 
~[doris-fe.jar:1.0-SNAPSHOT]
at 
org.apache.doris.qe.ConnectProcessor.processOnce(ConnectProcessor.java:556) 
~[doris-fe.jar:1.0-SNAPSHOT]
at 
org.apache.doris.mysql.nio.ReadListener.lambda$handleEvent$0(ReadListener.java:52)
 ~[doris-fe.jar:1.0-SNAPSHOT]
at 
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1128) 
~[?:?]
at 
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:628) 
~[?:?]
at java.lang.Thread.run(Thread.java:829) ~[?:?]
   Caused by: org.apache.doris.common.AnalysisException: errCode = 2, 
detailMessage = RANGE is only supported with both the lower and upper bounds 
UNBOUNDED or one UNBOUNDED and the other CURRENT ROW.
at 
org.apache.doris.analysis.AnalyticWindow.analyze(AnalyticWindow.java:485) 
~[doris-fe.jar:1.0-SNAPSHOT]
at 
org.apache.doris.analysis.AnalyticExpr.analyzeImpl(AnalyticExpr.java:552) 
~[doris-fe.jar:1.0-SNAPSHOT]
at org.apache.doris.analysis.Expr.analyze(Expr.java:418) 
~[doris-fe.jar:1.0-SNAPSHOT]
at org.apache.doris.analysis.Expr.trySubstitute(Expr.java:700) 
~[doris-fe.jar:1.0-SNAPSHOT]
at org.apache.doris.analysis.Expr.trySubstituteList(Expr.java:737) 
~[doris-fe.jar:1.0-SNAPSHOT]
at org.apache.doris.analysis.Expr.substituteList(Expr.java:746) 
~[doris-fe.jar:1.0-SNAPSHOT]
... 18 more
   ```
   
   ### What You Expected?
   
   fix
   
   ### How to Reproduce?
   
   _No response_
   
   ### Anything Else?
   
   _No response_
   
   ### Are you willing to submit PR?
   
   - [ ] Yes I am willing to submit a PR!
   
   ### Code of Conduct
   
   - [X] I agree to follow this project's [Code of 
Conduct](https://www.apache.org/foundation/policies/conduct)
   


-- 
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.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



[GitHub] [doris] jacktengg commented on pull request #11454: [feature](nereids) Convert subqueries into algebraic expressions and …

2022-08-03 Thread GitBox


jacktengg commented on PR #11454:
URL: https://github.com/apache/doris/pull/11454#issuecomment-1203639233

   Please rebase master to re-run P0 test


-- 
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



[GitHub] [doris] adonis0147 commented on a diff in pull request #11459: [enhancement](Nereids)set default join type to CROSS_JOIN

2022-08-03 Thread GitBox


adonis0147 commented on code in PR #11459:
URL: https://github.com/apache/doris/pull/11459#discussion_r936397601


##
fe/fe-core/src/main/java/org/apache/doris/nereids/parser/LogicalPlanBuilder.java:
##
@@ -584,7 +584,7 @@ public LogicalPlan visitFromClause(FromClauseContext ctx) {
 LogicalPlan right = plan(relation.relationPrimary());
 left = left == null

Review Comment:
   Add parentheses to improve readability.
   
   ```suggestion
   left = (left == null)
   ```



-- 
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



[GitHub] [doris] BiteTheDDDDt opened a new pull request, #11463: [Bug](function) fix current_date not equal to curdate

2022-08-03 Thread GitBox


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

   # Proposed changes
   
   Issue Number: close #11451
   
   ## Problem summary
   
   Describe your changes.
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [X] Yes
   - [ ] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [X] Yes
   - [ ] No
   - [ ] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [ ] No
   - [X] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [X] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [X] No
   
   ## 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



[doris-thirdparty] branch bdbje created (now 284830b)

2022-08-03 Thread yangzhg
This is an automated email from the ASF dual-hosted git repository.

yangzhg pushed a change to branch bdbje
in repository https://gitbox.apache.org/repos/asf/doris-thirdparty.git


  at 284830b  patch bdbje

This branch includes the following new commits:

 new 2d31276  initial commit
 new 040649b  init origin source
 new 284830b  patch bdbje

The 3 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.



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



[doris-thirdparty] 01/03: initial commit

2022-08-03 Thread yangzhg
This is an automated email from the ASF dual-hosted git repository.

yangzhg pushed a commit to branch bdbje
in repository https://gitbox.apache.org/repos/asf/doris-thirdparty.git

commit 2d3127627b87d5d39a17e3f7ca6867bb7116aedf
Author: Zhengguo Yang 
AuthorDate: Wed Aug 3 13:36:42 2022 +0800

initial commit
---
 LICENSE.txt | 749 
 README.md   |  29 +++
 2 files changed, 778 insertions(+)

diff --git a/LICENSE.txt b/LICENSE.txt
new file mode 100644
index 000..5c9c62d
--- /dev/null
+++ b/LICENSE.txt
@@ -0,0 +1,749 @@
+ Apache License
+   Version 2.0, January 2004
+http://www.apache.org/licenses/
+
+   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
+
+   1. Definitions.
+
+  "License" shall mean the terms and conditions for use, reproduction,
+  and distribution as defined by Sections 1 through 9 of this document.
+
+  "Licensor" shall mean the copyright owner or entity authorized by
+  the copyright owner that is granting the License.
+
+  "Legal Entity" shall mean the union of the acting entity and all
+  other entities that control, are controlled by, or are under common
+  control with that entity. For the purposes of this definition,
+  "control" means (i) the power, direct or indirect, to cause the
+  direction or management of such entity, whether by contract or
+  otherwise, or (ii) ownership of fifty percent (50%) or more of the
+  outstanding shares, or (iii) beneficial ownership of such entity.
+
+  "You" (or "Your") shall mean an individual or Legal Entity
+  exercising permissions granted by this License.
+
+  "Source" form shall mean the preferred form for making modifications,
+  including but not limited to software source code, documentation
+  source, and configuration files.
+
+  "Object" form shall mean any form resulting from mechanical
+  transformation or translation of a Source form, including but
+  not limited to compiled object code, generated documentation,
+  and conversions to other media types.
+
+  "Work" shall mean the work of authorship, whether in Source or
+  Object form, made available under the License, as indicated by a
+  copyright notice that is included in or attached to the work
+  (an example is provided in the Appendix below).
+
+  "Derivative Works" shall mean any work, whether in Source or Object
+  form, that is based on (or derived from) the Work and for which the
+  editorial revisions, annotations, elaborations, or other modifications
+  represent, as a whole, an original work of authorship. For the purposes
+  of this License, Derivative Works shall not include works that remain
+  separable from, or merely link (or bind by name) to the interfaces of,
+  the Work and Derivative Works thereof.
+
+  "Contribution" shall mean any work of authorship, including
+  the original version of the Work and any modifications or additions
+  to that Work or Derivative Works thereof, that is intentionally
+  submitted to Licensor for inclusion in the Work by the copyright owner
+  or by an individual or Legal Entity authorized to submit on behalf of
+  the copyright owner. For the purposes of this definition, "submitted"
+  means any form of electronic, verbal, or written communication sent
+  to the Licensor or its representatives, including but not limited to
+  communication on electronic mailing lists, source code control systems,
+  and issue tracking systems that are managed by, or on behalf of, the
+  Licensor for the purpose of discussing and improving the Work, but
+  excluding communication that is conspicuously marked or otherwise
+  designated in writing by the copyright owner as "Not a Contribution."
+
+  "Contributor" shall mean Licensor and any individual or Legal Entity
+  on behalf of whom a Contribution has been received by Licensor and
+  subsequently incorporated within the Work.
+
+   2. Grant of Copyright License. Subject to the terms and conditions of
+  this License, each Contributor hereby grants to You a perpetual,
+  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+  copyright license to reproduce, prepare Derivative Works of,
+  publicly display, publicly perform, sublicense, and distribute the
+  Work and such Derivative Works in Source or Object form.
+
+   3. Grant of Patent License. Subject to the terms and conditions of
+  this License, each Contributor hereby grants to You a perpetual,
+  worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+  (except as stated in this section) patent license to make, have made,
+  use, offer to sell, sell, import, and otherwise transfer the Work,
+  where such license applies only to those paten

[doris-thirdparty] 03/03: patch bdbje

2022-08-03 Thread yangzhg
This is an automated email from the ASF dual-hosted git repository.

yangzhg pushed a commit to branch bdbje
in repository https://gitbox.apache.org/repos/asf/doris-thirdparty.git

commit 284830b22b0dc8cefbeef81c3002e97faa2dff01
Author: Zhengguo Yang 
AuthorDate: Wed Aug 3 17:09:09 2022 +0800

patch bdbje
---
 .gitignore|  84 
 README.md |   5 +
 pom.xml   | 190 ++
 src/com/sleepycat/je/dbi/EnvironmentImpl.java |   4 +
 src/com/sleepycat/je/log/LogManager.java  |   3 +
 src/com/sleepycat/je/rep/impl/RepImpl.java|   5 +
 src/com/sleepycat/je/rep/vlsn/VLSNIndex.java  |  20 ++-
 7 files changed, 309 insertions(+), 2 deletions(-)

diff --git a/.gitignore b/.gitignore
new file mode 100644
index 000..e9e224c
--- /dev/null
+++ b/.gitignore
@@ -0,0 +1,84 @@
+##
+## Java
+##
+.mtj.tmp/
+*.class
+*.jar
+*.war
+*.ear
+*.nar
+hs_err_pid*
+
+##
+## Maven
+##
+target/
+pom.xml.tag
+pom.xml.releaseBackup
+pom.xml.versionsBackup
+pom.xml.next
+pom.xml.bak
+release.properties
+dependency-reduced-pom.xml
+buildNumber.properties
+.mvn/timing.properties
+.mvn/wrapper/maven-wrapper.jar
+
+##
+## Gradle
+##
+bin/
+build/
+.gradle
+.gradletasknamecache
+gradle-app.setting
+!gradle-wrapper.jar
+
+##
+## IntelliJ
+##
+out/
+.idea/
+.idea_modules/
+*.iml
+*.ipr
+*.iws
+
+##
+## Eclipse
+##
+.settings/
+bin/
+tmp/
+.metadata
+.classpath
+.project
+*.tmp
+*.bak
+*.swp
+*~.nib
+local.properties
+.loadpath
+.factorypath
+
+##
+## NetBeans
+##
+nbproject/private/
+build/
+nbbuild/
+dist/
+nbdist/
+nbactions.xml
+nb-configuration.xml
+
+##
+## Visual Studio Code
+##
+.vscode/
+.code-workspace
+
+##
+## OS X
+##
+.DS_Store
\ No newline at end of file
diff --git a/README.md b/README.md
index 6b446cb..14f209d 100644
--- a/README.md
+++ b/README.md
@@ -27,3 +27,8 @@ Berkley Database Java Edition - build and runtime support.
 | Source code  | 
http://www.oracle.com/technetwork/database/database-technologies/nosqldb/downloads/index.html
 |
 | Organization | Oracle Corporation   |
 | Developers   | Oracle Corporation   |
+
+# Alternatives
+
+A fork of com.sleepycat:je:18.3.12 from 
[bdbje](https://repo1.maven.org/maven2/com/sleepycat/je/18.3.12/je-18.3.12-sources.jar),
 Applied patches from [StarRocks bdbje](https://github.com/StarRocks/bdb-je/).
+Because of  StarRocks bdbje based on version 7.x, Apache Doris use bdbje  base 
on version 18.x.  So cannot use StarRocks bdb-je directly.
diff --git a/pom.xml b/pom.xml
new file mode 100644
index 000..c377413
--- /dev/null
+++ b/pom.xml
@@ -0,0 +1,190 @@
+
+http://maven.apache.org/POM/4.0.0";
+ xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance";
+ xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 
http://maven.apache.org/xsd/maven-4.0.0.xsd";>
+4.0.0
+
+org.apache
+apache
+23
+
+org.apache.doris
+je
+18.3.12-doris
+bdb-je apache doris release
+https://doris.apache.org/
+fork from bdb-je 18.3.12 from maven with starrocks bdbje 
patches
+
+
+Apache 2.0 License
+https://www.apache.org/licenses/LICENSE-2.0.html
+repo
+
+
+
+
scm:git:https://g...@github.com/apache/doris-thirdparty.git
+
scm:git:https://g...@github.com/apache/doris-thirdparty.git
+scm:git:https://g...@github.com/apache/doris-thirdparty.git
+HEAD
+
+
+GitHub
+https://github.com/apache/doris/issues
+
+
+
+Dev Mailing List
+d...@doris.apache.org
+dev-subscr...@doris.apache.org
+dev-unsubscr...@doris.apache.org
+
+
+Commits Mailing List
+commits@doris.apache.org
+commits-subscr...@doris.apache.org
+commits-unsubscr...@doris.apache.org
+
+
+
+
+javax.resource
+connector
+1.0
+
+
+org.apache.ant
+ant
+1.10.12
+
+
+org.checkerframework
+checker
+3.22.2
+
+
+org.checkerframework
+checker-qual
+3.22.2
+
+
+sun.jdk
+jconsole
+jdk
+system
+${java.home}/../lib/j

[GitHub] [doris] BiteTheDDDDt commented on issue #11462: [Bug] window function meet failed analysis after expr substitution

2022-08-03 Thread GitBox


BiteThet commented on issue #11462:
URL: https://github.com/apache/doris/issues/11462#issuecomment-1203689193

   the reason is this usage not supported, I add some message on #11463


-- 
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



[GitHub] [doris] BiteTheDDDDt closed issue #11462: [Bug] window function meet failed analysis after expr substitution

2022-08-03 Thread GitBox


BiteThet closed issue #11462: [Bug] window function meet failed analysis 
after expr substitution
URL: https://github.com/apache/doris/issues/11462


-- 
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-thirdparty] annotated tag libhdfs3-v2.3.1 updated (ebf8bd2 -> 0dce8d6)

2022-08-03 Thread yangzhg
This is an automated email from the ASF dual-hosted git repository.

yangzhg pushed a change to annotated tag libhdfs3-v2.3.1
in repository https://gitbox.apache.org/repos/asf/doris-thirdparty.git


*** WARNING: tag libhdfs3-v2.3.1 was modified! ***

from ebf8bd2  (commit)
  to 0dce8d6  (tag)
 tagging ebf8bd21a573918442f656eece99b73f2d1c4dc0 (commit)
  by Zhengguo Yang
  on Wed Aug 3 17:13:50 2022 +0800

- Log -
release libhdfs3 v2.3.1
---


No new revisions were added by this update.

Summary of changes:


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



[GitHub] [doris] yiguolei merged pull request #11401: [Improvement](datev2) apply time LUT to datev2/datetimev2

2022-08-03 Thread GitBox


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


-- 
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: [Improvement](datev2) apply time LUT to datev2/datetimev2 (#11401)

2022-08-03 Thread yiguolei
This is an automated email from the ASF dual-hosted git repository.

yiguolei 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 e1b878fe10 [Improvement](datev2) apply time LUT to datev2/datetimev2 
(#11401)
e1b878fe10 is described below

commit e1b878fe1081784b4d166d1af9796a39ded18fb6
Author: Gabriel 
AuthorDate: Wed Aug 3 17:15:09 2022 +0800

[Improvement](datev2) apply time LUT to datev2/datetimev2 (#11401)

* [Improvement](datev2) apply time LUT to datev2/datetimev2
---
 be/src/vec/runtime/vdatetime_value.cpp | 15 ++-
 1 file changed, 14 insertions(+), 1 deletion(-)

diff --git a/be/src/vec/runtime/vdatetime_value.cpp 
b/be/src/vec/runtime/vdatetime_value.cpp
index 492ee4e391..05a568f9ad 100644
--- a/be/src/vec/runtime/vdatetime_value.cpp
+++ b/be/src/vec/runtime/vdatetime_value.cpp
@@ -2328,6 +2328,10 @@ uint8_t DateV2Value::week(uint8_t mode) const {
 
 template 
 uint32_t DateV2Value::year_week(uint8_t mode) const {
+if (config::enable_time_lut && mode == 4 && this->year() >= 1950 && 
this->year() < 2030) {
+return doris::TimeLUT::GetImplement()
+->year_week_table[this->year() - 1950][this->month() - 
1][this->day() - 1];
+}
 uint16_t year = 0;
 // The range of the week in the year_week is 1-53, so the mode WEEK_YEAR 
is always true.
 uint8_t week =
@@ -2806,7 +2810,7 @@ bool DateV2Value::to_format_string(const char* format, 
int len, char* to) con
 // Year for the week where Sunday is the first day of the week,
 // numeric, four digits; used with %V
 uint16_t year = 0;
-calc_week(this->daynr(), this->year(), this->month(), this->day(), 
mysql_week_mode(3),
+calc_week(this->daynr(), this->year(), this->month(), this->day(), 
mysql_week_mode(2),
   &year);
 pos = int_to_str(year, buf);
 to = append_with_prefix(buf, pos - buf, '0', 4, to);
@@ -2939,6 +2943,15 @@ template 
 uint8_t DateV2Value::calc_week(const uint32_t& day_nr, const uint16_t& year,
   const uint8_t& month, const uint8_t& day, 
uint8_t mode,
   uint16_t* to_year) {
+if (config::enable_time_lut && mode == 3 && year >= 1950 && year < 2030) {
+return doris::TimeLUT::GetImplement()
+->week_of_year_table[year - doris::LUT_START_YEAR][month - 
1][day - 1];
+}
+// mode=4 is used for week()
+if (config::enable_time_lut && mode == 4 && year >= 1950 && year < 2030) {
+return doris::TimeLUT::GetImplement()
+->week_table[year - doris::LUT_START_YEAR][month - 1][day - 1];
+}
 bool monday_first = mode & WEEK_MONDAY_FIRST;
 bool week_year = mode & WEEK_YEAR;
 bool first_weekday = mode & WEEK_FIRST_WEEKDAY;


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



[GitHub] [doris] smallhibiscus opened a new pull request, #11464: [regression-test](join) Add test case of join sql

2022-08-03 Thread GitBox


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

   # Proposed changes
   
   Issue Number: close #xxx
   
   ## Problem summary
   
   1.Add test case of join sql.
   2.sql  `select  t.* from ( select  * from wftest1 t1  left join wftest2 t2 
on t1.aa=t2.cc  ) t  where   dayofweek(current_date())=2;`  correct result 
should be empty 
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [ ] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [ ] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [ ] No
   
   ## 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



[GitHub] [doris] yiguolei commented on pull request #11441: [refactor](schema change)Remove delete from sc

2022-08-03 Thread GitBox


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

   part of https://github.com/apache/doris/pull/10136


-- 
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



[GitHub] [doris] yiguolei commented on pull request #11397: [refactor](schema change) spark dpp need not call convert rowset during load process

2022-08-03 Thread GitBox


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

   part of https://github.com/apache/doris/pull/10136


-- 
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



[GitHub] [doris] yiguolei commented on pull request #10860: [improvement] improvement for light weight schema change

2022-08-03 Thread GitBox


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

   part of https://github.com/apache/doris/pull/10136


-- 
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



[GitHub] [doris] BiteTheDDDDt commented on pull request #11463: [Bug](function) fix current_date not equal to curdate

2022-08-03 Thread GitBox


BiteThet commented on PR #11463:
URL: https://github.com/apache/doris/pull/11463#issuecomment-1203702567

   > FEFunctions in FE has the same problem. Could you fix them together?
   
   FE function only have `curdate`, the result is right. Do you means I should 
add `current_date` to fe?


-- 
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



[GitHub] [doris] Wujiao233 opened a new issue, #11465: [Bug] Broker Load cannot correctly import hive data when column name start with number

2022-08-03 Thread GitBox


Wujiao233 opened a new issue, #11465:
URL: https://github.com/apache/doris/issues/11465

   ### Search before asking
   
   - [X] I had searched in the 
[issues](https://github.com/apache/incubator-doris/issues?q=is%3Aissue) and 
found no similar issues.
   
   
   ### Version
   
   1.1.0-rc05
   
   ### What's Wrong?
   
   hive table is like
   ```sql
   create table tmp.t_doris_import_test as 
   select 'a' as id, 1 as `41_col`
   union all 
   select 'b' as id, 2 as `41_col`
   union all 
   select 'c' as id, 3 as `41_col`
   ```
   which has a column name start with number
   
   and doris table is 
   ```sql
   CREATE TABLE tmp.t_doris_import_test
   (
   `id` varchar(20)
   ,`_41_col` bigint 
   )
   DUPLICATE KEY(`id`)
   DISTRIBUTED BY RANDOM
   ```
   because doris cannot use column name start with number so I add a underline 
before number
   
   then use broker load to load data from hive to doris
   ```sql
   LOAD LABEL sync_t_doris_import_test_1
   (
   DATA INFILE("hdfs://path/to/warehouse/tmp.db/t_doris_import_test/*")
   INTO TABLE t_doris_import_test
   FORMAT AS "orc"
   (`id`,`41_col`)
   )
   WITH BROKER "brokers"
   (
   "username" = "xxx",
   "password" = "xxx"
   )
   PROPERTIES
   (
   "timeout"="3600"
   );
   ```
   
   which finish successfully.. However when I query this table on doris 
   ```sql
   select * from tmp.t_doris_import_test
   ```
   
   it return 
   
   | id   | _41_col |
   | --- | --- |
   | a|NULL |
   | b|NULL |
   | c|NULL |
   
   
   ### What You Expected?
   
   the result should be like 
   
   
   | id   | _41_col |
   | --- | --- |
   | a|1 |
   | b|2 |
   | c|3 |
   
   or maybe I use the wrong load configuration...
   
   ### How to Reproduce?
   
   _No response_
   
   ### Anything Else?
   
   _No response_
   
   ### Are you willing to submit PR?
   
   - [ ] Yes I am willing to submit a PR!
   
   ### Code of Conduct
   
   - [X] I agree to follow this project's [Code of 
Conduct](https://www.apache.org/foundation/policies/conduct)
   


-- 
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.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



[GitHub] [doris] englefly commented on a diff in pull request #11459: [enhancement](Nereids)set default join type to CROSS_JOIN

2022-08-03 Thread GitBox


englefly commented on code in PR #11459:
URL: https://github.com/apache/doris/pull/11459#discussion_r936364439


##
fe/fe-core/src/main/java/org/apache/doris/nereids/parser/LogicalPlanBuilder.java:
##
@@ -584,7 +584,7 @@ public LogicalPlan visitFromClause(FromClauseContext ctx) {
 LogicalPlan right = plan(relation.relationPrimary());
 left = left == null
 ? right
-: new LogicalJoin(JoinType.INNER_JOIN, 
Optional.empty(), left, right);
+: new LogicalJoin<>(JoinType.CROSS_JOIN, 
Optional.empty(), left, right);

Review Comment:
   If this is a cross join, I think there must be some place where we change 
the default join type (INNER_JOIN) to CROSS_JOIN. 
   Simllarly, if we change the default join type to CROSS_JOIN, there should be 
some place we change join type from CROSS_JOIN to INNER_JOIN.



-- 
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



[GitHub] [doris] jacktengg commented on pull request #11169: [feature](FE): add new property to control whether use light schema change or not

2022-08-03 Thread GitBox


jacktengg commented on PR #11169:
URL: https://github.com/apache/doris/pull/11169#issuecomment-1203742522

   Please fix FE code style check error.


-- 
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



[GitHub] [doris] github-actions[bot] commented on pull request #11186: [feature](cache) Add FileCache for RemoteFile

2022-08-03 Thread GitBox


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

   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



[GitHub] [doris] github-actions[bot] commented on pull request #11186: [feature](cache) Add FileCache for RemoteFile

2022-08-03 Thread GitBox


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

   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



[GitHub] [doris] ChPi opened a new issue, #11466: [Bug] select list expression not produced by aggregation output

2022-08-03 Thread GitBox


ChPi opened a new issue, #11466:
URL: https://github.com/apache/doris/issues/11466

   ### Search before asking
   
   - [X] I had searched in the 
[issues](https://github.com/apache/incubator-doris/issues?q=is%3Aissue) and 
found no similar issues.
   
   
   ### Version
   
   1.1.1
   
   ### What's Wrong?
   
   error
   ```
   select list expression not produced by aggregation output (missing from 
GROUP BY clause?): concat(`k1`, '1')
   ```
   
   ### What You Expected?
   
   success
   
   ### How to Reproduce?
   
   create table 
   ```
   CREATE TABLE `test1` (
 `k1` int(11) NOT NULL COMMENT "user id",
 `k2` int(11) NOT NULL COMMENT "data import time"
   ) ENGINE=OLAP
   DUPLICATE KEY(`k1`)
   COMMENT "OLAP"
   DISTRIBUTED BY HASH(`k1`) BUCKETS 1
   PROPERTIES (
   "replication_allocation" = "tag.location.default: 1",
   "in_memory" = "false",
   "storage_format" = "V2"
   )
   ```
   query 
   ```
   select concat(k1,'1') as k,count(*) from test1 group by concat(k1,'1')
   ```
   success.
   but
   ```
   select concat(k1,'1') as k1,count(*) from test1 group by concat(k1,'1')
   ```
   fail.
   
   
   ### Anything Else?
   
   _No response_
   
   ### Are you willing to submit PR?
   
   - [ ] Yes I am willing to submit a PR!
   
   ### Code of Conduct
   
   - [X] I agree to follow this project's [Code of 
Conduct](https://www.apache.org/foundation/policies/conduct)
   


-- 
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.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



[GitHub] [doris] Gabriel39 opened a new issue, #11467: [Enhancement] Derive push-down predicate from vconjuncts

2022-08-03 Thread GitBox


Gabriel39 opened a new issue, #11467:
URL: https://github.com/apache/doris/issues/11467

   ### Search before asking
   
   - [X] I had searched in the 
[issues](https://github.com/apache/incubator-doris/issues?q=is%3Aissue) and 
found no similar issues.
   
   
   ### Description
   
   Currently we always derive  push-down predicates from row-based expressions 
`conjuncts` although we use vectorized engine.
   
   ### Solution
   
   Derive push-down predicates from `vconjuncts` on vectorized engine.
   
   ### Are you willing to submit PR?
   
   - [X] Yes I am willing to submit a PR!
   
   ### Code of Conduct
   
   - [X] I agree to follow this project's [Code of 
Conduct](https://www.apache.org/foundation/policies/conduct)
   


-- 
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.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



[GitHub] [doris] Gabriel39 opened a new pull request, #11468: [Refactor](push-down predicate) WIP

2022-08-03 Thread GitBox


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

   
   # Proposed changes
   
   Issue Number: close #11467
   
   ## Problem summary
   
   Describe your changes.
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [ ] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [ ] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [ ] No
   
   ## 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



[doris-thirdparty] branch bdbje updated: release bdbje-18.3.13-doris-SNAPSHOTD

2022-08-03 Thread yangzhg
This is an automated email from the ASF dual-hosted git repository.

yangzhg pushed a commit to branch bdbje
in repository https://gitbox.apache.org/repos/asf/doris-thirdparty.git


The following commit(s) were added to refs/heads/bdbje by this push:
 new e4bb850  release bdbje-18.3.13-doris-SNAPSHOTD
e4bb850 is described below

commit e4bb8501a0afe16d2401e0dcce820e80ab9fcc81
Author: Zhengguo Yang 
AuthorDate: Wed Aug 3 17:50:24 2022 +0800

release bdbje-18.3.13-doris-SNAPSHOTD
---
 pom.xml | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)

diff --git a/pom.xml b/pom.xml
index c377413..4d372c3 100644
--- a/pom.xml
+++ b/pom.xml
@@ -10,7 +10,7 @@
 
 org.apache.doris
 je
-18.3.12-doris
+18.3.12-doris-SNAPSHOT
 bdb-je apache doris release
 https://doris.apache.org/
 fork from bdb-je 18.3.12 from maven with starrocks bdbje 
patches
@@ -187,4 +187,4 @@
 https://repo.grails.org/grails/core/
 
 
-
\ No newline at end of file
+


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



[doris-thirdparty] tag bdbje-18.3.13-doris-snapshot created (now e4bb850)

2022-08-03 Thread yangzhg
This is an automated email from the ASF dual-hosted git repository.

yangzhg pushed a change to tag bdbje-18.3.13-doris-snapshot
in repository https://gitbox.apache.org/repos/asf/doris-thirdparty.git


  at e4bb850  (commit)
No new revisions were added by this update.


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



[GitHub] [doris] hf200012 merged pull request #11456: [doc](schema change) Correct Schema Change error description

2022-08-03 Thread GitBox


hf200012 merged PR #11456:
URL: https://github.com/apache/doris/pull/11456


-- 
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: [doc](schema change) Correct Schema Change error description (#11456)

2022-08-03 Thread jiafengzheng
This is an automated email from the ASF dual-hosted git repository.

jiafengzheng 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 7366f187d7 [doc](schema change) Correct Schema Change error 
description (#11456)
7366f187d7 is described below

commit 7366f187d7de5c623541676cf9cc1f6f81a0126b
Author: ZenoYang 
AuthorDate: Wed Aug 3 18:35:55 2022 +0800

[doc](schema change) Correct Schema Change error description (#11456)

Correct Schema Change error description
---
 docs/en/docs/advanced/materialized-view.md| 2 +-
 docs/zh-CN/docs/advanced/materialized-view.md | 2 +-
 2 files changed, 2 insertions(+), 2 deletions(-)

diff --git a/docs/en/docs/advanced/materialized-view.md 
b/docs/en/docs/advanced/materialized-view.md
index ea3d51ead8..96ba58735f 100644
--- a/docs/en/docs/advanced/materialized-view.md
+++ b/docs/en/docs/advanced/materialized-view.md
@@ -484,7 +484,7 @@ This problem can be solved by creating a materialized view 
with k3 as the first
 
 ## Error
 1. DATA_QUALITY_ERR: "The data quality does not satisfy, please check your 
data"
-Materialized view creation failed due to data quality issues.
+Materialized view creation failed due to data quality issues or Schema Change 
memory usage exceeding the limit. If it is a memory problem, increase the 
`memory_limitation_per_thread_for_schema_change_bytes` parameter.
 Note: The bitmap type only supports positive integers. If there are negative 
Numbers in the original data, the materialized view will fail to be created
 
 ## More Help
diff --git a/docs/zh-CN/docs/advanced/materialized-view.md 
b/docs/zh-CN/docs/advanced/materialized-view.md
index 799d944988..4d269da531 100644
--- a/docs/zh-CN/docs/advanced/materialized-view.md
+++ b/docs/zh-CN/docs/advanced/materialized-view.md
@@ -481,7 +481,7 @@ MySQL [test]> desc advertiser_view_record;
 
## 异常错误
 
-   1. DATA_QUALITY_ERR: "The data quality does not satisfy, please check your 
data" 由于数据质量问题导致物化视图创建失败。 注意:bitmap类型仅支持正整型, 如果原始数据中存在负数,会导致物化视图创建失败
+   1. DATA_QUALITY_ERR: "The data quality does not satisfy, please check your 
data" 由于数据质量问题或者Schema 
Change内存使用超出限制导致物化视图创建失败。如果是内存问题,调大`memory_limitation_per_thread_for_schema_change_bytes`参数即可。
 注意:bitmap类型仅支持正整型, 如果原始数据中存在负数,会导致物化视图创建失败
 
 
 


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



[GitHub] [doris] github-actions[bot] commented on pull request #11463: [Bug](function) fix current_date not equal to curdate

2022-08-03 Thread GitBox


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

   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



[GitHub] [doris] hf200012 opened a new pull request, #11471: [doc](website)fe elastic scaling documentation issue

2022-08-03 Thread GitBox


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

   
   https://github.com/apache/doris/discussions/11460
   
   # Proposed changes
   
   Issue Number: close #xxx
   
   ## Problem summary
   
   Describe your changes.
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [ ] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [ ] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [ ] No
   
   ## 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



[doris-website] branch master updated: fix

2022-08-03 Thread jiafengzheng
This is an automated email from the ASF dual-hosted git repository.

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


The following commit(s) were added to refs/heads/master by this push:
 new 9101ce47ce7 fix
9101ce47ce7 is described below

commit 9101ce47ce7fcaf09c2d90a67e261340d9579f05
Author: jiafeng.zhang 
AuthorDate: Wed Aug 3 18:50:59 2022 +0800

fix
---
 .../cluster-management/elastic-expansion.md   | 16 ++--
 docs/advanced/materialized-view.md|  2 +-
 docs/get-starting/get-starting.md |  3 ++-
 .../cluster-management/elastic-expansion.md   | 18 --
 .../current/advanced/materialized-view.md |  2 +-
 .../current/get-starting/get-starting.md  | 19 +--
 6 files changed, 35 insertions(+), 25 deletions(-)

diff --git a/docs/admin-manual/cluster-management/elastic-expansion.md 
b/docs/admin-manual/cluster-management/elastic-expansion.md
index 94446ae55ae..be6cc0e07a8 100644
--- a/docs/admin-manual/cluster-management/elastic-expansion.md
+++ b/docs/admin-manual/cluster-management/elastic-expansion.md
@@ -51,6 +51,16 @@ FE is divided into three roles: Leader, Follower and 
Observer. By default, a clu
 
 The first FE to start automatically becomes Leader. On this basis, several 
Followers and Observers can be added.
 
+ Configure and start Follower or Observer.
+
+ Follower and Observer are configured with Leader. The following commands need 
to be executed at the first startup:
+
+`bin/start_fe.sh --helper host:edit_log_port --daemon`
+
+The host is the node IP of Leader, and the edit\_log\_port in Lead's 
configuration file fe.conf. The --helper is only required when 
follower/observer is first startup.
+
+ Add Follower or Observer to the cluster
+
 Add Follower or Observer. Connect to the started FE using mysql-client and 
execute:
 
 `ALTER SYSTEM ADD FOLLOWER "follower_host:edit_log_port";`
@@ -61,12 +71,6 @@ or
 
 The follower\_host and observer\_host is the node IP of Follower or Observer, 
and the edit\_log\_port in its configuration file fe.conf.
 
-Configure and start Follower or Observer. Follower and Observer are configured 
with Leader. The following commands need to be executed at the first startup:
-
-`bin/start_fe.sh --helper host:edit_log_port --daemon`
-
-The host is the node IP of Leader, and the edit\_log\_port in Lead's 
configuration file fe.conf. The --helper is only required when 
follower/observer is first startup.
-
 View the status of Follower or Observer. Connect to any booted FE using 
mysql-client and execute:
 
 ```SHOW PROC '/frontends';```
diff --git a/docs/advanced/materialized-view.md 
b/docs/advanced/materialized-view.md
index ea3d51ead8c..96ba58735f1 100644
--- a/docs/advanced/materialized-view.md
+++ b/docs/advanced/materialized-view.md
@@ -484,7 +484,7 @@ This problem can be solved by creating a materialized view 
with k3 as the first
 
 ## Error
 1. DATA_QUALITY_ERR: "The data quality does not satisfy, please check your 
data"
-Materialized view creation failed due to data quality issues.
+Materialized view creation failed due to data quality issues or Schema Change 
memory usage exceeding the limit. If it is a memory problem, increase the 
`memory_limitation_per_thread_for_schema_change_bytes` parameter.
 Note: The bitmap type only supports positive integers. If there are negative 
Numbers in the original data, the materialized view will fail to be created
 
 ## More Help
diff --git a/docs/get-starting/get-starting.md 
b/docs/get-starting/get-starting.md
index 4119718ed15..3c6ee49d281 100644
--- a/docs/get-starting/get-starting.md
+++ b/docs/get-starting/get-starting.md
@@ -241,7 +241,7 @@ For a complete parameter comparison table, please go to 
[Profile parameter analy
 
> For more detailed syntax and best practices used by Create-DataBase, see 
[Create-Database](../sql-manual/sql-reference/Data-Definition-Statements/Create/CREATE-DATABASE)
 command manual.
>
-   > If you don't know the full name of the command, you can use "help command 
a field" for fuzzy query. If you type 'HELP CREATE', you can match `CREATE 
DATABASE`, `CREATE TABLE`, `CREATE USER` and other commands.
+   > If you don't know the full name of the command, you can use "help command 
a field" for fuzzy query. If you type `HELP CREATE`, you can match `CREATE 
DATABASE`, `CREATE TABLE`, `CREATE USER` and other commands 

After the database is created, you can view the database information 
through `SHOW DATABASES;`.

@@ -469,6 +469,7 @@ For a complete parameter comparison table, please go to 
[Profile parameter analy
 
  > 1. FE_HOST is the IP of the node where any FE is located, and 8030 is 
the http_port in fe.conf.
  > 2. You can use the IP of any BE and the webserver_port in be.conf to 
import. For example: `BE_HOST:8040`
+ > 3. example_db is the database which 

[GitHub] [doris] github-actions[bot] commented on pull request #11439: [doc]fix-doc

2022-08-03 Thread GitBox


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

   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



[GitHub] [doris] github-actions[bot] commented on pull request #11439: [doc]fix-doc

2022-08-03 Thread GitBox


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

   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



[doris-thirdparty] tag bdbje-18.3.13-doris-snapshot created (now 1c5a526)

2022-08-03 Thread yangzhg
This is an automated email from the ASF dual-hosted git repository.

yangzhg pushed a change to tag bdbje-18.3.13-doris-snapshot
in repository https://gitbox.apache.org/repos/asf/doris-thirdparty.git


  at 1c5a526  (commit)
No new revisions were added by this update.


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



[GitHub] [doris] SWJTU-ZhangLei closed pull request #11424: [bug](bdbje) switch bdbje to fix bdb recoverTracker error.

2022-08-03 Thread GitBox


SWJTU-ZhangLei closed pull request #11424: [bug](bdbje) switch bdbje to fix bdb 
recoverTracker error.
URL: https://github.com/apache/doris/pull/11424


-- 
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



[GitHub] [doris] Lchangliang opened a new issue, #11472: [Bug] select with condition will coredump

2022-08-03 Thread GitBox


Lchangliang opened a new issue, #11472:
URL: https://github.com/apache/doris/issues/11472

   ### Search before asking
   
   - [X] I had searched in the 
[issues](https://github.com/apache/incubator-doris/issues?q=is%3Aissue) and 
found no similar issues.
   
   
   ### Version
   
   master
   
   ### What's Wrong?
   
   In thie case, BE will core when find condition by cid. Now, every rowset 
will store their segment, but in unique table, that is a hide column 
'delete_sign' always at schema end. So after do schema change, this column 
index in each segment is different. 
   
   ```
   DROP TABLE IF EXISTS schema_change_update_regression_test;
   
   CREATE TABLE schema_change_update_regression_test (
   `user_id` LARGEINT NOT NULL COMMENT "用户id",
   `date` DATE NOT NULL COMMENT "数据灌入日期时间",
   `city` VARCHAR(20) COMMENT "用户所在城市",
   `age` SMALLINT COMMENT "用户年龄",
   `sex` TINYINT COMMENT "用户性别",
   `last_visit_date` DATETIME DEFAULT "1970-01-01 00:00:00" 
COMMENT "用户最后一次访问时间",
   `last_update_date` DATETIME DEFAULT "1970-01-01 00:00:00" 
COMMENT "用户最后一次更新时间",
   `last_visit_date_not_null` DATETIME NOT NULL DEFAULT 
"1970-01-01 00:00:00" COMMENT "用户最后一次访问时间",
   `cost` BIGINT DEFAULT "0" COMMENT "用户总消费",
   `max_dwell_time` INT DEFAULT "0" COMMENT "用户最大停留时间",
   `min_dwell_time` INT DEFAULT "9" COMMENT "用户最小停留时间")
   UNIQUE KEY(`user_id`, `date`, `city`, `age`, `sex`) DISTRIBUTED 
BY HASH(`user_id`)
   PROPERTIES ( "replication_num" = "1" );
   
   INSERT INTO schema_change_update_regression_test VALUES
(1, '2017-10-01', 'Beijing', 10, 1, '2020-01-01', '2020-01-01', 
'2020-01-01', 1, 30, 20);
   
   INSERT INTO schema_change_update_regression_test VALUES
(2, '2017-10-01', 'Beijing', 10, 1, '2020-01-02', '2020-01-02', 
'2020-01-02', 1, 31, 21);
   
   SELECT * FROM schema_change_update_regression_test order by user_id ASC, 
last_visit_date;
   
   ALTER table schema_change_update_regression_test ADD COLUMN new_column INT 
default "1";
   
   SELECT * FROM schema_change_update_regression_test order by user_id DESC, 
last_visit_date;
   ```
   
   ### What You Expected?
   
   work
   
   ### How to Reproduce?
   
   _No response_
   
   ### Anything Else?
   
   _No response_
   
   ### Are you willing to submit PR?
   
   - [X] Yes I am willing to submit a PR!
   
   ### Code of Conduct
   
   - [X] I agree to follow this project's [Code of 
Conduct](https://www.apache.org/foundation/policies/conduct)
   


-- 
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.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



[GitHub] [doris] Lchangliang opened a new pull request, #11474: [BugFix] fix condition index doesn't match

2022-08-03 Thread GitBox


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

   # Proposed changes
   
   Issue Number: close #11472
   
   ## Problem summary
   
   Describe your changes.
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [ ] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [ ] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [ ] No
   
   ## 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



[GitHub] [doris] shutao917 closed issue #11127: [Bug] query odbc table error when set enable_vectorized_engine to true

2022-08-03 Thread GitBox


shutao917 closed issue #11127: [Bug] query odbc table error when set 
enable_vectorized_engine to true
URL: https://github.com/apache/doris/issues/11127


-- 
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



[GitHub] [doris] adonis0147 commented on pull request #11468: [Refactor](push-down predicate) WIP

2022-08-03 Thread GitBox


adonis0147 commented on PR #11468:
URL: https://github.com/apache/doris/pull/11468#issuecomment-1203840100

   > [Refactor](push-down predicate) WIP
   
   The title of this pr is not good.


-- 
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



[GitHub] [doris] yiguolei merged pull request #11434: [improvement](fe) Remove constant keys in aggregation

2022-08-03 Thread GitBox


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


-- 
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: [improvement](fe) Remove constant keys in aggregation (#11434)

2022-08-03 Thread yiguolei
This is an automated email from the ASF dual-hosted git repository.

yiguolei 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 4ba2422039 [improvement](fe) Remove constant keys in aggregation 
(#11434)
4ba2422039 is described below

commit 4ba2422039170b75f1082ad29c92a97e100b7b6d
Author: Jerry Hu 
AuthorDate: Wed Aug 3 19:43:35 2022 +0800

[improvement](fe) Remove constant keys in aggregation (#11434)
---
 .../java/org/apache/doris/analysis/SelectStmt.java | 15 ++
 regression-test/data/query/aggregate/aggregate.out | 23 ++
 .../suites/query/aggregate/aggregate.groovy|  2 ++
 3 files changed, 36 insertions(+), 4 deletions(-)

diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/SelectStmt.java 
b/fe/fe-core/src/main/java/org/apache/doris/analysis/SelectStmt.java
index b087ff451b..2440dc1956 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/SelectStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/SelectStmt.java
@@ -1048,17 +1048,24 @@ public class SelectStmt extends QueryStmt {
 List groupingByTupleIds = new ArrayList<>();
 if (groupByClause != null) {
 groupByClause.genGroupingExprs();
+ArrayList groupingExprs = groupByClause.getGroupingExprs();
 if (groupingInfo != null) {
-groupingInfo.buildRepeat(groupByClause.getGroupingExprs(), 
groupByClause.getGroupingSetList());
+groupingInfo.buildRepeat(groupingExprs, 
groupByClause.getGroupingSetList());
 }
-substituteOrdinalsAliases(groupByClause.getGroupingExprs(), "GROUP 
BY", analyzer);
+
+substituteOrdinalsAliases(groupingExprs, "GROUP BY", analyzer);
+
+if (!groupByClause.isGroupByExtension()) {
+groupingExprs.removeIf(Expr::isConstant);
+}
+
 if (groupingInfo != null) {
-groupingInfo.genOutputTupleDescAndSMap(analyzer, 
groupByClause.getGroupingExprs(), aggExprs);
+groupingInfo.genOutputTupleDescAndSMap(analyzer, 
groupingExprs, aggExprs);
 // must do it before copying for createAggInfo()
 
groupingByTupleIds.add(groupingInfo.getOutputTupleDesc().getId());
 }
 groupByClause.analyze(analyzer);
-createAggInfo(groupByClause.getGroupingExprs(), aggExprs, 
analyzer);
+createAggInfo(groupingExprs, aggExprs, analyzer);
 } else {
 createAggInfo(new ArrayList<>(), aggExprs, analyzer);
 }
diff --git a/regression-test/data/query/aggregate/aggregate.out 
b/regression-test/data/query/aggregate/aggregate.out
index b0358637d9..44bbb9bf0f 100644
--- a/regression-test/data/query/aggregate/aggregate.out
+++ b/regression-test/data/query/aggregate/aggregate.out
@@ -74,3 +74,26 @@ TESTING  AGAIN
 -- !aggregate --
 9223845.04 1607.258579891
 
+-- !aggregate --
+1  2   \\N 98.52
+1  2   12  12.25
+1  2   25  55.52
+1  2   100 134.884202
+1  2   964 0.245
+1  2   500067.87
+1  2   525212.25
+1  2   5748271.48
+1  2   6000\\N
+1  2   899698.8777
+
+-- !aggregate --
+\\N
+36
+75
+300
+2892
+15000
+15756
+17244
+18000
+26988
diff --git a/regression-test/suites/query/aggregate/aggregate.groovy 
b/regression-test/suites/query/aggregate/aggregate.groovy
index edd7a9b8e1..9296c150a0 100644
--- a/regression-test/suites/query/aggregate/aggregate.groovy
+++ b/regression-test/suites/query/aggregate/aggregate.groovy
@@ -100,4 +100,6 @@ suite("aggregate", "query") {
 qt_aggregate """ select variance(c_bigint), variance(c_double) from 
${tableName}  """
 qt_aggregate """ select variance(distinct c_bigint), variance(c_double) 
from ${tableName}  """
 qt_aggregate """ select variance(c_bigint), variance(distinct c_double) 
from ${tableName}  """
+qt_aggregate """ select 1 k1, 2 k2, c_bigint k3, sum(c_double) from 
${tableName} group by 1, k2, k3 order by k1, k2, k3 """
+qt_aggregate """ select (k1 + k2) * k3 k4 from (select 1 k1, 2 k2, 
c_bigint k3, sum(c_double) from ${tableName} group by 1, k2, k3) t order by k4 
"""
 }
\ No newline at end of file


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



[GitHub] [doris] yiguolei merged pull request #11457: [Bug](httpserver) Fix bug that http server should not be stoped in destructor if it not running

2022-08-03 Thread GitBox


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


-- 
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: [Bug](httpserver) Fix bug that http server should not be stoped in destructor if it not running

2022-08-03 Thread yiguolei
This is an automated email from the ASF dual-hosted git repository.

yiguolei 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 838fdc1354 [Bug](httpserver) Fix bug that http server should not be 
stoped in destructor if it not running
838fdc1354 is described below

commit 838fdc1354c39875b53f67680c04088e9b2a392e
Author: weizuo93 
AuthorDate: Wed Aug 3 19:44:46 2022 +0800

[Bug](httpserver) Fix bug that http server should not be stoped in 
destructor if it not running

Co-authored-by: weizuo 
---
 be/src/http/ev_http_server.cpp | 6 +-
 be/src/http/ev_http_server.h   | 1 +
 2 files changed, 6 insertions(+), 1 deletion(-)

diff --git a/be/src/http/ev_http_server.cpp b/be/src/http/ev_http_server.cpp
index bf612ca830..96a8709ace 100644
--- a/be/src/http/ev_http_server.cpp
+++ b/be/src/http/ev_http_server.cpp
@@ -83,10 +83,13 @@ EvHttpServer::EvHttpServer(const std::string& host, int 
port, int num_workers)
 }
 
 EvHttpServer::~EvHttpServer() {
-stop();
+if (_started) {
+stop();
+}
 }
 
 void EvHttpServer::start() {
+_started = true;
 // bind to
 auto s = _bind();
 CHECK(s.ok()) << s.to_string();
@@ -137,6 +140,7 @@ void EvHttpServer::stop() {
 }
 _workers->shutdown();
 close(_server_fd);
+_started = false;
 }
 
 void EvHttpServer::join() {}
diff --git a/be/src/http/ev_http_server.h b/be/src/http/ev_http_server.h
index f5ca94760a..7263b2f3ef 100644
--- a/be/src/http/ev_http_server.h
+++ b/be/src/http/ev_http_server.h
@@ -78,6 +78,7 @@ private:
 PathTrie _delete_handlers;
 PathTrie _head_handlers;
 PathTrie _options_handlers;
+bool _started = false;
 };
 
 } // namespace doris


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



[GitHub] [doris] freemandealer commented on issue #11465: [Bug] Broker Load cannot correctly import hive data when column name start with number

2022-08-03 Thread GitBox


freemandealer commented on issue #11465:
URL: https://github.com/apache/doris/issues/11465#issuecomment-1203844155

   just gussing... maybe  both tables should have the same name?


-- 
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



[GitHub] [doris] yiguolei opened a new pull request, #11475: [refactor](schema change) Using tablet schema shared ptr instead of raw ptr

2022-08-03 Thread GitBox


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

   # Proposed changes
   
   This is part of light weight schema change 
https://github.com/apache/doris/pull/10136
   
   ## Problem summary
   
   Describe your changes.
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [ ] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [ ] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [ ] No
   
   ## 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



[GitHub] [doris] yiguolei commented on a diff in pull request #11474: [BugFix](BE) fix condition index doesn't match

2022-08-03 Thread GitBox


yiguolei commented on code in PR #11474:
URL: https://github.com/apache/doris/pull/11474#discussion_r936578677


##
be/src/olap/rowset/segment_v2/segment_iterator.h:
##
@@ -165,9 +165,9 @@ class SegmentIterator : public RowwiseIterator {
 const Schema& _schema;
 // _column_iterators.size() == _schema.num_columns()
 // _column_iterators[cid] == nullptr if cid is not in _schema
-std::vector _column_iterators;
+std::map _column_iterators;
 // FIXME prefer vector>

Review Comment:
   modify the comments and explain the map structure.



-- 
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



[GitHub] [doris] xy720 opened a new issue, #11477: [Bug] compile hyperscan failed when build thirdparty

2022-08-03 Thread GitBox


xy720 opened a new issue, #11477:
URL: https://github.com/apache/doris/issues/11477

   ### Search before asking
   
   - [X] I had searched in the 
[issues](https://github.com/apache/incubator-doris/issues?q=is%3Aissue) and 
found no similar issues.
   
   
   ### Version
   
   master
   
   ### What's Wrong?
   
   
   ```
   FAILED: src/parser/Parser.cpp 
/home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/src/hyperscan-5.4.0/doris_build/src/parser/Parser.cpp
   cd 
/home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/src/hyperscan-5.4.0/doris_build
 && 
/home/disk4/xuyang/work/baidu/bdg/doris/palo-toolchain/ldb_toolchain/bin/cmake 
-E make_directory 
/home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/src/hyperscan-5.4.0/doris_build/src/parser
 && /home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/installed/bin/ragel 
/home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/src/hyperscan-5.4.0/src/parser/Parser.rl
 -o 
/home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/src/hyperscan-5.4.0/doris_build/src/parser/Parser.cpp
   /home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/installed/bin/ragel: 
/lib64/libc.so.6: version `GLIBC_2.14' not found (required by 
/home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/installed/bin/ragel)
   /home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/installed/bin/ragel: 
/usr/lib64/libstdc++.so.6: version `CXXABI_1.3.8' not found (required by 
/home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/installed/bin/ragel)
   /home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/installed/bin/ragel: 
/usr/lib64/libstdc++.so.6: version `GLIBCXX_3.4.26' not found (required by 
/home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/installed/bin/ragel)
   /home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/installed/bin/ragel: 
/usr/lib64/libstdc++.so.6: version `CXXABI_1.3.9' not found (required by 
/home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/installed/bin/ragel)
   /home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/installed/bin/ragel: 
/usr/lib64/libstdc++.so.6: version `GLIBCXX_3.4.21' not found (required by 
/home/disk4/xuyang/work/baidu/bdg/doris/core/thirdparty/installed/bin/ragel)
   [135/344] Building C object 
CMakeFiles/hs_exec_avx2.dir/src/rose/program_runtime.c.o
   ninja: build stopped: subcommand failed.
   ```
   
   
   ### What You Expected?
   
   work
   
   ### How to Reproduce?
   
   Clean the thirdparty.
   Build be.
   And compile error occur.
   
   ### Anything Else?
   
   _No response_
   
   ### Are you willing to submit PR?
   
   - [ ] Yes I am willing to submit a PR!
   
   ### Code of Conduct
   
   - [X] I agree to follow this project's [Code of 
Conduct](https://www.apache.org/foundation/policies/conduct)
   


-- 
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.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



[GitHub] [doris] caiconghui opened a new issue, #11478: [Enhancement] Improve the performance of meta management(Step-2)

2022-08-03 Thread GitBox


caiconghui opened a new issue, #11478:
URL: https://github.com/apache/doris/issues/11478

   ### Search before asking
   
   - [X] I had searched in the 
[issues](https://github.com/apache/incubator-doris/issues?q=is%3Aissue) and 
found no similar issues.
   
   
   ### Description
   
   As the DSIP-004 described, I will do some optimization for meta management
   
https://cwiki.apache.org/confluence/display/DORIS/DSIP-004%3A+Improve+meta+Management
   
   Now, I will optimize for get id operation in fe when create table, truncate 
table, add partition and so on 
   
   ### Solution
   
   _No response_
   
   ### Are you willing to submit PR?
   
   - [X] Yes I am willing to submit a PR!
   
   ### Code of Conduct
   
   - [X] I agree to follow this project's [Code of 
Conduct](https://www.apache.org/foundation/policies/conduct)
   


-- 
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.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



[GitHub] [doris] caiconghui opened a new pull request, #11479: [Enhancement](IdGenerator) Use IdGeneratorBuffer to get better performance for getNextId operation when create table, truncate table, add

2022-08-03 Thread GitBox


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

   # Proposed changes
   
   Issue Number: close #11478 
   
   ## Problem summary
   
   Describe your changes.
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [x] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [ ] No
   - [x] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [x] No
   - [ ] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [x] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [x] No
   
   ## 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



[GitHub] [doris] xinyiZzz opened a new issue, #11480: [Enhancement] exceed memory limit readability

2022-08-03 Thread GitBox


xinyiZzz opened a new issue, #11480:
URL: https://github.com/apache/doris/issues/11480

   ### Search before asking
   
   - [X] I had searched in the 
[issues](https://github.com/apache/incubator-doris/issues?q=is%3Aissue) and 
found no similar issues.
   
   
   ### Description
   
   The returned information when BE exceed memory limit is not easy to 
understand.
   
   ### Solution
   
   _No response_
   
   ### Are you willing to submit PR?
   
   - [X] Yes I am willing to submit a PR!
   
   ### Code of Conduct
   
   - [X] I agree to follow this project's [Code of 
Conduct](https://www.apache.org/foundation/policies/conduct)
   


-- 
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.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



[GitHub] [doris] Gabriel39 commented on pull request #11468: [Refactor](push-down predicate) WIP

2022-08-03 Thread GitBox


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

   > > [Refactor](push-down predicate) WIP
   > 
   > The title of this pr is not good. You can mark the pr as a draft if you 
are working on it.
   
   I will change this title when this PR is ready for review


-- 
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



[GitHub] [doris] xy720 opened a new pull request, #11481: [Bug] compile hyperscan failed when build thirdparty

2022-08-03 Thread GitBox


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

   # Proposed changes
   
   Issue Number: close #11477 
   
   ## Problem summary
   
   Describe your changes.
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [x] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [ ] No
   - [x] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [ ] No
   - [x] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [x] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [x] No
   
   ## 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



[GitHub] [doris] yew1eb opened a new issue, #11482: [Enhancement] Fix benchmark scripts, cover case that $PASSWORD not empty

2022-08-03 Thread GitBox


yew1eb opened a new issue, #11482:
URL: https://github.com/apache/doris/issues/11482

   ### Search before asking
   
   - [X] I had searched in the 
[issues](https://github.com/apache/incubator-doris/issues?q=is%3Aissue) and 
found no similar issues.
   
   
   ### Description
   
   TPCH benchmark scripts(eg. create-tpch-tables.sh) should support situation 
that $PASSWORD not empty
   and simplify other SSB & TPCH scripts support that.
   
   ### Solution
   
   replace  `-p` with `--password=`  option in mysql cli command, referenced 
from stackoverflow's answer 
[link](https://stackoverflow.com/questions/3843973/mysql-is-prompting-for-password-even-though-my-password-is-empty)
   
   ### Are you willing to submit PR?
   
   - [X] Yes I am willing to submit a PR!
   
   ### Code of Conduct
   
   - [X] I agree to follow this project's [Code of 
Conduct](https://www.apache.org/foundation/policies/conduct)
   


-- 
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.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



[GitHub] [doris] xiaokang commented on a diff in pull request #10694: optimize topn query if order by columns is prefix of sort keys of table

2022-08-03 Thread GitBox


xiaokang commented on code in PR #10694:
URL: https://github.com/apache/doris/pull/10694#discussion_r936697486


##
be/src/olap/reader.cpp:
##
@@ -197,11 +197,17 @@ Status TabletReader::_capture_rs_readers(const 
ReaderParams& read_params,
 // it's ok for rowset to return unordered result
 need_ordered_result = false;
 }
+
+if (read_params.read_orderby_key) {
+need_ordered_result = true;

Review Comment:
   btw, for normal query on UNIQUE_KEYS, need_ordered_result is true but 
read_params.read_orderby_key is false.



-- 
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



[GitHub] [doris] xinyiZzz opened a new pull request, #11485: [enhancement](memtracker) Optimize exceed memory limit log readability

2022-08-03 Thread GitBox


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

   # Proposed changes
   
   Issue Number: close #11480
   
   ## Problem summary
   
   Optimize the returned information when query exceeds memory limit.
   
   mysql client return error:
   
   Memory limit exceeded: exec node:unknown, `set exec_mem_limit=xxx` to change 
limit, failed mem consume:, std::allocator > const&, long) at 
/mnt/disk1/liyifan/doris/core/be/src/runtime/memory/mem_tracker_limiter.cpp:238
1# doris::ThreadMemTrackerMgr::exceeded(long) at 
/mnt/disk1/liyifan/doris/core/be/src/runtime/memory/thread_mem_tracker_mgr.cpp:65
2# void doris::ThreadMemTrackerMgr::flush_untracked_mem() at 
/mnt/disk1/liyifan/doris/core/be/src/runtime/memory/thread_mem_tracker_mgr.h:199
3# doris::ThreadMemTrackerMgr::consume(long) at 
/mnt/disk1/liyifan/doris/core/be/src/runtime/memory/thread_mem_tracker_mgr.h:170
4# new_hook(void const*, unsigned long) at 
/mnt/disk1/liyifan/doris/core/be/src/runtime/memory/tcmalloc_hook.h:48
5# MallocHook::InvokeNewHookSlow(void const*, unsigned long) at 
src/malloc_hook.cc:498
6# tcmalloc::allocate_full_cpp_throw_oom(unsigned long) at 
src/tcmalloc.cc:1815
7# snappy::internal::WorkingMemory::WorkingMemory(unsigned long) in 
/mnt/disk1/liyifan/doris/core/output_run/be/lib/doris_be
8# snappy::Compress(snappy::Source*, snappy::Sink*) in 
/mnt/disk1/liyifan/doris/core/output_run/be/lib/doris_be
9# snappy::RawCompress(char const*, unsigned long, char*, unsigned long*) 
in /mnt/disk1/liyifan/doris/core/output_run/be/lib/doris_be
   10# doris::vectorized::Block::serialize(doris::PBlock*, unsigned long*, 
unsigned long*, bool) const at 
/mnt/disk1/liyifan/doris/core/be/src/vec/core/block.cpp:722
   11# 
doris::vectorized::VDataStreamSender::serialize_block(doris::vectorized::Block*,
 doris::PBlock*, int) at 
/mnt/disk1/liyifan/doris/core/be/src/vec/sink/vdata_stream_sender.cpp:592
   12# doris::vectorized::VDataStreamSender::Channel::send_current_block(bool) 
at /mnt/disk1/liyifan/doris/core/be/src/vec/sink/vdata_stream_sender.cpp:87
   13# 
doris::vectorized::VDataStreamSender::Channel::add_rows(doris::vectorized::Block*,
 std::vector > const&) at 
/mnt/disk1/liyifan/doris/core/be/src/vec/sink/vdata_stream_sender.cpp:218
   14# doris::Status 
doris::vectorized::VDataStreamSender::channel_add_rows >, 
std::vector > >(std::vecto
   r >&, int, 
std::vector > const&, int, 
doris::vectorized::Block*) at /mnt/disk1/liyifan/doris/core/be/src/vec/sink/
   vdata_stream_sender.h:316
   15# doris::vectorized::VDataStreamSender::send(doris::RuntimeState*, 
doris::vectorized::Block*) at 
/mnt/disk1/liyifan/doris/core/be/src/vec/sink/vdata_stream_sender.cpp:516
   16# doris::PlanFragmentExecutor::open_vectorized_internal() at 
/mnt/disk1/liyifan/doris/core/be/src/runtime/plan_fragment_executor.cpp:299
   17# doris::PlanFragmentExecutor::open() at 
/mnt/disk1/liyifan/doris/core/be/src/runtime/plan_fragment_executor.cpp:239
   18# doris::FragmentExecState::execute() at 
/mnt/disk1/liyifan/doris/core/be/src/runtime/fragment_mgr.cpp:246
   19# 
doris::FragmentMgr::_exec_actual(std::shared_ptr, 
std::function) at 
/mnt/disk1/liyifan/doris/core/be/src/runtime/fragment_mgr.cpp:500
   20# doris::FragmentMgr::exec_plan_fragment(doris::TExecPlanFragmentParams 
const&, std::function)::{lambda()#1}::operator()() const at 
/mnt/disk1/liyifan/doris/core/be/src/runtime/fragment_mgr.cpp:681
   21# void std::__invoke_impl)::{lambda()#1}&>(std::__invoke_other, 
doris::FragmentMgr::exec_plan_fragment(doris::TExecPlanFragmentParams
const&, std::function)::{lambda()#1}&) 
at /mnt/disk1/liyifan/doris/ldb_toolchain/include/c++/11/bits/invoke.h:61
   22# std::enable_if)::{lambda()#1}&>, 
void>::type std::__invoke_r)::{lambda()#1}&>(doris::FragmentMgr::exec_plan_fragment(doris::TExecPlanFragmentParams
 const&, std::function)::{lambda()#1}&) at 
/mnt/disk1/liyifan/dor
   is/ldb_toolchain/include/c++/11/bits/invoke.h:117
   23# std::_Function_handler)::{lambda()#1}>::_M_invoke(std::_Any_data 
const&) at /mnt/disk1/liyifan/doris/ldb_toolchain/include/c++/1
   1/bits/std_function.h:292
   24# std::function::operator()() const at 
/mnt/disk1/liyifan/doris/ldb_toolchain/include/c++/11/bits/std_function.h:560
   25# doris::FunctionRunnable::run() at 
/mnt/disk1/liyifan/doris/core/be/src/util/threadpool.cpp:45
   26# doris::ThreadPool::dispatch_thread() at 
/mnt/disk1/liyifan/doris/core/be/src/util/threadpool.cpp:548
   27# void std::__invoke_impl(std::__invoke_memfun_deref, void 
(doris::ThreadPool::*&)(), doris::ThreadPool*&) at 
/mnt/disk1/liyifan/doris/ldb_toolchain/include/c++/11/bits/invoke.h:74
   28# std::__invoke_result::type std::__invoke(void (doris::ThreadPool::*&)(), doris::ThreadPool*&) at 
/mnt/disk1/liyifan/doris/ldb_toolchain/include/c++/11/bits/invo
   ke.h:97
   29# void std::_Bind::__call(std::tuple<>&&, std::_Index_tuple<0ul>) at 
/mnt/disk1/liyifan/doris/ldb_toolchain

[GitHub] [doris] yew1eb opened a new pull request, #11486: [Enhancement] Fix benchmark scripts, cover case that $PASSWORD not empty

2022-08-03 Thread GitBox


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

   # Proposed changes
   
   Issue Number: close #11482
   
   ## Problem summary
   
   TPCH benchmark scripts(eg. create-tpch-tables.sh) should support situation 
that $PASSWORD not empty
   and simplify other SSB & TPCH scripts support that.
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [x] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [x] No
   - [ ] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [x] No
   - [ ] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [x] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [x] No
   
   ## 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



[GitHub] [doris] morningman opened a new pull request, #11487: [improvement](outfile) support multibyte separator in outfile clause

2022-08-03 Thread GitBox


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

   # Proposed changes
   
   Issue Number: close #xxx
   
   ## Problem summary
   
   ```
   select * from tbl1 into outfile "file:///tmp/res_" 
properties("column_separator" = "\\x01", "line_delimiter = "abc");
   ```
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [ ] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [ ] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [ ] No
   
   ## 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



[GitHub] [doris] kpfly commented on pull request #11479: [Enhancement](IdGenerator) Use IdGeneratorBuffer to get better performance for getNextId operation when create table, truncate table, add parti

2022-08-03 Thread GitBox


kpfly commented on PR #11479:
URL: https://github.com/apache/doris/pull/11479#issuecomment-1204068623

   Is there any performance tests?


-- 
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



[GitHub] [doris] wsjz opened a new pull request, #11488: [feature-wip](parquet-reader) add predicate filter

2022-08-03 Thread GitBox


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

   # Proposed changes
   
   Issue Number: close #xxx
   
   ## Problem summary
   
   Describe your changes.
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [ ] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [ ] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [ ] No
   
   ## 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



[GitHub] [doris] caiconghui commented on pull request #11479: [Enhancement](IdGenerator) Use IdGeneratorBuffer to get better performance for getNextId operation when create table, truncate table, add

2022-08-03 Thread GitBox


caiconghui commented on PR #11479:
URL: https://github.com/apache/doris/pull/11479#issuecomment-1204104383

   > Is there any performance tests?
   
   the main cost is EditLog write, I use thread.sleep(2) to Simulate editlog 
write and here is the example for single thread
   
   ```
MetaIdGenerator idGenerator = new MetaIdGenerator(0);
   int size = 5;
   long[] idList = new long[size];
   long startTime = System.currentTimeMillis();
   //for (int i = 0; i < size; i++) {
   //idList[i] = idGenerator.getNextId();
   //}
   IdGeneratorBuffer idGeneratorBuffer = 
idGenerator.getIdGeneratorBuffer(size);
   for (int i = 0; i < size; ++i) {
   idList[i] = idGeneratorBuffer.getNextId();
   }
   System.out.println("cost " + (System.currentTimeMillis() - 
startTime));
   ```
   cost is 123ms vs 4ms this example is for creating table on single thread


-- 
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



[GitHub] [doris] morrySnow commented on a diff in pull request #11264: [feature](nereids)add InPredicate in expressions

2022-08-03 Thread GitBox


morrySnow commented on code in PR #11264:
URL: https://github.com/apache/doris/pull/11264#discussion_r936810275


##
fe/fe-core/src/main/java/org/apache/doris/nereids/glue/translator/ExpressionTranslator.java:
##
@@ -141,10 +145,48 @@ public Expr visitNullSafeEqual(NullSafeEqual 
nullSafeEqual, PlanTranslatorContex
 
 @Override
 public Expr visitNot(Not not, PlanTranslatorContext context) {
-return new org.apache.doris.analysis.CompoundPredicate(
-org.apache.doris.analysis.CompoundPredicate.Operator.NOT,
-not.child(0).accept(this, context),
-null);
+if (not.child() instanceof InPredicate) {
+InPredicate inPredicate = (InPredicate) not.child();
+List inList = inPredicate.getOptions().stream()
+.map(e -> translate(e, context))
+.collect(Collectors.toList());
+return new org.apache.doris.analysis.InPredicate(
+inPredicate.getCompareExpr().accept(this, context),
+inList,
+true);
+} else if (not.child() instanceof Like) {
+Like like = (Like) not.child();
+LikePredicate likePredicate = (LikePredicate) visitLike(like, 
context);
+CompoundPredicate compoundPredicate = new 
CompoundPredicate(CompoundPredicate.Operator.NOT,
+likePredicate,
+null);
+return compoundPredicate;
+} else if (not.child() instanceof Regexp) {
+Regexp regexp = (Regexp) not.child();
+LikePredicate likePredicate = (LikePredicate) visitRegexp(regexp, 
context);
+CompoundPredicate compoundPredicate = new 
CompoundPredicate(CompoundPredicate.Operator.NOT,
+likePredicate,
+null);
+return compoundPredicate;
+} else if (not.child() instanceof Between) {
+Between between = (Between) not.child();
+BetweenPredicate betweenPredicate = new BetweenPredicate(
+between.getCompareExpr().accept(this, context),
+between.getLowerBound().accept(this, context),
+between.getUpperBound().accept(this, context),
+true);
+return betweenPredicate;

Review Comment:
   we cannot meet between when we do expression translate



##
fe/fe-core/src/main/java/org/apache/doris/nereids/glue/translator/ExpressionTranslator.java:
##
@@ -141,10 +145,48 @@ public Expr visitNullSafeEqual(NullSafeEqual 
nullSafeEqual, PlanTranslatorContex
 
 @Override
 public Expr visitNot(Not not, PlanTranslatorContext context) {
-return new org.apache.doris.analysis.CompoundPredicate(
-org.apache.doris.analysis.CompoundPredicate.Operator.NOT,
-not.child(0).accept(this, context),
-null);
+if (not.child() instanceof InPredicate) {
+InPredicate inPredicate = (InPredicate) not.child();
+List inList = inPredicate.getOptions().stream()
+.map(e -> translate(e, context))
+.collect(Collectors.toList());
+return new org.apache.doris.analysis.InPredicate(
+inPredicate.getCompareExpr().accept(this, context),
+inList,
+true);
+} else if (not.child() instanceof Like) {
+Like like = (Like) not.child();
+LikePredicate likePredicate = (LikePredicate) visitLike(like, 
context);
+CompoundPredicate compoundPredicate = new 
CompoundPredicate(CompoundPredicate.Operator.NOT,
+likePredicate,
+null);
+return compoundPredicate;
+} else if (not.child() instanceof Regexp) {
+Regexp regexp = (Regexp) not.child();
+LikePredicate likePredicate = (LikePredicate) visitRegexp(regexp, 
context);
+CompoundPredicate compoundPredicate = new 
CompoundPredicate(CompoundPredicate.Operator.NOT,
+likePredicate,
+null);
+return compoundPredicate;

Review Comment:
   could merge into else?



-- 
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



[GitHub] [doris] stalary commented on a diff in pull request #11479: [Enhancement](IdGenerator) Use IdGeneratorBuffer to get better performance for getNextId operation when create table, truncate tabl

2022-08-03 Thread GitBox


stalary commented on code in PR #11479:
URL: https://github.com/apache/doris/pull/11479#discussion_r937236862


##
fe/fe-core/src/main/java/org/apache/doris/catalog/MetaIdGenerator.java:
##
@@ -41,16 +43,27 @@ public void setEditLog(EditLog editLog) {
 
 // performance is more quickly
 public synchronized long getNextId() {
-if (nextId < batchEndId) {
-return nextId++;
-} else {
+if (nextId >= batchEndId) {
 batchEndId = batchEndId + BATCH_ID_INTERVAL;
 if (editLog != null) {
 // add this check just for unit test
 editLog.logSaveNextId(batchEndId);
 }
-return nextId++;
 }
+return nextId++;
+}
+
+public synchronized IdGeneratorBuffer getIdGeneratorBuffer(long 
bufferSize) {
+Preconditions.checkState(bufferSize > 0);
+IdGeneratorBuffer idGeneratorBuffer = new IdGeneratorBuffer(nextId, 
nextId + bufferSize - 1);

Review Comment:
   I'm a little confused, It looks like we're getting ids in batches, Is the 
number of Editlog calls the same as before?The reason for the improvement is 
that getNextId no longer requires synchronized or reduce the number of Editlog 
calls?



##
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalDataSource.java:
##
@@ -2073,7 +2082,6 @@ private void createOdbcTable(Database db, CreateTableStmt 
stmt) throws DdlExcept
 ErrorReport.reportDdlException(ErrorCode.ERR_TABLE_EXISTS_ERROR, 
tableName);
 }
 LOG.info("successfully create table[{}-{}]", tableName, tableId);
-return;
 }
 
 private Table createEsTable(Database db, CreateTableStmt stmt) throws 
DdlException {

Review Comment:
   createEsTable return Table seems not used, Maybe delete it, too.



-- 
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



[GitHub] [doris] github-actions[bot] commented on pull request #11487: [improvement](outfile) support multibyte separator in outfile clause

2022-08-03 Thread GitBox


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

   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



[GitHub] [doris] stalary commented on a diff in pull request #11450: [feature](cold_on_s3) Show remote data usage

2022-08-03 Thread GitBox


stalary commented on code in PR #11450:
URL: https://github.com/apache/doris/pull/11450#discussion_r937251713


##
fe/fe-core/src/main/java/org/apache/doris/common/proc/TabletsProcDir.java:
##
@@ -45,7 +45,7 @@ public class TabletsProcDir implements ProcDirInterface {
 public static final ImmutableList TITLE_NAMES = new 
ImmutableList.Builder()
 
.add("TabletId").add("ReplicaId").add("BackendId").add("SchemaHash").add("Version")
 
.add("LstSuccessVersion").add("LstFailedVersion").add("LstFailedTime")
-.add("DataSize").add("RowCount").add("State")
+
.add("LocalDataSize").add("RemoteDataSize").add("RowCount").add("State")

Review Comment:
   This would cause compatibility problems, would using DataSize also work?



-- 
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



[GitHub] [doris] github-actions[bot] commented on pull request #11471: [doc](website)fe elastic scaling documentation issue

2022-08-03 Thread GitBox


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

   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



[GitHub] [doris] stalary commented on pull request #11386: [improvement](profile)fix profile may cause query slow

2022-08-03 Thread GitBox


stalary commented on PR #11386:
URL: https://github.com/apache/doris/pull/11386#issuecomment-1204631050

   It looks like you need rebase~


-- 
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-website] branch master updated: Fix doc (#28)

2022-08-03 Thread jiafengzheng
This is an automated email from the ASF dual-hosted git repository.

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


The following commit(s) were added to refs/heads/master by this push:
 new 917f520eb90 Fix doc (#28)
917f520eb90 is described below

commit 917f520eb90f487e46ab0416f8eb820b5d692909
Author: Liqf <109049295+lemonlit...@users.noreply.github.com>
AuthorDate: Thu Aug 4 08:48:36 2022 +0800

Fix doc (#28)

* fix-doc
---
 .../sql-functions/date-time-functions/current_timestamp.md   | 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/date_add.md| 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/date_format.md | 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/date_sub.md| 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/datediff.md| 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/day.md | 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/dayname.md | 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/dayofmonth.md  | 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/dayofweek.md   | 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/dayofyear.md   | 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/from_days.md   | 4 +++-
 docs/sql-manual/sql-functions/date-time-functions/from_unixtime.md   | 1 +
 docs/sql-manual/sql-functions/date-time-functions/hour.md| 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/makedate.md| 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/minute.md  | 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/month.md   | 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/monthname.md   | 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/now.md | 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/second.md  | 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/time_round.md  | 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/timediff.md| 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/timestampadd.md| 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/timestampdiff.md   | 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/to_days.md | 3 ++-
 docs/sql-manual/sql-functions/date-time-functions/utc_timestamp.md   | 4 +---
 docs/sql-manual/sql-functions/date-time-functions/week.md| 1 +
 docs/sql-manual/sql-functions/date-time-functions/yearweek.md| 1 +
 .../current/sql-manual/sql-functions/date-time-functions/hour.md | 3 ++-
 .../current/sql-manual/sql-functions/date-time-functions/minute.md   | 3 ++-
 .../current/sql-manual/sql-functions/date-time-functions/second.md   | 3 ++-
 .../sql-manual/sql-functions/date-time-functions/time_round.md   | 3 ++-
 .../sql-manual/sql-functions/date-time-functions/timestampadd.md | 3 ++-
 .../sql-manual/sql-functions/date-time-functions/timestampdiff.md| 5 +++--
 .../sql-manual/sql-functions/date-time-functions/utc_timestamp.md| 4 +---
 .../current/sql-manual/sql-functions/date-time-functions/week.md | 3 ++-
 .../current/sql-manual/sql-functions/date-time-functions/yearweek.md | 1 +
 36 files changed, 68 insertions(+), 37 deletions(-)

diff --git 
a/docs/sql-manual/sql-functions/date-time-functions/current_timestamp.md 
b/docs/sql-manual/sql-functions/date-time-functions/current_timestamp.md
index 412f0a095d8..7674d8f4a0c 100644
--- a/docs/sql-manual/sql-functions/date-time-functions/current_timestamp.md
+++ b/docs/sql-manual/sql-functions/date-time-functions/current_timestamp.md
@@ -44,4 +44,5 @@ mysql> select current_timestamp();
 +-+
 ```
 ### keywords
-CURRENT_TIMESTAMP,CURRENT,TIMESTAMP
+
+CURRENT_TIMESTAMP,CURRENT,TIMESTAMP
diff --git a/docs/sql-manual/sql-functions/date-time-functions/date_add.md 
b/docs/sql-manual/sql-functions/date-time-functions/date_add.md
index b1868755dcf..3623a6f28a4 100644
--- a/docs/sql-manual/sql-functions/date-time-functions/date_add.md
+++ b/docs/sql-manual/sql-functions/date-time-functions/date_add.md
@@ -50,4 +50,5 @@ mysql> select date_add('2010-11-30 23:59:59', INTERVAL 2 DAY);
 +-+
 ```
 ### keywords
-DATE_ADD,DATE,ADD
+
+DATE_ADD,DATE,ADD
diff --git a/docs/sql-manual/sql-functions/date-time-functions/date_format.md 
b/docs/sql-manual/sql-functions/date-time-functions/date_format.md
index 5ecfe0b983f..a2e90fcbde3 100644
--- a/docs/sql-manual/sql-functions/date-time-functions/date_format.md
+++ b/docs/sql-manual/sql-functions/date-time-functions/date_format.md
@@ -163,4 +163,5 @@ mysql> select date_format('2006-06-01', '%%%d');
 ++
 ```
 ### keywords
-DATE_FORMAT,DATE,FORMAT
+
+DATE_FORMAT,DATE,FORMAT
diff --git a/docs/sql-manual/sql-functions/date-time-functions/date

[GitHub] [doris] yiguolei merged pull request #11487: [improvement](outfile) support multibyte separator in outfile clause

2022-08-03 Thread GitBox


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


-- 
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: [improvement](outfile) support multibyte separator in outfile clause (#11487)

2022-08-03 Thread yiguolei
This is an automated email from the ASF dual-hosted git repository.

yiguolei 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 33053ad1fe [improvement](outfile) support multibyte separator in 
outfile clause (#11487)
33053ad1fe is described below

commit 33053ad1fea00c70240e8d32b6d5fad3f2960517
Author: Mingyu Chen 
AuthorDate: Thu Aug 4 09:06:06 2022 +0800

[improvement](outfile) support multibyte separator in outfile clause 
(#11487)
---
 .../org/apache/doris/analysis/OutFileClause.java   |   6 +-
 .../data/export/test_outfile_separator.out |  10 ++
 .../suites/export/test_outfile_separator.groovy| 102 +
 3 files changed, 116 insertions(+), 2 deletions(-)

diff --git 
a/fe/fe-core/src/main/java/org/apache/doris/analysis/OutFileClause.java 
b/fe/fe-core/src/main/java/org/apache/doris/analysis/OutFileClause.java
index 95ef74c5ba..a66bd3b9bb 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/OutFileClause.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/OutFileClause.java
@@ -379,7 +379,7 @@ public class OutFileClause {
 if (!isCsvFormat()) {
 throw new AnalysisException(PROP_COLUMN_SEPARATOR + " is only 
for CSV format");
 }
-columnSeparator = properties.get(PROP_COLUMN_SEPARATOR);
+columnSeparator = 
Separator.convertSeparator(properties.get(PROP_COLUMN_SEPARATOR));
 processedPropKeys.add(PROP_COLUMN_SEPARATOR);
 }
 
@@ -387,7 +387,7 @@ public class OutFileClause {
 if (!isCsvFormat()) {
 throw new AnalysisException(PROP_LINE_DELIMITER + " is only 
for CSV format");
 }
-lineDelimiter = properties.get(PROP_LINE_DELIMITER);
+lineDelimiter = 
Separator.convertSeparator(properties.get(PROP_LINE_DELIMITER));
 processedPropKeys.add(PROP_LINE_DELIMITER);
 }
 
@@ -583,3 +583,5 @@ public class OutFileClause {
 return sinkOptions;
 }
 }
+
+
diff --git a/regression-test/data/export/test_outfile_separator.out 
b/regression-test/data/export/test_outfile_separator.out
new file mode 100644
index 00..e1ad11da09
--- /dev/null
+++ b/regression-test/data/export/test_outfile_separator.out
@@ -0,0 +1,10 @@
+-- This file is automatically generated. You should know what you did if you 
want to edit this
+-- !select_1 --
+1  abc
+2  def
+
+-- !select_2 --
+1  abc
+1  abc
+2  def
+2  def
diff --git a/regression-test/suites/export/test_outfile_separator.groovy 
b/regression-test/suites/export/test_outfile_separator.groovy
new file mode 100644
index 00..fb869c5eb0
--- /dev/null
+++ b/regression-test/suites/export/test_outfile_separator.groovy
@@ -0,0 +1,102 @@
+// 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.
+
+import org.codehaus.groovy.runtime.IOGroovyMethods
+
+import java.nio.charset.StandardCharsets
+import java.nio.file.Files
+import java.nio.file.Paths
+
+suite("test_outfile", "separator") {
+StringBuilder strBuilder = new StringBuilder()
+strBuilder.append("curl --location-trusted -u " + context.config.jdbcUser 
+ ":" + context.config.jdbcPassword)
+strBuilder.append(" http://"; + context.config.feHttpAddress + 
"/rest/v1/config/fe")
+
+String command = strBuilder.toString()
+def process = command.toString().execute()
+def code = process.waitFor()
+def err = IOGroovyMethods.getText(new BufferedReader(new 
InputStreamReader(process.getErrorStream(;
+def out = process.getText()
+logger.info("Request FE Config: code=" + code + ", out=" + out + ", err=" 
+ err)
+assertEquals(code, 0)
+def response = parseJson(out.trim())
+assertEquals(response.code, 0)
+assertEquals(response.msg, "success")
+def configJson = response.data.rows
+boolean enableOutfileToLocal = false
+for (Object conf: configJson) {
+assert conf instanceof Map
+if (((Map) conf).get("Name").toLowerCase() == 
"enable_outfile_to_local") {
+enableOutfileToLocal = ((Map) 
conf).get("Value").toLowerCase() == "true"
+

[GitHub] [doris] morningman commented on pull request #11474: [BugFix](BE) fix condition index doesn't match

2022-08-03 Thread GitBox


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

   Please fill the Checklist


-- 
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



[GitHub] [doris] morningman commented on a diff in pull request #11468: [Refactor](push-down predicate) WIP

2022-08-03 Thread GitBox


morningman commented on code in PR #11468:
URL: https://github.com/apache/doris/pull/11468#discussion_r937262759


##
build.sh:
##
@@ -84,7 +84,7 @@ clean_be() {
 
 # "build.sh --clean" just cleans and exits, however CMAKE_BUILD_DIR is set
 # while building be.
-CMAKE_BUILD_TYPE=${BUILD_TYPE:-Release}

Review Comment:
   why change this?



-- 
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



[GitHub] [doris] yiguolei merged pull request #11463: [Bug](function) fix current_date not equal to curdate

2022-08-03 Thread GitBox


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


-- 
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 (33053ad1fe -> ce68d24e95)

2022-08-03 Thread yiguolei
This is an automated email from the ASF dual-hosted git repository.

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


from 33053ad1fe [improvement](outfile) support multibyte separator in 
outfile clause (#11487)
 add ce68d24e95 [Bug](function) fix current_date not equal to curdate 
(#11463)

No new revisions were added by this update.

Summary of changes:
 be/src/vec/runtime/vdatetime_value.cpp |  5 +
 .../src/main/java/org/apache/doris/analysis/DateLiteral.java   | 10 ++
 fe/fe-core/src/main/java/org/apache/doris/analysis/Expr.java   |  2 +-
 .../sql_functions/datetime_functions/test_date_function.out|  6 ++
 .../sql_functions/datetime_functions/test_date_function.groovy |  3 +++
 5 files changed, 21 insertions(+), 5 deletions(-)


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



[GitHub] [doris] yiguolei closed issue #11451: [Bug] CURRENT_DATE函数返回日期无法与日期常量正确比较

2022-08-03 Thread GitBox


yiguolei closed issue #11451: [Bug] CURRENT_DATE函数返回日期无法与日期常量正确比较
URL: https://github.com/apache/doris/issues/11451


-- 
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



[GitHub] [doris] github-actions[bot] commented on pull request #11479: [Enhancement](IdGenerator) Use IdGeneratorBuffer to get better performance for getNextId operation when create table, truncate ta

2022-08-03 Thread GitBox


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

   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



[GitHub] [doris] github-actions[bot] commented on pull request #11479: [Enhancement](IdGenerator) Use IdGeneratorBuffer to get better performance for getNextId operation when create table, truncate ta

2022-08-03 Thread GitBox


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

   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



[GitHub] [doris] wangbo commented on pull request #11475: [refactor](schema change) Using tablet schema shared ptr instead of raw ptr

2022-08-03 Thread GitBox


wangbo commented on PR #11475:
URL: https://github.com/apache/doris/pull/11475#issuecomment-1204662327

   Have you done a stress test to see whether this is a performance drop for 
this pr?


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

To unsubscribe, e-mail: 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



[GitHub] [doris] Jibing-Li opened a new pull request, #11489: Oss

2022-08-03 Thread GitBox


Jibing-Li opened a new pull request, #11489:
URL: https://github.com/apache/doris/pull/11489

   # Proposed changes
   
   Issue Number: close #xxx
   
   ## Problem summary
   
   Describe your changes.
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [ ] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [ ] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [ ] No
   
   ## 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



[GitHub] [doris] caiconghui commented on a diff in pull request #11479: [Enhancement](IdGenerator) Use IdGeneratorBuffer to get better performance for getNextId operation when create table, truncate t

2022-08-03 Thread GitBox


caiconghui commented on code in PR #11479:
URL: https://github.com/apache/doris/pull/11479#discussion_r937285824


##
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalDataSource.java:
##
@@ -2073,7 +2082,6 @@ private void createOdbcTable(Database db, CreateTableStmt 
stmt) throws DdlExcept
 ErrorReport.reportDdlException(ErrorCode.ERR_TABLE_EXISTS_ERROR, 
tableName);
 }
 LOG.info("successfully create table[{}-{}]", tableName, tableId);
-return;
 }
 
 private Table createEsTable(Database db, CreateTableStmt stmt) throws 
DdlException {

Review Comment:
   may be solved in other PR, it cost long time to run pipeline test 



-- 
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



[GitHub] [doris] zy-kkk opened a new pull request, #11490: improve the create table err msg

2022-08-03 Thread GitBox


zy-kkk opened a new pull request, #11490:
URL: https://github.com/apache/doris/pull/11490

   improve the err msg returned when the key not in columns when create table
   
   # Proposed changes
   
   Issue Number: close #xxx
   
   ## Problem summary
   
   Describe your changes.
   
   ## Checklist(Required)
   
   1. Does it affect the original behavior: 
   - [ ] Yes
   - [ ] No
   - [ ] I don't know
   2. Has unit tests been added:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   3. Has document been added or modified:
   - [ ] Yes
   - [ ] No
   - [ ] No Need
   4. Does it need to update dependencies:
   - [ ] Yes
   - [ ] No
   5. Are there any changes that cannot be rolled back:
   - [ ] Yes (If Yes, please explain WHY)
   - [ ] No
   
   ## 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



[GitHub] [doris] stalary commented on a diff in pull request #11479: [Enhancement](IdGenerator) Use IdGeneratorBuffer to get better performance for getNextId operation when create table, truncate tabl

2022-08-03 Thread GitBox


stalary commented on code in PR #11479:
URL: https://github.com/apache/doris/pull/11479#discussion_r937286386


##
fe/fe-core/src/main/java/org/apache/doris/datasource/InternalDataSource.java:
##
@@ -2073,7 +2082,6 @@ private void createOdbcTable(Database db, CreateTableStmt 
stmt) throws DdlExcept
 ErrorReport.reportDdlException(ErrorCode.ERR_TABLE_EXISTS_ERROR, 
tableName);
 }
 LOG.info("successfully create table[{}-{}]", tableName, tableId);
-return;
 }
 
 private Table createEsTable(Database db, CreateTableStmt stmt) throws 
DdlException {

Review Comment:
   ok~



-- 
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



[GitHub] [doris] caiconghui commented on a diff in pull request #11479: [Enhancement](IdGenerator) Use IdGeneratorBuffer to get better performance for getNextId operation when create table, truncate t

2022-08-03 Thread GitBox


caiconghui commented on code in PR #11479:
URL: https://github.com/apache/doris/pull/11479#discussion_r937286463


##
fe/fe-core/src/main/java/org/apache/doris/catalog/MetaIdGenerator.java:
##
@@ -41,16 +43,27 @@ public void setEditLog(EditLog editLog) {
 
 // performance is more quickly
 public synchronized long getNextId() {
-if (nextId < batchEndId) {
-return nextId++;
-} else {
+if (nextId >= batchEndId) {
 batchEndId = batchEndId + BATCH_ID_INTERVAL;
 if (editLog != null) {
 // add this check just for unit test
 editLog.logSaveNextId(batchEndId);
 }
-return nextId++;
 }
+return nextId++;
+}
+
+public synchronized IdGeneratorBuffer getIdGeneratorBuffer(long 
bufferSize) {
+Preconditions.checkState(bufferSize > 0);
+IdGeneratorBuffer idGeneratorBuffer = new IdGeneratorBuffer(nextId, 
nextId + bufferSize - 1);

Review Comment:
   the time cost for meta management should be as small as possible, because 
the editlog is shared by the whole cluster, when there are many dbs, tables, 
tablets, it is easy to see poor performance for meta-management



-- 
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



[GitHub] [doris] englefly commented on a diff in pull request #11209: [feature] (Nereids) support limit clause

2022-08-03 Thread GitBox


englefly commented on code in PR #11209:
URL: https://github.com/apache/doris/pull/11209#discussion_r937289497


##
fe/fe-core/src/main/java/org/apache/doris/statistics/StatsDeriveResult.java:
##
@@ -112,10 +112,22 @@ public void setSlotToColumnStats(Map 
slotToColumnStats) {
 this.slotToColumnStats = slotToColumnStats;
 }
 
-public StatsDeriveResult multiplyDouble(double selectivity) {
+public StatsDeriveResult updateRowCountBySelectivity(double selectivity) {
 rowCount *= selectivity;
 for (Entry entry : slotToColumnStats.entrySet()) {
-entry.getValue().multiplyDouble(selectivity);
+entry.getValue().updateBySelectivity(selectivity);

Review Comment:
   @morrySnow @924060929 请看看这里用selectivity是否更合理



-- 
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



[GitHub] [doris] yiguolei merged pull request #11485: [enhancement](memtracker) Optimize exceed memory limit log readability

2022-08-03 Thread GitBox


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


-- 
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



[GitHub] [doris] yiguolei closed issue #11480: [Enhancement] exceed memory limit readability

2022-08-03 Thread GitBox


yiguolei closed issue #11480: [Enhancement] exceed memory limit readability
URL: https://github.com/apache/doris/issues/11480


-- 
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: [bugfix](memtracker)fix exceed memory limit log (#11485)

2022-08-03 Thread yiguolei
This is an automated email from the ASF dual-hosted git repository.

yiguolei 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 ecbf87d77b [bugfix](memtracker)fix exceed memory limit log (#11485)
ecbf87d77b is described below

commit ecbf87d77b36e345d9cf6deb6a776f2344de3bdc
Author: Xinyi Zou 
AuthorDate: Thu Aug 4 10:22:20 2022 +0800

[bugfix](memtracker)fix exceed memory limit log (#11485)
---
 be/src/exec/cross_join_node.cpp  |  1 -
 be/src/exec/es/es_scroll_parser.cpp  | 11 ++---
 be/src/exec/except_node.cpp  |  1 -
 be/src/exec/hash_join_node.cpp   |  2 -
 be/src/exec/intersect_node.cpp   |  1 -
 be/src/exec/olap_scanner.cpp |  5 +-
 be/src/exec/partitioned_aggregation_node.cc  | 10 ++--
 be/src/exec/partitioned_hash_table.cc|  7 ++-
 be/src/exec/set_operation_node.cpp   |  1 -
 be/src/exprs/anyval_util.cpp |  6 +--
 be/src/exprs/expr_context.cpp|  6 +--
 be/src/runtime/mem_pool.h| 43 +++--
 be/src/runtime/memory/mem_tracker_limiter.cpp| 59 +++-
 be/src/runtime/memory/mem_tracker_limiter.h  | 16 +++
 be/src/runtime/memory/mem_tracker_task_pool.cpp  |  8 ++--
 be/src/runtime/memory/thread_mem_tracker_mgr.cpp | 31 ++---
 be/src/runtime/memory/thread_mem_tracker_mgr.h   | 41 +++-
 be/src/runtime/plan_fragment_executor.cpp|  1 +
 be/src/runtime/runtime_state.cpp |  4 +-
 be/src/runtime/thread_context.cpp| 18 
 be/src/runtime/thread_context.h  | 40 +---
 be/src/vec/exec/join/vhash_join_node.cpp |  1 -
 be/src/vec/exec/vaggregation_node.cpp|  2 -
 be/src/vec/exec/vcross_join_node.cpp |  1 -
 be/src/vec/exec/vset_operation_node.cpp  |  1 -
 25 files changed, 106 insertions(+), 211 deletions(-)

diff --git a/be/src/exec/cross_join_node.cpp b/be/src/exec/cross_join_node.cpp
index c80560bf82..fe748904f0 100644
--- a/be/src/exec/cross_join_node.cpp
+++ b/be/src/exec/cross_join_node.cpp
@@ -52,7 +52,6 @@ Status CrossJoinNode::close(RuntimeState* state) {
 Status CrossJoinNode::construct_build_side(RuntimeState* state) {
 // Do a full scan of child(1) and store all build row batches.
 RETURN_IF_ERROR(child(1)->open(state));
-SCOPED_UPDATE_MEM_EXCEED_CALL_BACK("Cross join, while getting next from 
child 1");
 
 while (true) {
 RowBatch* batch =
diff --git a/be/src/exec/es/es_scroll_parser.cpp 
b/be/src/exec/es/es_scroll_parser.cpp
index a95af7bb51..7170057ac2 100644
--- a/be/src/exec/es/es_scroll_parser.cpp
+++ b/be/src/exec/es/es_scroll_parser.cpp
@@ -348,12 +348,11 @@ Status ScrollParser::fill_tuple(const TupleDescriptor* 
tuple_desc, Tuple* tuple,
 // obj[FIELD_ID] must not be nullptr
 std::string _id = obj[FIELD_ID].GetString();
 size_t len = _id.length();
-Status rst;
-char* buffer = 
reinterpret_cast(tuple_pool->try_allocate_unaligned(len, &rst));
+char* buffer = 
reinterpret_cast(tuple_pool->try_allocate_unaligned(len));
 if (UNLIKELY(buffer == nullptr)) {
 std::string details = 
strings::Substitute(ERROR_MEM_LIMIT_EXCEEDED,
   
"MaterializeNextRow", len, "string slot");
-RETURN_LIMIT_EXCEEDED(nullptr, details, len, rst);
+RETURN_LIMIT_EXCEEDED(nullptr, details, len);
 }
 memcpy(buffer, _id.data(), len);
 reinterpret_cast(slot)->ptr = buffer;
@@ -407,13 +406,11 @@ Status ScrollParser::fill_tuple(const TupleDescriptor* 
tuple_desc, Tuple* tuple,
 }
 }
 size_t val_size = val.length();
-Status rst;
-char* buffer =
-
reinterpret_cast(tuple_pool->try_allocate_unaligned(val_size, &rst));
+char* buffer = 
reinterpret_cast(tuple_pool->try_allocate_unaligned(val_size));
 if (UNLIKELY(buffer == nullptr)) {
 std::string details = strings::Substitute(
 ERROR_MEM_LIMIT_EXCEEDED, "MaterializeNextRow", 
val_size, "string slot");
-RETURN_LIMIT_EXCEEDED(nullptr, details, val_size, rst);
+RETURN_LIMIT_EXCEEDED(nullptr, details, val_size);
 }
 memcpy(buffer, val.data(), val_size);
 reinterpret_cast(slot)->ptr = buffer;
diff --git a/be/src/exec/except_node.cpp b/be/src/exec/except_node.cpp
index 8084fb47f4..8ad7ce9044 100644
--- a/be/src/exec/except_node.cpp
+++ b/be/src/exec/except_node.cpp
@@ -40,7 +40,6 @@ Status ExceptNode::init(const TPlanNode& tnode, RuntimeState* 
state) {
 
 

  1   2   >