| Package | Description | 
|---|---|
| com.hazelcast.jet.aggregate | 
 Contains  
AggregateOperation and its several variants, as well
 as a builder object for the aggregate operations. | 
| com.hazelcast.jet.core.processor | 
 Contains static utility classes with factories of Jet processors. 
 | 
| com.hazelcast.jet.pipeline | 
 The Pipeline API is Jet's high-level API to build and execute
 distributed computation jobs. 
 | 
| com.hazelcast.jet.s3 | 
 AWS S3 read/write support for Hazelcast Jet. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
static <T0,T1,T2,A0,A1,A2,R0,R1,R2,R> | 
AggregateOperations.aggregateOperation3(AggregateOperation1<? super T0,A0,? extends R0> op0,
                   AggregateOperation1<? super T1,A1,? extends R1> op1,
                   AggregateOperation1<? super T2,A2,? extends R2> op2,
                   TriFunction<? super R0,? super R1,? super R2,? extends R> exportFinishFn)
Returns an aggregate operation that is a composite of three independent
 aggregate operations, each one accepting its own input. 
 | 
static <T,A0,A1,A2,R0,R1,R2,R> | 
AggregateOperations.allOf(AggregateOperation1<? super T,A0,? extends R0> op0,
     AggregateOperation1<? super T,A1,? extends R1> op1,
     AggregateOperation1<? super T,A2,? extends R2> op2,
     TriFunction<? super R0,? super R1,? super R2,? extends R> exportFinishFn)
Returns an aggregate operation that is a composite of three aggregate
 operations. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
static <T,K,S,R> SupplierEx<Processor> | 
Processors.flatMapStatefulP(long ttl,
                FunctionEx<? super T,? extends K> keyFn,
                ToLongFunctionEx<? super T> timestampFn,
                Supplier<? extends S> createFn,
                TriFunction<? super S,? super K,? super T,? extends Traverser<R>> statefulFlatMapFn,
                TriFunction<? super S,? super K,? super Long,? extends Traverser<R>> onEvictFn)
Returns a supplier of processors for a vertex that performs a stateful
 flat-mapping of its input. 
 | 
static <T,K,S,R> SupplierEx<Processor> | 
Processors.flatMapStatefulP(long ttl,
                FunctionEx<? super T,? extends K> keyFn,
                ToLongFunctionEx<? super T> timestampFn,
                Supplier<? extends S> createFn,
                TriFunction<? super S,? super K,? super T,? extends Traverser<R>> statefulFlatMapFn,
                TriFunction<? super S,? super K,? super Long,? extends Traverser<R>> onEvictFn)
Returns a supplier of processors for a vertex that performs a stateful
 flat-mapping of its input. 
 | 
static <T,K,S,R> SupplierEx<Processor> | 
Processors.mapStatefulP(long ttl,
            FunctionEx<? super T,? extends K> keyFn,
            ToLongFunctionEx<? super T> timestampFn,
            Supplier<? extends S> createFn,
            TriFunction<? super S,? super K,? super T,? extends R> statefulMapFn,
            TriFunction<? super S,? super K,? super Long,? extends R> onEvictFn)
Returns a supplier of processors for a vertex that performs a stateful
 mapping of its input. 
 | 
static <T,K,S,R> SupplierEx<Processor> | 
Processors.mapStatefulP(long ttl,
            FunctionEx<? super T,? extends K> keyFn,
            ToLongFunctionEx<? super T> timestampFn,
            Supplier<? extends S> createFn,
            TriFunction<? super S,? super K,? super T,? extends R> statefulMapFn,
            TriFunction<? super S,? super K,? super Long,? extends R> onEvictFn)
Returns a supplier of processors for a vertex that performs a stateful
 mapping of its input. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
<S,R> StreamStage<R> | 
StreamStageWithKey.flatMapStateful(long ttl,
               SupplierEx<? extends S> createFn,
               TriFunction<? super S,? super K,? super T,? extends Traverser<R>> flatMapFn,
               TriFunction<? super S,? super K,? super Long,? extends Traverser<R>> onEvictFn)
Attaches a stage that performs a stateful flat-mapping operation. 
 | 
<S,R> StreamStage<R> | 
StreamStageWithKey.flatMapStateful(long ttl,
               SupplierEx<? extends S> createFn,
               TriFunction<? super S,? super K,? super T,? extends Traverser<R>> flatMapFn,
               TriFunction<? super S,? super K,? super Long,? extends Traverser<R>> onEvictFn)
Attaches a stage that performs a stateful flat-mapping operation. 
 | 
<S,R> StreamStage<R> | 
StreamStageWithKey.flatMapStateful(SupplierEx<? extends S> createFn,
               TriFunction<? super S,? super K,? super T,? extends Traverser<R>> flatMapFn)  | 
<S,R> BatchStage<R> | 
BatchStageWithKey.flatMapStateful(SupplierEx<? extends S> createFn,
               TriFunction<? super S,? super K,? super T,? extends Traverser<R>> flatMapFn)  | 
<S,R> GeneralStage<R> | 
GeneralStageWithKey.flatMapStateful(SupplierEx<? extends S> createFn,
               TriFunction<? super S,? super K,? super T,? extends Traverser<R>> flatMapFn)
Attaches a stage that performs a stateful flat-mapping operation. 
 | 
<S,R> StreamStage<R> | 
StreamStageWithKey.flatMapUsingService(ServiceFactory<?,S> serviceFactory,
                   TriFunction<? super S,? super K,? super T,? extends Traverser<R>> flatMapFn)  | 
<S,R> BatchStage<R> | 
BatchStageWithKey.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). | 
<K1,K2,T1_IN,T2_IN,T1,T2,R> | 
BatchStage.hashJoin2(BatchStage<T1_IN> stage1,
         JoinClause<K1,? super T,? super T1_IN,? extends T1> joinClause1,
         BatchStage<T2_IN> stage2,
         JoinClause<K2,? super T,? super T2_IN,? extends T2> joinClause2,
         TriFunction<T,T1,T2,R> mapToOutputFn)  | 
<K1,K2,T1_IN,T2_IN,T1,T2,R> | 
GeneralStage.hashJoin2(BatchStage<T1_IN> stage1,
         JoinClause<K1,? super T,? super T1_IN,? extends T1> joinClause1,
         BatchStage<T2_IN> stage2,
         JoinClause<K2,? super T,? super T2_IN,? extends T2> joinClause2,
         TriFunction<T,T1,T2,R> mapToOutputFn)
Attaches to this and the two supplied stages a hash-joining stage and
 returns it. 
 | 
<K1,K2,T1_IN,T2_IN,T1,T2,R> | 
StreamStage.hashJoin2(BatchStage<T1_IN> stage1,
         JoinClause<K1,? super T,? super T1_IN,? extends T1> joinClause1,
         BatchStage<T2_IN> stage2,
         JoinClause<K2,? super T,? super T2_IN,? extends T2> joinClause2,
         TriFunction<T,T1,T2,R> mapToOutputFn)  | 
<K1,K2,T1_IN,T2_IN,T1,T2,R> | 
BatchStage.innerHashJoin2(BatchStage<T1_IN> stage1,
              JoinClause<K1,? super T,? super T1_IN,? extends T1> joinClause1,
              BatchStage<T2_IN> stage2,
              JoinClause<K2,? super T,? super T2_IN,? extends T2> joinClause2,
              TriFunction<T,T1,T2,R> mapToOutputFn)  | 
<K1,K2,T1_IN,T2_IN,T1,T2,R> | 
GeneralStage.innerHashJoin2(BatchStage<T1_IN> stage1,
              JoinClause<K1,? super T,? super T1_IN,? extends T1> joinClause1,
              BatchStage<T2_IN> stage2,
              JoinClause<K2,? super T,? super T2_IN,? extends T2> joinClause2,
              TriFunction<T,T1,T2,R> mapToOutputFn)
Attaches to this and the two supplied stages a inner hash-joining stage
 and returns it. 
 | 
<K1,K2,T1_IN,T2_IN,T1,T2,R> | 
StreamStage.innerHashJoin2(BatchStage<T1_IN> stage1,
              JoinClause<K1,? super T,? super T1_IN,? extends T1> joinClause1,
              BatchStage<T2_IN> stage2,
              JoinClause<K2,? super T,? super T2_IN,? extends T2> joinClause2,
              TriFunction<T,T1,T2,R> mapToOutputFn)  | 
<S,R> StreamStage<R> | 
StreamStageWithKey.mapStateful(long ttl,
           SupplierEx<? extends S> createFn,
           TriFunction<? super S,? super K,? super T,? extends R> mapFn,
           TriFunction<? super S,? super K,? super Long,? extends R> onEvictFn)
Attaches a stage that performs a stateful mapping operation. 
 | 
<S,R> StreamStage<R> | 
StreamStageWithKey.mapStateful(long ttl,
           SupplierEx<? extends S> createFn,
           TriFunction<? super S,? super K,? super T,? extends R> mapFn,
           TriFunction<? super S,? super K,? super Long,? extends R> onEvictFn)
Attaches a stage that performs a stateful mapping operation. 
 | 
<S,R> StreamStage<R> | 
StreamStageWithKey.mapStateful(SupplierEx<? extends S> createFn,
           TriFunction<? super S,? super K,? super T,? extends R> mapFn)  | 
<S,R> BatchStage<R> | 
BatchStageWithKey.mapStateful(SupplierEx<? extends S> createFn,
           TriFunction<? super S,? super K,? super T,? extends R> mapFn)  | 
<S,R> GeneralStage<R> | 
GeneralStageWithKey.mapStateful(SupplierEx<? extends S> createFn,
           TriFunction<? super S,? super K,? super T,? extends R> mapFn)
Attaches a stage that performs a stateful mapping operation. 
 | 
<S,R> StreamStage<R> | 
StreamStageWithKey.mapUsingService(ServiceFactory<?,S> serviceFactory,
               TriFunction<? super S,? super K,? super T,? extends R> mapFn)  | 
<S,R> BatchStage<R> | 
BatchStageWithKey.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> StreamStage<R> | 
StreamStageWithKey.mapUsingServiceAsync(ServiceFactory<?,S> serviceFactory,
                    int maxConcurrentOps,
                    boolean preserveOrder,
                    TriFunction<? super S,? super K,? super T,CompletableFuture<R>> mapAsyncFn)  | 
<S,R> BatchStage<R> | 
BatchStageWithKey.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). | 
default <S,R> StreamStage<R> | 
StreamStageWithKey.mapUsingServiceAsync(ServiceFactory<?,S> serviceFactory,
                    TriFunction<? super S,? super K,? super T,CompletableFuture<R>> mapAsyncFn)  | 
default <S,R> BatchStage<R> | 
BatchStageWithKey.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). | 
<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> BatchStage<R> | 
BatchStageWithKey.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). | 
| Modifier and Type | Method and Description | 
|---|---|
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 S3  
BatchSource which lists all the objects in the
 bucket-list using given prefix, reads them using provided readFileFn, transforms each read item to the desired output object
 using given mapFn and emits them to downstream. | 
Copyright © 2021 Hazelcast, Inc.. All rights reserved.