TestingPrestoClient.java
/*
* 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 com.facebook.presto.tests;
import com.facebook.presto.Session;
import com.facebook.presto.client.IntervalDayTime;
import com.facebook.presto.client.IntervalYearMonth;
import com.facebook.presto.client.QueryData;
import com.facebook.presto.client.QueryStatusInfo;
import com.facebook.presto.common.type.ArrayType;
import com.facebook.presto.common.type.BigintEnumType;
import com.facebook.presto.common.type.DecimalType;
import com.facebook.presto.common.type.DistinctType;
import com.facebook.presto.common.type.JsonType;
import com.facebook.presto.common.type.MapType;
import com.facebook.presto.common.type.RowType;
import com.facebook.presto.common.type.SqlTimestamp;
import com.facebook.presto.common.type.SqlTimestampWithTimeZone;
import com.facebook.presto.common.type.Type;
import com.facebook.presto.common.type.TypeWithName;
import com.facebook.presto.common.type.UuidType;
import com.facebook.presto.common.type.VarcharEnumType;
import com.facebook.presto.common.type.VarcharType;
import com.facebook.presto.geospatial.type.GeometryType;
import com.facebook.presto.server.testing.TestingPrestoServer;
import com.facebook.presto.spi.PrestoWarning;
import com.facebook.presto.spi.analyzer.UpdateInfo;
import com.facebook.presto.testing.MaterializedResult;
import com.facebook.presto.testing.MaterializedRow;
import com.facebook.presto.type.SqlIntervalDayTime;
import com.facebook.presto.type.SqlIntervalYearMonth;
import com.google.common.base.Function;
import com.google.common.collect.ImmutableList;
import java.math.BigDecimal;
import java.time.LocalDate;
import java.time.LocalDateTime;
import java.time.LocalTime;
import java.time.OffsetTime;
import java.time.ZoneOffset;
import java.time.ZonedDateTime;
import java.time.format.DateTimeFormatter;
import java.time.format.DateTimeParseException;
import java.util.ArrayList;
import java.util.LinkedHashMap;
import java.util.List;
import java.util.Map;
import java.util.Optional;
import java.util.OptionalLong;
import java.util.Set;
import java.util.concurrent.atomic.AtomicReference;
import java.util.stream.Collectors;
import static com.facebook.presto.common.type.BigintType.BIGINT;
import static com.facebook.presto.common.type.BooleanType.BOOLEAN;
import static com.facebook.presto.common.type.Chars.isCharType;
import static com.facebook.presto.common.type.DateType.DATE;
import static com.facebook.presto.common.type.DoubleType.DOUBLE;
import static com.facebook.presto.common.type.IntegerType.INTEGER;
import static com.facebook.presto.common.type.JsonType.JSON;
import static com.facebook.presto.common.type.RealType.REAL;
import static com.facebook.presto.common.type.SmallintType.SMALLINT;
import static com.facebook.presto.common.type.TimeType.TIME;
import static com.facebook.presto.common.type.TimeWithTimeZoneType.TIME_WITH_TIME_ZONE;
import static com.facebook.presto.common.type.TimestampType.TIMESTAMP;
import static com.facebook.presto.common.type.TimestampWithTimeZoneType.TIMESTAMP_WITH_TIME_ZONE;
import static com.facebook.presto.common.type.TinyintType.TINYINT;
import static com.facebook.presto.common.type.VarbinaryType.VARBINARY;
import static com.facebook.presto.testing.MaterializedResult.DEFAULT_PRECISION;
import static com.facebook.presto.type.IntervalDayTimeType.INTERVAL_DAY_TIME;
import static com.facebook.presto.type.IntervalYearMonthType.INTERVAL_YEAR_MONTH;
import static com.facebook.presto.type.IpAddressType.IPADDRESS;
import static com.google.common.base.Preconditions.checkArgument;
import static com.google.common.base.Preconditions.checkState;
import static com.google.common.collect.Iterables.transform;
import static java.util.stream.Collectors.toList;
public class TestingPrestoClient
extends AbstractTestingPrestoClient<MaterializedResult>
{
private static final DateTimeFormatter timeWithUtcZoneFormat = DateTimeFormatter.ofPattern("HH:mm:ss.SSS 'UTC'"); // UTC zone would be printed as "Z" in "XXX" format
private static final DateTimeFormatter timeWithZoneOffsetFormat = DateTimeFormatter.ofPattern("HH:mm:ss.SSS XXX");
private static final DateTimeFormatter timestampWithTimeZoneFormat = DateTimeFormatter.ofPattern(SqlTimestampWithTimeZone.JSON_FORMAT);
public TestingPrestoClient(TestingPrestoServer prestoServer, Session defaultSession)
{
super(prestoServer, defaultSession);
}
@Override
protected ResultsSession<MaterializedResult> getResultSession(Session session)
{
return new MaterializedResultSession();
}
private class MaterializedResultSession
implements ResultsSession<MaterializedResult>
{
private final ImmutableList.Builder<MaterializedRow> rows = ImmutableList.builder();
private final AtomicReference<List<Type>> types = new AtomicReference<>();
private final AtomicReference<Optional<UpdateInfo>> updateInfo = new AtomicReference<>(Optional.empty());
private final AtomicReference<OptionalLong> updateCount = new AtomicReference<>(OptionalLong.empty());
private final AtomicReference<List<PrestoWarning>> warnings = new AtomicReference<>(ImmutableList.of());
@Override
public void setUpdateInfo(UpdateInfo type)
{
updateInfo.set(Optional.of(type));
}
@Override
public void setUpdateCount(long count)
{
updateCount.set(OptionalLong.of(count));
}
@Override
public void setWarnings(List<PrestoWarning> warnings)
{
this.warnings.set(warnings);
}
@Override
public void addResults(QueryStatusInfo statusInfo, QueryData data)
{
if (types.get() == null && statusInfo.getColumns() != null) {
types.set(getTypes(statusInfo.getColumns()));
}
if (data.getData() != null) {
checkState(types.get() != null, "data received without types");
rows.addAll(transform(data.getData(), dataToRow(types.get())));
}
}
@Override
public MaterializedResult build(Map<String, String> setSessionProperties, Set<String> resetSessionProperties)
{
checkState(types.get() != null, "never received types for the query");
return new MaterializedResult(
rows.build(),
types.get(),
setSessionProperties,
resetSessionProperties,
updateInfo.get(),
updateCount.get(),
warnings.get());
}
}
private static Function<List<Object>, MaterializedRow> dataToRow(final List<Type> types)
{
return data -> {
checkArgument(data.size() == types.size(), "columns size does not match types size");
List<Object> row = new ArrayList<>();
for (int i = 0; i < data.size(); i++) {
Object value = data.get(i);
Type type = types.get(i);
row.add(convertToRowValue(type, value));
}
return new MaterializedRow(DEFAULT_PRECISION, row);
};
}
private static Object convertToRowValue(Type type, Object value)
{
if (value == null) {
return null;
}
if (BOOLEAN.equals(type)) {
return value;
}
else if (TINYINT.equals(type)) {
return ((Number) value).byteValue();
}
else if (SMALLINT.equals(type)) {
return ((Number) value).shortValue();
}
else if (INTEGER.equals(type)) {
return ((Number) value).intValue();
}
else if (BIGINT.equals(type)) {
return ((Number) value).longValue();
}
else if (DOUBLE.equals(type)) {
return ((Number) value).doubleValue();
}
else if (REAL.equals(type)) {
return ((Number) value).floatValue();
}
else if (type instanceof VarcharType) {
return value;
}
else if (isCharType(type)) {
return value;
}
else if (VARBINARY.equals(type)) {
return value;
}
else if (DATE.equals(type)) {
return DateTimeFormatter.ISO_LOCAL_DATE.parse(((String) value), LocalDate::from);
}
else if (TIME.equals(type)) {
return DateTimeFormatter.ISO_LOCAL_TIME.parse(((String) value), LocalTime::from);
}
else if (TIME_WITH_TIME_ZONE.equals(type)) {
// Only zone-offset timezones are supported (TODO remove political timezones support for TIME WITH TIME ZONE)
try {
return timeWithUtcZoneFormat.parse(((String) value), LocalTime::from).atOffset(ZoneOffset.UTC);
}
catch (DateTimeParseException e) {
return timeWithZoneOffsetFormat.parse(((String) value), OffsetTime::from);
}
}
else if (TIMESTAMP.equals(type)) {
return SqlTimestamp.JSON_MILLIS_FORMATTER.parse((String) value, LocalDateTime::from);
}
else if (TIMESTAMP_WITH_TIME_ZONE.equals(type)) {
return timestampWithTimeZoneFormat.parse((String) value, ZonedDateTime::from);
}
else if (INTERVAL_DAY_TIME.equals(type)) {
return new SqlIntervalDayTime(IntervalDayTime.parseMillis(String.valueOf(value)));
}
else if (INTERVAL_YEAR_MONTH.equals(type)) {
return new SqlIntervalYearMonth(IntervalYearMonth.parseMonths(String.valueOf(value)));
}
else if (IPADDRESS.equals(type)) {
return value;
}
else if (type instanceof ArrayType) {
return ((List<Object>) value).stream()
.map(element -> convertToRowValue(((ArrayType) type).getElementType(), element))
.collect(toList());
}
else if (type instanceof MapType) {
return ((Map<Object, Object>) value).entrySet().stream()
.collect(Collectors.toMap(
e -> convertToRowValue(((MapType) type).getKeyType(), e.getKey()),
e -> convertToRowValue(((MapType) type).getValueType(), e.getValue())));
}
else if (type instanceof RowType) {
if (value instanceof LinkedHashMap) {
// If value is an ordered map, use indexes instead of names.
List<Object> data = new ArrayList<>(((Map<String, Object>) value).values());
List<RowType.Field> fields = ((RowType) type).getFields();
List<Object> rowValues = new ArrayList<>();
for (int i = 0; i < fields.size(); i++) {
rowValues.add(convertToRowValue(fields.get(i).getType(), data.get(i)));
}
return rowValues;
}
Map<String, Object> data = (Map<String, Object>) value;
RowType rowType = (RowType) type;
return rowType.getFields().stream()
.map(field -> convertToRowValue(field.getType(), data.get(field.getName().get())))
.collect(toList());
}
else if (type instanceof DecimalType) {
return new BigDecimal((String) value);
}
else if (type instanceof JsonType) {
return value;
}
else if (type instanceof UuidType) {
return value;
}
else if (type instanceof VarcharEnumType) {
return value;
}
else if (type instanceof BigintEnumType) {
return ((Number) value).longValue();
}
else if (type instanceof DistinctType) {
return convertToRowValue(((DistinctType) type).getBaseType(), value);
}
else if (type instanceof TypeWithName) {
return convertToRowValue(((TypeWithName) type).getType(), value);
}
else if (type.getTypeSignature().getBase().equals("ObjectId")) {
return value;
}
else if (JSON.equals(type)) {
return value;
}
else if (type instanceof GeometryType) {
return value;
}
else {
throw new AssertionError("unhandled type: " + type);
}
}
}