Package | Description |
---|---|
com.hazelcast.aggregation |
Contains classes related to aggregations.
|
com.hazelcast.auditlog |
Contains interfaces and classes related to auditable events.
|
com.hazelcast.aws |
Provides interfaces/classes for Hazelcast AWS.
|
com.hazelcast.azure |
Provides interfaces/classes for Hazelcast Azure Discovery Provider
|
com.hazelcast.buildutils |
This module contains Maven and other build additions that are used by
Hazelcast to build bundle modules
|
com.hazelcast.cache |
This package contains the public API extension for Hazelcast JCache,
the Hazelcast implementation of the JSR-107 commonly referred to as JCache.
|
com.hazelcast.cardinality |
This package contains Cardinality Estimator functionality for Hazelcast.
|
com.hazelcast.client |
Contains classes/interfaces related to Client
|
com.hazelcast.client.cache |
Public API of client-side CachingProvider
|
com.hazelcast.client.config |
Contains classes related to config for com.hazelcast.client
|
com.hazelcast.client.properties |
Contains the Hazelcast client properties implementation.
|
com.hazelcast.client.util |
This package contains some utility classes and the base implementations of the
loadbalancer implementations
|
com.hazelcast.cluster |
This package contains the cluster functionality.
|
com.hazelcast.cluster.memberselector |
This package contains several
MemberSelector implementations. |
com.hazelcast.collection |
This package contains classes to support the collection API.
|
com.hazelcast.commandline |
This package contains the classes related to base `hz` command
|
com.hazelcast.config |
Provides classes for configuring HazelcastInstance.
|
com.hazelcast.config.cp |
This package contains configuration classes
for the
CPSubsystem |
com.hazelcast.config.matcher |
Provides implementations for
ConfigPatternMatcher . |
com.hazelcast.config.properties |
This package contains the public API for properties defined in the XML configuration.
|
com.hazelcast.config.replacer |
This package contains the public API and default implementation of variable replacers for configuration files.
|
com.hazelcast.config.replacer.spi |
This package contains the SPI for configuration files variable replacers.
|
com.hazelcast.config.security |
Provides classes for configuring security realms in Hazelcast.
|
com.hazelcast.connector |
Hazelcast 3 connector provides sources, sinks and enrichment using data
in Hazelcast 3 remote cluster
|
com.hazelcast.connector.map |
Interface for Hazelcast 3 Map adapter
|
com.hazelcast.console |
This package contains classes related to ConsoleApp
|
com.hazelcast.core |
Provides core API interfaces/classes.
|
com.hazelcast.cp |
Contains public APIs of CP Subsystem
|
com.hazelcast.cp.event |
Contains definitions of CP Subsystem events and listeners.
|
com.hazelcast.cp.exception |
Contains exceptions that can be thrown by APIs of CP Subsystem
|
com.hazelcast.cp.lock |
Contains locking APIs of CP Subsystem
|
com.hazelcast.cp.lock.exception |
Contains exception classes related to the locking API of CP Subsystem
|
com.hazelcast.cp.session |
Contains session abstractions of CP Subsystem
|
com.hazelcast.crdt |
This package contains the common classes for CRDT (conflict-free replicated
data type) implementations based on the Hazelcast infrastructure.
|
com.hazelcast.crdt.pncounter |
This package contains the PN (Positive-Negative) CRDT counter
interface.
|
com.hazelcast.durableexecutor |
This package contains DurableExecutorService functionality for Hazelcast.
The DurableExecutorService extends the ExecutorService and provides additional methods like
executing tasks on a member who is owner of a specific key. |
com.hazelcast.executor |
This package contains public API for Hazelcast executors.
|
com.hazelcast.flakeidgen |
This package contains Flake ID Generator functionality for Hazelcast.
|
com.hazelcast.function |
Serializable and exception-declaring variants of functional interfaces from
java.util.function . |
com.hazelcast.gcp |
Provides interfaces/classes for Hazelcast GCP.
|
com.hazelcast.hotrestart | |
com.hazelcast.jet |
Hazelcast Jet is a distributed computation engine running on top of
Hazelcast IMDG technology.
|
com.hazelcast.jet.accumulator |
Classes intended to be used for accumulator objects in an
AggregateOperation . |
com.hazelcast.jet.aggregate |
Contains
AggregateOperation and its several variants, as well
as a builder object for the aggregate operations. |
com.hazelcast.jet.annotation |
Annotations used for describing public API stability.
|
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.config |
Jet's configuration data objects.
|
com.hazelcast.jet.core |
Jet's Core API.
|
com.hazelcast.jet.core.function |
Functional interfaces used by Jet Core API
|
com.hazelcast.jet.core.metrics |
Jet's Job Metric API.
|
com.hazelcast.jet.core.processor |
Contains static utility classes with factories of Jet processors.
|
com.hazelcast.jet.core.test |
Utilities for writing tests of Core API Processors.
|
com.hazelcast.jet.datamodel |
Generic data containers used by the Pipeline API.
|
com.hazelcast.jet.elastic |
Contains sources and sinks for Elasticsearch 7
|
com.hazelcast.jet.function |
Serializable and exception-declaring variants of functional interfaces from
java.util.function . |
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.json |
Utility classes for JSON parsing and serialization.
|
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.file |
This package offers the
FileSourceBuilder
which allows you to construct various kinds of Pipeline sources that read from local or distributed files. |
com.hazelcast.jet.pipeline.test |
This package contains various mock sources to help with pipeline testing
and development.
|
com.hazelcast.jet.protobuf |
Protocol Buffers v3 support for Hazelcast Jet.
|
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.retry |
Interfaces and utility classes for defining and tracking various types of
retry behaviour.
|
com.hazelcast.jet.s3 |
AWS S3 read/write support for Hazelcast Jet.
|
com.hazelcast.json |
Contains Json interface
|
com.hazelcast.kubernetes |
Provides interfaces/classes for Hazelcast Kubernetes Discovery Plugin
|
com.hazelcast.logging |
This package contains logging functionality for Hazelcast.
Since Hazelcast has a zero dependency policy, Hazelcast provides a logging abstraction like commons logging, so that different logging frameworks like log4j, can be hooked in. |
com.hazelcast.map |
Contains Hazelcast map module classes.
|
com.hazelcast.map.listener |
Contains various
MapListener interfaces. |
com.hazelcast.memory |
Provides classes/interfaces for memory utilities, heap/native memory storage support.
|
com.hazelcast.multimap |
Contains the API for the
MultiMap . |
com.hazelcast.nearcache |
This package contains public API for near cache.
|
com.hazelcast.nio |
This package contains classes related to New IO
|
com.hazelcast.nio.serialization |
Contains interfaces/classes related to serialization,
such as serializer interfaces, input/output streams.
|
com.hazelcast.nio.serialization.compact |
Package contains API for Compact Serializer
|
com.hazelcast.osgi |
This package contains the OSGI functionality contract points for Hazelcast.
|
com.hazelcast.partition |
Contains the partition logic for Hazelcast.
|
com.hazelcast.partition.strategy |
Packages contains different partitioning strategies.
|
com.hazelcast.persistence |
This package contains Persistence classes needed for open source Hazelcast code
|
com.hazelcast.projection |
Contains classes related to projections.
|
com.hazelcast.query |
Contains interfaces/classes related to Hazelcast query and indexing support.
|
com.hazelcast.query.extractor |
Contains classes related to custom attributes and the extraction of their values.
|
com.hazelcast.replicatedmap |
Classes for replicated map.
|
com.hazelcast.ringbuffer |
Contains the API for the
Ringbuffer . |
com.hazelcast.scheduledexecutor |
This package contains ScheduledExecutorService functionality for Hazelcast.
|
com.hazelcast.security |
Provides interfaces/classes for Hazelcast security implementation.
|
com.hazelcast.security.jsm |
Contains Java Security Manager permissions.
|
com.hazelcast.security.permission |
Contains Hazelcast client permissions.
|
com.hazelcast.spi |
Contains functionality for the Hazelcast SPI
|
com.hazelcast.spi.annotation |
Contains annotations for Hazelcast SPI.
|
com.hazelcast.spi.discovery |
This package contains the public SPI for vendors and users to implement their
custom node / IP discovery strategy.
|
com.hazelcast.spi.discovery.integration |
This package contains the public part of the integrators SPI and is meant for
people that integrate Hazelcast into their own systems or frameworks and cannot
use the default discovery service implementation (for example using a different
DiscoveryStrategy lookup strategy like OSGi). |
com.hazelcast.spi.discovery.multicast |
Contains the hazelcast multicast plugin classes
|
com.hazelcast.spi.eviction |
This package contains interfaces for eviction
|
com.hazelcast.spi.exception |
Contains exceptions for Hazelcast SPI.
|
com.hazelcast.spi.merge |
This package contains interfaces and classes of the split-brain merging SPI.
|
com.hazelcast.spi.partitiongroup |
This package contains the basic SPI for the Partition Group SPI to define
or configure how Hazelcast will configure and distribute backups in the
cluster.
|
com.hazelcast.spi.properties |
Contains the Hazelcast properties implementation.
|
com.hazelcast.spi.tenantcontrol |
Classes for tenant control
|
com.hazelcast.spi.utils |
Contains utils classes for Hazelcast SPI.
|
com.hazelcast.splitbrainprotection |
Contains classes related to cluster split brain protection.
|
com.hazelcast.spring |
Provides Spring interfaces/classes for Hazelcast.
|
com.hazelcast.spring.cache |
Contains Hazelcast cache classes related to Spring.
|
com.hazelcast.spring.config |
Contains config factory classes.
|
com.hazelcast.spring.context |
Contains context classes for Spring.
|
com.hazelcast.spring.hibernate |
Contains class related to Hibernate.
|
com.hazelcast.spring.jet |
Provides Jet related Spring interfaces/classes for Hazelcast.
|
com.hazelcast.spring.transaction |
Contains Hazelcast transaction classes for Spring Transaction API.
|
com.hazelcast.sql |
This package contains the SQL API.
|
com.hazelcast.test.archunit |
ArchUnit rules for Hazelcast code
|
com.hazelcast.topic |
Contains the API for the
ITopic . |
com.hazelcast.transaction |
Provides interfaces/classes for Hazelcast transaction support.
|
com.hazelcast.version |
This package contains classes to support the versioning API.
|
com.hazelcast.wan |
This package contains the WAN replication API
|
org.apache.calcite.jdbc | |
org.apache.calcite.plan | |
org.apache.calcite.plan.volcano | |
org.apache.calcite.runtime | |
org.apache.calcite.sql.validate |
Copyright © 2023 Hazelcast, Inc.. All rights reserved.