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.operator.TopNRankingOperator 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.operator;
import com.google.common.annotations.VisibleForTesting;
import com.google.common.base.Supplier;
import com.google.common.base.Suppliers;
import com.google.common.collect.ImmutableList;
import com.google.common.primitives.Ints;
import io.airlift.units.DataSize;
import io.trino.Session;
import io.trino.memory.context.LocalMemoryContext;
import io.trino.spi.Page;
import io.trino.spi.connector.SortOrder;
import io.trino.spi.type.Type;
import io.trino.spi.type.TypeOperators;
import io.trino.sql.gen.JoinCompiler;
import io.trino.sql.planner.plan.PlanNodeId;
import io.trino.sql.planner.plan.TopNRankingNode.RankingType;
import io.trino.type.BlockTypeOperators;
import java.util.Iterator;
import java.util.List;
import java.util.Optional;
import static com.google.common.base.Preconditions.checkArgument;
import static com.google.common.base.Preconditions.checkState;
import static io.trino.operator.GroupByHash.createGroupByHash;
import static java.util.Objects.requireNonNull;
public class TopNRankingOperator
implements Operator
{
public static class TopNRankingOperatorFactory
implements OperatorFactory
{
private final int operatorId;
private final PlanNodeId planNodeId;
private final RankingType rankingType;
private final List sourceTypes;
private final List outputChannels;
private final List partitionChannels;
private final List partitionTypes;
private final List sortChannels;
private final List sortOrder;
private final int maxRowCountPerPartition;
private final boolean partial;
private final Optional hashChannel;
private final int expectedPositions;
private final boolean generateRanking;
private boolean closed;
private final JoinCompiler joinCompiler;
private final TypeOperators typeOperators;
private final BlockTypeOperators blockTypeOperators;
private final Optional maxPartialMemory;
public TopNRankingOperatorFactory(
int operatorId,
PlanNodeId planNodeId,
RankingType rankingType,
List extends Type> sourceTypes,
List outputChannels,
List partitionChannels,
List extends Type> partitionTypes,
List sortChannels,
List sortOrder,
int maxRowCountPerPartition,
boolean partial,
Optional hashChannel,
int expectedPositions,
Optional maxPartialMemory,
JoinCompiler joinCompiler,
TypeOperators typeOperators,
BlockTypeOperators blockTypeOperators)
{
this.operatorId = operatorId;
this.planNodeId = requireNonNull(planNodeId, "planNodeId is null");
this.rankingType = requireNonNull(rankingType, "rankingType is null");
this.sourceTypes = ImmutableList.copyOf(sourceTypes);
this.outputChannels = ImmutableList.copyOf(requireNonNull(outputChannels, "outputChannels is null"));
this.partitionChannels = ImmutableList.copyOf(requireNonNull(partitionChannels, "partitionChannels is null"));
this.partitionTypes = ImmutableList.copyOf(requireNonNull(partitionTypes, "partitionTypes is null"));
this.sortChannels = ImmutableList.copyOf(requireNonNull(sortChannels));
this.sortOrder = ImmutableList.copyOf(requireNonNull(sortOrder));
this.hashChannel = requireNonNull(hashChannel, "hashChannel is null");
this.partial = partial;
checkArgument(maxRowCountPerPartition > 0, "maxRowCountPerPartition must be > 0");
this.maxRowCountPerPartition = maxRowCountPerPartition;
checkArgument(expectedPositions > 0, "expectedPositions must be > 0");
this.generateRanking = !partial;
this.expectedPositions = expectedPositions;
this.joinCompiler = requireNonNull(joinCompiler, "joinCompiler is null");
this.typeOperators = requireNonNull(typeOperators, "typeOperators is null");
this.blockTypeOperators = requireNonNull(blockTypeOperators, "blockTypeOperators is null");
this.maxPartialMemory = requireNonNull(maxPartialMemory, "maxPartialMemory is null");
}
@Override
public Operator createOperator(DriverContext driverContext)
{
checkState(!closed, "Factory is already closed");
OperatorContext operatorContext = driverContext.addOperatorContext(operatorId, planNodeId, TopNRankingOperator.class.getSimpleName());
return new TopNRankingOperator(
operatorContext,
rankingType,
sourceTypes,
outputChannels,
partitionChannels,
partitionTypes,
sortChannels,
sortOrder,
maxRowCountPerPartition,
generateRanking,
hashChannel,
expectedPositions,
maxPartialMemory,
joinCompiler,
typeOperators,
blockTypeOperators);
}
@Override
public void noMoreOperators()
{
closed = true;
}
@Override
public OperatorFactory duplicate()
{
return new TopNRankingOperatorFactory(
operatorId,
planNodeId,
rankingType,
sourceTypes,
outputChannels,
partitionChannels,
partitionTypes,
sortChannels,
sortOrder,
maxRowCountPerPartition,
partial,
hashChannel,
expectedPositions,
maxPartialMemory,
joinCompiler,
typeOperators,
blockTypeOperators);
}
}
private final OperatorContext operatorContext;
private final LocalMemoryContext localMemoryContext;
private final int[] outputChannels;
private final Supplier groupedTopNBuilderSupplier;
private final boolean partial;
private final long maxFlushableBytes;
private GroupedTopNBuilder groupedTopNBuilder;
private boolean finishing;
private Work> unfinishedWork;
private Iterator outputIterator;
public TopNRankingOperator(
OperatorContext operatorContext,
RankingType rankingType,
List extends Type> sourceTypes,
List outputChannels,
List partitionChannels,
List partitionTypes,
List sortChannels,
List sortOrders,
int maxRankingPerPartition,
boolean generateRanking,
Optional hashChannel,
int expectedPositions,
Optional maxPartialMemory,
JoinCompiler joinCompiler,
TypeOperators typeOperators,
BlockTypeOperators blockTypeOperators)
{
requireNonNull(maxPartialMemory, "maxPartialMemory is null");
this.operatorContext = requireNonNull(operatorContext, "operatorContext is null");
this.localMemoryContext = operatorContext.localUserMemoryContext();
ImmutableList.Builder outputChannelsBuilder = ImmutableList.builder();
for (int channel : requireNonNull(outputChannels, "outputChannels is null")) {
outputChannelsBuilder.add(channel);
}
if (generateRanking) {
outputChannelsBuilder.add(outputChannels.size());
}
this.outputChannels = Ints.toArray(outputChannelsBuilder.build());
this.partial = !generateRanking;
checkArgument(maxRankingPerPartition > 0, "maxRankingPerPartition must be > 0");
checkArgument(maxPartialMemory.isEmpty() || !generateRanking, "no partial memory on final TopN");
this.maxFlushableBytes = maxPartialMemory.map(DataSize::toBytes).orElse(Long.MAX_VALUE);
int[] groupByChannels;
if (hashChannel.isPresent()) {
groupByChannels = new int[partitionChannels.size() + 1];
for (int i = 0; i < partitionChannels.size(); i++) {
groupByChannels[i] = partitionChannels.get(i);
}
groupByChannels[partitionChannels.size()] = hashChannel.get();
}
else {
groupByChannels = Ints.toArray(partitionChannels);
}
this.groupedTopNBuilderSupplier = getGroupedTopNBuilderSupplier(
rankingType,
ImmutableList.copyOf(sourceTypes),
sortChannels,
sortOrders,
maxRankingPerPartition,
generateRanking,
typeOperators,
blockTypeOperators,
groupByChannels,
getGroupByHashSupplier(
expectedPositions,
partitionTypes,
hashChannel.isPresent(),
operatorContext.getSession(),
joinCompiler,
this::updateMemoryReservation));
}
private static Supplier getGroupByHashSupplier(
int expectedPositions,
List partitionTypes,
boolean hasPrecomputedHash,
Session session,
JoinCompiler joinCompiler,
UpdateMemory updateMemory)
{
if (partitionTypes.isEmpty()) {
return Suppliers.ofInstance(new NoChannelGroupByHash());
}
checkArgument(expectedPositions > 0, "expectedPositions must be > 0");
return () -> createGroupByHash(
session,
partitionTypes,
hasPrecomputedHash,
expectedPositions,
joinCompiler,
updateMemory);
}
private static Supplier getGroupedTopNBuilderSupplier(
RankingType rankingType,
List sourceTypes,
List sortChannels,
List sortOrders,
int maxRankingPerPartition,
boolean generateRanking,
TypeOperators typeOperators,
BlockTypeOperators blockTypeOperators,
int[] groupByChannels,
Supplier groupByHashSupplier)
{
if (rankingType == RankingType.ROW_NUMBER) {
PageWithPositionComparator comparator = new SimplePageWithPositionComparator(sourceTypes, sortChannels, sortOrders, typeOperators);
return () -> new GroupedTopNRowNumberBuilder(
sourceTypes,
comparator,
maxRankingPerPartition,
generateRanking,
groupByChannels,
groupByHashSupplier.get());
}
if (rankingType == RankingType.RANK) {
PageWithPositionComparator comparator = new SimplePageWithPositionComparator(sourceTypes, sortChannels, sortOrders, typeOperators);
PageWithPositionEqualsAndHash equalsAndHash = new SimplePageWithPositionEqualsAndHash(ImmutableList.copyOf(sourceTypes), sortChannels, blockTypeOperators);
return () -> new GroupedTopNRankBuilder(
sourceTypes,
comparator,
equalsAndHash,
maxRankingPerPartition,
generateRanking,
groupByChannels,
groupByHashSupplier.get());
}
if (rankingType == RankingType.DENSE_RANK) {
throw new UnsupportedOperationException();
}
throw new AssertionError("Unknown ranking type: " + rankingType);
}
@Override
public OperatorContext getOperatorContext()
{
return operatorContext;
}
@Override
public void finish()
{
finishing = true;
}
@Override
public boolean isFinished()
{
// has no more input, has finished flushing, and has no unfinished work
return finishing && outputIterator == null && groupedTopNBuilder == null && unfinishedWork == null;
}
@Override
public boolean needsInput()
{
// still has more input, has not started flushing yet, and has no unfinished work
return !finishing && outputIterator == null && !isBuilderFull() && unfinishedWork == null;
}
@Override
public void addInput(Page page)
{
checkState(!finishing, "Operator is already finishing");
checkState(unfinishedWork == null, "Cannot add input with the operator when unfinished work is not empty");
checkState(outputIterator == null, "Cannot add input with the operator when flushing");
requireNonNull(page, "page is null");
checkState(!isBuilderFull(), "TopN buffer is already full");
if (groupedTopNBuilder == null) {
groupedTopNBuilder = groupedTopNBuilderSupplier.get();
}
unfinishedWork = groupedTopNBuilder.processPage(page);
if (unfinishedWork.process()) {
unfinishedWork = null;
}
updateMemoryReservation();
}
@Override
public Page getOutput()
{
if (unfinishedWork != null) {
boolean finished = unfinishedWork.process();
updateMemoryReservation();
if (!finished) {
return null;
}
unfinishedWork = null;
}
if (!finishing && (!partial || !isBuilderFull()) && outputIterator == null) {
return null;
}
if (outputIterator == null && groupedTopNBuilder != null) {
// start flushing
outputIterator = groupedTopNBuilder.buildResult();
}
Page output;
if (outputIterator != null && outputIterator.hasNext()) {
// rewrite to expected column ordering
output = outputIterator.next().getColumns(outputChannels);
}
else {
closeGroupedTopNBuilder();
return null;
}
updateMemoryReservation();
return output;
}
@Override
public void close()
{
closeGroupedTopNBuilder();
}
private void closeGroupedTopNBuilder()
{
outputIterator = null;
groupedTopNBuilder = null;
localMemoryContext.setBytes(0);
}
private boolean updateMemoryReservation()
{
if (groupedTopNBuilder == null) {
localMemoryContext.setBytes(0);
return true;
}
// TODO: may need to use trySetMemoryReservation with a compaction to free memory (but that may cause GC pressure)
localMemoryContext.setBytes(groupedTopNBuilder.getEstimatedSizeInBytes());
if (partial) {
// do not yield on memory for partial aggregations
return true;
}
return operatorContext.isWaitingForMemory().isDone();
}
private boolean isBuilderFull()
{
return groupedTopNBuilder != null && groupedTopNBuilder.getEstimatedSizeInBytes() >= maxFlushableBytes;
}
@VisibleForTesting
GroupedTopNBuilder getGroupedTopNBuilder()
{
return groupedTopNBuilder;
}
}