Skip navigation links

hazelcast-jet-distribution 0.7 API

Packages 
Package Description
com.hazelcast.aggregation
Contains classes related to aggregations.
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.cache.journal
Contains EventJournal event interface for ICache.
com.hazelcast.cache.merge
Contains out-of-the-box merge policies for ICache.
com.hazelcast.cardinality
This package contains Cardinality Estimator functionality for Hazelcast.
com.hazelcast.client
This package contains the serverside client functionality
com.hazelcast.client.config
Contains classes related to config for com.hazelcast.client
com.hazelcast.client.connection
Provides connection interfaces/classes for com.hazelcast.client
com.hazelcast.client.connection.nio
Contains classes related to New IO for com.hazelcast.client.connection
com.hazelcast.client.console
This package contains ClientConsoleApp
com.hazelcast.client.proxy
This package contains client side proxy implementations of the different Hazelcast data structures and operation types
com.hazelcast.client.proxy.txn
Contains classes related to proxy for client transactions
com.hazelcast.client.proxy.txn.xa
Contains classes related to proxy for XA
com.hazelcast.client.spi
Contains classes/interfaces related to the Hazelcast client Service Provider Interface.
com.hazelcast.client.spi.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.com.eclipsesource.json  
com.hazelcast.concurrent.atomiclong
This package contains IAtomicLong functionality for Hazelcast.
The IAtomicLong is the distributed version of the AtomicLong.
com.hazelcast.concurrent.atomiclong.operations
This package contains the operations on the IAtomicLong.
com.hazelcast.concurrent.atomicreference
This package contains IAtomicReferece functionality for Hazelcast.
The IAtomicReference is the distributed version of the AtomicReference.
com.hazelcast.concurrent.atomicreference.operations
This package contains the operations on the IAtomicReference.
com.hazelcast.concurrent.countdownlatch
This package contains ICountDownLatch functionality for Hazelcast.
The ICountDownLatch is the distributed version of the CountDownLatch.
com.hazelcast.concurrent.countdownlatch.operations
This package contains the operations on the ICountDownLatch.
com.hazelcast.concurrent.idgen
This package contains IdGenerator functionality for Hazelcast.
com.hazelcast.concurrent.lock
This package contains Lock for Hazelcast.
The ILock is the distributed version of the Lock.
com.hazelcast.concurrent.lock.operations
This package contains the operations on the ILock.
com.hazelcast.concurrent.semaphore
This package contains ISemaphore functionality for Hazelcast.
The ISemaphore is the distributed version of the Semaphore.
com.hazelcast.concurrent.semaphore.operations
This package contains the operations on the ISemaphore.
com.hazelcast.config
Provides classes for configuring HazelcastInstance.
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.console
This package contains classes related to ConsoleApp
com.hazelcast.core
Provides core API interfaces/classes.
com.hazelcast.core.server
This package contains classes to launch standalone Hazelcast Instance
com.hazelcast.crdt
This package contains 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 implementation.
com.hazelcast.crdt.pncounter.operations
Contains the operations for the PNCounter member-side implementation.
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.flakeidgen
This package contains Flake ID Generator functionality for Hazelcast.
com.hazelcast.hotrestart
This package contains Hot Restart classes needed for open source Hazelcast code
com.hazelcast.instance
This package contains Hazelcast Instance functionality.
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 several its variants, as well as a builder object for the aggregate operations.
com.hazelcast.jet.avro
Apache Avro file read/write support for Hazelcast Jet.
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.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.function
Serializable and exception-declaring variants of functional interfaces from java.util.function.
com.hazelcast.jet.hadoop
Apache Hadoop HDFS read/write support for Hazelcast Jet.
com.hazelcast.jet.kafka
Apache Kafka reader/writer 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.server
Contains Java program entry points that will start a Jet server instance, submit jobs to a Jet cluster, etc.
com.hazelcast.jet.spring
Spring integration for Hazelcast Jet
com.hazelcast.logging
This package contains logging functionality for Hazelcast.
Since Hazelcast has a zero dependency policy, Hazelcast provides a logging abstraction like commongs logging, so that different logging frameworks like log4j, can be hooked in.
com.hazelcast.map
Contains Hazelcast map module classes.
com.hazelcast.map.eviction
This package contains eviction specific classes.
com.hazelcast.map.journal
Contains EventJournal event interface for IMap.
com.hazelcast.map.listener
Contains various MapListener interfaces.
com.hazelcast.map.merge
Contains out-of-the-box merge policies for IMap.
com.hazelcast.mapreduce
This package contains the MapReduce API definition for Hazelcast.
All map reduce operations running in a distributed manner inside the active Hazelcast cluster.
com.hazelcast.mapreduce.aggregation
This package contains the aggregation API and the convenience helper classes to retrieve predefined aggregation implementations.
com.hazelcast.memory
Provides classes/interfaces for memory utilities, heap/native memory storage support.
com.hazelcast.monitor
Contains Hazelcast statistics interfaces related to map, queue, topic, multimap, executor service etc.
com.hazelcast.nio
This package contains classes related to New IO
com.hazelcast.nio.ascii
Contains SocketTextReader and SocketTextWriter classes;
com.hazelcast.nio.serialization
Contains interfaces/classes related to serialization; such as serializer interfaces, input/output streams.
com.hazelcast.nio.ssl
Contains interfaces/classes related to SSL for New IO
com.hazelcast.nio.tcp
Contains functionality for the TCP/IP Networking for cluster members
This whole package is internal and no compatibility will be provided.
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.membergroup
todo
com.hazelcast.partition.strategy
Packages contains different partitioning strategies.
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.quorum
Contains classes related to cluster quorum.
com.hazelcast.replicatedmap
Classes for replicated map.
com.hazelcast.replicatedmap.merge
Contains out-of-the-box merge policies for ReplicatedMap.
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.permission
Contains all the security permissions
com.hazelcast.spi
Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services.
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.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.partition
Contains the SPI for partition logic for Hazelcast.
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.serialization
Contains SPI related to serialization
com.hazelcast.spring
Provides Spring interfaces/classes for Hazelcast.
com.hazelcast.spring.cache
Contains Hazelcast cache classes related to Spring.
com.hazelcast.spring.context
Contains context classes for Spring.
com.hazelcast.spring.hibernate
Contains class related to Hibernate.
com.hazelcast.spring.transaction
Contains Hazelcast transaction classes for Spring Transaction API.
com.hazelcast.topic
Contains the API for the ITopic.
com.hazelcast.transaction
Provides interfaces/classes for Hazelcast transaction support.
com.hazelcast.util
This package contains classes to support the inner workings of Hazelcast as well as some backports of newer Java features / data structures to support older Java versions in a clean and nice way.
com.hazelcast.util.collection
The Agrona project backport: collections.
com.hazelcast.util.concurrent
Abstractions that deal with common needs in concurrent programming.
com.hazelcast.util.executor
This package contains classes related to Util.Executor
com.hazelcast.util.function
Backport of Java 8 functional interfaces which Agrona depends on.
com.hazelcast.util.scheduler
This package contains scheduler classes for Util
com.hazelcast.version
This package contains classes to support the versioning API.
com.hazelcast.wan
This package contains the WAN replication API
Skip navigation links

Copyright © 2018 Hazelcast, Inc.. All rights reserved.