Please wait. This can take some minutes ...
Many resources are needed to download a project. Please understand that we have to compensate our server costs. Thank you in advance.
Project price only 1 $
You can buy this project and download/modify it how often you want.
io.trino.server.protocol.QueryResultRows Maven / Gradle / Ivy
/*
* Licensed 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 io.trino.server.protocol;
import com.google.common.annotations.VisibleForTesting;
import com.google.common.collect.AbstractIterator;
import com.google.common.collect.ImmutableList;
import com.google.common.collect.Maps;
import io.trino.Session;
import io.trino.client.ClientCapabilities;
import io.trino.client.Column;
import io.trino.spi.Page;
import io.trino.spi.TrinoException;
import io.trino.spi.block.Block;
import io.trino.spi.block.BlockBuilder;
import io.trino.spi.connector.ConnectorSession;
import io.trino.spi.type.ArrayType;
import io.trino.spi.type.MapType;
import io.trino.spi.type.RowType;
import io.trino.spi.type.SqlTime;
import io.trino.spi.type.SqlTimeWithTimeZone;
import io.trino.spi.type.SqlTimestamp;
import io.trino.spi.type.SqlTimestampWithTimeZone;
import io.trino.spi.type.TimeType;
import io.trino.spi.type.TimeWithTimeZoneType;
import io.trino.spi.type.TimestampType;
import io.trino.spi.type.TimestampWithTimeZoneType;
import io.trino.spi.type.Type;
import jakarta.annotation.Nullable;
import java.util.ArrayDeque;
import java.util.ArrayList;
import java.util.Arrays;
import java.util.Deque;
import java.util.Iterator;
import java.util.List;
import java.util.Map;
import java.util.Optional;
import java.util.function.Consumer;
import static com.google.common.base.MoreObjects.toStringHelper;
import static com.google.common.base.Preconditions.checkArgument;
import static com.google.common.base.Preconditions.checkState;
import static com.google.common.base.Verify.verify;
import static com.google.common.collect.ImmutableList.toImmutableList;
import static io.trino.spi.StandardErrorCode.SERIALIZATION_ERROR;
import static io.trino.spi.type.BigintType.BIGINT;
import static io.trino.spi.type.BooleanType.BOOLEAN;
import static java.lang.String.format;
import static java.util.Collections.unmodifiableList;
import static java.util.Collections.unmodifiableMap;
import static java.util.Objects.requireNonNull;
public class QueryResultRows
implements Iterable>
{
private final ConnectorSession session;
private final Optional> columns;
private final List pages;
private final Optional> exceptionConsumer;
private final long totalRows;
private final boolean supportsParametricDateTime;
private QueryResultRows(Session session, Optional> columns, List pages, Consumer exceptionConsumer)
{
this.session = session.toConnectorSession();
this.columns = requireNonNull(columns, "columns is null");
this.pages = ImmutableList.copyOf(pages);
this.exceptionConsumer = Optional.ofNullable(exceptionConsumer);
this.totalRows = countRows(pages);
this.supportsParametricDateTime = session.getClientCapabilities().contains(ClientCapabilities.PARAMETRIC_DATETIME.toString());
verify(totalRows == 0 || (totalRows > 0 && columns.isPresent()), "data present without columns and types");
}
public boolean isEmpty()
{
return totalRows == 0;
}
public Optional> getColumns()
{
return columns.map(columns -> columns.stream()
.map(ColumnAndType::getColumn)
.collect(toImmutableList()));
}
/**
* Returns expected row count (we don't know yet if every row is serializable).
*/
@VisibleForTesting
public long getTotalRowsCount()
{
return totalRows;
}
public Optional getUpdateCount()
{
// We should have exactly single bigint value as an update count.
if (totalRows != 1 || columns.isEmpty()) {
return Optional.empty();
}
List columns = this.columns.get();
if (columns.size() != 1 || !columns.get(0).getType().equals(BIGINT)) {
return Optional.empty();
}
checkState(!pages.isEmpty(), "no data pages available");
Number value = (Number) columns.get(0).getType().getObjectValue(session, pages.get(0).getBlock(0), 0);
return Optional.ofNullable(value).map(Number::longValue);
}
@Override
public Iterator> iterator()
{
return new ResultsIterator(this);
}
private static long countRows(List pages)
{
long rows = 0;
for (Page page : pages) {
rows += page.getPositionCount();
}
return rows;
}
@Override
public String toString()
{
return toStringHelper(this)
.add("columns", columns)
.add("totalRowsCount", getTotalRowsCount())
.add("pagesCount", this.pages.size())
.toString();
}
public static QueryResultRows empty(Session session)
{
return new QueryResultRows(session, Optional.empty(), ImmutableList.of(), null);
}
public static Builder queryResultRowsBuilder(Session session)
{
return new Builder(session);
}
public static class Builder
{
private final Session session;
private ImmutableList.Builder pages = ImmutableList.builder();
private Optional> columns = Optional.empty();
private Consumer exceptionConsumer;
public Builder(Session session)
{
this.session = requireNonNull(session, "session is null");
}
public Builder addPage(Page page)
{
pages.add(page);
return this;
}
public Builder addPages(List page)
{
pages.addAll(page);
return this;
}
public Builder withColumnsAndTypes(@Nullable List columns, @Nullable List types)
{
if (columns != null || types != null) {
this.columns = Optional.of(combine(columns, types));
}
return this;
}
public Builder withSingleBooleanValue(Column column, boolean value)
{
BlockBuilder blockBuilder = BOOLEAN.createBlockBuilder(null, 1);
BOOLEAN.writeBoolean(blockBuilder, value);
pages = ImmutableList.builder().add(new Page(blockBuilder.build()));
columns = Optional.of(combine(ImmutableList.of(column), ImmutableList.of(BOOLEAN)));
return this;
}
public Builder withExceptionConsumer(Consumer exceptionConsumer)
{
this.exceptionConsumer = exceptionConsumer;
return this;
}
public QueryResultRows build()
{
return new QueryResultRows(
session,
columns,
pages.build(),
exceptionConsumer);
}
private static List combine(@Nullable List columns, @Nullable List types)
{
checkArgument(columns != null && types != null, "columns and types must be present at the same time");
checkArgument(columns.size() == types.size(), "columns and types size mismatch");
ImmutableList.Builder builder = ImmutableList.builderWithExpectedSize(columns.size());
for (int i = 0; i < columns.size(); i++) {
builder.add(new ColumnAndType(i, columns.get(i), types.get(i)));
}
return builder.build();
}
}
private static class ColumnAndType
{
private final int position;
private final Column column;
private final Type type;
private ColumnAndType(int position, Column column, Type type)
{
this.position = position;
this.column = column;
this.type = type;
}
public Column getColumn()
{
return column;
}
public Type getType()
{
return type;
}
public int getPosition()
{
return position;
}
@Override
public String toString()
{
return toStringHelper(this)
.add("column", column)
.add("type", type)
.add("position", position)
.toString();
}
}
private static class ResultsIterator
extends AbstractIterator>
{
private final Deque queue;
private final QueryResultRows results;
private Page currentPage;
private int rowPosition = -1;
private int inPageIndex = -1;
public ResultsIterator(QueryResultRows results)
{
this.queue = new ArrayDeque<>(results.pages);
this.results = results;
this.currentPage = queue.pollFirst();
}
@Override
protected List computeNext()
{
while (true) {
if (currentPage == null) {
return endOfData();
}
inPageIndex++;
if (inPageIndex >= currentPage.getPositionCount()) {
currentPage = queue.pollFirst();
if (currentPage == null) {
return endOfData();
}
inPageIndex = 0;
}
rowPosition++;
List row = getRowValues();
if (row != null) {
// row is not skipped, return it
return row;
}
}
}
@Nullable
private List getRowValues()
{
// types are present if data is present
List columns = results.columns.orElseThrow();
Object[] row = new Object[currentPage.getChannelCount()];
for (int channel = 0; channel < currentPage.getChannelCount(); channel++) {
ColumnAndType column = columns.get(channel);
Type type = column.getType();
Block block = currentPage.getBlock(channel);
try {
Object value = type.getObjectValue(results.session, block, inPageIndex);
if (!results.supportsParametricDateTime) {
value = getLegacyValue(value, type);
}
row[channel] = value;
}
catch (Throwable throwable) {
propagateException(rowPosition, column, throwable);
// skip row as it contains non-serializable value
return null;
}
}
return unmodifiableList(Arrays.asList(row));
}
private Object getLegacyValue(Object value, Type type)
{
if (value == null) {
return null;
}
if (!results.supportsParametricDateTime) {
// for legacy clients we need to round timestamp and timestamp with timezone to default precision (3)
if (type instanceof TimestampType) {
return ((SqlTimestamp) value).roundTo(3);
}
if (type instanceof TimestampWithTimeZoneType) {
return ((SqlTimestampWithTimeZone) value).roundTo(3);
}
if (type instanceof TimeType) {
return ((SqlTime) value).roundTo(3);
}
if (type instanceof TimeWithTimeZoneType) {
return ((SqlTimeWithTimeZone) value).roundTo(3);
}
}
if (type instanceof ArrayType) {
Type elementType = ((ArrayType) type).getElementType();
if (!(elementType instanceof TimestampType || elementType instanceof TimestampWithTimeZoneType)) {
return value;
}
List listValue = (List) value;
List legacyValues = new ArrayList<>(listValue.size());
for (Object element : listValue) {
legacyValues.add(getLegacyValue(element, elementType));
}
return unmodifiableList(legacyValues);
}
if (type instanceof MapType) {
Type keyType = ((MapType) type).getKeyType();
Type valueType = ((MapType) type).getValueType();
Map mapValue = (Map) value;
Map result = Maps.newHashMapWithExpectedSize(mapValue.size());
mapValue.forEach((key, val) -> result.put(getLegacyValue(key, keyType), getLegacyValue(val, valueType)));
return unmodifiableMap(result);
}
if (type instanceof RowType) {
List fields = ((RowType) type).getFields();
List values = (List) value;
List result = new ArrayList<>(values.size());
for (int i = 0; i < values.size(); i++) {
result.add(getLegacyValue(values.get(i), fields.get(i).getType()));
}
return unmodifiableList(result);
}
return value;
}
private void propagateException(int row, ColumnAndType column, Throwable cause)
{
// columns and rows are 0-indexed
String message = format("Could not serialize column '%s' of type '%s' at position %d:%d",
column.getColumn().getName(),
column.getType(),
row + 1,
column.getPosition() + 1);
results.exceptionConsumer.ifPresent(consumer -> consumer.accept(new TrinoException(SERIALIZATION_ERROR, message, cause)));
}
}
}