Package | Description |
---|---|
com.hazelcast.client.config |
Contains classes related to config for com.hazelcast.client
|
com.hazelcast.config |
Provides classes for configuring HazelcastInstance.
|
com.hazelcast.config.alto |
This package contains configuration classes
for Alto.
|
com.hazelcast.connector |
Hazelcast 3 connector provides sources, sinks and enrichment using data
in Hazelcast 3 remote cluster
|
com.hazelcast.core |
Provides core API interfaces/classes.
|
com.hazelcast.datalink |
This package contains code handling data links.
|
com.hazelcast.jet |
Hazelcast Jet is a distributed computation engine running on top of
Hazelcast IMDG technology.
|
com.hazelcast.jet.config |
Jet's configuration data objects.
|
com.hazelcast.jet.core |
Jet's Core API.
|
com.hazelcast.jet.core.processor |
Contains static utility classes with factories of Jet processors.
|
com.hazelcast.jet.kafka |
Apache Kafka reader/writer support for Hazelcast Jet.
|
com.hazelcast.jet.kafka.connect |
Contains a generic Kafka Connect source provides ability to plug any Kafka
Connect source for data ingestion to Jet pipelines.
|
com.hazelcast.jet.mongodb |
Contains sources and sinks for MongoDB.
|
com.hazelcast.jet.mongodb.datalink |
Contains classes related to Mongo DB Data Link.
|
com.hazelcast.jet.pipeline |
The Pipeline API is Jet's high-level API to build and execute
distributed computation jobs.
|
com.hazelcast.spi.properties |
Contains the Hazelcast properties implementation.
|
com.hazelcast.spi.tenantcontrol |
Classes for tenant control
|
Package | Description |
---|---|
com.hazelcast.datalink |
This package contains code handling data links.
|
Modifier and Type | Class and Description |
---|---|
class |
ClientAltoConfig
Contains client configurations for Alto.
|
Modifier and Type | Method and Description |
---|---|
ClientAltoConfig |
ClientConfig.getAltoConfig()
Returns the Alto configuration.
|
ClientConfig |
ClientConfig.setAltoConfig(ClientAltoConfig altoConfig)
Sets the Alto configuration.
|
Modifier and Type | Class and Description |
---|---|
class |
AdvancedNetworkConfig
Similar to
NetworkConfig with the additional ability to define multiple
endpoints, each with its own separate protocol/security and/or socket properties. |
class |
DataLinkConfig
|
Modifier and Type | Method and Description |
---|---|
Config |
Config.addDataLinkConfig(DataLinkConfig dataLinkConfig)
Adds an data link configuration.
|
DataLinkConfig |
Config.findDataLinkConfig(String name)
Returns a read-only
DataLinkConfig
configuration for the given name. |
AltoConfig |
Config.getAltoConfig()
Gets the Alto config.
|
AltoSocketConfig |
EndpointConfig.getAltoSocketConfig()
Gets the Alto socket config.
|
AltoSocketConfig |
NetworkConfig.getAltoSocketConfig()
Gets the Alto socket config.
|
DataLinkConfig |
Config.getDataLinkConfig(String name)
Returns the data link configuration for the given name, creating one
if necessary and adding it to the collection of known configurations.
|
Map<String,DataLinkConfig> |
Config.getDataLinkConfigs()
Returns the map of data link configurations, mapped by config name.
|
Config |
Config.setAltoConfig(AltoConfig altoConfig)
Sets the Alto config.
|
ServerSocketEndpointConfig |
ServerSocketEndpointConfig.setAltoSocketConfig(AltoSocketConfig altoSocketConfig) |
EndpointConfig |
EndpointConfig.setAltoSocketConfig(AltoSocketConfig altoSocketConfig)
Sets the Alto socket config.
|
RestServerEndpointConfig |
RestServerEndpointConfig.setAltoSocketConfig(AltoSocketConfig altoSocketConfig) |
NetworkConfig |
NetworkConfig.setAltoSocketConfig(AltoSocketConfig altoSocketConfig)
Sets the Alto socket config.
|
Config |
Config.setDataLinkConfigs(Map<String,DataLinkConfig> dataLinkConfigs)
Sets the map of data link configurations, mapped by config name.
|
Modifier and Type | Class and Description |
---|---|
class |
AltoConfig
Hazelcast Alto is the next generation of Hazelcast built with thread
per core architecture.
|
class |
AltoSocketConfig
Socket configuration for Alto.
|
Modifier and Type | Class and Description |
---|---|
class |
Hz3Enrichment
Provides a way to perform enrichment using a Map or ReplicatedMap from
Hazelcast 3 cluster.
|
class |
Hz3Sinks
Provides sinks to write to Hazelcast 3 cluster.
|
class |
Hz3Sources
Provides sources to read from Hazelcast 3 cluster.
|
Modifier and Type | Method and Description |
---|---|
static <K,V> ServiceFactory<Hz3MapAdapter,AsyncMap<K,V>> |
Hz3Enrichment.hz3MapServiceFactory(String mapName,
String clientXML)
Create a service factory for enrichment using Hazelcast 3 remote map.
|
static <K,V> ServiceFactory<Hz3MapAdapter,Map<K,V>> |
Hz3Enrichment.hz3ReplicatedMapServiceFactory(String mapName,
String clientXML)
Create a service factory for enrichment using Hazelcast 3 remote replicated map.
|
static <K,V,T,R> BiFunctionEx<? super Map<K,V>,? super T,R> |
Hz3Enrichment.mapUsingIMap(FunctionEx<? super T,? extends K> lookupKeyFn,
BiFunctionEx<? super T,? super V,? extends R> mapFn)
Helper function to convert simple lookupKeyFn and mapFn to mapAsyncFn required by
GeneralStage.mapUsingServiceAsync(ServiceFactory, BiFunctionEx) |
static <K,V,T,R> BiFunctionEx<? super AsyncMap<K,V>,? super T,CompletableFuture<R>> |
Hz3Enrichment.mapUsingIMapAsync(FunctionEx<? super T,? extends K> lookupKeyFn,
BiFunctionEx<? super T,? super V,? extends R> mapFn)
Helper function to convert simple lookupKeyFn and mapFn to mapAsyncFn required by
GeneralStage.mapUsingServiceAsync(ServiceFactory, BiFunctionEx) |
static ProcessorSupplier |
Hz3Sources.readRemoteMapP(String mapName,
String clientXml)
Returns a supplier of processors for
Sources.remoteMap(String, ClientConfig) . |
static <T,K,V> Sink<T> |
Hz3Sinks.remoteMap(String mapName,
FunctionEx<? super T,? extends K> toKeyFn,
FunctionEx<? super T,? extends V> toValueFn,
String clientXml)
Returns a sink that uses the supplied functions to extract the key
and value with which to put to a Hazelcast
IMap with the
specified name. |
static <K,V> Sink<Map.Entry<K,V>> |
Hz3Sinks.remoteMap(String mapName,
String clientXml)
Returns a sink that puts
Map.Entry s it receives into a Hazelcast
IMap with the specified name. |
static <K,V> BatchSource<Map.Entry<K,V>> |
Hz3Sources.remoteMap(String mapName,
String clientXml)
Returns a source that fetches entries from the Hazelcast
IMap
with the specified name in a remote cluster identified by the supplied
XML configuration. |
Modifier and Type | Class and Description |
---|---|
class |
Pipelining<E>
The Pipelining can be used to speed up requests.
|
Modifier and Type | Interface and Description |
---|---|
interface |
DataLink
DataLink is a reference to a single external system.
|
class |
DataLinkBase
Base class for
DataLink implementations. |
interface |
DataLinkRegistration
Registration for a
DataLink . |
class |
DataLinkResource
DataLink Resource is an object for which a mapping can be created.
|
class |
HazelcastDataLink
Creates a HazelcastInstance that is shared to connect to a remote cluster.
|
class |
JdbcDataLink
TODO move this class to impl package when changing
DataLinkConfig.className to type |
Modifier and Type | Method and Description |
---|---|
SqlService |
JetInstance.getSql()
Deprecated.
since 5.0
Use
HazelcastInstance.getSql() instead. |
Modifier and Type | Method and Description |
---|---|
JobConfig |
JobConfig.addCustomClasspath(String name,
String path)
Adds custom classpath element to a stage with the given name.
|
JobConfig |
JobConfig.addCustomClasspaths(String name,
List<String> paths)
Adds custom classpath elements to a stage with the given name.
|
Modifier and Type | Method and Description |
---|---|
static ProcessorMetaSupplier |
ProcessorMetaSupplier.randomMember(ProcessorSupplier supplier)
Wraps the provided
ProcessorSupplier into a meta-supplier that
will only use the given ProcessorSupplier on a random node |
Modifier and Type | Method and Description |
---|---|
static <T> ProcessorMetaSupplier |
SinkProcessors.writeJdbcP(String updateQuery,
DataLinkRef dataLinkRef,
BiConsumerEx<? super PreparedStatement,? super T> bindFn,
boolean exactlyOnce,
int batchLimit)
Returns a supplier of processors for
Sinks.jdbcBuilder() . |
Modifier and Type | Class and Description |
---|---|
class |
KafkaDataLink
DataLink implementation for Kafka. |
Modifier and Type | Method and Description |
---|---|
static <E> KafkaSinks.Builder<E> |
KafkaSinks.kafka(DataLinkRef dataLinkRef)
Returns a builder object that you can use to create an Apache Kafka
pipeline sink.
|
static <E,K,V> Sink<E> |
KafkaSinks.kafka(DataLinkRef dataLinkRef,
FunctionEx<? super E,org.apache.kafka.clients.producer.ProducerRecord<K,V>> toRecordFn)
Returns a sink that publishes messages to Apache Kafka topic(s).
|
static <K,V,T> StreamSource<T> |
KafkaSources.kafka(DataLinkRef dataLinkRef,
FunctionEx<org.apache.kafka.clients.consumer.ConsumerRecord<K,V>,T> projectionFn,
String... topics)
Returns a source that consumes one or more Apache Kafka topics and emits
items from them as
Map.Entry instances. |
static <K,V> StreamSource<Map.Entry<K,V>> |
KafkaSources.kafka(DataLinkRef dataLinkRef,
String... topics)
Convenience for
KafkaSources.kafka(DataLinkRef, FunctionEx, String...)
wrapping the output in Map.Entry . |
static <K,V> Sink<Map.Entry<K,V>> |
KafkaSinks.kafka(DataLinkRef dataLinkRef,
String topic)
Convenience for
KafkaSinks.kafka(DataLinkRef, String, FunctionEx, FunctionEx)
which expects Map.Entry<K, V> as input and extracts its key and value
parts to be published to Kafka. |
static <E,K,V> Sink<E> |
KafkaSinks.kafka(DataLinkRef dataLinkRef,
String topic,
FunctionEx<? super E,K> extractKeyFn,
FunctionEx<? super E,V> extractValueFn)
Convenience for
KafkaSinks.kafka(Properties, FunctionEx) which creates
a ProducerRecord using the given topic and the given key and value
mapping functions |
Modifier and Type | Class and Description |
---|---|
class |
KafkaConnectSources
Contains factory methods to create a Kafka Connect source.
|
Modifier and Type | Method and Description |
---|---|
static StreamSource<org.apache.kafka.connect.source.SourceRecord> |
KafkaConnectSources.connect(Properties properties)
A generic Kafka Connect source provides ability to plug any Kafka
Connect source for data ingestion to Jet pipelines.
|
Modifier and Type | Class and Description |
---|---|
class |
MongoSinkBuilder<T>
|
class |
MongoSinks
Contains factory methods for MongoDB sinks.
|
class |
MongoSourceBuilder
Top-level class for MongoDB custom source builders.
|
class |
WriteMode
Defines allowed operations.
|
Modifier and Type | Method and Description |
---|---|
static MongoSourceBuilder.Batch<org.bson.Document> |
MongoSources.batch(String name,
DataLinkRef dataLinkRef)
Creates as builder for new batch mongo source.
|
static BatchSource<org.bson.Document> |
MongoSources.batch(String name,
DataLinkRef dataLinkRef,
String database,
String collection,
org.bson.conversions.Bson filter,
org.bson.conversions.Bson projection)
Returns a MongoDB batch source which queries the collection using given
filter and applies the given projection on the documents. |
static BatchSource<org.bson.Document> |
MongoSources.batch(String name,
String connectionString,
String database,
String collection,
org.bson.conversions.Bson filter,
org.bson.conversions.Bson projection)
Returns a MongoDB batch source which queries the collection using given
filter and applies the given projection on the documents. |
static MongoSourceBuilder.Batch<org.bson.Document> |
MongoSources.batch(String name,
SupplierEx<? extends com.mongodb.client.MongoClient> clientSupplier)
Creates as builder for new batch mongo source.
|
static <T> MongoSinkBuilder<T> |
MongoSinks.builder(String name,
Class<T> itemClass,
DataLinkRef dataLinkRef)
Returns a builder object that offers a step-by-step fluent API to build
a custom MongoDB
Sink for the Pipeline API. |
static <T> MongoSinkBuilder<T> |
MongoSinks.builder(String name,
Class<T> itemClass,
SupplierEx<com.mongodb.client.MongoClient> clientSupplier)
Returns a builder object that offers a step-by-step fluent API to build
a custom MongoDB
Sink for the Pipeline API. |
static Sink<org.bson.Document> |
MongoSinks.mongodb(String name,
DataLinkRef dataLinkRef,
String database,
String collection)
|
static Sink<org.bson.Document> |
MongoSinks.mongodb(String name,
String connectionString,
String database,
String collection)
|
static StreamSource<? extends org.bson.Document> |
MongoSources.stream(String name,
String connectionString,
String database,
String collection,
org.bson.Document filter,
org.bson.Document projection)
Returns a MongoDB stream source which watches the changes on the
collection.
|
static MongoSourceBuilder.Stream<org.bson.Document> |
MongoSources.stream(String name,
SupplierEx<? extends com.mongodb.client.MongoClient> clientSupplier)
Creates as builder for new stream mongo source.
|
Modifier and Type | Class and Description |
---|---|
class |
MongoDataLink
Creates a MongoDB DataLink.
|
Modifier and Type | Class and Description |
---|---|
class |
DataLinkRef
Represents a reference to the data link, used with
Sources.jdbc(DataLinkRef, ToResultSetFunction, FunctionEx) . |
Modifier and Type | Method and Description |
---|---|
JdbcSinkBuilder<T> |
JdbcSinkBuilder.dataLinkRef(DataLinkRef dataLinkRef)
Sets the reference to the configured data link of
DataLinkRef from which
the instance of the DataSource will be retrieved. |
static <T> BatchSource<T> |
Sources.jdbc(DataLinkRef dataLinkRef,
ToResultSetFunction resultSetFn,
FunctionEx<? super ResultSet,? extends T> createOutputFn)
Returns a source which connects to the specified database using the given
dataLinkRef , queries the database and creates a result set
using the given resultSetFn . |
static <T> Sink<T> |
Sinks.jdbc(String updateQuery,
DataLinkRef dataLinkRef,
BiConsumerEx<PreparedStatement,T> bindFn)
A shortcut for:
|
static <K,V> StreamSource<Map.Entry<K,V>> |
Sources.remoteMapJournal(String mapName,
DataLinkRef dataLinkRef,
JournalInitialPosition initialPos)
Convenience for
Sources.remoteMapJournal(String, DataLinkRef, JournalInitialPosition, FunctionEx, PredicateEx)
which will pass only ADDED
and UPDATED events and will
project the event's key and new value into a Map.Entry . |
static <T,K,V> StreamSource<T> |
Sources.remoteMapJournal(String mapName,
DataLinkRef dataLinkRef,
JournalInitialPosition initialPos,
FunctionEx<? super EventJournalMapEvent<K,V>,? extends T> projectionFn,
PredicateEx<? super EventJournalMapEvent<K,V>> predicateFn)
The same as the
Sources.remoteMapJournal(String, ClientConfig, JournalInitialPosition, FunctionEx, PredicateEx)
method. |
Modifier and Type | Field and Description |
---|---|
static HazelcastProperty |
ClusterProperty.SQL_CUSTOM_TYPES_ENABLED
Enable experimental support for accessing nested fields by using custom
types in SQL.
|
Modifier and Type | Interface and Description |
---|---|
interface |
DestroyEventContext
Hook to decouple Hazelcast object from the tenant
|
interface |
Tenantable
Interface to be implemented by classes which can be queried for requirement
of a tenant context.
|
interface |
TenantControl
Hooks for multi-tenancy for application servers.
|
interface |
TenantControlFactory
A
TenantControlFactory supplies TenantControl objects when
Hazelcast service attaches the tenant control to a distributed object. |
Copyright © 2023 Hazelcast, Inc.. All rights reserved.