- AbstractProcessor - Class in com.hazelcast.jet
-
Base class to implement custom processors.
- AbstractProcessor() - Constructor for class com.hazelcast.jet.AbstractProcessor
-
- AbstractProcessor.FlatMapper<T,R> - Class in com.hazelcast.jet
-
- accept(T, U) - Method in interface com.hazelcast.jet.function.DistributedBiConsumer
-
- accept(T) - Method in interface com.hazelcast.jet.function.DistributedConsumer
-
- accept(T) - Method in class com.hazelcast.jet.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.
- accumulate(AggregateOperation<T, A, R>) - Static method in class com.hazelcast.jet.processor.Processors
-
Returns a supplier of processor that performs the provided aggregate
operation on all the items it receives.
- accumulateByFrame(DistributedFunction<? super T, K>, DistributedToLongFunction<? super T>, TimestampKind, WindowDefinition, AggregateOperation<? super T, A, ?>) - Static method in class com.hazelcast.jet.processor.Processors
-
Returns a supplier of the first-stage processor in a two-stage sliding
window aggregation setup (see the
class
Javadoc
for an explanation of aggregation stages).
- accumulateByKey(DistributedFunction<? super T, K>, AggregateOperation<? super T, A, ?>) - Static method in class com.hazelcast.jet.processor.Processors
-
Returns a supplier of the first-stage processor in a two-stage
group-and-aggregate setup.
- accumulateItemF() - Method in interface com.hazelcast.jet.AggregateOperation
-
A primitive that updates the accumulator state to account for a new item.
- accumulator() - Method in interface com.hazelcast.jet.stream.DistributedCollector
-
A function that folds a value into a mutable result container.
- 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.
- 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(URL, String) - 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(File, String) - 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.
- addJar(String, 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.
- aggregate(AggregateOperation<T, A, R>) - Static method in class com.hazelcast.jet.processor.Processors
-
Returns a supplier of processor that performs the provided aggregate
operation on all the items it receives.
- aggregateByKey(DistributedFunction<? super T, K>, AggregateOperation<? super T, A, R>) - Static method in class com.hazelcast.jet.processor.Processors
-
Returns a supplier of processor that groups items by key and performs
the provided aggregate operation on each group.
- AggregateOperation<T,A,R> - Interface in com.hazelcast.jet
-
Contains primitives needed to compute an aggregated result of
stream processing.
- AggregateOperations - Class in com.hazelcast.jet
-
Utility class with factory methods for several useful windowing
operations.
- aggregateToSessionWindow(long, DistributedToLongFunction<? super T>, DistributedFunction<? super T, K>, AggregateOperation<? super T, A, R>) - Static method in class com.hazelcast.jet.processor.Processors
-
Returns a supplier of processor that aggregates events into session
windows.
- aggregateToSlidingWindow(DistributedFunction<? super T, K>, DistributedToLongFunction<? super T>, TimestampKind, WindowDefinition, AggregateOperation<? super T, A, R>) - Static method in class com.hazelcast.jet.processor.Processors
-
Returns a supplier of processor 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
-
Returns whether all elements of this stream match the provided predicate.
- allMatch(DoublePredicate) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- allMatch(DistributedIntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns whether all elements of this stream match the provided predicate.
- allMatch(IntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- allMatch(DistributedLongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns whether all elements of this stream match the provided predicate.
- allMatch(LongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- allMatch(DistributedPredicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Returns whether all elements of this stream match the provided predicate.
- allMatch(Predicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- allOf(AggregateOperation<? super T, ?, ?>...) - Static method in class com.hazelcast.jet.AggregateOperations
-
Returns an operation, that calculates multiple aggregations and returns their value in
List<Object>
.
- allToOne() - Method in class com.hazelcast.jet.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
-
Returns a composed predicate that represents a short-circuiting logical
AND of this predicate and another.
- and(DistributedDoublePredicate) - Method in interface com.hazelcast.jet.function.DistributedDoublePredicate
-
Returns a composed predicate that represents a short-circuiting logical
AND of this predicate and another.
- and(DistributedIntPredicate) - Method in interface com.hazelcast.jet.function.DistributedIntPredicate
-
Returns a composed predicate that represents a short-circuiting logical
AND of this predicate and another.
- and(DistributedLongPredicate) - Method in interface com.hazelcast.jet.function.DistributedLongPredicate
-
Returns a composed predicate that represents a short-circuiting logical
AND of this predicate and another.
- and(DistributedPredicate<? super T>) - Method in interface com.hazelcast.jet.function.DistributedPredicate
-
Returns a composed predicate that represents a short-circuiting logical
AND of this predicate and another.
- andThen(DistributedBiConsumer<? super T, ? super U>) - Method in interface com.hazelcast.jet.function.DistributedBiConsumer
-
Returns a composed BiConsumer
that performs, in sequence, this
operation followed by the after
operation.
- andThen(DistributedFunction<? super R, ? extends V>) - Method in interface com.hazelcast.jet.function.DistributedBiFunction
-
Returns a composed function that first applies this function to
its input, and then applies the after
function to the result.
- andThen(DistributedConsumer<? super T>) - Method in interface com.hazelcast.jet.function.DistributedConsumer
-
Returns a composed Consumer
that performs, in sequence, this
operation followed by the after
operation.
- andThen(DistributedDoubleConsumer) - Method in interface com.hazelcast.jet.function.DistributedDoubleConsumer
-
Returns a composed DoubleConsumer
that performs, in sequence, this
operation followed by the after
operation.
- andThen(DistributedDoubleUnaryOperator) - Method in interface com.hazelcast.jet.function.DistributedDoubleUnaryOperator
-
Returns a composed operator that first applies this operator to
its input, and then applies the after
operator to the result.
- andThen(DistributedFunction<? super R, ? extends V>) - Method in interface com.hazelcast.jet.function.DistributedFunction
-
Returns a composed function that first applies this function to
its input, and then applies the after
function to the result.
- andThen(DistributedIntConsumer) - Method in interface com.hazelcast.jet.function.DistributedIntConsumer
-
Returns a composed IntConsumer
that performs, in sequence, this
operation followed by the after
operation.
- andThen(DistributedIntUnaryOperator) - Method in interface com.hazelcast.jet.function.DistributedIntUnaryOperator
-
Returns a composed operator that first applies this operator to
its input, and then applies the after
operator to the result.
- andThen(DistributedLongConsumer) - Method in interface com.hazelcast.jet.function.DistributedLongConsumer
-
Returns a composed LongConsumer
that performs, in sequence, this
operation followed by the after
operation.
- andThen(DistributedLongUnaryOperator) - Method in interface com.hazelcast.jet.function.DistributedLongUnaryOperator
-
Returns a composed operator that first applies this operator to
its input, and then applies the after
operator to the result.
- anyMatch(DistributedDoublePredicate) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Returns whether any elements of this stream match the provided
predicate.
- anyMatch(DoublePredicate) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- anyMatch(DistributedIntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns whether any elements of this stream match the provided
predicate.
- anyMatch(IntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- anyMatch(DistributedLongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns whether any elements of this stream match the provided
predicate.
- anyMatch(LongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- anyMatch(DistributedPredicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Returns whether any elements of this stream match the provided
predicate.
- anyMatch(Predicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- append(T) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser which appends an additional item to this traverser
after it returns the first null
value.
- apply(T, U) - Method in interface com.hazelcast.jet.function.DistributedBiFunction
-
- apply(T) - Method in interface com.hazelcast.jet.function.DistributedFunction
-
- applyAsLong(T) - Method in interface com.hazelcast.jet.function.DistributedToLongFunction
-
- asDoubleStream() - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns a DoubleStream
consisting of the elements of this stream,
converted to double
.
- asDoubleStream() - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns a DoubleStream
consisting of the elements of this stream,
converted to double
.
- asLongStream() - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns a LongStream
consisting of the elements of this stream,
converted to long
.
- averagingDouble(DistributedToDoubleFunction<T>) - Static method in class com.hazelcast.jet.AggregateOperations
-
Returns an operation that calculates the arithmetic mean of double
values returned by the mapToDoubleF
function.
- averagingDouble(DistributedToDoubleFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
that produces the arithmetic mean of a double-valued
function applied to the input elements.
- averagingInt(DistributedToIntFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
that produces the arithmetic mean of an integer-valued
function applied to the input elements.
- averagingLong(DistributedToLongFunction<T>) - Static method in class com.hazelcast.jet.AggregateOperations
-
Returns an operation that calculates the arithmetic mean of long
values returned by the mapToLongF
function.
- averagingLong(DistributedToLongFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
that produces the arithmetic mean of a long-valued
function applied to the input elements.
- collect(DistributedSupplier<R>, DistributedObjDoubleConsumer<R>, DistributedBiConsumer<R, R>) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Performs a mutable
reduction operation on the elements of this stream.
- 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
-
Performs a mutable
reduction operation on the elements of this stream.
- 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
-
Performs a mutable
reduction operation on the elements of this stream.
- 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
-
Performs a mutable
reduction operation on the elements of this stream.
- collect(DistributedCollector<? super T, A, R>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Performs a mutable
reduction operation on the elements of this stream using a
DistributedCollector
.
- 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
-
Adapts a DistributedCollector
to perform an additional finishing
transformation.
- com.hazelcast.jet - package com.hazelcast.jet
-
The base package of Hazelcast Jet.
- com.hazelcast.jet.accumulator - package com.hazelcast.jet.accumulator
-
Classes intended to be used for accumulator objects in Jet aggregation
operations.
- com.hazelcast.jet.config - package com.hazelcast.jet.config
-
Jet's configuration data objects.
- com.hazelcast.jet.function - package com.hazelcast.jet.function
-
Serializable variants of functional interfaces from
java.util.function
.
- com.hazelcast.jet.processor - package com.hazelcast.jet.processor
-
Contains static utility classes with factories of Jet processors.
- 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
- com.hazelcast.jet.test - package com.hazelcast.jet.test
-
Utilities for writing tests for Hazelcast Jet.
- combine(LinTrendAccumulator) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Combines this accumulator with the supplied one.
- combine(AggregateOperation<T, A, R>) - Static method in class com.hazelcast.jet.processor.Processors
-
Returns a supplier of processor that performs the provided aggregate
operation on all the items it receives.
- combineAccumulatorsF() - Method in interface com.hazelcast.jet.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.
- combineByKey(AggregateOperation<?, A, R>) - Static method in class com.hazelcast.jet.processor.Processors
-
Returns a supplier of the second-stage processor in a two-stage
group-and-aggregate setup.
- combiner() - Method in interface com.hazelcast.jet.stream.DistributedCollector
-
A function that accepts two partial results and merges them.
- combineToSlidingWindow(WindowDefinition, AggregateOperation<?, A, R>) - Static method in class com.hazelcast.jet.processor.Processors
-
Returns a supplier of the second-stage processor in a two-stage sliding
window aggregation setup (see the
class
Javadoc
for an explanation of aggregation stages).
- 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() - Method in interface com.hazelcast.jet.Processor
-
Called after all the inbound edges' streams are exhausted.
- complete(Throwable) - Method in interface com.hazelcast.jet.ProcessorSupplier
-
Called after execution is finished on all the nodes, whether successfully
or not.
- compose(DistributedDoubleUnaryOperator) - Method in interface com.hazelcast.jet.function.DistributedDoubleUnaryOperator
-
Returns a composed operator that first applies the before
operator to its input, and then applies this operator to the result.
- compose(DistributedFunction<? super V, ? extends T>) - Method in interface com.hazelcast.jet.function.DistributedFunction
-
Returns a composed function that first applies the before
function to its input, and then applies this function to the result.
- compose(DistributedIntUnaryOperator) - Method in interface com.hazelcast.jet.function.DistributedIntUnaryOperator
-
Returns a composed operator that first applies the before
operator to its input, and then applies this operator to the result.
- compose(DistributedLongUnaryOperator) - Method in interface com.hazelcast.jet.function.DistributedLongUnaryOperator
-
Returns a composed operator that first applies the before
operator to its input, and then applies this operator to the result.
- 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
-
- counting() - Static method in class com.hazelcast.jet.AggregateOperations
-
Returns an operation that tracks the count of items in the window.
- counting() - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
accepting elements of type T
that
counts the number of input elements.
- createAccumulatorF() - Method in interface com.hazelcast.jet.AggregateOperation
-
A primitive that returns a new accumulator.
- createFactory() - Method in class com.hazelcast.jet.JetDataSerializerHook
-
- DAG - Class in com.hazelcast.jet
-
Describes a computation to be performed by the Jet computation engine.
- DAG() - Constructor for class com.hazelcast.jet.DAG
-
- deduct(LinTrendAccumulator) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Deducts the supplied accumulator from this one.
- deductAccumulatorF() - Method in interface com.hazelcast.jet.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_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_OUTBOX_CAPACITY - Static variable in class com.hazelcast.jet.config.EdgeConfig
-
- 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.Partitioner
-
Returns a partitioner which applies the default Hazelcast partitioning.
- DefaultPartitionStrategy - Interface in com.hazelcast.jet
-
A facade that hides the details of Hazelcast partitioning SPI and exposes
just the partitioning strategy.
- DiagnosticProcessors - Class in com.hazelcast.jet.processor
-
Static utility class with factories of sinks and wrappers that log
the data flowing through the DAG.
- distinct() - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Returns a stream consisting of the distinct elements of this stream.
- distinct() - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns a stream consisting of the distinct elements of this stream.
- distinct() - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns a stream consisting of the distinct elements of this stream.
- distinct() - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- distributed() - Method in class com.hazelcast.jet.Edge
-
Declares that the edge is distributed.
- DistributedBiConsumer<T,U> - Interface in com.hazelcast.jet.function
-
Represents an operation that accepts two input arguments and returns no
result.
- DistributedBiFunction<T,U,R> - Interface in com.hazelcast.jet.function
-
Represents a function that accepts two arguments and produces a result.
- DistributedBinaryOperator<T> - Interface in com.hazelcast.jet.function
-
Represents an operation upon two operands of the same type, producing a result
of the same type as the operands.
- DistributedBiPredicate<T,U> - Interface in com.hazelcast.jet.function
-
Represents a predicate (boolean-valued function) of two arguments.
- DistributedBooleanSupplier - Interface in com.hazelcast.jet.function
-
Represents a supplier of boolean
-valued results.
- DistributedCollector<T,A,R> - Interface in com.hazelcast.jet.stream
-
A mutable reduction operation that
accumulates input elements into a mutable result container, optionally transforming
the accumulated result into a final representation after all input elements
have been processed.
- 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
-
Implementations of
DistributedCollector
that implement various
useful reduction operations, such as accumulating elements into
collections, summarizing elements according to various criteria, etc.
- DistributedCollectors() - Constructor for class com.hazelcast.jet.stream.DistributedCollectors
-
- DistributedComparator<T> - Interface in com.hazelcast.jet.function
-
A comparison function, which imposes a total ordering on some
collection of objects.
- DistributedConsumer<T> - Interface in com.hazelcast.jet.function
-
Represents an operation that accepts a single input argument and returns no
result.
- DistributedDoubleBinaryOperator - Interface in com.hazelcast.jet.function
-
Represents an operation upon two double
-valued operands and producing a
double
-valued result.
- DistributedDoubleConsumer - Interface in com.hazelcast.jet.function
-
Represents an operation that accepts a single double
-valued argument and
returns no result.
- DistributedDoubleFunction<R> - Interface in com.hazelcast.jet.function
-
Represents a function that accepts a double-valued argument and produces a
result.
- DistributedDoublePredicate - Interface in com.hazelcast.jet.function
-
Represents a predicate (boolean-valued function) of one double
-valued
argument.
- 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
-
Represents a supplier of double
-valued results.
- DistributedDoubleToIntFunction - Interface in com.hazelcast.jet.function
-
Represents a function that accepts a double-valued argument and produces an
int-valued result.
- DistributedDoubleToLongFunction - Interface in com.hazelcast.jet.function
-
Represents a function that accepts a double-valued argument and produces a
long-valued result.
- DistributedDoubleUnaryOperator - Interface in com.hazelcast.jet.function
-
Represents an operation on a single double
-valued operand that produces
a double
-valued result.
- DistributedFunction<T,R> - Interface in com.hazelcast.jet.function
-
Represents a function that accepts one argument and produces a result.
- DistributedFunctions - Class in com.hazelcast.jet.function
-
Factory methods for several common distributed functions.
- DistributedIntBinaryOperator - Interface in com.hazelcast.jet.function
-
Represents an operation upon two int
-valued operands and producing an
int
-valued result.
- DistributedIntConsumer - Interface in com.hazelcast.jet.function
-
Represents an operation that accepts a single int
-valued argument and
returns no result.
- DistributedIntFunction<R> - Interface in com.hazelcast.jet.function
-
Represents a function that accepts an int-valued argument and produces a
result.
- DistributedIntPredicate - Interface in com.hazelcast.jet.function
-
Represents a predicate (boolean-valued function) of one int
-valued
argument.
- 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
-
Represents a supplier of int
-valued results.
- DistributedIntToDoubleFunction - Interface in com.hazelcast.jet.function
-
Represents a function that accepts an int-valued argument and produces a
double-valued result.
- DistributedIntToLongFunction - Interface in com.hazelcast.jet.function
-
Represents a function that accepts an int-valued argument and produces a
long-valued result.
- DistributedIntUnaryOperator - Interface in com.hazelcast.jet.function
-
Represents an operation on a single int
-valued operand that produces
an int
-valued result.
- DistributedLongBinaryOperator - Interface in com.hazelcast.jet.function
-
Represents an operation upon two long
-valued operands and producing a
long
-valued result.
- DistributedLongConsumer - Interface in com.hazelcast.jet.function
-
Represents an operation that accepts a single long
-valued argument and
returns no result.
- DistributedLongFunction<R> - Interface in com.hazelcast.jet.function
-
Represents a function that accepts a long-valued argument and produces a
result.
- DistributedLongPredicate - Interface in com.hazelcast.jet.function
-
Represents a predicate (boolean-valued function) of one long
-valued
argument.
- 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
-
Represents a supplier of long
-valued results.
- DistributedLongToDoubleFunction - Interface in com.hazelcast.jet.function
-
Represents a function that accepts a long-valued argument and produces a
double-valued result.
- DistributedLongToIntFunction - Interface in com.hazelcast.jet.function
-
Represents a function that accepts a long-valued argument and produces an
int-valued result.
- DistributedLongUnaryOperator - Interface in com.hazelcast.jet.function
-
Represents an operation on a single long
-valued operand that produces
a long
-valued result.
- DistributedObjDoubleConsumer<T> - Interface in com.hazelcast.jet.function
-
Represents an operation that accepts an object-valued and a
double
-valued argument, and returns no result.
- DistributedObjIntConsumer<T> - Interface in com.hazelcast.jet.function
-
Represents an operation that accepts an object-valued and a
int
-valued argument, and returns no result.
- DistributedObjLongConsumer<T> - Interface in com.hazelcast.jet.function
-
Represents an operation that accepts an object-valued and a
long
-valued argument, and returns no result.
- DistributedOptional<T> - Class in com.hazelcast.jet.function
-
A container object which may or may not contain a non-null value.
- DistributedPredicate<T> - Interface in com.hazelcast.jet.function
-
Represents a predicate (boolean-valued function) of one argument.
- 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
-
Represents a supplier of results.
- DistributedToDoubleBiFunction<T,U> - Interface in com.hazelcast.jet.function
-
Represents a function that accepts two arguments and produces a double-valued
result.
- DistributedToDoubleFunction<T> - Interface in com.hazelcast.jet.function
-
Represents a function that produces a double-valued result.
- DistributedToIntBiFunction<T,U> - Interface in com.hazelcast.jet.function
-
Represents a function that accepts two arguments and produces an int-valued
result.
- DistributedToIntFunction<T> - Interface in com.hazelcast.jet.function
-
Represents a function that produces an int-valued result.
- DistributedToLongBiFunction<T,U> - Interface in com.hazelcast.jet.function
-
Represents a function that accepts two arguments and produces a long-valued
result.
- DistributedToLongFunction<T> - Interface in com.hazelcast.jet.function
-
Represents a function that produces a long-valued result.
- DistributedUnaryOperator<T> - Interface in com.hazelcast.jet.function
-
Represents an operation on a single operand that produces a result of the
same type as its operand.
- DoubleAccumulator - Class in com.hazelcast.jet.accumulator
-
Accumulator of a primitive 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.Inbox
-
Passes each of this object's items to the supplied consumer until it is empty.
- drainOutbox(Queue<Object>, List<Object>) - Static method in class com.hazelcast.jet.test.TestSupport
-
Move all items from the outbox to the outputList
.
- drainTo(Collection<E>) - Method in interface com.hazelcast.jet.Inbox
-
- edge(Edge) - Method in class com.hazelcast.jet.DAG
-
Adds an edge to this DAG.
- Edge - Class in com.hazelcast.jet
-
- Edge.RoutingPolicy - Enum in com.hazelcast.jet
-
An edge describes a connection from many upstream processors to many
downstream processors.
- EdgeConfig - Class in com.hazelcast.jet.config
-
The configuration object for a DAG
Edge
.
- EdgeConfig() - Constructor for class com.hazelcast.jet.config.EdgeConfig
-
- emit(int, Object) - Method in class com.hazelcast.jet.AbstractProcessor
-
Adds the item to the outbox bucket with the supplied ordinal, throwing
an exception if the outbox refuses it.
- emit(Object) - Method in class com.hazelcast.jet.AbstractProcessor
-
Adds the item to all the outbox buckets, throwing an exception if the
outbox refuses it.
- emit(int[], Object) - Method in class com.hazelcast.jet.AbstractProcessor
-
Adds the item to the outbox buckets identified in the supplied array,
throwing an exception if the outbox refuses it.
- emitByFrame(WindowDefinition) - Static method in interface com.hazelcast.jet.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.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<?>) - Method in class com.hazelcast.jet.AbstractProcessor
-
Obtains items from the traverser and offers them to the outbox's bucket
with the supplied ordinal.
- emitFromTraverser(Traverser<?>) - Method in class com.hazelcast.jet.AbstractProcessor
-
- emitFromTraverser(int[], Traverser<?>) - Method in class com.hazelcast.jet.AbstractProcessor
-
Obtains items from the traverser and offers them to the outbox's buckets
identified in the supplied array.
- empty() - Static method in class com.hazelcast.jet.function.DistributedOptional
-
Returns an empty Optional
instance.
- empty() - Static method in class com.hazelcast.jet.Traversers
-
Returns a traverser that always returns null.
- 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
.
- enumerate(Enumeration<T>) - Static method in class com.hazelcast.jet.Traversers
-
Returns a simple adapter from Enumeration
to Traverser
.
- 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.Edge
-
- equals(Object) - Method in class com.hazelcast.jet.function.DistributedOptional
-
Indicates whether some other object is "equal to" this Optional.
- equals(Object) - Method in class com.hazelcast.jet.Session
-
- equals(Object) - Method in class com.hazelcast.jet.TimestampedEntry
-
- equals(Object) - Method in class com.hazelcast.jet.Watermark
-
- execute() - Method in interface com.hazelcast.jet.Job
-
Executes the job.
- filter(DistributedPredicate<? super T>) - Method in class com.hazelcast.jet.function.DistributedOptional
-
If a value is present, and the value matches the given predicate,
return an Optional
describing the value, otherwise return an
empty Optional
.
- filter(DistributedPredicate<T>) - Static method in class com.hazelcast.jet.processor.Processors
-
Returns a supplier of processor which emits the same items it receives,
but only those that pass the given predicate.
- filter(DistributedDoublePredicate) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Returns a stream consisting of the elements of this stream that match
the given predicate.
- filter(DoublePredicate) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- filter(DistributedIntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns a stream consisting of the elements of this stream that match
the given predicate.
- filter(IntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- filter(DistributedLongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns a stream consisting of the elements of this stream that match
the given predicate.
- filter(LongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- filter(DistributedPredicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Returns a stream consisting of the elements of this stream that match
the given predicate.
- filter(Predicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- filter(Predicate<? super T>) - Method in interface com.hazelcast.jet.Traverser
-
Adds a filtering layer to this traverser.
- finish() - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Computes the linear coefficient of the linear regression of the
accumulated samples.
- finishAccumulationF() - Method in interface com.hazelcast.jet.AggregateOperation
-
A primitive that finishes the accumulation process by transforming
the accumulator object into the final result.
- finisher() - Method in interface com.hazelcast.jet.stream.DistributedCollector
-
Perform the final transformation from the intermediate accumulation type
A
to the final result type R
.
- flatMap(DistributedFunction<? super T, DistributedOptional<U>>) - Method in class com.hazelcast.jet.function.DistributedOptional
-
If a value is present, apply the provided Optional
-bearing
mapping function to it, return that result, otherwise return an empty
Optional
.
- flatMap(DistributedFunction<T, ? extends Traverser<? extends R>>) - Static method in class com.hazelcast.jet.processor.Processors
-
Returns a supplier of processor which applies the provided
item-to-traverser mapping function to each received item and emits all
the items from the resulting traverser.
- flatMap(DistributedDoubleFunction<? extends DoubleStream>) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Returns a stream consisting of the results of replacing each element of
this stream with the contents of a mapped stream produced by applying
the provided mapping function to each element.
- flatMap(DoubleFunction<? extends DoubleStream>) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- flatMap(DistributedIntFunction<? extends IntStream>) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns a stream consisting of the results of replacing each element of
this stream with the contents of a mapped stream produced by applying
the provided mapping function to each element.
- flatMap(IntFunction<? extends IntStream>) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- flatMap(DistributedLongFunction<? extends LongStream>) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns a stream consisting of the results of replacing each element of
this stream with the contents of a mapped stream produced by applying
the provided mapping function to each element.
- 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
-
Returns a stream consisting of the results of replacing each element of
this stream with the contents of a mapped stream produced by applying
the provided mapping function to each element.
- 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
-
Adds a flat-mapping layer to this traverser.
- flatMapper(int, Function<? super T, ? extends Traverser<? extends R>>) - Method in class com.hazelcast.jet.AbstractProcessor
-
- flatMapper(Function<? super T, ? extends Traverser<? extends R>>) - Method in class com.hazelcast.jet.AbstractProcessor
-
- flatMapper(int[], Function<? super T, ? extends Traverser<? extends R>>) - Method in class com.hazelcast.jet.AbstractProcessor
-
- flatMapToDouble(DistributedFunction<? super T, ? extends DoubleStream>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Returns an DoubleStream
consisting of the results of replacing
each element of this stream with the contents of a mapped stream produced
by applying the provided mapping function to each element.
- 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
-
Returns an IntStream
consisting of the results of replacing each
element of this stream with the contents of a mapped stream produced by
applying the provided mapping function to each element.
- 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
-
Returns an LongStream
consisting of the results of replacing each
element of this stream with the contents of a mapped stream produced by
applying the provided mapping function to each element.
- flatMapToLong(Function<? super T, ? extends LongStream>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- floorFrameTs(long) - Method in class com.hazelcast.jet.WindowDefinition
-
Returns the highest frame timestamp less than or equal to the given
timestamp.
- forEach(DistributedDoubleConsumer) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Performs an action for each element of this stream.
- forEach(DoubleConsumer) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- forEachOrdered(DistributedDoubleConsumer) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Performs an action for each element of this stream, guaranteeing that
each element is processed in encounter order for streams that have a
defined encounter order.
- forEachOrdered(DoubleConsumer) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- frameLength() - Method in class com.hazelcast.jet.WindowDefinition
-
Returns the length of the frame (equal to the sliding step).
- frameOffset() - Method in class com.hazelcast.jet.WindowDefinition
-
Returns the frame offset.
- from(Vertex) - Static method in class com.hazelcast.jet.Edge
-
Returns an edge with the given source vertex and no destination vertex.
- from(Vertex, int) - Static method in class com.hazelcast.jet.Edge
-
Returns an edge with the given source vertex at the given ordinal
and no destination vertex.
- 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() - Method in class com.hazelcast.jet.function.DistributedOptional
-
If a value is present in this Optional
, returns the value,
otherwise throws NoSuchElementException
.
- get() - Method in interface com.hazelcast.jet.function.DistributedSupplier
-
- get(List<Address>) - Method in interface com.hazelcast.jet.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.ProcessorSupplier
-
- getCache(String) - Method in interface com.hazelcast.jet.JetInstance
-
Returns the distributed cache instance with the specified name.
- 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.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.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.
- getDescriptor() - Method in class com.hazelcast.jet.config.ResourceConfig
-
- getDestination() - Method in class com.hazelcast.jet.Edge
-
Returns this edge's destination vertex.
- getDestName() - Method in class com.hazelcast.jet.Edge
-
Returns the name of the destination vertex.
- getDestOrdinal() - Method in class com.hazelcast.jet.Edge
-
Returns the ordinal of the edge at the destination vertex.
- getEnd() - Method in class com.hazelcast.jet.Session
-
Returns the ending timestamp of the session.
- getFactoryId() - Method in class com.hazelcast.jet.DAG
-
- getFactoryId() - Method in class com.hazelcast.jet.Edge
-
- getFactoryId() - Method in class com.hazelcast.jet.JetDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.jet.Vertex
-
- getFlowControlPeriodMs() - Method in class com.hazelcast.jet.config.InstanceConfig
-
- 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.
- getId() - Method in class com.hazelcast.jet.DAG
-
- getId() - Method in class com.hazelcast.jet.Edge
-
- getId() - Method in class com.hazelcast.jet.Vertex
-
- getInboundEdges(String) - Method in class com.hazelcast.jet.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.
- getKey() - Method in class com.hazelcast.jet.Session
-
Returns the session's key.
- getKey() - Method in class com.hazelcast.jet.TimestampedEntry
-
- 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.Vertex
-
Returns the number of processors corresponding to this vertex that will
be created on each member.
- getLogger() - Method in class com.hazelcast.jet.AbstractProcessor
-
Returns the logger associated with this processor instance.
- getMap(String) - Method in interface com.hazelcast.jet.JetInstance
-
Returns the distributed map instance with the specified name.
- getName() - Method in interface com.hazelcast.jet.JetInstance
-
Returns the name of the Jet instance.
- getName() - Method in class com.hazelcast.jet.Vertex
-
Returns the name of this vertex.
- getOutboundEdges(String) - Method in class com.hazelcast.jet.DAG
-
Returns the outbound edges connected to the vertex with the given name.
- getOutboxCapacity() - Method in class com.hazelcast.jet.config.EdgeConfig
-
Returns the
capacity
of the
Outbox
bucket corresponding to this edge.
- getPacketSizeLimit() - Method in class com.hazelcast.jet.config.EdgeConfig
-
- getPartition(Object) - Method in interface com.hazelcast.jet.DefaultPartitionStrategy
-
Returns the Hazelcast partition ID of the given object.
- getPartition(Object, int) - Method in class com.hazelcast.jet.Partitioner.Default
-
- getPartition(T, int) - Method in interface com.hazelcast.jet.Partitioner
-
Returns the partition ID of the given item.
- getPartitioner() - Method in class com.hazelcast.jet.Edge
-
Returns the instance encapsulating the partitioning strategy in effect
on this edge.
- getPriority() - Method in class com.hazelcast.jet.Edge
-
- 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.Session
-
Returns the aggregated result for the session.
- getRoutingPolicy() - Method in class com.hazelcast.jet.Edge
-
- getSource() - Method in class com.hazelcast.jet.Edge
-
Returns this edge's source vertex.
- getSourceName() - Method in class com.hazelcast.jet.Edge
-
Returns the name of the source vertex.
- getSourceOrdinal() - Method in class com.hazelcast.jet.Edge
-
Returns the ordinal of the edge at the source vertex.
- getStart() - Method in class com.hazelcast.jet.Session
-
Returns the starting timestamp of the session.
- getSupplier() - Method in class com.hazelcast.jet.Vertex
-
Returns this vertex's meta-supplier of processors.
- getTempDir() - Method in class com.hazelcast.jet.config.InstanceConfig
-
Returns Jet's temp directory.
- getTimestamp() - Method in class com.hazelcast.jet.TimestampedEntry
-
Returns the timestamp of this entry.
- 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.TimestampedEntry
-
- 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.DAG
-
Returns the vertex with the given name.
- globalProcessorIndex() - Method in interface com.hazelcast.jet.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.test.TestProcessorContext
-
- groupingBy(DistributedFunction<? super T, ? extends K>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
implementing a "group by" operation on
input elements of type T
, grouping elements according to a
classification function, and returning the results in a Map
.
- groupingBy(DistributedFunction<? super T, ? extends K>, DistributedCollector<? super T, A, D>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
implementing a cascaded "group by" operation
on input elements of type T
, grouping elements according to a
classification function, and then performing a reduction operation on
the values associated with a given key using the specified downstream
DistributedCollector
.
- groupingBy(DistributedFunction<? super T, ? extends K>, DistributedSupplier<M>, DistributedCollector<? super T, A, D>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
implementing a cascaded "group by" operation
on input elements of type T
, grouping elements according to a
classification function, and then performing a reduction operation on
the values associated with a given key using the specified downstream
DistributedCollector
.
- groupingByToICache(String, DistributedFunction<? super T, ? extends K>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a Reducer
implementing a "group by" operation on
input elements of type T
, grouping elements according to a
classification function, and returning the results in a
new distributed Hazelcast ICache
.
- groupingByToICache(String, DistributedFunction<? super T, ? extends K>, DistributedCollector<? super T, A, D>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a Reducer
implementing a cascaded "group by" operation
on input elements of type T
, grouping elements according to a
classification function, and then performing a reduction operation on
the values associated with a given key using the specified downstream
DistributedCollector
.
- groupingByToIMap(String, DistributedFunction<? super T, ? extends K>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a Reducer
implementing a "group by" operation on
input elements of type T
, grouping elements according to a
classification function, and returning the results in a
new distributed Hazelcast IMap
.
- groupingByToIMap(String, DistributedFunction<? super T, ? extends K>, DistributedCollector<? super T, A, D>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a Reducer
implementing a cascaded "group by" operation
on input elements of type T
, grouping elements according to a
classification function, and then performing a reduction operation on
the values associated with a given key using the specified downstream
DistributedCollector
.
- identity() - Static method in interface com.hazelcast.jet.function.DistributedDoubleUnaryOperator
-
Returns a unary operator that always returns its input argument.
- identity() - Static method in interface com.hazelcast.jet.function.DistributedFunction
-
Returns a function that always returns its input argument.
- identity() - Static method in interface com.hazelcast.jet.function.DistributedIntUnaryOperator
-
Returns a unary operator that always returns its input argument.
- identity() - Static method in interface com.hazelcast.jet.function.DistributedLongUnaryOperator
-
Returns a unary operator that always returns its input argument.
- identity() - Static method in interface com.hazelcast.jet.function.DistributedUnaryOperator
-
Returns a unary operator that always returns its input argument.
- ifPresent(DistributedConsumer<? super T>) - Method in class com.hazelcast.jet.function.DistributedOptional
-
If a value is present, invoke the specified consumer with the value,
otherwise do nothing.
- Inbox - Interface in com.hazelcast.jet
-
A subset of Queue<Object>
API restricted to the consumer side,
with additional support for bulk draining operations.
- init(Outbox, Processor.Context) - Method in class com.hazelcast.jet.AbstractProcessor
-
- init(Processor.Context) - Method in class com.hazelcast.jet.AbstractProcessor
-
Method that can be overridden to perform any necessary initialization
for the processor.
- init(DefaultPartitionStrategy) - Method in class com.hazelcast.jet.Partitioner.Default
-
- init(DefaultPartitionStrategy) - Method in interface com.hazelcast.jet.Partitioner
-
- init(Outbox, Processor.Context) - Method in interface com.hazelcast.jet.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.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.ProcessorSupplier
-
Called on each cluster member after deserialization.
- insertWatermarks(DistributedToLongFunction<T>, DistributedSupplier<WatermarkPolicy>, WatermarkEmissionPolicy) - Static method in class com.hazelcast.jet.processor.Processors
-
Returns a supplier of processor that inserts
watermark items
into a data
(sub)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
-
- isBuffered() - Method in class com.hazelcast.jet.Edge
-
- isCooperative() - Method in class com.hazelcast.jet.AbstractProcessor
-
- isCooperative() - Method in interface com.hazelcast.jet.Processor
-
Tells whether this processor is able to participate in cooperative
multithreading.
- isDistributed() - Method in class com.hazelcast.jet.Edge
-
Says whether this edge is distributed.
- isEmpty() - Method in interface com.hazelcast.jet.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.Edge
-
Activates the
ISOLATED
routing policy
which establishes isolated paths from upstream to downstream processors.
- isPresent() - Method in class com.hazelcast.jet.function.DistributedOptional
-
Return true
if there is a value present, otherwise false
.
- IStreamCache<K,V> - Interface in com.hazelcast.jet.stream
-
A decorator for
ICache
for supporting distributed
Stream
implementation.
- IStreamList<E> - Interface in com.hazelcast.jet.stream
-
A decorator for
IList
for supporting distributed
Stream
implementation.
- IStreamMap<K,V> - Interface in com.hazelcast.jet.stream
-
A decorator for
IMap
for supporting distributed
Stream
implementation.
- isTumbling() - Method in class com.hazelcast.jet.WindowDefinition
-
Tells whether this definition describes a tumbling window.
- iterate(Iterator<T>) - Static method in class com.hazelcast.jet.Traversers
-
Returns a simple adapter from Iterator
to Traverser
.
- iterator() - Method in class com.hazelcast.jet.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.
- limit(long) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Returns a stream consisting of the elements of this stream, truncated
to be no longer than maxSize
in length.
- limit(long) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns a stream consisting of the elements of this stream, truncated
to be no longer than maxSize
in length.
- limit(long) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns a stream consisting of the elements of this stream, truncated
to be no longer than maxSize
in length.
- limit(long) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- limitingLagAndDelay(long, long) - Static method in class com.hazelcast.jet.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.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.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.AggregateOperations
-
Returns an operation that computes a linear trend on the items in the
window.
- 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.
- localParallelism() - Method in interface com.hazelcast.jet.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.ProcessorSupplier.Context
-
Returns the number of processors that the associated ProcessorSupplier
will be asked to create.
- localParallelism() - Method in class com.hazelcast.jet.test.TestProcessorMetaSupplierContext
-
- localParallelism() - Method in class com.hazelcast.jet.test.TestProcessorSupplierContext
-
- localParallelism(int) - Method in class com.hazelcast.jet.Vertex
-
Sets the number of processors corresponding to this vertex that will be
created on each member.
- logger() - Method in interface com.hazelcast.jet.Processor.Context
-
Return a logger for the processor
- logger() - Method in class com.hazelcast.jet.test.TestProcessorContext
-
- LongAccumulator - Class in com.hazelcast.jet.accumulator
-
Accumulator of a primitive 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
-
Accumulator of a two primitive long
values.
- 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
-
Accumulator of a two primitive 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 T, ? extends U>) - Method in class com.hazelcast.jet.function.DistributedOptional
-
If a value is present, apply the provided mapping function to it,
and if the result is non-null, return an Optional
describing the
result.
- map(DistributedFunction<T, R>) - Static method in class com.hazelcast.jet.processor.Processors
-
Returns a supplier of processor which, for each received item, emits the
result of applying the given mapping function to it.
- map(DistributedDoubleUnaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Returns a stream consisting of the results of applying the given
function to the elements of this stream.
- map(DoubleUnaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- map(DistributedIntUnaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns a stream consisting of the results of applying the given
function to the elements of this stream.
- map(IntUnaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- map(DistributedLongUnaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns a stream consisting of the results of applying the given
function to the elements of this stream.
- map(LongUnaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- map(DistributedFunction<? super T, ? extends R>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Returns a stream consisting of the results of applying the given
function to the elements of this stream.
- 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
-
Adds a mapping layer to this traverser.
- mapping(DistributedFunction<? super T, ? extends U>, AggregateOperation<? super U, A, R>) - Static method in class com.hazelcast.jet.AggregateOperations
-
Adapts an AggregateOperation
accepting elements of type U
to one accepting elements of type T
by applying a mapping
function to each input element before accumulation.
- mapping(DistributedFunction<? super T, ? extends U>, DistributedCollector<? super U, A, R>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Adapts a DistributedCollector
accepting elements of type U
to one
accepting elements of type T
by applying a mapping function to
each input element before accumulation.
- mapToDouble(DistributedIntToDoubleFunction) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns a DistributedDoubleStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToDouble(IntToDoubleFunction) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- mapToDouble(DistributedLongToDoubleFunction) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns a DoubleStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToDouble(LongToDoubleFunction) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- mapToDouble(DistributedToDoubleFunction<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Returns a DistributedDoubleStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToDouble(ToDoubleFunction<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- mapToInt(DistributedDoubleToIntFunction) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Returns an IntStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToInt(DoubleToIntFunction) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- mapToInt(DistributedLongToIntFunction) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns an IntStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToInt(LongToIntFunction) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- mapToInt(DistributedToIntFunction<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Returns an DistributedIntStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToInt(ToIntFunction<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- mapToLong(DistributedDoubleToLongFunction) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Returns a LongStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToLong(DoubleToLongFunction) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- mapToLong(DistributedIntToLongFunction) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns a DistributedLongStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToLong(IntToLongFunction) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- mapToLong(DistributedToLongFunction<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Returns a DistributedLongStream
consisting of the results of applying the
given function to the elements of this stream.
- mapToLong(ToLongFunction<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- mapToObj(DistributedDoubleFunction<? extends U>) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Returns an object-valued Stream
consisting of the results of
applying the given function to the elements of this stream.
- mapToObj(DoubleFunction<? extends U>) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- mapToObj(DistributedIntFunction<? extends U>) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns an object-valued DistributedStream
consisting of the results of
applying the given function to the elements of this stream.
- mapToObj(IntFunction<? extends U>) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- mapToObj(DistributedLongFunction<? extends U>) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns an object-valued Stream
consisting of the results of
applying the given function to the elements of this stream.
- mapToObj(LongFunction<? extends U>) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- max(DistributedComparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Returns the maximum element of this stream according to the provided
DistributedComparator
.
- max(Comparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- maxBy(DistributedComparator<? super T>) - Static method in class com.hazelcast.jet.AggregateOperations
-
Returns an operation that returns the maximum item, according 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
-
Returns a DistributedCollector
that produces the maximal element according
to a given DistributedComparator
, described as an Optional<T>
.
- min(DistributedComparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Returns the minimum element of this stream according to the provided
DistributedComparator
.
- min(Comparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- minBy(DistributedComparator<? super T>) - Static method in class com.hazelcast.jet.AggregateOperations
-
Returns an operation that returns the minimum item, according 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
-
Returns a DistributedCollector
that produces the minimal element according
to a given DistributedComparator
, described as an Optional<T>
.
- 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.
- naturalOrder() - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
Returns a comparator that compares
Comparable
objects in natural
order.
- negate() - Method in interface com.hazelcast.jet.function.DistributedBiPredicate
-
Returns a predicate that represents the logical negation of this
predicate.
- negate() - Method in interface com.hazelcast.jet.function.DistributedDoublePredicate
-
Returns a predicate that represents the logical negation of this
predicate.
- negate() - Method in interface com.hazelcast.jet.function.DistributedIntPredicate
-
Returns a predicate that represents the logical negation of this
predicate.
- negate() - Method in interface com.hazelcast.jet.function.DistributedLongPredicate
-
Returns a predicate that represents the logical negation of this
predicate.
- negate() - Method in interface com.hazelcast.jet.function.DistributedPredicate
-
Returns a predicate that represents the logical negation of this
predicate.
- 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 an executable job based on a given DAG.
- newJob(DAG, JobConfig) - Method in interface com.hazelcast.jet.JetInstance
-
Creates and returns an executable Job based on the supplied DAG and job
configuration.
- newVertex(String, DistributedSupplier<? extends Processor>) - Method in class com.hazelcast.jet.DAG
-
Creates a vertex from a Supplier<Processor>
and adds it to this DAG.
- newVertex(String, ProcessorSupplier) - Method in class com.hazelcast.jet.DAG
-
Creates a vertex from a ProcessorSupplier
and adds it to this DAG.
- newVertex(String, ProcessorMetaSupplier) - Method in class com.hazelcast.jet.DAG
-
Creates a vertex from a ProcessorMetaSupplier
and adds it to this DAG.
- next() - Method in class com.hazelcast.jet.ResettableSingletonTraverser
-
- next() - Method in interface com.hazelcast.jet.Traverser
-
Returns the next item in the sequence, or null
if the sequence is
already exhausted
- nonCooperative(ProcessorSupplier) - Static method in class com.hazelcast.jet.processor.Processors
-
Decorates a ProcessorSupplier
with one that will declare all its
processors non-cooperative.
- nonCooperative(DistributedSupplier<Processor>) - Static method in class com.hazelcast.jet.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
-
Returns whether no elements of this stream match the provided predicate.
- noneMatch(DoublePredicate) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- noneMatch(DistributedIntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns whether no elements of this stream match the provided predicate.
- noneMatch(IntPredicate) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- noneMatch(DistributedLongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns whether no elements of this stream match the provided predicate.
- noneMatch(LongPredicate) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- noneMatch(DistributedPredicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Returns whether no elements of this stream match the provided predicate.
- noneMatch(Predicate<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- noop() - Static method in class com.hazelcast.jet.processor.Processors
-
Returns a supplier of processor that consumes all its input (if any) and
does nothing with it.
- noopConsumer() - Static method in class com.hazelcast.jet.function.DistributedFunctions
-
Returns a consumer that does nothing with the argument.
- 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(DistributedSupplier<A>, DistributedBiConsumer<? super A, T>, DistributedBiConsumer<? super A, ? super A>, DistributedBiConsumer<? super A, ? super A>, DistributedFunction<? super A, R>) - Static method in interface com.hazelcast.jet.AggregateOperation
-
Returns a new AggregateOperation
object composed from the provided
primitives.
- of(T) - Static method in class com.hazelcast.jet.function.DistributedOptional
-
Returns an Optional
with the specified present non-null value.
- of(ProcessorSupplier) - Static method in interface com.hazelcast.jet.ProcessorMetaSupplier
-
Factory method that wraps the given ProcessorSupplier
and returns the same instance for each given Address
.
- of(DistributedSupplier<? extends Processor>) - Static method in interface com.hazelcast.jet.ProcessorMetaSupplier
-
Factory method that wraps the given Supplier<Processor>
and uses it as the supplier of all Processor
instances.
- of(DistributedFunction<Address, ProcessorSupplier>) - Static method in interface com.hazelcast.jet.ProcessorMetaSupplier
-
- of(DistributedSupplier<? extends Processor>) - Static method in interface com.hazelcast.jet.ProcessorSupplier
-
Returns a ProcessorSupplier
which will delegate to the given
Supplier<Processor>
to create all Processor
instances.
- of(DistributedSupplier<R>, DistributedBiConsumer<R, T>, DistributedBinaryOperator<R>, Collector.Characteristics...) - Static method in interface com.hazelcast.jet.stream.DistributedCollector
-
Returns a new DistributedCollector
described by the given supplier
,
accumulator
, and combiner
functions.
- of(DistributedSupplier<A>, DistributedBiConsumer<A, T>, DistributedBinaryOperator<A>, DistributedFunction<A, R>, Collector.Characteristics...) - Static method in interface com.hazelcast.jet.stream.DistributedCollector
-
Returns a new DistributedCollector
described by the given supplier
,
accumulator
, combiner
, and finisher
functions.
- offer(int, Object) - Method in interface com.hazelcast.jet.Outbox
-
Offers the supplied item to the output bucket with the supplied
ordinal.
- offer(int[], Object) - Method in interface com.hazelcast.jet.Outbox
-
First ensures that all the buckets identified in the supplied
array of ordinals have room for another item, then adds the
supplied item to them.
- offer(Object) - Method in interface com.hazelcast.jet.Outbox
-
First ensures that all buckets have room for another item, then
adds the supplied item to them.
- offer(int, Object) - Method in class com.hazelcast.jet.test.TestOutbox
-
- offer(int[], Object) - Method in class com.hazelcast.jet.test.TestOutbox
-
- ofNullable(T) - Static method in class com.hazelcast.jet.function.DistributedOptional
-
Returns an Optional
describing the specified value, if non-null,
otherwise returns an empty Optional
.
- onFirstNull(Runnable) - Method in interface com.hazelcast.jet.Traverser
-
Returns a traverser that will emit the same items as this traverser and
will additionally run the supplied action first time this traverser
returns null
.
- or(DistributedBiPredicate<? super T, ? super U>) - Method in interface com.hazelcast.jet.function.DistributedBiPredicate
-
Returns a composed predicate that represents a short-circuiting logical
OR of this predicate and another.
- or(DistributedDoublePredicate) - Method in interface com.hazelcast.jet.function.DistributedDoublePredicate
-
Returns a composed predicate that represents a short-circuiting logical
OR of this predicate and another.
- or(DistributedIntPredicate) - Method in interface com.hazelcast.jet.function.DistributedIntPredicate
-
Returns a composed predicate that represents a short-circuiting logical
OR of this predicate and another.
- or(DistributedLongPredicate) - Method in interface com.hazelcast.jet.function.DistributedLongPredicate
-
Returns a composed predicate that represents a short-circuiting logical
OR of this predicate and another.
- or(DistributedPredicate<? super T>) - Method in interface com.hazelcast.jet.function.DistributedPredicate
-
Returns a composed predicate that represents a short-circuiting logical
OR of this predicate and another.
- orElse(T) - Method in class com.hazelcast.jet.function.DistributedOptional
-
Return the value if present, otherwise return other
.
- orElseGet(DistributedSupplier<? extends T>) - Method in class com.hazelcast.jet.function.DistributedOptional
-
Return the value if present, otherwise invoke other
and return
the result of that invocation.
- orElseThrow(DistributedSupplier<? extends X>) - Method in class com.hazelcast.jet.function.DistributedOptional
-
Return the contained value, if present, otherwise throw an exception
to be created by the provided supplier.
- Outbox - Interface in com.hazelcast.jet
-
- 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
-
Returns an equivalent stream that is parallel.
- parallel() - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns an equivalent stream that is parallel.
- parallel() - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns an equivalent stream that is parallel.
- parallel() - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- parallelStream() - Method in interface com.hazelcast.jet.stream.IStreamList
-
Returns a parallel Stream
with this list as its source.
- partitioned(DistributedFunction<T, ?>) - Method in class com.hazelcast.jet.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.Edge
-
Activates the
PARTITIONED
routing
policy and applies the provided partitioning strategy.
- Partitioner<T> - Interface in com.hazelcast.jet
-
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
-
Partitioner which applies the default Hazelcast partitioning strategy.
- partitioningBy(DistributedPredicate<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
which partitions the input elements according
to a DistributedPredicate
, and organizes them into a
Map<Boolean, List<T>>
.
- partitioningBy(DistributedPredicate<? super T>, DistributedCollector<? super T, A, D>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
which partitions the input elements according
to a DistributedPredicate
, reduces the values in each partition according to
another DistributedCollector
, and organizes them into a
Map<Boolean, D>
whose values are the result of the downstream
reduction.
- peek() - Method in interface com.hazelcast.jet.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
-
Returns a stream consisting of the elements of this stream, additionally
performing the provided action on each element as elements are consumed
from the resulting stream.
- peek(DoubleConsumer) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
- peek(DistributedIntConsumer) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns a stream consisting of the elements of this stream, additionally
performing the provided action on each element as elements are consumed
from the resulting stream.
- peek(IntConsumer) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
- peek(DistributedLongConsumer) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns a stream consisting of the elements of this stream, additionally
performing the provided action on each element as elements are consumed
from the resulting stream.
- peek(LongConsumer) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
- peek(DistributedConsumer<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Returns a stream consisting of the elements of this stream, additionally
performing the provided action on each element as elements are consumed
from the resulting stream.
- 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 item to the supplied consumer.
- peekInput(DistributedFunction<Object, String>, DistributedPredicate<Object>, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.processor.DiagnosticProcessors
-
Returns a meta-supplier that will add logging to the processors created
by the provided meta-supplier.
- peekInput(DistributedFunction<Object, String>, DistributedPredicate<Object>, ProcessorSupplier) - Static method in class com.hazelcast.jet.processor.DiagnosticProcessors
-
- peekInput(DistributedFunction<Object, String>, DistributedPredicate<Object>, DistributedSupplier<Processor>) - Static method in class com.hazelcast.jet.processor.DiagnosticProcessors
-
- peekInput(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.processor.DiagnosticProcessors
-
- peekInput(ProcessorSupplier) - Static method in class com.hazelcast.jet.processor.DiagnosticProcessors
-
- peekInput(DistributedSupplier<Processor>) - Static method in class com.hazelcast.jet.processor.DiagnosticProcessors
-
- peekOutput(DistributedFunction<Object, String>, DistributedPredicate<Object>, ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.processor.DiagnosticProcessors
-
Returns a meta-supplier that will add logging to the processors created
by the provided meta-supplier.
- peekOutput(DistributedFunction<Object, String>, DistributedPredicate<Object>, ProcessorSupplier) - Static method in class com.hazelcast.jet.processor.DiagnosticProcessors
-
- peekOutput(DistributedFunction<Object, String>, DistributedPredicate<Object>, DistributedSupplier<Processor>) - Static method in class com.hazelcast.jet.processor.DiagnosticProcessors
-
- peekOutput(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.processor.DiagnosticProcessors
-
- peekOutput(ProcessorSupplier) - Static method in class com.hazelcast.jet.processor.DiagnosticProcessors
-
- peekOutput(DistributedSupplier<Processor>) - Static method in class com.hazelcast.jet.processor.DiagnosticProcessors
-
- poll() - Method in interface com.hazelcast.jet.Inbox
-
Retrieves and removes the head of this inbox, or returns null
if it is empty.
- 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.Edge
-
Sets the priority of the edge.
- process(int, Inbox) - Method in class com.hazelcast.jet.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.Processor
-
Called with a batch of items retrieved from an inbound edge's stream.
- process0(Inbox) - Method in class com.hazelcast.jet.AbstractProcessor
-
- process1(Inbox) - Method in class com.hazelcast.jet.AbstractProcessor
-
- process2(Inbox) - Method in class com.hazelcast.jet.AbstractProcessor
-
- process3(Inbox) - Method in class com.hazelcast.jet.AbstractProcessor
-
- process4(Inbox) - Method in class com.hazelcast.jet.AbstractProcessor
-
- processAny(int, Inbox) - Method in class com.hazelcast.jet.AbstractProcessor
-
- Processor - Interface in com.hazelcast.jet
-
Does the computation needed to transform zero or more input data streams
into zero or more output streams.
- Processor.Context - Interface in com.hazelcast.jet
-
Context passed to the processor in the
init()
call.
- processorFrom(DistributedSupplier<Processor>) - Static method in class com.hazelcast.jet.test.TestSupport
-
Gets single processor instance from processor supplier.
- processorFrom(ProcessorSupplier) - Static method in class com.hazelcast.jet.test.TestSupport
-
Gets single processor instance from processor supplier.
- processorFrom(ProcessorMetaSupplier) - Static method in class com.hazelcast.jet.test.TestSupport
-
Gets single processor instance from meta processor supplier.
- ProcessorMetaSupplier - Interface in com.hazelcast.jet
-
- ProcessorMetaSupplier.Context - Interface in com.hazelcast.jet
-
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.processor
-
Static utility class with factory methods for Jet processors.
- ProcessorSupplier - Interface in com.hazelcast.jet
-
- ProcessorSupplier.Context - Interface in com.hazelcast.jet
-
Context passed to the supplier in the
init()
call.
- readCache(String) - Static method in class com.hazelcast.jet.processor.Sources
-
Returns a meta-supplier of processor that will fetch entries from the
Hazelcast ICache
with the specified name and will emit them as
Cache.Entry
.
- readCache(String, ClientConfig) - Static method in class com.hazelcast.jet.processor.Sources
-
Returns a meta-supplier of processor that will fetch entries from a
Hazelcast ICache
in a remote cluster.
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.DAG
-
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.Edge
-
- readData(ObjectDataInput) - Method in class com.hazelcast.jet.Vertex
-
- readFiles(String) - Static method in class com.hazelcast.jet.processor.Sources
-
- readFiles(String, Charset, String) - Static method in class com.hazelcast.jet.processor.Sources
-
A source that emits lines from all files in a directory (but not its
subdirectories), or only the files matching the supplied glob
pattern.
- readList(String) - Static method in class com.hazelcast.jet.processor.Sources
-
Returns a meta-supplier of processor that emits items retrieved from an
IMDG IList.
- readList(String, ClientConfig) - Static method in class com.hazelcast.jet.processor.Sources
-
Returns a meta-supplier of processor that emits items retrieved from an
IMDG IList in a remote cluster.
- readMap(String) - Static method in class com.hazelcast.jet.processor.Sources
-
Returns a meta-supplier of processor that will fetch entries from the
Hazelcast IMap
with the specified name and will emit them as
Map.Entry
.
- readMap(String, ClientConfig) - Static method in class com.hazelcast.jet.processor.Sources
-
Returns a meta-supplier of processor that will fetch entries from a
Hazelcast IMap
in a remote cluster.
- reduce(StreamContext, Pipeline<? 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
-
Performs a reduction on the
elements of this stream, using the provided identity value and an
associative
accumulation function, and returns the reduced value.
- reduce(DistributedDoubleBinaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Performs a reduction on the
elements of this stream, using an
associative accumulation
function, and returns an OptionalDouble
describing the reduced
value, if any.
- 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
-
Performs a reduction on the
elements of this stream, using the provided identity value and an
associative
accumulation function, and returns the reduced value.
- reduce(DistributedIntBinaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Performs a reduction on the
elements of this stream, using an
associative accumulation
function, and returns an OptionalInt
describing the reduced value,
if any.
- 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
-
Performs a reduction on the
elements of this stream, using the provided identity value and an
associative
accumulation function, and returns the reduced value.
- reduce(DistributedLongBinaryOperator) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Performs a reduction on the
elements of this stream, using an
associative accumulation
function, and returns an OptionalLong
describing the reduced value,
if any.
- 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
-
Performs a reduction on the
elements of this stream, using the provided identity value and an
associative
accumulation function, and returns the reduced value.
- reduce(DistributedBinaryOperator<T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Performs a reduction on the
elements of this stream, using an
associative accumulation
function, and returns an Optional
describing the reduced value,
if any.
- reduce(U, DistributedBiFunction<U, ? super T, U>, DistributedBinaryOperator<U>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Performs a reduction on the
elements of this stream, using the provided identity, accumulation and
combining functions.
- 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.AggregateOperations
-
A reducing operation maintains an accumulated value that starts out as
emptyAccValue
and is being iteratively transformed by applying
the combine
primitive to it and each stream item's accumulated
value, as returned from toAccValueF
.
- reducing(T, DistributedBinaryOperator<T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
which performs a reduction of its
input elements under a specified DistributedBinaryOperator
using the
provided identity.
- reducing(DistributedBinaryOperator<T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
which performs a reduction of its
input elements under a specified DistributedBinaryOperator
.
- reducing(U, DistributedFunction<? super T, ? extends U>, DistributedBinaryOperator<U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
which performs a reduction of its
input elements under a specified mapping function and
DistributedBinaryOperator
.
- remove() - Method in interface com.hazelcast.jet.Inbox
-
Retrieves and removes the head of this inbox.
- reportEvent(long) - Method in interface com.hazelcast.jet.WatermarkPolicy
-
Called to report the observation of an event with the given timestamp.
- ResettableSingletonTraverser<T> - Class in com.hazelcast.jet
-
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.ResettableSingletonTraverser
-
- ResourceConfig - Class in com.hazelcast.jet.config
-
Describes a single resource to deploy to the Jet cluster.
- ResourceConfig(URL, String, ResourceKind) - Constructor for class com.hazelcast.jet.config.ResourceConfig
-
Creates a resource config with the given properties.
- ResourceConfig(Class) - Constructor for class com.hazelcast.jet.config.ResourceConfig
-
Creates a config for a class to be deployed.
- reversed() - Method in interface com.hazelcast.jet.function.DistributedComparator
-
- reverseIterator() - Method in class com.hazelcast.jet.DAG
-
Returns an iterator over the DAG's vertices in reverse topological order.
- reverseOrder() - Static method in interface com.hazelcast.jet.function.DistributedComparator
-
Returns a comparator that imposes the reverse of the natural
ordering.
- sequential() - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Returns an equivalent stream that is sequential.
- sequential() - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns an equivalent stream that is sequential.
- sequential() - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns an equivalent stream that is sequential.
- sequential() - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- Session<K,R> - Class in com.hazelcast.jet
-
Holds the aggregated result of a session window.
- Session(K, long, long, R) - Constructor for class com.hazelcast.jet.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.
- setConfig(EdgeConfig) - Method in class com.hazelcast.jet.Edge
-
Assigns an EdgeConfig
to this edge.
- setCooperative(boolean) - Method in class com.hazelcast.jet.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.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.test.TestProcessorContext
-
Set the jet instance.
- setJetInstance(JetInstance) - Method in class com.hazelcast.jet.test.TestProcessorMetaSupplierContext
-
Set the jet instance.
- setJetInstance(JetInstance) - Method in class com.hazelcast.jet.test.TestProcessorSupplierContext
-
Set the jet instance.
- setJobFuture(CompletableFuture<Void>) - Method in class com.hazelcast.jet.test.TestProcessorContext
-
Set the job future.
- setLocalParallelism(int) - Method in class com.hazelcast.jet.test.TestProcessorMetaSupplierContext
-
Set local parallelism.
- setLocalParallelism(int) - Method in class com.hazelcast.jet.test.TestProcessorSupplierContext
-
Set local parallelism.
- setLogger(ILogger) - Method in class com.hazelcast.jet.test.TestProcessorContext
-
Set the logger.
- setOutboxCapacity(int) - Method in class com.hazelcast.jet.config.EdgeConfig
-
Sets the capacity of the outbox bucket corresponding to this edge.
- 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.
- 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.
- 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.test.TestProcessorMetaSupplierContext
-
Set total parallelism.
- setValue(V) - Method in class com.hazelcast.jet.TimestampedEntry
-
- 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.test.TestProcessorContext
-
Set the vertex name.
- shouldEmit(long, long) - Method in interface com.hazelcast.jet.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.
- Sinks - Class in com.hazelcast.jet.processor
-
Static utility class with factories of sink processors (the terminators
of the DAG data flow).
- skip(long) - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Returns a stream consisting of the remaining elements of this stream
after discarding the first n
elements of the stream.
- skip(long) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns a stream consisting of the remaining elements of this stream
after discarding the first n
elements of the stream.
- skip(long) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns a stream consisting of the remaining elements of this stream
after discarding the first n
elements of the stream.
- skip(long) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- slidingWindowDef(long, long) - Static method in class com.hazelcast.jet.WindowDefinition
-
Returns the definition of a sliding window of length windowLength
that slides by slideBy
.
- sorted() - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
-
Returns a stream consisting of the elements of this stream in sorted
order.
- sorted() - Method in interface com.hazelcast.jet.stream.DistributedIntStream
-
Returns a stream consisting of the elements of this stream in sorted
order.
- sorted() - Method in interface com.hazelcast.jet.stream.DistributedLongStream
-
Returns a stream consisting of the elements of this stream in sorted
order.
- sorted() - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- sorted(DistributedComparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
Returns a stream consisting of the elements of this stream, sorted
according to the provided Comparator
.
- sorted(Comparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
-
- Sources - Class in com.hazelcast.jet.processor
-
Static utility class with factories of source processors (the DAG
entry points).
- spliterate(Spliterator<T>) - Static method in class com.hazelcast.jet.Traversers
-
Returns a simple adapter from Spliterator
to Traverser
.
- StartServer - Class in com.hazelcast.jet.server
-
Main class that starts a Hazelcast Jet instance.
- stream() - Method in interface com.hazelcast.jet.stream.IStreamCache
-
Returns a parallel and distributed Stream
with this list as its source.
- stream() - Method in interface com.hazelcast.jet.stream.IStreamList
-
Returns a sequential Stream
with this list as its source.
- stream() - Method in interface com.hazelcast.jet.stream.IStreamMap
-
Returns a parallel and distributed Stream
with this list as its source.
- streamFiles(String) - Static method in class com.hazelcast.jet.processor.Sources
-
- streamFiles(String, Charset, String) - Static method in class com.hazelcast.jet.processor.Sources
-
A source that generates a stream of lines of text coming from files in
the watched directory (but not its subdirectories).
- streamSocket(String, int) - Static method in class com.hazelcast.jet.processor.Sources
-
- streamSocket(String, int, Charset) - Static method in class com.hazelcast.jet.processor.Sources
-
Returns a supplier of processor which connects to a specified socket and
reads and emits text line by line.
- 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
-
Returns a DistributedCollector
which applies an double
-producing
mapping function to each input element, and returns summary statistics
for the resulting values.
- summarizingInt(DistributedToIntFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
which applies an int
-producing
mapping function to each input element, and returns summary statistics
for the resulting values.
- summarizingLong(DistributedToLongFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
which applies an long
-producing
mapping function to each input element, and returns summary statistics
for the resulting values.
- summingDouble(DistributedToDoubleFunction<T>) - Static method in class com.hazelcast.jet.AggregateOperations
-
Returns an operation that tracks the sum of the quantity returned by
mapToDoubleF
applied to each item in the window.
- summingDouble(DistributedToDoubleFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
that produces the sum of a double-valued
function applied to the input elements.
- summingInt(DistributedToIntFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
that produces the sum of a integer-valued
function applied to the input elements.
- summingLong(DistributedToLongFunction<T>) - Static method in class com.hazelcast.jet.AggregateOperations
-
Returns an operation that tracks the sum of the quantity returned by
mapToLongF
applied to each item in the window.
- summingLong(DistributedToLongFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
that produces the sum of a long-valued
function applied to the input elements.
- supplier() - Method in interface com.hazelcast.jet.stream.DistributedCollector
-
A function that creates and returns a new mutable result container.
- suppressDuplicates() - Static method in interface com.hazelcast.jet.WatermarkEmissionPolicy
-
Returns a policy that ensures that each emitted watermark has a higher
timestamp than the last one.
- test(T) - Method in interface com.hazelcast.jet.function.DistributedPredicate
-
- TestInbox - Class in com.hazelcast.jet.test
-
- TestInbox() - Constructor for class com.hazelcast.jet.test.TestInbox
-
- TestOutbox - Class in com.hazelcast.jet.test
-
- TestOutbox(int...) - Constructor for class com.hazelcast.jet.test.TestOutbox
-
- testProcessor(DistributedSupplier<Processor>, List<T>, List<U>) - Static method in class com.hazelcast.jet.test.TestSupport
-
- testProcessor(ProcessorSupplier, List<T>, List<U>) - Static method in class com.hazelcast.jet.test.TestSupport
-
- testProcessor(ProcessorMetaSupplier, List<T>, List<U>) - Static method in class com.hazelcast.jet.test.TestSupport
-
- testProcessor(Processor, List<T>, List<U>) - Static method in class com.hazelcast.jet.test.TestSupport
-
- testProcessor(DistributedSupplier<Processor>, List<T>, List<U>, boolean) - Static method in class com.hazelcast.jet.test.TestSupport
-
- testProcessor(ProcessorSupplier, List<T>, List<U>, boolean) - Static method in class com.hazelcast.jet.test.TestSupport
-
- testProcessor(ProcessorMetaSupplier, List<T>, List<U>, boolean) - Static method in class com.hazelcast.jet.test.TestSupport
-
- testProcessor(Processor, List<T>, List<U>, boolean) - Static method in class com.hazelcast.jet.test.TestSupport
-
A utility to test processors.
- TestProcessorContext - Class in com.hazelcast.jet.test
-
Simple implementation of Processor.Context
.
- TestProcessorContext() - Constructor for class com.hazelcast.jet.test.TestProcessorContext
-
Constructor with default values.
- TestProcessorMetaSupplierContext - Class in com.hazelcast.jet.test
-
Simple implementation of ProcessorMetaSupplier.Context
.
- TestProcessorMetaSupplierContext() - Constructor for class com.hazelcast.jet.test.TestProcessorMetaSupplierContext
-
- TestProcessorSupplierContext - Class in com.hazelcast.jet.test
-
Simple implementation of ProcessorSupplier.Context
.
- TestProcessorSupplierContext() - Constructor for class com.hazelcast.jet.test.TestProcessorSupplierContext
-
- TestSupport - Class in com.hazelcast.jet.test
-
Utilities to write unit tests.
- 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
-
- timestamp() - Method in class com.hazelcast.jet.Watermark
-
Returns the timestamp of this watermark item.
- TimestampedEntry<K,V> - Class in com.hazelcast.jet
-
Map.Entry
extended with a long timestamp
.
- TimestampedEntry(long, K, V) - Constructor for class com.hazelcast.jet.TimestampedEntry
-
Constructs a timestamped entry with the supplied field values.
- TimestampKind - Enum in com.hazelcast.jet
-
Enumerates the two possible kinds of timestamp: event timestamp and
frame timestamp.
- to(Vertex) - Method in class com.hazelcast.jet.Edge
-
Sets the destination vertex of this edge, with ordinal 0.
- to(Vertex, int) - Method in class com.hazelcast.jet.Edge
-
Sets the destination vertex and ordinal of this edge.
- toCollection(DistributedSupplier<C>) - Static method in class com.hazelcast.jet.AggregateOperations
-
Returns an AggregateOperation
that accumulates the input
elements into a new Collection
.
- toCollection(DistributedSupplier<C>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
that accumulates the input
elements into a new Collection
, in encounter order.
- toICache(String, DistributedFunction<? super T, ? extends K>, DistributedFunction<? super T, ? extends U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a Reducer
that accumulates elements into a
new Hazelcast ICache
whose keys and values are the result of applying the provided
mapping functions to the input elements.
- toICache(String) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a Reducer
that accumulates elements into a
new distributed Hazelcast ICache
whose keys and values are the keys and values of
the corresponding Cache.Entry
.
- toICache(String, DistributedFunction<? super T, ? extends K>, DistributedFunction<? super T, ? extends U>, DistributedBinaryOperator<U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a Reducer
that accumulates elements into a
new distributed Hazelcast ICache
whose keys and values are the result of applying
the provided mapping functions to the input elements.
- toIList(String) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a Reducer
that accumulates the input elements into a
new Hazelcast IList
.
- toIMap(String, DistributedFunction<? super T, ? extends K>, DistributedFunction<? super T, ? extends U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a Reducer
that accumulates elements into a
new Hazelcast IMap
whose keys and values are the result of applying the provided
mapping functions to the input elements.
- toIMap(String) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a Reducer
that accumulates elements into a
new distributed Hazelcast IMap
whose keys and values are the keys and values of
the corresponding Map.Entry
.
- toIMap(String, DistributedFunction<? super T, ? extends K>, DistributedFunction<? super T, ? extends U>, DistributedBinaryOperator<U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a Reducer
that accumulates elements into a
new distributed Hazelcast IMap
whose keys and values are the result of applying
the provided mapping functions to the input elements.
- toList() - Static method in class com.hazelcast.jet.AggregateOperations
-
Returns an AggregateOperation
that accumulates the input
elements into a new ArrayList
.
- toList() - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
that accumulates the input
elements into a new List
.
- toMap(DistributedFunction<? super T, ? extends K>, DistributedFunction<? super T, ? extends U>) - Static method in class com.hazelcast.jet.AggregateOperations
-
Returns an AggregateOperation
that accumulates elements
into a HashMap
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>, DistributedBinaryOperator<U>) - Static method in class com.hazelcast.jet.AggregateOperations
-
Returns an AggregateOperation
that accumulates elements
into a HashMap
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>, DistributedBinaryOperator<U>, DistributedSupplier<M>) - Static method in class com.hazelcast.jet.AggregateOperations
-
Returns an AggregateOperation
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
-
Returns a DistributedCollector
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>, DistributedBinaryOperator<U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
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>, DistributedBinaryOperator<U>, DistributedSupplier<M>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
that accumulates elements into a
Map
whose keys and values are the result of applying the provided
mapping functions to the input elements.
- TopologyChangedException - Exception in com.hazelcast.jet
-
Thrown when a topology change (member addition/removal) happens
while executing a job.
- TopologyChangedException(String) - Constructor for exception com.hazelcast.jet.TopologyChangedException
-
Creates the exception with a message.
- TopologyChangedException(String, Throwable) - Constructor for exception com.hazelcast.jet.TopologyChangedException
-
Creates the exception with a message and a cause.
- toSet() - Static method in class com.hazelcast.jet.AggregateOperations
-
Returns an AggregateOperation
that accumulates the input
elements into a new HashSet
.
- toSet() - Static method in class com.hazelcast.jet.stream.DistributedCollectors
-
Returns a DistributedCollector
that accumulates the input
elements into a new Set
.
- 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.DAG
-
- toString() - Method in class com.hazelcast.jet.Edge
-
- toString() - Method in class com.hazelcast.jet.function.DistributedOptional
-
Returns a non-empty string representation of this Optional suitable for
debugging.
- toString() - Method in class com.hazelcast.jet.Session
-
- toString() - Method in class com.hazelcast.jet.test.TestOutbox
-
- toString() - Method in class com.hazelcast.jet.TimestampedEntry
-
- toString() - Method in class com.hazelcast.jet.Vertex
-
- toString() - Method in class com.hazelcast.jet.Watermark
-
- totalParallelism() - Method in interface com.hazelcast.jet.ProcessorMetaSupplier.Context
-
Returns the total number of Processor
s that will be
created across the cluster.
- totalParallelism() - Method in class com.hazelcast.jet.test.TestProcessorMetaSupplierContext
-
- toTumblingByFrame() - Method in class com.hazelcast.jet.WindowDefinition
-
Converts this definition to one defining a tumbling window of the
same length as this definition's frame.
- traverseArray(T[]) - Static method in class com.hazelcast.jet.Traversers
-
Returns a traverser over the given array.
- traverseIterable(Iterable<T>) - Static method in class com.hazelcast.jet.Traversers
-
Returns a traverser over the given iterable.
- Traverser<T> - Interface in com.hazelcast.jet
-
Traverses a potentially infinite sequence of non-null
items.
- Traversers - Class in com.hazelcast.jet
-
- 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.AbstractProcessor
-
Offers the item to the outbox bucket at the supplied ordinal.
- tryEmit(Object) - Method in class com.hazelcast.jet.AbstractProcessor
-
Offers the item to all the outbox buckets.
- tryEmit(int[], Object) - Method in class com.hazelcast.jet.AbstractProcessor
-
Offers the item to the outbox buckets identified in the supplied array.
- tryProcess(T) - Method in class com.hazelcast.jet.AbstractProcessor.FlatMapper
-
Method designed to be called from one of AbstractProcessor#tryProcessX()
methods.
- tryProcess(int, Object) - Method in class com.hazelcast.jet.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.Processor
-
Called when there is no pending data in the inbox.
- tryProcess0(Object) - Method in class com.hazelcast.jet.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.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.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.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.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.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.AbstractProcessor
-
- tryProcessWm1(Watermark) - Method in class com.hazelcast.jet.AbstractProcessor
-
- tryProcessWm2(Watermark) - Method in class com.hazelcast.jet.AbstractProcessor
-
- tryProcessWm3(Watermark) - Method in class com.hazelcast.jet.AbstractProcessor
-
- tryProcessWm4(Watermark) - Method in class com.hazelcast.jet.AbstractProcessor
-
- tumblingWindowDef(long) - Static method in class com.hazelcast.jet.WindowDefinition
-
Returns the definition of a tumbling window of length windowLength
.
- Watermark - Class in com.hazelcast.jet
-
Watermark is an item occasionally inserted into a disordered
(sub)stream of timestamped items.
- Watermark(long) - Constructor for class com.hazelcast.jet.Watermark
-
Constructs a new watermark item.
- WatermarkEmissionPolicy - Interface in com.hazelcast.jet
-
A policy object that decides when when the watermark has advanced
enough to emit a new watermark item.
- WatermarkPolicies - Class in com.hazelcast.jet
-
Utility class with factories of several useful watermark policies.
- WatermarkPolicy - Interface in com.hazelcast.jet
-
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
-
Contains parameters that define a sliding/tumbling window over which Jet
will apply an aggregate function.
- windowLength() - Method in class com.hazelcast.jet.WindowDefinition
-
Returns the length of the window (the size of the timestamp range it covers).
- withAccumulate(DistributedBiConsumer<A, T1>) - Method in interface com.hazelcast.jet.AggregateOperation
-
Returns a copy of this aggregate operation with the accumulate
primitive replaced by the supplied one.
- withFinish(DistributedFunction<? super A, R1>) - Method in interface com.hazelcast.jet.AggregateOperation
-
Returns a copy of this aggregate operation with the finish
primitive replaced by the supplied one.
- withFixedLag(long) - Static method in class com.hazelcast.jet.WatermarkPolicies
-
Maintains watermark that lags behind the top observed timestamp by the
given amount.
- withOffset(long) - Method in class com.hazelcast.jet.WindowDefinition
-
Returns a new window definition where all the frames are shifted by the
given offset.
- writeBuffered(DistributedIntFunction<B>, DistributedBiConsumer<B, T>, DistributedConsumer<B>) - Static method in class com.hazelcast.jet.processor.Sinks
-
Returns a supplier of processor which drains all items from its inbox
to an intermediate buffer and then flushes the buffer.
- writeBuffered(DistributedIntFunction<B>, DistributedBiConsumer<B, T>, DistributedConsumer<B>, DistributedConsumer<B>) - Static method in class com.hazelcast.jet.processor.Sinks
-
Returns a supplier of processor which drains all items from the inbox
to an intermediate buffer and then flushes the buffer.
- writeCache(String) - Static method in class com.hazelcast.jet.processor.Sinks
-
Returns a supplier of processor which will put data into a Hazelcast
ICache
.
- writeCache(String, ClientConfig) - Static method in class com.hazelcast.jet.processor.Sinks
-
Returns a supplier of processor which will put data into a Hazelcast
ICache
in a remote cluster.
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.DAG
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.Edge
-
- writeData(ObjectDataOutput) - Method in class com.hazelcast.jet.Vertex
-
- writeFile(String) - Static method in class com.hazelcast.jet.processor.Sinks
-
- writeFile(String, DistributedFunction<T, String>) - Static method in class com.hazelcast.jet.processor.Sinks
-
- writeFile(String, DistributedFunction<T, String>, Charset, boolean) - Static method in class com.hazelcast.jet.processor.Sinks
-
Returns a meta-supplier of processor that writes all items to a local
file on each member.
- writeList(String) - Static method in class com.hazelcast.jet.processor.Sinks
-
Returns a supplier of processor which writes received items to an IMDG
IList
.
- writeList(String, ClientConfig) - Static method in class com.hazelcast.jet.processor.Sinks
-
Returns a supplier of processor which writes received items to an IMDG
IList
in a remote cluster.
- writeLogger(DistributedFunction<T, String>) - Static method in class com.hazelcast.jet.processor.DiagnosticProcessors
-
Returns a supplier of processor that acts as a sink and logs all items
at the INFO level.
- writeLogger() - Static method in class com.hazelcast.jet.processor.DiagnosticProcessors
-
- writeMap(String) - Static method in class com.hazelcast.jet.processor.Sinks
-
Returns a supplier of processor that will put data into a Hazelcast
IMap
.
- writeMap(String, ClientConfig) - Static method in class com.hazelcast.jet.processor.Sinks
-
Returns a supplier of processor that will put data into a Hazelcast
IMap
in a remote cluster.
- writeObject(ObjectDataOutput) - Method in class com.hazelcast.jet.accumulator.LinTrendAccumulator
-
Serializes this accumulator.
- writeSocket(String, int) - Static method in class com.hazelcast.jet.processor.Sinks
-
- writeSocket(String, int, DistributedFunction<T, String>) - Static method in class com.hazelcast.jet.processor.Sinks
-
- writeSocket(String, int, DistributedFunction<T, String>, Charset) - Static method in class com.hazelcast.jet.processor.Sinks
-
Returns a supplier of processor which connects to specified socket and
writes the items as text.