Search in sources :

Example 11 with OperatorContext

use of com.facebook.presto.operator.OperatorContext in project presto by prestodb.

the class TestMemoryRevokingScheduler method testCountAlreadyRevokedMemoryWithinAPool.

@Test
public void testCountAlreadyRevokedMemoryWithinAPool() throws Exception {
    // Given
    MemoryPool anotherMemoryPool = new MemoryPool(new MemoryPoolId("test"), new DataSize(10, BYTE));
    SqlTask sqlTask1 = newSqlTask(new QueryId("q1"), anotherMemoryPool);
    OperatorContext operatorContext1 = createContexts(sqlTask1);
    SqlTask sqlTask2 = newSqlTask(new QueryId("q2"), memoryPool);
    OperatorContext operatorContext2 = createContexts(sqlTask2);
    List<SqlTask> tasks = ImmutableList.of(sqlTask1, sqlTask2);
    MemoryRevokingScheduler scheduler = new MemoryRevokingScheduler(asList(memoryPool, anotherMemoryPool), () -> tasks, queryContexts::get, 1.0, 1.0, ORDER_BY_CREATE_TIME, false);
    try {
        scheduler.start();
        allOperatorContexts = ImmutableSet.of(operatorContext1, operatorContext2);
        /*
             * sqlTask1 fills its pool
             */
        operatorContext1.localRevocableMemoryContext().setBytes(12);
        scheduler.awaitAsynchronousCallbacksRun();
        assertMemoryRevokingRequestedFor(operatorContext1);
        /*
             * When sqlTask2 fills its pool
             */
        operatorContext2.localRevocableMemoryContext().setBytes(12);
        scheduler.awaitAsynchronousCallbacksRun();
        /*
             * Then sqlTask2 should be asked to revoke its memory too
             */
        assertMemoryRevokingRequestedFor(operatorContext1, operatorContext2);
    } finally {
        scheduler.stop();
    }
}
Also used : SqlTask.createSqlTask(com.facebook.presto.execution.SqlTask.createSqlTask) DataSize(io.airlift.units.DataSize) QueryId(com.facebook.presto.spi.QueryId) OperatorContext(com.facebook.presto.operator.OperatorContext) MemoryPoolId(com.facebook.presto.spi.memory.MemoryPoolId) MemoryPool(com.facebook.presto.memory.MemoryPool) Test(org.testng.annotations.Test)

Example 12 with OperatorContext

use of com.facebook.presto.operator.OperatorContext in project presto by prestodb.

the class LocalQueryRunner method executeInternal.

private MaterializedResultWithPlan executeInternal(Session session, @Language("SQL") String sql, WarningCollector warningCollector) {
    lock.readLock().lock();
    try (Closer closer = Closer.create()) {
        AtomicReference<MaterializedResult.Builder> builder = new AtomicReference<>();
        PageConsumerOutputFactory outputFactory = new PageConsumerOutputFactory(types -> {
            builder.compareAndSet(null, MaterializedResult.resultBuilder(session, types));
            return builder.get()::page;
        });
        Plan plan = createPlan(session, sql, warningCollector);
        TaskContext taskContext = TestingTaskContext.builder(notificationExecutor, yieldExecutor, session).setMaxSpillSize(nodeSpillConfig.getMaxSpillPerNode()).setQueryMaxSpillSize(nodeSpillConfig.getQueryMaxSpillPerNode()).setQueryMaxTotalMemory(getQueryMaxTotalMemoryPerNode(session)).setTaskPlan(plan.getRoot()).build();
        taskContext.getQueryContext().setVerboseExceededMemoryLimitErrorsEnabled(isVerboseExceededMemoryLimitErrorsEnabled(session));
        taskContext.getQueryContext().setHeapDumpOnExceededMemoryLimitEnabled(isHeapDumpOnExceededMemoryLimitEnabled(session));
        String heapDumpFilePath = Paths.get(getHeapDumpFileDirectory(session), format("%s_%s.hprof", session.getQueryId().getId(), taskContext.getTaskId().getStageExecutionId().getStageId().getId())).toString();
        taskContext.getQueryContext().setHeapDumpFilePath(heapDumpFilePath);
        List<Driver> drivers = createDrivers(session, plan, outputFactory, taskContext);
        drivers.forEach(closer::register);
        boolean done = false;
        while (!done) {
            boolean processed = false;
            for (Driver driver : drivers) {
                if (alwaysRevokeMemory) {
                    driver.getDriverContext().getOperatorContexts().stream().filter(operatorContext -> operatorContext.getOperatorStats().getRevocableMemoryReservation().getValue() > 0).forEach(OperatorContext::requestMemoryRevoking);
                }
                if (!driver.isFinished()) {
                    driver.process();
                    processed = true;
                }
            }
            done = !processed;
        }
        verify(builder.get() != null, "Output operator was not created");
        return new MaterializedResultWithPlan(builder.get().build(), plan);
    } catch (IOException e) {
        throw new UncheckedIOException(e);
    } finally {
        lock.readLock().unlock();
    }
}
Also used : Closer(com.google.common.io.Closer) WarningCollector(com.facebook.presto.spi.WarningCollector) PrepareTask(com.facebook.presto.execution.PrepareTask) RowExpressionDomainTranslator(com.facebook.presto.sql.relational.RowExpressionDomainTranslator) PluginManagerConfig(com.facebook.presto.server.PluginManagerConfig) QueryExplainer(com.facebook.presto.sql.analyzer.QueryExplainer) ResetSession(com.facebook.presto.sql.tree.ResetSession) NodeSelectionStats(com.facebook.presto.execution.scheduler.nodeSelection.NodeSelectionStats) ConnectorPlanOptimizerManager(com.facebook.presto.sql.planner.ConnectorPlanOptimizerManager) RenameColumnTask(com.facebook.presto.execution.RenameColumnTask) MoreFutures.getFutureValue(com.facebook.airlift.concurrent.MoreFutures.getFutureValue) ColumnPropertyManager(com.facebook.presto.metadata.ColumnPropertyManager) NOT_PARTITIONED(com.facebook.presto.spi.connector.NotPartitionedPartitionHandle.NOT_PARTITIONED) StageExecutionDescriptor(com.facebook.presto.operator.StageExecutionDescriptor) ThrowingNodeTtlFetcherManager(com.facebook.presto.ttl.nodettlfetchermanagers.ThrowingNodeTtlFetcherManager) Map(java.util.Map) QualifiedObjectName(com.facebook.presto.common.QualifiedObjectName) PageFunctionCompiler(com.facebook.presto.sql.gen.PageFunctionCompiler) CreateTable(com.facebook.presto.sql.tree.CreateTable) TaskCountEstimator(com.facebook.presto.cost.TaskCountEstimator) SessionPropertyDefaults(com.facebook.presto.server.SessionPropertyDefaults) PageSinkManager(com.facebook.presto.split.PageSinkManager) SortOrder(com.facebook.presto.common.block.SortOrder) Prepare(com.facebook.presto.sql.tree.Prepare) StandaloneSpillerFactory(com.facebook.presto.spiller.StandaloneSpillerFactory) Plugin(com.facebook.presto.spi.Plugin) CreateMaterializedView(com.facebook.presto.sql.tree.CreateMaterializedView) DropViewTask(com.facebook.presto.execution.DropViewTask) QueryPreparer(com.facebook.presto.execution.QueryPreparer) PasswordAuthenticatorManager(com.facebook.presto.server.security.PasswordAuthenticatorManager) DropTable(com.facebook.presto.sql.tree.DropTable) RowExpressionPredicateCompiler(com.facebook.presto.sql.gen.RowExpressionPredicateCompiler) RemoteSourceFactory(com.facebook.presto.sql.planner.RemoteSourceFactory) SystemSessionProperties(com.facebook.presto.SystemSessionProperties) RollbackTask(com.facebook.presto.execution.RollbackTask) StreamingPlanSection(com.facebook.presto.execution.scheduler.StreamingPlanSection) PlanOptimizer(com.facebook.presto.sql.planner.optimizations.PlanOptimizer) ViewDefinition(com.facebook.presto.metadata.ViewDefinition) AnalyzePropertiesSystemTable(com.facebook.presto.connector.system.AnalyzePropertiesSystemTable) LookupJoinOperators(com.facebook.presto.operator.LookupJoinOperators) GenericSpillerFactory(com.facebook.presto.spiller.GenericSpillerFactory) ScheduledExecutorService(java.util.concurrent.ScheduledExecutorService) AnalyzePropertyManager(com.facebook.presto.metadata.AnalyzePropertyManager) IndexJoinLookupStats(com.facebook.presto.operator.index.IndexJoinLookupStats) TransactionManager(com.facebook.presto.transaction.TransactionManager) PreparedQuery(com.facebook.presto.execution.QueryPreparer.PreparedQuery) TableCommitContext(com.facebook.presto.operator.TableCommitContext) StreamingPlanSection.extractStreamingSections(com.facebook.presto.execution.scheduler.StreamingPlanSection.extractStreamingSections) Session(com.facebook.presto.Session) IOException(java.io.IOException) SplitSchedulingStrategy(com.facebook.presto.spi.connector.ConnectorSplitManager.SplitSchedulingStrategy) Split(com.facebook.presto.metadata.Split) ThrowingClusterTtlProviderManager(com.facebook.presto.ttl.clusterttlprovidermanagers.ThrowingClusterTtlProviderManager) SpillerFactory(com.facebook.presto.spiller.SpillerFactory) OperatorContext(com.facebook.presto.operator.OperatorContext) Metadata(com.facebook.presto.metadata.Metadata) LocalExecutionPlanner(com.facebook.presto.sql.planner.LocalExecutionPlanner) TablePropertyManager(com.facebook.presto.metadata.TablePropertyManager) DropMaterializedViewTask(com.facebook.presto.execution.DropMaterializedViewTask) TaskManagerConfig(com.facebook.presto.execution.TaskManagerConfig) SystemSessionProperties.getHeapDumpFileDirectory(com.facebook.presto.SystemSessionProperties.getHeapDumpFileDirectory) Duration(io.airlift.units.Duration) Preconditions.checkArgument(com.google.common.base.Preconditions.checkArgument) WarningCollectorConfig(com.facebook.presto.execution.warnings.WarningCollectorConfig) ConnectorManager(com.facebook.presto.connector.ConnectorManager) GlobalSystemConnector(com.facebook.presto.connector.system.GlobalSystemConnector) UNGROUPED_SCHEDULING(com.facebook.presto.spi.connector.ConnectorSplitManager.SplitSchedulingStrategy.UNGROUPED_SCHEDULING) TransactionBuilder.transaction(com.facebook.presto.transaction.TransactionBuilder.transaction) DropView(com.facebook.presto.sql.tree.DropView) TreeAssertions.assertFormattedSql(com.facebook.presto.sql.testing.TreeAssertions.assertFormattedSql) StatsNormalizer(com.facebook.presto.cost.StatsNormalizer) ImmutableSet(com.google.common.collect.ImmutableSet) QualifiedTablePrefix(com.facebook.presto.metadata.QualifiedTablePrefix) TableWriteInfo.createTableWriteInfo(com.facebook.presto.execution.scheduler.TableWriteInfo.createTableWriteInfo) CostCalculatorUsingExchanges(com.facebook.presto.cost.CostCalculatorUsingExchanges) SourceOperatorFactory(com.facebook.presto.operator.SourceOperatorFactory) CostCalculator(com.facebook.presto.cost.CostCalculator) NodeSpillConfig(com.facebook.presto.spiller.NodeSpillConfig) SplitManager(com.facebook.presto.split.SplitManager) GlobalSystemConnectorFactory(com.facebook.presto.connector.system.GlobalSystemConnectorFactory) TransactionManagerConfig(com.facebook.presto.transaction.TransactionManagerConfig) DefaultWarningCollector(com.facebook.presto.execution.warnings.DefaultWarningCollector) SetSession(com.facebook.presto.sql.tree.SetSession) CreateFunctionTask(com.facebook.presto.execution.CreateFunctionTask) CreateView(com.facebook.presto.sql.tree.CreateView) ExpressionCompiler(com.facebook.presto.sql.gen.ExpressionCompiler) Commit(com.facebook.presto.sql.tree.Commit) DataDefinitionTask(com.facebook.presto.execution.DataDefinitionTask) QueryPrerequisitesManager(com.facebook.presto.dispatcher.QueryPrerequisitesManager) SimpleTtlNodeSelectorConfig(com.facebook.presto.execution.scheduler.nodeSelection.SimpleTtlNodeSelectorConfig) RowExpressionDeterminismEvaluator(com.facebook.presto.sql.relational.RowExpressionDeterminismEvaluator) Function(java.util.function.Function) PlanOptimizers(com.facebook.presto.sql.planner.PlanOptimizers) LegacyNetworkTopology(com.facebook.presto.execution.scheduler.LegacyNetworkTopology) DriverFactory(com.facebook.presto.operator.DriverFactory) ImmutableList(com.google.common.collect.ImmutableList) PageSourceManager(com.facebook.presto.split.PageSourceManager) PlanPrinter(com.facebook.presto.sql.planner.planPrinter.PlanPrinter) PlanChecker(com.facebook.presto.sql.planner.sanity.PlanChecker) StatsCalculatorModule.createNewStatsCalculator(com.facebook.presto.cost.StatsCalculatorModule.createNewStatsCalculator) IndexManager(com.facebook.presto.index.IndexManager) DropTableTask(com.facebook.presto.execution.DropTableTask) ScheduledSplit(com.facebook.presto.execution.ScheduledSplit) SessionPropertyManager(com.facebook.presto.metadata.SessionPropertyManager) EventListener(com.facebook.presto.spi.eventlistener.EventListener) Plan(com.facebook.presto.sql.planner.Plan) Type(com.facebook.presto.common.type.Type) InMemoryNodeManager(com.facebook.presto.metadata.InMemoryNodeManager) ExecutorService(java.util.concurrent.ExecutorService) SubPlan(com.facebook.presto.sql.planner.SubPlan) CreateViewTask(com.facebook.presto.execution.CreateViewTask) OutputFactory(com.facebook.presto.operator.OutputFactory) JoinFilterFunctionCompiler(com.facebook.presto.sql.gen.JoinFilterFunctionCompiler) CatalogManager(com.facebook.presto.metadata.CatalogManager) PlanNode(com.facebook.presto.spi.plan.PlanNode) Statement(com.facebook.presto.sql.tree.Statement) StartTransaction(com.facebook.presto.sql.tree.StartTransaction) StreamingSubPlan(com.facebook.presto.execution.scheduler.StreamingSubPlan) CreateTypeTask(com.facebook.presto.execution.CreateTypeTask) CreateMaterializedViewTask(com.facebook.presto.execution.CreateMaterializedViewTask) EventListenerManager(com.facebook.presto.eventlistener.EventListenerManager) CatalogSystemTable(com.facebook.presto.connector.system.CatalogSystemTable) NoOpFragmentResultCacheManager(com.facebook.presto.operator.NoOpFragmentResultCacheManager) FinalizerService(com.facebook.presto.util.FinalizerService) Executors.newScheduledThreadPool(java.util.concurrent.Executors.newScheduledThreadPool) QueryManagerConfig(com.facebook.presto.execution.QueryManagerConfig) ScalarStatsCalculator(com.facebook.presto.cost.ScalarStatsCalculator) ReadWriteLock(java.util.concurrent.locks.ReadWriteLock) Rollback(com.facebook.presto.sql.tree.Rollback) PageConsumerOutputFactory(com.facebook.presto.testing.PageConsumerOperator.PageConsumerOutputFactory) GenericPartitioningSpillerFactory(com.facebook.presto.spiller.GenericPartitioningSpillerFactory) Explain(com.facebook.presto.sql.tree.Explain) Set(java.util.Set) CreateType(com.facebook.presto.sql.tree.CreateType) JsonCodec.jsonCodec(com.facebook.airlift.json.JsonCodec.jsonCodec) FeaturesConfig(com.facebook.presto.sql.analyzer.FeaturesConfig) UncheckedIOException(java.io.UncheckedIOException) LocalExecutionPlan(com.facebook.presto.sql.planner.LocalExecutionPlanner.LocalExecutionPlan) TESTING_CATALOG(com.facebook.presto.testing.TestingSession.TESTING_CATALOG) DropMaterializedView(com.facebook.presto.sql.tree.DropMaterializedView) Analyzer(com.facebook.presto.sql.analyzer.Analyzer) NodeInfo(com.facebook.airlift.node.NodeInfo) ReentrantReadWriteLock(java.util.concurrent.locks.ReentrantReadWriteLock) CreateFunction(com.facebook.presto.sql.tree.CreateFunction) ArrayList(java.util.ArrayList) Closer(com.google.common.io.Closer) BlockEncodingManager(com.facebook.presto.common.block.BlockEncodingManager) RenameTable(com.facebook.presto.sql.tree.RenameTable) PageSorter(com.facebook.presto.spi.PageSorter) CommitTask(com.facebook.presto.execution.CommitTask) TaskContext(com.facebook.presto.operator.TaskContext) PlanNodeIdAllocator(com.facebook.presto.spi.plan.PlanNodeIdAllocator) Language(org.intellij.lang.annotations.Language) Driver(com.facebook.presto.operator.Driver) ConnectorFactory(com.facebook.presto.spi.connector.ConnectorFactory) Lock(java.util.concurrent.locks.Lock) AlterFunctionTask(com.facebook.presto.execution.AlterFunctionTask) TracingConfig(com.facebook.presto.tracing.TracingConfig) TestingSession.createBogusTestingCatalog(com.facebook.presto.testing.TestingSession.createBogusTestingCatalog) Paths(java.nio.file.Paths) TableScanNode(com.facebook.presto.spi.plan.TableScanNode) ResetSessionTask(com.facebook.presto.execution.ResetSessionTask) InMemoryTransactionManager(com.facebook.presto.transaction.InMemoryTransactionManager) DriverContext(com.facebook.presto.operator.DriverContext) PartitioningProviderManager(com.facebook.presto.sql.planner.PartitioningProviderManager) FunctionAndTypeManager(com.facebook.presto.metadata.FunctionAndTypeManager) PartitioningSpillerFactory(com.facebook.presto.spiller.PartitioningSpillerFactory) CostCalculatorWithEstimatedExchanges(com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges) TransactionsSystemTable(com.facebook.presto.connector.system.TransactionsSystemTable) NodeTaskMap(com.facebook.presto.execution.NodeTaskMap) MetadataManager(com.facebook.presto.metadata.MetadataManager) TestingMBeanServer(org.weakref.jmx.testing.TestingMBeanServer) REWINDABLE_GROUPED_SCHEDULING(com.facebook.presto.spi.connector.ConnectorSplitManager.SplitSchedulingStrategy.REWINDABLE_GROUPED_SCHEDULING) NodeScheduler(com.facebook.presto.execution.scheduler.NodeScheduler) FileSingleStreamSpillerFactory(com.facebook.presto.spiller.FileSingleStreamSpillerFactory) NoOpResourceGroupManager(com.facebook.presto.execution.resourceGroups.NoOpResourceGroupManager) PagesIndex(com.facebook.presto.operator.PagesIndex) TempStorageStandaloneSpillerFactory(com.facebook.presto.spiller.TempStorageStandaloneSpillerFactory) StatsCalculator(com.facebook.presto.cost.StatsCalculator) PageIndexerFactory(com.facebook.presto.spi.PageIndexerFactory) ColumnPropertiesSystemTable(com.facebook.presto.connector.system.ColumnPropertiesSystemTable) ConnectorMetadataUpdaterManager(com.facebook.presto.metadata.ConnectorMetadataUpdaterManager) DropFunctionTask(com.facebook.presto.execution.DropFunctionTask) FilterStatsCalculator(com.facebook.presto.cost.FilterStatsCalculator) SplitSource(com.facebook.presto.split.SplitSource) GROUPED_SCHEDULING(com.facebook.presto.spi.connector.ConnectorSplitManager.SplitSchedulingStrategy.GROUPED_SCHEDULING) Lifespan(com.facebook.presto.execution.Lifespan) NodeMemoryConfig(com.facebook.presto.memory.NodeMemoryConfig) NodeSystemTable(com.facebook.presto.connector.system.NodeSystemTable) ImmutableMap(com.google.common.collect.ImmutableMap) SchemaPropertyManager(com.facebook.presto.metadata.SchemaPropertyManager) String.format(java.lang.String.format) SqlParser(com.facebook.presto.sql.parser.SqlParser) Preconditions.checkState(com.google.common.base.Preconditions.checkState) Threads.daemonThreadsNamed(com.facebook.airlift.concurrent.Threads.daemonThreadsNamed) StartTransactionTask(com.facebook.presto.execution.StartTransactionTask) List(java.util.List) RenameColumn(com.facebook.presto.sql.tree.RenameColumn) SystemSessionProperties.isHeapDumpOnExceededMemoryLimitEnabled(com.facebook.presto.SystemSessionProperties.isHeapDumpOnExceededMemoryLimitEnabled) Analysis(com.facebook.presto.sql.analyzer.Analysis) Optional(java.util.Optional) PluginManager(com.facebook.presto.server.PluginManager) ConnectorId(com.facebook.presto.spi.ConnectorId) LogicalPlanner(com.facebook.presto.sql.planner.LogicalPlanner) CreateTableTask(com.facebook.presto.execution.CreateTableTask) NodeSchedulerConfig(com.facebook.presto.execution.scheduler.NodeSchedulerConfig) PlanNodeId(com.facebook.presto.spi.plan.PlanNodeId) SpillerStats(com.facebook.presto.spiller.SpillerStats) ParsingUtil.createParsingOptions(com.facebook.presto.sql.ParsingUtil.createParsingOptions) HashMap(java.util.HashMap) SchemaPropertiesSystemTable(com.facebook.presto.connector.system.SchemaPropertiesSystemTable) AtomicReference(java.util.concurrent.atomic.AtomicReference) NoOpQueryManager(com.facebook.presto.dispatcher.NoOpQueryManager) OrderingCompiler(com.facebook.presto.sql.gen.OrderingCompiler) Verify.verify(com.google.common.base.Verify.verify) Deallocate(com.facebook.presto.sql.tree.Deallocate) Objects.requireNonNull(java.util.Objects.requireNonNull) SystemSessionProperties.getQueryMaxTotalMemoryPerNode(com.facebook.presto.SystemSessionProperties.getQueryMaxTotalMemoryPerNode) SetSessionTask(com.facebook.presto.execution.SetSessionTask) MemoryManagerConfig(com.facebook.presto.memory.MemoryManagerConfig) RenameTableTask(com.facebook.presto.execution.RenameTableTask) PlanFragmenter(com.facebook.presto.sql.planner.PlanFragmenter) PlanNodeSearcher.searchFrom(com.facebook.presto.sql.planner.optimizations.PlanNodeSearcher.searchFrom) PagesIndexPageSorter(com.facebook.presto.PagesIndexPageSorter) DropFunction(com.facebook.presto.sql.tree.DropFunction) NodePartitioningManager(com.facebook.presto.sql.planner.NodePartitioningManager) TaskSource(com.facebook.presto.execution.TaskSource) ObjectMapper(com.fasterxml.jackson.databind.ObjectMapper) DeallocateTask(com.facebook.presto.execution.DeallocateTask) TablePropertiesSystemTable(com.facebook.presto.connector.system.TablePropertiesSystemTable) MetadataUtil(com.facebook.presto.metadata.MetadataUtil) SystemSessionProperties.isVerboseExceededMemoryLimitErrorsEnabled(com.facebook.presto.SystemSessionProperties.isVerboseExceededMemoryLimitErrorsEnabled) TimeUnit(java.util.concurrent.TimeUnit) Executors.newCachedThreadPool(java.util.concurrent.Executors.newCachedThreadPool) AlterFunction(com.facebook.presto.sql.tree.AlterFunction) CostComparator(com.facebook.presto.cost.CostComparator) GroupByHashPageIndexerFactory(com.facebook.presto.GroupByHashPageIndexerFactory) MBeanExporter(org.weakref.jmx.MBeanExporter) HandleResolver(com.facebook.presto.metadata.HandleResolver) JoinCompiler(com.facebook.presto.sql.gen.JoinCompiler) TaskContext(com.facebook.presto.operator.TaskContext) PageConsumerOutputFactory(com.facebook.presto.testing.PageConsumerOperator.PageConsumerOutputFactory) Driver(com.facebook.presto.operator.Driver) AtomicReference(java.util.concurrent.atomic.AtomicReference) UncheckedIOException(java.io.UncheckedIOException) IOException(java.io.IOException) UncheckedIOException(java.io.UncheckedIOException) Plan(com.facebook.presto.sql.planner.Plan) SubPlan(com.facebook.presto.sql.planner.SubPlan) StreamingSubPlan(com.facebook.presto.execution.scheduler.StreamingSubPlan) LocalExecutionPlan(com.facebook.presto.sql.planner.LocalExecutionPlanner.LocalExecutionPlan) OperatorContext(com.facebook.presto.operator.OperatorContext)

Example 13 with OperatorContext

use of com.facebook.presto.operator.OperatorContext in project presto by prestodb.

the class TestQueryContext method testMoveTaggedAllocations.

@Test
public void testMoveTaggedAllocations() {
    MemoryPool generalPool = new MemoryPool(GENERAL_POOL, new DataSize(10_000, BYTE));
    MemoryPool reservedPool = new MemoryPool(RESERVED_POOL, new DataSize(10_000, BYTE));
    QueryId queryId = new QueryId("query");
    QueryContext queryContext = createQueryContext(queryId, generalPool);
    TaskStateMachine taskStateMachine = new TaskStateMachine(TaskId.valueOf("queryid.0.0.0"), TEST_EXECUTOR);
    TaskContext taskContext = queryContext.addTaskContext(taskStateMachine, TEST_SESSION, Optional.of(PLAN_FRAGMENT.getRoot()), false, false, false, false, false);
    DriverContext driverContext = taskContext.addPipelineContext(0, false, false, false).addDriverContext();
    OperatorContext operatorContext = driverContext.addOperatorContext(0, new PlanNodeId("test"), "test");
    // allocate some memory in the general pool
    LocalMemoryContext memoryContext = operatorContext.aggregateUserMemoryContext().newLocalMemoryContext("test_context");
    memoryContext.setBytes(1_000);
    Map<String, Long> allocations = generalPool.getTaggedMemoryAllocations(queryId);
    assertEquals(allocations, ImmutableMap.of("test_context", 1_000L));
    queryContext.setMemoryPool(reservedPool);
    assertNull(generalPool.getTaggedMemoryAllocations(queryId));
    allocations = reservedPool.getTaggedMemoryAllocations(queryId);
    assertEquals(allocations, ImmutableMap.of("test_context", 1_000L));
    assertEquals(generalPool.getFreeBytes(), 10_000);
    assertEquals(reservedPool.getFreeBytes(), 9_000);
    memoryContext.close();
    assertEquals(generalPool.getFreeBytes(), 10_000);
    assertEquals(reservedPool.getFreeBytes(), 10_000);
}
Also used : DriverContext(com.facebook.presto.operator.DriverContext) LocalMemoryContext(com.facebook.presto.memory.context.LocalMemoryContext) TaskContext(com.facebook.presto.operator.TaskContext) QueryId(com.facebook.presto.spi.QueryId) TaskStateMachine(com.facebook.presto.execution.TaskStateMachine) PlanNodeId(com.facebook.presto.spi.plan.PlanNodeId) DataSize(io.airlift.units.DataSize) OperatorContext(com.facebook.presto.operator.OperatorContext) Test(org.testng.annotations.Test)

Example 14 with OperatorContext

use of com.facebook.presto.operator.OperatorContext in project presto by prestodb.

the class TestOptimizedPartitionedOutputOperator method verifyOutputSizes.

private static void verifyOutputSizes(OptimizedPartitionedOutputOperator operator, long expectedSizeInBytes, long expectedPositionCount) {
    OperatorContext operatorContext = operator.getOperatorContext();
    assertBetweenInclusive(operatorContext.getOutputDataSize().getTotalCount(), (long) (expectedSizeInBytes / OUTPUT_SIZE_ESTIMATION_ERROR_ALLOWANCE), (long) (expectedSizeInBytes * OUTPUT_SIZE_ESTIMATION_ERROR_ALLOWANCE));
    assertEquals(operatorContext.getOutputPositions().getTotalCount(), expectedPositionCount);
}
Also used : OperatorContext(com.facebook.presto.operator.OperatorContext)

Aggregations

OperatorContext (com.facebook.presto.operator.OperatorContext)14 TaskContext (com.facebook.presto.operator.TaskContext)10 DriverContext (com.facebook.presto.operator.DriverContext)7 QueryId (com.facebook.presto.spi.QueryId)6 PlanNodeId (com.facebook.presto.spi.plan.PlanNodeId)6 ImmutableList (com.google.common.collect.ImmutableList)5 AtomicLong (java.util.concurrent.atomic.AtomicLong)5 Test (org.testng.annotations.Test)5 DataSize (io.airlift.units.DataSize)4 List (java.util.List)4 Session (com.facebook.presto.Session)3 MemoryPool (com.facebook.presto.memory.MemoryPool)3 QueryContext (com.facebook.presto.memory.QueryContext)3 LocalMemoryContext (com.facebook.presto.memory.context.LocalMemoryContext)3 Split (com.facebook.presto.metadata.Split)3 TestingGcMonitor (com.facebook.airlift.stats.TestingGcMonitor)2 QualifiedObjectName (com.facebook.presto.common.QualifiedObjectName)2 SqlTask.createSqlTask (com.facebook.presto.execution.SqlTask.createSqlTask)2 Metadata (com.facebook.presto.metadata.Metadata)2 PipelineContext (com.facebook.presto.operator.PipelineContext)2