| Package | Description | 
|---|---|
| com.hazelcast.connector | 
 Hazelcast 3 connector provides sources, sinks and enrichment using data
 in Hazelcast 3 remote cluster 
 | 
| com.hazelcast.jet.core.processor | 
 Contains static utility classes with factories of Jet processors. 
 | 
| 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.pipeline | 
 The Pipeline API is Jet's high-level API to build and execute
 distributed computation jobs. 
 | 
| com.hazelcast.spring.jet | 
 Provides Jet related Spring interfaces/classes for Hazelcast. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
static <K,V> ServiceFactory<Hz3MapAdapter,AsyncMap<K,V>> | 
Hz3Enrichment.hz3MapServiceFactory(String mapName,
                    String clientXML)
Create a service factory for enrichment using Hazelcast 3 remote map. 
 | 
static <K,V> ServiceFactory<Hz3MapAdapter,Map<K,V>> | 
Hz3Enrichment.hz3ReplicatedMapServiceFactory(String mapName,
                              String clientXML)
Create a service factory for enrichment using Hazelcast 3 remote replicated map. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
static <C,S,T> ProcessorSupplier | 
Processors.filterUsingServiceP(ServiceFactory<C,S> serviceFactory,
                   BiPredicateEx<? super S,? super T> filterFn)
Returns a supplier of processors for a vertex that emits the same items
 it receives, but only those that pass the given predicate. 
 | 
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> | 
Processors.mapUsingServiceAsyncP(ServiceFactory<C,S> serviceFactory,
                     int maxConcurrentOps,
                     boolean preserveOrder,
                     FunctionEx<T,K> extractKeyFn,
                     BiFunctionEx<? super S,? super T,CompletableFuture<R>> mapAsyncFn)
Asynchronous version of  
Processors.mapUsingServiceP(com.hazelcast.jet.pipeline.ServiceFactory<C, S>, com.hazelcast.function.BiFunctionEx<? super S, ? super T, ? extends R>): the mapAsyncFn returns a CompletableFuture<R> instead of just
 R. | 
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. 
 | 
| Modifier and Type | Method and 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 a  
ServiceFactory 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 a  
ServiceFactory that calls out to a
 unary gRPC service. | 
| Modifier and Type | Method and Description | 
|---|---|
protected ServiceFactory<C,S> | 
ServiceFactory.clone()  | 
static <K,V> ServiceFactory<?,IMap<K,V>> | 
ServiceFactories.iMapService(String mapName)
Returns a factory that provides an  
IMap as the service. | 
static <S> ServiceFactory<?,S> | 
ServiceFactories.nonSharedService(FunctionEx<? super Processor.Context,? extends S> createServiceFn)
A variant of  
nonSharedService(createFn, destroyFn) with a no-op destroyFn. | 
static <S> ServiceFactory<?,S> | 
ServiceFactories.nonSharedService(FunctionEx<? super Processor.Context,? extends S> createServiceFn,
                ConsumerEx<? super S> destroyServiceFn)
Returns a  
ServiceFactory which creates a separate service
 instance for each parallel Jet processor. | 
static <K,V> ServiceFactory<?,ReplicatedMap<K,V>> | 
ServiceFactories.replicatedMapService(String mapName)
Returns a factory that provides a  
ReplicatedMap as the service
 object. | 
static <S> ServiceFactory<?,S> | 
ServiceFactories.sharedService(FunctionEx<? super ProcessorSupplier.Context,S> createServiceFn)
A variant of  
sharedService(createFn, destroyFn) with a no-op destroyFn. | 
static <S> ServiceFactory<?,S> | 
ServiceFactories.sharedService(FunctionEx<? super ProcessorSupplier.Context,S> createServiceFn,
             ConsumerEx<S> destroyServiceFn)
Returns a  
ServiceFactory which will provide a single shared
 service object per cluster member. | 
ServiceFactory<C,S> | 
ServiceFactory.toNonCooperative()
Returns a copy of this  
ServiceFactory with the isCooperative flag set to false. | 
ServiceFactory<C,S> | 
ServiceFactory.withAttachedDirectory(String id,
                     File directory)
Attaches a directory to this service factory under the given ID. 
 | 
ServiceFactory<C,S> | 
ServiceFactory.withAttachedFile(String id,
                File file)
Attaches a file to this service factory under the given ID. 
 | 
static <C> ServiceFactory<C,Void> | 
ServiceFactory.withCreateContextFn(FunctionEx<? super ProcessorSupplier.Context,? extends C> createContextFn)
Creates a new  
ServiceFactory with the given function that
 creates the shared context object. | 
<S_NEW> ServiceFactory<C,S_NEW> | 
ServiceFactory.withCreateServiceFn(BiFunctionEx<? super Processor.Context,? super C,? extends S_NEW> createServiceFn)
Returns a copy of this  
ServiceFactory with the given createService function. | 
ServiceFactory<C,S> | 
ServiceFactory.withDestroyContextFn(ConsumerEx<? super C> destroyContextFn)
Returns a copy of this  
ServiceFactory with the destroyContext function replaced with the given function. | 
ServiceFactory<C,S> | 
ServiceFactory.withDestroyServiceFn(ConsumerEx<? super S> destroyServiceFn)
Returns a copy of this  
ServiceFactory with the destroyService function replaced with the given function. | 
ServiceFactory<C,S> | 
ServiceFactory.withoutAttachedFiles()
Returns a copy of this  
ServiceFactory with any attached files
 removed. | 
ServiceFactory<C,S> | 
ServiceFactory.withPermission(Permission permission)
Returns a copy of this  
ServiceFactory with setting the
 required permission. | 
| Modifier and Type | Method and Description | 
|---|---|
<S> StreamStage<T> | 
StreamStage.filterUsingService(ServiceFactory<?,S> serviceFactory,
                  BiPredicateEx<? super S,? super T> filterFn)  | 
<S> GeneralStage<T> | 
GeneralStage.filterUsingService(ServiceFactory<?,S> serviceFactory,
                  BiPredicateEx<? super S,? super T> filterFn)
Attaches a filtering stage which applies the provided predicate function
 to each input item to decide whether to pass the item to the output or
 to discard it. 
 | 
<S> BatchStage<T> | 
BatchStage.filterUsingService(ServiceFactory<?,S> serviceFactory,
                  BiPredicateEx<? super S,? super T> filterFn)  | 
<S> StreamStage<T> | 
StreamStageWithKey.filterUsingService(ServiceFactory<?,S> serviceFactory,
                  TriPredicate<? super S,? super K,? super T> filterFn)  | 
<S> GeneralStage<T> | 
GeneralStageWithKey.filterUsingService(ServiceFactory<?,S> serviceFactory,
                  TriPredicate<? super S,? super K,? super T> filterFn)
Deprecated. 
 
Jet now has first-class support for data rebalancing, see
  
GeneralStage.rebalance() and GeneralStage.rebalance(FunctionEx). | 
<S> BatchStage<T> | 
BatchStageWithKey.filterUsingService(ServiceFactory<?,S> serviceFactory,
                  TriPredicate<? super S,? super K,? super T> filterFn)  | 
<S,R> StreamStage<R> | 
StreamStage.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 the  
Traverser it returns as the output items. | 
<S,R> BatchStage<R> | 
BatchStage.flatMapUsingService(ServiceFactory<?,S> serviceFactory,
                   BiFunctionEx<? super S,? super T,? extends Traverser<R>> flatMapFn)  | 
<S,R> StreamStage<R> | 
StreamStageWithKey.flatMapUsingService(ServiceFactory<?,S> serviceFactory,
                   TriFunction<? super S,? super K,? super T,? extends Traverser<R>> flatMapFn)  | 
<S,R> GeneralStage<R> | 
GeneralStageWithKey.flatMapUsingService(ServiceFactory<?,S> serviceFactory,
                   TriFunction<? super S,? super K,? super T,? extends Traverser<R>> flatMapFn)
Deprecated. 
 
Jet now has first-class support for data rebalancing, see
  
GeneralStage.rebalance() and GeneralStage.rebalance(FunctionEx). | 
<S,R> BatchStage<R> | 
BatchStageWithKey.flatMapUsingService(ServiceFactory<?,S> serviceFactory,
                   TriFunction<? super S,? super K,? super T,? extends Traverser<R>> flatMapFn)  | 
<S,R> StreamStage<R> | 
StreamStage.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> BatchStage<R> | 
BatchStage.mapUsingService(ServiceFactory<?,S> serviceFactory,
               BiFunctionEx<? super S,? super T,? extends R> mapFn)  | 
<S,R> StreamStage<R> | 
StreamStageWithKey.mapUsingService(ServiceFactory<?,S> serviceFactory,
               TriFunction<? super S,? super K,? super T,? extends R> mapFn)  | 
<S,R> GeneralStage<R> | 
GeneralStageWithKey.mapUsingService(ServiceFactory<?,S> serviceFactory,
               TriFunction<? super S,? super K,? super T,? extends R> mapFn)
Deprecated. 
 
Jet now has first-class support for data rebalancing, see
  
GeneralStage.rebalance() and GeneralStage.rebalance(FunctionEx). | 
<S,R> BatchStage<R> | 
BatchStageWithKey.mapUsingService(ServiceFactory<?,S> serviceFactory,
               TriFunction<? super S,? super K,? super T,? extends R> mapFn)  | 
default <S,R> StreamStage<R> | 
StreamStage.mapUsingServiceAsync(ServiceFactory<?,S> serviceFactory,
                    BiFunctionEx<? super S,? super T,? extends CompletableFuture<R>> mapAsyncFn)  | 
default <S,R> GeneralStage<R> | 
GeneralStage.mapUsingServiceAsync(ServiceFactory<?,S> serviceFactory,
                    BiFunctionEx<? super S,? super T,? extends CompletableFuture<R>> mapAsyncFn)
Asynchronous version of  
GeneralStage.mapUsingService(com.hazelcast.jet.pipeline.ServiceFactory<?, S>, com.hazelcast.function.BiFunctionEx<? super S, ? super T, ? extends R>): the mapAsyncFn
 returns a CompletableFuture<R> instead of just R. | 
default <S,R> BatchStage<R> | 
BatchStage.mapUsingServiceAsync(ServiceFactory<?,S> serviceFactory,
                    BiFunctionEx<? super S,? super T,? extends CompletableFuture<R>> mapAsyncFn)  | 
<S,R> StreamStage<R> | 
StreamStage.mapUsingServiceAsync(ServiceFactory<?,S> serviceFactory,
                    int maxConcurrentOps,
                    boolean preserveOrder,
                    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 of  
GeneralStage.mapUsingService(com.hazelcast.jet.pipeline.ServiceFactory<?, S>, com.hazelcast.function.BiFunctionEx<? super S, ? super T, ? extends R>): the mapAsyncFn
 returns a CompletableFuture<R> instead of just R. | 
<S,R> BatchStage<R> | 
BatchStage.mapUsingServiceAsync(ServiceFactory<?,S> serviceFactory,
                    int maxConcurrentOps,
                    boolean preserveOrder,
                    BiFunctionEx<? super S,? super T,? extends CompletableFuture<R>> mapAsyncFn)  | 
<S,R> StreamStage<R> | 
StreamStageWithKey.mapUsingServiceAsync(ServiceFactory<?,S> serviceFactory,
                    int maxConcurrentOps,
                    boolean preserveOrder,
                    TriFunction<? super S,? super K,? super T,CompletableFuture<R>> mapAsyncFn)  | 
<S,R> GeneralStage<R> | 
GeneralStageWithKey.mapUsingServiceAsync(ServiceFactory<?,S> serviceFactory,
                    int maxConcurrentOps,
                    boolean preserveOrder,
                    TriFunction<? super S,? super K,? super T,CompletableFuture<R>> mapAsyncFn)
Deprecated. 
 
Jet now has first-class support for data rebalancing, see
  
GeneralStage.rebalance() and GeneralStage.rebalance(FunctionEx). | 
<S,R> BatchStage<R> | 
BatchStageWithKey.mapUsingServiceAsync(ServiceFactory<?,S> serviceFactory,
                    int maxConcurrentOps,
                    boolean preserveOrder,
                    TriFunction<? super S,? super K,? super T,CompletableFuture<R>> mapAsyncFn)  | 
default <S,R> StreamStage<R> | 
StreamStageWithKey.mapUsingServiceAsync(ServiceFactory<?,S> serviceFactory,
                    TriFunction<? super S,? super K,? super T,CompletableFuture<R>> mapAsyncFn)  | 
default <S,R> GeneralStage<R> | 
GeneralStageWithKey.mapUsingServiceAsync(ServiceFactory<?,S> serviceFactory,
                    TriFunction<? super S,? super K,? super T,CompletableFuture<R>> mapAsyncFn)
Deprecated. 
 
Jet now has first-class support for data rebalancing, see
  
GeneralStage.rebalance() and GeneralStage.rebalance(FunctionEx). | 
default <S,R> BatchStage<R> | 
BatchStageWithKey.mapUsingServiceAsync(ServiceFactory<?,S> serviceFactory,
                    TriFunction<? super S,? super K,? super T,CompletableFuture<R>> mapAsyncFn)  | 
<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)  | 
<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, see
  
GeneralStage.rebalance() and GeneralStage.rebalance(FunctionEx). | 
<S,R> GeneralStage<R> | 
GeneralStage.mapUsingServiceAsyncBatched(ServiceFactory<?,S> serviceFactory,
                           int maxBatchSize,
                           BiFunctionEx<? super S,? super List<T>,? extends CompletableFuture<List<R>>> mapAsyncFn)
Batched version of  
GeneralStage.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 a CompletableFuture<List<R>>. | 
<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> StreamStage<R> | 
StreamStageWithKey.mapUsingServiceAsyncBatched(ServiceFactory<?,S> serviceFactory,
                           int maxBatchSize,
                           TriFunction<? super S,? super List<K>,? super List<T>,? extends CompletableFuture<List<R>>> mapAsyncFn)  | 
<S,R> GeneralStage<R> | 
GeneralStageWithKey.mapUsingServiceAsyncBatched(ServiceFactory<?,S> serviceFactory,
                           int maxBatchSize,
                           TriFunction<? super S,? super List<K>,? super List<T>,? extends CompletableFuture<List<R>>> mapAsyncFn)
Deprecated. 
 
Jet now has first-class support for data rebalancing, see
  
GeneralStage.rebalance() and GeneralStage.rebalance(FunctionEx). | 
<S,R> BatchStage<R> | 
BatchStageWithKey.mapUsingServiceAsyncBatched(ServiceFactory<?,S> serviceFactory,
                           int maxBatchSize,
                           TriFunction<? super S,? super List<K>,? super List<T>,? extends CompletableFuture<List<R>>> mapAsyncFn)  | 
| Modifier and Type | Method and Description | 
|---|---|
static <T> ServiceFactory<?,T> | 
JetSpringServiceFactories.bean(Class<T> requiredType)
Returns a Spring Bean  
ServiceFactory. | 
static <T> ServiceFactory<?,T> | 
JetSpringServiceFactories.bean(String beanName)
Returns a Spring Bean  
ServiceFactory. | 
static <T> ServiceFactory<?,T> | 
JetSpringServiceFactories.bean(String beanName,
    Class<T> requiredType)
Returns a Spring Bean  
ServiceFactory. | 
Copyright © 2022 Hazelcast, Inc.. All rights reserved.