InsertUtils.java

// Licensed to the Apache Software Foundation (ASF) under one
// or more contributor license agreements.  See the NOTICE file
// distributed with this work for additional information
// regarding copyright ownership.  The ASF licenses this file
// to you under the Apache License, Version 2.0 (the
// "License"); you may not use this file except in compliance
// with the License.  You may obtain a copy of the License at
//
//   http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing,
// software distributed under the License is distributed on an
// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
// KIND, either express or implied.  See the License for the
// specific language governing permissions and limitations
// under the License.

package org.apache.doris.nereids.trees.plans.commands.insert;

import org.apache.doris.catalog.Column;
import org.apache.doris.catalog.Database;
import org.apache.doris.catalog.Env;
import org.apache.doris.catalog.GeneratedColumnInfo;
import org.apache.doris.catalog.KeysType;
import org.apache.doris.catalog.OlapTable;
import org.apache.doris.catalog.Table;
import org.apache.doris.catalog.TableIf;
import org.apache.doris.common.Config;
import org.apache.doris.common.FormatOptions;
import org.apache.doris.datasource.hive.HMSExternalTable;
import org.apache.doris.datasource.jdbc.JdbcExternalTable;
import org.apache.doris.nereids.CascadesContext;
import org.apache.doris.nereids.analyzer.Scope;
import org.apache.doris.nereids.analyzer.UnboundAlias;
import org.apache.doris.nereids.analyzer.UnboundDictionarySink;
import org.apache.doris.nereids.analyzer.UnboundFunction;
import org.apache.doris.nereids.analyzer.UnboundHiveTableSink;
import org.apache.doris.nereids.analyzer.UnboundIcebergTableSink;
import org.apache.doris.nereids.analyzer.UnboundInlineTable;
import org.apache.doris.nereids.analyzer.UnboundJdbcTableSink;
import org.apache.doris.nereids.analyzer.UnboundSlot;
import org.apache.doris.nereids.analyzer.UnboundStar;
import org.apache.doris.nereids.analyzer.UnboundTableSink;
import org.apache.doris.nereids.analyzer.UnboundVariable;
import org.apache.doris.nereids.exceptions.AnalysisException;
import org.apache.doris.nereids.parser.NereidsParser;
import org.apache.doris.nereids.properties.PhysicalProperties;
import org.apache.doris.nereids.rules.analysis.ExpressionAnalyzer;
import org.apache.doris.nereids.rules.expression.ExpressionRewriteContext;
import org.apache.doris.nereids.rules.expression.rules.ConvertAggStateCast;
import org.apache.doris.nereids.rules.expression.rules.FoldConstantRuleOnFE;
import org.apache.doris.nereids.trees.expressions.Alias;
import org.apache.doris.nereids.trees.expressions.Cast;
import org.apache.doris.nereids.trees.expressions.DefaultValueSlot;
import org.apache.doris.nereids.trees.expressions.Expression;
import org.apache.doris.nereids.trees.expressions.NamedExpression;
import org.apache.doris.nereids.trees.expressions.literal.Literal;
import org.apache.doris.nereids.trees.expressions.literal.NullLiteral;
import org.apache.doris.nereids.trees.plans.Plan;
import org.apache.doris.nereids.trees.plans.algebra.InlineTable;
import org.apache.doris.nereids.trees.plans.commands.info.DMLCommandType;
import org.apache.doris.nereids.trees.plans.logical.LogicalInlineTable;
import org.apache.doris.nereids.trees.plans.logical.LogicalPlan;
import org.apache.doris.nereids.trees.plans.logical.UnboundLogicalSink;
import org.apache.doris.nereids.types.AggStateType;
import org.apache.doris.nereids.types.DataType;
import org.apache.doris.nereids.util.RelationUtil;
import org.apache.doris.nereids.util.TypeCoercionUtils;
import org.apache.doris.proto.InternalService;
import org.apache.doris.qe.ConnectContext;
import org.apache.doris.qe.InsertStreamTxnExecutor;
import org.apache.doris.qe.MasterTxnExecutor;
import org.apache.doris.qe.SessionVariable;
import org.apache.doris.qe.StmtExecutor;
import org.apache.doris.service.ExecuteEnv;
import org.apache.doris.service.FrontendOptions;
import org.apache.doris.thrift.TFileFormatType;
import org.apache.doris.thrift.TFileType;
import org.apache.doris.thrift.TLoadTxnBeginRequest;
import org.apache.doris.thrift.TLoadTxnBeginResult;
import org.apache.doris.thrift.TMergeType;
import org.apache.doris.thrift.TStreamLoadPutRequest;
import org.apache.doris.thrift.TTxnParams;
import org.apache.doris.transaction.TransactionEntry;
import org.apache.doris.transaction.TransactionState;
import org.apache.doris.transaction.TransactionStatus;

import com.google.common.collect.ImmutableList;
import com.google.common.collect.Lists;
import com.google.common.collect.Sets;
import org.apache.commons.collections.CollectionUtils;
import org.apache.commons.lang3.StringUtils;

import java.util.ArrayList;
import java.util.List;
import java.util.Optional;
import java.util.Set;
import java.util.stream.Collectors;

/**
 * The helper class for insert operation.
 */
public class InsertUtils {

    /**
     * execute insert values in transaction.
     */
    public static void executeBatchInsertTransaction(ConnectContext ctx, String dbName, String tableName,
            List<Column> columns, List<List<NamedExpression>> constantExprsList) {
        if (ctx.isInsertValuesTxnIniting()) { // first time, begin txn
            beginBatchInsertTransaction(ctx, dbName, tableName, columns);
        }
        if (!ctx.getTxnEntry().getTxnConf().getDb().equals(dbName)
                || !ctx.getTxnEntry().getTxnConf().getTbl().equals(tableName)) {
            throw new AnalysisException("Only one table can be inserted in one transaction.");
        }

        TransactionEntry txnEntry = ctx.getTxnEntry();
        int effectRows = 0;
        FormatOptions options = FormatOptions.getDefault();
        for (List<NamedExpression> row : constantExprsList) {
            ++effectRows;
            InternalService.PDataRow data = getRowStringValue(row, options);
            if (data == null) {
                continue;
            }
            List<InternalService.PDataRow> dataToSend = txnEntry.getDataToSend();
            dataToSend.add(data);
            if (dataToSend.size() >= StmtExecutor.MAX_DATA_TO_SEND_FOR_TXN) {
                // send data
                InsertStreamTxnExecutor executor = new InsertStreamTxnExecutor(txnEntry);
                try {
                    executor.sendData();
                } catch (Exception e) {
                    throw new AnalysisException("send data to be failed, because " + e.getMessage(), e);
                }
            }
        }
        txnEntry.setRowsInTransaction(txnEntry.getRowsInTransaction() + effectRows);

        // {'label':'my_label1', 'status':'visible', 'txnId':'123'}
        // {'label':'my_label1', 'status':'visible', 'txnId':'123' 'err':'error messages'}
        String sb = "{'label':'" + ctx.getTxnEntry().getLabel()
                + "', 'status':'" + TransactionStatus.PREPARE.name()
                + "', 'txnId':'" + ctx.getTxnEntry().getTxnConf().getTxnId() + "'"
                + "}";

        ctx.getState().setOk(effectRows, 0, sb);
        // set insert result in connection context,
        // so that user can use `show insert result` to get info of the last insert operation.
        ctx.setOrUpdateInsertResult(
                ctx.getTxnEntry().getTxnConf().getTxnId(),
                ctx.getTxnEntry().getLabel(),
                dbName,
                tableName,
                TransactionStatus.PREPARE,
                effectRows,
                0);
        // update it, so that user can get loaded rows in fe.audit.log
        ctx.updateReturnRows(effectRows);
    }

    /**
     * literal expr in insert operation
     */
    public static InternalService.PDataRow getRowStringValue(List<NamedExpression> cols, FormatOptions options) {
        if (cols.isEmpty()) {
            return null;
        }
        InternalService.PDataRow.Builder row = InternalService.PDataRow.newBuilder();
        for (Expression expr : cols) {
            while (expr instanceof Alias || expr instanceof Cast) {
                expr = expr.child(0);
            }
            if (!(expr instanceof Literal)) {
                throw new AnalysisException(
                        "do not support non-literal expr in transactional insert operation: " + expr.toSql());
            }
            row.addColBuilder().setValue(((Literal) expr).toLegacyLiteral().getStringValueForStreamLoad(options));
        }
        return row.build();
    }

    private static void beginBatchInsertTransaction(ConnectContext ctx,
            String dbName, String tblName, List<Column> columns) {
        TransactionEntry txnEntry = ctx.getTxnEntry();
        if (txnEntry.isTransactionBegan()) {
            // FIXME: support mix usage of `insert into values` and `insert into select`
            throw new AnalysisException(
                    "Transaction insert can not insert into values and insert into select at the same time");
        }
        TTxnParams txnConf = txnEntry.getTxnConf();
        SessionVariable sessionVariable = ctx.getSessionVariable();
        long timeoutSecond = ctx.getExecTimeoutS();
        TransactionState.LoadJobSourceType sourceType = TransactionState.LoadJobSourceType.INSERT_STREAMING;
        Database dbObj = Env.getCurrentInternalCatalog()
                .getDbOrException(dbName, s -> new AnalysisException("database is invalid for dbName: " + s));
        Table tblObj = dbObj.getTableOrException(tblName, s -> new AnalysisException("table is invalid: " + s));
        txnConf.setDbId(dbObj.getId()).setTbl(tblName).setDb(dbName);
        txnEntry.setTable(tblObj);
        txnEntry.setDb(dbObj);
        String label = txnEntry.getLabel();
        try {
            long txnId;
            String token = Env.getCurrentEnv().getTokenManager().acquireToken();
            if (Config.isCloudMode() || Env.getCurrentEnv().isMaster()) {
                txnId = Env.getCurrentGlobalTransactionMgr().beginTransaction(
                        txnConf.getDbId(), Lists.newArrayList(tblObj.getId()), label,
                        new TransactionState.TxnCoordinator(TransactionState.TxnSourceType.FE, 0,
                                FrontendOptions.getLocalHostAddress(),
                                ExecuteEnv.getInstance().getStartupTime()),
                        sourceType, timeoutSecond);
            } else {
                MasterTxnExecutor masterTxnExecutor = new MasterTxnExecutor(ctx);
                TLoadTxnBeginRequest request = new TLoadTxnBeginRequest();
                request.setDb(txnConf.getDb()).setTbl(txnConf.getTbl()).setToken(token)
                        .setLabel(label).setUser("").setUserIp("").setPasswd("");
                TLoadTxnBeginResult result = masterTxnExecutor.beginTxn(request);
                txnId = result.getTxnId();
            }
            txnConf.setTxnId(txnId);
            txnConf.setToken(token);
        } catch (Exception e) {
            throw new AnalysisException(e.getMessage(), e);
        }

        TStreamLoadPutRequest request = new TStreamLoadPutRequest();
        long maxExecMemByte = sessionVariable.getMaxExecMemByte();
        String timeZone = sessionVariable.getTimeZone();
        int sendBatchParallelism = sessionVariable.getSendBatchParallelism();
        request.setTxnId(txnConf.getTxnId())
                .setDb(txnConf.getDb())
                .setTbl(txnConf.getTbl())
                .setColumns(columns.stream()
                        .map(Column::getName)
                        .map(n -> n.replace("`", "``"))
                        .map(n -> "`" + n + "`")
                        .collect(Collectors.joining(",")))
                .setFileType(TFileType.FILE_STREAM)
                .setFormatType(TFileFormatType.FORMAT_CSV_PLAIN)
                .setMergeType(TMergeType.APPEND)
                .setThriftRpcTimeoutMs(5000)
                .setLoadId(ctx.queryId())
                .setExecMemLimit(maxExecMemByte)
                .setTimeout((int) timeoutSecond)
                .setTimezone(timeZone)
                .setSendBatchParallelism(sendBatchParallelism)
                .setSequenceCol(columns.stream()
                        .filter(c -> Column.SEQUENCE_COL.equalsIgnoreCase(c.getName()))
                        .map(Column::getName)
                        .findFirst()
                        .orElse(null));

        // execute begin txn
        InsertStreamTxnExecutor executor = new InsertStreamTxnExecutor(txnEntry);
        try {
            executor.beginTransaction(request);
        } catch (Exception e) {
            throw new AnalysisException(e.getMessage(), e);
        }
    }

    /**
     * normalize plan to let it could be process correctly by nereids
     */
    public static Plan normalizePlan(LogicalPlan plan, TableIf table,
            Optional<CascadesContext> analyzeContext,
            Optional<InsertCommandContext> insertCtx) {
        table.readLock();
        try {
            return normalizePlanWithoutLock(plan, table, analyzeContext, insertCtx);
        } finally {
            table.readUnlock();
        }
    }

    private static Plan normalizePlanWithoutLock(LogicalPlan plan, TableIf table,
                                     Optional<CascadesContext> analyzeContext,
                                     Optional<InsertCommandContext> insertCtx) {
        UnboundLogicalSink<? extends Plan> unboundLogicalSink = (UnboundLogicalSink<? extends Plan>) plan;
        if (table instanceof HMSExternalTable) {
            HMSExternalTable hiveTable = (HMSExternalTable) table;
            if (hiveTable.isView()) {
                throw new AnalysisException("View is not support in hive external table.");
            }
        }
        if (table instanceof JdbcExternalTable) {
            // todo:
            // For JDBC External Table, we always allow certain columns to be missing during insertion
            // Specific check for non-nullable columns only if insertion is direct VALUES or SELECT constants
        }
        if (table instanceof OlapTable && ((OlapTable) table).getKeysType() == KeysType.UNIQUE_KEYS) {
            if (unboundLogicalSink instanceof UnboundTableSink
                    && ((UnboundTableSink<? extends Plan>) unboundLogicalSink).isPartialUpdate()) {
                // check the necessary conditions for partial updates
                OlapTable olapTable = (OlapTable) table;

                if (!olapTable.getEnableUniqueKeyMergeOnWrite() || olapTable.isUniqKeyMergeOnWriteWithClusterKeys()) {
                    // when enable_unique_key_partial_update = true,
                    // only unique table with MOW (and without cluster keys)
                    // insert with target columns can consider be a partial update,
                    // and unique table without MOW, insert will be like a normal insert.
                    ((UnboundTableSink<? extends Plan>) unboundLogicalSink).setPartialUpdate(false);
                } else {
                    if (unboundLogicalSink.getDMLCommandType() == DMLCommandType.INSERT) {
                        if (unboundLogicalSink.getColNames().isEmpty()) {
                            ((UnboundTableSink<? extends Plan>) unboundLogicalSink).setPartialUpdate(false);
                        } else {
                            boolean hasSyncMaterializedView = olapTable.getFullSchema().stream()
                                    .anyMatch(col -> col.isMaterializedViewColumn());
                            if (hasSyncMaterializedView) {
                                throw new AnalysisException("Can't do partial update on merge-on-write Unique table"
                                        + " with sync materialized view.");
                            }
                            boolean hasMissingColExceptAutoIncKey = false;
                            boolean hasMissingAutoIncKey = false;
                            for (Column col : olapTable.getFullSchema()) {
                                Optional<String> insertCol = unboundLogicalSink.getColNames().stream()
                                        .filter(c -> c.equalsIgnoreCase(col.getName())).findFirst();
                                if (col.isKey() && !col.isAutoInc() && !insertCol.isPresent()) {
                                    throw new AnalysisException("Partial update should include all key columns,"
                                            + " missing: " + col.getName());
                                }
                                if (!col.getGeneratedColumnsThatReferToThis().isEmpty()
                                        && col.getGeneratedColumnInfo() == null && !insertCol.isPresent()) {
                                    throw new AnalysisException("Partial update should include"
                                            + " all ordinary columns referenced"
                                            + " by generated columns, missing: " + col.getName());
                                }
                                if (!(col.isAutoInc() && col.isKey()) && !insertCol.isPresent() && col.isVisible()) {
                                    hasMissingColExceptAutoIncKey = true;
                                }
                                if (col.isAutoInc() && col.isKey() && !insertCol.isPresent()) {
                                    hasMissingAutoIncKey = true;
                                }
                            }
                            if (!hasMissingColExceptAutoIncKey) {
                                ((UnboundTableSink<? extends Plan>) unboundLogicalSink).setPartialUpdate(false);
                            } else {
                                if (hasMissingAutoIncKey) {
                                    // becuase of the uniqueness of genetaed value of auto-increment column,
                                    // we convert this load to upsert when is misses auto-increment key column
                                    ((UnboundTableSink<? extends Plan>) unboundLogicalSink).setPartialUpdate(false);
                                }
                            }
                        }
                    }
                }
            }
        }
        Plan query = unboundLogicalSink.child();
        checkGeneratedColumnForInsertIntoSelect(table, unboundLogicalSink, insertCtx);
        if (!(query instanceof UnboundInlineTable)) {
            return plan;
        }

        UnboundInlineTable unboundInlineTable = (UnboundInlineTable) query;
        ImmutableList.Builder<List<NamedExpression>> optimizedRowConstructors
                = ImmutableList.builderWithExpectedSize(unboundInlineTable.getConstantExprsList().size());
        List<Column> columns = table.getBaseSchema(false);

        ConnectContext context = ConnectContext.get();
        ExpressionRewriteContext rewriteContext = null;
        if (context != null && context.getStatementContext() != null) {
            rewriteContext = new ExpressionRewriteContext(
                    CascadesContext.initContext(
                            context.getStatementContext(), unboundInlineTable, PhysicalProperties.ANY
                    )
            );
        }

        Optional<ExpressionAnalyzer> analyzer = analyzeContext.map(
                cascadesContext -> buildExprAnalyzer(plan, cascadesContext)
        );

        for (List<NamedExpression> values : unboundInlineTable.getConstantExprsList()) {
            ImmutableList.Builder<NamedExpression> optimizedRowConstructor = ImmutableList.builder();
            if (values.isEmpty()) {
                if (CollectionUtils.isNotEmpty(unboundLogicalSink.getColNames())) {
                    throw new AnalysisException("value list should not be empty if columns are specified");
                }
                for (int i = 0; i < columns.size(); i++) {
                    Column column = columns.get(i);
                    NamedExpression defaultExpression = generateDefaultExpression(column);
                    addColumnValue(analyzer, optimizedRowConstructor, defaultExpression);
                }
            } else {
                if (CollectionUtils.isNotEmpty(unboundLogicalSink.getColNames())) {
                    if (values.size() != unboundLogicalSink.getColNames().size()) {
                        throw new AnalysisException("Column count doesn't match value count");
                    }
                    for (int i = 0; i < values.size(); i++) {
                        Column sameNameColumn = null;
                        for (Column column : table.getBaseSchema(true)) {
                            if (unboundLogicalSink.getColNames().get(i).equalsIgnoreCase(column.getName())) {
                                sameNameColumn = column;
                                break;
                            }
                        }
                        if (sameNameColumn == null) {
                            throw new AnalysisException("Unknown column '"
                                    + unboundLogicalSink.getColNames().get(i) + "' in target table.");
                        }
                        if (sameNameColumn.getGeneratedColumnInfo() != null
                                && !(values.get(i) instanceof DefaultValueSlot)) {
                            throw new AnalysisException("The value specified for generated column '"
                                    + sameNameColumn.getName()
                                    + "' in table '" + table.getName() + "' is not allowed.");
                        }
                        if (values.get(i) instanceof DefaultValueSlot) {
                            NamedExpression defaultExpression = generateDefaultExpression(sameNameColumn);
                            addColumnValue(analyzer, optimizedRowConstructor, defaultExpression);
                        } else {
                            DataType targetType = DataType.fromCatalogType(sameNameColumn.getType());
                            Expression castValue = castValue(values.get(i), targetType);
                            castValue = rewriteContext == null
                                    ? castValue
                                    : FoldConstantRuleOnFE.evaluate(castValue, rewriteContext);
                            addColumnValue(analyzer, optimizedRowConstructor, (NamedExpression) castValue);
                        }
                    }
                } else {
                    if (values.size() != columns.size()) {
                        throw new AnalysisException("Column count doesn't match value count");
                    }
                    for (int i = 0; i < columns.size(); i++) {
                        if (columns.get(i).getGeneratedColumnInfo() != null
                                && !(values.get(i) instanceof DefaultValueSlot)) {
                            throw new AnalysisException("The value specified for generated column '"
                                    + columns.get(i).getName()
                                    + "' in table '" + table.getName() + "' is not allowed.");
                        }
                        if (values.get(i) instanceof DefaultValueSlot) {
                            NamedExpression defaultExpression = generateDefaultExpression(columns.get(i));
                            addColumnValue(analyzer, optimizedRowConstructor, defaultExpression);
                        } else {
                            DataType targetType = DataType.fromCatalogType(columns.get(i).getType());
                            Expression castValue = castValue(values.get(i), targetType);
                            castValue = rewriteContext == null
                                    ? castValue
                                    : FoldConstantRuleOnFE.evaluate(castValue, rewriteContext);
                            addColumnValue(analyzer, optimizedRowConstructor, (NamedExpression) castValue);
                        }
                    }
                }
            }
            optimizedRowConstructors.add(optimizedRowConstructor.build());
        }
        return plan.withChildren(new LogicalInlineTable(optimizedRowConstructors.build()));
    }

    /** buildAnalyzer */
    public static ExpressionAnalyzer buildExprAnalyzer(Plan plan, CascadesContext analyzeContext) {
        return new ExpressionAnalyzer(plan, new Scope(ImmutableList.of()),
            analyzeContext, false, false) {
            @Override
            public Expression visitCast(Cast cast, ExpressionRewriteContext context) {
                Expression expr = super.visitCast(cast, context);
                if (expr instanceof Cast) {
                    if (expr.child(0).getDataType() instanceof AggStateType) {
                        expr = ConvertAggStateCast.convert((Cast) expr);
                    } else {
                        expr = FoldConstantRuleOnFE.evaluate(expr, context);
                    }
                }
                return expr;
            }

            @Override
            public Expression visitUnboundFunction(UnboundFunction unboundFunction, ExpressionRewriteContext context) {
                Expression expr = super.visitUnboundFunction(unboundFunction, context);
                if (expr instanceof UnboundFunction) {
                    throw new IllegalStateException("Can not analyze function " + unboundFunction.getName());
                }
                return expr;
            }

            @Override
            public Expression visitUnboundSlot(UnboundSlot unboundSlot, ExpressionRewriteContext context) {
                Expression expr = super.visitUnboundSlot(unboundSlot, context);
                if (expr instanceof UnboundFunction) {
                    throw new AnalysisException("Can not analyze slot " + unboundSlot.getName());
                }
                return expr;
            }

            @Override
            public Expression visitUnboundVariable(UnboundVariable unboundVariable, ExpressionRewriteContext context) {
                Expression expr = super.visitUnboundVariable(unboundVariable, context);
                if (expr instanceof UnboundVariable) {
                    throw new AnalysisException("Can not analyze variable " + unboundVariable.getName());
                }
                return expr;
            }

            @Override
            public Expression visitUnboundAlias(UnboundAlias unboundAlias, ExpressionRewriteContext context) {
                Expression expr = super.visitUnboundAlias(unboundAlias, context);
                if (expr instanceof UnboundVariable) {
                    throw new AnalysisException("Can not analyze alias");
                }
                return expr;
            }

            @Override
            public Expression visitUnboundStar(UnboundStar unboundStar, ExpressionRewriteContext context) {
                Expression expr = super.visitUnboundStar(unboundStar, context);
                if (expr instanceof UnboundStar) {
                    List<String> qualifier = unboundStar.getQualifier();
                    List<String> qualified = new ArrayList<>(qualifier);
                    qualified.add("*");
                    throw new AnalysisException("Can not analyze " + StringUtils.join(qualified, "."));
                }
                return expr;
            }
        };
    }

    private static void addColumnValue(
            Optional<ExpressionAnalyzer> analyzer,
            ImmutableList.Builder<NamedExpression> optimizedRowConstructor,
            NamedExpression value) {
        if (analyzer.isPresent() && !(value instanceof Alias && value.child(0) instanceof Literal)) {
            ExpressionAnalyzer expressionAnalyzer = analyzer.get();
            value = (NamedExpression) expressionAnalyzer.analyze(
                value, new ExpressionRewriteContext(expressionAnalyzer.getCascadesContext())
            );
        }
        optimizedRowConstructor.add(value);
    }

    private static Expression castValue(Expression value, DataType targetType) {
        if (value instanceof Alias) {
            Expression oldChild = value.child(0);
            Expression newChild = TypeCoercionUtils.castUnbound(oldChild, targetType);
            return oldChild == newChild ? value : value.withChildren(newChild);
        } else if (value instanceof UnboundAlias) {
            UnboundAlias unboundAlias = (UnboundAlias) value;
            return new Alias(TypeCoercionUtils.castUnbound(unboundAlias.child(), targetType));
        } else {
            return TypeCoercionUtils.castUnbound(value, targetType);
        }
    }

    /**
     * get target table from names.
     */
    public static TableIf getTargetTable(Plan plan, ConnectContext ctx) {
        List<String> tableQualifier = getTargetTableQualified(plan, ctx);
        return RelationUtil.getTable(tableQualifier, ctx.getEnv());
    }

    /**
     * get target table from names.
     */
    public static List<String> getTargetTableQualified(Plan plan, ConnectContext ctx) {
        UnboundLogicalSink<? extends Plan> unboundTableSink;
        if (plan instanceof UnboundTableSink) {
            unboundTableSink = (UnboundTableSink<? extends Plan>) plan;
        } else if (plan instanceof UnboundHiveTableSink) {
            unboundTableSink = (UnboundHiveTableSink<? extends Plan>) plan;
        } else if (plan instanceof UnboundIcebergTableSink) {
            unboundTableSink = (UnboundIcebergTableSink<? extends Plan>) plan;
        } else if (plan instanceof UnboundJdbcTableSink) {
            unboundTableSink = (UnboundJdbcTableSink<? extends Plan>) plan;
        } else if (plan instanceof UnboundDictionarySink) {
            unboundTableSink = (UnboundDictionarySink<? extends Plan>) plan;
        } else {
            throw new AnalysisException(
                    "the root of plan only accept Olap, Dictionary, Hive, Iceberg or Jdbc table sink, but it is "
                            + plan.getType());
        }
        return RelationUtil.getQualifierName(ctx, unboundTableSink.getNameParts());
    }

    private static NamedExpression generateDefaultExpression(Column column) {
        try {
            GeneratedColumnInfo generatedColumnInfo = column.getGeneratedColumnInfo();
            // Using NullLiteral as a placeholder.
            // If return the expr in generatedColumnInfo, will lead to slot not found error in analyze.
            // Instead, getting the generated column expr and analyze the expr in BindSink can avoid the error.
            if (generatedColumnInfo != null) {
                return new Alias(new NullLiteral(DataType.fromCatalogType(column.getType())), column.getName());
            }
            if (column.getDefaultValue() == null) {
                if (!column.isAllowNull() && !column.isAutoInc()) {
                    throw new AnalysisException("Column has no default value, column=" + column.getName());
                }
            }
            if (column.getDefaultValueExpr() != null) {
                Expression defualtValueExpression = new NereidsParser().parseExpression(
                        column.getDefaultValueExpr().toSqlWithoutTbl());
                if (!(defualtValueExpression instanceof UnboundAlias)) {
                    defualtValueExpression = new UnboundAlias(defualtValueExpression);
                }
                return (NamedExpression) defualtValueExpression;
            } else {
                return new Alias(Literal.of(column.getDefaultValue())
                        .checkedCastTo(DataType.fromCatalogType(column.getType())),
                        column.getName());
            }
        } catch (org.apache.doris.common.AnalysisException e) {
            throw new AnalysisException(e.getMessage(), e);
        }
    }

    /**
     * get plan for explain.
     */
    public static Plan getPlanForExplain(
            ConnectContext ctx, Optional<CascadesContext> analyzeContext, LogicalPlan logicalQuery) {
        return InsertUtils.normalizePlan(
            logicalQuery, InsertUtils.getTargetTable(logicalQuery, ctx), analyzeContext, Optional.empty());
    }

    /** supportFastInsertIntoValues */
    public static boolean supportFastInsertIntoValues(
            LogicalPlan logicalPlan, TableIf targetTableIf, ConnectContext ctx) {
        return logicalPlan instanceof UnboundTableSink && logicalPlan.child(0) instanceof InlineTable
                && targetTableIf instanceof OlapTable
                && ctx != null && ctx.getSessionVariable().isEnableFastAnalyzeInsertIntoValues();
    }

    // check for insert into t1(a,b,gen_col) select 1,2,3;
    private static void checkGeneratedColumnForInsertIntoSelect(TableIf table,
            UnboundLogicalSink<? extends Plan> unboundLogicalSink, Optional<InsertCommandContext> insertCtx) {
        // should not check delete stmt, because deletestmt can transform to insert delete sign
        if (unboundLogicalSink.getDMLCommandType() == DMLCommandType.DELETE
                || unboundLogicalSink.getDMLCommandType() == DMLCommandType.GROUP_COMMIT) {
            return;
        }
        // This is for the insert overwrite values(),()
        // Insert overwrite stmt can enter normalizePlan() twice.
        // Insert overwrite values(),() is checked in the first time when deal with ConstantExprsList,
        // and then the insert into values(),() will be transformed to insert into union all in normalizePlan,
        // and this function is for insert into select, which will check the insert into union all again,
        // and that is no need, also will lead to problems.
        // So for insert overwrite values(),(), this check is only performed
        // when it first enters the normalizePlan checking constantExprsList
        if (insertCtx.isPresent() && insertCtx.get() instanceof OlapInsertCommandContext
                && ((OlapInsertCommandContext) insertCtx.get()).isOverwrite()) {
            return;
        }
        Plan query = unboundLogicalSink.child();
        if (table instanceof OlapTable && !(query instanceof InlineTable)) {
            OlapTable olapTable = (OlapTable) table;
            Set<String> insertNames = Sets.newHashSet();
            if (unboundLogicalSink.getColNames() != null) {
                insertNames.addAll(unboundLogicalSink.getColNames());
            }
            if (insertNames.isEmpty()) {
                for (Column col : olapTable.getFullSchema()) {
                    if (col.getGeneratedColumnInfo() != null) {
                        throw new AnalysisException("The value specified for generated column '"
                                + col.getName()
                                + "' in table '" + table.getName() + "' is not allowed.");
                    }
                }
            } else {
                for (Column col : olapTable.getFullSchema()) {
                    if (col.getGeneratedColumnInfo() != null && insertNames.contains(col.getName())) {
                        throw new AnalysisException("The value specified for generated column '"
                                + col.getName()
                                + "' in table '" + table.getName() + "' is not allowed.");
                    }
                }
            }
        }
    }
}