Skip to content
Closed
Show file tree
Hide file tree
Changes from 8 commits
Commits
Show all changes
46 commits
Select commit Hold shift + click to select a range
69a47a1
init
ulysses-you Jun 16, 2020
a95dcb6
update doc
ulysses-you Jun 17, 2020
3fc807e
fix typo
ulysses-you Jun 17, 2020
b282348
update doc
ulysses-you Jun 17, 2020
f677a4a
update doc again
ulysses-you Jun 17, 2020
a6c5d8b
use v2 command
ulysses-you Jun 17, 2020
de54470
fix
ulysses-you Jun 17, 2020
9e09875
fix mistake
ulysses-you Jun 17, 2020
63695c0
use v2 commnd analyze
ulysses-you Jun 17, 2020
9e9d5ce
add line
ulysses-you Jun 17, 2020
c434821
update doc
ulysses-you Jun 18, 2020
35fd44b
update doc
ulysses-you Jun 18, 2020
f83fd8b
fix child
ulysses-you Jun 18, 2020
e444943
fix children
ulysses-you Jun 18, 2020
afd510b
add comment
ulysses-you Jun 18, 2020
1241bde
fix copy error
ulysses-you Jun 18, 2020
93f5d71
update doc
ulysses-you Jun 18, 2020
dc684b5
update comment
ulysses-you Jun 18, 2020
0ea7dd6
fix LookupCatalog
ulysses-you Jun 18, 2020
643969c
merge to ResolveFunctions
ulysses-you Jun 18, 2020
6cb2edd
remove ignoreIfNotExists
ulysses-you Jun 19, 2020
cffc207
fix ut
ulysses-you Jun 22, 2020
4b6408d
fix resolve
ulysses-you Jun 22, 2020
5d5fe71
brush functions
ulysses-you Jun 22, 2020
4ba345b
fix
ulysses-you Jun 22, 2020
6765395
use catalogfunction
ulysses-you Jun 22, 2020
dc86b82
fix
ulysses-you Jun 23, 2020
a38d656
fix comment
ulysses-you Jun 23, 2020
cdea55b
ut nit
ulysses-you Jun 24, 2020
5e227d7
fix nit
ulysses-you Jun 24, 2020
703ad47
nit
ulysses-you Jun 24, 2020
a79f72b
update ResolvedFunc
ulysses-you Jun 24, 2020
a4d144a
Merge branch 'master' of https://github.com/apache/spark into SPARK-3…
ulysses-you Jul 6, 2020
3bd8d23
update doc
ulysses-you Jul 6, 2020
60ac2a0
fix doc
ulysses-you Jul 6, 2020
b36b760
update comment
ulysses-you Jul 6, 2020
c5937a2
rewrite RefreshFunctionCommand
ulysses-you Jul 6, 2020
56ec5ea
update doc
ulysses-you Jul 13, 2020
c129a54
fix functions
ulysses-you Jul 14, 2020
a956144
fix
ulysses-you Jul 14, 2020
711656d
remove unnecessary param
ulysses-you Jul 14, 2020
5d4c152
simplify
ulysses-you Jul 16, 2020
94fa132
fix
ulysses-you Jul 17, 2020
fc4789f
simplify
ulysses-you Jul 17, 2020
e83194f
address comment
ulysses-you Jul 21, 2020
b18437c
fix
ulysses-you Jul 21, 2020
File filter

Filter by extension

Filter by extension

Conversations
Failed to load comments.
Loading
Jump to
Jump to file
Failed to load files.
Loading
Diff view
Diff view
2 changes: 2 additions & 0 deletions docs/_data/menu-sql.yaml
Original file line number Diff line number Diff line change
Expand Up @@ -208,6 +208,8 @@
url: sql-ref-syntax-aux-cache-clear-cache.html
- text: REFRESH TABLE
url: sql-ref-syntax-aux-refresh-table.html
- text: REFRESH FUNCTION
url: sql-ref-syntax-aux-refresh-function.html
- text: REFRESH
url: sql-ref-syntax-aux-cache-refresh.html
- text: DESCRIBE
Expand Down
1 change: 1 addition & 0 deletions docs/sql-ref-syntax-aux-cache-cache-table.md
Original file line number Diff line number Diff line change
Expand Up @@ -80,3 +80,4 @@ CACHE TABLE testCache OPTIONS ('storageLevel' 'DISK_ONLY') SELECT * FROM testDat
* [UNCACHE TABLE](sql-ref-syntax-aux-cache-uncache-table.html)
* [REFRESH TABLE](sql-ref-syntax-aux-refresh-table.html)
* [REFRESH](sql-ref-syntax-aux-cache-refresh.html)
* [REFRESH FUNCTION](sql-ref-syntax-aux-refresh-function.html)
1 change: 1 addition & 0 deletions docs/sql-ref-syntax-aux-cache-clear-cache.md
Original file line number Diff line number Diff line change
Expand Up @@ -41,3 +41,4 @@ CLEAR CACHE;
* [UNCACHE TABLE](sql-ref-syntax-aux-cache-uncache-table.html)
* [REFRESH TABLE](sql-ref-syntax-aux-refresh-table.html)
* [REFRESH](sql-ref-syntax-aux-cache-refresh.html)
* [REFRESH FUNCTION](sql-ref-syntax-aux-refresh-function.html)
1 change: 1 addition & 0 deletions docs/sql-ref-syntax-aux-cache-refresh.md
Original file line number Diff line number Diff line change
Expand Up @@ -54,3 +54,4 @@ REFRESH "hdfs://path/to/table";
* [CLEAR CACHE](sql-ref-syntax-aux-cache-clear-cache.html)
* [UNCACHE TABLE](sql-ref-syntax-aux-cache-uncache-table.html)
* [REFRESH TABLE](sql-ref-syntax-aux-refresh-table.html)
* [REFRESH FUNCTION](sql-ref-syntax-aux-refresh-function.html)
1 change: 1 addition & 0 deletions docs/sql-ref-syntax-aux-cache-uncache-table.md
Original file line number Diff line number Diff line change
Expand Up @@ -50,3 +50,4 @@ UNCACHE TABLE t1;
* [CLEAR CACHE](sql-ref-syntax-aux-cache-clear-cache.html)
* [REFRESH TABLE](sql-ref-syntax-aux-refresh-table.html)
* [REFRESH](sql-ref-syntax-aux-cache-refresh.html)
* [REFRESH FUNCTION](sql-ref-syntax-aux-refresh-function.html)
3 changes: 2 additions & 1 deletion docs/sql-ref-syntax-aux-cache.md
Original file line number Diff line number Diff line change
Expand Up @@ -23,4 +23,5 @@ license: |
* [UNCACHE TABLE statement](sql-ref-syntax-aux-cache-uncache-table.html)
* [CLEAR CACHE statement](sql-ref-syntax-aux-cache-clear-cache.html)
* [REFRESH TABLE statement](sql-ref-syntax-aux-refresh-table.html)
* [REFRESH statement](sql-ref-syntax-aux-cache-refresh.html)
* [REFRESH statement](sql-ref-syntax-aux-cache-refresh.html)
* [REFRESH FUNCTION statement](sql-ref-syntax-aux-refresh-function.html)
60 changes: 60 additions & 0 deletions docs/sql-ref-syntax-aux-refresh-function.md
Original file line number Diff line number Diff line change
@@ -0,0 +1,60 @@
---
layout: global
title: REFRESH FUNCTION
displayTitle: REFRESH FUNCTION
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.
---

### Description
Copy link
Member

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.


`REFRESH FUNCTION` statement invalidates the cached function entry, which include class name
and resource location of the given function. The invalidated cache is populated right away.
Note that, refresh function only works for permanent function. Refresh native function or temporary function will cause exception.
Copy link
Contributor

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

Sorry, the suggestion I gave you yesterday has a few grammar mistakes.

which include class name -> which includes the class name

Note that, refresh function only works for permanent function. -> Note that REFRESH FUNCTION only works for permanent functions.

Refresh native function or temporary function will cause exception. ->
Refreshing native functions or temporary functions will cause an exception.


### Syntax

```sql
REFRESH FUNCTION function_identifier
```

### Parameters

* **function_identifier**

Specifies a function name, which is either a qualified or unqualified name. If no database identifier is provided, use the current database.
Copy link
Contributor

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

use the current database -> uses the current database


**Syntax:** `[ database_name. ] function_name`

### Examples

```sql
-- The cached entries of the function will be refreshed
Copy link
Member

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

The cached entries -> The cached entry?

-- The function is resolved from the current database as the function name is unqualified.
REFRESH FUNCTION func1;

-- The cached entries of the function will be refreshed
Copy link
Member

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

ditto: The cached entries -> The cached entry?

-- The function is resolved from tempDB database as the function name is qualified.
REFRESH FUNCTION tempDB.func1;
```

### Related Statements

* [CACHE TABLE](sql-ref-syntax-aux-cache-cache-table.html)
* [CLEAR CACHE](sql-ref-syntax-aux-cache-clear-cache.html)
* [UNCACHE TABLE](sql-ref-syntax-aux-cache-uncache-table.html)
Copy link
Member

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

Do we need to mention the above three data-related statement? The following REFRESH statement looks enough for this REFRESH FUNCTION.

Copy link
Contributor Author

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

Just feel they are part of the cache and list each other.

* [REFRESH TABLE](sql-ref-syntax-aux-refresh-table.html)
* [REFRESH](sql-ref-syntax-aux-cache-refresh.html)
1 change: 1 addition & 0 deletions docs/sql-ref-syntax-aux-refresh-table.md
Original file line number Diff line number Diff line change
Expand Up @@ -57,3 +57,4 @@ REFRESH TABLE tempDB.view1;
* [CLEAR CACHE](sql-ref-syntax-aux-cache-clear-cache.html)
* [UNCACHE TABLE](sql-ref-syntax-aux-cache-uncache-table.html)
* [REFRESH](sql-ref-syntax-aux-cache-refresh.html)
* [REFRESH FUNCTION](sql-ref-syntax-aux-refresh-function.html)
1 change: 1 addition & 0 deletions docs/sql-ref-syntax.md
Original file line number Diff line number Diff line change
Expand Up @@ -83,6 +83,7 @@ Spark SQL is Apache Spark's module for working with structured data. The SQL Syn
* [LIST JAR](sql-ref-syntax-aux-resource-mgmt-list-jar.html)
* [REFRESH](sql-ref-syntax-aux-cache-refresh.html)
* [REFRESH TABLE](sql-ref-syntax-aux-refresh-table.html)
* [REFRESH FUNCTION](sql-ref-syntax-aux-refresh-function.html)
* [RESET](sql-ref-syntax-aux-conf-mgmt-reset.html)
* [SET](sql-ref-syntax-aux-conf-mgmt-set.html)
* [SHOW COLUMNS](sql-ref-syntax-aux-show-columns.html)
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -229,6 +229,7 @@ statement
comment=(STRING | NULL) #commentNamespace
| COMMENT ON TABLE multipartIdentifier IS comment=(STRING | NULL) #commentTable
| REFRESH TABLE multipartIdentifier #refreshTable
| REFRESH FUNCTION multipartIdentifier #refreshFunction
| REFRESH (STRING | .*?) #refreshResource
| CACHE LAZY? TABLE multipartIdentifier
(OPTIONS options=tablePropertyList)? (AS? query)? #cacheTable
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -1341,6 +1341,16 @@ class SessionCatalog(
functionRegistry.registerFunction(func, info, builder)
}

/**
* Unregister a temporary or permanent function from a session-specific [[FunctionRegistry]]
*/
def unregisterFunction(name: FunctionIdentifier, ignoreIfNotExists: Boolean): Unit = {
Copy link
Member

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

ignoreIfNotExists not used now?

Copy link
Contributor Author

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

Not used. If the function not exists, refresh function will throw exception.

Copy link
Member

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

Could we remove it now?

if (!functionRegistry.dropFunction(name) && !ignoreIfNotExists) {
throw new NoSuchFunctionException(
Copy link
Member

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

Actually, it does not throw this exception because this check's already done in https://github.com/apache/spark/pull/28840/files#diff-d2a203f08c862bd762e6740c16e972f7R267-R268 ?

formatDatabaseName(name.database.getOrElse(currentDb)), name.funcName)
}
}

/**
* Drop a temporary function.
*/
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -3650,6 +3650,11 @@ class AstBuilder(conf: SQLConf) extends SqlBaseBaseVisitor[AnyRef] with Logging
ctx.REPLACE != null)
}

override def visitRefreshFunction(ctx: RefreshFunctionContext): LogicalPlan = withOrigin(ctx) {
val functionIdentifier = visitMultipartIdentifier(ctx.multipartIdentifier)
RefreshFunction(functionIdentifier)
}

override def visitCommentNamespace(ctx: CommentNamespaceContext): LogicalPlan = withOrigin(ctx) {
val comment = ctx.comment.getType match {
case SqlBaseParser.NULL => ""
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -516,3 +516,8 @@ case class CommentOnNamespace(child: LogicalPlan, comment: String) extends Comma
case class CommentOnTable(child: LogicalPlan, comment: String) extends Command {
override def children: Seq[LogicalPlan] = child :: Nil
}

/**
* The logical plan of the REFRESH FUNCTION command that works for v2 catalogs.
*/
case class RefreshFunction(func: Seq[String]) extends Command
Copy link
Contributor

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

Can we create a UnresolvedFunc, similar to UnresolvedTable?

The key point is to do the resolution in the analyzer, not at runtime in RefreshFunctionCommand.run.

Copy link
Contributor Author

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

Get it.

Original file line number Diff line number Diff line change
Expand Up @@ -2113,6 +2113,12 @@ class DDLParserSuite extends AnalysisTest {
"Operation not allowed: CREATE FUNCTION with resource type 'other'")
}

test("REFRESH FUNCTION") {
parseCompare("REFRESH FUNCTION c", RefreshFunction(Seq("c")))
parseCompare("REFRESH FUNCTION b.c", RefreshFunction(Seq("b", "c")))
parseCompare("REFRESH FUNCTION a.b.c", RefreshFunction(Seq("a", "b", "c")))
}

private case class TableSpec(
name: Seq[String],
schema: Option[StructType],
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -611,6 +611,12 @@ class ResolveSessionCatalog(
CreateFunctionCommand(database, function, className, resources, isTemp, ignoreIfExists,
replace)
}

case RefreshFunction(func) =>
val FunctionIdentifier(function, database) =
parseSessionCatalogFunctionIdentifier(func, "REFRESH FUNCTION")
// Fallback to v1 command
RefreshFunctionCommand(database, function)
}

// TODO: move function related v2 statements to the new framework.
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -236,6 +236,58 @@ case class ShowFunctionsCommand(
}
}


/**
* A command for users to refresh the persistent function.
* The syntax of using this command in SQL is:
* {{{
* REFRESH FUNCTION functionName
* }}}
*/
case class RefreshFunctionCommand(
databaseName: Option[String],
functionName: String)
extends RunnableCommand {

override def run(sparkSession: SparkSession): Seq[Row] = {
val catalog = sparkSession.sessionState.catalog
if (FunctionRegistry.builtin.functionExists(FunctionIdentifier(functionName))) {
Copy link
Member

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

We still can create persistent function with the same name as the built-in function. For example,

CREATE FUNCTION rand AS 'org.apache.spark.sql.catalyst.expressions.Abs'
DESC function default.rand

I think we should still allow this case.

Copy link
Contributor Author

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

It seems no meaning to refresh a persistent function whose name is same as a built-in function.

Yes, we can create a persistent function with the same name as the built-in function, but just create in metastore. The actual function we used is the built-in function. The reason is built-in functions are pre-cached in registry and we lookup cached function first.

e.g., CREATE FUNCTION rand AS 'xxx', DESC FUNCTION rand will always return Class: org.apache.spark.sql.catalyst.expressions.Rand.

BTW, maybe it's the reason why we create function and load it lazy that just be a Hive client, otherwise we can't create such function like rand,md5 in metastore. @cloud-fan

Copy link
Contributor

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

how about

CREATE FUNCTION rand AS 'xxx';
DESC FUNCTION default.rand;

I think this is similar to table and temp views. Spark will try to look up temp view first, so if the name conflicts, temp view is preferred. But users can still use a qualified table name to read the table explicitly.

Copy link
Contributor Author

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

You are right.

Missed qualified name case, I will fix this in followup.

throw new AnalysisException(s"Cannot refresh native function $functionName")
} else if (catalog.isTemporaryFunction(FunctionIdentifier(functionName, databaseName))) {
throw new AnalysisException(s"Cannot refresh temp function $functionName")
} else {
// we only refresh the permanent function.
// there are 4 cases:
// 1. registry exists externalCatalog exists
// 2. registry exists externalCatalog not exists
// 3. registry not exists externalCatalog exists
// 4. registry not exists externalCatalog not exists
val identifier = FunctionIdentifier(
functionName, Some(databaseName.getOrElse(catalog.getCurrentDatabase)))
val isRegisteredFunction = catalog.isRegisteredFunction(identifier)
val isPersistentFunction = catalog.isPersistentFunction(identifier)
if (isRegisteredFunction && isPersistentFunction) {
// re-register function
catalog.unregisterFunction(identifier, true)
val func = catalog.getFunctionMetadata(identifier)
catalog.registerFunction(func, true)
} else if (isRegisteredFunction && !isPersistentFunction) {
// unregister function and throw NoSuchFunctionException
catalog.unregisterFunction(identifier, true)
throw new NoSuchFunctionException(identifier.database.get, functionName)
} else if (!isRegisteredFunction && isPersistentFunction) {
// register function
val func = catalog.getFunctionMetadata(identifier)
catalog.registerFunction(func, true)
} else {
throw new NoSuchFunctionException(identifier.database.get, functionName)
}
}

Seq.empty[Row]
}
}

object FunctionsCommand {
// operators that do not have corresponding functions.
// They should be handled `DescribeFunctionCommand`, `ShowFunctionsCommand`
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -28,8 +28,8 @@ import org.apache.spark.{SparkException, SparkFiles}
import org.apache.spark.internal.config
import org.apache.spark.internal.config.RDD_PARALLEL_LISTING_THRESHOLD
import org.apache.spark.sql.{AnalysisException, QueryTest, Row, SaveMode}
import org.apache.spark.sql.catalyst.{QualifiedTableName, TableIdentifier}
import org.apache.spark.sql.catalyst.analysis.{FunctionRegistry, NoSuchDatabaseException, NoSuchPartitionException, NoSuchTableException, TempTableAlreadyExistsException}
import org.apache.spark.sql.catalyst.{FunctionIdentifier, QualifiedTableName, TableIdentifier}
import org.apache.spark.sql.catalyst.analysis.{FunctionRegistry, NoSuchDatabaseException, NoSuchFunctionException, NoSuchPartitionException, NoSuchTableException, TempTableAlreadyExistsException}
import org.apache.spark.sql.catalyst.catalog._
import org.apache.spark.sql.catalyst.catalog.CatalogTypes.TablePartitionSpec
import org.apache.spark.sql.connector.catalog.SupportsNamespaces.PROP_OWNER
Expand Down Expand Up @@ -3030,6 +3030,49 @@ abstract class DDLSuite extends QueryTest with SQLTestUtils {
}
}
}

test("REFRESH FUNCTION") {
val msg = intercept[AnalysisException] {
sql("REFRESH FUNCTION md5")
}.getMessage
assert(msg.contains("Cannot refresh native function"))

withUserDefinedFunction("func1" -> true) {
sql("CREATE TEMPORARY FUNCTION func1 AS 'test.org.apache.spark.sql.MyDoubleAvg'")
val msg = intercept[AnalysisException] {
sql("REFRESH FUNCTION func1")
}.getMessage
assert(msg.contains("Cannot refresh temp function"))
}

withUserDefinedFunction("func1" -> false) {
intercept[NoSuchFunctionException] {
sql("REFRESH FUNCTION func1")
}

val func = FunctionIdentifier("func1", Some("default"))
sql("CREATE FUNCTION func1 AS 'test.org.apache.spark.sql.MyDoubleAvg'")
assert(spark.sessionState.catalog.isRegisteredFunction(func) == false)
Copy link
Member

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

nit: assert(!spark.sessionState.catalog.isRegisteredFunction(func) )?

sql("REFRESH FUNCTION func1")
Copy link
Member

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

This is the only positive test case. Could you think more and try to cover more cases?

assert(spark.sessionState.catalog.isRegisteredFunction(func) == true)

spark.sessionState.catalog.externalCatalog.dropFunction("default", "func1")
assert(spark.sessionState.catalog.isRegisteredFunction(func) == true)
intercept[NoSuchFunctionException] {
sql("REFRESH FUNCTION func1")
}
assert(spark.sessionState.catalog.isRegisteredFunction(func) == false)

val function = CatalogFunction(func, "test.non.exists.udf", Seq.empty)
spark.sessionState.catalog.createFunction(function, false)
Copy link
Contributor

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

It's a bit weird if we don't fail invalid functions when creating, but fail when refreshing it. How hard is it to make REFRESH TABLE lazy?

Copy link
Contributor Author

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

I don't know why we not check function during create. It seems no use to create a not exists function but can produce some problem like typo.

The same command, Hive failed directly create function f1 as 'test.non.exists.udf'.

Copy link
Contributor

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

We can fix CREATE FUNCTION later and update this test.

Copy link
Contributor

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

or is it because you are calling the internal API not the CREATE FUNCTION command?

Copy link
Contributor Author

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

If we make REFRESH FUNCTION lazy as CREATE FUNCTION, something like this

if (catalog.isRegisteredFunction(identifier)) {
  catalog.unregisterFunction(identifier)
}
if (!catalog.isPersistentFunction(identifier)) {
  throw new NoSuchFunctionException(identifier.database.get, functionName)
}

The different thing is we don't register/check function and the register/check action happened when user query with this function like select func(f).

I think it might be better to do the function check right now.

Copy link
Contributor

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

Maybe we should make CREATE FUNCTION not lazy, in a new PR.

Copy link
Contributor Author

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

ok, I will try it after this pr finished.

assert(spark.sessionState.catalog.isRegisteredFunction(func) == false)
val err = intercept[AnalysisException] {
sql("REFRESH FUNCTION func1")
}.getMessage
assert(err.contains("Can not load class"))
assert(spark.sessionState.catalog.isRegisteredFunction(func) == false)
}
}
}

object FakeLocalFsFileSystem {
Expand Down