forked from apache/spark
-
Notifications
You must be signed in to change notification settings - Fork 0
Commit
This commit does not belong to any branch on this repository, and may belong to a fork outside of the repository.
[SPARK-27724][SQL] Implement REPLACE TABLE and REPLACE TABLE AS SELEC…
…T with V2 ## What changes were proposed in this pull request? Implements the `REPLACE TABLE` and `REPLACE TABLE AS SELECT` logical plans. `REPLACE TABLE` is now a valid operation in spark-sql provided that the tables being modified are managed by V2 catalogs. This also introduces an atomic mix-in that table catalogs can choose to implement. Table catalogs can now implement `TransactionalTableCatalog`. The semantics of this API are that table creation and replacement can be "staged" and then "committed". On the execution of `REPLACE TABLE AS SELECT`, `REPLACE TABLE`, and `CREATE TABLE AS SELECT`, if the catalog implements transactional operations, the physical plan will use said functionality. Otherwise, these operations fall back on non-atomic variants. For `REPLACE TABLE` in particular, the usage of non-atomic operations can unfortunately lead to inconsistent state. ## How was this patch tested? Unit tests - multiple additions to `DataSourceV2SQLSuite`. Closes apache#24798 from mccheah/spark-27724. Authored-by: mcheah <[email protected]> Signed-off-by: Wenchen Fan <[email protected]>
- Loading branch information
Showing
14 changed files
with
1,402 additions
and
258 deletions.
There are no files selected for viewing
This file contains bidirectional Unicode text that may be interpreted or compiled differently than what appears below. To review, open the file in an editor that reveals hidden Unicode characters.
Learn more about bidirectional Unicode characters
142 changes: 142 additions & 0 deletions
142
sql/catalyst/src/main/java/org/apache/spark/sql/catalog/v2/StagingTableCatalog.java
This file contains bidirectional Unicode text that may be interpreted or compiled differently than what appears below. To review, open the file in an editor that reveals hidden Unicode characters.
Learn more about bidirectional Unicode characters
Original file line number | Diff line number | Diff line change |
---|---|---|
@@ -0,0 +1,142 @@ | ||
/* | ||
* 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.catalog.v2; | ||
|
||
import java.util.Map; | ||
|
||
import org.apache.spark.sql.catalog.v2.expressions.Transform; | ||
import org.apache.spark.sql.catalyst.analysis.NoSuchNamespaceException; | ||
import org.apache.spark.sql.catalyst.analysis.NoSuchTableException; | ||
import org.apache.spark.sql.catalyst.analysis.TableAlreadyExistsException; | ||
import org.apache.spark.sql.sources.v2.StagedTable; | ||
import org.apache.spark.sql.sources.v2.SupportsWrite; | ||
import org.apache.spark.sql.sources.v2.writer.BatchWrite; | ||
import org.apache.spark.sql.sources.v2.writer.WriterCommitMessage; | ||
import org.apache.spark.sql.types.StructType; | ||
import org.apache.spark.sql.util.CaseInsensitiveStringMap; | ||
|
||
/** | ||
* An optional mix-in for implementations of {@link TableCatalog} that support staging creation of | ||
* the a table before committing the table's metadata along with its contents in CREATE TABLE AS | ||
* SELECT or REPLACE TABLE AS SELECT operations. | ||
* <p> | ||
* It is highly recommended to implement this trait whenever possible so that CREATE TABLE AS | ||
* SELECT and REPLACE TABLE AS SELECT operations are atomic. For example, when one runs a REPLACE | ||
* TABLE AS SELECT operation, if the catalog does not implement this trait, the planner will first | ||
* drop the table via {@link TableCatalog#dropTable(Identifier)}, then create the table via | ||
* {@link TableCatalog#createTable(Identifier, StructType, Transform[], Map)}, and then perform | ||
* the write via {@link SupportsWrite#newWriteBuilder(CaseInsensitiveStringMap)}. However, if the | ||
* write operation fails, the catalog will have already dropped the table, and the planner cannot | ||
* roll back the dropping of the table. | ||
* <p> | ||
* If the catalog implements this plugin, the catalog can implement the methods to "stage" the | ||
* creation and the replacement of a table. After the table's | ||
* {@link BatchWrite#commit(WriterCommitMessage[])} is called, | ||
* {@link StagedTable#commitStagedChanges()} is called, at which point the staged table can | ||
* complete both the data write and the metadata swap operation atomically. | ||
*/ | ||
public interface StagingTableCatalog extends TableCatalog { | ||
|
||
/** | ||
* Stage the creation of a table, preparing it to be committed into the metastore. | ||
* <p> | ||
* When the table is committed, the contents of any writes performed by the Spark planner are | ||
* committed along with the metadata about the table passed into this method's arguments. If the | ||
* table exists when this method is called, the method should throw an exception accordingly. If | ||
* another process concurrently creates the table before this table's staged changes are | ||
* committed, an exception should be thrown by {@link StagedTable#commitStagedChanges()}. | ||
* | ||
* @param ident a table identifier | ||
* @param schema the schema of the new table, as a struct type | ||
* @param partitions transforms to use for partitioning data in the table | ||
* @param properties a string map of table properties | ||
* @return metadata for the new table | ||
* @throws TableAlreadyExistsException If a table or view already exists for the identifier | ||
* @throws UnsupportedOperationException If a requested partition transform is not supported | ||
* @throws NoSuchNamespaceException If the identifier namespace does not exist (optional) | ||
*/ | ||
StagedTable stageCreate( | ||
Identifier ident, | ||
StructType schema, | ||
Transform[] partitions, | ||
Map<String, String> properties) throws TableAlreadyExistsException, NoSuchNamespaceException; | ||
|
||
/** | ||
* Stage the replacement of a table, preparing it to be committed into the metastore when the | ||
* returned table's {@link StagedTable#commitStagedChanges()} is called. | ||
* <p> | ||
* When the table is committed, the contents of any writes performed by the Spark planner are | ||
* committed along with the metadata about the table passed into this method's arguments. If the | ||
* table exists, the metadata and the contents of this table replace the metadata and contents of | ||
* the existing table. If a concurrent process commits changes to the table's data or metadata | ||
* while the write is being performed but before the staged changes are committed, the catalog | ||
* can decide whether to move forward with the table replacement anyways or abort the commit | ||
* operation. | ||
* <p> | ||
* If the table does not exist, committing the staged changes should fail with | ||
* {@link NoSuchTableException}. This differs from the semantics of | ||
* {@link #stageCreateOrReplace(Identifier, StructType, Transform[], Map)}, which should create | ||
* the table in the data source if the table does not exist at the time of committing the | ||
* operation. | ||
* | ||
* @param ident a table identifier | ||
* @param schema the schema of the new table, as a struct type | ||
* @param partitions transforms to use for partitioning data in the table | ||
* @param properties a string map of table properties | ||
* @return metadata for the new table | ||
* @throws UnsupportedOperationException If a requested partition transform is not supported | ||
* @throws NoSuchNamespaceException If the identifier namespace does not exist (optional) | ||
* @throws NoSuchTableException If the table does not exist | ||
*/ | ||
StagedTable stageReplace( | ||
Identifier ident, | ||
StructType schema, | ||
Transform[] partitions, | ||
Map<String, String> properties) throws NoSuchNamespaceException, NoSuchTableException; | ||
|
||
/** | ||
* Stage the creation or replacement of a table, preparing it to be committed into the metastore | ||
* when the returned table's {@link StagedTable#commitStagedChanges()} is called. | ||
* <p> | ||
* When the table is committed, the contents of any writes performed by the Spark planner are | ||
* committed along with the metadata about the table passed into this method's arguments. If the | ||
* table exists, the metadata and the contents of this table replace the metadata and contents of | ||
* the existing table. If a concurrent process commits changes to the table's data or metadata | ||
* while the write is being performed but before the staged changes are committed, the catalog | ||
* can decide whether to move forward with the table replacement anyways or abort the commit | ||
* operation. | ||
* <p> | ||
* If the table does not exist when the changes are committed, the table should be created in the | ||
* backing data source. This differs from the expected semantics of | ||
* {@link #stageReplace(Identifier, StructType, Transform[], Map)}, which should fail when | ||
* the staged changes are committed but the table doesn't exist at commit time. | ||
* | ||
* @param ident a table identifier | ||
* @param schema the schema of the new table, as a struct type | ||
* @param partitions transforms to use for partitioning data in the table | ||
* @param properties a string map of table properties | ||
* @return metadata for the new table | ||
* @throws UnsupportedOperationException If a requested partition transform is not supported | ||
* @throws NoSuchNamespaceException If the identifier namespace does not exist (optional) | ||
*/ | ||
StagedTable stageCreateOrReplace( | ||
Identifier ident, | ||
StructType schema, | ||
Transform[] partitions, | ||
Map<String, String> properties) throws NoSuchNamespaceException; | ||
} |
52 changes: 52 additions & 0 deletions
52
sql/catalyst/src/main/java/org/apache/spark/sql/sources/v2/StagedTable.java
This file contains bidirectional Unicode text that may be interpreted or compiled differently than what appears below. To review, open the file in an editor that reveals hidden Unicode characters.
Learn more about bidirectional Unicode characters
Original file line number | Diff line number | Diff line change |
---|---|---|
@@ -0,0 +1,52 @@ | ||
/* | ||
* 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.sources.v2; | ||
|
||
import java.util.Map; | ||
import org.apache.spark.sql.catalog.v2.Identifier; | ||
import org.apache.spark.sql.catalog.v2.StagingTableCatalog; | ||
import org.apache.spark.sql.catalog.v2.expressions.Transform; | ||
import org.apache.spark.sql.types.StructType; | ||
import org.apache.spark.sql.util.CaseInsensitiveStringMap; | ||
|
||
/** | ||
* Represents a table which is staged for being committed to the metastore. | ||
* <p> | ||
* This is used to implement atomic CREATE TABLE AS SELECT and REPLACE TABLE AS SELECT queries. The | ||
* planner will create one of these via | ||
* {@link StagingTableCatalog#stageCreate(Identifier, StructType, Transform[], Map)} or | ||
* {@link StagingTableCatalog#stageReplace(Identifier, StructType, Transform[], Map)} to prepare the | ||
* table for being written to. This table should usually implement {@link SupportsWrite}. A new | ||
* writer will be constructed via {@link SupportsWrite#newWriteBuilder(CaseInsensitiveStringMap)}, | ||
* and the write will be committed. The job concludes with a call to {@link #commitStagedChanges()}, | ||
* at which point implementations are expected to commit the table's metadata into the metastore | ||
* along with the data that was written by the writes from the write builder this table created. | ||
*/ | ||
public interface StagedTable extends Table { | ||
|
||
/** | ||
* Finalize the creation or replacement of this table. | ||
*/ | ||
void commitStagedChanges(); | ||
|
||
/** | ||
* Abort the changes that were staged, both in metadata and from temporary outputs of this | ||
* table's writers. | ||
*/ | ||
void abortStagedChanges(); | ||
} |
29 changes: 29 additions & 0 deletions
29
...ain/scala/org/apache/spark/sql/catalyst/analysis/CannotReplaceMissingTableException.scala
This file contains bidirectional Unicode text that may be interpreted or compiled differently than what appears below. To review, open the file in an editor that reveals hidden Unicode characters.
Learn more about bidirectional Unicode characters
Original file line number | Diff line number | Diff line change |
---|---|---|
@@ -0,0 +1,29 @@ | ||
/* | ||
* 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.catalyst.analysis | ||
|
||
import org.apache.spark.sql.AnalysisException | ||
import org.apache.spark.sql.catalog.v2.Identifier | ||
|
||
class CannotReplaceMissingTableException( | ||
tableIdentifier: Identifier, | ||
cause: Option[Throwable] = None) | ||
extends AnalysisException( | ||
s"Table $tableIdentifier cannot be replaced as it did not exist." + | ||
s" Use CREATE OR REPLACE TABLE to create the table.", cause = cause) |
This file contains bidirectional Unicode text that may be interpreted or compiled differently than what appears below. To review, open the file in an editor that reveals hidden Unicode characters.
Learn more about bidirectional Unicode characters
This file contains bidirectional Unicode text that may be interpreted or compiled differently than what appears below. To review, open the file in an editor that reveals hidden Unicode characters.
Learn more about bidirectional Unicode characters
Oops, something went wrong.