Uses of Interface
com.hazelcast.function.BiFunctionEx
Package
Description
Serializable and exception-declaring variants of functional interfaces from
java.util.function
.Contains
AggregateOperation
and its several variants, as well
as a builder object for the aggregate operations.Apache Avro file read/write support for Hazelcast Jet.
Contains static utility classes with factories of Jet processors.
Apache Hadoop read/write support for Hazelcast Jet.
Amazon Kinesis Data Streams producer/consumer support for Hazelcast Jet.
Contains sources and sinks for MongoDB.
The Pipeline API is Jet's high-level API to build and execute
distributed computation jobs.
Contributes a
PythonTransforms.mapUsingPython(com.hazelcast.jet.python.PythonServiceConfig)
transform that allows you to transform Jet pipeline data using a Python
function.AWS S3 read/write support for Hazelcast Jet.
-
Uses of BiFunctionEx in com.hazelcast.function
Modifier and TypeMethodDescriptiondefault <V> BiFunctionEx<T,
U, V> BiFunctionEx.andThen
(FunctionEx<? super R, ? extends V> after) Serializable
variant ofjava.util.function.BiFunction#andThen(Function)
. -
Uses of BiFunctionEx in com.hazelcast.jet.aggregate
Modifier and TypeMethodDescriptionstatic <T0,
A0, R0, T1, A1, R1, R>
AggregateOperation2<T0,T1, Tuple2<A0, A1>, R> AggregateOperations.aggregateOperation2
(AggregateOperation1<? super T0, A0, ? extends R0> op0, AggregateOperation1<? super T1, A1, ? extends R1> op1, BiFunctionEx<? super R0, ? super R1, ? extends R> exportFinishFn) Returns an aggregate operation that is a composite of two independent aggregate operations, each one accepting its own input.static <T,
A0, A1, R0, R1, R>
AggregateOperation1<T,Tuple2<A0, A1>, R> AggregateOperations.allOf
(AggregateOperation1<? super T, A0, ? extends R0> op0, AggregateOperation1<? super T, A1, ? extends R1> op1, BiFunctionEx<? super R0, ? super R1, ? extends R> exportFinishFn) Returns an aggregate operation that is a composite of two aggregate operations. -
Uses of BiFunctionEx in com.hazelcast.jet.avro
Modifier and TypeMethodDescription<T> BatchSource<T>
AvroSourceBuilder.build
(BiFunctionEx<String, ? super D, T> mapOutputFn) Builds a custom Avro fileBatchSource
with supplied components and the output functionmapOutputFn
.static <D> BatchSource<D>
AvroSources.files
(String directory, BiFunctionEx<String, org.apache.avro.generic.GenericRecord, D> mapOutputFn) Convenience forAvroSources.filesBuilder(String, SupplierEx)
which reads all the files in the supplied directory as generic records and emits the results of transforming each generic record with the supplied mapping function.static <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>)
. -
Uses of BiFunctionEx in com.hazelcast.jet.core.processor
Modifier and TypeMethodDescriptionstatic <K,
A, R, OUT>
SupplierEx<Processor>Processors.aggregateByKeyP
(List<FunctionEx<?, ? extends K>> keyFns, AggregateOperation<A, R> aggrOp, BiFunctionEx<? super K, ? super R, OUT> mapToOutputFn) Returns a supplier of processors for a vertex that groups items by key and performs the provided aggregate operation on each group.static <K,
A, R, OUT>
SupplierEx<Processor>Processors.combineByKeyP
(AggregateOperation<A, R> aggrOp, BiFunctionEx<? super K, ? super R, OUT> mapToOutputFn) Returns a supplier of processors for the second-stage vertex in a two-stage group-and-aggregate setup.static <C,
S, T, R> ProcessorSupplier Processors.flatMapUsingServiceP
(ServiceFactory<C, S> serviceFactory, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>> flatMapFn) Returns a supplier of processors for a vertex that applies the provided item-to-traverser mapping function to each received item and emits all the items from the resulting traverser.static <C,
S, T, K, R>
ProcessorSupplierProcessors.mapUsingServiceAsyncP
(ServiceFactory<C, S> serviceFactory, int maxConcurrentOps, boolean preserveOrder, FunctionEx<T, K> extractKeyFn, BiFunctionEx<? super S, ? super T, CompletableFuture<R>> mapAsyncFn) Asynchronous version ofProcessors.mapUsingServiceP(com.hazelcast.jet.pipeline.ServiceFactory<C, S>, com.hazelcast.function.BiFunctionEx<? super S, ? super T, ? extends R>)
: themapAsyncFn
returns aCompletableFuture<R>
instead of justR
.static <C,
S, T, R> ProcessorSupplier Processors.mapUsingServiceP
(ServiceFactory<C, S> serviceFactory, BiFunctionEx<? super S, ? super T, ? extends R> mapFn) Returns a supplier of processors for a vertex which, for each received item, emits the result of applying the given mapping function to it.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 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,
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> 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> 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>)
. -
Uses of BiFunctionEx in com.hazelcast.jet.hadoop
Modifier and TypeMethodDescriptionstatic <K,
V, E> BatchSource<E> HadoopSources.inputFormat
(ConsumerEx<org.apache.hadoop.conf.Configuration> configureFn, BiFunctionEx<K, V, E> projectionFn) Returns a source that reads records from Apache Hadoop HDFS and emits the results of transforming each record (a key-value pair) with the supplied projection function.static <K,
V, E> BatchSource<E> HadoopSources.inputFormat
(org.apache.hadoop.conf.Configuration configuration, BiFunctionEx<K, V, E> projectionFn) Returns a source that reads records from Apache Hadoop HDFS and emits the results of transforming each record (a key-value pair) with the supplied projection function.static <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)
. -
Uses of BiFunctionEx in com.hazelcast.jet.kinesis
Modifier and TypeMethodDescription<T_NEW> KinesisSources.Builder<T_NEW>
KinesisSources.Builder.withProjectionFn
(BiFunctionEx<com.amazonaws.services.kinesis.model.Record, com.amazonaws.services.kinesis.model.Shard, T_NEW> projectionFn) Specifies projection function, that will map inputRecord
andShard
from which this record was read into user-defined type. -
Uses of BiFunctionEx in com.hazelcast.jet.mongodb
Modifier and TypeMethodDescription<T_NEW> MongoSourceBuilder.Stream<T_NEW>
MongoSourceBuilder.Stream.mapFn
(BiFunctionEx<com.mongodb.client.model.changestream.ChangeStreamDocument<org.bson.Document>, Long, T_NEW> mapFn) -
Uses of BiFunctionEx in com.hazelcast.jet.pipeline
Modifier and TypeMethodDescriptionBiFunctionEx<? super Processor.Context,
? super C, ? extends S> ServiceFactory.createServiceFn()
Returns the function that creates the service object.Modifier and TypeMethodDescription<T> BatchSource<T>
FileSourceBuilder.build
(BiFunctionEx<String, String, ? extends T> mapOutputFn) Deprecated.<R,
OUT> BatchStage<OUT> GroupAggregateBuilder1.build
(AggregateOperation<?, R> aggrOp, BiFunctionEx<? super K, ? super R, OUT> mapToOutputFn) Deprecated.This is a leftover from an earlier development cycle of the Pipeline API.<R> BatchStage<R>
HashJoinBuilder.build
(BiFunctionEx<T0, ItemsByTag, R> mapToOutputFn) Builds a new pipeline stage that performs the hash-join operation.<R> StreamStage<R>
StreamHashJoinBuilder.build
(BiFunctionEx<T0, ItemsByTag, R> mapToOutputFn) Builds a new pipeline stage that performs the hash-join operation.<T> StreamSource<T>
FileSourceBuilder.buildWatcher
(BiFunctionEx<String, String, ? extends T> mapOutputFn) Builds a source that emits a stream of lines of text coming from files in the watched directory (but not its subdirectories).<S,
R> BatchStage<R> BatchStage.flatMapStateful
(SupplierEx<? extends S> createFn, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>> flatMapFn) <S,
R> GeneralStage<R> GeneralStage.flatMapStateful
(SupplierEx<? extends S> createFn, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>> flatMapFn) Attaches a stage that performs a stateful flat-mapping operation.<S,
R> StreamStage<R> StreamStage.flatMapStateful
(SupplierEx<? extends S> createFn, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>> flatMapFn) <S,
R> BatchStage<R> BatchStage.flatMapUsingService
(ServiceFactory<?, S> serviceFactory, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>> flatMapFn) <S,
R> GeneralStage<R> GeneralStage.flatMapUsingService
(ServiceFactory<?, S> serviceFactory, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>> flatMapFn) Attaches a flat-mapping stage which applies the supplied function to each input item independently and emits all items from theTraverser
it returns as the output items.<S,
R> StreamStage<R> StreamStage.flatMapUsingService
(ServiceFactory<?, S> serviceFactory, BiFunctionEx<? super S, ? super T, ? extends Traverser<R>> flatMapFn) <K,
T1_IN, T1, R>
BatchStage<R>BatchStage.hashJoin
(BatchStage<T1_IN> stage1, JoinClause<K, ? super T, ? super T1_IN, ? extends T1> joinClause1, BiFunctionEx<T, T1, R> mapToOutputFn) <K,
T1_IN, T1, R>
GeneralStage<R>GeneralStage.hashJoin
(BatchStage<T1_IN> stage1, JoinClause<K, ? super T, ? super T1_IN, ? extends T1> joinClause1, BiFunctionEx<T, T1, R> mapToOutputFn) Attaches to both this and the supplied stage a hash-joining stage and returns it.<K,
T1_IN, T1, R>
StreamStage<R>StreamStage.hashJoin
(BatchStage<T1_IN> stage1, JoinClause<K, ? super T, ? super T1_IN, ? extends T1> joinClause1, BiFunctionEx<T, T1, R> mapToOutputFn) <K,
T1_IN, T1, R>
BatchStage<R>BatchStage.innerHashJoin
(BatchStage<T1_IN> stage1, JoinClause<K, ? super T, ? super T1_IN, ? extends T1> joinClause1, BiFunctionEx<T, T1, R> mapToOutputFn) <K,
T1_IN, T1, R>
GeneralStage<R>GeneralStage.innerHashJoin
(BatchStage<T1_IN> stage1, JoinClause<K, ? super T, ? super T1_IN, ? extends T1> joinClause1, BiFunctionEx<T, T1, R> mapToOutputFn) Attaches to both this and the supplied stage an inner hash-joining stage and returns it.<K,
T1_IN, T1, R>
StreamStage<R>StreamStage.innerHashJoin
(BatchStage<T1_IN> stage1, JoinClause<K, ? super T, ? super T1_IN, ? extends T1> joinClause1, BiFunctionEx<T, T1, R> mapToOutputFn) <S,
R> BatchStage<R> BatchStage.mapStateful
(SupplierEx<? extends S> createFn, BiFunctionEx<? super S, ? super T, ? extends R> mapFn) <S,
R> GeneralStage<R> GeneralStage.mapStateful
(SupplierEx<? extends S> createFn, BiFunctionEx<? super S, ? super T, ? extends R> mapFn) Attaches a stage that performs a stateful mapping operation.<S,
R> StreamStage<R> StreamStage.mapStateful
(SupplierEx<? extends S> createFn, BiFunctionEx<? super S, ? super T, ? extends R> mapFn) default <K,
V, R> BatchStage<R> BatchStage.mapUsingIMap
(IMap<K, V> iMap, FunctionEx<? super T, ? extends K> lookupKeyFn, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) default <K,
V, R> BatchStage<R> BatchStage.mapUsingIMap
(String mapName, FunctionEx<? super T, ? extends K> lookupKeyFn, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) default <V,
R> BatchStage<R> BatchStageWithKey.mapUsingIMap
(IMap<K, V> iMap, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) default <V,
R> BatchStage<R> BatchStageWithKey.mapUsingIMap
(String mapName, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) default <K,
V, R> GeneralStage<R> GeneralStage.mapUsingIMap
(IMap<K, V> iMap, FunctionEx<? super T, ? extends K> lookupKeyFn, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) Attaches a mapping stage where for each item a lookup in the suppliedIMap
is performed and the result of the lookup is merged with the item and emitted.default <K,
V, R> GeneralStage<R> GeneralStage.mapUsingIMap
(String mapName, FunctionEx<? super T, ? extends K> lookupKeyFn, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) Attaches a mapping stage where for each item a lookup in theIMap
with the supplied name is performed and the result of the lookup is merged with the item and emitted.default <V,
R> GeneralStage<R> GeneralStageWithKey.mapUsingIMap
(IMap<K, V> iMap, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) Attaches a mapping stage where for each item a lookup in the suppliedIMap
using the grouping key is performed and the result of the lookup is merged with the item and emitted.default <V,
R> GeneralStage<R> GeneralStageWithKey.mapUsingIMap
(String mapName, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) Attaches a mapping stage where for each item a lookup in theIMap
with the supplied name using the grouping key is performed and the result of the lookup is merged with the item and emitted.default <K,
V, R> StreamStage<R> StreamStage.mapUsingIMap
(IMap<K, V> iMap, FunctionEx<? super T, ? extends K> lookupKeyFn, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) default <K,
V, R> StreamStage<R> StreamStage.mapUsingIMap
(String mapName, FunctionEx<? super T, ? extends K> lookupKeyFn, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) default <V,
R> StreamStage<R> StreamStageWithKey.mapUsingIMap
(IMap<K, V> iMap, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) default <V,
R> StreamStage<R> StreamStageWithKey.mapUsingIMap
(String mapName, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) default <K,
V, R> BatchStage<R> BatchStage.mapUsingReplicatedMap
(ReplicatedMap<K, V> replicatedMap, FunctionEx<? super T, ? extends K> lookupKeyFn, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) default <K,
V, R> BatchStage<R> BatchStage.mapUsingReplicatedMap
(String mapName, FunctionEx<? super T, ? extends K> lookupKeyFn, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) default <K,
V, R> GeneralStage<R> GeneralStage.mapUsingReplicatedMap
(ReplicatedMap<K, V> replicatedMap, FunctionEx<? super T, ? extends K> lookupKeyFn, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) Attaches a mapping stage where for each item a lookup in the suppliedReplicatedMap
is performed and the result of the lookup is merged with the item and emitted.default <K,
V, R> GeneralStage<R> GeneralStage.mapUsingReplicatedMap
(String mapName, FunctionEx<? super T, ? extends K> lookupKeyFn, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) Attaches a mapping stage where for each item a lookup in theReplicatedMap
with the supplied name is performed and the result of the lookup is merged with the item and emitted.default <K,
V, R> StreamStage<R> StreamStage.mapUsingReplicatedMap
(ReplicatedMap<K, V> replicatedMap, FunctionEx<? super T, ? extends K> lookupKeyFn, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) default <K,
V, R> StreamStage<R> StreamStage.mapUsingReplicatedMap
(String mapName, FunctionEx<? super T, ? extends K> lookupKeyFn, BiFunctionEx<? super T, ? super V, ? extends R> mapFn) <S,
R> BatchStage<R> BatchStage.mapUsingService
(ServiceFactory<?, S> serviceFactory, BiFunctionEx<? super S, ? super T, ? extends R> mapFn) <S,
R> GeneralStage<R> GeneralStage.mapUsingService
(ServiceFactory<?, S> serviceFactory, BiFunctionEx<? super S, ? super T, ? extends R> mapFn) Attaches a mapping stage which applies the supplied function to each input item independently and emits the function's result as the output item.<S,
R> StreamStage<R> StreamStage.mapUsingService
(ServiceFactory<?, S> serviceFactory, BiFunctionEx<? super S, ? super T, ? extends R> mapFn) <S,
R> BatchStage<R> BatchStage.mapUsingServiceAsync
(ServiceFactory<?, S> serviceFactory, int maxConcurrentOps, boolean preserveOrder, BiFunctionEx<? super S, ? super T, ? extends CompletableFuture<R>> mapAsyncFn) default <S,
R> BatchStage<R> BatchStage.mapUsingServiceAsync
(ServiceFactory<?, S> serviceFactory, BiFunctionEx<? super S, ? super T, ? extends CompletableFuture<R>> mapAsyncFn) <S,
R> GeneralStage<R> GeneralStage.mapUsingServiceAsync
(ServiceFactory<?, S> serviceFactory, int maxConcurrentOps, boolean preserveOrder, BiFunctionEx<? super S, ? super T, ? extends CompletableFuture<R>> mapAsyncFn) Asynchronous version ofGeneralStage.mapUsingService(com.hazelcast.jet.pipeline.ServiceFactory<?, S>, com.hazelcast.function.BiFunctionEx<? super S, ? super T, ? extends R>)
: themapAsyncFn
returns aCompletableFuture<R>
instead of justR
.default <S,
R> GeneralStage<R> GeneralStage.mapUsingServiceAsync
(ServiceFactory<?, S> serviceFactory, BiFunctionEx<? super S, ? super T, ? extends CompletableFuture<R>> mapAsyncFn) Asynchronous version ofGeneralStage.mapUsingService(com.hazelcast.jet.pipeline.ServiceFactory<?, S>, com.hazelcast.function.BiFunctionEx<? super S, ? super T, ? extends R>)
: themapAsyncFn
returns aCompletableFuture<R>
instead of justR
.<S,
R> StreamStage<R> StreamStage.mapUsingServiceAsync
(ServiceFactory<?, S> serviceFactory, int maxConcurrentOps, boolean preserveOrder, BiFunctionEx<? super S, ? super T, ? extends CompletableFuture<R>> mapAsyncFn) default <S,
R> StreamStage<R> StreamStage.mapUsingServiceAsync
(ServiceFactory<?, S> serviceFactory, BiFunctionEx<? super S, ? super T, ? extends CompletableFuture<R>> mapAsyncFn) <S,
R> BatchStage<R> BatchStage.mapUsingServiceAsyncBatched
(ServiceFactory<?, S> serviceFactory, int maxBatchSize, BiFunctionEx<? super S, ? super List<T>, ? extends CompletableFuture<List<R>>> mapAsyncFn) <S,
R> BatchStage<R> BatchStageWithKey.mapUsingServiceAsyncBatched
(ServiceFactory<?, S> serviceFactory, int maxBatchSize, BiFunctionEx<? super S, ? super List<T>, ? extends CompletableFuture<List<R>>> mapAsyncFn) <S,
R> GeneralStage<R> GeneralStage.mapUsingServiceAsyncBatched
(ServiceFactory<?, S> serviceFactory, int maxBatchSize, BiFunctionEx<? super S, ? super List<T>, ? extends CompletableFuture<List<R>>> mapAsyncFn) Batched version ofGeneralStage.mapUsingServiceAsync(com.hazelcast.jet.pipeline.ServiceFactory<?, S>, com.hazelcast.function.BiFunctionEx<? super S, ? super T, ? extends java.util.concurrent.CompletableFuture<R>>)
:mapAsyncFn
takes a list of input items and returns aCompletableFuture<List<R>>
.<S,
R> GeneralStage<R> GeneralStageWithKey.mapUsingServiceAsyncBatched
(ServiceFactory<?, S> serviceFactory, int maxBatchSize, BiFunctionEx<? super S, ? super List<T>, ? extends CompletableFuture<List<R>>> mapAsyncFn) Deprecated.Jet now has first-class support for data rebalancing, seeGeneralStage.rebalance()
andGeneralStage.rebalance(FunctionEx)
.<S,
R> StreamStage<R> StreamStage.mapUsingServiceAsyncBatched
(ServiceFactory<?, S> serviceFactory, int maxBatchSize, BiFunctionEx<? super S, ? super List<T>, ? extends CompletableFuture<List<R>>> mapAsyncFn) <S,
R> StreamStage<R> StreamStageWithKey.mapUsingServiceAsyncBatched
(ServiceFactory<?, S> serviceFactory, int maxBatchSize, BiFunctionEx<? super S, ? super List<T>, ? extends CompletableFuture<List<R>>> mapAsyncFn) Sinks.mapWithUpdating
(IMap<? super K, ? super V> map, BiFunctionEx<? super V, ? super E, ? extends V> updateFn) Convenience forSinks.mapWithUpdating(IMap, FunctionEx, BiFunctionEx)
withMap.Entry
as the input item.static <T,
K, V> Sink<T> Sinks.mapWithUpdating
(IMap<? super K, ? super V> map, FunctionEx<? super T, ? extends K> toKeyFn, BiFunctionEx<? super V, ? super T, ? extends V> updateFn) Returns a sink that uses the supplied key-extracting and value-updating functions to update a HazelcastIMap
.Sinks.mapWithUpdating
(String mapName, BiFunctionEx<? super V, ? super E, ? extends V> updateFn) Convenience forSinks.mapWithUpdating(String, FunctionEx, BiFunctionEx)
withMap.Entry
as the input item.static <T,
K, V> Sink<T> Sinks.mapWithUpdating
(String mapName, FunctionEx<? super T, ? extends K> toKeyFn, BiFunctionEx<? super V, ? super T, ? extends V> updateFn) Returns a sink that uses the supplied key-extracting and value-updating functions to update a HazelcastIMap
.JmsSinkBuilder.messageFn
(BiFunctionEx<jakarta.jms.Session, T, jakarta.jms.Message> messageFn) Sets the function which creates the message from the item.Sinks.remoteMapWithUpdating
(String mapName, ClientConfig clientConfig, BiFunctionEx<? super V, ? super E, ? extends V> updateFn) static <T,
K, V> Sink<T> Sinks.remoteMapWithUpdating
(String mapName, ClientConfig clientConfig, FunctionEx<? super T, ? extends K> toKeyFn, BiFunctionEx<? super V, ? super T, ? extends V> updateFn) Returns a sink equivalent toSinks.mapWithUpdating(java.lang.String, com.hazelcast.function.FunctionEx<? super T, ? extends K>, com.hazelcast.function.BiFunctionEx<? super V, ? super T, ? extends V>)
, but for a map in a remote Hazelcast cluster identified by the suppliedClientConfig
.Sinks.remoteMapWithUpdating
(String mapName, DataConnectionRef dataConnectionRef, BiFunctionEx<? super V, ? super E, ? extends V> updateFn) The same as theSinks.remoteMapWithUpdating(String, ClientConfig, BiFunctionEx)
method.static <T,
K, V> Sink<T> Sinks.remoteMapWithUpdating
(String mapName, DataConnectionRef dataConnectionRef, FunctionEx<? super T, ? extends K> toKeyFn, BiFunctionEx<? super V, ? super T, ? extends V> updateFn) The same as theSinks.remoteMapWithUpdating(String, ClientConfig, BiFunctionEx)
method.MapSinkBuilder.updateFn
(BiFunctionEx<? super V, ? super T, ? extends V> updateFn) Set the function to update the value in Hazelcast IMap.<S_NEW> ServiceFactory<C,
S_NEW> ServiceFactory.withCreateServiceFn
(BiFunctionEx<? super Processor.Context, ? super C, ? extends S_NEW> createServiceFn) Returns a copy of thisServiceFactory
with the givencreateService
function. -
Uses of BiFunctionEx in com.hazelcast.jet.python
Modifier and TypeMethodDescriptionBiFunctionEx<String,
Integer, ? extends io.grpc.ManagedChannelBuilder<?>> PythonServiceConfig.channelFn()
Modifier and TypeMethodDescriptionPythonServiceConfig.setChannelFn
(BiFunctionEx<String, Integer, ? extends io.grpc.ManagedChannelBuilder<?>> channelFn) Sets the channel function. -
Uses of BiFunctionEx in com.hazelcast.jet.s3
Modifier and TypeMethodDescriptionstatic <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.static <I,
T> BatchSource<T> S3Sources.s3
(List<String> bucketNames, String prefix, SupplierEx<? extends software.amazon.awssdk.services.s3.S3Client> clientSupplier, TriFunction<? super InputStream, String, String, ? 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.static <T> BatchSource<T>
S3Sources.s3
(List<String> bucketNames, String prefix, Charset charset, SupplierEx<? extends software.amazon.awssdk.services.s3.S3Client> clientSupplier, BiFunctionEx<String, String, ? extends T> mapFn) Creates an AWS S3BatchSource
which lists all the objects in the bucket-list using givenprefix
, reads them line by line, transforms each line to the desired output object using givenmapFn
and emits them to downstream.
FileSources.files(java.lang.String)
.