| AbstractAutoCloseableRegistry<R extends AutoCloseable,C extends R,T,E extends Exception> |
This is the abstract base class for registries that allow to register instances of Closeable, which are all closed if this registry is closed.
|
| AbstractID |
A statistically unique identification number.
|
| AbstractParameterTool |
|
| ArrayUtils |
Utility class for Java arrays.
|
| ChildFirstClassLoader |
A variant of the URLClassLoader that first loads from the URLs and only after that from the
parent.
|
| ClassLoaderUtil |
Utilities for information with respect to class loaders, specifically class loaders for the
dynamic loading of user defined classes.
|
| CloseableIterable.Empty<T> |
Empty iterator.
|
| CloseableIterator.IteratorAdapter<E> |
|
| CloseShieldOutputStream |
A proxy output stream that prevents the underlying output stream from being closed.
|
| CollectionUtil |
Simple utility to work with Java collections.
|
| CompressedSerializedValue<T> |
An extension of SerializedValue that compresses the value after the serialization.
|
| CompressionUtils |
Utils used to extract compressed files.
|
| ExceptionUtils |
A collection of utility functions for dealing with exceptions and exception workflows.
|
| ExecutorUtils |
|
| FatalExitExceptionHandler |
Handler for uncaught exceptions that will log the exception and kill the process afterwards.
|
| FileLock |
A file lock used for avoiding race condition among multiple threads/processes.
|
| FileUtils |
This is a utility class to deal files and directories.
|
| FlinkUserCodeClassLoader |
|
| FlinkUserCodeClassLoaders |
Gives the URLClassLoader a nicer name for debugging purposes.
|
| FlinkUserCodeClassLoaders.ParentFirstClassLoader |
Regular URLClassLoader that first loads from the parent and only after that from the URLs.
|
| FlinkUserCodeClassLoaders.SafetyNetWrapperClassLoader |
Ensures that holding a reference on the context class loader outliving the scope of user code
does not prevent the user classloader to be garbage collected (FLINK-16245).
|
| InstantiationUtil |
Utility class to create instances from class objects and checking failure reasons.
|
| InstantiationUtil.ClassLoaderObjectInputStream |
A custom ObjectInputStream that can load classes using a specific ClassLoader.
|
| InstantiationUtil.FailureTolerantObjectInputStream |
|
| IOUtils |
An utility class for I/O related functionality.
|
| IterableUtils |
A collection of utilities that expand the usage of Iterable.
|
| JarUtils |
Utility functions for jar files.
|
| LambdaUtil |
This class offers utility functions for Java's lambda features.
|
| LinkedOptionalMap<K,V> |
A LinkedOptionalMap is an order preserving map (like LinkedHashMap) where keys have a
unique string name, but are optionally present, and the values are optional.
|
| LinkedOptionalMap.KeyValue<K,V> |
Key-value pairs stored by the underlying map.
|
| LinkedOptionalMap.MergeResult<K,V> |
|
| LinkedOptionalMapSerializer |
|
| LongValueSequenceIterator |
The LongValueSequenceIterator is an iterator that returns a sequence of numbers (as
LongValue)s.
|
| MathUtils |
Collection of simple mathematical routines.
|
| MdcUtils |
Utility class to manage common Flink attributes in MDC (only JobID ATM).
|
| MultipleParameterTool |
This class provides simple utility methods for reading and parsing program arguments from
different sources.
|
| MutableURLClassLoader |
URL class loader that exposes the `addURL` method in URLClassLoader.
|
| NetUtils |
Utility for various network related tasks (such as finding free ports).
|
| NetUtils.Port |
Port wrapper class which holds a FileLock until it releases.
|
| NumberSequenceIterator |
The NumberSequenceIterator is an iterator that returns a sequence of numbers (as
Long)s.
|
| OptionalConsumer<T> |
Utility class which allows to run code depending on whether the optional has a value or is empty.
|
| OptionalFailure<T> |
Wrapper around an object representing either a success (with a given value) or a failure cause.
|
| OptionalUtils |
|
| OutputTag<T> |
An OutputTag is a typed and named tag to use for tagging side outputs of an operator.
|
| ParameterTool |
This class provides simple utility methods for reading and parsing program arguments from
different sources.
|
| PortRange |
Represents a port range and provides access to an iterator of the given range.
|
| Preconditions |
A collection of static utility methods to validate input.
|
| PropertiesUtil |
Simple utilities for getting typed values from Properties.
|
| Reference<T> |
Wrapper class that allows to express whether the value is borrowed or owned.
|
| ReflectionUtil |
Utility for reflection operations on classes and generic type parametrization.
|
| ReflectionUtil.FullTypeInfo |
Container for the full type information of a type.
|
| ResourceGuard |
This class is a guard for shared resources with the following invariants.
|
| SerializableObject |
A simple object that only implements Serializable, so it can be used in
serializable classes.
|
| SerializedValue<T> |
This class is used to transfer (via serialization) objects whose classes are not available in the
system class loader.
|
| ShutdownHookUtil |
Utils class for dealing with JVM shutdown hooks.
|
| SimpleUserCodeClassLoader |
Simple UserCodeClassLoader implementation which assumes that the provided class loader
will never be released and, hence, will never execute the release hooks.
|
| SplittableIterator<T> |
Abstract base class for iterators that can split themselves into multiple disjoint iterators.
|
| StringBasedID |
Base class for typed IDs that are internally represented by a string.
|
| StringUtils |
Utility class to convert objects into strings in vice-versa.
|
| StringValueUtils |
|
| StringValueUtils.WhitespaceTokenizer |
A tokenizer for string values that uses whitespace characters as token delimiters.
|
| TaskManagerExceptionUtils |
Exception utils to handle and enrich exceptions occurring in TaskManager.
|
| TemporaryClassLoaderContext |
Sets a context class loader in a "try-with-resources" pattern.
|
| ThrowableCatchingRunnable |
This class catches all the Throwables from the wrapped runnable.
|
| TimeUtils |
Collection of utilities about time intervals.
|
| UnionIterator<T> |
An iterator that concatenates a collection of iterators.
|
| Utils |
Utility class that contains helper methods to work with Java APIs.
|
| Utils.ChecksumHashCode |
|
| Utils.ChecksumHashCodeHelper<T> |
|
| Utils.CollectHelper<T> |
Utility sink function that collects elements into an accumulator, from which it they can be
retrieved by the client.
|
| Utils.CountHelper<T> |
Utility sink function that counts elements and writes the count into an accumulator, from
which it can be retrieved by the client.
|
| WrappingProxyUtil |
|
| XORShiftRandom |
Implement a random number generator based on the XORShift algorithm discovered by George
Marsaglia.
|