Uses of Interface
com.hazelcast.jet.core.ProcessorMetaSupplier
Package
Description
Apache Avro file read/write support for Hazelcast Jet.
Jet's Core API.
Contains static utility classes with factories of Jet processors.
Utilities for writing tests of Core API Processors.
Apache Hadoop read/write support for Hazelcast Jet.
Apache Kafka reader/writer support for Hazelcast Jet.
The Pipeline API is Jet's high-level API to build and execute
distributed computation jobs.
This package offers the
FileSourceBuilder
which allows you to construct various kinds of Pipeline
sources that read from local or distributed files.-
Uses of ProcessorMetaSupplier in com.hazelcast.jet.avro
Modifier and TypeMethodDescriptionstatic <D,
T> ProcessorMetaSupplier AvroProcessors.readFilesP
(String directory, String glob, boolean sharedFileSystem, SupplierEx<? extends org.apache.avro.io.DatumReader<D>> datumReaderSupplier, BiFunctionEx<String, ? super D, T> mapOutputFn) Returns a supplier of processors forAvroSources.filesBuilder(java.lang.String, java.lang.Class<D>)
.static <D> ProcessorMetaSupplier
AvroProcessors.writeFilesP
(String directoryName, org.apache.avro.Schema schema, SupplierEx<org.apache.avro.io.DatumWriter<D>> datumWriterSupplier) Returns a supplier of processors forAvroSinks.files(java.lang.String, org.apache.avro.Schema, com.hazelcast.function.SupplierEx<org.apache.avro.io.DatumWriter<R>>)
. -
Uses of ProcessorMetaSupplier in com.hazelcast.jet.core
Modifier and TypeClassDescriptionstatic class
static class
A meta-supplier that will only use the givenProcessorSupplier
on a node with givenAddress
or random member if address is not given.Modifier and TypeMethodDescriptionstatic ProcessorMetaSupplier
ProcessorMetaSupplier.forceTotalParallelismOne
(ProcessorSupplier supplier) Variant offorceTotalParallelismOne(ProcessorSupplier, String, Permission)
where the node for the supplier will be chosen randomly and without any required permission.static ProcessorMetaSupplier
ProcessorMetaSupplier.forceTotalParallelismOne
(ProcessorSupplier supplier, Address memberAddress) Wraps the providedProcessorSupplier
into a meta-supplier that will only use the givenProcessorSupplier
on a node with the givenAddress
.static ProcessorMetaSupplier
ProcessorMetaSupplier.forceTotalParallelismOne
(ProcessorSupplier supplier, String partitionKey) Variant offorceTotalParallelismOne(ProcessorSupplier, String, Permission)
without any required permission.static ProcessorMetaSupplier
ProcessorMetaSupplier.forceTotalParallelismOne
(ProcessorSupplier supplier, String partitionKey, Permission permission) Wraps the providedProcessorSupplier
into a meta-supplier that will only use the givenProcessorSupplier
on a single node.static ProcessorMetaSupplier
ProcessorMetaSupplier.forceTotalParallelismOne
(ProcessorSupplier supplier, Permission permission) Variant offorceTotalParallelismOne(ProcessorSupplier, String, Permission)
where the node for the supplier will be chosen randomly.Vertex.getMetaSupplier()
Returns this vertex's meta-supplier of processors.static ProcessorMetaSupplier
ProcessorMetaSupplier.of
(int preferredLocalParallelism, FunctionEx<? super Address, ? extends ProcessorSupplier> addressToSupplier) Factory method that creates aProcessorMetaSupplier
from the supplied function that maps a cluster member address to aProcessorSupplier
.static ProcessorMetaSupplier
ProcessorMetaSupplier.of
(int preferredLocalParallelism, SupplierEx<? extends Processor> procSupplier) Factory method that wraps the givenSupplier<Processor>
and uses it as the supplier of allProcessor
instances.static ProcessorMetaSupplier
ProcessorMetaSupplier.of
(int preferredLocalParallelism, ProcessorSupplier procSupplier) Variant ofof(int, Permission, ProcessorSupplier)
where the processor does not require any permission to run.static ProcessorMetaSupplier
ProcessorMetaSupplier.of
(int preferredLocalParallelism, Permission permission, ProcessorSupplier procSupplier) Factory method that wraps the givenProcessorSupplier
and returns the same instance for each givenAddress
.static ProcessorMetaSupplier
ProcessorMetaSupplier.of
(FunctionEx<? super Address, ? extends ProcessorSupplier> addressToSupplier) Factory method that creates aProcessorMetaSupplier
from the supplied function that maps a cluster member address to aProcessorSupplier
.static ProcessorMetaSupplier
ProcessorMetaSupplier.of
(SupplierEx<? extends Processor> procSupplier) Factory method that wraps the givenSupplier<Processor>
and uses it as the supplier of allProcessor
instances.static ProcessorMetaSupplier
ProcessorMetaSupplier.of
(ProcessorSupplier procSupplier) Variant ofof(Permission, ProcessorSupplier)
where the processor does not require any permission to run.static ProcessorMetaSupplier
ProcessorMetaSupplier.of
(Permission permission, ProcessorSupplier procSupplier) Wraps the providedProcessorSupplier
into a meta-supplier that will always return it.static ProcessorMetaSupplier
ProcessorMetaSupplier.preferLocalParallelismOne
(SupplierEx<? extends Processor> procSupplier) Variant ofpreferLocalParallelismOne(ProcessorSupplier)
where the suppliedSupplierEx<Processor>
will be wrapped into aProcessorSupplier
.static ProcessorMetaSupplier
ProcessorMetaSupplier.preferLocalParallelismOne
(ProcessorSupplier supplier) Wraps the providedProcessorSupplier
into a meta-supplier that will always return it.static ProcessorMetaSupplier
ProcessorMetaSupplier.preferLocalParallelismOne
(Permission permission, SupplierEx<? extends Processor> procSupplier) Variant ofpreferLocalParallelismOne(SupplierEx)
where the processor requires given permission to run.static ProcessorMetaSupplier
ProcessorMetaSupplier.preferLocalParallelismOne
(Permission permission, ProcessorSupplier supplier) Variant ofpreferLocalParallelismOne(ProcessorSupplier)
where the processor requires given permission to run.static ProcessorMetaSupplier
ProcessorMetaSupplier.randomMember
(ProcessorSupplier supplier) Wraps the providedProcessorSupplier
into a meta-supplier that will only use the givenProcessorSupplier
on a random nodeModifier and TypeMethodDescriptionDAG.newUniqueVertex
(String namePrefix, ProcessorMetaSupplier metaSupplier) Creates a vertex from aProcessorMetaSupplier
and adds it to this DAG.DAG.newVertex
(String name, ProcessorMetaSupplier metaSupplier) Creates a vertex from aProcessorMetaSupplier
and adds it to this DAG.Modifier and TypeMethodDescriptionvoid
Vertex.updateMetaSupplier
(UnaryOperator<ProcessorMetaSupplier> updateFn) Applies the provided operator function to the current processor meta-supplier and replaces it with the one it returns.ModifierConstructorDescriptionVertex
(String name, ProcessorMetaSupplier metaSupplier) Creates a vertex from aProcessorMetaSupplier
. -
Uses of ProcessorMetaSupplier in com.hazelcast.jet.core.processor
Modifier and TypeMethodDescriptionstatic <C,
T, S> ProcessorMetaSupplier SourceProcessors.convenientSourceP
(FunctionEx<? super Processor.Context, ? extends C> createFn, BiConsumerEx<? super C, ? super SourceBuilder.SourceBuffer<T>> fillBufferFn, FunctionEx<? super C, ? extends S> createSnapshotFn, BiConsumerEx<? super C, ? super List<S>> restoreSnapshotFn, ConsumerEx<? super C> destroyFn, int preferredLocalParallelism, boolean isBatch, Permission permission) Returns a supplier of processors for a source that the user can create using theSourceBuilder
.static <C,
T, S> ProcessorMetaSupplier SourceProcessors.convenientTimestampedSourceP
(FunctionEx<? super Processor.Context, ? extends C> createFn, BiConsumerEx<? super C, ? super SourceBuilder.TimestampedSourceBuffer<T>> fillBufferFn, EventTimePolicy<? super T> eventTimePolicy, FunctionEx<? super C, ? extends S> createSnapshotFn, BiConsumerEx<? super C, ? super List<S>> restoreSnapshotFn, ConsumerEx<? super C> destroyFn, int preferredLocalParallelism) Returns a supplier of processors for a source that the user can create using theSourceBuilder
.static <T,
K, V> ProcessorMetaSupplier SinkProcessors.mergeMapP
(String mapName, FunctionEx<? super T, ? extends K> toKeyFn, FunctionEx<? super T, ? extends V> toValueFn, BinaryOperatorEx<V> mergeFn) Returns a supplier of processors forSinks.mapWithMerging(String, FunctionEx, FunctionEx, BinaryOperatorEx)
.static <T,
K, V> ProcessorMetaSupplier SinkProcessors.mergeRemoteMapP
(String mapName, ClientConfig clientConfig, FunctionEx<? super T, ? extends K> toKeyFn, FunctionEx<? super T, ? extends V> toValueFn, BinaryOperatorEx<V> mergeFn) Returns a supplier of processors forSinks.remoteMapWithMerging(String, ClientConfig, FunctionEx, FunctionEx, BinaryOperatorEx)
.static <T> ProcessorMetaSupplier
DiagnosticProcessors.peekInputP
(FunctionEx<T, ? extends CharSequence> toStringFn, PredicateEx<T> shouldLogFn, ProcessorMetaSupplier wrapped) Returns a meta-supplier that wraps the provided one and adds a logging layer to each processor it creates.static ProcessorMetaSupplier
DiagnosticProcessors.peekInputP
(ProcessorMetaSupplier wrapped) Convenience forpeekInput(toStringFn, shouldLogFn, metaSupplier)
with a pass-through filter andObject#toString
as the formatting function.static <T> ProcessorMetaSupplier
DiagnosticProcessors.peekOutputP
(FunctionEx<? super T, ? extends CharSequence> toStringFn, PredicateEx<? super T> shouldLogFn, ProcessorMetaSupplier wrapped) Returns a meta-supplier that wraps the provided one and adds a logging layer to each processor it creates.static ProcessorMetaSupplier
DiagnosticProcessors.peekOutputP
(ProcessorMetaSupplier wrapped) Convenience forpeekOutput(toStringFn, shouldLogFn, metaSupplier
with a pass-through filter andObject#toString
as the formatting function.static <K,
V> ProcessorMetaSupplier DiagnosticProcessors.peekSnapshotP
(FunctionEx<? super Map.Entry<K, V>, ? extends CharSequence> toStringFn, PredicateEx<? super Map.Entry<K, V>> shouldLogFn, ProcessorMetaSupplier wrapped) Returns a meta-supplier that wraps the provided one and adds a logging layer to each processor it creates.static ProcessorMetaSupplier
DiagnosticProcessors.peekSnapshotP
(ProcessorMetaSupplier wrapped) Convenience forpeekSnapshot(toStringFn, shouldLogFn, metaSupplier
with a pass-through filter andObject#toString
as the formatting function.static ProcessorMetaSupplier
SourceProcessors.readCacheP
(String cacheName) Returns a supplier of processors forSources.cache(String)
.static <I> ProcessorMetaSupplier
SourceProcessors.readFilesP
(String directory, String glob, boolean sharedFileSystem, boolean ignoreFileNotFound, FunctionEx<? super Path, ? extends Stream<I>> readFileFn) Returns a supplier of processors forFileSources.files(String)
to read local files.static <I> ProcessorMetaSupplier
SourceProcessors.readFilesP
(String directory, String glob, boolean sharedFileSystem, FunctionEx<? super Path, ? extends Stream<I>> readFileFn) Returns a supplier of processors forSources.filesBuilder(java.lang.String)
.static <R> ProcessorMetaSupplier
SourceProcessors.readFilesP
(String directory, Charset charset, String glob, boolean sharedFileSystem, BiFunctionEx<? super String, ? super String, ? extends R> mapOutputFn) Returns a supplier of processors forSources.filesBuilder(java.lang.String)
.static <T> ProcessorMetaSupplier
SourceProcessors.readJdbcP
(SupplierEx<? extends Connection> newConnectionFn, ToResultSetFunction resultSetFn, FunctionEx<? super ResultSet, ? extends T> mapOutputFn) Returns a supplier of processors forSources.jdbc(SupplierEx, ToResultSetFunction, FunctionEx)
.static <T> ProcessorMetaSupplier
SourceProcessors.readJdbcP
(DataConnectionRef dataConnectionRef, ToResultSetFunction resultSetFn, FunctionEx<? super ResultSet, ? extends T> mapOutputFn) Returns a supplier of processors forSources.jdbc(DataConnectionRef, ToResultSetFunction, FunctionEx)
.static <T> ProcessorMetaSupplier
SourceProcessors.readJdbcP
(String connectionURL, String query, FunctionEx<? super ResultSet, ? extends T> mapOutputFn) Returns a supplier of processors forSources.jdbc(String, String, FunctionEx)
.static <T> ProcessorMetaSupplier
SourceProcessors.readJdbcP
(String connectionURL, String query, Properties properties, FunctionEx<? super ResultSet, ? extends T> mapOutputFn) static ProcessorMetaSupplier
Returns a supplier of processors forSources.list(String)
.static ProcessorMetaSupplier
Returns a supplier of processors forSources.map(String)
.static <T,
K, V> ProcessorMetaSupplier SourceProcessors.readMapP
(String mapName, Predicate<K, V> predicate, Projection<? super Map.Entry<K, V>, ? extends T> projection) Returns a supplier of processors forSources.map(String, Predicate, Projection)
.static ProcessorMetaSupplier
SourceProcessors.readRemoteListP
(String listName, ClientConfig clientConfig) Returns a supplier of processors forSources.remoteList(String, ClientConfig)
.static <T,
K, V> ProcessorMetaSupplier SourceProcessors.streamCacheP
(String cacheName, PredicateEx<? super EventJournalCacheEvent<K, V>> predicateFn, FunctionEx<? super EventJournalCacheEvent<K, V>, ? extends T> projectionFn, JournalInitialPosition initialPos, EventTimePolicy<? super T> eventTimePolicy) Returns a supplier of processors forSources.cacheJournal(String, JournalInitialPosition, FunctionEx, PredicateEx)
.static <K,
V> ProcessorMetaSupplier SourceProcessors.streamCacheP
(String cacheName, JournalInitialPosition initialPos, EventTimePolicy<? super Map.Entry<K, V>> eventTimePolicy) Returns a supplier of processors forSources.cacheJournal(String, JournalInitialPosition)
.static ProcessorMetaSupplier
SourceProcessors.streamFilesP
(String watchedDirectory, Charset charset, String glob, boolean sharedFileSystem, BiFunctionEx<? super String, ? super String, ?> mapOutputFn) Returns a supplier of processors forSources.filesBuilder(java.lang.String)
.static <T> ProcessorMetaSupplier
SourceProcessors.streamJmsQueueP
(String destination, ProcessingGuarantee maxGuarantee, EventTimePolicy<? super T> eventTimePolicy, SupplierEx<? extends jakarta.jms.Connection> newConnectionFn, FunctionEx<? super jakarta.jms.Session, ? extends jakarta.jms.MessageConsumer> consumerFn, FunctionEx<? super jakarta.jms.Message, ?> messageIdFn, FunctionEx<? super jakarta.jms.Message, ? extends T> projectionFn) Returns a supplier of processors forSources.jmsQueueBuilder(com.hazelcast.function.SupplierEx<? extends jakarta.jms.ConnectionFactory>)
.static <T> ProcessorMetaSupplier
SourceProcessors.streamJmsTopicP
(String destination, boolean isSharedConsumer, ProcessingGuarantee maxGuarantee, EventTimePolicy<? super T> eventTimePolicy, SupplierEx<? extends jakarta.jms.Connection> newConnectionFn, FunctionEx<? super jakarta.jms.Session, ? extends jakarta.jms.MessageConsumer> consumerFn, FunctionEx<? super jakarta.jms.Message, ?> messageIdFn, FunctionEx<? super jakarta.jms.Message, ? extends T> projectionFn) Returns a supplier of processors forSources.jmsTopicBuilder(com.hazelcast.function.SupplierEx<? extends jakarta.jms.ConnectionFactory>)
.static <T,
K, V> ProcessorMetaSupplier SourceProcessors.streamMapP
(String mapName, PredicateEx<? super EventJournalMapEvent<K, V>> predicateFn, FunctionEx<? super EventJournalMapEvent<K, V>, ? extends T> projectionFn, JournalInitialPosition initialPos, EventTimePolicy<? super T> eventTimePolicy) Returns a supplier of processors forSources.mapJournal(String, JournalInitialPosition, FunctionEx, PredicateEx)
.static <K,
V> ProcessorMetaSupplier SourceProcessors.streamMapP
(String mapName, JournalInitialPosition initialPos, EventTimePolicy<? super Map.Entry<K, V>> eventTimePolicy) Returns a supplier of processors forSources.mapJournal(String, JournalInitialPosition)
.static <T,
K, V> ProcessorMetaSupplier SourceProcessors.streamRemoteCacheP
(String cacheName, ClientConfig clientConfig, PredicateEx<? super EventJournalCacheEvent<K, V>> predicateFn, FunctionEx<? super EventJournalCacheEvent<K, V>, ? extends T> projectionFn, JournalInitialPosition initialPos, EventTimePolicy<? super T> eventTimePolicy) Returns a supplier of processors forSources.remoteCacheJournal(String, ClientConfig, JournalInitialPosition, FunctionEx, PredicateEx)
.static <K,
V> ProcessorMetaSupplier SourceProcessors.streamRemoteCacheP
(String cacheName, ClientConfig clientConfig, JournalInitialPosition initialPos, EventTimePolicy<? super Map.Entry<K, V>> eventTimePolicy) Returns a supplier of processors forSources.remoteCacheJournal(String, ClientConfig, JournalInitialPosition)
.static <T,
K, V> ProcessorMetaSupplier SourceProcessors.streamRemoteMapP
(String mapName, ClientConfig clientConfig, PredicateEx<? super EventJournalMapEvent<K, V>> predicateFn, FunctionEx<? super EventJournalMapEvent<K, V>, ? extends T> projectionFn, JournalInitialPosition initialPos, EventTimePolicy<? super T> eventTimePolicy) Returns a supplier of processors forSources.remoteMapJournal(String, ClientConfig, JournalInitialPosition, FunctionEx, PredicateEx)
.static <K,
V> ProcessorMetaSupplier SourceProcessors.streamRemoteMapP
(String mapName, ClientConfig clientConfig, JournalInitialPosition initialPos, EventTimePolicy<? super Map.Entry<K, V>> eventTimePolicy) Returns a supplier of processors forSources.remoteMapJournal(String, ClientConfig, JournalInitialPosition)
.static ProcessorMetaSupplier
SourceProcessors.streamSocketP
(String host, int port, Charset charset) Returns a supplier of processors forSources.socket(String, int, Charset)
.static <T,
K, V, R> ProcessorMetaSupplier SinkProcessors.updateMapP
(int maxParallelAsyncOps, String mapName, FunctionEx<? super T, ? extends K> toKeyFn, FunctionEx<? super T, ? extends EntryProcessor<K, V, R>> toEntryProcessorFn) Returns a supplier of processors forSinks.mapWithEntryProcessor(int, String, FunctionEx, FunctionEx)
.static <T,
K, V> ProcessorMetaSupplier SinkProcessors.updateMapP
(com.hazelcast.jet.impl.connector.MapSinkConfiguration<T, K, V> configuration) static <T,
K, V> ProcessorMetaSupplier SinkProcessors.updateMapP
(String mapName, FunctionEx<? super T, ? extends K> toKeyFn, BiFunctionEx<? super V, ? super T, ? extends V> updateFn) Returns a supplier of processors forSinks.mapWithEntryProcessor(String, FunctionEx, FunctionEx)
.static <T,
K, V, R> ProcessorMetaSupplier SinkProcessors.updateMapP
(String mapName, FunctionEx<? super T, ? extends K> toKeyFn, FunctionEx<? super T, ? extends EntryProcessor<K, V, R>> toEntryProcessorFn) Returns a supplier of processors forSinks.mapWithEntryProcessor(String, FunctionEx, FunctionEx)
.static <T,
K, V> ProcessorMetaSupplier SinkProcessors.updateRemoteMapP
(String mapName, ClientConfig clientConfig, FunctionEx<? super T, ? extends K> toKeyFn, BiFunctionEx<? super V, ? super T, ? extends V> updateFn) Returns a supplier of processors forSinks.remoteMapWithUpdating(String, ClientConfig, FunctionEx, BiFunctionEx)
.static <T,
K, V, R> ProcessorMetaSupplier SinkProcessors.updateRemoteMapP
(String mapName, ClientConfig clientConfig, FunctionEx<? super T, ? extends K> toKeyFn, FunctionEx<? super T, ? extends EntryProcessor<K, V, R>> toEntryProcessorFn) Returns a supplier of processors forSinks.remoteMapWithEntryProcessor(String, ClientConfig, FunctionEx, FunctionEx)
.static ProcessorMetaSupplier
SinkProcessors.writeCacheP
(String cacheName) Returns a supplier of processors forSinks.cache(String)
.static <T> ProcessorMetaSupplier
SinkProcessors.writeFileP
(String directoryName, Charset charset, String datePattern, long maxFileSize, boolean exactlyOnce, FunctionEx<? super T, ? extends String> toStringFn) Returns a supplier of processors forSinks.filesBuilder(java.lang.String)
.static <T> ProcessorMetaSupplier
SinkProcessors.writeJdbcP
(String updateQuery, DataConnectionRef dataConnectionRef, BiConsumerEx<? super PreparedStatement, ? super T> bindFn, boolean exactlyOnce, int batchLimit) Returns a supplier of processors forSinks.jdbcBuilder()
.static <T> ProcessorMetaSupplier
SinkProcessors.writeJdbcP
(String jdbcUrl, String updateQuery, SupplierEx<? extends CommonDataSource> dataSourceSupplier, BiConsumerEx<? super PreparedStatement, ? super T> bindFn, boolean exactlyOnce, int batchLimit) Returns a supplier of processors forSinks.jdbcBuilder()
.static <T> ProcessorMetaSupplier
SinkProcessors.writeJmsQueueP
(String queueName, boolean exactlyOnce, SupplierEx<? extends jakarta.jms.Connection> newConnectionFn, BiFunctionEx<? super jakarta.jms.Session, ? super T, ? extends jakarta.jms.Message> messageFn) Returns a supplier of processors forSinks.jmsQueueBuilder(com.hazelcast.function.SupplierEx<jakarta.jms.ConnectionFactory>)
.static <T> ProcessorMetaSupplier
SinkProcessors.writeJmsTopicP
(String topicName, boolean exactlyOnce, SupplierEx<? extends jakarta.jms.Connection> newConnectionFn, BiFunctionEx<? super jakarta.jms.Session, ? super T, ? extends jakarta.jms.Message> messageFn) Returns a supplier of processors forSinks.jmsTopicBuilder(com.hazelcast.function.SupplierEx<jakarta.jms.ConnectionFactory>)
.static ProcessorMetaSupplier
SinkProcessors.writeListP
(String listName) Returns a supplier of processors forSinks.list(String)
.static ProcessorMetaSupplier
DiagnosticProcessors.writeLoggerP()
static <T> ProcessorMetaSupplier
DiagnosticProcessors.writeLoggerP
(FunctionEx<T, ? extends CharSequence> toStringFn) Returns a meta-supplier of processors for a sink vertex that logs all the data items it receives.static <T,
K, V> ProcessorMetaSupplier SinkProcessors.writeMapP
(com.hazelcast.jet.impl.connector.MapSinkConfiguration<T, K, V> configuration) Returns a supplier of processorsstatic <K,
V> ProcessorMetaSupplier Returns a supplier of processors forSinks.map(String)
.static <T,
K, V> ProcessorMetaSupplier SinkProcessors.writeMapP
(String mapName, FunctionEx<? super T, ? extends K> toKeyFn, FunctionEx<? super T, ? extends V> toValueFn) Returns a supplier of processors forSinks.map(String, FunctionEx, FunctionEx)
.static ProcessorMetaSupplier
SinkProcessors.writeObservableP
(String name) Returns a supplier of processors forSinks.observable(java.lang.String)
.static ProcessorMetaSupplier
SinkProcessors.writeRemoteCacheP
(String cacheName, ClientConfig clientConfig) Returns a supplier of processors forSinks.remoteCache(String, ClientConfig)
.static ProcessorMetaSupplier
SinkProcessors.writeRemoteListP
(String listName, ClientConfig clientConfig) Returns a supplier of processors forSinks.remoteList(String, ClientConfig)
.static ProcessorMetaSupplier
SinkProcessors.writeRemoteMapP
(String mapName, ClientConfig clientConfig) Returns a supplier of processors forSinks.remoteMap(String, ClientConfig)
.static <T,
K, V> ProcessorMetaSupplier SinkProcessors.writeRemoteMapP
(String mapName, ClientConfig clientConfig, FunctionEx<? super T, ? extends K> toKeyFn, FunctionEx<? super T, ? extends V> toValueFn) Returns a supplier of processors forSinks.remoteMap(String, ClientConfig, FunctionEx, FunctionEx)
.static <T> ProcessorMetaSupplier
SinkProcessors.writeSocketP
(String host, int port, FunctionEx<? super T, ? extends String> toStringFn, Charset charset) Returns a supplier of processors forSinks.socket(String, int)
.Modifier and TypeMethodDescriptionstatic <T> ProcessorMetaSupplier
DiagnosticProcessors.peekInputP
(FunctionEx<T, ? extends CharSequence> toStringFn, PredicateEx<T> shouldLogFn, ProcessorMetaSupplier wrapped) Returns a meta-supplier that wraps the provided one and adds a logging layer to each processor it creates.static ProcessorMetaSupplier
DiagnosticProcessors.peekInputP
(ProcessorMetaSupplier wrapped) Convenience forpeekInput(toStringFn, shouldLogFn, metaSupplier)
with a pass-through filter andObject#toString
as the formatting function.static <T> ProcessorMetaSupplier
DiagnosticProcessors.peekOutputP
(FunctionEx<? super T, ? extends CharSequence> toStringFn, PredicateEx<? super T> shouldLogFn, ProcessorMetaSupplier wrapped) Returns a meta-supplier that wraps the provided one and adds a logging layer to each processor it creates.static ProcessorMetaSupplier
DiagnosticProcessors.peekOutputP
(ProcessorMetaSupplier wrapped) Convenience forpeekOutput(toStringFn, shouldLogFn, metaSupplier
with a pass-through filter andObject#toString
as the formatting function.static <K,
V> ProcessorMetaSupplier DiagnosticProcessors.peekSnapshotP
(FunctionEx<? super Map.Entry<K, V>, ? extends CharSequence> toStringFn, PredicateEx<? super Map.Entry<K, V>> shouldLogFn, ProcessorMetaSupplier wrapped) Returns a meta-supplier that wraps the provided one and adds a logging layer to each processor it creates.static ProcessorMetaSupplier
DiagnosticProcessors.peekSnapshotP
(ProcessorMetaSupplier wrapped) Convenience forpeekSnapshot(toStringFn, shouldLogFn, metaSupplier
with a pass-through filter andObject#toString
as the formatting function. -
Uses of ProcessorMetaSupplier in com.hazelcast.jet.core.test
Modifier and TypeMethodDescriptionTestSupport.supplierFrom
(ProcessorMetaSupplier supplier) Wraps the providedProcessorMetaSupplier
with aSupplier<Processor>
that returns processors obtained from it.TestSupport.supplierFrom
(ProcessorMetaSupplier supplier, ProcessorSupplier.Context context) Wraps the providedProcessorMetaSupplier
with aSupplier<Processor>
that returns processors obtained from it.static TestSupport
TestSupport.verifyProcessor
(ProcessorMetaSupplier supplier) -
Uses of ProcessorMetaSupplier in com.hazelcast.jet.hadoop
Modifier and TypeMethodDescriptionstatic <K,
V, R> ProcessorMetaSupplier HadoopProcessors.readHadoopP
(Permission permission, ConsumerEx<org.apache.hadoop.conf.Configuration> configureFn, BiFunctionEx<K, V, R> projectionFn) Returns a supplier of processors forFileSources.files(String)
.static <K,
V, R> ProcessorMetaSupplier HadoopProcessors.readHadoopP
(org.apache.hadoop.conf.Configuration configuration, BiFunctionEx<K, V, R> projectionFn) Returns a supplier of processors forHadoopSources.inputFormat(Configuration, BiFunctionEx)
.static <E,
K, V> ProcessorMetaSupplier HadoopProcessors.writeHadoopP
(org.apache.hadoop.conf.Configuration configuration, FunctionEx<? super E, K> extractKeyFn, FunctionEx<? super E, V> extractValueFn) Returns a supplier of processors forHadoopSinks.outputFormat(Configuration, FunctionEx, FunctionEx)
. -
Uses of ProcessorMetaSupplier in com.hazelcast.jet.kafka
Modifier and TypeMethodDescriptionstatic <K,
V, T> ProcessorMetaSupplier KafkaProcessors.streamKafkaP
(DataConnectionRef dataConnectionRef, FunctionEx<? super org.apache.kafka.clients.consumer.ConsumerRecord<K, V>, ? extends T> projectionFn, EventTimePolicy<? super T> eventTimePolicy, String... topics) Returns a supplier of processors forKafkaSources.kafka(DataConnectionRef, FunctionEx, String...)
.static <K,
V, T> ProcessorMetaSupplier KafkaProcessors.streamKafkaP
(Properties properties, FunctionEx<? super org.apache.kafka.clients.consumer.ConsumerRecord<K, V>, ? extends T> projectionFn, EventTimePolicy<? super T> eventTimePolicy, TopicsConfig topicsConfig) Returns a supplier of processors forKafkaSources.kafka(Properties, FunctionEx, TopicsConfig)
}.static <K,
V, T> ProcessorMetaSupplier KafkaProcessors.streamKafkaP
(Properties properties, FunctionEx<? super org.apache.kafka.clients.consumer.ConsumerRecord<K, V>, ? extends T> projectionFn, EventTimePolicy<? super T> eventTimePolicy, String... topics) Returns a supplier of processors forKafkaSources.kafka(Properties, FunctionEx, String...)
.static <T,
K, V> ProcessorMetaSupplier KafkaProcessors.writeKafkaP
(DataConnectionRef dataConnectionRef, FunctionEx<? super T, ? extends org.apache.kafka.clients.producer.ProducerRecord<K, V>> toRecordFn, boolean exactlyOnce) Returns a supplier of processors forKafkaSinks.kafka(DataConnectionRef, FunctionEx)
.static <T,
K, V> ProcessorMetaSupplier KafkaProcessors.writeKafkaP
(DataConnectionRef dataConnectionRef, String topic, FunctionEx<? super T, ? extends K> extractKeyFn, FunctionEx<? super T, ? extends V> extractValueFn, boolean exactlyOnce) Returns a supplier of processors forKafkaSinks.kafka(DataConnectionRef, String, FunctionEx, FunctionEx)
.static <T,
K, V> ProcessorMetaSupplier KafkaProcessors.writeKafkaP
(DataConnectionRef dataConnectionRef, Properties properties, FunctionEx<? super T, ? extends org.apache.kafka.clients.producer.ProducerRecord<K, V>> toRecordFn, boolean exactlyOnce) Returns a supplier of processors forKafkaSinks.kafka(Properties, FunctionEx)
.static <T,
K, V> ProcessorMetaSupplier KafkaProcessors.writeKafkaP
(DataConnectionRef dataConnectionRef, Properties properties, String topic, FunctionEx<? super T, ? extends K> extractKeyFn, FunctionEx<? super T, ? extends V> extractValueFn, boolean exactlyOnce) Returns a supplier of processors forKafkaSinks.kafka(DataConnectionRef, Properties, String, FunctionEx, FunctionEx)
.static <T,
K, V> ProcessorMetaSupplier KafkaProcessors.writeKafkaP
(Properties properties, FunctionEx<? super T, ? extends org.apache.kafka.clients.producer.ProducerRecord<K, V>> toRecordFn, boolean exactlyOnce) Returns a supplier of processors forKafkaSinks.kafka(Properties, FunctionEx)
.static <T,
K, V> ProcessorMetaSupplier KafkaProcessors.writeKafkaP
(Properties properties, String topic, FunctionEx<? super T, ? extends K> extractKeyFn, FunctionEx<? super T, ? extends V> extractValueFn, boolean exactlyOnce) Returns a supplier of processors forKafkaSinks.kafka(Properties, String, FunctionEx, FunctionEx)
. -
Uses of ProcessorMetaSupplier in com.hazelcast.jet.pipeline
Modifier and TypeMethodDescriptionstatic <T> BatchSource<T>
Sources.batchFromProcessor
(String sourceName, ProcessorMetaSupplier metaSupplier) Returns a bounded (batch) source constructed directly from the given Core API processor meta-supplier.<R> BatchStage<R>
BatchStage.customTransform
(String stageName, ProcessorMetaSupplier procSupplier) <R> BatchStage<R>
BatchStageWithKey.customTransform
(String stageName, ProcessorMetaSupplier procSupplier) <R> GeneralStage<R>
GeneralStage.customTransform
(String stageName, ProcessorMetaSupplier procSupplier) Attaches a stage with a custom transform based on the provided supplier of Core APIProcessor
s.<R> GeneralStage<R>
GeneralStageWithKey.customTransform
(String stageName, ProcessorMetaSupplier procSupplier) Attaches a stage with a custom transform based on the provided supplier of Core APIProcessor
s.<R> StreamStage<R>
StreamStage.customTransform
(String stageName, ProcessorMetaSupplier procSupplier) <R> StreamStage<R>
StreamStageWithKey.customTransform
(String stageName, ProcessorMetaSupplier procSupplier) static <T> Sink<T>
Sinks.fromProcessor
(String sinkName, ProcessorMetaSupplier metaSupplier) Returns a sink constructed directly from the given Core API processor meta-supplier.static <T> Sink<T>
Sinks.fromProcessor
(String sinkName, ProcessorMetaSupplier metaSupplier, FunctionEx<? super T, ?> partitionKeyFn) Returns a sink constructed directly from the given Core API processor meta-supplier.static <T> StreamSource<T>
Sources.streamFromProcessor
(String sourceName, ProcessorMetaSupplier metaSupplier) Returns an unbounded (event stream) source constructed directly from the given Core API processor meta-supplier.Modifier and TypeMethodDescriptionstatic <T> StreamSource<T>
Sources.streamFromProcessorWithWatermarks
(String sourceName, boolean supportsNativeTimestamps, FunctionEx<EventTimePolicy<? super T>, ProcessorMetaSupplier> metaSupplierFn) Returns an unbounded (event stream) source that will use the supplied function to create processor meta-suppliers as required by the Core API. -
Uses of ProcessorMetaSupplier in com.hazelcast.jet.pipeline.file
Modifier and TypeMethodDescriptionFileSourceBuilder.buildMetaSupplier()
Builds aProcessorMetaSupplier
based on the current state of the builder.