Search in sources :

Example 1 with SerializationServiceAware

use of com.hazelcast.internal.serialization.SerializationServiceAware in project hazelcast by hazelcast.

the class TestSupport method initProcessor.

private void initProcessor(Processor processor, TestOutbox outbox) {
    SerializationService serializationService;
    if (hazelcastInstance != null && hazelcastInstance instanceof SerializationServiceSupport) {
        SerializationServiceSupport impl = (SerializationServiceSupport) hazelcastInstance;
        serializationService = impl.getSerializationService();
    } else {
        serializationService = new DefaultSerializationServiceBuilder().setManagedContext(e -> e).build();
    }
    TestProcessorContext context = new TestProcessorContext().setLogger(getLogger(processor.getClass().getName())).setManagedContext(serializationService.getManagedContext()).setLocalProcessorIndex(localProcessorIndex).setGlobalProcessorIndex(globalProcessorIndex).setLocalParallelism(localParallelism).setTotalParallelism(totalParallelism);
    if (hazelcastInstance != null) {
        context.setHazelcastInstance(hazelcastInstance);
    }
    if (jobConfig != null) {
        context.setJobConfig(jobConfig);
    }
    if (processor instanceof SerializationServiceAware) {
        ((SerializationServiceAware) processor).setSerializationService(serializationService);
    }
    try {
        processor.init(outbox, context);
    } catch (Exception e) {
        throw sneakyThrow(e);
    }
}
Also used : DefaultSerializationServiceBuilder(com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder) SerializationService(com.hazelcast.internal.serialization.SerializationService) SerializationServiceSupport(com.hazelcast.spi.impl.SerializationServiceSupport) SerializationServiceAware(com.hazelcast.internal.serialization.SerializationServiceAware) UnknownHostException(java.net.UnknownHostException)

Example 2 with SerializationServiceAware

use of com.hazelcast.internal.serialization.SerializationServiceAware in project hazelcast by hazelcast.

the class ExecutionPlan method initDag.

private void initDag(InternalSerializationService jobSerializationService) {
    final Map<Integer, VertexDef> vMap = vertices.stream().collect(toMap(VertexDef::vertexId, v -> v));
    for (VertexDef v : vertices) {
        v.inboundEdges().forEach(e -> e.initTransientFields(vMap, v, false));
        v.outboundEdges().forEach(e -> e.initTransientFields(vMap, v, true));
    }
    final IPartitionService partitionService = nodeEngine.getPartitionService();
    vertices.stream().map(VertexDef::outboundEdges).flatMap(List::stream).map(EdgeDef::partitioner).filter(Objects::nonNull).forEach(partitioner -> {
        if (partitioner instanceof SerializationServiceAware) {
            ((SerializationServiceAware) partitioner).setSerializationService(jobSerializationService);
        }
        partitioner.init(object -> partitionService.getPartitionId(jobSerializationService.toData(object)));
    });
}
Also used : Address(com.hazelcast.cluster.Address) ImdgUtil.getMemberConnection(com.hazelcast.jet.impl.util.ImdgUtil.getMemberConnection) Arrays(java.util.Arrays) SnapshotContext(com.hazelcast.jet.impl.execution.SnapshotContext) Collections.unmodifiableList(java.util.Collections.unmodifiableList) ConcurrentConveyor.concurrentConveyor(com.hazelcast.internal.util.concurrent.ConcurrentConveyor.concurrentConveyor) Processor(com.hazelcast.jet.core.Processor) OutboundCollector.compositeCollector(com.hazelcast.jet.impl.execution.OutboundCollector.compositeCollector) ObjectWithPartitionId(com.hazelcast.jet.impl.util.ObjectWithPartitionId) ProcessorTasklet(com.hazelcast.jet.impl.execution.ProcessorTasklet) ImdgUtil(com.hazelcast.jet.impl.util.ImdgUtil) Collectors.toMap(java.util.stream.Collectors.toMap) ConcurrentConveyor(com.hazelcast.internal.util.concurrent.ConcurrentConveyor) Map(java.util.Map) Util.memoize(com.hazelcast.jet.impl.util.Util.memoize) SerializationServiceAware(com.hazelcast.internal.serialization.SerializationServiceAware) DISTRIBUTE_TO_ALL(com.hazelcast.jet.core.Edge.DISTRIBUTE_TO_ALL) ObjectDataInput(com.hazelcast.nio.ObjectDataInput) TASKLET_INIT_CLOSE_EXECUTOR_NAME(com.hazelcast.jet.impl.execution.TaskletExecutionService.TASKLET_INIT_CLOSE_EXECUTOR_NAME) InboundEdgeStream(com.hazelcast.jet.impl.execution.InboundEdgeStream) PrefixedLogger.prefix(com.hazelcast.jet.impl.util.PrefixedLogger.prefix) Collection(java.util.Collection) IPartitionService(com.hazelcast.internal.partition.IPartitionService) JobConfig(com.hazelcast.jet.config.JobConfig) ConcurrentHashMap(java.util.concurrent.ConcurrentHashMap) Set(java.util.Set) ConcurrentInboundEdgeStream(com.hazelcast.jet.impl.execution.ConcurrentInboundEdgeStream) Collectors(java.util.stream.Collectors) Objects(java.util.Objects) List(java.util.List) Stream(java.util.stream.Stream) DEFAULT_QUEUE_SIZE(com.hazelcast.jet.config.EdgeConfig.DEFAULT_QUEUE_SIZE) StoreSnapshotTasklet(com.hazelcast.jet.impl.execution.StoreSnapshotTasklet) ObjectDataOutput(com.hazelcast.nio.ObjectDataOutput) TopologyChangedException(com.hazelcast.jet.core.TopologyChangedException) IntStream(java.util.stream.IntStream) ComparatorEx(com.hazelcast.function.ComparatorEx) IdentifiedDataSerializable(com.hazelcast.nio.serialization.IdentifiedDataSerializable) ImdgUtil.writeList(com.hazelcast.jet.impl.util.ImdgUtil.writeList) OutboundEdgeStream(com.hazelcast.jet.impl.execution.OutboundEdgeStream) RoutingPolicy(com.hazelcast.jet.core.Edge.RoutingPolicy) Util.doWithClassLoader(com.hazelcast.jet.impl.util.Util.doWithClassLoader) SenderTasklet(com.hazelcast.jet.impl.execution.SenderTasklet) HashMap(java.util.HashMap) Supplier(java.util.function.Supplier) ProcSupplierCtx(com.hazelcast.jet.impl.execution.init.Contexts.ProcSupplierCtx) ArrayList(java.util.ArrayList) PrefixedLogger.prefixedLogger(com.hazelcast.jet.impl.util.PrefixedLogger.prefixedLogger) JetException(com.hazelcast.jet.JetException) ConveyorCollector(com.hazelcast.jet.impl.execution.ConveyorCollector) ReceiverTasklet(com.hazelcast.jet.impl.execution.ReceiverTasklet) ILogger(com.hazelcast.logging.ILogger) InternalSerializationService(com.hazelcast.internal.serialization.InternalSerializationService) Nonnull(javax.annotation.Nonnull) ProcessorSupplier(com.hazelcast.jet.core.ProcessorSupplier) QueuedPipe(com.hazelcast.internal.util.concurrent.QueuedPipe) IntFunction(java.util.function.IntFunction) JetConfig(com.hazelcast.jet.config.JetConfig) NodeEngineImpl(com.hazelcast.spi.impl.NodeEngineImpl) OneToOneConcurrentArrayQueue(com.hazelcast.internal.util.concurrent.OneToOneConcurrentArrayQueue) Connection(com.hazelcast.internal.nio.Connection) Tasklet(com.hazelcast.jet.impl.execution.Tasklet) ProcCtx(com.hazelcast.jet.impl.execution.init.Contexts.ProcCtx) AsyncSnapshotWriterImpl(com.hazelcast.jet.impl.util.AsyncSnapshotWriterImpl) IOException(java.io.IOException) ConveyorCollectorWithPartition(com.hazelcast.jet.impl.execution.ConveyorCollectorWithPartition) Subject(javax.security.auth.Subject) File(java.io.File) ImdgUtil.readList(com.hazelcast.jet.impl.util.ImdgUtil.readList) Collectors.toList(java.util.stream.Collectors.toList) OutboundCollector(com.hazelcast.jet.impl.execution.OutboundCollector) JobClassLoaderService(com.hazelcast.jet.impl.JobClassLoaderService) ProcessingGuarantee(com.hazelcast.jet.config.ProcessingGuarantee) JetServiceBackend(com.hazelcast.jet.impl.JetServiceBackend) IPartitionService(com.hazelcast.internal.partition.IPartitionService) SerializationServiceAware(com.hazelcast.internal.serialization.SerializationServiceAware)

Aggregations

SerializationServiceAware (com.hazelcast.internal.serialization.SerializationServiceAware)2 Address (com.hazelcast.cluster.Address)1 ComparatorEx (com.hazelcast.function.ComparatorEx)1 Connection (com.hazelcast.internal.nio.Connection)1 IPartitionService (com.hazelcast.internal.partition.IPartitionService)1 InternalSerializationService (com.hazelcast.internal.serialization.InternalSerializationService)1 SerializationService (com.hazelcast.internal.serialization.SerializationService)1 DefaultSerializationServiceBuilder (com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder)1 ConcurrentConveyor (com.hazelcast.internal.util.concurrent.ConcurrentConveyor)1 ConcurrentConveyor.concurrentConveyor (com.hazelcast.internal.util.concurrent.ConcurrentConveyor.concurrentConveyor)1 OneToOneConcurrentArrayQueue (com.hazelcast.internal.util.concurrent.OneToOneConcurrentArrayQueue)1 QueuedPipe (com.hazelcast.internal.util.concurrent.QueuedPipe)1 JetException (com.hazelcast.jet.JetException)1 DEFAULT_QUEUE_SIZE (com.hazelcast.jet.config.EdgeConfig.DEFAULT_QUEUE_SIZE)1 JetConfig (com.hazelcast.jet.config.JetConfig)1 JobConfig (com.hazelcast.jet.config.JobConfig)1 ProcessingGuarantee (com.hazelcast.jet.config.ProcessingGuarantee)1 DISTRIBUTE_TO_ALL (com.hazelcast.jet.core.Edge.DISTRIBUTE_TO_ALL)1 RoutingPolicy (com.hazelcast.jet.core.Edge.RoutingPolicy)1 Processor (com.hazelcast.jet.core.Processor)1