Search in sources :

Example 1 with SCALED_WRITER_DISTRIBUTION

use of com.facebook.presto.sql.planner.SystemPartitioningHandle.SCALED_WRITER_DISTRIBUTION in project presto by prestodb.

the class SectionExecutionFactory method createStageScheduler.

private StageScheduler createStageScheduler(SplitSourceFactory splitSourceFactory, Session session, StreamingSubPlan plan, Function<PartitioningHandle, NodePartitionMap> partitioningCache, Optional<SqlStageExecution> parentStageExecution, StageId stageId, SqlStageExecution stageExecution, PartitioningHandle partitioningHandle, TableWriteInfo tableWriteInfo, Set<SqlStageExecution> childStageExecutions) {
    Map<PlanNodeId, SplitSource> splitSources = splitSourceFactory.createSplitSources(plan.getFragment(), session, tableWriteInfo);
    int maxTasksPerStage = getMaxTasksPerStage(session);
    if (partitioningHandle.equals(SOURCE_DISTRIBUTION)) {
        // nodes are selected dynamically based on the constraints of the splits and the system load
        Map.Entry<PlanNodeId, SplitSource> entry = getOnlyElement(splitSources.entrySet());
        PlanNodeId planNodeId = entry.getKey();
        SplitSource splitSource = entry.getValue();
        ConnectorId connectorId = splitSource.getConnectorId();
        if (isInternalSystemConnector(connectorId)) {
            connectorId = null;
        }
        NodeSelector nodeSelector = nodeScheduler.createNodeSelector(session, connectorId, maxTasksPerStage);
        SplitPlacementPolicy placementPolicy = new DynamicSplitPlacementPolicy(nodeSelector, stageExecution::getAllTasks);
        checkArgument(!plan.getFragment().getStageExecutionDescriptor().isStageGroupedExecution());
        return newSourcePartitionedSchedulerAsStageScheduler(stageExecution, planNodeId, splitSource, placementPolicy, splitBatchSize);
    } else if (partitioningHandle.equals(SCALED_WRITER_DISTRIBUTION)) {
        Supplier<Collection<TaskStatus>> sourceTasksProvider = () -> childStageExecutions.stream().map(SqlStageExecution::getAllTasks).flatMap(Collection::stream).map(RemoteTask::getTaskStatus).collect(toList());
        Supplier<Collection<TaskStatus>> writerTasksProvider = () -> stageExecution.getAllTasks().stream().map(RemoteTask::getTaskStatus).collect(toList());
        ScaledWriterScheduler scheduler = new ScaledWriterScheduler(stageExecution, sourceTasksProvider, writerTasksProvider, nodeScheduler.createNodeSelector(session, null), scheduledExecutor, getWriterMinSize(session), isOptimizedScaleWriterProducerBuffer(session));
        whenAllStages(childStageExecutions, StageExecutionState::isDone).addListener(scheduler::finish, directExecutor());
        return scheduler;
    } else {
        if (!splitSources.isEmpty()) {
            // contains local source
            List<PlanNodeId> schedulingOrder = plan.getFragment().getTableScanSchedulingOrder();
            ConnectorId connectorId = partitioningHandle.getConnectorId().orElseThrow(IllegalStateException::new);
            List<ConnectorPartitionHandle> connectorPartitionHandles;
            boolean groupedExecutionForStage = plan.getFragment().getStageExecutionDescriptor().isStageGroupedExecution();
            if (groupedExecutionForStage) {
                connectorPartitionHandles = nodePartitioningManager.listPartitionHandles(session, partitioningHandle);
                checkState(!ImmutableList.of(NOT_PARTITIONED).equals(connectorPartitionHandles));
            } else {
                connectorPartitionHandles = ImmutableList.of(NOT_PARTITIONED);
            }
            BucketNodeMap bucketNodeMap;
            List<InternalNode> stageNodeList;
            if (plan.getFragment().getRemoteSourceNodes().stream().allMatch(node -> node.getExchangeType() == REPLICATE)) {
                // no non-replicated remote source
                boolean dynamicLifespanSchedule = plan.getFragment().getStageExecutionDescriptor().isDynamicLifespanSchedule();
                bucketNodeMap = nodePartitioningManager.getBucketNodeMap(session, partitioningHandle, dynamicLifespanSchedule);
                // verify execution is consistent with planner's decision on dynamic lifespan schedule
                verify(bucketNodeMap.isDynamic() == dynamicLifespanSchedule);
                if (bucketNodeMap.hasInitialMap()) {
                    stageNodeList = bucketNodeMap.getBucketToNode().get().stream().distinct().collect(toImmutableList());
                } else {
                    stageNodeList = new ArrayList<>(nodeScheduler.createNodeSelector(session, connectorId).selectRandomNodes(maxTasksPerStage));
                }
            } else {
                // cannot use dynamic lifespan schedule
                verify(!plan.getFragment().getStageExecutionDescriptor().isDynamicLifespanSchedule());
                // remote source requires nodePartitionMap
                NodePartitionMap nodePartitionMap = partitioningCache.apply(plan.getFragment().getPartitioning());
                if (groupedExecutionForStage) {
                    checkState(connectorPartitionHandles.size() == nodePartitionMap.getBucketToPartition().length);
                }
                stageNodeList = nodePartitionMap.getPartitionToNode();
                bucketNodeMap = nodePartitionMap.asBucketNodeMap();
            }
            FixedSourcePartitionedScheduler fixedSourcePartitionedScheduler = new FixedSourcePartitionedScheduler(stageExecution, splitSources, plan.getFragment().getStageExecutionDescriptor(), schedulingOrder, stageNodeList, bucketNodeMap, splitBatchSize, getConcurrentLifespansPerNode(session), nodeScheduler.createNodeSelector(session, connectorId), connectorPartitionHandles);
            if (plan.getFragment().getStageExecutionDescriptor().isRecoverableGroupedExecution()) {
                stageExecution.registerStageTaskRecoveryCallback(taskId -> {
                    checkArgument(taskId.getStageExecutionId().getStageId().equals(stageId), "The task did not execute this stage");
                    checkArgument(parentStageExecution.isPresent(), "Parent stage execution must exist");
                    checkArgument(parentStageExecution.get().getAllTasks().size() == 1, "Parent stage should only have one task for recoverable grouped execution");
                    parentStageExecution.get().removeRemoteSourceIfSingleTaskStage(taskId);
                    fixedSourcePartitionedScheduler.recover(taskId);
                });
            }
            return fixedSourcePartitionedScheduler;
        } else {
            // all sources are remote
            NodePartitionMap nodePartitionMap = partitioningCache.apply(plan.getFragment().getPartitioning());
            List<InternalNode> partitionToNode = nodePartitionMap.getPartitionToNode();
            // todo this should asynchronously wait a standard timeout period before failing
            checkCondition(!partitionToNode.isEmpty(), NO_NODES_AVAILABLE, "No worker nodes available");
            return new FixedCountScheduler(stageExecution, partitionToNode);
        }
    }
}
Also used : NodeTaskMap(com.facebook.presto.execution.NodeTaskMap) TaskStatus(com.facebook.presto.execution.TaskStatus) ForScheduler(com.facebook.presto.operator.ForScheduler) RemoteSourceNode(com.facebook.presto.sql.planner.plan.RemoteSourceNode) REPLICATE(com.facebook.presto.sql.planner.plan.ExchangeNode.Type.REPLICATE) SplitSourceFactory(com.facebook.presto.sql.planner.SplitSourceFactory) SettableFuture(com.google.common.util.concurrent.SettableFuture) SqlStageExecution(com.facebook.presto.execution.SqlStageExecution) NOT_PARTITIONED(com.facebook.presto.spi.connector.NotPartitionedPartitionHandle.NOT_PARTITIONED) SqlStageExecution.createSqlStageExecution(com.facebook.presto.execution.SqlStageExecution.createSqlStageExecution) Preconditions.checkArgument(com.google.common.base.Preconditions.checkArgument) Map(java.util.Map) SystemSessionProperties.getConcurrentLifespansPerNode(com.facebook.presto.SystemSessionProperties.getConcurrentLifespansPerNode) SystemSessionProperties.isOptimizedScaleWriterProducerBuffer(com.facebook.presto.SystemSessionProperties.isOptimizedScaleWriterProducerBuffer) QueryManagerConfig(com.facebook.presto.execution.QueryManagerConfig) Collectors.toSet(java.util.stream.Collectors.toSet) SplitSource(com.facebook.presto.split.SplitSource) RemoteTaskFactory(com.facebook.presto.execution.RemoteTaskFactory) ImmutableSet(com.google.common.collect.ImmutableSet) Predicate(java.util.function.Predicate) SystemSessionProperties.getWriterMinSize(com.facebook.presto.SystemSessionProperties.getWriterMinSize) Collection(java.util.Collection) TableWriteInfo.createTableWriteInfo(com.facebook.presto.execution.scheduler.TableWriteInfo.createTableWriteInfo) ImmutableList.toImmutableList(com.google.common.collect.ImmutableList.toImmutableList) Set(java.util.Set) NO_NODES_AVAILABLE(com.facebook.presto.spi.StandardErrorCode.NO_NODES_AVAILABLE) Iterables.getLast(com.google.common.collect.Iterables.getLast) NodeSelector(com.facebook.presto.execution.scheduler.nodeSelection.NodeSelector) SOURCE_DISTRIBUTION(com.facebook.presto.sql.planner.SystemPartitioningHandle.SOURCE_DISTRIBUTION) SourcePartitionedScheduler.newSourcePartitionedSchedulerAsStageScheduler(com.facebook.presto.execution.scheduler.SourcePartitionedScheduler.newSourcePartitionedSchedulerAsStageScheduler) Preconditions.checkState(com.google.common.base.Preconditions.checkState) MoreExecutors.directExecutor(com.google.common.util.concurrent.MoreExecutors.directExecutor) List(java.util.List) Optional(java.util.Optional) StageExecutionId(com.facebook.presto.execution.StageExecutionId) ConnectorId(com.facebook.presto.spi.ConnectorId) ConnectorId.isInternalSystemConnector(com.facebook.presto.spi.ConnectorId.isInternalSystemConnector) PlanNodeId(com.facebook.presto.spi.plan.PlanNodeId) StageId(com.facebook.presto.execution.StageId) OutputBuffers(com.facebook.presto.execution.buffer.OutputBuffers) ConnectorPartitionHandle(com.facebook.presto.spi.connector.ConnectorPartitionHandle) NodePartitionMap(com.facebook.presto.sql.planner.NodePartitionMap) ListenableFuture(com.google.common.util.concurrent.ListenableFuture) HashMap(java.util.HashMap) Function(java.util.function.Function) Supplier(java.util.function.Supplier) ArrayList(java.util.ArrayList) Inject(javax.inject.Inject) ImmutableList(com.google.common.collect.ImmutableList) Verify.verify(com.google.common.base.Verify.verify) Objects.requireNonNull(java.util.Objects.requireNonNull) ScheduledExecutorService(java.util.concurrent.ScheduledExecutorService) PlanFragmentId(com.facebook.presto.sql.planner.plan.PlanFragmentId) SystemSessionProperties.getMaxTasksPerStage(com.facebook.presto.SystemSessionProperties.getMaxTasksPerStage) StageExecutionState(com.facebook.presto.execution.StageExecutionState) ExecutorService(java.util.concurrent.ExecutorService) Failures.checkCondition(com.facebook.presto.util.Failures.checkCondition) NodePartitioningManager(com.facebook.presto.sql.planner.NodePartitioningManager) Session(com.facebook.presto.Session) Sets.newConcurrentHashSet(com.google.common.collect.Sets.newConcurrentHashSet) SCALED_WRITER_DISTRIBUTION(com.facebook.presto.sql.planner.SystemPartitioningHandle.SCALED_WRITER_DISTRIBUTION) Iterables.getOnlyElement(com.google.common.collect.Iterables.getOnlyElement) PlanNodeSearcher(com.facebook.presto.sql.planner.optimizations.PlanNodeSearcher) InternalNode(com.facebook.presto.metadata.InternalNode) PlanNode(com.facebook.presto.spi.plan.PlanNode) Collectors.toList(java.util.stream.Collectors.toList) RemoteTask(com.facebook.presto.execution.RemoteTask) FailureDetector(com.facebook.presto.failureDetector.FailureDetector) TableScanNode(com.facebook.presto.spi.plan.TableScanNode) PartitioningHandle(com.facebook.presto.sql.planner.PartitioningHandle) ForQueryExecution(com.facebook.presto.execution.ForQueryExecution) Metadata(com.facebook.presto.metadata.Metadata) NodePartitionMap(com.facebook.presto.sql.planner.NodePartitionMap) ArrayList(java.util.ArrayList) RemoteTask(com.facebook.presto.execution.RemoteTask) TaskStatus(com.facebook.presto.execution.TaskStatus) SqlStageExecution(com.facebook.presto.execution.SqlStageExecution) SqlStageExecution.createSqlStageExecution(com.facebook.presto.execution.SqlStageExecution.createSqlStageExecution) PlanNodeId(com.facebook.presto.spi.plan.PlanNodeId) StageExecutionState(com.facebook.presto.execution.StageExecutionState) Supplier(java.util.function.Supplier) ImmutableList.toImmutableList(com.google.common.collect.ImmutableList.toImmutableList) List(java.util.List) ArrayList(java.util.ArrayList) ImmutableList(com.google.common.collect.ImmutableList) Collectors.toList(java.util.stream.Collectors.toList) NodeSelector(com.facebook.presto.execution.scheduler.nodeSelection.NodeSelector) SplitSource(com.facebook.presto.split.SplitSource) NodeTaskMap(com.facebook.presto.execution.NodeTaskMap) Map(java.util.Map) NodePartitionMap(com.facebook.presto.sql.planner.NodePartitionMap) HashMap(java.util.HashMap) ConnectorId(com.facebook.presto.spi.ConnectorId)

Example 2 with SCALED_WRITER_DISTRIBUTION

use of com.facebook.presto.sql.planner.SystemPartitioningHandle.SCALED_WRITER_DISTRIBUTION in project presto by prestodb.

the class LocalExecutionPlanner method createOutputPartitioning.

private Optional<OutputPartitioning> createOutputPartitioning(TaskContext taskContext, PartitioningScheme partitioningScheme) {
    if (partitioningScheme.getPartitioning().getHandle().equals(FIXED_BROADCAST_DISTRIBUTION) || partitioningScheme.getPartitioning().getHandle().equals(FIXED_ARBITRARY_DISTRIBUTION) || partitioningScheme.getPartitioning().getHandle().equals(SCALED_WRITER_DISTRIBUTION) || partitioningScheme.getPartitioning().getHandle().equals(SINGLE_DISTRIBUTION) || partitioningScheme.getPartitioning().getHandle().equals(COORDINATOR_DISTRIBUTION)) {
        return Optional.empty();
    }
    List<VariableReferenceExpression> outputLayout = partitioningScheme.getOutputLayout();
    // We can convert the variables directly into channels, because the root must be a sink and therefore the layout is fixed
    List<Integer> partitionChannels;
    List<Optional<ConstantExpression>> partitionConstants;
    List<Type> partitionChannelTypes;
    if (partitioningScheme.getHashColumn().isPresent()) {
        partitionChannels = ImmutableList.of(outputLayout.indexOf(partitioningScheme.getHashColumn().get()));
        partitionConstants = ImmutableList.of(Optional.empty());
        partitionChannelTypes = ImmutableList.of(BIGINT);
    } else {
        checkArgument(partitioningScheme.getPartitioning().getArguments().stream().allMatch(argument -> argument instanceof ConstantExpression || argument instanceof VariableReferenceExpression), format("Expect all partitioning arguments to be either ConstantExpression or VariableReferenceExpression, but get %s", partitioningScheme.getPartitioning().getArguments()));
        partitionChannels = partitioningScheme.getPartitioning().getArguments().stream().map(argument -> {
            if (argument instanceof ConstantExpression) {
                return -1;
            }
            return outputLayout.indexOf(argument);
        }).collect(toImmutableList());
        partitionConstants = partitioningScheme.getPartitioning().getArguments().stream().map(argument -> {
            if (argument instanceof ConstantExpression) {
                return Optional.of((ConstantExpression) argument);
            }
            return Optional.<ConstantExpression>empty();
        }).collect(toImmutableList());
        partitionChannelTypes = partitioningScheme.getPartitioning().getArguments().stream().map(RowExpression::getType).collect(toImmutableList());
    }
    PartitionFunction partitionFunction = nodePartitioningManager.getPartitionFunction(taskContext.getSession(), partitioningScheme, partitionChannelTypes);
    OptionalInt nullChannel = OptionalInt.empty();
    Set<VariableReferenceExpression> partitioningColumns = partitioningScheme.getPartitioning().getVariableReferences();
    // partitioningColumns expected to have one column in the normal case, and zero columns when partitioning on a constant
    checkArgument(!partitioningScheme.isReplicateNullsAndAny() || partitioningColumns.size() <= 1);
    if (partitioningScheme.isReplicateNullsAndAny() && partitioningColumns.size() == 1) {
        nullChannel = OptionalInt.of(outputLayout.indexOf(getOnlyElement(partitioningColumns)));
    }
    return Optional.of(new OutputPartitioning(partitionFunction, partitionChannels, partitionConstants, partitioningScheme.isReplicateNullsAndAny(), nullChannel));
}
Also used : GENERIC_INTERNAL_ERROR(com.facebook.presto.spi.StandardErrorCode.GENERIC_INTERNAL_ERROR) RowNumberOperator(com.facebook.presto.operator.RowNumberOperator) GROUPED_EXECUTION(com.facebook.presto.operator.PipelineExecutionStrategy.GROUPED_EXECUTION) SystemSessionProperties.isOrderBySpillEnabled(com.facebook.presto.SystemSessionProperties.isOrderBySpillEnabled) StatisticAggregationsDescriptor(com.facebook.presto.sql.planner.plan.StatisticAggregationsDescriptor) IndexJoinOptimizer(com.facebook.presto.sql.planner.optimizations.IndexJoinOptimizer) DistinctLimitOperatorFactory(com.facebook.presto.operator.DistinctLimitOperator.DistinctLimitOperatorFactory) StageExecutionDescriptor(com.facebook.presto.operator.StageExecutionDescriptor) CursorProcessor(com.facebook.presto.operator.project.CursorProcessor) Map(java.util.Map) QualifiedObjectName(com.facebook.presto.common.QualifiedObjectName) IndexJoinNode(com.facebook.presto.sql.planner.plan.IndexJoinNode) SystemSessionProperties.getDynamicFilteringMaxPerDriverSize(com.facebook.presto.SystemSessionProperties.getDynamicFilteringMaxPerDriverSize) NO_COMMIT(com.facebook.presto.operator.PageSinkCommitStrategy.NO_COMMIT) FragmentResultCacheManager(com.facebook.presto.operator.FragmentResultCacheManager) OrderingScheme(com.facebook.presto.spi.plan.OrderingScheme) PageFunctionCompiler(com.facebook.presto.sql.gen.PageFunctionCompiler) DynamicFilterPlaceholder(com.facebook.presto.expressions.DynamicFilters.DynamicFilterPlaceholder) PARTIAL(com.facebook.presto.spi.plan.AggregationNode.Step.PARTIAL) LookupOuterOperatorFactory(com.facebook.presto.operator.LookupOuterOperator.LookupOuterOperatorFactory) PageSinkManager(com.facebook.presto.split.PageSinkManager) SortOrder(com.facebook.presto.common.block.SortOrder) RowNumberNode(com.facebook.presto.sql.planner.plan.RowNumberNode) SqlFunctionProperties(com.facebook.presto.common.function.SqlFunctionProperties) PageProcessor(com.facebook.presto.operator.project.PageProcessor) StandaloneSpillerFactory(com.facebook.presto.spiller.StandaloneSpillerFactory) InternalAggregationFunction(com.facebook.presto.operator.aggregation.InternalAggregationFunction) LimitOperatorFactory(com.facebook.presto.operator.LimitOperator.LimitOperatorFactory) LimitNode(com.facebook.presto.spi.plan.LimitNode) FunctionMetadata(com.facebook.presto.spi.function.FunctionMetadata) LIFESPAN_COMMIT(com.facebook.presto.operator.PageSinkCommitStrategy.LIFESPAN_COMMIT) LocalPlannerAware(com.facebook.presto.operator.LocalPlannerAware) REPLICATED(com.facebook.presto.sql.planner.plan.JoinNode.DistributionType.REPLICATED) LocalMergeSourceOperatorFactory(com.facebook.presto.operator.exchange.LocalMergeSourceOperator.LocalMergeSourceOperatorFactory) SystemSessionProperties(com.facebook.presto.SystemSessionProperties) JoinFilterFunctionFactory(com.facebook.presto.sql.gen.JoinFilterFunctionCompiler.JoinFilterFunctionFactory) CreateHandle(com.facebook.presto.execution.scheduler.ExecutionWriterTarget.CreateHandle) JoinOperatorFactory(com.facebook.presto.operator.JoinOperatorFactory) SystemSessionProperties.isExchangeCompressionEnabled(com.facebook.presto.SystemSessionProperties.isExchangeCompressionEnabled) UnnestOperatorFactory(com.facebook.presto.operator.unnest.UnnestOperator.UnnestOperatorFactory) Supplier(java.util.function.Supplier) LookupJoinOperators(com.facebook.presto.operator.LookupJoinOperators) LinkedHashMap(java.util.LinkedHashMap) ScanFilterAndProjectOperatorFactory(com.facebook.presto.operator.ScanFilterAndProjectOperator.ScanFilterAndProjectOperatorFactory) UNGROUPED_EXECUTION(com.facebook.presto.operator.PipelineExecutionStrategy.UNGROUPED_EXECUTION) Lists(com.google.common.collect.Lists) LogicalRowExpressions(com.facebook.presto.expressions.LogicalRowExpressions) ConnectorIndex(com.facebook.presto.spi.ConnectorIndex) InternalPlanVisitor(com.facebook.presto.sql.planner.plan.InternalPlanVisitor) ImmutableSet.toImmutableSet(com.google.common.collect.ImmutableSet.toImmutableSet) IndexJoinLookupStats(com.facebook.presto.operator.index.IndexJoinLookupStats) MetadataDeleteOperatorFactory(com.facebook.presto.operator.MetadataDeleteOperator.MetadataDeleteOperatorFactory) SystemSessionProperties.getTaskPartitionedWriterCount(com.facebook.presto.SystemSessionProperties.getTaskPartitionedWriterCount) TableCommitContext(com.facebook.presto.operator.TableCommitContext) RefreshMaterializedViewHandle(com.facebook.presto.execution.scheduler.ExecutionWriterTarget.RefreshMaterializedViewHandle) Session(com.facebook.presto.Session) PageSinkCommitter(com.facebook.presto.operator.TableFinishOperator.PageSinkCommitter) TASK_COMMIT(com.facebook.presto.operator.PageSinkCommitStrategy.TASK_COMMIT) SCALED_WRITER_DISTRIBUTION(com.facebook.presto.sql.planner.SystemPartitioningHandle.SCALED_WRITER_DISTRIBUTION) Frame(com.facebook.presto.sql.planner.plan.WindowNode.Frame) Iterables.getOnlyElement(com.google.common.collect.Iterables.getOnlyElement) NestedLoopJoinBridge(com.facebook.presto.operator.NestedLoopJoinBridge) TableScanOperatorFactory(com.facebook.presto.operator.TableScanOperator.TableScanOperatorFactory) SphericalGeographyUtils.sphericalDistance(com.facebook.presto.geospatial.SphericalGeographyUtils.sphericalDistance) RecordSet(com.facebook.presto.spi.RecordSet) AnalyzeTableHandle(com.facebook.presto.metadata.AnalyzeTableHandle) RIGHT(com.facebook.presto.sql.planner.plan.JoinNode.Type.RIGHT) SqlFunctionId(com.facebook.presto.spi.function.SqlFunctionId) TypeSignature.parseTypeSignature(com.facebook.presto.common.type.TypeSignature.parseTypeSignature) REMOTE(com.facebook.presto.spi.plan.ProjectNode.Locality.REMOTE) TaskMetadataContext(com.facebook.presto.execution.TaskMetadataContext) RowExpressionInterpreter.rowExpressionInterpreter(com.facebook.presto.sql.planner.RowExpressionInterpreter.rowExpressionInterpreter) SystemSessionProperties.getFilterAndProjectMinOutputPageRowCount(com.facebook.presto.SystemSessionProperties.getFilterAndProjectMinOutputPageRowCount) SpillerFactory(com.facebook.presto.spiller.SpillerFactory) OuterOperatorFactoryResult(com.facebook.presto.operator.JoinOperatorFactory.OuterOperatorFactoryResult) MappedRecordSet(com.facebook.presto.split.MappedRecordSet) SystemSessionProperties.isWindowSpillEnabled(com.facebook.presto.SystemSessionProperties.isWindowSpillEnabled) Metadata(com.facebook.presto.metadata.Metadata) ExpressionTreeUtils.createSymbolReference(com.facebook.presto.sql.analyzer.ExpressionTreeUtils.createSymbolReference) COORDINATOR_DISTRIBUTION(com.facebook.presto.sql.planner.SystemPartitioningHandle.COORDINATOR_DISTRIBUTION) JsonCodec(com.facebook.airlift.json.JsonCodec) PartitionedLookupSourceFactory(com.facebook.presto.operator.PartitionedLookupSourceFactory) AggregationNode(com.facebook.presto.spi.plan.AggregationNode) ExplainAnalyzeNode(com.facebook.presto.sql.planner.plan.ExplainAnalyzeNode) DiscreteDomain.integers(com.google.common.collect.DiscreteDomain.integers) IntStream.range(java.util.stream.IntStream.range) RemoteSourceNode(com.facebook.presto.sql.planner.plan.RemoteSourceNode) FRAGMENT_CHANNEL(com.facebook.presto.operator.TableWriterUtils.FRAGMENT_CHANNEL) MetadataDeleteNode(com.facebook.presto.sql.planner.plan.MetadataDeleteNode) TaskManagerConfig(com.facebook.presto.execution.TaskManagerConfig) Expressions.constant(com.facebook.presto.sql.relational.Expressions.constant) SystemSessionProperties.isAggregationSpillEnabled(com.facebook.presto.SystemSessionProperties.isAggregationSpillEnabled) Preconditions.checkArgument(com.google.common.base.Preconditions.checkArgument) HashMultimap(com.google.common.collect.HashMultimap) AccumulatorFactory(com.facebook.presto.operator.aggregation.AccumulatorFactory) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) LookupSourceFactory(com.facebook.presto.operator.LookupSourceFactory) TopNRowNumberNode(com.facebook.presto.sql.planner.plan.TopNRowNumberNode) IndexLookupSourceFactory(com.facebook.presto.operator.index.IndexLookupSourceFactory) IndexSourceNode(com.facebook.presto.sql.planner.plan.IndexSourceNode) DynamicFilterSourceOperator(com.facebook.presto.operator.DynamicFilterSourceOperator) CallExpression(com.facebook.presto.spi.relation.CallExpression) FIXED_BROADCAST_DISTRIBUTION(com.facebook.presto.sql.planner.SystemPartitioningHandle.FIXED_BROADCAST_DISTRIBUTION) VariableToChannelTranslator(com.facebook.presto.sql.relational.VariableToChannelTranslator) ImmutableSetMultimap(com.google.common.collect.ImmutableSetMultimap) OutputNode(com.facebook.presto.sql.planner.plan.OutputNode) HashBuilderOperatorFactory(com.facebook.presto.operator.HashBuilderOperator.HashBuilderOperatorFactory) SymbolReference(com.facebook.presto.sql.tree.SymbolReference) ImmutableSet(com.google.common.collect.ImmutableSet) Collection(java.util.Collection) SourceOperatorFactory(com.facebook.presto.operator.SourceOperatorFactory) LambdaDefinitionExpression(com.facebook.presto.spi.relation.LambdaDefinitionExpression) Collectors(java.util.stream.Collectors) MarkDistinctOperatorFactory(com.facebook.presto.operator.MarkDistinctOperator.MarkDistinctOperatorFactory) SystemSessionProperties.isExchangeChecksumEnabled(com.facebook.presto.SystemSessionProperties.isExchangeChecksumEnabled) SpatialJoinUtils.extractSupportedSpatialFunctions(com.facebook.presto.util.SpatialJoinUtils.extractSupportedSpatialFunctions) MoreFutures.addSuccessCallback(com.facebook.airlift.concurrent.MoreFutures.addSuccessCallback) DynamicTupleFilterFactory(com.facebook.presto.operator.index.DynamicTupleFilterFactory) Range.closedOpen(com.google.common.collect.Range.closedOpen) StreamingAggregationOperatorFactory(com.facebook.presto.operator.StreamingAggregationOperator.StreamingAggregationOperatorFactory) WindowFunctionSupplier(com.facebook.presto.operator.window.WindowFunctionSupplier) InputReferenceExpression(com.facebook.presto.spi.relation.InputReferenceExpression) SystemSessionProperties.isOptimizeCommonSubExpressions(com.facebook.presto.SystemSessionProperties.isOptimizeCommonSubExpressions) SpatialPredicate(com.facebook.presto.operator.SpatialIndexBuilderOperator.SpatialPredicate) ST_INTERSECTS(com.facebook.presto.util.SpatialJoinUtils.ST_INTERSECTS) AssignUniqueIdOperator(com.facebook.presto.operator.AssignUniqueIdOperator) ExpressionCompiler(com.facebook.presto.sql.gen.ExpressionCompiler) IntStream(java.util.stream.IntStream) ST_DISTANCE(com.facebook.presto.util.SpatialJoinUtils.ST_DISTANCE) DeterminismEvaluator(com.facebook.presto.spi.relation.DeterminismEvaluator) ROW_COUNT_CHANNEL(com.facebook.presto.operator.TableWriterUtils.ROW_COUNT_CHANNEL) ExplainAnalyzeOperatorFactory(com.facebook.presto.operator.ExplainAnalyzeOperator.ExplainAnalyzeOperatorFactory) FrameInfo(com.facebook.presto.operator.window.FrameInfo) PagesSerdeFactory(com.facebook.presto.execution.buffer.PagesSerdeFactory) UnionNode(com.facebook.presto.spi.plan.UnionNode) OperatorFactory(com.facebook.presto.operator.OperatorFactory) OptionalInt(java.util.OptionalInt) Function(java.util.function.Function) BlockEncodingSerde(com.facebook.presto.common.block.BlockEncodingSerde) Inject(javax.inject.Inject) DriverFactory(com.facebook.presto.operator.DriverFactory) ImmutableList(com.google.common.collect.ImmutableList) PagesSpatialIndexFactory(com.facebook.presto.operator.PagesSpatialIndexFactory) SystemSessionProperties.isJoinSpillingEnabled(com.facebook.presto.SystemSessionProperties.isJoinSpillingEnabled) ExecutionWriterTarget(com.facebook.presto.execution.scheduler.ExecutionWriterTarget) IndexManager(com.facebook.presto.index.IndexManager) SystemSessionProperties.getDynamicFilteringMaxPerDriverRowCount(com.facebook.presto.SystemSessionProperties.getDynamicFilteringMaxPerDriverRowCount) DynamicFilters(com.facebook.presto.expressions.DynamicFilters) SingleStreamSpillerFactory(com.facebook.presto.spiller.SingleStreamSpillerFactory) Type(com.facebook.presto.common.type.Type) JoinNode(com.facebook.presto.sql.planner.plan.JoinNode) SystemSessionProperties.isOptimizedRepartitioningEnabled(com.facebook.presto.SystemSessionProperties.isOptimizedRepartitioningEnabled) TypeUtils.writeNativeValue(com.facebook.presto.common.type.TypeUtils.writeNativeValue) OutputFactory(com.facebook.presto.operator.OutputFactory) JoinFilterFunctionCompiler(com.facebook.presto.sql.gen.JoinFilterFunctionCompiler) Reflection.constructorMethodHandle(com.facebook.presto.util.Reflection.constructorMethodHandle) StatisticsWriterOperatorFactory(com.facebook.presto.operator.StatisticsWriterOperator.StatisticsWriterOperatorFactory) SystemSessionProperties.getTaskWriterCount(com.facebook.presto.SystemSessionProperties.getTaskWriterCount) PlanNode(com.facebook.presto.spi.plan.PlanNode) FunctionHandle(com.facebook.presto.spi.function.FunctionHandle) DeleteScanInfo(com.facebook.presto.execution.scheduler.TableWriteInfo.DeleteScanInfo) SystemSessionProperties.getAggregationOperatorUnspillMemoryLimit(com.facebook.presto.SystemSessionProperties.getAggregationOperatorUnspillMemoryLimit) SystemSessionProperties.isEnableDynamicFiltering(com.facebook.presto.SystemSessionProperties.isEnableDynamicFiltering) RowExpressionNodeInliner.replaceExpression(com.facebook.presto.expressions.RowExpressionNodeInliner.replaceExpression) Page(com.facebook.presto.common.Page) Arrays(java.util.Arrays) PageSinkCommitStrategy(com.facebook.presto.operator.PageSinkCommitStrategy) STATS_START_CHANNEL(com.facebook.presto.operator.TableWriterUtils.STATS_START_CHANNEL) TableWriterOperatorFactory(com.facebook.presto.operator.TableWriterOperator.TableWriterOperatorFactory) PageSourceProvider(com.facebook.presto.split.PageSourceProvider) ST_EQUALS(com.facebook.presto.util.SpatialJoinUtils.ST_EQUALS) OutputBuffer(com.facebook.presto.execution.buffer.OutputBuffer) SqlInvokedFunction(com.facebook.presto.spi.function.SqlInvokedFunction) PageChannelSelector(com.facebook.presto.operator.exchange.PageChannelSelector) ST_OVERLAPS(com.facebook.presto.util.SpatialJoinUtils.ST_OVERLAPS) TypeSignature(com.facebook.presto.common.type.TypeSignature) FULL(com.facebook.presto.sql.planner.plan.JoinNode.Type.FULL) PageBuilder(com.facebook.presto.common.PageBuilder) ValuesNode(com.facebook.presto.spi.plan.ValuesNode) TableWriteInfo(com.facebook.presto.execution.scheduler.TableWriteInfo) WindowFunctionDefinition.window(com.facebook.presto.operator.WindowFunctionDefinition.window) TableWriterMergeOperatorFactory(com.facebook.presto.operator.TableWriterMergeOperator.TableWriterMergeOperatorFactory) NestedLoopBuildOperatorFactory(com.facebook.presto.operator.NestedLoopBuildOperator.NestedLoopBuildOperatorFactory) PipelineExecutionStrategy(com.facebook.presto.operator.PipelineExecutionStrategy) LocalExchangeSinkOperatorFactory(com.facebook.presto.operator.exchange.LocalExchangeSinkOperator.LocalExchangeSinkOperatorFactory) ImmutableList.toImmutableList(com.google.common.collect.ImmutableList.toImmutableList) Set(java.util.Set) GroupIdOperator(com.facebook.presto.operator.GroupIdOperator) ST_TOUCHES(com.facebook.presto.util.SpatialJoinUtils.ST_TOUCHES) InsertHandle(com.facebook.presto.execution.scheduler.ExecutionWriterTarget.InsertHandle) EnforceSingleRowOperator(com.facebook.presto.operator.EnforceSingleRowOperator) SystemSessionProperties.isSpillEnabled(com.facebook.presto.SystemSessionProperties.isSpillEnabled) ProjectNode(com.facebook.presto.spi.plan.ProjectNode) StageExecutionId(com.facebook.presto.execution.StageExecutionId) AssignUniqueId(com.facebook.presto.sql.planner.plan.AssignUniqueId) LocalExchangeSourceOperatorFactory(com.facebook.presto.operator.exchange.LocalExchangeSourceOperator.LocalExchangeSourceOperatorFactory) FilterAndProjectOperatorFactory(com.facebook.presto.operator.FilterAndProjectOperator.FilterAndProjectOperatorFactory) NestedLoopJoinOperatorFactory(com.facebook.presto.operator.NestedLoopJoinOperator.NestedLoopJoinOperatorFactory) AbstractJoinNode(com.facebook.presto.sql.planner.plan.AbstractJoinNode) FieldSetFilteringRecordSet(com.facebook.presto.operator.index.FieldSetFilteringRecordSet) FragmentResultCacheContext.createFragmentResultCacheContext(com.facebook.presto.execution.FragmentResultCacheContext.createFragmentResultCacheContext) Iterables(com.google.common.collect.Iterables) FIXED_ARBITRARY_DISTRIBUTION(com.facebook.presto.sql.planner.SystemPartitioningHandle.FIXED_ARBITRARY_DISTRIBUTION) SINGLE_DISTRIBUTION(com.facebook.presto.sql.planner.SystemPartitioningHandle.SINGLE_DISTRIBUTION) ContiguousSet(com.google.common.collect.ContiguousSet) SystemSessionProperties.getFilterAndProjectMinOutputPageSize(com.facebook.presto.SystemSessionProperties.getFilterAndProjectMinOutputPageSize) GroupIdNode(com.facebook.presto.sql.planner.plan.GroupIdNode) Assignments(com.facebook.presto.spi.plan.Assignments) DistinctLimitNode(com.facebook.presto.spi.plan.DistinctLimitNode) ConstantExpression(com.facebook.presto.spi.relation.ConstantExpression) TopNOperatorFactory(com.facebook.presto.operator.TopNOperator.TopNOperatorFactory) ValuesOperatorFactory(com.facebook.presto.operator.ValuesOperator.ValuesOperatorFactory) Builder(com.google.common.collect.ImmutableMap.Builder) ArrayList(java.util.ArrayList) OptimizedPartitionedOutputFactory(com.facebook.presto.operator.repartition.OptimizedPartitionedOutputOperator.OptimizedPartitionedOutputFactory) TableWriterMergeNode(com.facebook.presto.sql.planner.plan.TableWriterMergeNode) AggregationOperatorFactory(com.facebook.presto.operator.AggregationOperator.AggregationOperatorFactory) SystemSessionProperties.isDistinctAggregationSpillEnabled(com.facebook.presto.SystemSessionProperties.isDistinctAggregationSpillEnabled) SpatialIndexBuilderOperatorFactory(com.facebook.presto.operator.SpatialIndexBuilderOperator.SpatialIndexBuilderOperatorFactory) TableHandle(com.facebook.presto.spi.TableHandle) FunctionResolution(com.facebook.presto.sql.relational.FunctionResolution) BIGINT(com.facebook.presto.common.type.BigintType.BIGINT) TaskContext(com.facebook.presto.operator.TaskContext) WindowNode(com.facebook.presto.sql.planner.plan.WindowNode) SystemSessionProperties.getDynamicFilteringRangeRowLimitPerDriver(com.facebook.presto.SystemSessionProperties.getDynamicFilteringRangeRowLimitPerDriver) TableFinisher(com.facebook.presto.operator.TableFinishOperator.TableFinisher) OperatorType(com.facebook.presto.common.function.OperatorType) LocalExchangeFactory(com.facebook.presto.operator.exchange.LocalExchange.LocalExchangeFactory) ColumnHandle(com.facebook.presto.spi.ColumnHandle) TableScanNode(com.facebook.presto.spi.plan.TableScanNode) SemiJoinNode(com.facebook.presto.sql.planner.plan.SemiJoinNode) TopNNode(com.facebook.presto.spi.plan.TopNNode) Aggregation(com.facebook.presto.spi.plan.AggregationNode.Aggregation) FunctionAndTypeManager(com.facebook.presto.metadata.FunctionAndTypeManager) AssignmentUtils.identityAssignments(com.facebook.presto.sql.planner.plan.AssignmentUtils.identityAssignments) PartitioningSpillerFactory(com.facebook.presto.spiller.PartitioningSpillerFactory) LambdaProvider(com.facebook.presto.operator.aggregation.LambdaProvider) SpatialJoinNode(com.facebook.presto.sql.planner.plan.SpatialJoinNode) SortNode(com.facebook.presto.sql.planner.plan.SortNode) VariableReferenceExpression(com.facebook.presto.spi.relation.VariableReferenceExpression) TableWriterNode(com.facebook.presto.sql.planner.plan.TableWriterNode) TableFinishOperatorFactory(com.facebook.presto.operator.TableFinishOperator.TableFinishOperatorFactory) INTERMEDIATE(com.facebook.presto.spi.plan.AggregationNode.Step.INTERMEDIATE) PagesIndex(com.facebook.presto.operator.PagesIndex) IndexSourceOperator(com.facebook.presto.operator.index.IndexSourceOperator) TaskOutputFactory(com.facebook.presto.operator.TaskOutputOperator.TaskOutputFactory) OrderByOperatorFactory(com.facebook.presto.operator.OrderByOperator.OrderByOperatorFactory) SpatialJoinOperatorFactory(com.facebook.presto.operator.SpatialJoinOperator.SpatialJoinOperatorFactory) TopNRowNumberOperator(com.facebook.presto.operator.TopNRowNumberOperator) LOCAL(com.facebook.presto.spi.plan.ProjectNode.Locality.LOCAL) ST_WITHIN(com.facebook.presto.util.SpatialJoinUtils.ST_WITHIN) HashAggregationOperatorFactory(com.facebook.presto.operator.HashAggregationOperator.HashAggregationOperatorFactory) ConnectorMetadataUpdaterManager(com.facebook.presto.metadata.ConnectorMetadataUpdaterManager) SystemSessionProperties.getTaskConcurrency(com.facebook.presto.SystemSessionProperties.getTaskConcurrency) DeleteHandle(com.facebook.presto.execution.scheduler.ExecutionWriterTarget.DeleteHandle) LambdaBytecodeGenerator.compileLambdaProvider(com.facebook.presto.sql.gen.LambdaBytecodeGenerator.compileLambdaProvider) SetBuilderOperatorFactory(com.facebook.presto.operator.SetBuilderOperator.SetBuilderOperatorFactory) Step(com.facebook.presto.spi.plan.AggregationNode.Step) NestedLoopJoinPagesSupplier(com.facebook.presto.operator.NestedLoopJoinPagesSupplier) ImmutableMap(com.google.common.collect.ImmutableMap) Predicate(java.util.function.Predicate) JoinBridgeManager(com.facebook.presto.operator.JoinBridgeManager) CONTEXT_CHANNEL(com.facebook.presto.operator.TableWriterUtils.CONTEXT_CHANNEL) IndexBuildDriverFactoryProvider(com.facebook.presto.operator.index.IndexBuildDriverFactoryProvider) TRUE_CONSTANT(com.facebook.presto.expressions.LogicalRowExpressions.TRUE_CONSTANT) String.format(java.lang.String.format) Preconditions.checkState(com.google.common.base.Preconditions.checkState) FragmentResultCacheContext(com.facebook.presto.execution.FragmentResultCacheContext) DataSize(io.airlift.units.DataSize) List(java.util.List) NOT_SUPPORTED(com.facebook.presto.spi.StandardErrorCode.NOT_SUPPORTED) SampleNode(com.facebook.presto.sql.planner.plan.SampleNode) Optional(java.util.Optional) ST_CONTAINS(com.facebook.presto.util.SpatialJoinUtils.ST_CONTAINS) MarkDistinctNode(com.facebook.presto.spi.plan.MarkDistinctNode) INNER(com.facebook.presto.sql.planner.plan.JoinNode.Type.INNER) DynamicFilterExtractResult(com.facebook.presto.expressions.DynamicFilters.DynamicFilterExtractResult) PlanNodeId(com.facebook.presto.spi.plan.PlanNodeId) Locality(com.facebook.presto.spi.plan.ProjectNode.Locality) HashMap(java.util.HashMap) SystemSessionProperties.getIndexLoaderTimeout(com.facebook.presto.SystemSessionProperties.getIndexLoaderTimeout) PrestoException(com.facebook.presto.spi.PrestoException) Multimap(com.google.common.collect.Multimap) ImmutableBiMap(com.google.common.collect.ImmutableBiMap) FilterNode(com.facebook.presto.spi.plan.FilterNode) ST_CROSSES(com.facebook.presto.util.SpatialJoinUtils.ST_CROSSES) DevNullOperatorFactory(com.facebook.presto.operator.DevNullOperator.DevNullOperatorFactory) OrderingCompiler(com.facebook.presto.sql.gen.OrderingCompiler) Verify.verify(com.google.common.base.Verify.verify) PartitionedOutputFactory(com.facebook.presto.operator.repartition.PartitionedOutputOperator.PartitionedOutputFactory) FINAL(com.facebook.presto.spi.plan.AggregationNode.Step.FINAL) Objects.requireNonNull(java.util.Objects.requireNonNull) ExplainAnalyzeContext(com.facebook.presto.execution.ExplainAnalyzeContext) SpatialJoinUtils.extractSupportedSpatialComparisons(com.facebook.presto.util.SpatialJoinUtils.extractSupportedSpatialComparisons) MemoryManagerConfig(com.facebook.presto.memory.MemoryManagerConfig) SystemSessionProperties.isOrderByAggregationSpillEnabled(com.facebook.presto.SystemSessionProperties.isOrderByAggregationSpillEnabled) HashSemiJoinOperatorFactory(com.facebook.presto.operator.HashSemiJoinOperator.HashSemiJoinOperatorFactory) UnnestNode(com.facebook.presto.sql.planner.plan.UnnestNode) RowExpression(com.facebook.presto.spi.relation.RowExpression) VerifyException(com.google.common.base.VerifyException) WindowOperatorFactory(com.facebook.presto.operator.WindowOperator.WindowOperatorFactory) ObjectMapper(com.fasterxml.jackson.databind.ObjectMapper) RemoteProjectOperatorFactory(com.facebook.presto.operator.RemoteProjectOperator.RemoteProjectOperatorFactory) PartitionFunction(com.facebook.presto.operator.PartitionFunction) WindowFunctionDefinition(com.facebook.presto.operator.WindowFunctionDefinition) Ints(com.google.common.primitives.Ints) TupleDomain(com.facebook.presto.common.predicate.TupleDomain) DeleteNode(com.facebook.presto.sql.planner.plan.DeleteNode) SetMultimap(com.google.common.collect.SetMultimap) OPTIMIZED(com.facebook.presto.spi.relation.ExpressionOptimizer.Level.OPTIMIZED) SetSupplier(com.facebook.presto.operator.SetBuilderOperator.SetSupplier) VisibleForTesting(com.google.common.annotations.VisibleForTesting) COMPILER_ERROR(com.facebook.presto.spi.StandardErrorCode.COMPILER_ERROR) TableFinishNode(com.facebook.presto.sql.planner.plan.TableFinishNode) BYTE(io.airlift.units.DataSize.Unit.BYTE) DeleteOperatorFactory(com.facebook.presto.operator.DeleteOperator.DeleteOperatorFactory) JoinCompiler(com.facebook.presto.sql.gen.JoinCompiler) EnforceSingleRowNode(com.facebook.presto.sql.planner.plan.EnforceSingleRowNode) ExchangeNode(com.facebook.presto.sql.planner.plan.ExchangeNode) StatisticsWriterNode(com.facebook.presto.sql.planner.plan.StatisticsWriterNode) PartitionFunction(com.facebook.presto.operator.PartitionFunction) Optional(java.util.Optional) ConstantExpression(com.facebook.presto.spi.relation.ConstantExpression) RowExpression(com.facebook.presto.spi.relation.RowExpression) OptionalInt(java.util.OptionalInt) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) Type(com.facebook.presto.common.type.Type) OperatorType(com.facebook.presto.common.function.OperatorType) VariableReferenceExpression(com.facebook.presto.spi.relation.VariableReferenceExpression)

Aggregations

Session (com.facebook.presto.Session)2 MoreFutures.addSuccessCallback (com.facebook.airlift.concurrent.MoreFutures.addSuccessCallback)1 JsonCodec (com.facebook.airlift.json.JsonCodec)1 SystemSessionProperties (com.facebook.presto.SystemSessionProperties)1 SystemSessionProperties.getAggregationOperatorUnspillMemoryLimit (com.facebook.presto.SystemSessionProperties.getAggregationOperatorUnspillMemoryLimit)1 SystemSessionProperties.getConcurrentLifespansPerNode (com.facebook.presto.SystemSessionProperties.getConcurrentLifespansPerNode)1 SystemSessionProperties.getDynamicFilteringMaxPerDriverRowCount (com.facebook.presto.SystemSessionProperties.getDynamicFilteringMaxPerDriverRowCount)1 SystemSessionProperties.getDynamicFilteringMaxPerDriverSize (com.facebook.presto.SystemSessionProperties.getDynamicFilteringMaxPerDriverSize)1 SystemSessionProperties.getDynamicFilteringRangeRowLimitPerDriver (com.facebook.presto.SystemSessionProperties.getDynamicFilteringRangeRowLimitPerDriver)1 SystemSessionProperties.getFilterAndProjectMinOutputPageRowCount (com.facebook.presto.SystemSessionProperties.getFilterAndProjectMinOutputPageRowCount)1 SystemSessionProperties.getFilterAndProjectMinOutputPageSize (com.facebook.presto.SystemSessionProperties.getFilterAndProjectMinOutputPageSize)1 SystemSessionProperties.getIndexLoaderTimeout (com.facebook.presto.SystemSessionProperties.getIndexLoaderTimeout)1 SystemSessionProperties.getMaxTasksPerStage (com.facebook.presto.SystemSessionProperties.getMaxTasksPerStage)1 SystemSessionProperties.getTaskConcurrency (com.facebook.presto.SystemSessionProperties.getTaskConcurrency)1 SystemSessionProperties.getTaskPartitionedWriterCount (com.facebook.presto.SystemSessionProperties.getTaskPartitionedWriterCount)1 SystemSessionProperties.getTaskWriterCount (com.facebook.presto.SystemSessionProperties.getTaskWriterCount)1 SystemSessionProperties.getWriterMinSize (com.facebook.presto.SystemSessionProperties.getWriterMinSize)1 SystemSessionProperties.isAggregationSpillEnabled (com.facebook.presto.SystemSessionProperties.isAggregationSpillEnabled)1 SystemSessionProperties.isDistinctAggregationSpillEnabled (com.facebook.presto.SystemSessionProperties.isDistinctAggregationSpillEnabled)1 SystemSessionProperties.isEnableDynamicFiltering (com.facebook.presto.SystemSessionProperties.isEnableDynamicFiltering)1