// intermediate
AbstractJobVertex intermediate = createIterationIntermediate(jobGraph, numSubTasks, serializer, comparator);
TaskConfig intermediateConfig = new TaskConfig(intermediate.getConfiguration());
// output and auxiliaries
OutputFormatVertex output = createOutput(jobGraph, resultPath, numSubTasks, serializer);
AbstractJobVertex sync = createSync(jobGraph, numSubTasks, maxIterations);
// ------------------ the intermediate (ss join) ----------------------
AbstractJobVertex ssJoinIntermediate = JobGraphUtils.createTask(IterationIntermediatePactTask.class,
"Solution Set Join", jobGraph, numSubTasks);
TaskConfig ssJoinIntermediateConfig = new TaskConfig(ssJoinIntermediate.getConfiguration());
{
ssJoinIntermediateConfig.setIterationId(ITERATION_ID);
// inputs
ssJoinIntermediateConfig.addInputToGroup(0);
ssJoinIntermediateConfig.setInputSerializer(serializer, 0);
// output
ssJoinIntermediateConfig.addOutputShipStrategy(ShipStrategyType.FORWARD);
ssJoinIntermediateConfig.addOutputShipStrategy(ShipStrategyType.FORWARD);
ssJoinIntermediateConfig.setOutputComparator(comparator, 0);
ssJoinIntermediateConfig.setOutputComparator(comparator, 1);
ssJoinIntermediateConfig.setOutputSerializer(serializer);
// driver
ssJoinIntermediateConfig.setDriver(JoinWithSolutionSetSecondDriver.class);
ssJoinIntermediateConfig.setDriverStrategy(DriverStrategy.HYBRIDHASH_BUILD_SECOND);
ssJoinIntermediateConfig.setDriverComparator(comparator, 0);
ssJoinIntermediateConfig.setDriverPairComparator(pairComparator);
ssJoinIntermediateConfig.setStubWrapper(
new UserCodeClassWrapper<UpdateComponentIdMatch>(UpdateComponentIdMatch.class));
}
// -------------------------- ss tail --------------------------------
AbstractJobVertex ssTail = JobGraphUtils.createTask(IterationTailPactTask.class, "IterationSolutionSetTail",
jobGraph, numSubTasks);
TaskConfig ssTailConfig = new TaskConfig(ssTail.getConfiguration());
{
ssTailConfig.setIterationId(ITERATION_ID);
ssTailConfig.setIsSolutionSetUpdate();
ssTailConfig.setIsWorksetIteration();
// inputs and driver
ssTailConfig.addInputToGroup(0);
ssTailConfig.setInputSerializer(serializer, 0);
ssTailConfig.setInputAsynchronouslyMaterialized(0, true);
ssTailConfig.setRelativeInputMaterializationMemory(0, MEM_FRAC_PER_CONSUMER);
// output
ssTailConfig.setOutputSerializer(serializer);
// the driver
ssTailConfig.setDriver(CollectorMapDriver.class);
ssTailConfig.setDriverStrategy(DriverStrategy.COLLECTOR_MAP);
ssTailConfig.setStubWrapper(new UserCodeClassWrapper<DummyMapper>(DummyMapper.class));
}
// -------------------------- ws tail --------------------------------
AbstractJobVertex wsTail = JobGraphUtils.createTask(IterationTailPactTask.class, "IterationWorksetTail",
jobGraph, numSubTasks);
TaskConfig wsTailConfig = new TaskConfig(wsTail.getConfiguration());
{
wsTailConfig.setIterationId(ITERATION_ID);
wsTailConfig.setIsWorksetIteration();
wsTailConfig.setIsWorksetUpdate();
// inputs and driver
wsTailConfig.addInputToGroup(0);
wsTailConfig.setInputSerializer(serializer, 0);
// output
wsTailConfig.setOutputSerializer(serializer);
// the driver
wsTailConfig.setDriver(CollectorMapDriver.class);
wsTailConfig.setDriverStrategy(DriverStrategy.COLLECTOR_MAP);
wsTailConfig.setStubWrapper(new UserCodeClassWrapper<DummyMapper>(DummyMapper.class));
}
// --------------- the wiring ---------------------
JobGraphUtils.connect(vertices, head, ChannelType.NETWORK, DistributionPattern.BIPARTITE);
JobGraphUtils.connect(edges, head, ChannelType.NETWORK, DistributionPattern.BIPARTITE);
JobGraphUtils.connect(vertices, head, ChannelType.NETWORK, DistributionPattern.BIPARTITE);
JobGraphUtils.connect(head, intermediate, ChannelType.NETWORK, DistributionPattern.BIPARTITE);
intermediateConfig.setGateIterativeWithNumberOfEventsUntilInterrupt(0, numSubTasks);
JobGraphUtils.connect(intermediate, ssJoinIntermediate, ChannelType.NETWORK, DistributionPattern.POINTWISE);
ssJoinIntermediateConfig.setGateIterativeWithNumberOfEventsUntilInterrupt(0, 1);
JobGraphUtils.connect(ssJoinIntermediate, ssTail, ChannelType.IN_MEMORY, DistributionPattern.POINTWISE);
ssTailConfig.setGateIterativeWithNumberOfEventsUntilInterrupt(0, 1);
JobGraphUtils.connect(ssJoinIntermediate, wsTail, ChannelType.IN_MEMORY, DistributionPattern.POINTWISE);
wsTailConfig.setGateIterativeWithNumberOfEventsUntilInterrupt(0, 1);
JobGraphUtils.connect(head, output, ChannelType.IN_MEMORY, DistributionPattern.POINTWISE);
JobGraphUtils.connect(head, sync, ChannelType.NETWORK, DistributionPattern.POINTWISE);
SlotSharingGroup sharingGroup = new SlotSharingGroup();
vertices.setSlotSharingGroup(sharingGroup);
edges.setSlotSharingGroup(sharingGroup);
head.setSlotSharingGroup(sharingGroup);
intermediate.setSlotSharingGroup(sharingGroup);
ssJoinIntermediate.setSlotSharingGroup(sharingGroup);
wsTail.setSlotSharingGroup(sharingGroup);
ssTail.setSlotSharingGroup(sharingGroup);
output.setSlotSharingGroup(sharingGroup);
sync.setSlotSharingGroup(sharingGroup);
intermediate.setStrictlyCoLocatedWith(head);
ssJoinIntermediate.setStrictlyCoLocatedWith(head);
wsTail.setStrictlyCoLocatedWith(head);