Package | Description |
---|---|
com.hazelcast.jet.core |
Jet's Core API.
|
com.hazelcast.jet.core.processor |
Contains static utility classes with factories of Jet processors.
|
com.hazelcast.jet.kafka |
Apache Kafka reader/writer support for Hazelcast Jet.
|
com.hazelcast.jet.pipeline |
The Pipeline API is Jet's high-level API to build and execute
distributed computation jobs.
|
com.hazelcast.jet.pipeline.test |
This package contains various mock sources to help with pipeline testing
and development.
|
Modifier and Type | Method and Description |
---|---|
static <T> EventTimePolicy<T> |
EventTimePolicy.eventTimePolicy(ToLongFunctionEx<? super T> timestampFn,
ObjLongBiFunction<? super T,?> wrapFn,
SupplierEx<? extends WatermarkPolicy> newWmPolicyFn,
long watermarkThrottlingFrameSize,
long watermarkThrottlingFrameOffset,
long idleTimeoutMillis)
Creates and returns a new event time policy.
|
static <T> EventTimePolicy<T> |
EventTimePolicy.eventTimePolicy(ToLongFunctionEx<? super T> timestampFn,
SupplierEx<? extends WatermarkPolicy> newWmPolicyFn,
long watermarkThrottlingFrameSize,
long watermarkThrottlingFrameOffset,
long idleTimeoutMillis)
Creates and returns a new event time policy.
|
static <T> EventTimePolicy<T> |
EventTimePolicy.noEventTime()
Returns an event time policy that results in no timestamping.
|
Constructor and Description |
---|
EventTimeMapper(EventTimePolicy<? super T> eventTimePolicy)
The partition count is initially set to 0, call
EventTimeMapper.addPartitions(int)
to add partitions. |
Modifier and Type | Method and Description |
---|---|
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 the
SourceBuilder . |
static <T> SupplierEx<Processor> |
Processors.insertWatermarksP(EventTimePolicy<? super T> eventTimePolicy)
Returns a supplier of processors for a vertex that inserts
watermark items into the stream. |
static <K,V> ProcessorMetaSupplier |
SourceProcessors.streamCacheP(String cacheName,
JournalInitialPosition initialPos,
EventTimePolicy<? super Map.Entry<K,V>> eventTimePolicy)
Returns a supplier of processors for
Sources.cacheJournal(String, JournalInitialPosition) . |
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 for
Sources.cacheJournal(String, JournalInitialPosition, FunctionEx, PredicateEx) . |
static <T> ProcessorMetaSupplier |
SourceProcessors.streamJmsQueueP(String destination,
ProcessingGuarantee maxGuarantee,
EventTimePolicy<? super T> eventTimePolicy,
SupplierEx<? extends javax.jms.Connection> newConnectionFn,
FunctionEx<? super javax.jms.Session,? extends javax.jms.MessageConsumer> consumerFn,
FunctionEx<? super javax.jms.Message,?> messageIdFn,
FunctionEx<? super javax.jms.Message,? extends T> projectionFn)
Returns a supplier of processors for
Sources.jmsQueueBuilder(com.hazelcast.function.SupplierEx<? extends javax.jms.ConnectionFactory>) . |
static <T> ProcessorMetaSupplier |
SourceProcessors.streamJmsTopicP(String destination,
boolean isSharedConsumer,
ProcessingGuarantee maxGuarantee,
EventTimePolicy<? super T> eventTimePolicy,
SupplierEx<? extends javax.jms.Connection> newConnectionFn,
FunctionEx<? super javax.jms.Session,? extends javax.jms.MessageConsumer> consumerFn,
FunctionEx<? super javax.jms.Message,?> messageIdFn,
FunctionEx<? super javax.jms.Message,? extends T> projectionFn)
Returns a supplier of processors for
Sources.jmsTopicBuilder(com.hazelcast.function.SupplierEx<? extends javax.jms.ConnectionFactory>) . |
static <K,V> ProcessorMetaSupplier |
SourceProcessors.streamMapP(String mapName,
JournalInitialPosition initialPos,
EventTimePolicy<? super Map.Entry<K,V>> eventTimePolicy)
Returns a supplier of processors for
Sources.mapJournal(String, JournalInitialPosition) )}. |
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 for
Sources.mapJournal(String, 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 for
Sources.remoteCacheJournal(String, ClientConfig, 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 for
Sources.remoteCacheJournal(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 for
Sources.remoteMapJournal(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 for
Sources.remoteMapJournal(String, ClientConfig, JournalInitialPosition, FunctionEx, PredicateEx) . |
Modifier and Type | Method and Description |
---|---|
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 for
KafkaSources.kafka(Properties, FunctionEx, String...) . |
Modifier and Type | Method and Description |
---|---|
static <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.
|
Constructor and Description |
---|
ParallelStreamP(long eventsPerSecondPerGenerator,
EventTimePolicy<? super T> eventTimePolicy,
List<? extends GeneratorFunction<T>> generators)
Creates a processor that generates items using its assigned
generator functions.
|
Copyright © 2023 Hazelcast, Inc.. All rights reserved.