use of com.hazelcast.jet.impl.execution.init.Contexts.ProcCtx in project hazelcast-jet by hazelcast.
the class ProcessorTaskletTest_Blocking method setUp.
@Before
public void setUp() {
this.processor = new PassThroughProcessor();
this.context = new ProcCtx(null, new DefaultSerializationServiceBuilder().build(), null, null, 0, NONE, 1, 1);
this.mockInput = IntStream.range(0, MOCK_INPUT_SIZE).boxed().collect(toList());
this.instreams = new ArrayList<>();
this.outstreams = new ArrayList<>();
}
use of com.hazelcast.jet.impl.execution.init.Contexts.ProcCtx in project hazelcast-jet by hazelcast.
the class ProcessorTaskletTest_Snapshots method setUp.
@Before
public void setUp() {
this.mockInput = IntStream.range(0, MOCK_INPUT_SIZE).boxed().collect(toList());
this.processor = new SnapshottableProcessor();
this.context = new ProcCtx(null, new DefaultSerializationServiceBuilder().build(), null, null, 0, EXACTLY_ONCE, 1, 1);
this.instreams = new ArrayList<>();
this.outstreams = new ArrayList<>();
this.snapshotCollector = new MockOutboundCollector(1024);
}
use of com.hazelcast.jet.impl.execution.init.Contexts.ProcCtx in project hazelcast-jet by hazelcast.
the class ProcessorTaskletTest_Watermarks method setUp.
@Before
public void setUp() {
this.processor = new ProcessorWithWatermarks();
this.context = new ProcCtx(null, new DefaultSerializationServiceBuilder().build(), null, null, 0, EXACTLY_ONCE, 1, 1);
this.instreams = new ArrayList<>();
this.outstreams = new ArrayList<>();
this.snapshotCollector = new MockOutboundCollector(0);
}
use of com.hazelcast.jet.impl.execution.init.Contexts.ProcCtx in project hazelcast-jet by hazelcast.
the class PeekWrappedP method init.
@Override
public void init(@Nonnull Outbox outbox, @Nonnull Context context) {
logger = context.logger();
outbox = new LoggingOutbox(outbox, peekOutput, peekSnapshot);
// and also other objects could be mocked or null, such as jetInstance())
if (context instanceof ProcCtx) {
ProcCtx c = (ProcCtx) context;
NodeEngine nodeEngine = ((HazelcastInstanceImpl) c.jetInstance().getHazelcastInstance()).node.nodeEngine;
ILogger newLogger = nodeEngine.getLogger(createLoggerName(wrapped.getClass().getName(), c.vertexName(), c.globalProcessorIndex()));
context = new ProcCtx(c.jetInstance(), c.getSerializationService(), newLogger, c.vertexName(), c.globalProcessorIndex(), c.processingGuarantee(), c.localParallelism(), c.totalParallelism());
}
super.init(outbox, context);
}
use of com.hazelcast.jet.impl.execution.init.Contexts.ProcCtx in project hazelcast by hazelcast.
the class ExecutionPlan method initialize.
/**
* A method called on the members as part of the InitExecutionOperation.
* Creates tasklets, inboxes/outboxes and connects these to make them ready
* for a later StartExecutionOperation.
*/
public void initialize(NodeEngineImpl nodeEngine, long jobId, long executionId, @Nonnull SnapshotContext snapshotContext, ConcurrentHashMap<String, File> tempDirectories, InternalSerializationService jobSerializationService) {
this.nodeEngine = nodeEngine;
this.jobClassLoaderService = ((JetServiceBackend) nodeEngine.getService(JetServiceBackend.SERVICE_NAME)).getJobClassLoaderService();
this.executionId = executionId;
initProcSuppliers(jobId, tempDirectories, jobSerializationService);
initDag(jobSerializationService);
this.ptionArrgmt = new PartitionArrangement(partitionAssignment, nodeEngine.getThisAddress());
Set<Integer> higherPriorityVertices = VertexDef.getHigherPriorityVertices(vertices);
for (Address destAddr : remoteMembers.get()) {
Connection conn = getMemberConnection(nodeEngine, destAddr);
if (conn == null) {
throw new TopologyChangedException("no connection to job participant: " + destAddr);
}
memberConnections.put(destAddr, conn);
}
for (VertexDef vertex : vertices) {
ClassLoader processorClassLoader = isLightJob ? null : jobClassLoaderService.getProcessorClassLoader(jobId, vertex.name());
Collection<? extends Processor> processors = doWithClassLoader(processorClassLoader, () -> createProcessors(vertex, vertex.localParallelism()));
String jobPrefix = prefix(jobConfig.getName(), jobId, vertex.name());
// create StoreSnapshotTasklet and the queues to it
ConcurrentConveyor<Object> ssConveyor = null;
if (!isLightJob) {
// Note that we create the snapshot queues for all non-light jobs, even if they don't have
// processing guarantee enabled, because in EE one can request a snapshot also for
// non-snapshotted jobs.
@SuppressWarnings("unchecked") QueuedPipe<Object>[] snapshotQueues = new QueuedPipe[vertex.localParallelism()];
Arrays.setAll(snapshotQueues, i -> new OneToOneConcurrentArrayQueue<>(SNAPSHOT_QUEUE_SIZE));
ssConveyor = ConcurrentConveyor.concurrentConveyor(null, snapshotQueues);
ILogger storeSnapshotLogger = prefixedLogger(nodeEngine.getLogger(StoreSnapshotTasklet.class), jobPrefix);
StoreSnapshotTasklet ssTasklet = new StoreSnapshotTasklet(snapshotContext, ConcurrentInboundEdgeStream.create(ssConveyor, 0, 0, true, jobPrefix + "/ssFrom", null), new AsyncSnapshotWriterImpl(nodeEngine, snapshotContext, vertex.name(), memberIndex, memberCount, jobSerializationService), storeSnapshotLogger, vertex.name(), higherPriorityVertices.contains(vertex.vertexId()));
tasklets.add(ssTasklet);
}
int localProcessorIdx = 0;
for (Processor processor : processors) {
int globalProcessorIndex = memberIndex * vertex.localParallelism() + localProcessorIdx;
String processorPrefix = prefix(jobConfig.getName(), jobId, vertex.name(), globalProcessorIndex);
ILogger logger = prefixedLogger(nodeEngine.getLogger(processor.getClass()), processorPrefix);
ProcCtx context = new ProcCtx(nodeEngine, jobId, executionId, getJobConfig(), logger, vertex.name(), localProcessorIdx, globalProcessorIndex, isLightJob, partitionAssignment, vertex.localParallelism(), memberIndex, memberCount, tempDirectories, jobSerializationService, subject, processorClassLoader);
// createOutboundEdgeStreams() populates localConveyorMap and edgeSenderConveyorMap.
// Also populates instance fields: senderMap, receiverMap, tasklets.
List<OutboundEdgeStream> outboundStreams = createOutboundEdgeStreams(vertex, localProcessorIdx, jobPrefix, jobSerializationService);
List<InboundEdgeStream> inboundStreams = createInboundEdgeStreams(vertex, localProcessorIdx, jobPrefix, globalProcessorIndex);
OutboundCollector snapshotCollector = ssConveyor == null ? null : new ConveyorCollector(ssConveyor, localProcessorIdx, null);
// vertices which are only used for snapshot restore will not be marked as "source=true" in metrics
// also do not consider snapshot restore edges for determining source tag
boolean isSource = vertex.inboundEdges().stream().allMatch(EdgeDef::isSnapshotRestoreEdge) && !vertex.isSnapshotVertex();
ProcessorTasklet processorTasklet = new ProcessorTasklet(context, nodeEngine.getExecutionService().getExecutor(TASKLET_INIT_CLOSE_EXECUTOR_NAME), jobSerializationService, processor, inboundStreams, outboundStreams, snapshotContext, snapshotCollector, isSource);
tasklets.add(processorTasklet);
this.processors.add(processor);
localProcessorIdx++;
}
}
List<ReceiverTasklet> allReceivers = receiverMap.values().stream().flatMap(o -> o.values().stream()).flatMap(a -> a.values().stream()).collect(toList());
tasklets.addAll(allReceivers);
}
Aggregations