Skip navigation links
A B C D E F G H I J K L M N O P R S T U V W 

A

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
A helper that simplifies the implementation of AbstractProcessor.tryProcess(int, Object) for flatMap-like behavior.
accept(T, U) - Method in interface com.hazelcast.jet.Distributed.BiConsumer
 
accept(T) - Method in interface com.hazelcast.jet.Distributed.Consumer
 
accumulate(Distributed.Supplier<? extends A>, Distributed.BiFunction<? super A, ? super T, ? extends A>, Distributed.Function<? super A, ? extends R>) - Static method in class com.hazelcast.jet.Processors
Returns a supplier of processor with the following semantics: Calls the supplier function to obtain the initial accumulated value.
accumulate(Distributed.Supplier<? extends A>, Distributed.BiFunction<? super A, ? super T, ? extends A>) - Static method in class com.hazelcast.jet.Processors
Convenience over accumulate(supplier, accumulator, finisher) with identity function as the finisher, which means the processor emits an item of type A.
accumulator() - Method in interface com.hazelcast.jet.stream.DistributedCollector
A function that folds a value into a mutable result container.
add(Object) - Method in interface com.hazelcast.jet.Outbox
Adds the supplied item to all the output buckets.
add(int, Object) - Method in interface com.hazelcast.jet.Outbox
Adds the supplied item to the output bucket with the supplied ordinal.
addClass(Class...) - Method in class com.hazelcast.jet.config.JobConfig
Add class to the job classLoader
addJar(URL) - Method in class com.hazelcast.jet.config.JobConfig
Add JAR to the job classLoader
addJar(URL, String) - Method in class com.hazelcast.jet.config.JobConfig
Add JAR to the job classLoader
addJar(File) - Method in class com.hazelcast.jet.config.JobConfig
Add JAR to the job classLoader
addJar(File, String) - Method in class com.hazelcast.jet.config.JobConfig
Add JAR to the job classLoader
addJar(String) - Method in class com.hazelcast.jet.config.JobConfig
Add JAR to the job classLoader
addJar(String, String) - Method in class com.hazelcast.jet.config.JobConfig
Add JAR to the job classLoader
addResource(URL) - Method in class com.hazelcast.jet.config.JobConfig
Add resource to the job classLoader
addResource(URL, String) - Method in class com.hazelcast.jet.config.JobConfig
Add resource to the job classLoader
addResource(File) - Method in class com.hazelcast.jet.config.JobConfig
Add resource to the job classLoader
addResource(File, String) - Method in class com.hazelcast.jet.config.JobConfig
Add resource to the job classLoader
addResource(String) - Method in class com.hazelcast.jet.config.JobConfig
Add resource to the job classLoader
addResource(String, String) - Method in class com.hazelcast.jet.config.JobConfig
Add resource to the job classLoader
allMatch(Distributed.DoublePredicate) - 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(Distributed.IntPredicate) - 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(Distributed.LongPredicate) - 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(Distributed.Predicate<? 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
 
allToOne() - Method in class com.hazelcast.jet.Edge
Activates a special-cased PARTITIONED forwarding pattern where all items will be assigned the same, randomly chosen partition ID.
and(Distributed.BiPredicate<? super T, ? super U>) - Method in interface com.hazelcast.jet.Distributed.BiPredicate
Returns a composed predicate that represents a short-circuiting logical AND of this predicate and another.
and(Distributed.DoublePredicate) - Method in interface com.hazelcast.jet.Distributed.DoublePredicate
Returns a composed predicate that represents a short-circuiting logical AND of this predicate and another.
and(Distributed.IntPredicate) - Method in interface com.hazelcast.jet.Distributed.IntPredicate
Returns a composed predicate that represents a short-circuiting logical AND of this predicate and another.
and(Distributed.LongPredicate) - Method in interface com.hazelcast.jet.Distributed.LongPredicate
Returns a composed predicate that represents a short-circuiting logical AND of this predicate and another.
and(Distributed.Predicate<? super T>) - Method in interface com.hazelcast.jet.Distributed.Predicate
Returns a composed predicate that represents a short-circuiting logical AND of this predicate and another.
andThen(Distributed.BiConsumer<? super T, ? super U>) - Method in interface com.hazelcast.jet.Distributed.BiConsumer
Returns a composed BiConsumer that performs, in sequence, this operation followed by the after operation.
andThen(Distributed.Function<? super R, ? extends V>) - Method in interface com.hazelcast.jet.Distributed.BiFunction
Returns a composed function that first applies this function to its input, and then applies the after function to the result.
andThen(Distributed.Consumer<? super T>) - Method in interface com.hazelcast.jet.Distributed.Consumer
Returns a composed Consumer that performs, in sequence, this operation followed by the after operation.
andThen(Distributed.DoubleConsumer) - Method in interface com.hazelcast.jet.Distributed.DoubleConsumer
Returns a composed DoubleConsumer that performs, in sequence, this operation followed by the after operation.
andThen(Distributed.DoubleUnaryOperator) - Method in interface com.hazelcast.jet.Distributed.DoubleUnaryOperator
Returns a composed operator that first applies this operator to its input, and then applies the after operator to the result.
andThen(Distributed.Function<? super R, ? extends V>) - Method in interface com.hazelcast.jet.Distributed.Function
Returns a composed function that first applies this function to its input, and then applies the after function to the result.
andThen(Distributed.IntConsumer) - Method in interface com.hazelcast.jet.Distributed.IntConsumer
Returns a composed IntConsumer that performs, in sequence, this operation followed by the after operation.
andThen(Distributed.IntUnaryOperator) - Method in interface com.hazelcast.jet.Distributed.IntUnaryOperator
Returns a composed operator that first applies this operator to its input, and then applies the after operator to the result.
andThen(Distributed.LongConsumer) - Method in interface com.hazelcast.jet.Distributed.LongConsumer
Returns a composed LongConsumer that performs, in sequence, this operation followed by the after operation.
andThen(Distributed.LongUnaryOperator) - Method in interface com.hazelcast.jet.Distributed.LongUnaryOperator
Returns a composed operator that first applies this operator to its input, and then applies the after operator to the result.
anyMatch(Distributed.DoublePredicate) - 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(Distributed.IntPredicate) - 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(Distributed.LongPredicate) - 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(Distributed.Predicate<? 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
 
apply(T, U) - Method in interface com.hazelcast.jet.Distributed.BiFunction
 
apply(T) - Method in interface com.hazelcast.jet.Distributed.Function
 
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(Distributed.ToDoubleFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector that produces the arithmetic mean of a double-valued function applied to the input elements.
averagingInt(Distributed.ToIntFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector that produces the arithmetic mean of an integer-valued function applied to the input elements.
averagingLong(Distributed.ToLongFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector that produces the arithmetic mean of a long-valued function applied to the input elements.

B

between(Vertex, Vertex) - Static method in class com.hazelcast.jet.Edge
Returns an edge between two vertices.
boxed() - Method in interface com.hazelcast.jet.stream.DistributedDoubleStream
Returns a DistributedStream consisting of the elements of this stream, boxed to Double.
boxed() - Method in interface com.hazelcast.jet.stream.DistributedIntStream
Returns a Stream consisting of the elements of this stream, each boxed to an Integer.
boxed() - Method in interface com.hazelcast.jet.stream.DistributedLongStream
Returns a Stream consisting of the elements of this stream, each boxed to a Long.
broadcast() - Method in class com.hazelcast.jet.Edge
Activates the BROADCAST forwarding pattern.
bucketCount() - Method in interface com.hazelcast.jet.Outbox
Returns the number of buckets in this outbox.
buffered() - Method in class com.hazelcast.jet.Edge
Activates unbounded buffering on this edge.

C

collect(Distributed.Supplier<? extends A>, Distributed.BiConsumer<? super A, ? super T>, Distributed.Function<? super A, ? extends R>) - Static method in class com.hazelcast.jet.Processors
Returns a supplier of processor with the following semantics: Calls the supplier function to obtain the mutable result container.
collect(Distributed.Supplier<? extends A>, Distributed.BiConsumer<? super A, ? super T>) - Static method in class com.hazelcast.jet.Processors
Convenience over collect(supplier, collector, finisher) with identity function as the finisher, which means the processor emits an item of type A.
collect(StreamContext, Pipeline<? extends T>) - Method in interface com.hazelcast.jet.stream.DistributedCollector
Executes the collector with the given context and upstream pipeline.
collect(Distributed.Supplier<R>, Distributed.ObjDoubleConsumer<R>, Distributed.BiConsumer<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(Distributed.Supplier<R>, Distributed.ObjIntConsumer<R>, Distributed.BiConsumer<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(Distributed.Supplier<R>, Distributed.ObjLongConsumer<R>, Distributed.BiConsumer<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(Distributed.Supplier<R>, Distributed.BiConsumer<R, ? super T>, Distributed.BiConsumer<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 Distributed.Collector.
collect(Supplier<R>, BiConsumer<R, ? super T>, BiConsumer<R, R>) - Method in interface com.hazelcast.jet.stream.DistributedStream
 
collect(Collector<? super T, A, R>) - Method in interface com.hazelcast.jet.stream.DistributedStream
 
collectingAndThen(DistributedCollector<T, A, R>, Distributed.Function<R, RR>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Adapts a Distributed.Collector to perform an additional finishing transformation.
com.hazelcast.jet - package com.hazelcast.jet
Hazelcast Jet is a distributed computation engine.
com.hazelcast.jet.config - package com.hazelcast.jet.config
Jet's configuration data objects.
com.hazelcast.jet.server - package com.hazelcast.jet.server
Util class for starting a server instance
com.hazelcast.jet.stream - package com.hazelcast.jet.stream
java.util.stream implementation using Hazelcast Jet
combiner() - Method in interface com.hazelcast.jet.stream.DistributedCollector
A function that accepts two partial results and merges them.
comparing(Function<? super T, ? extends U>, Comparator<? super U>) - Static method in interface com.hazelcast.jet.Distributed.Comparator
 
comparing(Distributed.Function<? super T, ? extends U>, Distributed.Comparator<? super U>) - Static method in interface com.hazelcast.jet.Distributed.Comparator
 
comparing(Function<? super T, ? extends U>) - Static method in interface com.hazelcast.jet.Distributed.Comparator
 
comparing(Distributed.Function<? super T, ? extends U>) - Static method in interface com.hazelcast.jet.Distributed.Comparator
 
comparingDouble(ToDoubleFunction<? super T>) - Static method in interface com.hazelcast.jet.Distributed.Comparator
 
comparingDouble(Distributed.ToDoubleFunction<? super T>) - Static method in interface com.hazelcast.jet.Distributed.Comparator
 
comparingInt(ToIntFunction<? super T>) - Static method in interface com.hazelcast.jet.Distributed.Comparator
 
comparingInt(Distributed.ToIntFunction<? super T>) - Static method in interface com.hazelcast.jet.Distributed.Comparator
 
comparingLong(ToLongFunction<? super T>) - Static method in interface com.hazelcast.jet.Distributed.Comparator
 
comparingLong(Distributed.ToLongFunction<? super T>) - Static method in interface com.hazelcast.jet.Distributed.Comparator
 
complete() - Method in interface com.hazelcast.jet.Processor
Called after all the inputs are exhausted.
complete(Throwable) - Method in interface com.hazelcast.jet.ProcessorSupplier
Called after execution is finished on all the nodes, whether successfully or not.
completeEdge(int) - Method in interface com.hazelcast.jet.Processor
Called after the edge input with the supplied ordinal is exhausted.
compose(Distributed.DoubleUnaryOperator) - Method in interface com.hazelcast.jet.Distributed.DoubleUnaryOperator
Returns a composed operator that first applies the before operator to its input, and then applies this operator to the result.
compose(Distributed.Function<? super V, ? extends T>) - Method in interface com.hazelcast.jet.Distributed.Function
Returns a composed function that first applies the before function to its input, and then applies this function to the result.
compose(Distributed.IntUnaryOperator) - Method in interface com.hazelcast.jet.Distributed.IntUnaryOperator
Returns a composed operator that first applies the before operator to its input, and then applies this operator to the result.
compose(Distributed.LongUnaryOperator) - Method in interface com.hazelcast.jet.Distributed.LongUnaryOperator
Returns a composed operator that first applies the before operator to its input, and then applies this operator to the result.
countDistinct(Distributed.Function<T, K>) - Static method in class com.hazelcast.jet.Processors
Returns a supplier of CountDistinctP processors.
countDistinct() - Static method in class com.hazelcast.jet.Processors
Convenience over Processors.countDistinct(Distributed.Function) with identity function as the key extractor, which means the processor will emit the number of distinct items it has seen in the input.
counting() - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector accepting elements of type T that counts the number of input elements.

D

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
 
DEFAULT_FLOW_CONTROL_PERIOD_MS - Static variable in class com.hazelcast.jet.config.InstanceConfig
The default value of the flow-control period.
DEFAULT_HIGH_WATER_MARK - Static variable in class com.hazelcast.jet.config.EdgeConfig
The default value of the high water mark.
DEFAULT_JET_MULTICAST_PORT - Static variable in class com.hazelcast.jet.config.JetConfig
The default port number for the cluster auto-discovery mechanism's multicast communication.
DEFAULT_PACKET_SIZE_LIMIT - Static variable in class com.hazelcast.jet.config.EdgeConfig
The default packet size limit.
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.
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 - Class in com.hazelcast.jet
Utility class with serializable versions of java.util.function interfaces.
distributed() - Method in class com.hazelcast.jet.Edge
Declares that the edge is distributed.
Distributed.BiConsumer<T,U> - Interface in com.hazelcast.jet
Represents an operation that accepts two input arguments and returns no result.
Distributed.BiFunction<T,U,R> - Interface in com.hazelcast.jet
Represents a function that accepts two arguments and produces a result.
Distributed.BinaryOperator<T> - Interface in com.hazelcast.jet
Represents an operation upon two operands of the same type, producing a result of the same type as the operands.
Distributed.BiPredicate<T,U> - Interface in com.hazelcast.jet
Represents a predicate (boolean-valued function) of two arguments.
Distributed.BooleanSupplier - Interface in com.hazelcast.jet
Represents a supplier of boolean-valued results.
Distributed.Comparator<T> - Interface in com.hazelcast.jet
A comparison function, which imposes a total ordering on some collection of objects.
Distributed.Consumer<T> - Interface in com.hazelcast.jet
Represents an operation that accepts a single input argument and returns no result.
Distributed.DoubleBinaryOperator - Interface in com.hazelcast.jet
Represents an operation upon two double-valued operands and producing a double-valued result.
Distributed.DoubleConsumer - Interface in com.hazelcast.jet
Represents an operation that accepts a single double-valued argument and returns no result.
Distributed.DoubleFunction<R> - Interface in com.hazelcast.jet
Represents a function that accepts a double-valued argument and produces a result.
Distributed.DoublePredicate - Interface in com.hazelcast.jet
Represents a predicate (boolean-valued function) of one double-valued argument.
Distributed.DoubleToIntFunction - Interface in com.hazelcast.jet
Represents a function that accepts a double-valued argument and produces an int-valued result.
Distributed.DoubleToLongFunction - Interface in com.hazelcast.jet
Represents a function that accepts a double-valued argument and produces a long-valued result.
Distributed.DoubleUnaryOperator - Interface in com.hazelcast.jet
Represents an operation on a single double-valued operand that produces a double-valued result.
Distributed.Function<T,R> - Interface in com.hazelcast.jet
Represents a function that accepts one argument and produces a result.
Distributed.IntBinaryOperator - Interface in com.hazelcast.jet
Represents an operation upon two int-valued operands and producing an int-valued result.
Distributed.IntConsumer - Interface in com.hazelcast.jet
Represents an operation that accepts a single int-valued argument and returns no result.
Distributed.IntFunction<R> - Interface in com.hazelcast.jet
Represents a function that accepts an int-valued argument and produces a result.
Distributed.IntPredicate - Interface in com.hazelcast.jet
Represents a predicate (boolean-valued function) of one int-valued argument.
Distributed.IntToDoubleFunction - Interface in com.hazelcast.jet
Represents a function that accepts an int-valued argument and produces a double-valued result.
Distributed.IntToLongFunction - Interface in com.hazelcast.jet
Represents a function that accepts an int-valued argument and produces a long-valued result.
Distributed.IntUnaryOperator - Interface in com.hazelcast.jet
Represents an operation on a single int-valued operand that produces an int-valued result.
Distributed.LongBinaryOperator - Interface in com.hazelcast.jet
Represents an operation upon two long-valued operands and producing a long-valued result.
Distributed.LongConsumer - Interface in com.hazelcast.jet
Represents an operation that accepts a single long-valued argument and returns no result.
Distributed.LongFunction<R> - Interface in com.hazelcast.jet
Represents a function that accepts a long-valued argument and produces a result.
Distributed.LongPredicate - Interface in com.hazelcast.jet
Represents a predicate (boolean-valued function) of one long-valued argument.
Distributed.LongToDoubleFunction - Interface in com.hazelcast.jet
Represents a function that accepts a long-valued argument and produces a double-valued result.
Distributed.LongToIntFunction - Interface in com.hazelcast.jet
Represents a function that accepts a long-valued argument and produces an int-valued result.
Distributed.LongUnaryOperator - Interface in com.hazelcast.jet
Represents an operation on a single long-valued operand that produces a long-valued result.
Distributed.ObjDoubleConsumer<T> - Interface in com.hazelcast.jet
Represents an operation that accepts an object-valued and a double-valued argument, and returns no result.
Distributed.ObjIntConsumer<T> - Interface in com.hazelcast.jet
Represents an operation that accepts an object-valued and a int-valued argument, and returns no result.
Distributed.ObjLongConsumer<T> - Interface in com.hazelcast.jet
Represents an operation that accepts an object-valued and a long-valued argument, and returns no result.
Distributed.Optional<T> - Class in com.hazelcast.jet
A container object which may or may not contain a non-null value.
Distributed.Predicate<T> - Interface in com.hazelcast.jet
Represents a predicate (boolean-valued function) of one argument.
Distributed.Supplier<T> - Interface in com.hazelcast.jet
Represents a supplier of results.
Distributed.ToDoubleBiFunction<T,U> - Interface in com.hazelcast.jet
Represents a function that accepts two arguments and produces a double-valued result.
Distributed.ToDoubleFunction<T> - Interface in com.hazelcast.jet
Represents a function that produces a double-valued result.
Distributed.ToIntBiFunction<T,U> - Interface in com.hazelcast.jet
Represents a function that accepts two arguments and produces an int-valued result.
Distributed.ToIntFunction<T> - Interface in com.hazelcast.jet
Represents a function that produces an int-valued result.
Distributed.ToLongBiFunction<T,U> - Interface in com.hazelcast.jet
Represents a function that accepts two arguments and produces a long-valued result.
Distributed.ToLongFunction<T> - Interface in com.hazelcast.jet
Represents a function that produces a long-valued result.
Distributed.UnaryOperator<T> - Interface in com.hazelcast.jet
Represents an operation on a single operand that produces a result of the same type as its operand.
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.
DistributedCollectors - Class in com.hazelcast.jet.stream
Distributed implementations of Collectors
DistributedCollectors() - Constructor for class com.hazelcast.jet.stream.DistributedCollectors
 
DistributedDoubleStream - Interface in com.hazelcast.jet.stream
An extension of DoubleStream to support distributed stream operations by replacing functional interfaces with their serializable equivalents.
DistributedIntStream - Interface in com.hazelcast.jet.stream
An extension of IntStream to support distributed stream operations by replacing functional interfaces with their serializable equivalents.
DistributedLongStream - Interface in com.hazelcast.jet.stream
An extension of LongStream to support distributed stream operations by replacing functional interfaces with their serializable equivalents.
DistributedStream<T> - Interface in com.hazelcast.jet.stream
An extension of Stream to support distributed stream operations by replacing functional interfaces with their serializable equivalents.
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.
drainTo(Collection<E>) - Method in interface com.hazelcast.jet.Inbox
Drains all elements into the provided Collection.

E

edge(Edge) - Method in class com.hazelcast.jet.DAG
Adds an edge to this DAG.
Edge - Class in com.hazelcast.jet
Represents an edge between two vertices in a DAG.
Edge.ForwardingPattern - Enum in com.hazelcast.jet
Enumerates the supported patterns of forwarding data items along an edge.
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
Emits the item to the outbox bucket at the supplied ordinal.
emit(Object) - Method in class com.hazelcast.jet.AbstractProcessor
Emits the item to all the outbox buckets.
emitCooperatively(int, Traverser<?>) - Method in class com.hazelcast.jet.AbstractProcessor
Emits the items obtained from the traverser to the outbox bucket with the supplied ordinal, in a cooperative fashion: if the outbox reports a high-water condition, backs off and returns false.
emitCooperatively(Traverser<?>) - Method in class com.hazelcast.jet.AbstractProcessor
Convenience for AbstractProcessor.emitCooperatively(int, Traverser) which emits to all ordinals.
empty() - Static method in class com.hazelcast.jet.Distributed.Optional
Returns an empty Optional instance.
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.KeyExtractors
Extractor that returns the key 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.Distributed.Optional
Indicates whether some other object is "equal to" this Optional.
equals(Object) - Method in class com.hazelcast.jet.Edge
 
execute() - Method in interface com.hazelcast.jet.Job
Executes the job.

F

filter(Distributed.Predicate<? super T>) - Method in class com.hazelcast.jet.Distributed.Optional
If a value is present, and the value matches the given predicate, return an Optional describing the value, otherwise return an empty Optional.
filter(Distributed.Predicate<? super T>) - Static method in class com.hazelcast.jet.Processors
Returns a supplier of processor which emits the same items it receives, but only those that pass the given predicate.
filter(Distributed.DoublePredicate) - 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(Distributed.IntPredicate) - 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(Distributed.LongPredicate) - 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(Distributed.Predicate<? 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.
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(Distributed.Function<? super T, Distributed.Optional<U>>) - Method in class com.hazelcast.jet.Distributed.Optional
If a value is present, apply the provided Optional-bearing mapping function to it, return that result, otherwise return an empty Optional.
flatMap(Distributed.Function<? super T, ? extends Traverser<? extends R>>) - Static method in class com.hazelcast.jet.Processors
Returns a supplier of TransformP processor with the given item-to-traverser function.
flatMap(Distributed.DoubleFunction<? 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(Distributed.IntFunction<? 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(Distributed.LongFunction<? 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(Distributed.Function<? 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
flatMapToDouble(Distributed.Function<? 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(Distributed.Function<? 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(Distributed.Function<? 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
 
forEach(Distributed.DoubleConsumer) - 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
 
forEach(Distributed.IntConsumer) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
Performs an action for each element of this stream.
forEach(IntConsumer) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
 
forEach(Distributed.LongConsumer) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
Performs an action for each element of this stream.
forEach(LongConsumer) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
 
forEach(Distributed.Consumer<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
Performs an action for each element of this stream.
forEach(Consumer<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
 
forEachOrdered(Distributed.DoubleConsumer) - 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
 
forEachOrdered(Distributed.IntConsumer) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
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(IntConsumer) - Method in interface com.hazelcast.jet.stream.DistributedIntStream
 
forEachOrdered(Distributed.LongConsumer) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
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(LongConsumer) - Method in interface com.hazelcast.jet.stream.DistributedLongStream
 
forEachOrdered(Distributed.Consumer<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
Performs an action for each element of this stream, in the encounter order of the stream if the stream has a defined encounter order.
forEachOrdered(Consumer<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
 
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.

G

get() - Method in class com.hazelcast.jet.Distributed.Optional
If a value is present in this Optional, returns the value, otherwise throws NoSuchElementException.
get() - Method in interface com.hazelcast.jet.Distributed.Supplier
 
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
Called after ProcessorSupplier.init(Context) to retrieve instances of Processor that will be used during the execution of the Jet job.
getCluster() - Method in interface com.hazelcast.jet.JetInstance
Returns information about the cluster that 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.
getDefaultEdgeConfig() - Method in class com.hazelcast.jet.config.JetConfig
Returns the default DAG edge configuration.
getDescriptor() - Method in class com.hazelcast.jet.config.ResourceConfig
Returns the ResourceDescriptor for the resource.
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.
getFactoryId() - Method in class com.hazelcast.jet.DAG
 
getFactoryId() - Method in class com.hazelcast.jet.Edge
 
getFactoryId() - Method in class com.hazelcast.jet.Vertex
 
getFlowControlPeriodMs() - Method in class com.hazelcast.jet.config.InstanceConfig
Returns the flow-control period in milliseconds.
getForwardingPattern() - Method in class com.hazelcast.jet.Edge
Returns the Edge.ForwardingPattern in effect on the edge.
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.
getHighWaterMark() - Method in class com.hazelcast.jet.config.EdgeConfig
Returns the high water mark that will be set on the bucket of Outbox corresponding to this edge.
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.
getInstanceConfig() - Method in class com.hazelcast.jet.config.JetConfig
Returns the Jet instance config.
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.
getOutbox() - Method in class com.hazelcast.jet.AbstractProcessor
Returns the outbox received in the init() method call.
getPacketSizeLimit() - Method in class com.hazelcast.jet.config.EdgeConfig
Returns the limit on the network packet size, in bytes
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
Returns the value of edge's priority, as explained on Edge.priority(int).
getProperties() - Method in class com.hazelcast.jet.config.JetConfig
Returns the Jet-specific configuration properties.
getProperties() - Method in class com.hazelcast.jet.config.JobConfig
 
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 deployment configurations
getResourcePartSize() - Method in class com.hazelcast.jet.config.JobConfig
Javadoc pending
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.
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.
getUrl() - Method in class com.hazelcast.jet.config.ResourceConfig
Returns the URL at which the resource will be available.
getVertex(String) - Method in class com.hazelcast.jet.DAG
Returns the vertex with the given name.
groupAndAccumulate(Distributed.Function<? super T, ? extends K>, Distributed.Supplier<? extends A>, Distributed.BiFunction<? super A, ? super T, ? extends A>, Distributed.BiFunction<? super K, ? super A, ? extends R>) - Static method in class com.hazelcast.jet.Processors
Returns a supplier of processor with the following semantics: Accepts items of type T.
groupAndAccumulate(Distributed.Function<? super T, ?>, Distributed.Supplier<? extends A>, Distributed.BiFunction<? super A, ? super T, ? extends A>) - Static method in class com.hazelcast.jet.Processors
Convenience over groupAndAccumulate(keyExtractor, supplier, accumulator, finisher) with the constructor of SimpleImmutableEntry as the finisher function, which means the processor emits items of type java.util.Map.Entry<K, A>.
groupAndAccumulate(Distributed.Supplier<? extends A>, Distributed.BiFunction<? super A, ? super T, ? extends A>) - Static method in class com.hazelcast.jet.Processors
Convenience over groupAndAccumulate(keyExtractor, supplier, accumulator, finisher) with identity function as the key extractor and constructor of SimpleImmutableEntry as the finisher function, which means the processor emits items of type java.util.Map.Entry<T, A>.
groupAndCollect(Distributed.Function<? super T, ? extends K>, Distributed.Supplier<? extends A>, Distributed.BiConsumer<? super A, ? super T>, Distributed.BiFunction<? super K, ? super A, ? extends R>) - Static method in class com.hazelcast.jet.Processors
Returns a supplier of processor with the following semantics: Accepts items of type T.
groupAndCollect(Distributed.Function<? super T, ?>, Distributed.Supplier<? extends A>, Distributed.BiConsumer<? super A, ? super T>) - Static method in class com.hazelcast.jet.Processors
Convenience over groupAndCollect(keyExtractor, supplier, collector, finisher) with the constructor of SimpleImmutableEntry as the finisher function, which means the processor emits items of type java.util.Map.Entry<K, A>.
groupAndCollect(Distributed.Supplier<? extends A>, Distributed.BiConsumer<? super A, ? super T>) - Static method in class com.hazelcast.jet.Processors
Convenience over groupAndCollect(keyExtractor, supplier, collector, finisher) with identity function as the key extractor and constructor of SimpleImmutableEntry as the finisher function, which means the processor emits items of type java.util.Map.Entry<T, A>.
groupingBy(Distributed.Function<? super T, ? extends K>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector 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(Distributed.Function<? super T, ? extends K>, DistributedCollector<? super T, A, D>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector 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 Distributed.Collector.
groupingBy(Distributed.Function<? super T, ? extends K>, Distributed.Supplier<M>, DistributedCollector<? super T, A, D>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector 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 Distributed.Collector.
groupingByToIMap(Distributed.Function<? super T, ? extends K>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector 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(Distributed.Function<? super T, ? extends K>, DistributedCollector<? super T, A, D>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector 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 Distributed.Collector.

H

HASH_CODE - Static variable in interface com.hazelcast.jet.Partitioner
Partitioner which calls Object.hashCode() and coerces it with the modulo operation into the allowed range of partition IDs.
hashCode() - Method in class com.hazelcast.jet.Distributed.Optional
Returns the hash code value of the present value, if any, or 0 (zero) if no value is present.
hashCode() - Method in class com.hazelcast.jet.Edge
 

I

identity() - Static method in interface com.hazelcast.jet.Distributed.DoubleUnaryOperator
Returns a unary operator that always returns its input argument.
identity() - Static method in interface com.hazelcast.jet.Distributed.Function
Returns a function that always returns its input argument.
identity() - Static method in interface com.hazelcast.jet.Distributed.IntUnaryOperator
Returns a unary operator that always returns its input argument.
identity() - Static method in interface com.hazelcast.jet.Distributed.LongUnaryOperator
Returns a unary operator that always returns its input argument.
identity() - Static method in interface com.hazelcast.jet.Distributed.UnaryOperator
Returns a unary operator that always returns its input argument.
ifPresent(Distributed.Consumer<? super T>) - Method in class com.hazelcast.jet.Distributed.Optional
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.
index() - Method in interface com.hazelcast.jet.Processor.Context
Returns the index of the current processor among all the processors created for this vertex on this node.
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
Callback that injects the Hazelcast's default partitioning strategy into this partitioner so it can be consulted by the Partitioner.getPartition(Object, int) method.
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.
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
Returns whether unbounded buffering is activated for this edge.
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.Distributed.Predicate
Returns a predicate that tests if two arguments are equal according to Objects.equals(Object, Object).
isHighWater() - Method in interface com.hazelcast.jet.Outbox
Returns true if any of this outbox's buckets is above its high water mark (i.e., Outbox.isHighWater(int) would return true for it).
isHighWater(int) - Method in interface com.hazelcast.jet.Outbox
Returns true if the bucket with the given ordinal is above its high water mark.
isPresent() - Method in class com.hazelcast.jet.Distributed.Optional
Return true if there is a value present, otherwise false.
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.
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 reverse topological order.

J

Jet - Class in com.hazelcast.jet
Entry point to the Jet product.
JetConfig - Class in com.hazelcast.jet.config
Configuration object for a Jet instance.
JetConfig() - Constructor for class com.hazelcast.jet.config.JetConfig
 
JetException - Exception in com.hazelcast.jet
Base Jet exception.
JetException() - Constructor for exception com.hazelcast.jet.JetException
 
JetException(String) - Constructor for exception com.hazelcast.jet.JetException
 
JetException(String, Throwable) - Constructor for exception com.hazelcast.jet.JetException
 
JetException(Throwable) - Constructor for exception com.hazelcast.jet.JetException
 
JetInstance - Interface in com.hazelcast.jet
Main entry point for interacting with a Jet cluster.
jetInstance() - Method in interface com.hazelcast.jet.Processor.Context
Returns the current Jet instance
jetInstance() - Method in interface com.hazelcast.jet.ProcessorMetaSupplier.Context
Returns the current Jet instance.
jetInstance() - Method in interface com.hazelcast.jet.ProcessorSupplier.Context
Returns the current Jet instance
Job - Interface in com.hazelcast.jet
A Jet computation job created from a DAG, ready to be executed.
JobConfig - Class in com.hazelcast.jet.config
Javadoc pending.
JobConfig() - Constructor for class com.hazelcast.jet.config.JobConfig
 
joining() - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector that concatenates the input elements into a String, in encounter order.
joining(CharSequence) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector that concatenates the input elements, separated by the specified delimiter, in encounter order.
joining(CharSequence, CharSequence, CharSequence) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector that concatenates the input elements, separated by the specified delimiter, with the specified prefix and suffix, in encounter order.

K

KeyExtractors - Class in com.hazelcast.jet
Factory methods for several common key extractor functions, to be used in Edge.partitioned(...) calls.

L

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
 
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(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

M

main(String[]) - Static method in class com.hazelcast.jet.server.StartServer
Creates a server instance of Hazelcast.
map(Distributed.Function<? super T, ? extends U>) - Method in class com.hazelcast.jet.Distributed.Optional
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(Distributed.Function<? super T, ? extends R>) - Static method in class com.hazelcast.jet.Processors
Returns a supplier of processor which, for each received item, emits the result of applying the given mapping function to it.
map(Distributed.DoubleUnaryOperator) - 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(Distributed.IntUnaryOperator) - 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(Distributed.LongUnaryOperator) - 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(Distributed.Function<? 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(Distributed.Function<? super T, ? extends U>, DistributedCollector<? super U, A, R>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Adapts a Distributed.Collector accepting elements of type U to one accepting elements of type T by applying a mapping function to each input element before accumulation.
mapToDouble(Distributed.IntToDoubleFunction) - 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(Distributed.LongToDoubleFunction) - 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(Distributed.ToDoubleFunction<? 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(Distributed.DoubleToIntFunction) - 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(Distributed.LongToIntFunction) - 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(Distributed.ToIntFunction<? 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(Distributed.DoubleToLongFunction) - 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(Distributed.IntToLongFunction) - 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(Distributed.ToLongFunction<? 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(Distributed.DoubleFunction<? 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(Distributed.IntFunction<? 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(Distributed.LongFunction<? 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(Distributed.Comparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
Returns the maximum element of this stream according to the provided Distributed.Comparator.
max(Comparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
 
maxBy(Comparator<? super T>) - Static method in interface com.hazelcast.jet.Distributed.BinaryOperator
Returns a Distributed.BinaryOperator which returns the greater of two elements according to the specified Comparator.
maxBy(Distributed.Comparator<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector that produces the maximal element according to a given Distributed.Comparator, described as an Optional<T>.
min(Distributed.Comparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
Returns the minimum element of this stream according to the provided Distributed.Comparator.
min(Comparator<? super T>) - Method in interface com.hazelcast.jet.stream.DistributedStream
 
minBy(Comparator<? super T>) - Static method in interface com.hazelcast.jet.Distributed.BinaryOperator
Returns a Distributed.BinaryOperator which returns the lesser of two elements according to the specified Comparator.
minBy(Distributed.Comparator<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector that produces the minimal element according to a given Distributed.Comparator, described as an Optional<T>.

N

naturalOrder() - Static method in interface com.hazelcast.jet.Distributed.Comparator
Returns a comparator that compares Comparable objects in natural order.
negate() - Method in interface com.hazelcast.jet.Distributed.BiPredicate
Returns a predicate that represents the logical negation of this predicate.
negate() - Method in interface com.hazelcast.jet.Distributed.DoublePredicate
Returns a predicate that represents the logical negation of this predicate.
negate() - Method in interface com.hazelcast.jet.Distributed.IntPredicate
Returns a predicate that represents the logical negation of this predicate.
negate() - Method in interface com.hazelcast.jet.Distributed.LongPredicate
Returns a predicate that represents the logical negation of this predicate.
negate() - Method in interface com.hazelcast.jet.Distributed.Predicate
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 a given DAG with a job specific configuration.
newVertex(String, Distributed.Supplier<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 interface com.hazelcast.jet.Traverser
Returns the next item in the sequence, or null if the sequence is already exhausted
noneMatch(Distributed.DoublePredicate) - 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(Distributed.IntPredicate) - 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(Distributed.LongPredicate) - 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(Distributed.Predicate<? 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
 
NoopP() - Constructor for class com.hazelcast.jet.Processors.NoopP
 
nullsFirst(Comparator<? super T>) - Static method in interface com.hazelcast.jet.Distributed.Comparator
 
nullsFirst(Distributed.Comparator<? super T>) - Static method in interface com.hazelcast.jet.Distributed.Comparator
 
nullsLast(Comparator<? super T>) - Static method in interface com.hazelcast.jet.Distributed.Comparator
 
nullsLast(Distributed.Comparator<? super T>) - Static method in interface com.hazelcast.jet.Distributed.Comparator
 

O

of(T) - Static method in class com.hazelcast.jet.Distributed.Optional
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(Distributed.Supplier<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(Distributed.Function<Address, ProcessorSupplier>) - Static method in interface com.hazelcast.jet.ProcessorMetaSupplier
Factory method that creates a ProcessorMetaSupplier based on a mapping to ProcessorSupplier for each given address
of(Distributed.Supplier<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(Distributed.Supplier<R>, Distributed.BiConsumer<R, T>, Distributed.BinaryOperator<R>, Collector.Characteristics...) - Static method in interface com.hazelcast.jet.stream.DistributedCollector
Returns a new Distributed.Collector described by the given supplier, accumulator, and combiner functions.
of(Distributed.Supplier<A>, Distributed.BiConsumer<A, T>, Distributed.BinaryOperator<A>, Distributed.Function<A, R>, Collector.Characteristics...) - Static method in interface com.hazelcast.jet.stream.DistributedCollector
Returns a new Distributed.Collector described by the given supplier, accumulator, combiner, and finisher functions.
ofNullable(T) - Static method in class com.hazelcast.jet.Distributed.Optional
Returns an Optional describing the specified value, if non-null, otherwise returns an empty Optional.
or(Distributed.BiPredicate<? super T, ? super U>) - Method in interface com.hazelcast.jet.Distributed.BiPredicate
Returns a composed predicate that represents a short-circuiting logical OR of this predicate and another.
or(Distributed.DoublePredicate) - Method in interface com.hazelcast.jet.Distributed.DoublePredicate
Returns a composed predicate that represents a short-circuiting logical OR of this predicate and another.
or(Distributed.IntPredicate) - Method in interface com.hazelcast.jet.Distributed.IntPredicate
Returns a composed predicate that represents a short-circuiting logical OR of this predicate and another.
or(Distributed.LongPredicate) - Method in interface com.hazelcast.jet.Distributed.LongPredicate
Returns a composed predicate that represents a short-circuiting logical OR of this predicate and another.
or(Distributed.Predicate<? super T>) - Method in interface com.hazelcast.jet.Distributed.Predicate
Returns a composed predicate that represents a short-circuiting logical OR of this predicate and another.
orElse(T) - Method in class com.hazelcast.jet.Distributed.Optional
Return the value if present, otherwise return other.
orElseGet(Distributed.Supplier<? extends T>) - Method in class com.hazelcast.jet.Distributed.Optional
Return the value if present, otherwise invoke other and return the result of that invocation.
orElseThrow(Distributed.Supplier<? extends X>) - Method in class com.hazelcast.jet.Distributed.Optional
Return the contained value, if present, otherwise throw an exception to be created by the provided supplier.
Outbox - Interface in com.hazelcast.jet
Single-threaded object which acts as a data sink for a Processor.
over(T...) - Static method in interface com.hazelcast.jet.Traverser
Returns a traverser over the supplied arguments (or item array).

P

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(Distributed.Function<T, ?>) - Method in class com.hazelcast.jet.Edge
Activates the PARTITIONED forwarding pattern and applies the default Hazelcast partitioning strategy.
partitioned(Distributed.Function<T, K>, Partitioner<? super K>) - Method in class com.hazelcast.jet.Edge
Activates the PARTITIONED forwarding pattern 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(Distributed.Predicate<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector which partitions the input elements according to a Distributed.Predicate, and organizes them into a Map<Boolean, List<T>>.
partitioningBy(Distributed.Predicate<? super T>, DistributedCollector<? super T, A, D>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector which partitions the input elements according to a Distributed.Predicate, reduces the values in each partition according to another Distributed.Collector, 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(Distributed.DoubleConsumer) - 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(Distributed.IntConsumer) - 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(Distributed.LongConsumer) - 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(Distributed.Consumer<? 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
 
poll() - Method in interface com.hazelcast.jet.Inbox
Retrieves and removes the head of this inbox, or returns null if it is empty.
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
Processes some items in the supplied inbox.
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.
ProcessorMetaSupplier - Interface in com.hazelcast.jet
Factory of ProcessorSupplier instances.
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
Static utility class with factory methods for predefined processors.
Processors.NoopP - Class in com.hazelcast.jet
A processor that does nothing.
ProcessorSupplier - Interface in com.hazelcast.jet
Factory of Processor instances.
ProcessorSupplier.Context - Interface in com.hazelcast.jet
Context passed to the supplier in the init() call.

R

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
 
readList(String) - Static method in class com.hazelcast.jet.Processors
Returns a meta-supplier of processors that emit items retrieved from an IMDG IList.
readList(String, ClientConfig) - Static method in class com.hazelcast.jet.Processors
Returns a meta-supplier of processors that emit items retrieved from an IMDG IList in a remote cluster.
readMap(String) - Static method in class com.hazelcast.jet.Processors
Returns a meta-supplier of processors that will fetch entries from the Hazelcast IMap with the specified name.
readMap(String, ClientConfig) - Static method in class com.hazelcast.jet.Processors
Returns a meta-supplier of processors that will fetch entries from a Hazelcast IMap in a remote cluster.
reduce(double, Distributed.DoubleBinaryOperator) - 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(Distributed.DoubleBinaryOperator) - 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, Distributed.IntBinaryOperator) - 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(Distributed.IntBinaryOperator) - 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, Distributed.LongBinaryOperator) - 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(Distributed.LongBinaryOperator) - 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, Distributed.BinaryOperator<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(Distributed.BinaryOperator<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, Distributed.BiFunction<U, ? super T, U>, Distributed.BinaryOperator<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(T, Distributed.BinaryOperator<T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector which performs a reduction of its input elements under a specified Distributed.BinaryOperator using the provided identity.
reducing(Distributed.BinaryOperator<T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector which performs a reduction of its input elements under a specified Distributed.BinaryOperator.
reducing(U, Distributed.Function<? super T, ? extends U>, Distributed.BinaryOperator<U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector which performs a reduction of its input elements under a specified mapping function and Distributed.BinaryOperator.
remove() - Method in interface com.hazelcast.jet.Inbox
Retrieves and removes the head of this inbox.
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.
reverseIterator() - Method in class com.hazelcast.jet.DAG
Returns an iterator over the DAG's vertices in topological order.
reverseOrder() - Static method in interface com.hazelcast.jet.Distributed.Comparator
Returns a comparator that imposes the reverse of the natural ordering.

S

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
 
setConfig(EdgeConfig) - Method in class com.hazelcast.jet.Edge
Assigns an EdgeConfig to this edge.
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.
setHazelcastConfig(Config) - Method in class com.hazelcast.jet.config.JetConfig
Sets the underlying IMDG instance's configuration object.
setHighWaterMark(int) - Method in class com.hazelcast.jet.config.EdgeConfig
Sets the high water mark for the edge.
setInstanceConfig(InstanceConfig) - Method in class com.hazelcast.jet.config.JetConfig
Sets the Jet instance config.
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 files.
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.
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
 
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(Distributed.Comparator<? 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
 
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
Starts a Hazelcast server.
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.
summarizingDouble(Distributed.ToDoubleFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector which applies an double-producing mapping function to each input element, and returns summary statistics for the resulting values.
summarizingInt(Distributed.ToIntFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector which applies an int-producing mapping function to each input element, and returns summary statistics for the resulting values.
summarizingLong(Distributed.ToLongFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector which applies an long-producing mapping function to each input element, and returns summary statistics for the resulting values.
summingDouble(Distributed.ToDoubleFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector that produces the sum of a double-valued function applied to the input elements.
summingInt(Distributed.ToIntFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector that produces the sum of a integer-valued function applied to the input elements.
summingLong(Distributed.ToLongFunction<? super T>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector 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.

T

thenComparing(Comparator<? super T>) - Method in interface com.hazelcast.jet.Distributed.Comparator
 
thenComparing(Distributed.Comparator<? super T>) - Method in interface com.hazelcast.jet.Distributed.Comparator
 
thenComparing(Function<? super T, ? extends U>, Comparator<? super U>) - Method in interface com.hazelcast.jet.Distributed.Comparator
 
thenComparing(Distributed.Function<? super T, ? extends U>, Distributed.Comparator<? super U>) - Method in interface com.hazelcast.jet.Distributed.Comparator
 
thenComparing(Function<? super T, ? extends U>) - Method in interface com.hazelcast.jet.Distributed.Comparator
 
thenComparing(Distributed.Function<? super T, ? extends U>) - Method in interface com.hazelcast.jet.Distributed.Comparator
 
thenComparingDouble(ToDoubleFunction<? super T>) - Method in interface com.hazelcast.jet.Distributed.Comparator
 
thenComparingDouble(Distributed.ToDoubleFunction<? super T>) - Method in interface com.hazelcast.jet.Distributed.Comparator
 
thenComparingInt(ToIntFunction<? super T>) - Method in interface com.hazelcast.jet.Distributed.Comparator
 
thenComparingInt(Distributed.ToIntFunction<? super T>) - Method in interface com.hazelcast.jet.Distributed.Comparator
 
thenComparingLong(ToLongFunction<? super T>) - Method in interface com.hazelcast.jet.Distributed.Comparator
 
thenComparingLong(Distributed.ToLongFunction<? super T>) - Method in interface com.hazelcast.jet.Distributed.Comparator
 
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(Distributed.Supplier<C>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector that accumulates the input elements into a new Collection, in encounter order.
toIList() - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector that accumulates the input elements into a new Hazelcast IList.
toIMap(Distributed.Function<? super T, ? extends K>, Distributed.Function<? super T, ? extends U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector 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() - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector that accumulates elements into a new distributed Hazelcast IMap whose keys and values are the keys and values of the corresponding Map.Entry.
toIMap(Distributed.Function<? super T, ? extends K>, Distributed.Function<? super T, ? extends U>, Distributed.BinaryOperator<U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector 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.stream.DistributedCollectors
Returns a Distributed.Collector that accumulates the input elements into a new List.
toMap(Distributed.Function<? super T, ? extends K>, Distributed.Function<? super T, ? extends U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector that accumulates elements into a Map whose keys and values are the result of applying the provided mapping functions to the input elements.
toMap(Distributed.Function<? super T, ? extends K>, Distributed.Function<? super T, ? extends U>, Distributed.BinaryOperator<U>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector that accumulates elements into a Map whose keys and values are the result of applying the provided mapping functions to the input elements.
toMap(Distributed.Function<? super T, ? extends K>, Distributed.Function<? super T, ? extends U>, Distributed.BinaryOperator<U>, Distributed.Supplier<M>) - Static method in class com.hazelcast.jet.stream.DistributedCollectors
Returns a Distributed.Collector 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.stream.DistributedCollectors
Returns a Distributed.Collector that accumulates the input elements into a new Set.
toString() - Method in class com.hazelcast.jet.config.ResourceConfig
 
toString() - Method in class com.hazelcast.jet.DAG
 
toString() - Method in class com.hazelcast.jet.Distributed.Optional
Returns a non-empty string representation of this Optional suitable for debugging.
toString() - Method in class com.hazelcast.jet.Edge
 
toString() - Method in class com.hazelcast.jet.Vertex
 
totalParallelism() - Method in interface com.hazelcast.jet.ProcessorMetaSupplier.Context
Returns the total number of Processors that will be created across the cluster.
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 over a sequence of non-null items, then starts returning null.
Traversers - Class in com.hazelcast.jet
Utility class with several Traversers useful in Processor implementations.
traverseStream(Stream<T>) - Static method in class com.hazelcast.jet.Traversers
Returns a traverser over the given stream.
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 over the supplied ordinal.
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.

U

unordered() - Method in interface com.hazelcast.jet.stream.DistributedStream
 
Util - Class in com.hazelcast.jet
Miscellaneous utility methods useful in DAG building logic.

V

valueOf(String) - Static method in enum com.hazelcast.jet.Edge.ForwardingPattern
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.hazelcast.jet.Edge.ForwardingPattern
Returns an array containing the constants of this enum type, in the order they are declared.
vertex(Vertex) - Method in class com.hazelcast.jet.DAG
Adds a vertex to this DAG.
Vertex - Class in com.hazelcast.jet
Represents a unit of data processing in a Jet computation job.
Vertex(String, Distributed.Supplier<Processor>) - Constructor for class com.hazelcast.jet.Vertex
Creates a vertex from a Supplier<Processor>.
Vertex(String, ProcessorSupplier) - Constructor for class com.hazelcast.jet.Vertex
Creates a vertex from a ProcessorSupplier.
Vertex(String, ProcessorMetaSupplier) - Constructor for class com.hazelcast.jet.Vertex
Creates a vertex from a ProcessorMetaSupplier.
vertexName() - Method in interface com.hazelcast.jet.Processor.Context
Returns the name of the vertex associated with this processor

W

wholeItem() - Static method in class com.hazelcast.jet.KeyExtractors
Transparent key extractor: returns its argument.
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
 
writeList(String) - Static method in class com.hazelcast.jet.Processors
Returns a meta-supplier of processors that write received items to an IMDG IList.
writeList(String, ClientConfig) - Static method in class com.hazelcast.jet.Processors
Returns a meta-supplier of processors that write received items to an IMDG IList in a remote cluster.
writeMap(String) - Static method in class com.hazelcast.jet.Processors
Returns a meta-supplier of processors that will put data into a Hazelcast IMap.
writeMap(String, ClientConfig) - Static method in class com.hazelcast.jet.Processors
Returns a meta-supplier of processors that will put data into a Hazelcast IMap in a remote cluster.
A B C D E F G H I J K L M N O P R S T U V W 
Skip navigation links

Copyright © 2017 Hazelcast, Inc.. All Rights Reserved.