RemoteDorisScanNode.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.datasource.doris.source;
import org.apache.doris.analysis.BinaryPredicate;
import org.apache.doris.analysis.BoolLiteral;
import org.apache.doris.analysis.DateLiteral;
import org.apache.doris.analysis.Expr;
import org.apache.doris.analysis.ExprSubstitutionMap;
import org.apache.doris.analysis.SlotDescriptor;
import org.apache.doris.analysis.SlotRef;
import org.apache.doris.analysis.TupleDescriptor;
import org.apache.doris.catalog.Column;
import org.apache.doris.catalog.TableIf;
import org.apache.doris.common.Pair;
import org.apache.doris.common.UserException;
import org.apache.doris.datasource.FileQueryScanNode;
import org.apache.doris.planner.PlanNodeId;
import org.apache.doris.qe.ConnectContext;
import org.apache.doris.qe.SessionVariable;
import org.apache.doris.spi.Split;
import org.apache.doris.thrift.TExplainLevel;
import org.apache.doris.thrift.TFileFormatType;
import org.apache.doris.thrift.TFileRangeDesc;
import org.apache.doris.thrift.TRemoteDorisFileDesc;
import org.apache.doris.thrift.TTableFormatFileDesc;
import com.google.common.base.Joiner;
import com.google.common.collect.Lists;
import org.apache.arrow.flight.CallOptions;
import org.apache.arrow.flight.FlightClient;
import org.apache.arrow.flight.FlightEndpoint;
import org.apache.arrow.flight.FlightInfo;
import org.apache.arrow.flight.Location;
import org.apache.arrow.flight.grpc.CredentialCallOption;
import org.apache.arrow.flight.sql.FlightSqlClient;
import org.apache.arrow.memory.BufferAllocator;
import org.apache.arrow.memory.RootAllocator;
import org.apache.logging.log4j.LogManager;
import org.apache.logging.log4j.Logger;
import java.net.URI;
import java.nio.ByteBuffer;
import java.util.ArrayList;
import java.util.HashSet;
import java.util.List;
import java.util.Map;
import java.util.Optional;
import java.util.Set;
import java.util.concurrent.TimeUnit;
import java.util.stream.Collectors;
public class RemoteDorisScanNode extends FileQueryScanNode {
private static final Logger LOG = LogManager.getLogger(RemoteDorisScanNode.class);
public static final String BOOLEAN_TRUE_REPRESENTATION = "1";
private final List<String> columns = new ArrayList<String>();
private final List<String> filters = new ArrayList<String>();
private RemoteDorisSource source;
public RemoteDorisScanNode(PlanNodeId id, TupleDescriptor desc, boolean needCheckColumnPriv,
SessionVariable sv) {
super(id, desc, "REMOTE_DORIS_SCAN_NODE", needCheckColumnPriv, sv);
}
@Override
protected void doInitialize() throws UserException {
super.doInitialize();
source = new RemoteDorisSource(desc);
}
@Override
public List<Split> getSplits(int numBackends) throws UserException {
List<Pair<String, ByteBuffer>> locationAndTicketList = executeQuery();
return locationAndTicketList.stream()
.map(locationAndTicket -> new RemoteDorisSplit(locationAndTicket.first, locationAndTicket.second))
.collect(Collectors.toList());
}
@Override
protected void setScanParams(TFileRangeDesc rangeDesc, Split split) {
if (split instanceof RemoteDorisSplit) {
RemoteDorisSplit dorisArrowSplit = (RemoteDorisSplit) split;
TRemoteDorisFileDesc fileDesc = new TRemoteDorisFileDesc();
fileDesc.setIp(source.getHostAndArrowPort().key());
fileDesc.setArrowPort(source.getHostAndArrowPort().value().toString());
fileDesc.setTicket(dorisArrowSplit.getTicket());
fileDesc.setLocationUri(dorisArrowSplit.getLocation());
fileDesc.setUser(source.getCatalog().getUsername());
fileDesc.setPassword(source.getCatalog().getPassword());
// set TTableFormatFileDesc
TTableFormatFileDesc tableFormatFileDesc = new TTableFormatFileDesc();
tableFormatFileDesc.setRemoteDorisParams(fileDesc);
tableFormatFileDesc.setTableFormatType(((RemoteDorisSplit) split).getTableFormatType().value());
// set TFileRangeDesc
rangeDesc.setTableFormatParams(tableFormatFileDesc);
}
}
@Override
public String getNodeExplainString(String prefix, TExplainLevel detailLevel) {
StringBuilder output = new StringBuilder();
output.append(prefix).append("TABLE: ").append(source.getTargetTable().getExternalTableName()).append("\n");
if (detailLevel == TExplainLevel.BRIEF) {
return output.toString();
}
output.append(prefix).append("QUERY: ").append(getQueryStr()).append("\n");
if (!conjuncts.isEmpty()) {
Expr expr = convertConjunctsToAndCompoundPredicate(conjuncts);
output.append(prefix).append("PREDICATES: ").append(expr.toSql()).append("\n");
}
return output.toString();
}
@Override
protected TFileFormatType getFileFormatType() throws UserException {
return TFileFormatType.FORMAT_ARROW;
}
@Override
protected List<String> getPathPartitionKeys() throws UserException {
return new ArrayList<>();
}
@Override
protected TableIf getTargetTable() throws UserException {
return desc.getTable();
}
@Override
protected Map<String, String> getLocationProperties() throws UserException {
return source.getCatalog().getProperties();
}
// Executes a SQL query using the Apache Arrow Flight SQL protocol with the provided credentials.
private List<Pair<String, ByteBuffer>> executeQuery() {
createColumns();
createFilters();
if (isExplainStatement()) {
return new ArrayList<>();
}
String queryStr = getQueryStr();
Exception lastException = null;
for (int i = 0; i < source.getCatalog().getQueryRetryCount(); i++) {
try {
return executeFlightSqlQuery(
source.nextHostAndArrowPort(),
source.getCatalog().getUsername(),
source.getCatalog().getPassword(),
queryStr
);
} catch (Exception e) {
LOG.warn("arrow request node [{}] failures {}, try next nodes",
source.getHostAndArrowPort().toString(), e);
lastException = new RuntimeException(e.getMessage());
}
}
throw new RuntimeException("Failed to execute query: " + queryStr, lastException);
}
private List<Pair<String, ByteBuffer>> executeFlightSqlQuery(Pair<String, Integer> hostAndPort,
String user, String psw, String sql) throws Exception {
try (
BufferAllocator allocatorFE = new RootAllocator();
FlightClient clientFE = createFlightClient(allocatorFE, hostAndPort);
FlightSqlClient sqlClientFE = new FlightSqlClient(clientFE)
) {
CredentialCallOption credentialCallOption = authenticate(clientFE, user, psw);
FlightInfo info = executeSqlWithTimeout(sqlClientFE, sql, credentialCallOption);
return processFlightEndpoints(info.getEndpoints());
}
}
private void createColumns() {
columns.clear();
for (SlotDescriptor slot : desc.getSlots()) {
Column col = slot.getColumn();
columns.add("`" + col.getName() + "`");
}
if (columns.isEmpty()) {
columns.add("*");
}
}
private String getQueryStr() {
StringBuilder sql = new StringBuilder("SELECT ");
if (source.getCatalog().enableParallelResultSink()) {
sql.append("/*+ SET_VAR(enable_parallel_result_sink=true) */ ");
} else {
sql.append("/*+ SET_VAR(enable_parallel_result_sink=false) */ ");
}
sql.append(Joiner.on(", ").join(columns));
sql.append(" FROM ").append(source.getTargetTable().getExternalTableName());
if (!filters.isEmpty()) {
sql.append(" WHERE (");
sql.append(Joiner.on(") AND (").join(filters));
sql.append(")");
}
if (limit != -1) {
sql.append(" LIMIT ").append(limit);
}
return sql.toString();
}
private void createFilters() {
if (conjuncts.isEmpty()) {
return;
}
List<SlotRef> slotRefs = Lists.newArrayList();
Expr.collectList(conjuncts, SlotRef.class, slotRefs);
ExprSubstitutionMap sMap = new ExprSubstitutionMap();
for (SlotRef slotRef : slotRefs) {
SlotRef slotRef1 = (SlotRef) slotRef.clone();
slotRef1.setTableNameInfoToNull();
slotRef1.setLabel("`" + slotRef1.getColumnName() + "`");
sMap.put(slotRef, slotRef1);
}
ArrayList<Expr> conjunctsList = Expr.cloneList(conjuncts, sMap);
for (Expr expr : conjunctsList) {
String filter = conjunctExprToString(expr, desc.getTable());
filters.add(filter);
}
}
private String conjunctExprToString(Expr expr, TableIf tbl) {
if (expr.contains(DateLiteral.class) && expr instanceof BinaryPredicate) {
ArrayList<Expr> children = expr.getChildren();
String filter = children.get(0).toExternalSql(TableIf.TableType.DORIS_EXTERNAL_TABLE, tbl);
filter += " " + ((BinaryPredicate) expr).getOp().toString() + " ";
filter += children.get(1).toExternalSql(TableIf.TableType.DORIS_EXTERNAL_TABLE, tbl);
return filter;
}
// Only for old planner
if (expr.contains(BoolLiteral.class) && BOOLEAN_TRUE_REPRESENTATION.equals(expr.getStringValue())
&& expr.getChildren().isEmpty()) {
return "1 = 1";
}
return expr.toExternalSql(TableIf.TableType.DORIS_EXTERNAL_TABLE, tbl);
}
// TODO: Use AST parsing instead of string matching for EXPLAIN detection
private boolean isExplainStatement() {
return ConnectContext.get().getStatementContext().getOriginStatement().originStmt
.trim().toLowerCase().startsWith("explain");
}
private FlightClient createFlightClient(BufferAllocator allocator,
Pair<String, Integer> hostAndPort) throws Exception {
URI uri = new URI("grpc", null, hostAndPort.first, hostAndPort.second, null, null, null);
return FlightClient.builder(allocator, new Location(uri)).build();
}
private CredentialCallOption authenticate(FlightClient client, String user, String psw) throws UserException {
Optional<CredentialCallOption> credentialCallOption = client.authenticateBasicToken(user, psw);
if (!credentialCallOption.isPresent()) {
throw new UserException("Authenticates with a username and password failure");
}
return credentialCallOption.get();
}
private FlightInfo executeSqlWithTimeout(FlightSqlClient sqlClient, String sql,
CredentialCallOption credentialCallOption) {
int timeoutSec = source.getCatalog().getQueryTimeoutSec();
return sqlClient.execute(sql, credentialCallOption,
CallOptions.timeout(timeoutSec, TimeUnit.SECONDS));
}
private List<Pair<String, ByteBuffer>> processFlightEndpoints(List<FlightEndpoint> endpoints) {
List<Pair<String, ByteBuffer>> uniquePairs = new ArrayList<>();
Set<String> seenPairs = new HashSet<>();
for (FlightEndpoint endpoint : endpoints) {
ByteBuffer ticket = endpoint.getTicket().serialize();
for (Location location : endpoint.getLocations()) {
String uri = location.getUri().toString();
String compositeKey = ticket.hashCode() + uri;
if (seenPairs.add(compositeKey)) {
uniquePairs.add(Pair.of(uri, ticket));
}
}
}
return uniquePairs;
}
}