Skip to content

Commit

Permalink
Clarify grouping in file comment
Browse files Browse the repository at this point in the history
Signed-off-by: Karen Feng <karen.feng@databricks.com>
  • Loading branch information
karenfeng committed Mar 4, 2021
1 parent 847ee74 commit 36c0ada
Show file tree
Hide file tree
Showing 2 changed files with 8 additions and 7 deletions.
Expand Up @@ -24,7 +24,7 @@ import org.apache.spark.sql.catalyst.{FunctionIdentifier, QualifiedTableName, Ta
import org.apache.spark.sql.catalyst.analysis.{CannotReplaceMissingTableException, NamespaceAlreadyExistsException, NoSuchNamespaceException, NoSuchTableException, ResolvedNamespace, ResolvedTable, ResolvedView, TableAlreadyExistsException}
import org.apache.spark.sql.catalyst.catalog.InvalidUDFClassException
import org.apache.spark.sql.catalyst.expressions.{Alias, Attribute, CreateMap, Expression, GroupingID, NamedExpression, SpecifiedWindowFrame, WindowFrame, WindowFunction, WindowSpecDefinition}
import org.apache.spark.sql.catalyst.plans.logical.{LogicalPlan, SerdeInfo}
import org.apache.spark.sql.catalyst.plans.logical.{Command, LogicalPlan, SerdeInfo}
import org.apache.spark.sql.catalyst.trees.TreeNode
import org.apache.spark.sql.catalyst.util.{toPrettySQL, FailFastMode, ParseMode, PermissiveMode}
import org.apache.spark.sql.connector.catalog.{Identifier, NamespaceChange, Table, TableCapability, TableChange, V1Table}
Expand All @@ -34,8 +34,9 @@ import org.apache.spark.sql.sources.Filter
import org.apache.spark.sql.types.{AbstractDataType, DataType, StructType}

/**
* Object for grouping all error messages of the query compilation.
* Currently it includes all AnalysisExceptions.
* Object for grouping error messages from exceptions thrown during query compilation.
* As [[Command]]s are executed eagerly, this also includes errors thrown during the execution of
* [[Command]]s, which users can see immediately.
*/
private[spark] object QueryCompilationErrors {

Expand Down
Expand Up @@ -30,6 +30,7 @@ import org.apache.spark.executor.CommitDeniedException
import org.apache.spark.sql.catalyst.analysis.UnresolvedGenerator
import org.apache.spark.sql.catalyst.catalog.CatalogDatabase
import org.apache.spark.sql.catalyst.expressions.{Expression, UnevaluableAggregate}
import org.apache.spark.sql.catalyst.plans.logical.Command
import org.apache.spark.sql.connector.catalog.CatalogV2Implicits._
import org.apache.spark.sql.connector.catalog.Identifier
import org.apache.spark.sql.connector.expressions.Transform
Expand All @@ -39,10 +40,9 @@ import org.apache.spark.unsafe.array.ByteArrayMethods
import org.apache.spark.unsafe.types.UTF8String

/**
* Object for grouping all error messages of the query runtime.
* Currently it includes all SparkExceptions, RuntimeExceptions(e.g.
* UnsupportedOperationException, IllegalStateException),
* IOExceptions, and CommitDeniedExceptions.
* Object for grouping error messages from (most) exceptions thrown during query execution.
* This does not include exceptions thrown during the eager execution of [[Command]]s, which are
* grouped into [[QueryCompilationErrors]].
*/
object QueryExecutionErrors {

Expand Down

0 comments on commit 36c0ada

Please sign in to comment.