Examples of PipelineContext


Examples of com.facebook.presto.operator.PipelineContext

            for (DriverFactory driverFactory : driverFactories) {
                if (driverFactory.getSourceIds().contains(fragment.getPartitionedSource())) {
                    partitionedDriverFactory = driverFactory;
                }
                else {
                    PipelineContext pipelineContext = taskContext.addPipelineContext(driverFactory.isInputDriver(), driverFactory.isOutputDriver());
                    Driver driver = driverFactory.createDriver(pipelineContext.addDriverContext());
                    unpartitionedDrivers.add(driver);
                }
            }
            this.unpartitionedDrivers = ImmutableList.copyOf(unpartitionedDrivers);
View Full Code Here

Examples of com.facebook.presto.operator.PipelineContext

            for (DriverFactory driverFactory : driverFactories) {
                if (driverFactory.getSourceIds().contains(fragment.getPartitionedSource())) {
                    partitionedDriverFactory = driverFactory;
                }
                else {
                    PipelineContext pipelineContext = taskContext.addPipelineContext(driverFactory.isInputDriver(), driverFactory.isOutputDriver());
                    Driver driver = driverFactory.createDriver(pipelineContext.addDriverContext());
                    unpartitionedDrivers.add(driver);
                    unpartitionedDriverFactories.add(driverFactory);
                }
            }
            this.unpartitionedDrivers = ImmutableList.copyOf(unpartitionedDrivers);
View Full Code Here

Examples of com.facebook.presto.operator.PipelineContext

    private synchronized void batchLoadRequests(List<UpdateRequest> requests)
    {
        if (indexSnapshotBuilder == null) {
            TaskContext taskContext = taskContextReference.get();
            checkState(taskContext != null, "Task context must be set before index can be built");
            PipelineContext pipelineContext = taskContext.addPipelineContext(false, false);
            indexSnapshotBuilder = new IndexSnapshotBuilder(
                    driverFactory,
                    pipelineContext,
                    sourcePlanNodeId,
                    pagesIndexOutput,
View Full Code Here

Examples of com.facebook.presto.operator.PipelineContext

    private synchronized void batchLoadRequests(List<UpdateRequest> requests)
    {
        if (indexSnapshotBuilder == null) {
            TaskContext taskContext = taskContextReference.get();
            checkState(taskContext != null, "Task context must be set before index can be built");
            PipelineContext pipelineContext = taskContext.addPipelineContext(false, false);
            indexSnapshotBuilder = new IndexSnapshotBuilder(
                    driverFactory,
                    pipelineContext,
                    sourcePlanNodeId,
                    pagesIndexOutput,
View Full Code Here

Examples of com.facebook.presto.operator.PipelineContext

    private synchronized void batchLoadRequests(List<UpdateRequest> requests)
    {
        if (indexSnapshotBuilder == null) {
            TaskContext taskContext = taskContextReference.get();
            checkState(taskContext != null, "Task context must be set before index can be built");
            PipelineContext pipelineContext = taskContext.addPipelineContext(false, false);
            indexSnapshotBuilder = new IndexSnapshotBuilder(
                    driverFactory,
                    pipelineContext,
                    sourcePlanNodeId,
                    pagesIndexOutput,
View Full Code Here

Examples of com.facebook.presto.operator.PipelineContext

            for (DriverFactory driverFactory : driverFactories) {
                if (driverFactory.getSourceIds().contains(fragment.getPartitionedSource())) {
                    partitionedDriverFactory = driverFactory;
                }
                else {
                    PipelineContext pipelineContext = taskContext.addPipelineContext(driverFactory.isInputDriver(), driverFactory.isOutputDriver());
                    Driver driver = driverFactory.createDriver(pipelineContext.addDriverContext());
                    unpartitionedDrivers.add(driver);
                }
            }
            this.unpartitionedDrivers = ImmutableList.copyOf(unpartitionedDrivers);
View Full Code Here

Examples of com.facebook.presto.operator.PipelineContext

    private synchronized void initializeIndexSnapshotLoaderIfNecessary()
    {
        if (indexSnapshotLoader == null) {
            TaskContext taskContext = taskContextReference.get();
            checkState(taskContext != null, "Task context must be set before index can be built");
            PipelineContext pipelineContext = taskContext.addPipelineContext(false, false);
            indexSnapshotLoader = new IndexSnapshotLoader(
                    driverFactory,
                    pipelineContext,
                    sourcePlanNodeId,
                    pagesIndexOutput,
View Full Code Here

Examples of com.facebook.presto.operator.PipelineContext

            for (DriverFactory driverFactory : driverFactories) {
                if (driverFactory.getSourceIds().contains(fragment.getPartitionedSource())) {
                    partitionedDriverFactory = driverFactory;
                }
                else {
                    PipelineContext pipelineContext = taskContext.addPipelineContext(driverFactory.isInputDriver(), driverFactory.isOutputDriver());
                    Driver driver = driverFactory.createDriver(pipelineContext.addDriverContext());
                    unpartitionedDrivers.add(driver);
                }
            }
            this.unpartitionedDrivers = ImmutableList.copyOf(unpartitionedDrivers);
View Full Code Here

Examples of org.geomajas.service.pipeline.PipelineContext

  @Test
  public void testPipeline() throws Exception {
    StringAttribute response = new StringAttribute("bla");

    PipelineContext context = pipelineService.createContext();
    context.put("start", "start");
    pipelineService.execute("pipelineTest", null, context, response);
    Assert.assertEquals("starts1s2s3", response.getValue());

    context.put("start", "bla-");
    pipelineService.execute("pipelineTest", "aLayer", context, response);
    Assert.assertEquals("bla-step-1step-3", response.getValue());

    context.put("start", "stop-");
    pipelineService.execute("pipelineTest", "stop", context, response);
    Assert.assertEquals("stop-s1-STOP", response.getValue());
  }
View Full Code Here

Examples of org.geomajas.service.pipeline.PipelineContext

    pipelineInfo = pipelineService.getPipeline("pipelineTest", "delegate");
    Assert.assertNotNull(pipelineInfo);

    StringAttribute response = new StringAttribute("bla");
    PipelineContext context = pipelineService.createContext();
    context.put("start", "stop-");
    pipelineService.execute(pipelineInfo, context, response);
    Assert.assertEquals("stop-s1-STOP", response.getValue());
  }
View Full Code Here
TOP
Copyright © 2018 www.massapi.com. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.