Interface | Description |
---|---|
EvictingBoundedList.Function<I,O> |
A simple unary function that can be used to transform elements via the
EvictingBoundedList.map(Function) method. |
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 |
---|---|
AtomicDisposableReferenceCounter |
Atomic reference counter, which enters a "disposed" state after it reaches a configurable
reference count (default 0).
|
ClassLoaderUtil |
Utilities for information with respect to class loaders, specifically class loaders for
the dynamic loading of user defined classes.
|
DependencyVisitor |
This class tracks class dependency with ASM visitors.
|
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.
|
EvictingBoundedList<T> |
This class implements a list (array based) that is physically bounded in maximum size, but can virtually grow beyond
the bounded size.
|
ExecutorThreadFactory |
A thread factory intended for use by critical thread pools.
|
FatalExitExceptionHandler |
Handler for uncaught exceptions that will log the exception and kill the process afterwards.
|
ForwardingInputStream |
Input stream, that wraps another input stream and forwards all method calls to the wrapped stream.
|
ForwardingOutputStream |
Output stream, that wraps another input stream and forwards all method calls to the wrapped stream.
|
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
|
JarFileCreator |
This is an auxiliary program which creates a jar file from a set of classes.
|
JvmShutdownSafeguard |
A utility that guards against blocking shutdown hooks that block JVM shutdown.
|
LeaderConnectionInfo |
Wrapper class for a pair of connection address and leader session ID.
|
LeaderRetrievalUtils |
Utility class to work with
LeaderRetrievalService class. |
LeaderRetrievalUtils.LeaderConnectionInfoListener |
Helper class which is used by the retrieveLeaderConnectionInfo method to retrieve the
leader's akka URL and the current leader session ID.
|
LeaderRetrievalUtils.LeaderGatewayListener |
Helper class which is used by the retrieveLeaderGateway method as the
LeaderRetrievalListener . |
LongArrayList |
Minimal implementation of an array-backed list of longs
|
NonClosingInputStreamDecorator |
Decorator for input streams that ignores calls to
InputStream.close() . |
NonClosingOutpusStreamDecorator |
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 . |
ProcessShutDownThread |
JVM shut down thread awaiting actor system shut down for a certain amount
of time before exiting the JVM.
|
RegularToMutableObjectIterator<T> | |
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 . |
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. |
StandaloneUtils |
Utility class to work with Flink standalone mode.
|
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–2018 The Apache Software Foundation. All rights reserved.