Uses of Interface
com.hazelcast.function.FunctionEx
Package | Description |
---|---|
com.hazelcast.function |
Serializable and exception-declaring variants of functional interfaces from
java.util.function . |
com.hazelcast.jet.grpc |
Contributes
gRPC service factories that can be to apply transformations to
a pipeline which for each input item calls to a gRPC service. |
com.hazelcast.jet.hadoop |
Apache Hadoop read/write support for Hazelcast Jet.
|
com.hazelcast.jet.kafka |
Apache Kafka reader/writer support for Hazelcast Jet.
|
com.hazelcast.jet.python |
Contributes a
PythonTransforms.mapUsingPython(com.hazelcast.jet.python.PythonServiceConfig)
transform that allows you to transform Jet pipeline data using a Python
function. |
com.hazelcast.jet.s3 |
AWS S3 read/write support for Hazelcast Jet.
|
-
Uses of FunctionEx in com.hazelcast.function
Methods in com.hazelcast.function that return FunctionEx Modifier and Type Method Description default <V> FunctionEx<T,V>
FunctionEx. andThen(FunctionEx<? super R,? extends V> after)
Serializable
variant ofjava.util.function.Function#andThen(Function)
.default <V> FunctionEx<V,R>
FunctionEx. compose(FunctionEx<? super V,? extends T> before)
Serializable
variant ofjava.util.function.Function#compose(Function)
.static <K> FunctionEx<Map.Entry<K,?>,K>
Functions. entryKey()
Returns a function that extracts the key of aMap.Entry
.static <V> FunctionEx<Map.Entry<?,V>,V>
Functions. entryValue()
Returns a function that extracts the value of aMap.Entry
.static <T> FunctionEx<T,T>
FunctionEx. identity()
Serializable
variant ofjava.util.function.Function#identity()
.static <T> FunctionEx<T,T>
Functions. wholeItem()
Synonym foridentity()
, to be used as a projection function (e.g., key extractor).Methods in com.hazelcast.function with parameters of type FunctionEx Modifier and Type Method Description default <V> BiFunctionEx<T,U,V>
BiFunctionEx. andThen(FunctionEx<? super R,? extends V> after)
Serializable
variant ofjava.util.function.BiFunction#andThen(Function)
.default <V> FunctionEx<T,V>
FunctionEx. andThen(FunctionEx<? super R,? extends V> after)
Serializable
variant ofjava.util.function.Function#andThen(Function)
.static <T, U extends Comparable<? super U>>
ComparatorEx<T>ComparatorEx. comparing(FunctionEx<? super T,? extends U> toKeyFn)
Serializable
variant ofjava.util.Comparator#comparing(Function)
.static <T, U> ComparatorEx<T>
ComparatorEx. comparing(FunctionEx<? super T,? extends U> toKeyFn, ComparatorEx<? super U> keyComparator)
Serializable
variant ofjava.util.Comparator#comparing(Function, Comparator)
.default <V> FunctionEx<V,R>
FunctionEx. compose(FunctionEx<? super V,? extends T> before)
Serializable
variant ofjava.util.function.Function#compose(Function)
.default <U extends Comparable<? super U>>
ComparatorEx<T>ComparatorEx. thenComparing(FunctionEx<? super T,? extends U> toKeyFn)
Serializable
variant ofjava.util.Comparator#thenComparing(Function)
.default <U> ComparatorEx<T>
ComparatorEx. thenComparing(FunctionEx<? super T,? extends U> toKeyFn, ComparatorEx<? super U> keyComparator)
Serializable
variant ofjava.util.Comparator#thenComparing(Function, Comparator)
. -
Uses of FunctionEx in com.hazelcast.jet.grpc
Methods in com.hazelcast.jet.grpc with parameters of type FunctionEx Modifier and Type Method Description static <T, R> ServiceFactory<?,? extends GrpcService<T,R>>
GrpcServices. bidirectionalStreamingService(SupplierEx<? extends io.grpc.ManagedChannelBuilder<?>> channelFn, FunctionEx<? super io.grpc.ManagedChannel,? extends FunctionEx<io.grpc.stub.StreamObserver<R>,io.grpc.stub.StreamObserver<T>>> callStubFn)
Creates aServiceFactory
that calls out to a bidrectional streaming gRPC service.static <T, R> ServiceFactory<?,? extends GrpcService<T,R>>
GrpcServices. unaryService(SupplierEx<? extends io.grpc.ManagedChannelBuilder<?>> channelFn, FunctionEx<? super io.grpc.ManagedChannel,? extends BiConsumerEx<T,io.grpc.stub.StreamObserver<R>>> callStubFn)
Creates aServiceFactory
that calls out to a unary gRPC service.Method parameters in com.hazelcast.jet.grpc with type arguments of type FunctionEx Modifier and Type Method Description static <T, R> ServiceFactory<?,? extends GrpcService<T,R>>
GrpcServices. bidirectionalStreamingService(SupplierEx<? extends io.grpc.ManagedChannelBuilder<?>> channelFn, FunctionEx<? super io.grpc.ManagedChannel,? extends FunctionEx<io.grpc.stub.StreamObserver<R>,io.grpc.stub.StreamObserver<T>>> callStubFn)
Creates aServiceFactory
that calls out to a bidrectional streaming gRPC service. -
Uses of FunctionEx in com.hazelcast.jet.hadoop
Methods in com.hazelcast.jet.hadoop with parameters of type FunctionEx Modifier and Type Method Description static <E, K, V> Sink<E>
HadoopSinks. outputFormat(org.apache.hadoop.conf.Configuration configuration, FunctionEx<? super E,K> extractKeyF, FunctionEx<? super E,V> extractValueF)
Returns a sink that writes to Apache Hadoop HDFS.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 FunctionEx in com.hazelcast.jet.kafka
Methods in com.hazelcast.jet.kafka with parameters of type FunctionEx Modifier and Type Method Description KafkaSinks.Builder<E>
KafkaSinks.Builder. extractKeyFn(FunctionEx<? super E,?> extractKeyFn)
Sets the function to extract the key from the stream items.KafkaSinks.Builder<E>
KafkaSinks.Builder. extractValueFn(FunctionEx<? super E,?> extractValueFn)
Sets the function to extract the value from the stream items.static <E, K, V> Sink<E>
KafkaSinks. kafka(Properties properties, FunctionEx<? super E,org.apache.kafka.clients.producer.ProducerRecord<K,V>> toRecordFn)
Returns a sink that publishes messages to Apache Kafka topic(s).static <E, K, V> Sink<E>
KafkaSinks. kafka(Properties properties, String topic, FunctionEx<? super E,K> extractKeyFn, FunctionEx<? super E,V> extractValueFn)
Convenience forKafkaSinks.kafka(Properties, FunctionEx)
which creates aProducerRecord
using the given topic and the given key and value mapping functionsstatic <K, V, T> StreamSource<T>
KafkaSources. kafka(Properties properties, FunctionEx<org.apache.kafka.clients.consumer.ConsumerRecord<K,V>,T> projectionFn, String... topics)
Returns a source that consumes one or more Apache Kafka topics and emits items from them asMap.Entry
instances.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...)
.KafkaSinks.Builder<E>
KafkaSinks.Builder. toRecordFn(FunctionEx<? super E,? extends org.apache.kafka.clients.producer.ProducerRecord<?,?>> toRecordFn)
Sets the function to convert stream items into Kafka'sProducerRecord
.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 FunctionEx in com.hazelcast.jet.python
Methods in com.hazelcast.jet.python that return FunctionEx Modifier and Type Method Description static <K> FunctionEx<StreamStage<String>,StreamStage<String>>
PythonTransforms. mapUsingPython(FunctionEx<? super String,? extends K> keyFn, PythonServiceConfig cfg)
A stage-transforming method that adds a partitioned "map using Python" pipeline stage.static FunctionEx<StreamStage<String>,StreamStage<String>>
PythonTransforms. mapUsingPython(PythonServiceConfig cfg)
A stage-transforming method that adds a "map using Python" pipeline stage.static <K> FunctionEx<BatchStage<String>,BatchStage<String>>
PythonTransforms. mapUsingPythonBatch(FunctionEx<? super String,? extends K> keyFn, PythonServiceConfig cfg)
A stage-transforming method that adds a partitioned "map using Python" pipeline stage.static FunctionEx<BatchStage<String>,BatchStage<String>>
PythonTransforms. mapUsingPythonBatch(PythonServiceConfig cfg)
A stage-transforming method that adds a "map using Python" pipeline stage.Methods in com.hazelcast.jet.python with parameters of type FunctionEx Modifier and Type Method Description static <K> FunctionEx<StreamStage<String>,StreamStage<String>>
PythonTransforms. mapUsingPython(FunctionEx<? super String,? extends K> keyFn, PythonServiceConfig cfg)
A stage-transforming method that adds a partitioned "map using Python" pipeline stage.static <K> FunctionEx<BatchStage<String>,BatchStage<String>>
PythonTransforms. mapUsingPythonBatch(FunctionEx<? super String,? extends K> keyFn, PythonServiceConfig cfg)
A stage-transforming method that adds a partitioned "map using Python" pipeline stage. -
Uses of FunctionEx in com.hazelcast.jet.s3
Methods in com.hazelcast.jet.s3 with parameters of type FunctionEx Modifier and Type Method Description static <T> Sink<? super T>
S3Sinks. s3(String bucketName, String prefix, Charset charset, SupplierEx<? extends software.amazon.awssdk.services.s3.S3Client> clientSupplier, FunctionEx<? super T,String> toStringFn)
Creates an AWS S3Sink
which writes items to files into the given bucket.static <I, T> BatchSource<T>
S3Sources. s3(List<String> bucketNames, String prefix, SupplierEx<? extends software.amazon.awssdk.services.s3.S3Client> clientSupplier, FunctionEx<? super InputStream,? extends Stream<I>> readFileFn, BiFunctionEx<String,? super I,? extends T> mapFn)
Creates an AWS S3BatchSource
which lists all the objects in the bucket-list using givenprefix
, reads them using providedreadFileFn
, transforms each read item to the desired output object using givenmapFn
and emits them to downstream.