Search in sources :

Example 1 with SelectAllFilter

use of io.prestosql.operator.project.TestPageProcessor.SelectAllFilter in project hetu-core by openlookeng.

the class TestScanFilterAndProjectOperator method testPageSourceLazyLoad.

@Test
public void testPageSourceLazyLoad() {
    Block inputBlock = BlockAssertions.createLongSequenceBlock(0, 100);
    // If column 1 is loaded, test will fail
    Page input = new Page(100, inputBlock, new LazyBlock(100, lazyBlock -> {
        throw new AssertionError("Lazy block should not be loaded");
    }));
    DriverContext driverContext = newDriverContext();
    List<RowExpression> projections = ImmutableList.of(field(0, VARCHAR));
    Supplier<CursorProcessor> cursorProcessor = expressionCompiler.compileCursorProcessor(Optional.empty(), projections, "key");
    PageProcessor pageProcessor = new PageProcessor(Optional.of(new SelectAllFilter()), ImmutableList.of(new LazyPagePageProjection()));
    ScanFilterAndProjectOperator.ScanFilterAndProjectOperatorFactory factory = new ScanFilterAndProjectOperator.ScanFilterAndProjectOperatorFactory(0, new PlanNodeId("test"), new PlanNodeId("0"), (session, split, table, columns, dynamicFilter) -> new SinglePagePageSource(input), cursorProcessor, () -> pageProcessor, TEST_TABLE_HANDLE, ImmutableList.of(), null, ImmutableList.of(BIGINT), new DataSize(0, BYTE), 0, ReuseExchangeOperator.STRATEGY.REUSE_STRATEGY_DEFAULT, new UUID(0, 0), false, Optional.empty(), 0, 0);
    SourceOperator operator = factory.createOperator(driverContext);
    operator.addSplit(new Split(new CatalogName("test"), TestingSplit.createLocalSplit(), Lifespan.taskWide()));
    operator.noMoreSplits();
    MaterializedResult expected = toMaterializedResult(driverContext.getSession(), ImmutableList.of(BIGINT), ImmutableList.of(new Page(inputBlock)));
    MaterializedResult actual = toMaterializedResult(driverContext.getSession(), ImmutableList.of(BIGINT), toPages(operator));
    assertEquals(actual.getRowCount(), expected.getRowCount());
    assertEquals(actual, expected);
}
Also used : BuiltInFunctionHandle(io.prestosql.spi.function.BuiltInFunctionHandle) Test(org.testng.annotations.Test) AbstractTestFunctions(io.prestosql.operator.scalar.AbstractTestFunctions) MaterializedResult(io.prestosql.testing.MaterializedResult) BlockAssertions.toValues(io.prestosql.block.BlockAssertions.toValues) TEST_TABLE_HANDLE(io.prestosql.testing.TestingHandles.TEST_TABLE_HANDLE) MAX_BATCH_SIZE(io.prestosql.operator.project.PageProcessor.MAX_BATCH_SIZE) Assert.assertEquals(io.prestosql.testing.assertions.Assert.assertEquals) Expressions.call(io.prestosql.sql.relational.Expressions.call) Executors.newScheduledThreadPool(java.util.concurrent.Executors.newScheduledThreadPool) PageFunctionCompiler(io.prestosql.sql.gen.PageFunctionCompiler) BOOLEAN(io.prestosql.spi.type.BooleanType.BOOLEAN) KILOBYTE(io.airlift.units.DataSize.Unit.KILOBYTE) Method(java.lang.reflect.Method) BIGINT(io.prestosql.spi.type.BigintType.BIGINT) PlanNodeId(io.prestosql.spi.plan.PlanNodeId) EQUAL(io.prestosql.spi.function.OperatorType.EQUAL) LazyPagePageProjection(io.prestosql.operator.project.TestPageProcessor.LazyPagePageProjection) SqlScalarFunction(io.prestosql.metadata.SqlScalarFunction) MetadataManager.createTestMetadataManager(io.prestosql.metadata.MetadataManager.createTestMetadataManager) LazyBlock(io.prestosql.spi.block.LazyBlock) RowPagesBuilder.rowPagesBuilder(io.prestosql.RowPagesBuilder.rowPagesBuilder) CatalogName(io.prestosql.spi.connector.CatalogName) UUID(java.util.UUID) Assert.assertNotNull(org.testng.Assert.assertNotNull) Metadata(io.prestosql.metadata.Metadata) InvocationTargetException(java.lang.reflect.InvocationTargetException) DataSize(io.airlift.units.DataSize) PageProcessor(io.prestosql.operator.project.PageProcessor) ReuseExchangeOperator(io.prestosql.spi.operator.ReuseExchangeOperator) List(java.util.List) ConnectorPageSource(io.prestosql.spi.connector.ConnectorPageSource) SelectAllFilter(io.prestosql.operator.project.TestPageProcessor.SelectAllFilter) TestingTaskContext.createTaskContext(io.prestosql.testing.TestingTaskContext.createTaskContext) Optional(java.util.Optional) TEST_SESSION(io.prestosql.SessionTestUtils.TEST_SESSION) Assert.assertNull(org.testng.Assert.assertNull) FixedPageSource(io.prestosql.spi.connector.FixedPageSource) PageRecordSet(io.prestosql.operator.index.PageRecordSet) ExpressionCompiler(io.prestosql.sql.gen.ExpressionCompiler) OperatorAssertion.toMaterializedResult(io.prestosql.operator.OperatorAssertion.toMaterializedResult) Split(io.prestosql.metadata.Split) Supplier(java.util.function.Supplier) QualifiedObjectName(io.prestosql.spi.connector.QualifiedObjectName) ArrayList(java.util.ArrayList) VARCHAR(io.prestosql.spi.type.VarcharType.VARCHAR) ImmutableList(com.google.common.collect.ImmutableList) TestingSplit(io.prestosql.testing.TestingSplit) BlockAssertions(io.prestosql.block.BlockAssertions) Threads.daemonThreadsNamed(io.airlift.concurrent.Threads.daemonThreadsNamed) ScheduledExecutorService(java.util.concurrent.ScheduledExecutorService) Signature(io.prestosql.spi.function.Signature) Block(io.prestosql.spi.block.Block) ExecutorService(java.util.concurrent.ExecutorService) SequencePageBuilder(io.prestosql.SequencePageBuilder) Lifespan(io.prestosql.execution.Lifespan) Expressions.constant(io.prestosql.sql.relational.Expressions.constant) Page(io.prestosql.spi.Page) Signature.internalScalarFunction(io.prestosql.spi.function.Signature.internalScalarFunction) Executors.newCachedThreadPool(java.util.concurrent.Executors.newCachedThreadPool) Expressions.field(io.prestosql.sql.relational.Expressions.field) RowExpression(io.prestosql.spi.relation.RowExpression) Assert.assertTrue(org.testng.Assert.assertTrue) RecordPageSource(io.prestosql.spi.connector.RecordPageSource) BYTE(io.airlift.units.DataSize.Unit.BYTE) SECONDS(java.util.concurrent.TimeUnit.SECONDS) CursorProcessor(io.prestosql.operator.project.CursorProcessor) PageAssertions.assertPageEquals(io.prestosql.operator.PageAssertions.assertPageEquals) CursorProcessor(io.prestosql.operator.project.CursorProcessor) RowExpression(io.prestosql.spi.relation.RowExpression) Page(io.prestosql.spi.Page) PlanNodeId(io.prestosql.spi.plan.PlanNodeId) LazyBlock(io.prestosql.spi.block.LazyBlock) PageProcessor(io.prestosql.operator.project.PageProcessor) LazyPagePageProjection(io.prestosql.operator.project.TestPageProcessor.LazyPagePageProjection) DataSize(io.airlift.units.DataSize) LazyBlock(io.prestosql.spi.block.LazyBlock) Block(io.prestosql.spi.block.Block) SelectAllFilter(io.prestosql.operator.project.TestPageProcessor.SelectAllFilter) CatalogName(io.prestosql.spi.connector.CatalogName) UUID(java.util.UUID) Split(io.prestosql.metadata.Split) TestingSplit(io.prestosql.testing.TestingSplit) MaterializedResult(io.prestosql.testing.MaterializedResult) OperatorAssertion.toMaterializedResult(io.prestosql.operator.OperatorAssertion.toMaterializedResult) Test(org.testng.annotations.Test)

Aggregations

ImmutableList (com.google.common.collect.ImmutableList)1 Threads.daemonThreadsNamed (io.airlift.concurrent.Threads.daemonThreadsNamed)1 DataSize (io.airlift.units.DataSize)1 BYTE (io.airlift.units.DataSize.Unit.BYTE)1 KILOBYTE (io.airlift.units.DataSize.Unit.KILOBYTE)1 RowPagesBuilder.rowPagesBuilder (io.prestosql.RowPagesBuilder.rowPagesBuilder)1 SequencePageBuilder (io.prestosql.SequencePageBuilder)1 TEST_SESSION (io.prestosql.SessionTestUtils.TEST_SESSION)1 BlockAssertions (io.prestosql.block.BlockAssertions)1 BlockAssertions.toValues (io.prestosql.block.BlockAssertions.toValues)1 Lifespan (io.prestosql.execution.Lifespan)1 Metadata (io.prestosql.metadata.Metadata)1 MetadataManager.createTestMetadataManager (io.prestosql.metadata.MetadataManager.createTestMetadataManager)1 Split (io.prestosql.metadata.Split)1 SqlScalarFunction (io.prestosql.metadata.SqlScalarFunction)1 OperatorAssertion.toMaterializedResult (io.prestosql.operator.OperatorAssertion.toMaterializedResult)1 PageAssertions.assertPageEquals (io.prestosql.operator.PageAssertions.assertPageEquals)1 PageRecordSet (io.prestosql.operator.index.PageRecordSet)1 CursorProcessor (io.prestosql.operator.project.CursorProcessor)1 PageProcessor (io.prestosql.operator.project.PageProcessor)1