Package | Description |
---|---|
com.hazelcast.connector |
Hazelcast 3 connector provides sources, sinks and enrichment using data
in Hazelcast 3 remote cluster
|
com.hazelcast.jet |
Hazelcast Jet is a distributed computation engine running on top of
Hazelcast IMDG technology.
|
com.hazelcast.jet.avro |
Apache Avro file read/write support for Hazelcast Jet.
|
com.hazelcast.jet.cdc |
Contains source/sink connectors that deal with Change Data Capture (CDC)
events from various databases as well as a generic connector for Debezium
CDC sources.
|
com.hazelcast.jet.cdc.mysql |
Contains connectors for change data capture events from MySQL
databases.
|
com.hazelcast.jet.cdc.postgres |
Contains connectors for change data capture events from PostgreSQL
databases.
|
com.hazelcast.jet.core.processor |
Contains static utility classes with factories of Jet processors.
|
com.hazelcast.jet.elastic |
Contains sources and sinks for Elasticsearch 7
|
com.hazelcast.jet.grpc |
Contributes
gRPC service factories that can be to apply transformations to
a pipeline which for each input item calls to a gRPC service. |
com.hazelcast.jet.hadoop |
Apache Hadoop read/write support for Hazelcast Jet.
|
com.hazelcast.jet.kafka |
Apache Kafka reader/writer support for Hazelcast Jet.
|
com.hazelcast.jet.kinesis |
Amazon Kinesis Data Streams producer/consumer support for Hazelcast Jet.
|
com.hazelcast.jet.pipeline |
The Pipeline API is Jet's high-level API to build and execute
distributed computation jobs.
|
com.hazelcast.jet.pipeline.test |
This package contains various mock sources to help with pipeline testing
and development.
|
com.hazelcast.jet.python |
Contributes a
PythonTransforms.mapUsingPython(com.hazelcast.jet.python.PythonServiceConfig)
transform that allows you to transform Jet pipeline data using a Python
function. |
com.hazelcast.jet.s3 |
AWS S3 read/write support for Hazelcast Jet.
|
com.hazelcast.spring.jet |
Provides Jet related Spring interfaces/classes for Hazelcast.
|
Class and Description |
---|
BatchSource
A finite source of data for a Jet pipeline.
|
ServiceFactory
A holder of functions needed to create and destroy a service object used in
pipeline transforms such as
stage.mapUsingService() . |
Sink
A data sink in a Jet pipeline.
|
Class and Description |
---|
Pipeline
Models a distributed computation job using an analogy with a system of
interconnected water pipes.
|
Class and Description |
---|
BatchSource
A finite source of data for a Jet pipeline.
|
Sink
A data sink in a Jet pipeline.
|
Class and Description |
---|
Sink
A data sink in a Jet pipeline.
|
StreamSource
An infinite source of data for a Jet pipeline.
|
Class and Description |
---|
StreamSource
An infinite source of data for a Jet pipeline.
|
Class and Description |
---|
StreamSource
An infinite source of data for a Jet pipeline.
|
Class and Description |
---|
JournalInitialPosition
When passed to an IMap/ICache Event Journal source, specifies which
event to start from.
|
ServiceFactory
A holder of functions needed to create and destroy a service object used in
pipeline transforms such as
stage.mapUsingService() . |
SourceBuilder.SourceBuffer
The buffer object that the
fillBufferFn gets on each call. |
SourceBuilder.TimestampedSourceBuffer
The buffer object that the
fillBufferFn gets on each call. |
Class and Description |
---|
BatchSource
A finite source of data for a Jet pipeline.
|
Sink
A data sink in a Jet pipeline.
|
Class and Description |
---|
ServiceFactory
A holder of functions needed to create and destroy a service object used in
pipeline transforms such as
stage.mapUsingService() . |
Class and Description |
---|
BatchSource
A finite source of data for a Jet pipeline.
|
Sink
A data sink in a Jet pipeline.
|
Class and Description |
---|
Sink
A data sink in a Jet pipeline.
|
StreamSource
An infinite source of data for a Jet pipeline.
|
Class and Description |
---|
Sink
A data sink in a Jet pipeline.
|
StreamSource
An infinite source of data for a Jet pipeline.
|
Class and Description |
---|
AggregateBuilder
Offers a step-by-step API to build a pipeline stage that co-aggregates
the data from several input stages.
|
AggregateBuilder1
Offers a step-by-step API to build a pipeline stage that co-aggregates
the data from several input stages.
|
BatchSource
A finite source of data for a Jet pipeline.
|
BatchStage
A stage in a distributed computation
pipeline that will
observe a finite amount of data (a batch). |
BatchStageWithKey
An intermediate step while constructing a group-and-aggregate batch
pipeline stage.
|
FileSinkBuilder |
FileSourceBuilder
Builder for a file source which reads lines from files in a directory (but not
its subdirectories) and emits output object created by
mapOutputFn |
GeneralHashJoinBuilder
Offers a step-by-step fluent API to build a hash-join pipeline stage.
|
GeneralStage |
GeneralStageWithKey
An intermediate step when constructing a group-and-aggregate pipeline
stage.
|
GroupAggregateBuilder
Offers a step-by-step API to build a pipeline stage that co-groups and
aggregates the data from several input stages.
|
GroupAggregateBuilder1
Offers a step-by-step API to build a pipeline stage that co-groups and
aggregates the data from several input stages.
|
HashJoinBuilder
Offers a step-by-step fluent API to build a hash-join pipeline stage.
|
JdbcSinkBuilder
See
Sinks.jdbcBuilder() . |
JmsSinkBuilder |
JmsSourceBuilder |
JoinClause
Specifies how to join an enriching stream to the primary stream in a
hash-join operation. |
JournalInitialPosition
When passed to an IMap/ICache Event Journal source, specifies which
event to start from.
|
Pipeline
Models a distributed computation job using an analogy with a system of
interconnected water pipes.
|
ServiceFactory
A holder of functions needed to create and destroy a service object used in
pipeline transforms such as
stage.mapUsingService() . |
SessionWindowDefinition
Represents the definition of a session window.
|
Sink
A data sink in a Jet pipeline.
|
SinkBuilder |
SinkStage
A pipeline stage that doesn't allow any downstream stages to be attached
to it.
|
SlidingWindowDefinition
Represents the definition of a sliding window.
|
SourceBuilder.Batch |
SourceBuilder.FaultTolerant
Represents a step in building a custom source where you add a
SourceBuilder.FaultTolerant.restoreSnapshotFn(com.hazelcast.function.BiConsumerEx<? super C, ? super java.util.List<S>>) after adding a createSnapshotFn . |
SourceBuilder.SourceBuffer
The buffer object that the
fillBufferFn gets on each call. |
SourceBuilder.Stream |
SourceBuilder.TimestampedSourceBuffer
The buffer object that the
fillBufferFn gets on each call. |
SourceBuilder.TimestampedStream |
Stage
The basic element of a Jet
pipeline , represents
a computation step. |
StageWithKeyAndWindow
Represents an intermediate step in the construction of a pipeline stage
that performs a windowed group-and-aggregate operation.
|
StageWithWindow
Represents an intermediate step in the construction of a pipeline stage
that performs a windowed aggregate operation.
|
StreamHashJoinBuilder
Offers a step-by-step fluent API to build a hash-join pipeline stage.
|
StreamSource
An infinite source of data for a Jet pipeline.
|
StreamSourceStage
A source stage in a distributed computation
pipeline
that will observe an unbounded amount of data (i.e., an event stream). |
StreamStage
A stage in a distributed computation
pipeline that will
observe an unbounded amount of data (i.e., an event stream). |
StreamStageWithKey
An intermediate step while constructing a pipeline transform that
involves a grouping key, such as windowed group-and-aggregate.
|
WindowAggregateBuilder
Offers a step-by-step fluent API to build a pipeline stage that
performs a windowed co-aggregation of the data from several input
stages.
|
WindowAggregateBuilder1
Offers a step-by-step fluent API to build a pipeline stage that
performs a windowed co-aggregation of the data from several input stages.
|
WindowDefinition
The definition of the window for a windowed aggregation operation.
|
WindowGroupAggregateBuilder
Offers a step-by-step API to build a pipeline stage that performs a
windowed co-grouping and aggregation of the data from several input
stages.
|
WindowGroupAggregateBuilder1
Offers a step-by-step API to build a pipeline stage that performs a
windowed co-grouping and aggregation of the data from several input
stages.
|
Class and Description |
---|
BatchSource
A finite source of data for a Jet pipeline.
|
BatchStage
A stage in a distributed computation
pipeline that will
observe a finite amount of data (a batch). |
Sink
A data sink in a Jet pipeline.
|
StreamSource
An infinite source of data for a Jet pipeline.
|
StreamStage
A stage in a distributed computation
pipeline that will
observe an unbounded amount of data (i.e., an event stream). |
Class and Description |
---|
BatchStage
A stage in a distributed computation
pipeline that will
observe a finite amount of data (a batch). |
StreamStage
A stage in a distributed computation
pipeline that will
observe an unbounded amount of data (i.e., an event stream). |
Class and Description |
---|
BatchSource
A finite source of data for a Jet pipeline.
|
Sink
A data sink in a Jet pipeline.
|
Class and Description |
---|
ServiceFactory
A holder of functions needed to create and destroy a service object used in
pipeline transforms such as
stage.mapUsingService() . |
Copyright © 2022 Hazelcast, Inc.. All rights reserved.