Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


codope merged PR #10225:
URL: https://github.com/apache/hudi/pull/10225


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1851286731

   
   ## CI report:
   
   * 8cc63ddef9ccc12489d0461f1c928e5c579b9277 UNKNOWN
   * bf5722620a6d6c4ab30944c2ebec3d17cd65f625 Azure: 
[SUCCESS](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21458)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1851169658

   
   ## CI report:
   
   * 8cc63ddef9ccc12489d0461f1c928e5c579b9277 UNKNOWN
   * df5bfa4109fe772403e52248e44347c4d682d5ea Azure: 
[SUCCESS](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21452)
 
   * bf5722620a6d6c4ab30944c2ebec3d17cd65f625 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21458)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1851164410

   
   ## CI report:
   
   * 8cc63ddef9ccc12489d0461f1c928e5c579b9277 UNKNOWN
   * df5bfa4109fe772403e52248e44347c4d682d5ea Azure: 
[SUCCESS](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21452)
 
   * bf5722620a6d6c4ab30944c2ebec3d17cd65f625 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1851113359

   
   ## CI report:
   
   * 8cc63ddef9ccc12489d0461f1c928e5c579b9277 UNKNOWN
   * df5bfa4109fe772403e52248e44347c4d682d5ea Azure: 
[SUCCESS](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21452)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


yihua commented on code in PR #10225:
URL: https://github.com/apache/hudi/pull/10225#discussion_r1423231130


##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/hudi/DefaultSource.scala:
##
@@ -285,7 +285,12 @@ object DefaultSource {
 resolveBaseFileOnlyRelation(sqlContext, globPaths, userSchema, 
metaClient, parameters)
   }
 case (COPY_ON_WRITE, QUERY_TYPE_INCREMENTAL_OPT_VAL, _) =>
-  new IncrementalRelation(sqlContext, parameters, userSchema, 
metaClient)
+  if (fileFormatUtils.isDefined) {
+new HoodieCopyOnWriteIncrementalHadoopFsRelationFactory(
+  sqlContext, metaClient, parameters, userSchema, isBootstrap = 
false).build()

Review Comment:
   `isBootstrappedTable` instead of `isBootstrap = false`?
   ```suggestion
 sqlContext, metaClient, parameters, userSchema, 
isBootstrappedTable).build()
   ```



-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


yihua commented on code in PR #10225:
URL: https://github.com/apache/hudi/pull/10225#discussion_r1423228983


##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/spark/sql/execution/datasources/parquet/HoodieFileGroupReaderBasedParquetFileFormat.scala:
##
@@ -65,6 +66,8 @@ class HoodieFileGroupReaderBasedParquetFileFormat(tableState: 
HoodieTableState,
   requiredFilters: Seq[Filter]
) extends ParquetFileFormat with 
SparkAdapterSupport with HoodieFormatTrait {
 
+  override def getRequiredFilters: Seq[Filter] = requiredFilters

Review Comment:
   I'm not particularly asking about this line.  We support `hoodie.data 
source.read.incr.filters` in `IncrementalRelation`.  Wondering if we also have 
the same support in the new file format class.



-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1850939526

   
   ## CI report:
   
   * 001b4c8494554f56e4e53bea3fb975996869c060 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21451)
 
   * 8cc63ddef9ccc12489d0461f1c928e5c579b9277 UNKNOWN
   * df5bfa4109fe772403e52248e44347c4d682d5ea Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21452)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1850929264

   
   ## CI report:
   
   * 001b4c8494554f56e4e53bea3fb975996869c060 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21451)
 
   * 8cc63ddef9ccc12489d0461f1c928e5c579b9277 UNKNOWN
   * df5bfa4109fe772403e52248e44347c4d682d5ea UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1850919208

   
   ## CI report:
   
   * 001b4c8494554f56e4e53bea3fb975996869c060 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21451)
 
   * 8cc63ddef9ccc12489d0461f1c928e5c579b9277 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1850863197

   
   ## CI report:
   
   * d07f06051fa4afa5fdc6c8702ce9a67834fc25d5 Azure: 
[SUCCESS](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21418)
 
   * 001b4c8494554f56e4e53bea3fb975996869c060 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21451)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1850853119

   
   ## CI report:
   
   * d07f06051fa4afa5fdc6c8702ce9a67834fc25d5 Azure: 
[SUCCESS](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21418)
 
   * 001b4c8494554f56e4e53bea3fb975996869c060 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


jonvex commented on code in PR #10225:
URL: https://github.com/apache/hudi/pull/10225#discussion_r1423078620


##
hudi-spark-datasource/hudi-spark/src/test/scala/org/apache/spark/sql/hudi/procedure/TestClusteringProcedure.scala:
##
@@ -50,31 +50,32 @@ class TestClusteringProcedure extends 
HoodieSparkProcedureTestBase {
  |  id int,
  |  name string,
  |  price double,
- |  ts long
+ |  ts long,
+ |  partition long
  |) using hudi
  | options (
  |  primaryKey ='id',
  |  type = '$tableType',
  |  preCombineField = 'ts'
  | )
- | partitioned by(ts)
+ | partitioned by(partition)

Review Comment:
   Using the partition field as precombine makes no sense and should not be done



-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


jonvex commented on code in PR #10225:
URL: https://github.com/apache/hudi/pull/10225#discussion_r1423071517


##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/spark/sql/execution/datasources/parquet/HoodieFileGroupReaderBasedParquetFileFormat.scala:
##
@@ -278,6 +276,8 @@ class 
HoodieFileGroupReaderBasedParquetFileFormat(tableState: HoodieTableState,
 val baseFileReader = super.buildReaderWithPartitionValues(sparkSession, 
dataSchema, partitionSchema, requiredSchema,
   filters ++ requiredFilters, options, new Configuration(hadoopConf))
 m.put(generateKey(dataSchema, requiredSchema), baseFileReader)
+m.put(0, super.buildReaderWithPartitionValues(sparkSession, dataSchema, 
partitionSchema, requiredSchema,

Review Comment:
   This isn't needed anymore so I got rid of it. The chance of a collision is 
2^64 so not likely



-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


jonvex commented on code in PR #10225:
URL: https://github.com/apache/hudi/pull/10225#discussion_r1423068962


##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/spark/sql/NewFileFormatUtils.scala:
##
@@ -0,0 +1,146 @@
+/*
+ * 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.
+ */
+
+/*
+ * 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.spark.sql
+
+import org.apache.hudi.{HoodieCDCFileIndex, SparkAdapterSupport, 
SparkHoodieTableFileIndex}
+import org.apache.spark.sql.catalyst.expressions.{And, Attribute, 
AttributeSet, Contains, EndsWith, EqualNullSafe, EqualTo, Expression, 
GreaterThan, GreaterThanOrEqual, In, IsNotNull, IsNull, LessThan, 
LessThanOrEqual, Literal, NamedExpression, Not, Or, StartsWith}
+import org.apache.spark.sql.catalyst.plans.logical.{Filter, Join, LogicalPlan, 
Project}
+import org.apache.spark.sql.execution.datasources.HadoopFsRelation
+import org.apache.spark.sql.execution.datasources.parquet.{HoodieFormatTrait, 
ParquetFileFormat}
+import org.apache.spark.sql.types.{BooleanType, StructType}
+
+import scala.util.Try
+
+object NewFileFormatUtils extends SparkAdapterSupport {
+
+  def applyNewFileFormatChanges(scanOperation: LogicalPlan, logicalRelation: 
LogicalPlan, fs: HadoopFsRelation): LogicalPlan = {
+val ff = fs.fileFormat.asInstanceOf[ParquetFileFormat with 
HoodieFormatTrait]
+ff.isProjected = true
+val tableSchema = fs.location match {
+  case index: HoodieCDCFileIndex => index.cdcRelation.schema
+  case index: SparkHoodieTableFileIndex => index.schema
+}
+val resolvedSchema = logicalRelation.resolve(tableSchema, 
fs.sparkSession.sessionState.analyzer.resolver)
+val unfilteredPlan = if (!fs.partitionSchema.fields.isEmpty && 
sparkAdapter.getCatalystPlanUtils.sameOutput(scanOperation, logicalRelation)) {
+  Project(resolvedSchema, scanOperation)
+} else {
+  scanOperation
+}
+applyFiltersToPlan(unfilteredPlan, tableSchema, resolvedSchema, 
ff.getRequiredFilters)
+  }
+
+  /**
+   * adapted from 
https://github.com/apache/spark/blob/20df062d85e80422a55afae80ddbf2060f26516c/sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/StructFilters.scala
+   */
+  def applyFiltersToPlan(plan: LogicalPlan, tableSchema: StructType, 
resolvedSchema: Seq[Attribute], filters: 
Seq[org.apache.spark.sql.sources.Filter]): LogicalPlan = {
+
+def filterToExpression(
+filter: sources.Filter,
+toRef: String => Option[NamedExpression]): 
Option[Expression] = {
+  def zipAttributeAndValue(name: String, value: Any): 
Option[(NamedExpression, Literal)] = {
+zip(toRef(name), toLiteral(value))
+  }
+
+  def translate(filter: sources.Filter): Option[Expression] = filter match 
{
+case sources.And(left, right) =>
+  zip(translate(left), translate(right)).map(And.tupled)
+case sources.Or(left, right) =>
+  zip(translate(left), translate(right)).map(Or.tupled)
+case sources.Not(child) =>
+  translate(child).map(Not)
+case sources.EqualTo(attribute, value) =>
+  zipAttributeAndValue(attribute, value).map(EqualTo.tupled)
+case sources.EqualNullSafe(attribute, value) =>
+  zipAttributeAndValue(attribute, value).map(EqualNullSafe.tupled)
+case sources.IsNull(attribute) =>
+  toRef(attribute).map(IsNull)
+case 

Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


jonvex commented on code in PR #10225:
URL: https://github.com/apache/hudi/pull/10225#discussion_r1423066933


##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/spark/sql/NewFileFormatUtils.scala:
##
@@ -0,0 +1,146 @@
+/*
+ * 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.
+ */
+
+/*
+ * 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.spark.sql
+
+import org.apache.hudi.{HoodieCDCFileIndex, SparkAdapterSupport, 
SparkHoodieTableFileIndex}
+import org.apache.spark.sql.catalyst.expressions.{And, Attribute, 
AttributeSet, Contains, EndsWith, EqualNullSafe, EqualTo, Expression, 
GreaterThan, GreaterThanOrEqual, In, IsNotNull, IsNull, LessThan, 
LessThanOrEqual, Literal, NamedExpression, Not, Or, StartsWith}
+import org.apache.spark.sql.catalyst.plans.logical.{Filter, Join, LogicalPlan, 
Project}
+import org.apache.spark.sql.execution.datasources.HadoopFsRelation
+import org.apache.spark.sql.execution.datasources.parquet.{HoodieFormatTrait, 
ParquetFileFormat}
+import org.apache.spark.sql.types.{BooleanType, StructType}
+
+import scala.util.Try
+
+object NewFileFormatUtils extends SparkAdapterSupport {

Review Comment:
   I should actually create a pr to delete NewHoodieParquetFileFormat entirely



-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


jonvex commented on code in PR #10225:
URL: https://github.com/apache/hudi/pull/10225#discussion_r1423065162


##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/hudi/HoodieCDCFileIndex.scala:
##
@@ -78,4 +79,8 @@ class HoodieCDCFileIndex (override val spark: SparkSession,
   new Path(fileGroupId.getPartitionPath, fileGroupId.getFileId).toString
 }.toArray
   }
+
+  override def getRequiredFilters: Seq[Filter] = {
+Seq.empty

Review Comment:
   CDC queries return 4 cols: op, ts_ms, before, after. The incremental filters 
are on the field "_hoodie_commit_time" so we will get an exception if we try to 
filter on that. If you look at CDCRelation you can see that buildScan0 does not 
use filters. So from that info + checking with @linliu-code I think this is 
correct course of action



-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


jonvex commented on code in PR #10225:
URL: https://github.com/apache/hudi/pull/10225#discussion_r1423050939


##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/spark/sql/NewFileFormatUtils.scala:
##
@@ -0,0 +1,146 @@
+/*
+ * 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.
+ */
+
+/*
+ * 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.
+ */

Review Comment:
   yep



-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


jonvex commented on code in PR #10225:
URL: https://github.com/apache/hudi/pull/10225#discussion_r1422912797


##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/spark/sql/execution/datasources/parquet/HoodieFileGroupReaderBasedParquetFileFormat.scala:
##
@@ -65,6 +66,8 @@ class HoodieFileGroupReaderBasedParquetFileFormat(tableState: 
HoodieTableState,
   requiredFilters: Seq[Filter]
) extends ParquetFileFormat with 
SparkAdapterSupport with HoodieFormatTrait {
 
+  override def getRequiredFilters: Seq[Filter] = requiredFilters

Review Comment:
   No. The override is implementing the method from the trait. I think 
"override" might not be necessary



-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


codope commented on code in PR #10225:
URL: https://github.com/apache/hudi/pull/10225#discussion_r1422874813


##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/hudi/DefaultSource.scala:
##
@@ -303,8 +308,21 @@ object DefaultSource {
 HoodieBootstrapMORRelation(sqlContext, userSchema, globPaths, 
metaClient, parameters)
   }
 
-case (MERGE_ON_READ, QUERY_TYPE_INCREMENTAL_OPT_VAL, _) =>
-  MergeOnReadIncrementalRelation(sqlContext, parameters, metaClient, 
userSchema)
+case (MERGE_ON_READ, QUERY_TYPE_INCREMENTAL_OPT_VAL, true) =>
+  if (fileFormatUtils.isDefined) {
+new HoodieMergeOnReadIncrementalHadoopFsRelationFactory(
+  sqlContext, metaClient, parameters, userSchema, isBootstrap = 
true).build()
+  } else {
+MergeOnReadIncrementalRelation(sqlContext, parameters, metaClient, 
userSchema)
+  }
+
+case (MERGE_ON_READ, QUERY_TYPE_INCREMENTAL_OPT_VAL, false) =>

Review Comment:
   this case can be merged with the above case right?



##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/hudi/HoodieCDCFileIndex.scala:
##
@@ -28,11 +28,12 @@ import org.apache.spark.sql.SparkSession
 import org.apache.spark.sql.catalyst.InternalRow
 import org.apache.spark.sql.catalyst.expressions.{Expression, 
GenericInternalRow}
 import org.apache.spark.sql.execution.datasources.{FileIndex, FileStatusCache, 
NoopCache, PartitionDirectory}
+import org.apache.spark.sql.sources.Filter
 import org.apache.spark.sql.types.StructType
 
 import scala.jdk.CollectionConverters.{asScalaBufferConverter, 
mapAsScalaMapConverter}
 
-class HoodieCDCFileIndex (override val spark: SparkSession,
+class HoodieCDCFileIndex(override val spark: SparkSession,

Review Comment:
   nit: fix the indentation



##
hudi-client/hudi-spark-client/src/main/scala/org/apache/spark/sql/HoodieCatalystPlansUtils.scala:
##
@@ -140,4 +142,6 @@ trait HoodieCatalystPlansUtils {
   def failAnalysisForMIT(a: Attribute, cols: String): Unit = {}
 
   def createMITJoin(left: LogicalPlan, right: LogicalPlan, joinType: JoinType, 
condition: Option[Expression], hint: String): LogicalPlan
+
+  def sameOutput(a: LogicalPlan, b: LogicalPlan): Boolean

Review Comment:
   please add scaladoc



##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/spark/sql/execution/datasources/parquet/HoodieFileGroupReaderBasedParquetFileFormat.scala:
##
@@ -278,6 +276,8 @@ class 
HoodieFileGroupReaderBasedParquetFileFormat(tableState: HoodieTableState,
 val baseFileReader = super.buildReaderWithPartitionValues(sparkSession, 
dataSchema, partitionSchema, requiredSchema,
   filters ++ requiredFilters, options, new Configuration(hadoopConf))
 m.put(generateKey(dataSchema, requiredSchema), baseFileReader)
+m.put(0, super.buildReaderWithPartitionValues(sparkSession, dataSchema, 
partitionSchema, requiredSchema,

Review Comment:
   What's the reason of key being hard-coded to 0 here? Also, is there any 
chance that the key evaluated in line 278 above i.e. `generateKey(dataSchema, 
requiredSchema)` can be 0. In that case, this line will override, which may not 
be the expected behavior. 



##
hudi-spark-datasource/hudi-spark/src/test/scala/org/apache/spark/sql/hudi/procedure/TestClusteringProcedure.scala:
##
@@ -50,31 +50,32 @@ class TestClusteringProcedure extends 
HoodieSparkProcedureTestBase {
  |  id int,
  |  name string,
  |  price double,
- |  ts long
+ |  ts long,
+ |  partition long
  |) using hudi
  | options (
  |  primaryKey ='id',
  |  type = '$tableType',
  |  preCombineField = 'ts'
  | )
- | partitioned by(ts)
+ | partitioned by(partition)

Review Comment:
   why is there a need to change the table schema for test? Moreover, the new 
partition firld has the same type as the old one, so i'm not sure if it adds 
any value for the test.



##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/spark/sql/NewFileFormatUtils.scala:
##
@@ -0,0 +1,146 @@
+/*
+ * 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 

Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


jonvex commented on code in PR #10225:
URL: https://github.com/apache/hudi/pull/10225#discussion_r1422909066


##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/spark/sql/execution/datasources/parquet/HoodieFileGroupReaderBasedParquetFileFormat.scala:
##
@@ -278,6 +276,8 @@ class 
HoodieFileGroupReaderBasedParquetFileFormat(tableState: HoodieTableState,
 val baseFileReader = super.buildReaderWithPartitionValues(sparkSession, 
dataSchema, partitionSchema, requiredSchema,
   filters ++ requiredFilters, options, new Configuration(hadoopConf))
 m.put(generateKey(dataSchema, requiredSchema), baseFileReader)
+m.put(0, super.buildReaderWithPartitionValues(sparkSession, dataSchema, 
partitionSchema, requiredSchema,

Review Comment:
   I'm not sure. I don't think this line is needed. 



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

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

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


jonvex commented on code in PR #10225:
URL: https://github.com/apache/hudi/pull/10225#discussion_r1422901237


##
hudi-common/src/main/java/org/apache/hudi/internal/schema/utils/AvroSchemaEvolutionUtils.java:
##
@@ -140,10 +140,14 @@ public static Schema reconcileSchema(Schema 
incomingSchema, Schema oldTableSchem
* @return schema (based off {@code source} one) that has nullability 
constraints and datatypes reconciled
*/
   public static Schema reconcileSchemaRequirements(Schema sourceSchema, Schema 
targetSchema, Map opts) {
-if (sourceSchema.getType() == Schema.Type.NULL || 
sourceSchema.getFields().isEmpty() || targetSchema.getFields().isEmpty()) {
+if (targetSchema.getType() == Schema.Type.NULL || 
targetSchema.getFields().isEmpty()) {

Review Comment:
   already landed as a separate pr: https://github.com/apache/hudi/pull/10288



-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


yihua commented on code in PR #10225:
URL: https://github.com/apache/hudi/pull/10225#discussion_r1422898633


##
hudi-common/src/main/java/org/apache/hudi/internal/schema/utils/AvroSchemaEvolutionUtils.java:
##
@@ -140,10 +140,14 @@ public static Schema reconcileSchema(Schema 
incomingSchema, Schema oldTableSchem
* @return schema (based off {@code source} one) that has nullability 
constraints and datatypes reconciled
*/
   public static Schema reconcileSchemaRequirements(Schema sourceSchema, Schema 
targetSchema, Map opts) {
-if (sourceSchema.getType() == Schema.Type.NULL || 
sourceSchema.getFields().isEmpty() || targetSchema.getFields().isEmpty()) {
+if (targetSchema.getType() == Schema.Type.NULL || 
targetSchema.getFields().isEmpty()) {

Review Comment:
   Are these required for this patch or they can be separated out as a separate 
fix?



##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/spark/sql/execution/datasources/parquet/HoodieFileGroupReaderBasedParquetFileFormat.scala:
##
@@ -65,6 +66,8 @@ class HoodieFileGroupReaderBasedParquetFileFormat(tableState: 
HoodieTableState,
   requiredFilters: Seq[Filter]
) extends ParquetFileFormat with 
SparkAdapterSupport with HoodieFormatTrait {
 
+  override def getRequiredFilters: Seq[Filter] = requiredFilters

Review Comment:
   Do we already support `hoodie.data source.read.incr.filters` for incremental 
pulls in the new Hudi parquet file format?



##
hudi-client/hudi-spark-client/src/main/scala/org/apache/spark/sql/HoodieCatalystPlansUtils.scala:
##
@@ -140,4 +142,6 @@ trait HoodieCatalystPlansUtils {
   def failAnalysisForMIT(a: Attribute, cols: String): Unit = {}
 
   def createMITJoin(left: LogicalPlan, right: LogicalPlan, joinType: JoinType, 
condition: Option[Expression], hint: String): LogicalPlan
+
+  def sameOutput(a: LogicalPlan, b: LogicalPlan): Boolean

Review Comment:
   rename to sth like `areSameLogicalPlans`?



##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/spark/sql/execution/datasources/parquet/HoodieFileGroupReaderBasedParquetFileFormat.scala:
##
@@ -278,6 +276,8 @@ class 
HoodieFileGroupReaderBasedParquetFileFormat(tableState: HoodieTableState,
 val baseFileReader = super.buildReaderWithPartitionValues(sparkSession, 
dataSchema, partitionSchema, requiredSchema,
   filters ++ requiredFilters, options, new Configuration(hadoopConf))
 m.put(generateKey(dataSchema, requiredSchema), baseFileReader)
+m.put(0, super.buildReaderWithPartitionValues(sparkSession, dataSchema, 
partitionSchema, requiredSchema,

Review Comment:
   Why is the key `0`?



##
hudi-spark-datasource/hudi-spark-common/src/main/scala/org/apache/spark/sql/NewFileFormatUtils.scala:
##
@@ -0,0 +1,146 @@
+/*
+ * 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.
+ */
+
+/*
+ * 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.
+ */

Review Comment:
   Redundant licence?



-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1850577359

   
   ## CI report:
   
   * d07f06051fa4afa5fdc6c8702ce9a67834fc25d5 Azure: 
[SUCCESS](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21418)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1850560197

   
   ## CI report:
   
   * d07f06051fa4afa5fdc6c8702ce9a67834fc25d5 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-11 Thread via GitHub


jonvex commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1850540456

   @yihua all azure tests passing
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-08 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1848068421

   
   ## CI report:
   
   * 33bdac0da5432e2093efde3f6cf31a05f3bbf238 UNKNOWN
   * d07f06051fa4afa5fdc6c8702ce9a67834fc25d5 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21418)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-08 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1847926410

   
   ## CI report:
   
   * 33bdac0da5432e2093efde3f6cf31a05f3bbf238 UNKNOWN
   * c619d55ac8159ce51db8892cf0f2e12e6e771230 Azure: 
[CANCELED](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21411)
 
   * 6629932d653cca2c80ee5ce583f8fdbc34ef8128 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21416)
 
   * d07f06051fa4afa5fdc6c8702ce9a67834fc25d5 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21418)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-08 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1847920499

   
   ## CI report:
   
   * 33bdac0da5432e2093efde3f6cf31a05f3bbf238 UNKNOWN
   * c619d55ac8159ce51db8892cf0f2e12e6e771230 Azure: 
[CANCELED](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21411)
 
   * 6629932d653cca2c80ee5ce583f8fdbc34ef8128 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21416)
 
   * d07f06051fa4afa5fdc6c8702ce9a67834fc25d5 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-08 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1847914258

   
   ## CI report:
   
   * 33bdac0da5432e2093efde3f6cf31a05f3bbf238 UNKNOWN
   * c619d55ac8159ce51db8892cf0f2e12e6e771230 Azure: 
[CANCELED](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21411)
 
   * 6629932d653cca2c80ee5ce583f8fdbc34ef8128 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21416)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-08 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1847811606

   
   ## CI report:
   
   * faa5e29404958e9f9656330bcc61bf4ad33ba26b Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21407)
 
   * 33bdac0da5432e2093efde3f6cf31a05f3bbf238 UNKNOWN
   * c619d55ac8159ce51db8892cf0f2e12e6e771230 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21411)
 
   * 6629932d653cca2c80ee5ce583f8fdbc34ef8128 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21416)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-08 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1847802283

   
   ## CI report:
   
   * faa5e29404958e9f9656330bcc61bf4ad33ba26b Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21407)
 
   * 33bdac0da5432e2093efde3f6cf31a05f3bbf238 UNKNOWN
   * c619d55ac8159ce51db8892cf0f2e12e6e771230 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21411)
 
   * 6629932d653cca2c80ee5ce583f8fdbc34ef8128 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-08 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1847716224

   
   ## CI report:
   
   * faa5e29404958e9f9656330bcc61bf4ad33ba26b Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21407)
 
   * 33bdac0da5432e2093efde3f6cf31a05f3bbf238 UNKNOWN
   * c619d55ac8159ce51db8892cf0f2e12e6e771230 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21411)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-08 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1847697202

   
   ## CI report:
   
   * 18ecefc2f57a446bfb5bb7d1cd0eaa23be1a0506 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21388)
 
   * faa5e29404958e9f9656330bcc61bf4ad33ba26b Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21407)
 
   * 33bdac0da5432e2093efde3f6cf31a05f3bbf238 UNKNOWN
   * c619d55ac8159ce51db8892cf0f2e12e6e771230 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21411)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-08 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1847653954

   
   ## CI report:
   
   * 18ecefc2f57a446bfb5bb7d1cd0eaa23be1a0506 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21388)
 
   * faa5e29404958e9f9656330bcc61bf4ad33ba26b Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21407)
 
   * 33bdac0da5432e2093efde3f6cf31a05f3bbf238 UNKNOWN
   * c619d55ac8159ce51db8892cf0f2e12e6e771230 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-08 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1847645319

   
   ## CI report:
   
   * 18ecefc2f57a446bfb5bb7d1cd0eaa23be1a0506 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21388)
 
   * faa5e29404958e9f9656330bcc61bf4ad33ba26b Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21407)
 
   * 33bdac0da5432e2093efde3f6cf31a05f3bbf238 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-08 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1847570879

   
   ## CI report:
   
   * 18ecefc2f57a446bfb5bb7d1cd0eaa23be1a0506 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21388)
 
   * faa5e29404958e9f9656330bcc61bf4ad33ba26b Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21407)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-08 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1847561736

   
   ## CI report:
   
   * 18ecefc2f57a446bfb5bb7d1cd0eaa23be1a0506 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21388)
 
   * faa5e29404958e9f9656330bcc61bf4ad33ba26b UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-07 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1846522498

   
   ## CI report:
   
   * 18ecefc2f57a446bfb5bb7d1cd0eaa23be1a0506 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21388)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-07 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1846457831

   
   ## CI report:
   
   * fd247787271f2f9e52de1c32227dcea61420ab3c Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21385)
 
   * 18ecefc2f57a446bfb5bb7d1cd0eaa23be1a0506 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21388)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-07 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1846453110

   
   ## CI report:
   
   * fd247787271f2f9e52de1c32227dcea61420ab3c Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21385)
 
   * 18ecefc2f57a446bfb5bb7d1cd0eaa23be1a0506 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-07 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1846415293

   
   ## CI report:
   
   * fd247787271f2f9e52de1c32227dcea61420ab3c Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21385)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-07 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1846267211

   
   ## CI report:
   
   * 1ba88ec8c8a18247b628741e5cac180f15f0d8a9 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21381)
 
   * fd247787271f2f9e52de1c32227dcea61420ab3c Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21385)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-07 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-1846261324

   
   ## CI report:
   
   * 73f73cc86999e819f584f9c63bfb49f9e9636ea5 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21377)
 
   * 1ba88ec8c8a18247b628741e5cac180f15f0d8a9 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21381)
 
   * fd247787271f2f9e52de1c32227dcea61420ab3c Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21385)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-07 Thread via GitHub


hudi-bot commented on PR #10225:
URL: https://github.com/apache/hudi/pull/10225#issuecomment-184625

   
   ## CI report:
   
   * 73f73cc86999e819f584f9c63bfb49f9e9636ea5 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21377)
 
   * 1ba88ec8c8a18247b628741e5cac180f15f0d8a9 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21381)
 
   * fd247787271f2f9e52de1c32227dcea61420ab3c UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-12-07 Thread via GitHub


jonvex closed pull request #10063: [HUDI-6658] inject filters for incremental 
query
URL: https://github.com/apache/hudi/pull/10063


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-29 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1832819218

   
   ## CI report:
   
   * edb9997799c672e69a5a81271f32504e270846d2 UNKNOWN
   * e1999c6bb70849aa29723415791abac9879eff12 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21227)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-29 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1832764871

   
   ## CI report:
   
   * edb9997799c672e69a5a81271f32504e270846d2 UNKNOWN
   * 34efaac278dde7fd73515e6d54418a6ff8815326 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20939)
 
   * e1999c6bb70849aa29723415791abac9879eff12 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=21227)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-29 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1832754560

   
   ## CI report:
   
   * edb9997799c672e69a5a81271f32504e270846d2 UNKNOWN
   * 34efaac278dde7fd73515e6d54418a6ff8815326 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20939)
 
   * e1999c6bb70849aa29723415791abac9879eff12 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813877422

   
   ## CI report:
   
   * edb9997799c672e69a5a81271f32504e270846d2 UNKNOWN
   * 34efaac278dde7fd73515e6d54418a6ff8815326 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20939)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813828231

   
   ## CI report:
   
   * edb9997799c672e69a5a81271f32504e270846d2 UNKNOWN
   * 2c51a6c39ee41fac34110a41f943a3f1dee93f0f Azure: 
[CANCELED](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20936)
 
   * 34efaac278dde7fd73515e6d54418a6ff8815326 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20939)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813750267

   
   ## CI report:
   
   * edb9997799c672e69a5a81271f32504e270846d2 UNKNOWN
   * d22fcb976c5c468cb129abf9c4ee200eb249fb73 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20934)
 
   * 2c51a6c39ee41fac34110a41f943a3f1dee93f0f Azure: 
[CANCELED](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20936)
 
   * 34efaac278dde7fd73515e6d54418a6ff8815326 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20939)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813745503

   
   ## CI report:
   
   * edb9997799c672e69a5a81271f32504e270846d2 UNKNOWN
   * d22fcb976c5c468cb129abf9c4ee200eb249fb73 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20934)
 
   * 2c51a6c39ee41fac34110a41f943a3f1dee93f0f Azure: 
[CANCELED](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20936)
 
   * 34efaac278dde7fd73515e6d54418a6ff8815326 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813707163

   
   ## CI report:
   
   * edb9997799c672e69a5a81271f32504e270846d2 UNKNOWN
   * d22fcb976c5c468cb129abf9c4ee200eb249fb73 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20934)
 
   * 411f1e09cc33590a4a1f7cc93c65db083494633b Azure: 
[CANCELED](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20935)
 
   * 2c51a6c39ee41fac34110a41f943a3f1dee93f0f Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20936)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813667907

   
   ## CI report:
   
   * edb9997799c672e69a5a81271f32504e270846d2 UNKNOWN
   * 97424b66af6de869a7feba00c6e8c24f80eb90a4 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20927)
 
   * d22fcb976c5c468cb129abf9c4ee200eb249fb73 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20934)
 
   * 411f1e09cc33590a4a1f7cc93c65db083494633b Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20935)
 
   * 2c51a6c39ee41fac34110a41f943a3f1dee93f0f UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813653979

   
   ## CI report:
   
   * edb9997799c672e69a5a81271f32504e270846d2 UNKNOWN
   * 97424b66af6de869a7feba00c6e8c24f80eb90a4 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20927)
 
   * d22fcb976c5c468cb129abf9c4ee200eb249fb73 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20934)
 
   * 411f1e09cc33590a4a1f7cc93c65db083494633b UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813638155

   
   ## CI report:
   
   * edb9997799c672e69a5a81271f32504e270846d2 UNKNOWN
   * 97424b66af6de869a7feba00c6e8c24f80eb90a4 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20927)
 
   * d22fcb976c5c468cb129abf9c4ee200eb249fb73 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813623184

   
   ## CI report:
   
   * edb9997799c672e69a5a81271f32504e270846d2 UNKNOWN
   * 97424b66af6de869a7feba00c6e8c24f80eb90a4 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20927)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813415830

   
   ## CI report:
   
   * aa9c728a383f933ce939cc047a4bdca3ab4260ad Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20924)
 
   * edb9997799c672e69a5a81271f32504e270846d2 UNKNOWN
   * 97424b66af6de869a7feba00c6e8c24f80eb90a4 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20927)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813402279

   
   ## CI report:
   
   * aa9c728a383f933ce939cc047a4bdca3ab4260ad Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20924)
 
   * edb9997799c672e69a5a81271f32504e270846d2 UNKNOWN
   * 97424b66af6de869a7feba00c6e8c24f80eb90a4 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813394735

   
   ## CI report:
   
   * aa9c728a383f933ce939cc047a4bdca3ab4260ad Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20924)
 
   * edb9997799c672e69a5a81271f32504e270846d2 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813386403

   
   ## CI report:
   
   * aa9c728a383f933ce939cc047a4bdca3ab4260ad Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20924)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


jonvex commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813368484

   > hey @jonvex : is this fixing any blocker/critical bug for 0.14.0? or only 
new file format with 1.x? I am trying to tag patches for 0.14.1.
   
   This is a 1.x patch


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


nsivabalan commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813199801

   hey @jonvex : is this fixing any blocker/critical bug for 0.14.0? or only 
new file format with 1.x?
   I am trying to tag patches for 0.14.1. 


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

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

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813182282

   
   ## CI report:
   
   * 7d73a5980bd1a78ae0625041c086afdb9039ecb0 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20911)
 
   * aa9c728a383f933ce939cc047a4bdca3ab4260ad Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20924)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-15 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1813170631

   
   ## CI report:
   
   * 7d73a5980bd1a78ae0625041c086afdb9039ecb0 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20911)
 
   * aa9c728a383f933ce939cc047a4bdca3ab4260ad UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811844516

   
   ## CI report:
   
   * 7d73a5980bd1a78ae0625041c086afdb9039ecb0 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20911)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811770536

   
   ## CI report:
   
   * cf5a3a8c8de471a54518bd35ad5ce8822037c4f2 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20906)
 
   * 7d73a5980bd1a78ae0625041c086afdb9039ecb0 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20911)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811765910

   
   ## CI report:
   
   * cf5a3a8c8de471a54518bd35ad5ce8822037c4f2 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20906)
 
   * 7d73a5980bd1a78ae0625041c086afdb9039ecb0 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811761416

   
   ## CI report:
   
   * cf5a3a8c8de471a54518bd35ad5ce8822037c4f2 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20906)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811727588

   
   ## CI report:
   
   * 692827330e231ed2c6d689e4a11fc5b340a3a49b Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20903)
 
   * cf5a3a8c8de471a54518bd35ad5ce8822037c4f2 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20906)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811682281

   
   ## CI report:
   
   * 4accb55977a1f8375e3abd01d932812445d3cdc8 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20901)
 
   * 692827330e231ed2c6d689e4a11fc5b340a3a49b Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20903)
 
   * cf5a3a8c8de471a54518bd35ad5ce8822037c4f2 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20906)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811676138

   
   ## CI report:
   
   * 4accb55977a1f8375e3abd01d932812445d3cdc8 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20901)
 
   * 692827330e231ed2c6d689e4a11fc5b340a3a49b Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20903)
 
   * cf5a3a8c8de471a54518bd35ad5ce8822037c4f2 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811582468

   
   ## CI report:
   
   * 4accb55977a1f8375e3abd01d932812445d3cdc8 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20901)
 
   * 692827330e231ed2c6d689e4a11fc5b340a3a49b Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20903)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811576334

   
   ## CI report:
   
   * 4accb55977a1f8375e3abd01d932812445d3cdc8 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20901)
 
   * 692827330e231ed2c6d689e4a11fc5b340a3a49b UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811569689

   
   ## CI report:
   
   * 4accb55977a1f8375e3abd01d932812445d3cdc8 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20901)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811506158

   
   ## CI report:
   
   * eb2d1942b2b8c4d2dea6f3709ff571b03158750e Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20900)
 
   * 4accb55977a1f8375e3abd01d932812445d3cdc8 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20901)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811428719

   
   ## CI report:
   
   * c09c2002b004e993e11c758f371996ef6603f2c4 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20898)
 
   * eb2d1942b2b8c4d2dea6f3709ff571b03158750e Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20900)
 
   * 4accb55977a1f8375e3abd01d932812445d3cdc8 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20901)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811380291

   
   ## CI report:
   
   * c09c2002b004e993e11c758f371996ef6603f2c4 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20898)
 
   * eb2d1942b2b8c4d2dea6f3709ff571b03158750e Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20900)
 
   * 4accb55977a1f8375e3abd01d932812445d3cdc8 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811370259

   
   ## CI report:
   
   * c09c2002b004e993e11c758f371996ef6603f2c4 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20898)
 
   * eb2d1942b2b8c4d2dea6f3709ff571b03158750e Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20900)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811289770

   
   ## CI report:
   
   * 56efb1e7d179737b5ee900e7f8a7d49e932a2906 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20896)
 
   * c09c2002b004e993e11c758f371996ef6603f2c4 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20898)
 
   * eb2d1942b2b8c4d2dea6f3709ff571b03158750e Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20900)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811259954

   
   ## CI report:
   
   * 56efb1e7d179737b5ee900e7f8a7d49e932a2906 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20896)
 
   * c09c2002b004e993e11c758f371996ef6603f2c4 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20898)
 
   * eb2d1942b2b8c4d2dea6f3709ff571b03158750e UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811128074

   
   ## CI report:
   
   * 56efb1e7d179737b5ee900e7f8a7d49e932a2906 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20896)
 
   * c09c2002b004e993e11c758f371996ef6603f2c4 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20898)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811105394

   
   ## CI report:
   
   * 56efb1e7d179737b5ee900e7f8a7d49e932a2906 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20896)
 
   * c09c2002b004e993e11c758f371996ef6603f2c4 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1811077805

   
   ## CI report:
   
   * 56efb1e7d179737b5ee900e7f8a7d49e932a2906 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20896)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1810928491

   
   ## CI report:
   
   * d5a12d6e3b314233a6757020f2fd56ea9bca1835 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20893)
 
   * 56efb1e7d179737b5ee900e7f8a7d49e932a2906 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20896)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1810840192

   
   ## CI report:
   
   * 336b6d27b4fafb849bcb93baf99056b91104914a Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20892)
 
   * d5a12d6e3b314233a6757020f2fd56ea9bca1835 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20893)
 
   * 56efb1e7d179737b5ee900e7f8a7d49e932a2906 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1810692823

   
   ## CI report:
   
   * 336b6d27b4fafb849bcb93baf99056b91104914a Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20892)
 
   * d5a12d6e3b314233a6757020f2fd56ea9bca1835 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20893)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1810678205

   
   ## CI report:
   
   * 336b6d27b4fafb849bcb93baf99056b91104914a Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20892)
 
   * d5a12d6e3b314233a6757020f2fd56ea9bca1835 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1810653166

   
   ## CI report:
   
   * 336b6d27b4fafb849bcb93baf99056b91104914a Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20892)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1810393783

   
   ## CI report:
   
   * 13294ba17058d7ebc5c8542ae9ee11898a269c12 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20885)
 
   * 336b6d27b4fafb849bcb93baf99056b91104914a Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20892)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-14 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1810377816

   
   ## CI report:
   
   * 13294ba17058d7ebc5c8542ae9ee11898a269c12 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20885)
 
   * 336b6d27b4fafb849bcb93baf99056b91104914a UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-13 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1809579640

   
   ## CI report:
   
   * 13294ba17058d7ebc5c8542ae9ee11898a269c12 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20885)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-13 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1809508265

   
   ## CI report:
   
   * d511bdcda3318a8c7522d1a0aa5b905c89f702ab Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20881)
 
   * 13294ba17058d7ebc5c8542ae9ee11898a269c12 Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20885)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-13 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1809503978

   
   ## CI report:
   
   * d511bdcda3318a8c7522d1a0aa5b905c89f702ab Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20881)
 
   * 13294ba17058d7ebc5c8542ae9ee11898a269c12 UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-13 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1809404026

   
   ## CI report:
   
   * d511bdcda3318a8c7522d1a0aa5b905c89f702ab Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20881)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-13 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1809354647

   
   ## CI report:
   
   * a0e16af506936c4040508b23885f3ef478786c8b Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20880)
 
   * d511bdcda3318a8c7522d1a0aa5b905c89f702ab Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20881)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-13 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1809318165

   
   ## CI report:
   
   * a0e16af506936c4040508b23885f3ef478786c8b Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20880)
 
   * d511bdcda3318a8c7522d1a0aa5b905c89f702ab UNKNOWN
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-13 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1809305610

   
   ## CI report:
   
   * a0e16af506936c4040508b23885f3ef478786c8b Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20880)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



Re: [PR] [HUDI-6658] inject filters for incremental query [hudi]

2023-11-13 Thread via GitHub


hudi-bot commented on PR #10063:
URL: https://github.com/apache/hudi/pull/10063#issuecomment-1809265670

   
   ## CI report:
   
   * dad8fa7cc5f3c3ff65fd0cd9024866083a67db61 Azure: 
[FAILURE](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20841)
 
   * ab3154e937435961094fa4b4640e308c3135ed0c Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20878)
 
   * a0e16af506936c4040508b23885f3ef478786c8b Azure: 
[PENDING](https://dev.azure.com/apache-hudi-ci-org/785b6ef4-2f42-4a89-8f0e-5f0d7039a0cc/_build/results?buildId=20880)
 
   
   
   Bot commands
 @hudi-bot supports the following commands:
   
- `@hudi-bot run azure` re-run the last Azure build
   


-- 
This is an automated message from the Apache Git Service.
To 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...@hudi.apache.org

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



  1   2   >