Interface | Description |
---|---|
GroupCache<G,K,V> |
This
GroupCache can cache group, key and value. |
KeyGroupedIterator<E> | |
MemoryBlockIterator |
The memory block iterator is an iterator that always buffers a block of elements in memory.
|
ResettableIterator<E> |
The resettable iterator is a specialization of the iterator, allowing to reset the iterator and
re-retrieve elements.
|
ResettableMutableObjectIterator<E> |
The resettable iterator is a specialization of the iterator, allowing to reset the iterator and
re-retrieve elements.
|
Class | Description |
---|---|
BoundedFIFOQueue<T> |
BoundedFIFOQueue collects elements up to given amount. |
ClusterUncaughtExceptionHandler |
Utility for handling any uncaught exceptions
Handles any uncaught exceptions according to cluster configuration in
ClusterOptions
to either just log exception, or fail job. |
ConfigurationParserUtils |
Utility class to extract related parameters from
Configuration and to sanity check them. |
DefaultGroupCache<G,K,V> |
Default implement of
GroupCache . |
DefaultGroupCache.Factory<G,K,V> |
The Factory of
DefaultGroupCache . |
DualKeyLinkedMap<A,B,V> |
Map which stores values under two different indices.
|
EmptyIterator<E> |
An empty iterator that never returns anything.
|
EmptyMutableObjectIterator<E> |
An empty mutable object iterator that never returns anything.
|
EnvironmentInformation |
Utility class that gives access to the execution environment of the JVM, like the executing user,
startup options, or the JVM version.
|
EnvironmentInformation.RevisionInformation |
Revision information encapsulates information about the source code revision of the Flink
code.
|
ForwardingInputStream |
Input stream, that wraps another input stream and forwards all method calls to the wrapped
stream.
|
ForwardingOutputStream |
OutputStream , that wraps another OutputStream and forwards all method calls to
the wrapped stream. |
HadoopConfigLoader |
This class lazily loads hadoop configuration from resettable Flink's configuration.
|
HadoopUtils |
Utility class for working with Hadoop-related classes.
|
Hardware |
Convenience class to extract hardware specifics of the computer executing the running JVM.
|
IntArrayList |
Minimal implementation of an array-backed list of ints
|
JvmShutdownSafeguard |
A utility that guards against blocking shutdown hooks that block JVM shutdown.
|
JvmUtils |
Utilities for
ManagementFactory . |
LeaderRetrievalUtils |
Utility class to work with
LeaderRetrievalService class. |
LeaderRetrievalUtils.LeaderInformationListener |
Helper class which is used by the retrieveLeaderInformation method to retrieve the leader's
rpc URL and the current leader session ID.
|
LongArrayList |
Minimal implementation of an array-backed list of longs
|
NonClosingInputStreamDecorator |
Decorator for input streams that ignores calls to
InputStream.close() . |
NonClosingOutputStreamDecorator |
Decorator for input streams that ignores calls to
OutputStream.close() . |
NonReusingKeyGroupedIterator<E> |
The key grouped iterator returns a key and all values that share the same key.
|
NonReusingMutableToRegularIteratorWrapper<T> |
This class wraps a
MutableObjectIterator into a regular Iterator . |
OperatorSubtaskDescriptionText |
This class generates a string that can be used to identify an operator subtask.
|
PortRange |
Represents a port range and provides access to an iterator of the given range.
|
RegularToMutableObjectIterator<T> | |
ResourceCounter |
Counter for
ResourceProfiles . |
ResourceManagerUtils |
Common utils for ResourceManager.
|
ReusingKeyGroupedIterator<E> |
The KeyValueIterator returns a key and all values that belong to the key (share the same key).
|
ReusingMutableToRegularIteratorWrapper<T> |
This class wraps a
MutableObjectIterator into a regular Iterator . |
Runnables |
Utils related to
Runnable . |
SignalHandler |
This signal handler / signal logger is based on Apache Hadoop's
org.apache.hadoop.util.SignalLogger.
|
SingleElementIterator<E> |
An
Iterator that contains only a single element. |
SlotSelectionStrategyUtils |
Utility class for selecting
SlotSelectionStrategy . |
StateHandleStoreUtils |
StateHandleStoreUtils collects utility methods that might be usefule for any StateHandleStore implementation. |
ZooKeeperUtils |
Class containing helper functions to interact with ZooKeeper.
|
ZooKeeperUtils.SecureAclProvider |
Secure
ACLProvider implementation. |
Enum | Description |
---|---|
ZooKeeperUtils.ZkClientACLMode |
ZooKeeper client ACL mode enum.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.