- AbstractProcessor - Class in com.hazelcast.jet.core
-
Base class to implement custom processors.
- AbstractProcessor() - Constructor for class com.hazelcast.jet.core.AbstractProcessor
-
- AbstractProcessor.FlatMapper<T,R> - Class in com.hazelcast.jet.core
-
- accept(T) - Method in class com.hazelcast.jet.core.ResettableSingletonTraverser
-
Resets this traverser so that the following next()
call will
return the item supplied here.
- accumulate(long, long) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Accumulates a new sample.
- accumulateByFrameP(DistributedFunction<? super T, K>, DistributedToLongFunction<? super T>, TimestampKind, WindowDefinition, AggregateOperation1<? super T, A, ?>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for the first-stage vertex in a
two-stage sliding window aggregation setup (see the
class Javadoc
for an explanation of aggregation stages).
- accumulateByKeyP(DistributedFunction<? super T, K>, AggregateOperation1<? super T, A, ?>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for the first-stage vertex in a
two-stage group-and-aggregate setup.
- accumulateFn(Tag<T>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
A primitive that updates the accumulator state to account for a new
item.
- accumulateFn(int) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
A primitive that updates the accumulator state to account for a new
item.
- accumulateFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation1
-
A primitive that updates the accumulator state to account for a new
item.
- accumulateFn0() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation2
-
A primitive that updates the accumulator state to account for a new
item coming from stream-0.
- accumulateFn0() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation3
-
A primitive that updates the accumulator state to account for a new
item coming from stream-0.
- accumulateFn1() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation2
-
A primitive that updates the accumulator state to account for a new
item coming from stream-1.
- accumulateFn1() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation3
-
A primitive that updates the accumulator state to account for a new
item coming from stream-1.
- accumulateFn2() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation3
-
A primitive that updates the accumulator state to account for a new
item coming from stream-2.
- accumulateP(AggregateOperation1<T, A, R>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that performs the provided
aggregate operation on all the items it receives.
- accumulator() - Method in interface com.hazelcast.jet.stream.DistributedCollector
-
- add(double) - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
-
Adds the value of to this objects' value.
- add(DoubleAccumulator) - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
-
Adds the value of the supplied accumulator to this one.
- add(long) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
Adds the supplied value to this accumulator.
- add(LongAccumulator) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
Adds the value of the supplied accumulator to this accumulator.
- add(ComputeStage<E>, DistributedFunction<? super E, K>) - Method in class com.hazelcast.jet.CoGroupBuilder
-
Adds another contributing pipeline stage to the co-grouping operation.
- add(ComputeStage<E1_IN>, JoinClause<K, E0, E1_IN, E1>) - Method in class com.hazelcast.jet.HashJoinBuilder
-
Adds another contributing pipeline stage to the hash-join operation.
- addClass(Class...) - Method in class com.hazelcast.jet.config.JobConfig
-
Adds the supplied classes to the list of resources that will be
available on the job's classpath while it's executing in the Jet
cluster.
- addExact(long) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
- addExact(LongAccumulator) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
Uses
Math.addExact()
to add the value
of the supplied accumulator into this one.
- addJar(URL) - Method in class com.hazelcast.jet.config.JobConfig
-
Adds the JAR identified by the supplied URL to the list of JARs that
will be a part of the job's classpath while it's executing in the Jet
cluster.
- addJar(File) - Method in class com.hazelcast.jet.config.JobConfig
-
Adds the supplied JAR file to the list of JARs that will be a part of
the job's classpath while it's executing in the Jet cluster.
- addJar(String) - Method in class com.hazelcast.jet.config.JobConfig
-
Adds the JAR identified by the supplied pathname to the list of JARs
that will be a part of the job's classpath while it's executing in the
Jet cluster.
- addResource(URL) - Method in class com.hazelcast.jet.config.JobConfig
-
Adds the resource identified by the supplied URL to the list of
resources that will be on the job's classpath while it's executing in
the Jet cluster.
- addResource(URL, String) - Method in class com.hazelcast.jet.config.JobConfig
-
Adds the resource identified by the supplied URL to the list of
resources that will be on the job's classpath while it's executing in
the Jet cluster.
- addResource(File) - Method in class com.hazelcast.jet.config.JobConfig
-
Adds the supplied file to the list of resources that will be on the
job's classpath while it's executing in the Jet cluster.
- addResource(File, String) - Method in class com.hazelcast.jet.config.JobConfig
-
Adds the supplied file to the list of resources that will be on the
job's classpath while it's executing in the Jet cluster.
- addResource(String) - Method in class com.hazelcast.jet.config.JobConfig
-
Adds the resource identified by the supplied pathname to the list of
resources that will be on the job's classpath while it's executing in
the Jet cluster.
- addResource(String, String) - Method in class com.hazelcast.jet.config.JobConfig
-
Adds the resource identified by the supplied pathname to the list of
resources that will be on the job's classpath while it's executing in
the Jet cluster.
- aggregateByKeyP(DistributedFunction<? super T, K>, AggregateOperation1<? super T, A, R>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that groups items by key
and performs the provided aggregate operation on each group.
- AggregateOperation<A,R> - Interface in com.hazelcast.jet.aggregate
-
Contains primitives needed to compute an aggregated result of stream
processing.
- AggregateOperation1<T,A,R> - Interface in com.hazelcast.jet.aggregate
-
Specialization of
AggregateOperation
to the "arity-1" case with
a single data stream being aggregated over.
- AggregateOperation2<T0,T1,A,R> - Interface in com.hazelcast.jet.aggregate
-
Specialization of
AggregateOperation
to the "arity-2" case with
two data stream being aggregated over.
- AggregateOperation3<T0,T1,T2,A,R> - Interface in com.hazelcast.jet.aggregate
-
Specialization of
AggregateOperation
to the "arity-3" case with
two data stream being aggregated over.
- AggregateOperationBuilder<A> - Class in com.hazelcast.jet.aggregate
-
A builder object that can be used to construct the definition of an
aggregate operation in a step-by-step manner.
- AggregateOperationBuilder.Arity1<T0,A> - Class in com.hazelcast.jet.aggregate
-
The arity-1 variant of the aggregate operation builder.
- AggregateOperationBuilder.Arity2<T0,T1,A> - Class in com.hazelcast.jet.aggregate
-
The arity-2 variant of the aggregate operation builder.
- AggregateOperationBuilder.Arity3<T0,T1,T2,A> - Class in com.hazelcast.jet.aggregate
-
The arity-3 variant of the aggregate operation builder.
- AggregateOperationBuilder.VarArity<A> - Class in com.hazelcast.jet.aggregate
-
The variable-arity variant of the aggregate operation builder.
- AggregateOperations - Class in com.hazelcast.jet.aggregate
-
Utility class with factory methods for several useful aggregate
operations.
- aggregateP(AggregateOperation1<T, A, R>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that performs the provided
aggregate operation on all the items it receives.
- aggregateToSessionWindowP(long, DistributedToLongFunction<? super T>, DistributedFunction<? super T, K>, AggregateOperation1<? super T, A, R>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that aggregates events into
session windows.
- aggregateToSlidingWindowP(DistributedFunction<? super T, K>, DistributedToLongFunction<? super T>, TimestampKind, WindowDefinition, AggregateOperation1<? super T, A, R>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that aggregates events
into a sliding window in a single stage (see the
class Javadoc
for an explanation of aggregation stages).
- allMatch(DistributedDoublePredicate) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- allMatch(DoublePredicate) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- allMatch(DistributedIntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- allMatch(IntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- allMatch(DistributedLongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- allMatch(LongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- allMatch(DistributedPredicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- allMatch(Predicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- allOf(AggregateOperation1<? super T, ?, ?>...) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns a composite operation that computes multiple aggregate
operations and returns their results in a List<Object>
.
- allToOne() - Method in class com.hazelcast.jet.core.Edge
-
Activates a special-cased
PARTITIONED
routing policy where all items will be assigned the same, randomly
chosen partition ID.
- alwaysFalse() - Static method in class com.hazelcast.jet.function.DistributedFunctions
-
Return sa predicate that always evaluates to false
.
- alwaysTrue() - Static method in class com.hazelcast.jet.function.DistributedFunctions
-
Returns a predicate that always evaluates to true
.
- and(DistributedBiPredicate<? super T, ? super U>) - Method in interface com.hazelcast.jet.function.DistributedBiPredicate
-
- and(DistributedDoublePredicate) - Method in interface com.hazelcast.jet.function.DistributedDoublePredicate
-
- and(DistributedIntPredicate) - Method in interface com.hazelcast.jet.function.DistributedIntPredicate
-
- and(DistributedLongPredicate) - Method in interface com.hazelcast.jet.function.DistributedLongPredicate
-
- and(DistributedPredicate<? super T>) - Method in interface com.hazelcast.jet.function.DistributedPredicate
-
- andAccumulate(DistributedBiConsumer<? super A, T>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder
-
Registers the supplied accumulate
primitive.
- andAccumulate(Tag<T>, DistributedBiConsumer<? super A, T>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder
-
Registers the supplied accumulate
primitive for the stream tagged
with the supplied tag.
- andAccumulate(Tag<T>, DistributedBiConsumer<? super A, T>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
-
Registers the supplied accumulate
primitive for the stream tagged
with the supplied tag.
- andAccumulate0(DistributedBiConsumer<? super A, T0>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder
-
Registers the supplied accumulate
primitive for stream-0.
- andAccumulate1(DistributedBiConsumer<? super A, T1>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
-
Registers the supplied accumulate
primitive for stream-1,
returning the arity-2 variant of the builder.
- andAccumulate2(DistributedBiConsumer<? super A, T2>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
-
Registers the supplied accumulate
primitive for stream-2,
returning the arity-3 variant of the builder.
- andCombine(DistributedBiConsumer<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
-
Registers the combine
primitive.
- andCombine(DistributedBiConsumer<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
-
Registers the combine
primitive.
- andCombine(DistributedBiConsumer<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
-
Registers the combine
primitive.
- andCombine(DistributedBiConsumer<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
-
Registers the combine
primitive.
- andDeduct(DistributedBiConsumer<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
-
Registers the deduct
primitive.
- andDeduct(DistributedBiConsumer<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
-
Registers the deduct
primitive.
- andDeduct(DistributedBiConsumer<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
-
Registers the deduct
primitive.
- andDeduct(DistributedBiConsumer<? super A, ? super A>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
-
Registers the deduct
primitive.
- andFinish(DistributedFunction<? super A, R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
-
Constructs and returns an
AggregateOperation1
from the
current state of the builder and the supplied
finish
primitive.
- andFinish(DistributedFunction<? super A, R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
-
Constructs and returns an
AggregateOperation2
from the
current state of the builder and the supplied
finish
primitive.
- andFinish(DistributedFunction<? super A, R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
-
Constructs and returns an
AggregateOperation3
from the
current state of the builder and the supplied
finish
primitive.
- andFinish(DistributedFunction<? super A, R>) - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
-
Constructs and returns an
AggregateOperation
from the
current state of the builder and the supplied
finish
primitive.
- andIdentityFinish() - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity1
-
Constructs and returns an
AggregateOperation1
from the current
state of the builder, with the identity function as the
finish
primitive.
- andIdentityFinish() - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity2
-
Constructs and returns an
AggregateOperation2
from the current
state of the builder, with the identity function as the
finish
primitive.
- andIdentityFinish() - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.Arity3
-
Constructs and returns an
AggregateOperation3
from the current
state of the builder, with the identity function as the
finish
primitive.
- andIdentityFinish() - Method in class com.hazelcast.jet.aggregate.AggregateOperationBuilder.VarArity
-
Constructs and returns an
AggregateOperation
from the current
state of the builder, with the identity function as the
finish
primitive.
- andThen(DistributedBiConsumer<? super T, ? super U>) - Method in interface com.hazelcast.jet.function.DistributedBiConsumer
-
- andThen(DistributedFunction<? super R, ? extends V>) - Method in interface com.hazelcast.jet.function.DistributedBiFunction
-
Serializable
variant of java.util.function.BiFunction#andThen(Function)
.
- andThen(DistributedConsumer<? super T>) - Method in interface com.hazelcast.jet.function.DistributedConsumer
-
- andThen(DistributedDoubleConsumer) - Method in interface com.hazelcast.jet.function.DistributedDoubleConsumer
-
- andThen(DistributedDoubleUnaryOperator) - Method in interface com.hazelcast.jet.function.DistributedDoubleUnaryOperator
-
- andThen(DistributedFunction<? super R, ? extends V>) - Method in interface com.hazelcast.jet.function.DistributedFunction
-
- andThen(DistributedIntConsumer) - Method in interface com.hazelcast.jet.function.DistributedIntConsumer
-
- andThen(DistributedIntUnaryOperator) - Method in interface com.hazelcast.jet.function.DistributedIntUnaryOperator
-
- andThen(DistributedLongConsumer) - Method in interface com.hazelcast.jet.function.DistributedLongConsumer
-
- andThen(DistributedLongUnaryOperator) - Method in interface com.hazelcast.jet.function.DistributedLongUnaryOperator
-
- anyMatch(DistributedDoublePredicate) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- anyMatch(DoublePredicate) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- anyMatch(DistributedIntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- anyMatch(IntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- anyMatch(DistributedLongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- anyMatch(LongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- anyMatch(DistributedPredicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- anyMatch(Predicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- append(T) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser that will return all the items of this traverser,
plus an additional item once this one returns null
.
- asDoubleStream() - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- asDoubleStream() - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- asLongStream() - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- averagingDouble(DistributedToDoubleFunction<T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that computes the arithmetic mean of the
double
values it obtains by applying getDoubleValueFn
to
each item.
- averagingDouble(DistributedToDoubleFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- averagingInt(DistributedToIntFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- averagingLong(DistributedToLongFunction<T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that computes the arithmetic mean of the
long
values it obtains by applying getLongValueFn
to
each item.
- averagingLong(DistributedToLongFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- bag(Tag<E>) - Method in class com.hazelcast.jet.datamodel.BagsByTag
-
Retrieves the bag associated with the supplied tag.
- bag0() - Method in class com.hazelcast.jet.datamodel.ThreeBags
-
Retrieves the bag at index 0.
- bag0() - Method in class com.hazelcast.jet.datamodel.TwoBags
-
Retrieves the bag at index 0.
- bag1() - Method in class com.hazelcast.jet.datamodel.ThreeBags
-
Retrieves the bag at index 1.
- bag1() - Method in class com.hazelcast.jet.datamodel.TwoBags
-
Retrieves the bag at index 1.
- bag2() - Method in class com.hazelcast.jet.datamodel.ThreeBags
-
Retrieves the bag at index 2.
- BagsByTag - Class in com.hazelcast.jet.datamodel
-
A heterogeneous map from Tag<E>
to Collection<E>
, where
E
can be different for each tag.
- BagsByTag() - Constructor for class com.hazelcast.jet.datamodel.BagsByTag
-
- bagsByTag(Object...) - Static method in class com.hazelcast.jet.datamodel.BagsByTag
-
Accepts an argument list of alternating tags and collections, interprets
them as a list of tag-bag pairs, and returns a BagsByTag
populated with these pairs.
- between(Vertex, Vertex) - Static method in class com.hazelcast.jet.core.Edge
-
Returns an edge between two vertices.
- boxed() - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- boxed() - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- boxed() - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- broadcast() - Method in class com.hazelcast.jet.core.Edge
-
- BroadcastKey<K> - Interface in com.hazelcast.jet.core
-
Marker interface for a key in the snapshot state that indicates the
corresponding entry should be broadcast to all processors
when restoring the snapshot.
- broadcastKey(K) - Static method in interface com.hazelcast.jet.core.BroadcastKey
-
Returns a given key as a broadcast key.
- bucketCount() - Method in interface com.hazelcast.jet.core.Outbox
-
Returns the number of buckets in this outbox.
- bucketCount() - Method in class com.hazelcast.jet.core.test.TestOutbox
-
- build(AggregateOperation<A, R>) - Method in class com.hazelcast.jet.CoGroupBuilder
-
Builds a new pipeline stage that performs the co-grouping operation.
- build() - Method in class com.hazelcast.jet.HashJoinBuilder
-
Builds a new pipeline stage that performs the hash-join operation.
- cache(String) - Static method in class com.hazelcast.jet.Sinks
-
Returns a sink that puts Map.Entry
s it receives into a Hazelcast
ICache
with the specified name.
- cache(String) - Static method in class com.hazelcast.jet.Sources
-
Returns a source that fetches entries from the Hazelcast ICache
with the specified name and emits them as Map.Entry
.
- cacheJournal(String, DistributedPredicate<EventJournalCacheEvent<K, V>>, DistributedFunction<EventJournalCacheEvent<K, V>, T>, boolean) - Static method in class com.hazelcast.jet.Sources
-
Returns a source that will stream the EventJournalCacheEvent
events of the Hazelcast ICache
with the specified name.
- cacheJournal(String, boolean) - Static method in class com.hazelcast.jet.Sources
-
- cancel() - Method in interface com.hazelcast.jet.Job
-
Attempts to cancel execution of this job.
- CloseableProcessorSupplier<E extends Processor & Closeable> - Class in com.hazelcast.jet.core
-
A
ProcessorSupplier
which closes created processor instances when
the job is complete.
- CloseableProcessorSupplier(DistributedSupplier<E>) - Constructor for class com.hazelcast.jet.core.CloseableProcessorSupplier
-
- CloseableProcessorSupplier(DistributedIntFunction<Collection<E>>) - Constructor for class com.hazelcast.jet.core.CloseableProcessorSupplier
-
- coAccumulateByKeyP(List<DistributedFunction<?, ? extends K>>, AggregateOperation<A, ?>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for the first-stage vertex in a
two-stage group-and-aggregate setup.
- coAggregateByKeyP(List<DistributedFunction<?, ? extends K>>, AggregateOperation<A, R>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that groups items by key
and performs the provided aggregate operation on each group.
- coGroup(DistributedFunction<? super E, ? extends K>, ComputeStage<E1>, DistributedFunction<? super E1, ? extends K>, AggregateOperation2<? super E, ? super E1, A, R>) - Method in interface com.hazelcast.jet.ComputeStage
-
Attaches to this and the supplied stage a stage that co-groups their items
by a common key and applies the supplied aggregate operation to co-grouped
items.
- coGroup(DistributedFunction<? super E, ? extends K>, ComputeStage<E1>, DistributedFunction<? super E1, ? extends K>, ComputeStage<E2>, DistributedFunction<? super E2, ? extends K>, AggregateOperation3<? super E, ? super E1, ? super E2, A, R>) - Method in interface com.hazelcast.jet.ComputeStage
-
Attaches to this and the supplied stages a stage that co-groups their items
by a common key and applies the supplied aggregate operation to co-grouped
items.
- CoGroupBuilder<K,E0> - Class in com.hazelcast.jet
-
Offers a step-by-step fluent API to build a co-grouping pipeline stage by
adding any number of contributing stages.
- coGroupBuilder(DistributedFunction<? super E, K>) - Method in interface com.hazelcast.jet.ComputeStage
-
Returns a fluent API builder object to construct a co-group operation
with any number of contributing stages.
- collect(DistributedSupplier<R>, DistributedObjDoubleConsumer<R>, DistributedBiConsumer<R, R>) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- collect(Supplier<R>, ObjDoubleConsumer<R>, BiConsumer<R, R>) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- collect(DistributedSupplier<R>, DistributedObjIntConsumer<R>, DistributedBiConsumer<R, R>) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- collect(Supplier<R>, ObjIntConsumer<R>, BiConsumer<R, R>) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- collect(DistributedSupplier<R>, DistributedObjLongConsumer<R>, DistributedBiConsumer<R, R>) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- collect(Supplier<R>, ObjLongConsumer<R>, BiConsumer<R, R>) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- collect(DistributedSupplier<R>, DistributedBiConsumer<R, ? super T>, DistributedBiConsumer<R, R>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- collect(DistributedCollector<? super T, A, R>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- collect(DistributedCollector.Reducer<? super T, R>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- collect(Supplier<R>, BiConsumer<R, ? super T>, BiConsumer<R, R>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- collectingAndThen(DistributedCollector<T, A, R>, DistributedFunction<R, RR>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Serializable
variant of {@link
Collectors#collectingAndThen(Collector, Function)
java.util.stream.Collectors#collectingAndThen(Collector, Function)
- com.hazelcast.jet - package com.hazelcast.jet
-
The Pipeline API is Jet's high-level API to build and execute
distributed computation jobs.
- com.hazelcast.jet.accumulator - package com.hazelcast.jet.accumulator
-
Classes intended to be used for accumulator objects in Jet aggregation
operations.
- com.hazelcast.jet.aggregate - package com.hazelcast.jet.aggregate
-
Contains AggregateOperation
and several its variants, as well
as a builder object for the aggregate operations.
- com.hazelcast.jet.config - package com.hazelcast.jet.config
-
Jet's configuration data objects.
- com.hazelcast.jet.core - package com.hazelcast.jet.core
-
Jet's Core API.
- com.hazelcast.jet.core.processor - package com.hazelcast.jet.core.processor
-
Contains static utility classes with factories of Jet processors.
- com.hazelcast.jet.core.test - package com.hazelcast.jet.core.test
-
Utilities for writing tests of Core API Processors.
- com.hazelcast.jet.datamodel - package com.hazelcast.jet.datamodel
-
Generic data containers used by the Pipeline API.
- com.hazelcast.jet.function - package com.hazelcast.jet.function
-
Serializable variants of functional interfaces from
java.util.function
.
- com.hazelcast.jet.server - package com.hazelcast.jet.server
-
Contains Java program entry points that will start a Jet server
instance, submit jobs to a Jet cluster, etc.
- com.hazelcast.jet.stream - package com.hazelcast.jet.stream
-
java.util.stream implementation using Hazelcast Jet
- combine(LinTrendAccumulator) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Combines this accumulator with the supplied one.
- combineByKeyP(AggregateOperation<A, R>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for the second-stage vertex in a
two-stage group-and-aggregate setup.
- combineFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
A primitive that accepts two accumulators and updates the state of the
left-hand one by combining it with the state of the right-hand one.
- combineP(AggregateOperation1<T, A, R>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that performs the provided
aggregate operation on all the items it receives.
- combiner() - Method in interface com.hazelcast.jet.stream.DistributedCollector
-
- combineToSlidingWindowP(WindowDefinition, AggregateOperation1<?, A, R>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for the second-stage vertex in a
two-stage sliding window aggregation setup (see the
class Javadoc
for an explanation of aggregation stages).
- combineWith(BagsByTag) - Method in class com.hazelcast.jet.datamodel.BagsByTag
-
Merges the contents of the supplied bag container into this one.
- combineWith(ThreeBags<E0, E1, E2>) - Method in class com.hazelcast.jet.datamodel.ThreeBags
-
Combines this and the supplied container by merging all the supplied
container's data into this one.
- combineWith(TwoBags<E0, E1>) - Method in class com.hazelcast.jet.datamodel.TwoBags
-
Combines this and the supplied container by merging all the supplied
container's data into this one.
- compareTo(Tag<?>) - Method in class com.hazelcast.jet.datamodel.Tag
-
- comparing(Function<? super T, ? extends U>, Comparator<? super U>) - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- comparing(DistributedFunction<? super T, ? extends U>, DistributedComparator<? super U>) - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- comparing(Function<? super T, ? extends U>) - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- comparing(DistributedFunction<? super T, ? extends U>) - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- comparingDouble(ToDoubleFunction<? super T>) - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- comparingDouble(DistributedToDoubleFunction<? super T>) - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- comparingInt(ToIntFunction<? super T>) - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- comparingInt(DistributedToIntFunction<? super T>) - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- comparingLong(ToLongFunction<? super T>) - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- comparingLong(DistributedToLongFunction<? super T>) - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- complete(Throwable) - Method in class com.hazelcast.jet.core.CloseableProcessorSupplier
-
- complete() - Method in interface com.hazelcast.jet.core.Processor
-
Called after all the inbound edges' streams are exhausted.
- complete(Throwable) - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Called on coordinator member after execution has finished on all
members, successfully or not.
- complete(Throwable) - Method in interface com.hazelcast.jet.core.ProcessorSupplier
-
Called after the execution has finished on all members, successfully
or not, or immediately, when the execution was aborted due to
a member leaving the cluster.
- completeEdge(int) - Method in interface com.hazelcast.jet.core.Processor
-
Called after the edge input with the supplied ordinal
is
exhausted.
- compose(DistributedDoubleUnaryOperator) - Method in interface com.hazelcast.jet.function.DistributedDoubleUnaryOperator
-
- compose(DistributedFunction<? super V, ? extends T>) - Method in interface com.hazelcast.jet.function.DistributedFunction
-
- compose(DistributedIntUnaryOperator) - Method in interface com.hazelcast.jet.function.DistributedIntUnaryOperator
-
- compose(DistributedLongUnaryOperator) - Method in interface com.hazelcast.jet.function.DistributedLongUnaryOperator
-
- ComputeStage<E> - Interface in com.hazelcast.jet
-
Represents a stage in a distributed computation
pipeline
.
- configure(JobConfig) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- configure(JobConfig) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- configure(JobConfig) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- configure(JobConfig) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- CONSTANT_KEY - Static variable in class com.hazelcast.jet.function.DistributedFunctions
-
- constantKey() - Static method in class com.hazelcast.jet.function.DistributedFunctions
-
- cooperativeTimeout(long) - Method in class com.hazelcast.jet.core.test.TestSupport
-
If timeout > 0
, the test will fail if any call to processing
method in a cooperative processor exceeds this timeout.
- copyTo(byte[], int) - Method in class com.hazelcast.jet.core.test.TestOutbox.MockData
-
- counting() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that computes the number of items.
- counting() - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- create() - Static method in interface com.hazelcast.jet.Pipeline
-
Creates a new, empty pipeline.
- createFactory() - Method in class com.hazelcast.jet.core.JetDataSerializerHook
-
- createFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
A primitive that returns a new accumulator.
- customTransform(String, DistributedSupplier<Processor>) - Method in interface com.hazelcast.jet.ComputeStage
-
Attaches to this stage a stage with a custom transform based on the
provided supplier of Core API
Processor
s.
- DAG - Class in com.hazelcast.jet.core
-
Describes a computation to be performed by the Jet computation engine.
- DAG() - Constructor for class com.hazelcast.jet.core.DAG
-
- dataSize() - Method in class com.hazelcast.jet.core.test.TestOutbox.MockData
-
- deduct(LinTrendAccumulator) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Deducts the supplied accumulator from this one.
- deductFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
A primitive that accepts two accumulators and updates the state of the
left-hand one by deducting the state of the right-hand one from it.
- DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.jet.config.InstanceConfig
-
- DEFAULT_FLOW_CONTROL_PERIOD_MS - Static variable in class com.hazelcast.jet.config.InstanceConfig
-
- DEFAULT_JET_MULTICAST_PORT - Static variable in class com.hazelcast.jet.config.JetConfig
-
The default port number for the cluster auto-discovery mechanism's
multicast communication.
- DEFAULT_PACKET_SIZE_LIMIT - Static variable in class com.hazelcast.jet.config.EdgeConfig
-
- DEFAULT_QUEUE_SIZE - Static variable in class com.hazelcast.jet.config.EdgeConfig
-
The default size of the
concurrent queues
connecting processors within a cluster member.
- DEFAULT_RECEIVE_WINDOW_MULTIPLIER - Static variable in class com.hazelcast.jet.config.EdgeConfig
-
- defaultPartitioner() - Static method in interface com.hazelcast.jet.core.Partitioner
-
Returns a partitioner which applies the default Hazelcast partitioning.
- DefaultPartitionStrategy - Interface in com.hazelcast.jet.core
-
A facade that hides the details of Hazelcast partitioning SPI and exposes
just the partitioning strategy.
- DiagnosticProcessors - Class in com.hazelcast.jet.core.processor
-
Static utility class with factories of sinks and wrappers that log
the data flowing through the DAG.
- disableCompleteCall() - Method in class com.hazelcast.jet.core.test.TestSupport
-
Disables calling complete()
method during the test.
- disableLogging() - Method in class com.hazelcast.jet.core.test.TestSupport
-
Disables logging of input and output objects.
- disableProgressAssertion() - Method in class com.hazelcast.jet.core.test.TestSupport
-
Disables checking of progress of processing methods (see
class javadoc
for information on what is "progress").
- disableRunUntilCompleted(long) - Method in class com.hazelcast.jet.core.test.TestSupport
-
If the timeout > 0, the complete()
method is called repeatedly
until the timeout elapses.
- disableSnapshots() - Method in class com.hazelcast.jet.core.test.TestSupport
-
Disable snapshot save and restore before first item and after each
process()
and complete()
call.
- distinct() - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- distinct() - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- distinct() - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- distinct() - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- distributed() - Method in class com.hazelcast.jet.core.Edge
-
Declares that the edge is distributed.
- DistributedBiConsumer<T,U> - Interface in com.hazelcast.jet.function
-
- DistributedBiFunction<T,U,R> - Interface in com.hazelcast.jet.function
-
- DistributedBinaryOperator<T> - Interface in com.hazelcast.jet.function
-
- DistributedBiPredicate<T,U> - Interface in com.hazelcast.jet.function
-
- DistributedBooleanSupplier - Interface in com.hazelcast.jet.function
-
- DistributedCollector<T,A,R> - Interface in com.hazelcast.jet.stream
-
- DistributedCollector.Reducer<T,R> - Interface in com.hazelcast.jet.stream
-
Interface for Jet-specific distributed reducers which execute the
terminal reduce operation over the current DistributedStream
by building and executing a DAG.
- DistributedCollectors - Class in com.hazelcast.jet.stream
-
- DistributedCollectors() - Constructor for class com.hazelcast.jet.stream.DistributedCollectors
-
- DistributedComparator<T> - Interface in com.hazelcast.jet.function
-
- DistributedConsumer<T> - Interface in com.hazelcast.jet.function
-
- DistributedDoubleBinaryOperator - Interface in com.hazelcast.jet.function
-
- DistributedDoubleConsumer - Interface in com.hazelcast.jet.function
-
- DistributedDoubleFunction<R> - Interface in com.hazelcast.jet.function
-
- DistributedDoublePredicate - Interface in com.hazelcast.jet.function
-
- DistributedDoubleStream - Interface in com.hazelcast.jet.stream
-
An extension of
DoubleStream
that supports
distributed stream operations by replacing functional interfaces with
their serializable equivalents.
- DistributedDoubleSupplier - Interface in com.hazelcast.jet.function
-
- DistributedDoubleToIntFunction - Interface in com.hazelcast.jet.function
-
- DistributedDoubleToLongFunction - Interface in com.hazelcast.jet.function
-
- DistributedDoubleUnaryOperator - Interface in com.hazelcast.jet.function
-
- DistributedFunction<T,R> - Interface in com.hazelcast.jet.function
-
- DistributedFunctions - Class in com.hazelcast.jet.function
-
Factory methods for several common distributed functions.
- DistributedIntBinaryOperator - Interface in com.hazelcast.jet.function
-
- DistributedIntConsumer - Interface in com.hazelcast.jet.function
-
- DistributedIntFunction<R> - Interface in com.hazelcast.jet.function
-
- DistributedIntPredicate - Interface in com.hazelcast.jet.function
-
- DistributedIntStream - Interface in com.hazelcast.jet.stream
-
An extension of
IntStream
that supports distributed stream
operations by replacing functional interfaces with their serializable
equivalents.
- DistributedIntSupplier - Interface in com.hazelcast.jet.function
-
- DistributedIntToDoubleFunction - Interface in com.hazelcast.jet.function
-
- DistributedIntToLongFunction - Interface in com.hazelcast.jet.function
-
- DistributedIntUnaryOperator - Interface in com.hazelcast.jet.function
-
- DistributedLongBinaryOperator - Interface in com.hazelcast.jet.function
-
- DistributedLongConsumer - Interface in com.hazelcast.jet.function
-
- DistributedLongFunction<R> - Interface in com.hazelcast.jet.function
-
- DistributedLongPredicate - Interface in com.hazelcast.jet.function
-
- DistributedLongStream - Interface in com.hazelcast.jet.stream
-
An extension of
LongStream
that supports distributed stream
operations by replacing functional interfaces with their serializable
equivalents.
- DistributedLongSupplier - Interface in com.hazelcast.jet.function
-
- DistributedLongToDoubleFunction - Interface in com.hazelcast.jet.function
-
- DistributedLongToIntFunction - Interface in com.hazelcast.jet.function
-
- DistributedLongUnaryOperator - Interface in com.hazelcast.jet.function
-
- DistributedObjDoubleConsumer<T> - Interface in com.hazelcast.jet.function
-
- DistributedObjIntConsumer<T> - Interface in com.hazelcast.jet.function
-
- DistributedObjLongConsumer<T> - Interface in com.hazelcast.jet.function
-
- DistributedOptional<T> - Class in com.hazelcast.jet.function
-
- DistributedPredicate<T> - Interface in com.hazelcast.jet.function
-
- DistributedStream<T> - Interface in com.hazelcast.jet.stream
-
An extension of
Stream
that supports distributed stream
operations by replacing functional interfaces with their
Serializable
equivalents.
- DistributedSupplier<T> - Interface in com.hazelcast.jet.function
-
- DistributedToDoubleBiFunction<T,U> - Interface in com.hazelcast.jet.function
-
- DistributedToDoubleFunction<T> - Interface in com.hazelcast.jet.function
-
- DistributedToIntBiFunction<T,U> - Interface in com.hazelcast.jet.function
-
- DistributedToIntFunction<T> - Interface in com.hazelcast.jet.function
-
- DistributedToLongBiFunction<T,U> - Interface in com.hazelcast.jet.function
-
- DistributedToLongFunction<T> - Interface in com.hazelcast.jet.function
-
- DistributedUnaryOperator<T> - Interface in com.hazelcast.jet.function
-
- dontParallelize(ProcessorSupplier) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Wraps the provided ProcessorSupplier
into a meta-supplier that
will always return it.
- dontParallelize(DistributedSupplier<? extends Processor>) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Factory method that wraps the given Supplier<Processor>
and uses it as the supplier of all Processor
instances.
- DoubleAccumulator - Class in com.hazelcast.jet.accumulator
-
Mutable container of a double
value.
- DoubleAccumulator() - Constructor for class com.hazelcast.jet.accumulator.DoubleAccumulator
-
Creates a new instance with value == 0
.
- DoubleAccumulator(double) - Constructor for class com.hazelcast.jet.accumulator.DoubleAccumulator
-
Creates a new instance with the specified value.
- drain(Consumer<E>) - Method in interface com.hazelcast.jet.core.Inbox
-
Passes each of this object's items to the supplied consumer until it is empty.
- drainOutbox(Queue<T>, Collection<? super T>, boolean) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
Move all items from the outbox to the target
list and make the
outbox available to accept more items.
- drainTo(Sink<? super E>) - Method in interface com.hazelcast.jet.ComputeStage
-
Attaches to this stage a sink stage, one that accepts data but doesn't
emit any.
- drainTo(Collection<E>) - Method in interface com.hazelcast.jet.core.Inbox
-
- drawFrom(Source<E>) - Method in interface com.hazelcast.jet.Pipeline
-
Returns a new pipeline stage that has no upstream stages and produces
some output for its downstream stages.
- dropWhile(Predicate<? super T>) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser that will emit a suffix of the original traverser,
starting from the item for which the predicate fails (inclusive).
- edge(Edge) - Method in class com.hazelcast.jet.core.DAG
-
Adds an edge to this DAG.
- Edge - Class in com.hazelcast.jet.core
-
- Edge() - Constructor for class com.hazelcast.jet.core.Edge
-
- Edge(Vertex, int, Vertex, int) - Constructor for class com.hazelcast.jet.core.Edge
-
- Edge.RoutingPolicy - Enum in com.hazelcast.jet.core
-
An edge describes a connection from many upstream processors to many
downstream processors.
- EdgeConfig - Class in com.hazelcast.jet.config
-
A configuration object for a DAG
Edge
that holds fine-tuning
parameters that influence its performance characteristics.
- EdgeConfig() - Constructor for class com.hazelcast.jet.config.EdgeConfig
-
- emitByFrame(WindowDefinition) - Static method in interface com.hazelcast.jet.core.WatermarkEmissionPolicy
-
Returns a watermark emission policy that ensures that the value of
the emitted watermark belongs to a frame higher than the previous
watermark's frame, as per the supplied WindowDefinition
.
- emitByMinStep(long) - Static method in interface com.hazelcast.jet.core.WatermarkEmissionPolicy
-
Returns a watermark emission policy that ensures that each emitted
watermark's value is at least minStep
more than the previous
one.
- emitFromTraverser(int[], Traverser<E>, Consumer<? super E>) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Obtains items from the traverser and offers them to the outbox's buckets
identified in the supplied array.
- emitFromTraverser(int, Traverser<E>, Consumer<? super E>) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Obtains items from the traverser and offers them to the outbox's buckets
identified in the supplied array.
- emitFromTraverser(Traverser<E>, Consumer<? super E>) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- emitFromTraverser(Traverser<?>) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- emitFromTraverser(int, Traverser<?>) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- emitFromTraverser(int[], Traverser<?>) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- emitFromTraverserToSnapshot(Traverser<T>) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Obtains items from the traverser and offers them to the snapshot bucket
of the outbox.
- empty() - Static method in class com.hazelcast.jet.function.DistributedOptional
-
- empty() - Static method in class com.hazelcast.jet.Traversers
-
Returns a traverser that always returns null.
- ensureBag(Tag<E>) - Method in class com.hazelcast.jet.datamodel.BagsByTag
-
Ensures that there is a mapping from the supplied tag to a bag,
creating an empty one if necessary.
- entry(K, V) - Static method in class com.hazelcast.jet.Util
-
Returns a Map.Entry
with the given key and value.
- entryKey() - Static method in class com.hazelcast.jet.function.DistributedFunctions
-
Returns a function that extracts the key of a Map.Entry
.
- entryValue() - Static method in class com.hazelcast.jet.function.DistributedFunctions
-
Returns a function that extracts the value of a Map.Entry
.
- equals(Object) - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
-
- equals(Object) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
- equals(Object) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
- equals(Object) - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
- equals(Object) - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
-
- equals(Object) - Method in class com.hazelcast.jet.accumulator.MutableReference
-
- equals(Object) - Method in class com.hazelcast.jet.core.Edge
-
- equals(Object) - Method in class com.hazelcast.jet.core.Watermark
-
- equals(Object) - Method in class com.hazelcast.jet.datamodel.BagsByTag
-
- equals(Object) - Method in class com.hazelcast.jet.datamodel.ItemsByTag
-
- equals(Object) - Method in class com.hazelcast.jet.datamodel.Session
-
- equals(Object) - Method in class com.hazelcast.jet.datamodel.Tag
-
- equals(Object) - Method in class com.hazelcast.jet.datamodel.ThreeBags
-
- equals(Object) - Method in class com.hazelcast.jet.datamodel.TimestampedEntry
-
- equals(Object) - Method in class com.hazelcast.jet.datamodel.Tuple2
-
- equals(Object) - Method in class com.hazelcast.jet.datamodel.Tuple3
-
- equals(Object) - Method in class com.hazelcast.jet.datamodel.TwoBags
-
- equals(Object) - Method in class com.hazelcast.jet.function.DistributedOptional
-
- execute() - Method in interface com.hazelcast.jet.Job
-
- expectOutput(List<?>) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Sets the expected output and runs the test.
- f0() - Method in class com.hazelcast.jet.datamodel.Tuple2
-
Returns the value of the field 0.
- f0() - Method in class com.hazelcast.jet.datamodel.Tuple3
-
Returns the value of the field 0.
- f1() - Method in class com.hazelcast.jet.datamodel.Tuple2
-
Returns the value of the field 1.
- f1() - Method in class com.hazelcast.jet.datamodel.Tuple3
-
Returns the value of the field 1.
- f2() - Method in class com.hazelcast.jet.datamodel.Tuple3
-
Returns the value of the field 2.
- files(String, DistributedFunction<E, String>, Charset, boolean) - Static method in class com.hazelcast.jet.Sinks
-
Returns a sink that that writes the items it receives to files.
- files(String, DistributedFunction<E, String>) - Static method in class com.hazelcast.jet.Sinks
-
- files(String) - Static method in class com.hazelcast.jet.Sinks
-
- files(String, Charset, String) - Static method in class com.hazelcast.jet.Sources
-
A source that emits lines from files in a directory (but not its
subdirectories.
- files(String) - Static method in class com.hazelcast.jet.Sources
-
- fileWatcher(String, Charset, String) - Static method in class com.hazelcast.jet.Sources
-
A source that emits a stream of lines of text coming from files in
the watched directory (but not its subdirectories).
- fileWatcher(String) - Static method in class com.hazelcast.jet.Sources
-
- filter(DistributedPredicate<E>) - Method in interface com.hazelcast.jet.ComputeStage
-
Attaches to this stage a filtering stage, one which applies the provided
predicate function to each input item to decide whether to pass the item
to the output or to discard it.
- filter(DistributedPredicate<? super T>) - Method in class com.hazelcast.jet.function.DistributedOptional
-
- filter(DistributedDoublePredicate) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- filter(DoublePredicate) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- filter(DistributedIntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- filter(IntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- filter(DistributedLongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- filter(LongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- filter(DistributedPredicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- filter(Predicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- filter(Predicate<? super T>) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser that will emit the same items as this traverser, but
only those that pass the given predicate.
- filterP(DistributedPredicate<T>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that emits the same items
it receives, but only those that pass the given predicate.
- finish() - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Computes the linear coefficient of the linear regression of the
accumulated samples.
- finisher() - Method in interface com.hazelcast.jet.stream.DistributedCollector
-
- finishFn() - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
A primitive that finishes the accumulation process by transforming
the accumulator object into the final result.
- finishSnapshotRestore() - Method in interface com.hazelcast.jet.core.Processor
-
Called after a job was restarted from a snapshot and the processor
has consumed all the snapshot data.
- flatMap(DistributedFunction<? super E, Traverser<? extends R>>) - Method in interface com.hazelcast.jet.ComputeStage
-
Attaches to this stage a flat-mapping stage, one which applies the
supplied function to each input item independently and emits all items
from the
Traverser
it returns as the output items.
- flatMap(DistributedFunction<? super T, DistributedOptional<U>>) - Method in class com.hazelcast.jet.function.DistributedOptional
-
- flatMap(DistributedDoubleFunction<? extends DoubleStream>) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- flatMap(DoubleFunction<? extends DoubleStream>) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- flatMap(DistributedIntFunction<? extends IntStream>) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- flatMap(IntFunction<? extends IntStream>) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- flatMap(DistributedLongFunction<? extends LongStream>) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- flatMap(LongFunction<? extends LongStream>) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- flatMap(DistributedFunction<? super T, ? extends Stream<? extends R>>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- flatMap(Function<? super T, ? extends Stream<? extends R>>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- flatMap(Function<? super T, ? extends Traverser<? extends R>>) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser traverser that will apply the given mapping function
to each item retrieved from this traverser and emit all the items from
the resulting traverser(s).
- flatMapP(DistributedFunction<T, ? extends Traverser<? extends R>>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
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.
- flatMapper(int, Function<? super T, ? extends Traverser<? extends R>>) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- flatMapper(Function<? super T, ? extends Traverser<? extends R>>) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- flatMapper(int[], Function<? super T, ? extends Traverser<? extends R>>) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- flatMapToDouble(DistributedFunction<? super T, ? extends DoubleStream>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- flatMapToDouble(Function<? super T, ? extends DoubleStream>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- flatMapToInt(DistributedFunction<? super T, ? extends IntStream>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- flatMapToInt(Function<? super T, ? extends IntStream>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- flatMapToLong(DistributedFunction<? super T, ? extends LongStream>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- flatMapToLong(Function<? super T, ? extends LongStream>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- floorFrameTs(long) - Method in class com.hazelcast.jet.core.WindowDefinition
-
Returns the highest frame timestamp less than or equal to the given
timestamp.
- forEach(DoubleConsumer) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- forEachOrdered(DoubleConsumer) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- frameLength() - Method in class com.hazelcast.jet.core.WindowDefinition
-
Returns the length of the frame (equal to the sliding step).
- frameOffset() - Method in class com.hazelcast.jet.core.WindowDefinition
-
Returns the frame offset.
- from(Vertex) - Static method in class com.hazelcast.jet.core.Edge
-
Returns an edge with the given source vertex and no destination vertex.
- from(Vertex, int) - Static method in class com.hazelcast.jet.core.Edge
-
Returns an edge with the given source vertex at the given ordinal
and no destination vertex.
- fromProcessor(String, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.Sinks
-
Returns a sink constructed directly from the given Core API processor
meta-supplier.
- fromProcessor(String, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.Sources
-
Returns a source constructed directly from the given Core API processor
meta-supplier.
- fromSource(JetInstance, ProcessorMetaSupplier) - Static method in interface com.hazelcast.jet.stream.DistributedStream
-
Returns a distributed Stream
with given processors as its source.
- get() - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
-
Returns the current value.
- get() - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
Returns the current value.
- get() - Method in class com.hazelcast.jet.accumulator.MutableReference
-
Returns the current value.
- get(int) - Method in class com.hazelcast.jet.core.CloseableProcessorSupplier
-
- get(List<Address>) - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Called to create a mapping from member
Address
to the
ProcessorSupplier
that will be sent to that member.
- get(int) - Method in interface com.hazelcast.jet.core.ProcessorSupplier
-
- get(Tag<E>) - Method in class com.hazelcast.jet.datamodel.ItemsByTag
-
Retrieves the value associated with the supplied tag and throws an
exception if there is none.
- get() - Method in class com.hazelcast.jet.function.DistributedOptional
-
- getBackupCount() - Method in class com.hazelcast.jet.config.InstanceConfig
-
Returns the
backup-count
used for job metadata
and snapshots
- getCache(String) - Method in interface com.hazelcast.jet.stream.JetCacheManager
-
Returns the cache instance with the specified, optionally prefixed, cache
name:
- getCacheManager() - Method in interface com.hazelcast.jet.JetInstance
-
Obtain the
JetCacheManager
that provides access to JSR-107 (JCache) caches
configured on a Hazelcast Jet cluster.
- getCluster() - Method in interface com.hazelcast.jet.JetInstance
-
Returns information about the cluster this Jet instance is part of.
- getConfig() - Method in class com.hazelcast.jet.core.Edge
-
Returns the EdgeConfig
instance associated with this edge.
- getConfig() - Method in interface com.hazelcast.jet.JetInstance
-
Returns the configuration for this Jet member.
- getCooperativeThreadCount() - Method in class com.hazelcast.jet.config.InstanceConfig
-
Returns the number of cooperative execution threads.
- getCurrentWatermark() - Method in interface com.hazelcast.jet.core.WatermarkPolicy
-
Called to get the current watermark in the absence of an observed
event.
- getDefaultEdgeConfig() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns the default DAG edge configuration.
- getDestination() - Method in class com.hazelcast.jet.core.Edge
-
Returns this edge's destination vertex.
- getDestName() - Method in class com.hazelcast.jet.core.Edge
-
Returns the name of the destination vertex.
- getDestOrdinal() - Method in class com.hazelcast.jet.core.Edge
-
Returns the ordinal of the edge at the destination vertex.
- getEnd() - Method in class com.hazelcast.jet.datamodel.Session
-
Returns the ending timestamp of the session.
- getFactoryId() - Method in class com.hazelcast.jet.core.DAG
-
- getFactoryId() - Method in class com.hazelcast.jet.core.Edge
-
- getFactoryId() - Method in class com.hazelcast.jet.core.JetDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.jet.core.Vertex
-
- getFlowControlPeriodMs() - Method in class com.hazelcast.jet.config.InstanceConfig
-
- getFuture() - Method in interface com.hazelcast.jet.Job
-
Gets the future associated with the job, used to control the job.
- getHazelcastConfig() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns the configuration object for the underlying Hazelcast instance.
- getHazelcastInstance() - Method in interface com.hazelcast.jet.JetInstance
-
Returns the underlying Hazelcast IMDG instance used by Jet.
- getHeapCost() - Method in class com.hazelcast.jet.core.test.TestOutbox.MockData
-
- getId() - Method in class com.hazelcast.jet.config.ResourceConfig
-
The ID of the resource, null for
archives
.
- getId() - Method in class com.hazelcast.jet.core.DAG
-
- getId() - Method in class com.hazelcast.jet.core.Edge
-
- getId() - Method in class com.hazelcast.jet.core.Vertex
-
- getInboundEdges(String) - Method in class com.hazelcast.jet.core.DAG
-
Returns the inbound edges connected to the vertex with the given name.
- getInstance() - Static method in class com.hazelcast.jet.server.JetBootstrap
-
Returns the bootstrapped JetInstance
.
- getInstanceConfig() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns the Jet instance config.
- getJobId() - Method in interface com.hazelcast.jet.Job
-
Returns the ID of this job.
- getJobs() - Method in interface com.hazelcast.jet.JetInstance
-
Returns all submitted jobs including running and completed ones
- getJobStatus() - Method in interface com.hazelcast.jet.Job
-
Returns the status of this job.
- getKey() - Method in class com.hazelcast.jet.datamodel.Session
-
Returns the session's key.
- getKey() - Method in class com.hazelcast.jet.datamodel.TimestampedEntry
-
- getKey() - Method in class com.hazelcast.jet.datamodel.Tuple2
-
- getList(String) - Method in interface com.hazelcast.jet.JetInstance
-
Returns the distributed list instance with the specified name.
- getLocalParallelism() - Method in class com.hazelcast.jet.core.Vertex
-
Returns the number of processors corresponding to this vertex that will
be created on each member.
- getLogger() - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Returns the logger associated with this processor instance.
- getManagedContext() - Method in class com.hazelcast.jet.core.test.TestOutbox.MockSerializationService
-
- getMap(String) - Method in interface com.hazelcast.jet.JetInstance
-
Returns the distributed map instance with the specified name.
- getMetaSupplier() - Method in class com.hazelcast.jet.core.Vertex
-
Returns this vertex's meta-supplier of processors.
- getName() - Method in class com.hazelcast.jet.core.Vertex
-
Returns the name of this vertex.
- getName() - Method in interface com.hazelcast.jet.JetInstance
-
Returns the name of the Jet instance.
- getObject() - Method in class com.hazelcast.jet.core.test.TestOutbox.MockData
-
Javadoc pending
- getOutboundEdges(String) - Method in class com.hazelcast.jet.core.DAG
-
Returns the outbound edges connected to the vertex with the given name.
- getPacketSizeLimit() - Method in class com.hazelcast.jet.config.EdgeConfig
-
- getPartition(Object) - Method in interface com.hazelcast.jet.core.DefaultPartitionStrategy
-
Returns the Hazelcast partition ID of the given object.
- getPartition(Object, int) - Method in class com.hazelcast.jet.core.Partitioner.Default
-
- getPartition(T, int) - Method in interface com.hazelcast.jet.core.Partitioner
-
Returns the partition ID of the given item.
- getPartitioner() - Method in class com.hazelcast.jet.core.Edge
-
Returns the instance encapsulating the partitioning strategy in effect
on this edge.
- getPartitionHash() - Method in class com.hazelcast.jet.core.test.TestOutbox.MockData
-
- getPipeline() - Method in interface com.hazelcast.jet.Stage
-
Returns the
Pipeline
this stage belongs to.
- getPriority() - Method in class com.hazelcast.jet.core.Edge
-
- getProcessingGuarantee() - Method in class com.hazelcast.jet.config.JobConfig
-
- getProperties() - Method in class com.hazelcast.jet.config.JetConfig
-
Returns the Jet-specific configuration properties.
- getQueueSize() - Method in class com.hazelcast.jet.config.EdgeConfig
-
Returns the size of the SPSC queues used to implement this edge.
- getReceiveWindowMultiplier() - Method in class com.hazelcast.jet.config.EdgeConfig
-
- getResourceConfigs() - Method in class com.hazelcast.jet.config.JobConfig
-
Returns all the registered resource configurations.
- getResult() - Method in class com.hazelcast.jet.datamodel.Session
-
Returns the aggregated result for the session.
- getRoutingPolicy() - Method in class com.hazelcast.jet.core.Edge
-
- getSnapshotIntervalMillis() - Method in class com.hazelcast.jet.config.JobConfig
-
- getSource() - Method in class com.hazelcast.jet.core.Edge
-
Returns this edge's source vertex.
- getSourceName() - Method in class com.hazelcast.jet.core.Edge
-
Returns the name of the source vertex.
- getSourceOrdinal() - Method in class com.hazelcast.jet.core.Edge
-
Returns the ordinal of the edge at the source vertex.
- getStart() - Method in class com.hazelcast.jet.datamodel.Session
-
Returns the starting timestamp of the session.
- getTempDir() - Method in class com.hazelcast.jet.config.InstanceConfig
-
Returns Jet's temp directory.
- getTimestamp() - Method in class com.hazelcast.jet.datamodel.TimestampedEntry
-
Returns the timestamp of this entry.
- getType() - Method in class com.hazelcast.jet.core.test.TestOutbox.MockData
-
- getUrl() - Method in class com.hazelcast.jet.config.ResourceConfig
-
Returns the URL at which the resource will be available.
- getValue() - Method in class com.hazelcast.jet.datamodel.TimestampedEntry
-
- getValue() - Method in class com.hazelcast.jet.datamodel.Tuple2
-
- getValue1() - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
Returns the current value1.
- getValue1() - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
-
Returns the current value1.
- getValue2() - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
Returns the current value2.
- getValue2() - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
-
Returns the current value2.
- getVertex(String) - Method in class com.hazelcast.jet.core.DAG
-
Returns the vertex with the given name.
- globalProcessorIndex() - Method in interface com.hazelcast.jet.core.Processor.Context
-
Returns the index of the processor among all the processors created for
this vertex on all nodes: its unique cluster-wide index.
- globalProcessorIndex() - Method in class com.hazelcast.jet.core.test.TestProcessorContext
-
- groupBy(DistributedFunction<? super E, ? extends K>, AggregateOperation1<? super E, A, R>) - Method in interface com.hazelcast.jet.ComputeStage
-
Attaches to this stage a group-by-key stage, one which will group all
received items by the key returned from the provided key-extracting
function.
- groupingBy(DistributedFunction<? super T, ? extends K>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- groupingBy(DistributedFunction<? super T, ? extends K>, DistributedCollector<? super T, A, D>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- groupingBy(DistributedFunction<? super T, ? extends K>, DistributedSupplier<M>, DistributedCollector<? super T, A, D>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- groupingByToICache(String, DistributedFunction<? super T, ? extends K>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- groupingByToICache(String, DistributedFunction<? super T, ? extends K>, DistributedCollector<? super T, A, D>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- groupingByToIMap(String, DistributedFunction<? super T, ? extends K>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- groupingByToIMap(String, DistributedFunction<? super T, ? extends K>, DistributedCollector<? super T, A, D>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- identity() - Static method in interface com.hazelcast.jet.function.DistributedDoubleUnaryOperator
-
- identity() - Static method in interface com.hazelcast.jet.function.DistributedFunction
-
- identity() - Static method in interface com.hazelcast.jet.function.DistributedIntUnaryOperator
-
- identity() - Static method in interface com.hazelcast.jet.function.DistributedLongUnaryOperator
-
- identity() - Static method in interface com.hazelcast.jet.function.DistributedUnaryOperator
-
- ifPresent(DistributedConsumer<? super T>) - Method in class com.hazelcast.jet.function.DistributedOptional
-
- Inbox - Interface in com.hazelcast.jet.core
-
A subset of Queue<Object>
API restricted to the consumer side,
with additional support for bulk draining operations.
- index() - Method in class com.hazelcast.jet.datamodel.Tag
-
Returns the index associated with this tag.
- init(Outbox, Processor.Context) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- init(Processor.Context) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Method that can be overridden to perform any necessary initialization
for the processor.
- init(ProcessorSupplier.Context) - Method in class com.hazelcast.jet.core.CloseableProcessorSupplier
-
- init(DefaultPartitionStrategy) - Method in class com.hazelcast.jet.core.Partitioner.Default
-
- init(DefaultPartitionStrategy) - Method in interface com.hazelcast.jet.core.Partitioner
-
- init(Outbox, Processor.Context) - Method in interface com.hazelcast.jet.core.Processor
-
Initializes this processor with the outbox that the processing methods
must use to deposit their output items.
- init(ProcessorMetaSupplier.Context) - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Called on the cluster member that receives the client request, after
deserializing the meta-supplier instance.
- init(ProcessorSupplier.Context) - Method in interface com.hazelcast.jet.core.ProcessorSupplier
-
Called on each cluster member after deserialization.
- input(List<?>) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Sets the input objects for processor.
- insertWatermarksP(DistributedToLongFunction<T>, DistributedSupplier<WatermarkPolicy>, WatermarkEmissionPolicy) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex that inserts
watermark items
into the stream.
- InstanceConfig - Class in com.hazelcast.jet.config
-
General configuration options pertaining to a Jet instance.
- InstanceConfig() - Constructor for class com.hazelcast.jet.config.InstanceConfig
-
- INTERNAL_JET_OBJECTS_PREFIX - Static variable in class com.hazelcast.jet.Jet
-
Prefix of all Hazelcast internal objects used by Jet (such as job
metadata, snapshots etc.)
- isArchive() - Method in class com.hazelcast.jet.config.ResourceConfig
-
Whether this entry is an Jar archive or a single resource element.
- isAutoRestartOnMemberFailureEnabled() - Method in class com.hazelcast.jet.config.JobConfig
-
- isCooperative() - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- isCooperative() - Method in interface com.hazelcast.jet.core.Processor
-
Tells whether this processor is able to participate in cooperative
multithreading.
- isDistributed() - Method in class com.hazelcast.jet.core.Edge
-
Says whether this edge is distributed.
- isEmpty() - Method in interface com.hazelcast.jet.core.Inbox
-
Returns true
if this inbox contains no elements, false
otherwise.
- isEqual(Object) - Static method in interface com.hazelcast.jet.function.DistributedPredicate
-
- isolated() - Method in class com.hazelcast.jet.core.Edge
-
Activates the
ISOLATED
routing policy
which establishes isolated paths from upstream to downstream processors.
- isPortable() - Method in class com.hazelcast.jet.core.test.TestOutbox.MockData
-
- isPresent() - Method in class com.hazelcast.jet.function.DistributedOptional
-
- isSplitBrainProtectionEnabled() - Method in class com.hazelcast.jet.config.JobConfig
-
- IStreamCache<K,V> - Interface in com.hazelcast.jet.stream
-
A decorator for
ICache
that provides a distributed
Stream
implementation.
- IStreamList<E> - Interface in com.hazelcast.jet.stream
-
A decorator for
IList
that provides a distributed
Stream
implementation.
- IStreamMap<K,V> - Interface in com.hazelcast.jet.stream
-
A decorator for
IMap
that provides a distributed
Stream
implementation.
- isTumbling() - Method in class com.hazelcast.jet.core.WindowDefinition
-
Tells whether this definition describes a tumbling window.
- isValidLocalParallelism(int) - Static method in class com.hazelcast.jet.core.Vertex
-
- ItemsByTag - Class in com.hazelcast.jet.datamodel
-
A heterogeneous map from Tag<E>
to E
, where E
can be different for each tag.
- ItemsByTag() - Constructor for class com.hazelcast.jet.datamodel.ItemsByTag
-
- itemsByTag(Object...) - Static method in class com.hazelcast.jet.datamodel.ItemsByTag
-
Accepts an argument list of alternating tags and values, interprets
them as a list of tag-value pairs, and returns an ItemsByTag
populated with these pairs.
- iterator() - Method in class com.hazelcast.jet.core.DAG
-
Returns an iterator over the DAG's vertices in topological order.
- lazy(Supplier<Traverser<T>>) - Static method in class com.hazelcast.jet.Traversers
-
Flattens a supplier of traverser into a lazy-initialized traverser.
- leftKeyFn() - Method in class com.hazelcast.jet.JoinClause
-
Returns the left-hand key extractor function.
- limit(long) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- limit(long) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- limit(long) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- limit(long) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- limitingLagAndDelay(long, long) - Static method in class com.hazelcast.jet.core.WatermarkPolicies
-
Maintains watermark that lags behind the top observed timestamp by at
most the given amount and is additionally guaranteed to reach the
timestamp of any given event within maxDelayMs
after observing
it.
- limitingLagAndLull(long, long) - Static method in class com.hazelcast.jet.core.WatermarkPolicies
-
Maintains watermark that lags behind the top timestamp by the amount
specified with lag
.
- limitingTimestampAndWallClockLag(long, long) - Static method in class com.hazelcast.jet.core.WatermarkPolicies
-
Maintains watermark that lags behind the top timestamp by at most
timestampLag
and behind wall-clock time by at most wallClockLag
.
- linearTrend(DistributedToLongFunction<T>, DistributedToLongFunction<T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that computes a linear trend on the items.
- LinTrendAccumulator - Class in com.hazelcast.jet.accumulator
-
Maintains the components needed to compute the linear regression on a
set of (long, long)
pairs.
- LinTrendAccumulator() - Constructor for class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Constructs a new accumulator with all components at zero.
- LinTrendAccumulator(long, BigInteger, BigInteger, BigInteger, BigInteger) - Constructor for class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Creates a new accumulator with the given components.
- list(String) - Static method in class com.hazelcast.jet.Sinks
-
Returns a sink that adds the items it receives to a Hazelcast IList
with the specified name.
- list(String) - Static method in class com.hazelcast.jet.Sources
-
Returns a source that emits items retrieved from a Hazelcast IList
.
- LOCAL_PARALLELISM_USE_DEFAULT - Static variable in class com.hazelcast.jet.core.Vertex
-
- localParallelism() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns the number of processors that each ProcessorSupplier
will be asked to create once deserialized on each member.
- localParallelism() - Method in interface com.hazelcast.jet.core.ProcessorSupplier.Context
-
Returns the number of processors that the associated ProcessorSupplier
will be asked to create.
- localParallelism() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
- localParallelism() - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
-
- localParallelism(int) - Method in class com.hazelcast.jet.core.Vertex
-
Sets the number of processors corresponding to this vertex that will be
created on each member.
- logger() - Method in interface com.hazelcast.jet.core.Processor.Context
-
Return a logger for the processor
- logger() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns a logger for the associated ProcessorSupplier
.
- logger() - Method in interface com.hazelcast.jet.core.ProcessorSupplier.Context
-
Returns a logger for the associated ProcessorSupplier
.
- logger() - Method in class com.hazelcast.jet.core.test.TestProcessorContext
-
- logger() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
- logger() - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
-
- logger(DistributedFunction<E, String>) - Static method in class com.hazelcast.jet.Sinks
-
Returns a sink that logs all the data items it receives, at the INFO
level to the log category
WriteLoggerP
.
- logger() - Static method in class com.hazelcast.jet.Sinks
-
- LongAccumulator - Class in com.hazelcast.jet.accumulator
-
Mutable container of a long
value.
- LongAccumulator() - Constructor for class com.hazelcast.jet.accumulator.LongAccumulator
-
Creates a new instance with value == 0
.
- LongAccumulator(long) - Constructor for class com.hazelcast.jet.accumulator.LongAccumulator
-
Creates a new instance with the specified value.
- LongDoubleAccumulator - Class in com.hazelcast.jet.accumulator
-
Mutable container of a long
and a double
value.
- LongDoubleAccumulator() - Constructor for class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
Creates a new instance with values equal to 0.
- LongDoubleAccumulator(long, double) - Constructor for class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
Creates a new instance with the specified value.
- LongLongAccumulator - Class in com.hazelcast.jet.accumulator
-
Mutable container of two long
values.
- LongLongAccumulator() - Constructor for class com.hazelcast.jet.accumulator.LongLongAccumulator
-
Creates a new instance with values equal to 0.
- LongLongAccumulator(long, long) - Constructor for class com.hazelcast.jet.accumulator.LongLongAccumulator
-
Creates a new instance with the specified value.
- main(String[]) - Static method in class com.hazelcast.jet.server.JetBootstrap
-
Runs the supplied JAR file and sets the static jar file name
- main(String[]) - Static method in class com.hazelcast.jet.server.StartServer
-
Creates a server instance of Hazelcast Jet.
- map(DistributedFunction<? super E, ? extends R>) - Method in interface com.hazelcast.jet.ComputeStage
-
Attaches to this stage a mapping stage, one which applies the supplied
function to each input item independently and emits the function's
result as the output item.
- map(DistributedFunction<? super T, ? extends U>) - Method in class com.hazelcast.jet.function.DistributedOptional
-
- map(String) - Static method in class com.hazelcast.jet.Sinks
-
Returns a sink that puts Map.Entry
s it receives into a Hazelcast
IMap
with the specified name.
- map(String) - Static method in class com.hazelcast.jet.Sources
-
Returns a source that fetches entries from a local Hazelcast IMap
with the specified name and emits them as Map.Entry
.
- map(String, Predicate<K, V>, Projection<Map.Entry<K, V>, T>) - Static method in class com.hazelcast.jet.Sources
-
Returns a source that fetches entries from a local Hazelcast IMap
with the specified name.
- map(String, Predicate<K, V>, DistributedFunction<Map.Entry<K, V>, T>) - Static method in class com.hazelcast.jet.Sources
-
- map(DistributedDoubleUnaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- map(DoubleUnaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- map(DistributedIntUnaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- map(IntUnaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- map(DistributedLongUnaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- map(LongUnaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- map(DistributedFunction<? super T, ? extends R>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- map(Function<? super T, ? extends R>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- map(Function<? super T, ? extends R>) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser traverser that will emit the results of applying the
mapping function to this traverser's items.
- mapJournal(String, DistributedPredicate<EventJournalMapEvent<K, V>>, DistributedFunction<EventJournalMapEvent<K, V>, T>, boolean) - Static method in class com.hazelcast.jet.Sources
-
Returns a source that will stream the EventJournalMapEvent
events of the Hazelcast IMap
with the specified name.
- mapJournal(String, boolean) - Static method in class com.hazelcast.jet.Sources
-
- mapP(DistributedFunction<T, R>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processors for a vertex which, for each received
item, emits the result of applying the given mapping function to it.
- mapping(DistributedFunction<? super T, ? extends U>, AggregateOperation1<? super U, A, R>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Adapts an aggregate operation accepting items of type U
to one accepting items of type T
by applying a mapping
function to each item before accumulation.
- mapping(DistributedFunction<? super T, ? extends U>, DistributedCollector<? super U, A, R>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- mapToDouble(DistributedIntToDoubleFunction) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- mapToDouble(IntToDoubleFunction) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- mapToDouble(DistributedLongToDoubleFunction) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- mapToDouble(LongToDoubleFunction) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- mapToDouble(DistributedToDoubleFunction<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- mapToDouble(ToDoubleFunction<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- mapToInt(DistributedDoubleToIntFunction) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- mapToInt(DoubleToIntFunction) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- mapToInt(DistributedLongToIntFunction) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- mapToInt(LongToIntFunction) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- mapToInt(DistributedToIntFunction<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- mapToInt(ToIntFunction<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- mapToLong(DistributedDoubleToLongFunction) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- mapToLong(DoubleToLongFunction) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- mapToLong(DistributedIntToLongFunction) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- mapToLong(IntToLongFunction) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- mapToLong(DistributedToLongFunction<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- mapToLong(ToLongFunction<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- mapToObj(DistributedDoubleFunction<? extends U>) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- mapToObj(DoubleFunction<? extends U>) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- mapToObj(DistributedIntFunction<? extends U>) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- mapToObj(IntFunction<? extends U>) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- mapToObj(DistributedLongFunction<? extends U>) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- mapToObj(LongFunction<? extends U>) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- max(DistributedComparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- max(Comparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- maxBy(DistributedComparator<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that computes the maximal item according
to the given comparator
.
- maxBy(Comparator<? super T>) - Static method in interface com.hazelcast.jet.function.DistributedBinaryOperator
-
- maxBy(DistributedComparator<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- min(DistributedComparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- min(Comparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- minBy(DistributedComparator<? super T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that computes the minimal item according
to the given comparator
.
- minBy(Comparator<? super T>) - Static method in interface com.hazelcast.jet.function.DistributedBinaryOperator
-
- minBy(DistributedComparator<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- MockData(Object) - Constructor for class com.hazelcast.jet.core.test.TestOutbox.MockData
-
Javadoc pending
- MockSerializationService() - Constructor for class com.hazelcast.jet.core.test.TestOutbox.MockSerializationService
-
- MutableReference<T> - Class in com.hazelcast.jet.accumulator
-
Mutable container of an object reference.
- MutableReference() - Constructor for class com.hazelcast.jet.accumulator.MutableReference
-
Creates a new instance with a null
value.
- MutableReference(T) - Constructor for class com.hazelcast.jet.accumulator.MutableReference
-
Creates a new instance with the specified value.
- name() - Method in interface com.hazelcast.jet.Transform
-
Returns the name of this transformation.
- naturalOrder() - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- negate() - Method in interface com.hazelcast.jet.function.DistributedBiPredicate
-
- negate() - Method in interface com.hazelcast.jet.function.DistributedDoublePredicate
-
- negate() - Method in interface com.hazelcast.jet.function.DistributedIntPredicate
-
- negate() - Method in interface com.hazelcast.jet.function.DistributedLongPredicate
-
- negate() - Method in interface com.hazelcast.jet.function.DistributedPredicate
-
- newJetClient() - Static method in class com.hazelcast.jet.Jet
-
Creates a Jet client with the default configuration.
- newJetClient(ClientConfig) - Static method in class com.hazelcast.jet.Jet
-
Creates a Jet client with the given Hazelcast client configuration.
- newJetInstance(JetConfig) - Static method in class com.hazelcast.jet.Jet
-
Creates a member of the Jet cluster with the given configuration.
- newJetInstance() - Static method in class com.hazelcast.jet.Jet
-
Creates a member of the Jet cluster with the default configuration.
- newJob(DAG) - Method in interface com.hazelcast.jet.JetInstance
-
Creates and returns a Jet job based on the supplied DAG.
- newJob(DAG, JobConfig) - Method in interface com.hazelcast.jet.JetInstance
-
Creates and returns a Jet job based on the supplied DAG and job
configuration.
- newJob(Pipeline) - Method in interface com.hazelcast.jet.JetInstance
-
Creates and returns an executable job based on the supplied pipeline.
- newJob(Pipeline, JobConfig) - Method in interface com.hazelcast.jet.JetInstance
-
Creates and returns a Jet job based on the supplied pipeline and job
configuration.
- newVertex(String, DistributedSupplier<? extends Processor>) - Method in class com.hazelcast.jet.core.DAG
-
Creates a vertex from a Supplier<Processor>
and adds it to this DAG.
- newVertex(String, ProcessorSupplier) - Method in class com.hazelcast.jet.core.DAG
-
Creates a vertex from a ProcessorSupplier
and adds it to this DAG.
- newVertex(String, ProcessorMetaSupplier) - Method in class com.hazelcast.jet.core.DAG
-
Creates a vertex from a ProcessorMetaSupplier
and adds it to this DAG.
- next() - Method in class com.hazelcast.jet.core.ResettableSingletonTraverser
-
- next() - Method in interface com.hazelcast.jet.Traverser
-
Returns the next item in the sequence, or null
if there is no next
item to return.
- nonCooperativeP(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Decorates a processor meta-supplier with one that will declare all its
processors non-cooperative.
- nonCooperativeP(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Decorates a ProcessorSupplier
with one that will declare all its
processors non-cooperative.
- nonCooperativeP(DistributedSupplier<Processor>) - Static method in class com.hazelcast.jet.core.processor.Processors
-
Decorates a Supplier<Processor>
into one that will declare
its processors non-cooperative.
- noneMatch(DistributedDoublePredicate) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- noneMatch(DoublePredicate) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- noneMatch(DistributedIntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- noneMatch(IntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- noneMatch(DistributedLongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- noneMatch(LongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- noneMatch(DistributedPredicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- noneMatch(Predicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- noopConsumer() - Static method in class com.hazelcast.jet.function.DistributedFunctions
-
Returns a consumer that does nothing with the argument.
- noopP() - Static method in class com.hazelcast.jet.core.processor.Processors
-
Returns a supplier of processor that consumes all its input (if any) and
does nothing with it.
- nullsFirst(Comparator<? super T>) - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- nullsFirst(DistributedComparator<? super T>) - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- nullsLast(Comparator<? super T>) - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- nullsLast(DistributedComparator<? super T>) - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- of(ProcessorSupplier, int) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Factory method that wraps the given ProcessorSupplier
and
returns the same instance for each given Address
.
- of(ProcessorSupplier) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Wraps the provided ProcessorSupplier
into a meta-supplier that
will always return it.
- of(DistributedSupplier<? extends Processor>, int) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Factory method that wraps the given Supplier<Processor>
and uses it as the supplier of all Processor
instances.
- of(DistributedSupplier<? extends Processor>) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Factory method that wraps the given Supplier<Processor>
and uses it as the supplier of all Processor
instances.
- of(DistributedFunction<Address, ProcessorSupplier>, int) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
- of(DistributedFunction<Address, ProcessorSupplier>) - Static method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
- of(DistributedSupplier<? extends Processor>) - Static method in interface com.hazelcast.jet.core.ProcessorSupplier
-
Returns a ProcessorSupplier
which will delegate to the given
Supplier<Processor>
to create all Processor
instances.
- of(T) - Static method in class com.hazelcast.jet.function.DistributedOptional
-
Serializable
variant of java.util.Optional#of(T)
.
- of(DistributedSupplier<R>, DistributedBiConsumer<R, T>, DistributedBinaryOperator<R>, Collector.Characteristics...) - Static method in interface com.hazelcast.jet.stream.DistributedCollector
-
- of(DistributedSupplier<A>, DistributedBiConsumer<A, T>, DistributedBinaryOperator<A>, DistributedFunction<A, R>, Collector.Characteristics...) - Static method in interface com.hazelcast.jet.stream.DistributedCollector
-
- offer(int, Object) - Method in interface com.hazelcast.jet.core.Outbox
-
Offers the supplied item to the bucket with the supplied ordinal.
- offer(int[], Object) - Method in interface com.hazelcast.jet.core.Outbox
-
Offers the item to all supplied edge ordinals.
- offer(Object) - Method in interface com.hazelcast.jet.core.Outbox
-
Offers the item to all edges.
- offer(int, Object) - Method in class com.hazelcast.jet.core.test.TestOutbox
-
- offer(int[], Object) - Method in class com.hazelcast.jet.core.test.TestOutbox
-
- offer(Object) - Method in class com.hazelcast.jet.core.test.TestOutbox
-
- offerToSnapshot(Object, Object) - Method in interface com.hazelcast.jet.core.Outbox
-
Offers the given key and value pair to the processor's snapshot
storage.
- offerToSnapshot(Object, Object) - Method in class com.hazelcast.jet.core.test.TestOutbox
-
- ofNullable(T) - Static method in class com.hazelcast.jet.function.DistributedOptional
-
Serializable
variant of java.util.Optional#ofNullable(T)
.
- onFirstNull(Runnable) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser that will emit the same items as this traverser and
additionally run the supplied action the first time this traverser
returns null
.
- onKeys(DistributedFunction<E0, K>, DistributedFunction<E1, K>) - Static method in class com.hazelcast.jet.JoinClause
-
Constructs and returns a join clause with the supplied left-hand and
right-hand key extractor functions, and with an identity right-hand
projection function.
- or(DistributedBiPredicate<? super T, ? super U>) - Method in interface com.hazelcast.jet.function.DistributedBiPredicate
-
- or(DistributedDoublePredicate) - Method in interface com.hazelcast.jet.function.DistributedDoublePredicate
-
- or(DistributedIntPredicate) - Method in interface com.hazelcast.jet.function.DistributedIntPredicate
-
- or(DistributedLongPredicate) - Method in interface com.hazelcast.jet.function.DistributedLongPredicate
-
- or(DistributedPredicate<? super T>) - Method in interface com.hazelcast.jet.function.DistributedPredicate
-
- orElse(T) - Method in class com.hazelcast.jet.function.DistributedOptional
-
Serializable
variant of java.util.Optional#orElse(T)
.
- orElseGet(DistributedSupplier<? extends T>) - Method in class com.hazelcast.jet.function.DistributedOptional
-
- orElseThrow(DistributedSupplier<? extends X>) - Method in class com.hazelcast.jet.function.DistributedOptional
-
- Outbox - Interface in com.hazelcast.jet.core
-
- outputChecker(BiPredicate<? super List<?>, ? super List<?>>) - Method in class com.hazelcast.jet.core.test.TestSupport
-
Predicate to compare expected and actual output.
- over(T...) - Static method in interface com.hazelcast.jet.Traverser
-
Returns a traverser over the supplied arguments (or item array).
- parallel() - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- parallel() - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- parallel() - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- parallel() - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- parallelStream() - Method in interface com.hazelcast.jet.stream.IStreamList
-
- partitioned(DistributedFunction<T, ?>) - Method in class com.hazelcast.jet.core.Edge
-
Activates the
PARTITIONED
routing
policy and applies the
default
Hazelcast partitioning strategy.
- partitioned(DistributedFunction<T, K>, Partitioner<? super K>) - Method in class com.hazelcast.jet.core.Edge
-
Activates the
PARTITIONED
routing
policy and applies the provided partitioning strategy.
- Partitioner<T> - Interface in com.hazelcast.jet.core
-
Encapsulates the logic associated with a
DAG
edge that decides
on the partition ID of an item traveling over it.
- Partitioner.Default - Class in com.hazelcast.jet.core
-
Partitioner which applies the default Hazelcast partitioning strategy.
- partitioningBy(DistributedPredicate<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- partitioningBy(DistributedPredicate<? super T>, DistributedCollector<? super T, A, D>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- peek(DistributedPredicate<? super E>, DistributedFunction<? super E, String>) - Method in interface com.hazelcast.jet.ComputeStage
-
Adds a peeking layer to this compute stage which logs its output.
- peek(DistributedFunction<? super E, String>) - Method in interface com.hazelcast.jet.ComputeStage
-
Adds a peeking layer to this compute stage which logs its output.
- peek() - Method in interface com.hazelcast.jet.ComputeStage
-
Adds a peeking layer to this compute stage which logs its output.
- peek() - Method in interface com.hazelcast.jet.core.Inbox
-
Retrieves, but does not remove, the head of this inbox, or returns
null
if it is empty.
- peek(DistributedDoubleConsumer) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- peek(DoubleConsumer) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- peek(DistributedIntConsumer) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- peek(IntConsumer) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- peek(DistributedLongConsumer) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- peek(LongConsumer) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- peek(DistributedConsumer<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- peek(Consumer<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- peek(Consumer<? super T>) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser that will emit the same items as this traverser,
additionally passing each (non-null) item to the supplied consumer.
- peekInputP(DistributedFunction<T, String>, DistributedPredicate<T>, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Returns a meta-supplier that wraps the provided one and adds a logging
layer to each processor it creates.
- peekInputP(DistributedFunction<T, String>, DistributedPredicate<T>, ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekInputP(DistributedFunction<T, String>, DistributedPredicate<T>, DistributedSupplier<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekInputP(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekInputP(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekInputP(DistributedSupplier<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekOutputP(DistributedFunction<T, String>, DistributedPredicate<T>, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Returns a meta-supplier that wraps the provided one and adds a logging
layer to each processor it creates.
- peekOutputP(DistributedFunction<T, String>, DistributedPredicate<T>, ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekOutputP(DistributedFunction<T, String>, DistributedPredicate<T>, DistributedSupplier<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekOutputP(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekOutputP(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekOutputP(DistributedSupplier<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekSnapshotP(DistributedFunction<Map.Entry<K, V>, String>, DistributedPredicate<Map.Entry<K, V>>, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Returns a meta-supplier that wraps the provided one and adds a logging
layer to each processor it creates.
- peekSnapshotP(DistributedFunction<Map.Entry<K, V>, String>, DistributedPredicate<Map.Entry<K, V>>, ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekSnapshotP(DistributedFunction<Map.Entry<K, V>, String>, DistributedPredicate<Map.Entry<K, V>>, DistributedSupplier<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekSnapshotP(DistributedSupplier<Processor>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekSnapshotP(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- peekSnapshotP(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- Pipeline - Interface in com.hazelcast.jet
-
Models a distributed computation job using an analogy with a system of
interconnected water pipes.
- poll() - Method in interface com.hazelcast.jet.core.Inbox
-
Retrieves and removes the head of this inbox, or returns null
if it is empty.
- preferredLocalParallelism() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier
-
Returns the local parallelism the vertex should be configured with.
- prepend(T) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser which prepends an additional item in front of
all the items of this traverser.
- priority(int) - Method in class com.hazelcast.jet.core.Edge
-
Sets the priority of the edge.
- process(int, Inbox) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Implements the boilerplate of dispatching against the ordinal,
taking items from the inbox one by one, and invoking the
processing logic on each.
- process(int, Inbox) - Method in interface com.hazelcast.jet.core.Processor
-
Called with a batch of items retrieved from an inbound edge's stream.
- ProcessingGuarantee - Enum in com.hazelcast.jet.config
-
Defines what message processing guarantees are given under failure
conditions.
- processingGuarantee() - Method in interface com.hazelcast.jet.core.Processor.Context
-
Returns the guarantee for current job.
- processingGuarantee() - Method in class com.hazelcast.jet.core.test.TestProcessorContext
-
- Processor - Interface in com.hazelcast.jet.core
-
When Jet executes a DAG, it creates one or more instances of Processor
on each cluster member to do the work of a given vertex.
- Processor.Context - Interface in com.hazelcast.jet.core
-
Context passed to the processor in the
init()
call.
- ProcessorMetaSupplier - Interface in com.hazelcast.jet.core
-
- ProcessorMetaSupplier.Context - Interface in com.hazelcast.jet.core
-
Context passed to the meta-supplier at init time on the member that
received a job request from the client.
- Processors - Class in com.hazelcast.jet.core.processor
-
Static utility class with factory methods for Jet processors.
- ProcessorSupplier - Interface in com.hazelcast.jet.core
-
- ProcessorSupplier.Context - Interface in com.hazelcast.jet.core
-
Context passed to the supplier in the
init()
call.
- projecting(DistributedFunction<E1, E1_NEW_OUT>) - Method in class com.hazelcast.jet.JoinClause
-
Returns a copy of this join clause, but with the right-hand projection
function replaced with the supplied one.
- put(Tag<E>, E) - Method in class com.hazelcast.jet.datamodel.ItemsByTag
-
Associates the supplied value with the supplied tag.
- readCacheP(String) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.core.DAG
-
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.core.Edge
-
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.core.Vertex
-
- readFilesP(String, Charset, String) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readListP(String) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readMapP(String) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readMapP(String, Predicate<K, V>, Projection<Map.Entry<K, V>, T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readMapP(String, Predicate<K, V>, DistributedFunction<Map.Entry<K, V>, T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readRemoteCacheP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readRemoteListP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readRemoteMapP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readRemoteMapP(String, ClientConfig, Predicate<K, V>, Projection<Map.Entry<K, V>, T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- readRemoteMapP(String, ClientConfig, Predicate<K, V>, DistributedFunction<Map.Entry<K, V>, T>) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- reduce(StreamContext, Pipe<? extends T>) - Method in interface com.hazelcast.jet.stream.DistributedCollector.Reducer
-
Executes the reducer with the given context and upstream pipeline.
- reduce(double, DistributedDoubleBinaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- reduce(DistributedDoubleBinaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- reduce(double, DoubleBinaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- reduce(DoubleBinaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- reduce(int, DistributedIntBinaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- reduce(DistributedIntBinaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- reduce(int, IntBinaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- reduce(IntBinaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- reduce(long, DistributedLongBinaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- reduce(DistributedLongBinaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- reduce(long, LongBinaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- reduce(LongBinaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- reduce(T, DistributedBinaryOperator<T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- reduce(DistributedBinaryOperator<T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- reduce(U, DistributedBiFunction<U, ? super T, U>, DistributedBinaryOperator<U>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- reduce(T, BinaryOperator<T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- reduce(BinaryOperator<T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- reduce(U, BiFunction<U, ? super T, U>, BinaryOperator<U>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- reducing(A, DistributedFunction<? super T, ? extends A>, DistributedBinaryOperator<A>, DistributedBinaryOperator<A>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
A reducing operation maintains an accumulated value that starts out as
emptyAccValue
and is iteratively transformed by applying
combineAccValuesFn
to it and each stream item's accumulated
value, as returned from toAccValueFn
.
- reducing(T, DistributedBinaryOperator<T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- reducing(DistributedBinaryOperator<T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- reducing(U, DistributedFunction<? super T, ? extends U>, DistributedBinaryOperator<U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- remoteCache(String, ClientConfig) - Static method in class com.hazelcast.jet.Sinks
-
Returns a sink that puts Map.Entry
s it receives into a Hazelcast
ICache
with the specified name in a remote cluster identified by
the supplied ClientConfig
.
- remoteCache(String, ClientConfig) - Static method in class com.hazelcast.jet.Sources
-
Returns a source that fetches entries from the Hazelcast ICache
with the specified name in a remote cluster identified by the supplied
ClientConfig
and emits them as Map.Entry
.
- remoteCacheJournal(String, ClientConfig, DistributedPredicate<EventJournalCacheEvent<K, V>>, DistributedFunction<EventJournalCacheEvent<K, V>, T>, boolean) - Static method in class com.hazelcast.jet.Sources
-
Returns a source that will stream the EventJournalCacheEvent
events of the Hazelcast ICache
with the specified name from a
remote cluster.
- remoteCacheJournal(String, ClientConfig, boolean) - Static method in class com.hazelcast.jet.Sources
-
- remoteList(String, ClientConfig) - Static method in class com.hazelcast.jet.Sinks
-
Returns a sink that adds the items it receives to a Hazelcast IList
with the specified name in a remote cluster identified by the
supplied ClientConfig
.
- remoteList(String, ClientConfig) - Static method in class com.hazelcast.jet.Sources
-
Returns a source that emits items retrieved from a Hazelcast IList
in a remote cluster identified by the supplied ClientConfig
.
- remoteMap(String, ClientConfig) - Static method in class com.hazelcast.jet.Sinks
-
Returns a sink that puts Map.Entry
s it receives into a Hazelcast
IMap
with the specified name in a remote cluster identified by
the supplied ClientConfig
.
- remoteMap(String, ClientConfig) - Static method in class com.hazelcast.jet.Sources
-
Returns a source that fetches entries from the Hazelcast IMap
with the specified name in a remote cluster identified by the supplied
ClientConfig
and emits them as Map.Entry
.
- remoteMap(String, ClientConfig, Predicate<K, V>, Projection<Map.Entry<K, V>, T>) - Static method in class com.hazelcast.jet.Sources
-
Returns a source that fetches entries from a remote Hazelcast IMap
with the specified name in a remote cluster identified by the
supplied ClientConfig
.
- remoteMap(String, ClientConfig, Predicate<K, V>, DistributedFunction<Map.Entry<K, V>, T>) - Static method in class com.hazelcast.jet.Sources
-
- remoteMapJournal(String, ClientConfig, DistributedPredicate<EventJournalMapEvent<K, V>>, DistributedFunction<EventJournalMapEvent<K, V>, T>, boolean) - Static method in class com.hazelcast.jet.Sources
-
Returns a source that will stream the EventJournalMapEvent
events of the Hazelcast IMap
with the specified name from a
remote cluster.
- remoteMapJournal(String, ClientConfig, boolean) - Static method in class com.hazelcast.jet.Sources
-
- remove() - Method in interface com.hazelcast.jet.core.Inbox
-
Retrieves and removes the head of this inbox.
- reportEvent(long) - Method in interface com.hazelcast.jet.core.WatermarkPolicy
-
Called to report the observation of an event with the given timestamp.
- ResettableSingletonTraverser<T> - Class in com.hazelcast.jet.core
-
Traverses over a single item which can be set from the outside, by using
this traverser as a Consumer<T>
.
- ResettableSingletonTraverser() - Constructor for class com.hazelcast.jet.core.ResettableSingletonTraverser
-
- ResourceConfig - Class in com.hazelcast.jet.config
-
Describes a single resource to deploy to the Jet cluster.
- restoreFromSnapshot(Inbox) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Implements the boilerplate of polling the inbox, casting the items to
Map.Entry
, and extracting the key and value.
- restoreFromSnapshot(Object, Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Called to restore one key-value pair from the snapshot to processor's
internal state.
- restoreFromSnapshot(Inbox) - Method in interface com.hazelcast.jet.core.Processor
-
Called when a batch of items is received during the "restore from
snapshot" operation.
- reversed() - Method in interface com.hazelcast.jet.function.DistributedComparator
-
- reverseOrder() - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
- rightKeyFn() - Method in class com.hazelcast.jet.JoinClause
-
Returns the right-hand key extractor function.
- rightProjectFn() - Method in class com.hazelcast.jet.JoinClause
-
Returns the right-hand projection function.
- saveToSnapshot() - Method in interface com.hazelcast.jet.core.Processor
-
Stores its snapshotted state by adding items to the outbox's
snapshot bucket
.
- sequential() - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- sequential() - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- sequential() - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- sequential() - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- Session<K,R> - Class in com.hazelcast.jet.datamodel
-
Holds the aggregated result of a session window.
- Session(K, long, long, R) - Constructor for class com.hazelcast.jet.datamodel.Session
-
- set(double) - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
-
Sets the value as given.
- set(long) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
Sets the value as given.
- set(T) - Method in class com.hazelcast.jet.accumulator.MutableReference
-
Sets the value as given.
- setAutoRestartOnMemberFailure(boolean) - Method in class com.hazelcast.jet.config.JobConfig
-
Sets whether the job should automatically restart after a
participating member leaves the cluster.
- setBackupCount(int) - Method in class com.hazelcast.jet.config.InstanceConfig
-
Sets the number of synchronous backups for storing job metadata and
snapshots.
- setConfig(EdgeConfig) - Method in class com.hazelcast.jet.core.Edge
-
Assigns an EdgeConfig
to this edge.
- setCooperative(boolean) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- setCooperativeThreadCount(int) - Method in class com.hazelcast.jet.config.InstanceConfig
-
Sets the number of threads each cluster member will use to execute Jet
jobs.
- setDefaultEdgeConfig(EdgeConfig) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets the configuration object that specifies the defaults to use
for a DAG edge configuration.
- setFlowControlPeriodMs(int) - Method in class com.hazelcast.jet.config.InstanceConfig
-
While executing a Jet job there is the issue of regulating the rate
at which one member of the cluster sends data to another member.
- setGlobalProcessorIndex(int) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
-
Set the global processor index
- setHazelcastConfig(Config) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets the underlying IMDG instance's configuration object.
- setInstanceConfig(InstanceConfig) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets the Jet instance config.
- setJetInstance(JetInstance) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
-
Set the jet instance.
- setJetInstance(JetInstance) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Set the jet instance.
- setJetInstance(JetInstance) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
-
Set the jet instance.
- setLocalParallelism(int) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Set local parallelism.
- setLocalParallelism(int) - Method in class com.hazelcast.jet.core.test.TestProcessorSupplierContext
-
Set local parallelism.
- setLogger(ILogger) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
-
Set the logger.
- setPacketSizeLimit(int) - Method in class com.hazelcast.jet.config.EdgeConfig
-
For a distributed edge, data is sent to a remote member via Hazelcast network
packets.
- setProcessingGuarantee(ProcessingGuarantee) - Method in class com.hazelcast.jet.config.JobConfig
-
- setProcessingGuarantee(ProcessingGuarantee) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
-
Sets the processing guarantee.
- setProperties(Properties) - Method in class com.hazelcast.jet.config.JetConfig
-
Sets the Jet-specific configuration properties.
- setQueueSize(int) - Method in class com.hazelcast.jet.config.EdgeConfig
-
Sets the capacity of processor-to-processor concurrent queues.
- setReceiveWindowMultiplier(int) - Method in class com.hazelcast.jet.config.EdgeConfig
-
Sets the scaling factor used by the adaptive receive window sizing
function.
- setSnapshotIntervalMillis(long) - Method in class com.hazelcast.jet.config.JobConfig
-
Sets the snapshot interval in milliseconds — the interval between
the completion of the previous snapshot and the start of a new one.
- setSplitBrainProtection(boolean) - Method in class com.hazelcast.jet.config.JobConfig
-
Configures the split brain protection feature.
- setTempDir(String) - Method in class com.hazelcast.jet.config.InstanceConfig
-
Sets the directory where Jet can place its temporary working directories.
- setTotalParallelism(int) - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
Set total parallelism.
- setValue(V) - Method in class com.hazelcast.jet.datamodel.TimestampedEntry
-
- setValue(E1) - Method in class com.hazelcast.jet.datamodel.Tuple2
-
- setValue1(long) - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
Sets the value1.
- setValue1(long) - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
-
Sets the value1.
- setValue2(double) - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
Sets the value2.
- setValue2(long) - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
-
Sets the value2.
- setVertexName(String) - Method in class com.hazelcast.jet.core.test.TestProcessorContext
-
Set the vertex name.
- shouldEmit(long, long) - Method in interface com.hazelcast.jet.core.WatermarkEmissionPolicy
-
Decides whether a watermark item with the supplied currentWm
value should be emitted, given the last emitted value lastEmittedWm
.
- shutdown() - Method in interface com.hazelcast.jet.JetInstance
-
Shutdowns the current instance.
- shutdownAll() - Static method in class com.hazelcast.jet.Jet
-
Shuts down all running Jet client and member instances.
- Sink<E> - Interface in com.hazelcast.jet
-
A transform which accepts an input stream and produces no output
streams.
- SinkProcessors - Class in com.hazelcast.jet.core.processor
-
Static utility class with factories of sink processors (the terminators
of the DAG data flow).
- Sinks - Class in com.hazelcast.jet
-
Contains factory methods for various types of pipeline sinks.
- SinkStage - Interface in com.hazelcast.jet
-
A pipeline stage that doesn't allow any downstream stages to be attached
to it.
- skip(long) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- skip(long) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- skip(long) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- skip(long) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- slidingWindowDef(long, long) - Static method in class com.hazelcast.jet.core.WindowDefinition
-
Returns the definition of a sliding window of length windowLength
that slides by slideBy
.
- snapshotQueue() - Method in class com.hazelcast.jet.core.test.TestOutbox
-
Returns the queue to which snapshot is written.
- snapshottingEnabled() - Method in interface com.hazelcast.jet.core.Processor.Context
-
Returns true, if snapshots will be saved for this job.
- socket(String, int, DistributedFunction<E, String>, Charset) - Static method in class com.hazelcast.jet.Sinks
-
Returns a sink that connects to the specified TCP socket and writes to
it a string representation of the items it receives.
- socket(String, int, DistributedFunction<E, String>) - Static method in class com.hazelcast.jet.Sinks
-
- socket(String, int) - Static method in class com.hazelcast.jet.Sinks
-
- socket(String, int, Charset) - Static method in class com.hazelcast.jet.Sources
-
Returns a source which connects to the specified socket and emits lines
of text received from it.
- sorted() - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- sorted() - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- sorted() - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- sorted() - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- sorted(DistributedComparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- sorted(Comparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- Source<E> - Interface in com.hazelcast.jet
-
A transform that takes no input streams and produces an output stream.
- SourceProcessors - Class in com.hazelcast.jet.core.processor
-
Static utility class with factories of source processors (the DAG
entry points).
- Sources - Class in com.hazelcast.jet
-
Contains factory methods for various types of pipeline sources.
- Stage - Interface in com.hazelcast.jet
-
- StartServer - Class in com.hazelcast.jet.server
-
Main class that starts a Hazelcast Jet instance.
- stream() - Method in interface com.hazelcast.jet.stream.IStreamCache
-
- stream() - Method in interface com.hazelcast.jet.stream.IStreamList
-
- stream() - Method in interface com.hazelcast.jet.stream.IStreamMap
-
- stream(Predicate<K, V>, DistributedFunction<Map.Entry<K, V>, T>) - Method in interface com.hazelcast.jet.stream.IStreamMap
-
- streamCacheP(String, boolean) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- streamCacheP(String, DistributedPredicate<EventJournalCacheEvent<K, V>>, DistributedFunction<EventJournalCacheEvent<K, V>, T>, boolean) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- streamFilesP(String, Charset, String) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- streamMapP(String, boolean) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- streamMapP(String, DistributedPredicate<EventJournalMapEvent<K, V>>, DistributedFunction<EventJournalMapEvent<K, V>, T>, boolean) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- streamRemoteCacheP(String, ClientConfig, boolean) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- streamRemoteCacheP(String, ClientConfig, DistributedPredicate<EventJournalCacheEvent<K, V>>, DistributedFunction<EventJournalCacheEvent<K, V>, T>, boolean) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- streamRemoteMapP(String, ClientConfig, boolean) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- streamRemoteMapP(String, ClientConfig, DistributedPredicate<EventJournalMapEvent<K, V>>, DistributedFunction<EventJournalMapEvent<K, V>, T>, boolean) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- streamSocketP(String, int, Charset) - Static method in class com.hazelcast.jet.core.processor.SourceProcessors
-
- subtract(DoubleAccumulator) - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
-
Subtracts the value of the supplied accumulator from this one.
- subtract(LongAccumulator) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
Subtracts the value of the supplied accumulator from this one.
- subtractExact(LongAccumulator) - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
- summarizingDouble(DistributedToDoubleFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- summarizingInt(DistributedToIntFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- summarizingLong(DistributedToLongFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- summingDouble(DistributedToDoubleFunction<T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that computes the sum of the double
values it obtains by applying getDoubleValueFn
to each item.
- summingDouble(DistributedToDoubleFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- summingInt(DistributedToIntFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- summingLong(DistributedToLongFunction<T>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that computes the sum of the long
values it obtains by applying getLongValueFn
to each item.
- summingLong(DistributedToLongFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- supplier() - Method in interface com.hazelcast.jet.stream.DistributedCollector
-
- supplierFrom(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
Wraps the provided ProcessorSupplier
with a Supplier<Processor>
that returns processors obtained from it.
- supplierFrom(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
Wraps the provided ProcessorMetaSupplier
with a Supplier<Processor>
that returns processors obtained from it.
- suppressDuplicates() - Static method in interface com.hazelcast.jet.core.WatermarkEmissionPolicy
-
Returns a policy that ensures that each emitted watermark has a higher
timestamp than the last one.
- Tag<T> - Class in com.hazelcast.jet.datamodel
-
A tag object useful as a key in heterogeneous maps.
- tag(int) - Static method in class com.hazelcast.jet.datamodel.Tag
-
Returns a tag object associated with the specified index.
- tag0() - Method in class com.hazelcast.jet.CoGroupBuilder
-
Returns the tag referring to the 0-indexed contributing pipeline
stage, the one from which this builder was obtained.
- tag0() - Static method in class com.hazelcast.jet.datamodel.Tag
-
- tag1() - Static method in class com.hazelcast.jet.datamodel.Tag
-
- tag2() - Static method in class com.hazelcast.jet.datamodel.Tag
-
- takeWhile(Predicate<? super T>) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser that will emit a prefix of the original traverser,
up to the item for which the predicate fails (exclusive).
- TestInbox - Class in com.hazelcast.jet.core.test
-
- TestInbox() - Constructor for class com.hazelcast.jet.core.test.TestInbox
-
- TestOutbox - Class in com.hazelcast.jet.core.test
-
- TestOutbox(int...) - Constructor for class com.hazelcast.jet.core.test.TestOutbox
-
- TestOutbox(int[], int) - Constructor for class com.hazelcast.jet.core.test.TestOutbox
-
- TestOutbox.MockData - Class in com.hazelcast.jet.core.test
-
Javadoc pending
- TestOutbox.MockSerializationService - Class in com.hazelcast.jet.core.test
-
Javadoc pending
- TestProcessorContext - Class in com.hazelcast.jet.core.test
-
Simple implementation of Processor.Context
.
- TestProcessorContext() - Constructor for class com.hazelcast.jet.core.test.TestProcessorContext
-
Constructor with default values.
- TestProcessorMetaSupplierContext - Class in com.hazelcast.jet.core.test
-
Simple implementation of ProcessorMetaSupplier.Context
.
- TestProcessorMetaSupplierContext() - Constructor for class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
- TestProcessorSupplierContext - Class in com.hazelcast.jet.core.test
-
Simple implementation of ProcessorSupplier.Context
.
- TestProcessorSupplierContext() - Constructor for class com.hazelcast.jet.core.test.TestProcessorSupplierContext
-
- TestSupport - Class in com.hazelcast.jet.core.test
-
A utility to test processors.
- thenComparing(Comparator<? super T>) - Method in interface com.hazelcast.jet.function.DistributedComparator
-
- thenComparing(DistributedComparator<? super T>) - Method in interface com.hazelcast.jet.function.DistributedComparator
-
- thenComparing(Function<? super T, ? extends U>, Comparator<? super U>) - Method in interface com.hazelcast.jet.function.DistributedComparator
-
- thenComparing(DistributedFunction<? super T, ? extends U>, DistributedComparator<? super U>) - Method in interface com.hazelcast.jet.function.DistributedComparator
-
- thenComparing(Function<? super T, ? extends U>) - Method in interface com.hazelcast.jet.function.DistributedComparator
-
- thenComparing(DistributedFunction<? super T, ? extends U>) - Method in interface com.hazelcast.jet.function.DistributedComparator
-
- thenComparingDouble(ToDoubleFunction<? super T>) - Method in interface com.hazelcast.jet.function.DistributedComparator
-
- thenComparingDouble(DistributedToDoubleFunction<? super T>) - Method in interface com.hazelcast.jet.function.DistributedComparator
-
- thenComparingInt(ToIntFunction<? super T>) - Method in interface com.hazelcast.jet.function.DistributedComparator
-
- thenComparingInt(DistributedToIntFunction<? super T>) - Method in interface com.hazelcast.jet.function.DistributedComparator
-
- thenComparingLong(ToLongFunction<? super T>) - Method in interface com.hazelcast.jet.function.DistributedComparator
-
- thenComparingLong(DistributedToLongFunction<? super T>) - Method in interface com.hazelcast.jet.function.DistributedComparator
-
- ThreeBags<E0,E1,E2> - Class in com.hazelcast.jet.datamodel
-
A container of three bags (collections), each with its own element
type.
- threeBags() - Static method in class com.hazelcast.jet.datamodel.ThreeBags
-
Returns a new, empty ThreeBags
container.
- threeBags(Collection<E0>, Collection<E1>, Collection<E2>) - Static method in class com.hazelcast.jet.datamodel.ThreeBags
-
Returns a new ThreeBags
container populated with the supplied
collections.
- timestamp() - Method in class com.hazelcast.jet.core.Watermark
-
Returns the timestamp of this watermark item.
- TimestampedEntry<K,V> - Class in com.hazelcast.jet.datamodel
-
A Map.Entry
extended with a long timestamp
, used for
event time-based data processing.
- TimestampedEntry(long, K, V) - Constructor for class com.hazelcast.jet.datamodel.TimestampedEntry
-
Constructs a timestamped entry with the supplied field values.
- TimestampKind - Enum in com.hazelcast.jet.core
-
Enumerates the two possible kinds of timestamp: event timestamp and
frame timestamp.
- to(Vertex) - Method in class com.hazelcast.jet.core.Edge
-
Sets the destination vertex of this edge, with ordinal 0.
- to(Vertex, int) - Method in class com.hazelcast.jet.core.Edge
-
Sets the destination vertex and ordinal of this edge.
- toByteArray() - Method in class com.hazelcast.jet.core.test.TestOutbox.MockData
-
- toCollection(DistributedSupplier<C>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that accumulates the items into a Collection
.
- toCollection(DistributedSupplier<C>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- toDag() - Method in interface com.hazelcast.jet.Pipeline
-
Transforms the pipeline into a Jet DAG, which can be submitted for
execution to a Jet instance.
- toData(Object) - Method in class com.hazelcast.jet.core.test.TestOutbox.MockSerializationService
-
- toData(Object, PartitioningStrategy) - Method in class com.hazelcast.jet.core.test.TestOutbox.MockSerializationService
-
- toICache(String, DistributedFunction<? super T, ? extends K>, DistributedFunction<? super T, ? extends U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- toICache(String) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- toICache(String, DistributedFunction<? super T, ? extends K>, DistributedFunction<? super T, ? extends U>, DistributedBinaryOperator<U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- toIList(String) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- toIMap(String, DistributedFunction<? super T, ? extends K>, DistributedFunction<? super T, ? extends U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- toIMap(String) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- toIMap(String, DistributedFunction<? super T, ? extends K>, DistributedFunction<? super T, ? extends U>, DistributedBinaryOperator<U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- toList() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that accumulates the items into an ArrayList
.
- toList() - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- toMap(DistributedFunction<? super T, ? extends K>, DistributedFunction<? super T, ? extends U>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that accumulates the items into a
HashMap
whose keys and values are the result of applying
the provided mapping functions.
- toMap(DistributedFunction<? super T, ? extends K>, DistributedFunction<? super T, ? extends U>, DistributedBinaryOperator<U>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that accumulates the items into a
HashMap
whose keys and values are the result of applying
the provided mapping functions.
- toMap(DistributedFunction<? super T, ? extends K>, DistributedFunction<? super T, ? extends U>, DistributedBinaryOperator<U>, DistributedSupplier<M>) - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an AggregateOperation1
that accumulates elements
into a Map
whose keys and values are the result of applying the
provided mapping functions to the input elements.
- toMap(DistributedFunction<? super T, ? extends K>, DistributedFunction<? super T, ? extends U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- toMap(DistributedFunction<? super T, ? extends K>, DistributedFunction<? super T, ? extends U>, DistributedBinaryOperator<U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- toMap(DistributedFunction<? super T, ? extends K>, DistributedFunction<? super T, ? extends U>, DistributedBinaryOperator<U>, DistributedSupplier<M>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- toObject(Object) - Method in class com.hazelcast.jet.core.test.TestOutbox.MockSerializationService
-
- toObject(Object, Class) - Method in class com.hazelcast.jet.core.test.TestOutbox.MockSerializationService
-
- TopologyChangedException - Exception in com.hazelcast.jet.core
-
Thrown when a topology change causes a job to abort.
- TopologyChangedException() - Constructor for exception com.hazelcast.jet.core.TopologyChangedException
-
Creates the exception
- TopologyChangedException(String) - Constructor for exception com.hazelcast.jet.core.TopologyChangedException
-
Creates the exception with a message.
- TopologyChangedException(String, Throwable) - Constructor for exception com.hazelcast.jet.core.TopologyChangedException
-
Creates the exception with a message and a cause.
- toSet() - Static method in class com.hazelcast.jet.aggregate.AggregateOperations
-
Returns an aggregate operation that accumulates the items into a HashSet
.
- toSet() - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
- toString() - Method in class com.hazelcast.jet.accumulator.DoubleAccumulator
-
- toString() - Method in class com.hazelcast.jet.accumulator.LongAccumulator
-
- toString() - Method in class com.hazelcast.jet.accumulator.LongDoubleAccumulator
-
- toString() - Method in class com.hazelcast.jet.accumulator.LongLongAccumulator
-
- toString() - Method in class com.hazelcast.jet.accumulator.MutableReference
-
- toString() - Method in class com.hazelcast.jet.config.ResourceConfig
-
- toString() - Method in class com.hazelcast.jet.core.DAG
-
- toString() - Method in class com.hazelcast.jet.core.Edge
-
- toString() - Method in class com.hazelcast.jet.core.test.TestOutbox
-
- toString() - Method in class com.hazelcast.jet.core.Vertex
-
- toString() - Method in class com.hazelcast.jet.core.Watermark
-
- toString() - Method in class com.hazelcast.jet.datamodel.BagsByTag
-
- toString() - Method in class com.hazelcast.jet.datamodel.ItemsByTag
-
- toString() - Method in class com.hazelcast.jet.datamodel.Session
-
- toString() - Method in class com.hazelcast.jet.datamodel.Tag
-
- toString() - Method in class com.hazelcast.jet.datamodel.ThreeBags
-
- toString() - Method in class com.hazelcast.jet.datamodel.TimestampedEntry
-
- toString() - Method in class com.hazelcast.jet.datamodel.Tuple2
-
- toString() - Method in class com.hazelcast.jet.datamodel.Tuple3
-
- toString() - Method in class com.hazelcast.jet.function.DistributedOptional
-
- totalParallelism() - Method in interface com.hazelcast.jet.core.ProcessorMetaSupplier.Context
-
Returns the total number of Processor
s that will be
created across the cluster.
- totalParallelism() - Method in class com.hazelcast.jet.core.test.TestProcessorMetaSupplierContext
-
- totalSize() - Method in class com.hazelcast.jet.core.test.TestOutbox.MockData
-
- toTumblingByFrame() - Method in class com.hazelcast.jet.core.WindowDefinition
-
Converts this definition to one defining a tumbling window of the
same length as this definition's frame.
- Transform - Interface in com.hazelcast.jet
-
Represents the data transformation performed by a pipeline
Stage
.
- traverseArray(T[]) - Static method in class com.hazelcast.jet.Traversers
-
Returns a traverser over the given array.
- traverseEnumeration(Enumeration<T>) - Static method in class com.hazelcast.jet.Traversers
-
Returns an adapter from Enumeration
to Traverser
.
- traverseIterable(Iterable<? extends T>) - Static method in class com.hazelcast.jet.Traversers
-
Returns a traverser over the given iterable.
- traverseIterator(Iterator<? extends T>) - Static method in class com.hazelcast.jet.Traversers
-
Returns an adapter from Iterator
to Traverser
.
- Traverser<T> - Interface in com.hazelcast.jet
-
Traverses a potentially infinite sequence of non-null
items.
- Traversers - Class in com.hazelcast.jet
-
- traverseSpliterator(Spliterator<T>) - Static method in class com.hazelcast.jet.Traversers
-
Returns an adapter from Spliterator
to Traverser
.
- traverseStream(Stream<T>) - Static method in class com.hazelcast.jet.Traversers
-
Returns a traverser over the given stream.
- tryEmit(int, Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Offers the item to the outbox bucket at the supplied ordinal.
- tryEmit(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Offers the item to all the outbox buckets (except the snapshot outbox).
- tryEmit(int[], Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Offers the item to the outbox buckets identified in the supplied array.
- tryEmitToSnapshot(Object, Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Offers one key-value pair to the snapshot bucket.
- tryProcess(T) - Method in class com.hazelcast.jet.core.AbstractProcessor.FlatMapper
-
Method designed to be called from one of AbstractProcessor#tryProcessX()
methods.
- tryProcess(int, Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Tries to process the supplied input item, which was received from the
edge with the supplied ordinal.
- tryProcess() - Method in interface com.hazelcast.jet.core.Processor
-
This method will be called periodically and only when the current batch
of items in the inbox has been exhausted.
- tryProcess0(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Tries to process the supplied input item, which was received from the
edge with ordinal 0.
- tryProcess1(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Tries to process the supplied input item, which was received from the
edge with ordinal 1.
- tryProcess2(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Tries to process the supplied input item, which was received from the
edge with ordinal 2.
- tryProcess3(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Tries to process the supplied input item, which was received from the
edge with ordinal 3.
- tryProcess4(Object) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Tries to process the supplied input item, which was received from the
edge with ordinal 4.
- tryProcessWm(int, Watermark) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
Tries to process the supplied watermark, which was received from the
edge with the supplied ordinal.
- tryProcessWm0(Watermark) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- tryProcessWm1(Watermark) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- tryProcessWm2(Watermark) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- tryProcessWm3(Watermark) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- tryProcessWm4(Watermark) - Method in class com.hazelcast.jet.core.AbstractProcessor
-
- tumblingWindowDef(long) - Static method in class com.hazelcast.jet.core.WindowDefinition
-
Returns the definition of a tumbling window of length windowLength
.
- Tuple2<E0,E1> - Class in com.hazelcast.jet.datamodel
-
A 2-tuple (pair) of statically typed fields.
- tuple2(E0, E1) - Static method in class com.hazelcast.jet.datamodel.Tuple2
-
Returns a new 2-tuple with the supplied values.
- Tuple3<E0,E1,E2> - Class in com.hazelcast.jet.datamodel
-
A 3-tuple (triple) of statically typed fields.
- tuple3(E0, E1, E2) - Static method in class com.hazelcast.jet.datamodel.Tuple3
-
Returns a new 3-tuple with the supplied values.
- TwoBags<E0,E1> - Class in com.hazelcast.jet.datamodel
-
A container of two bags (collections), each with its own element
type.
- twoBags() - Static method in class com.hazelcast.jet.datamodel.TwoBags
-
Returns a new, empty TwoBags
container.
- twoBags(Collection<E0>, Collection<E1>) - Static method in class com.hazelcast.jet.datamodel.TwoBags
-
Returns a new TwoBags
container populated with the supplied
collections.
- valueOf(String) - Static method in enum com.hazelcast.jet.config.ProcessingGuarantee
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.jet.core.Edge.RoutingPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.jet.core.JobStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.jet.core.TimestampKind
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.hazelcast.jet.config.ProcessingGuarantee
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.jet.core.Edge.RoutingPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.jet.core.JobStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.jet.core.TimestampKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- verifyProcessor(Processor) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
- verifyProcessor(Supplier<Processor>) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
- verifyProcessor(ProcessorSupplier) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
- verifyProcessor(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.core.test.TestSupport
-
- vertex(Vertex) - Method in class com.hazelcast.jet.core.DAG
-
Adds a vertex to this DAG.
- Vertex - Class in com.hazelcast.jet.core
-
Represents a unit of data processing in a Jet computation job.
- Vertex(String, DistributedSupplier<? extends Processor>) - Constructor for class com.hazelcast.jet.core.Vertex
-
Creates a vertex from a Supplier<Processor>
.
- Vertex(String, ProcessorSupplier) - Constructor for class com.hazelcast.jet.core.Vertex
-
Creates a vertex from a ProcessorSupplier
.
- Vertex(String, ProcessorMetaSupplier) - Constructor for class com.hazelcast.jet.core.Vertex
-
Creates a vertex from a ProcessorMetaSupplier
.
- vertexName() - Method in interface com.hazelcast.jet.core.Processor.Context
-
Returns the name of the vertex associated with this processor.
- vertexName() - Method in class com.hazelcast.jet.core.test.TestProcessorContext
-
- Watermark - Class in com.hazelcast.jet.core
-
Watermark is an item occasionally inserted into a disordered
(sub)stream of timestamped items.
- Watermark(long) - Constructor for class com.hazelcast.jet.core.Watermark
-
Constructs a new watermark item.
- WatermarkEmissionPolicy - Interface in com.hazelcast.jet.core
-
A policy object that decides when when the watermark has advanced
enough to emit a new watermark item.
- WatermarkPolicies - Class in com.hazelcast.jet.core
-
Utility class with factories of several useful watermark policies.
- WatermarkPolicy - Interface in com.hazelcast.jet.core
-
A policy object that decides on the watermark in a single data
(sub)stream.
- wholeItem() - Static method in class com.hazelcast.jet.function.DistributedFunctions
-
- WindowDefinition - Class in com.hazelcast.jet.core
-
Contains parameters that define a sliding/tumbling window over which Jet
will apply an aggregate function.
- windowLength() - Method in class com.hazelcast.jet.core.WindowDefinition
-
Returns the length of the window (the size of the timestamp range it covers).
- withCombiningAccumulateFn(DistributedFunction<T, A>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
Returns a copy of this aggregate operation, but with the accumulate
primitive replaced with one that expects to find
accumulator objects in the input and will combine them all into
a single accumulator of the same type.
- withCreate(DistributedSupplier<A>) - Static method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
Returns a builder object, initialized with the supplied create
primitive, that can be used to construct the definition of an aggregate
operation in a step-by-step manner.
- withFinishFn(DistributedFunction<? super A, R_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation
-
Returns a copy of this aggregate operation, but with the finish
primitive replaced with the supplied one.
- withFinishFn(DistributedFunction<? super A, R_NEW>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation1
-
- withFinishFn(DistributedFunction<? super A, R1>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation2
-
- withFinishFn(DistributedFunction<? super A, R1>) - Method in interface com.hazelcast.jet.aggregate.AggregateOperation3
-
- withFixedLag(long) - Static method in class com.hazelcast.jet.core.WatermarkPolicies
-
Maintains watermark that lags behind the top observed timestamp by the
given amount.
- withOffset(long) - Method in class com.hazelcast.jet.core.WindowDefinition
-
Returns a new window definition where all the frames are shifted by the
given offset.
- writeBufferedP(DistributedIntFunction<B>, DistributedBiConsumer<B, T>, DistributedConsumer<B>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for a vertex that drains all the items
from its inbox to an intermediate buffer and then flushes the buffer.
- writeBufferedP(DistributedIntFunction<B>, DistributedBiConsumer<B, T>, DistributedConsumer<B>, DistributedConsumer<B>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
Returns a supplier of processors for a vertex that drains all the items
from the inbox to an intermediate buffer and then flushes the buffer.
- writeCacheP(String) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.core.DAG
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.core.Edge
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.core.Vertex
-
- writeFileP(String, DistributedFunction<T, String>, Charset, boolean) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeFileP(String, DistributedFunction<T, String>) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeFileP(String) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeListP(String) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeLoggerP(DistributedFunction<T, String>) - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
Returns a meta-supplier of processors for a sink vertex that logs all
the data items it receives.
- writeLoggerP() - Static method in class com.hazelcast.jet.core.processor.DiagnosticProcessors
-
- writeMapP(String) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeObject(ObjectDataOutput) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Serializes this accumulator.
- writeRemoteCacheP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeRemoteListP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeRemoteMapP(String, ClientConfig) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-
- writeSocketP(String, int, DistributedFunction<T, String>, Charset) - Static method in class com.hazelcast.jet.core.processor.SinkProcessors
-