Uses of Package
org.apache.flink.util
-
Classes in org.apache.flink.util used by org.apache.flink.api.common Class Description AbstractID A statistically unique identification number.OptionalFailure Wrapper around an object representing either a success (with a given value) or a failure cause.Visitable This interface marks types as visitable during a traversal.Visitor A visitor encapsulates functionality that is applied to each node in the process of a traversal of a tree or DAG. -
Classes in org.apache.flink.util used by org.apache.flink.api.common.accumulators Class Description OptionalFailure Wrapper around an object representing either a success (with a given value) or a failure cause.SerializedValue This class is used to transfer (via serialization) objects whose classes are not available in the system class loader. -
Classes in org.apache.flink.util used by org.apache.flink.api.common.functions Class Description Collector Collects a record and forwards it. -
Classes in org.apache.flink.util used by org.apache.flink.api.common.functions.util Class Description Collector Collects a record and forwards it.UserCodeClassLoader UserCodeClassLoader allows to register release hooks for a user code class loader. -
Classes in org.apache.flink.util used by org.apache.flink.api.common.operators Class Description FlinkRuntimeException Base class of all Flink-specific unchecked exceptions.Visitable This interface marks types as visitable during a traversal.Visitor A visitor encapsulates functionality that is applied to each node in the process of a traversal of a tree or DAG. -
Classes in org.apache.flink.util used by org.apache.flink.api.common.operators.base Class Description Collector Collects a record and forwards it.Visitable This interface marks types as visitable during a traversal.Visitor A visitor encapsulates functionality that is applied to each node in the process of a traversal of a tree or DAG. -
Classes in org.apache.flink.util used by org.apache.flink.api.common.serialization Class Description Collector Collects a record and forwards it.TernaryBoolean A ternary boolean, which can have the values 'true', 'false', or 'undefined'.UserCodeClassLoader UserCodeClassLoader allows to register release hooks for a user code class loader. -
Classes in org.apache.flink.util used by org.apache.flink.api.connector.sink2 Class Description UserCodeClassLoader UserCodeClassLoader allows to register release hooks for a user code class loader. -
Classes in org.apache.flink.util used by org.apache.flink.api.connector.source Class Description UserCodeClassLoader UserCodeClassLoader allows to register release hooks for a user code class loader. -
Classes in org.apache.flink.util used by org.apache.flink.api.connector.source.lib Class Description NumberSequenceIterator TheNumberSequenceIterator
is an iterator that returns a sequence of numbers (asLong
)s. -
Classes in org.apache.flink.util used by org.apache.flink.core.execution Class Description AbstractID A statistically unique identification number. -
Classes in org.apache.flink.util used by org.apache.flink.core.fs Class Description AbstractAutoCloseableRegistry This is the abstract base class for registries that allow to register instances ofCloseable
, which are all closed if this registry is closed.RefCounted Interface to simply add reference counting functionality.WrappingProxy Interface for objects that wrap another object and proxy (possibly a subset) of the methods of that object. -
Classes in org.apache.flink.util used by org.apache.flink.util Class Description AbstractID A statistically unique identification number.AbstractParameterTool This class provides common utility methods ofParameterTool
andMultipleParameterTool
.CloseableIterable This interface represents an iterable that is also closeable.CloseableIterator This interface represents anIterator
that is alsoAutoCloseable
.CompressedSerializedValue An extension ofSerializedValue
that compresses the value after the serialization.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.FlinkException Base class of all Flink-specific checked exceptions.FlinkRuntimeException Base class of all Flink-specific unchecked exceptions.FlinkUserCodeClassLoader This class loader accepts a custom handler if an exception occurs inFlinkUserCodeClassLoader.loadClass(String, boolean)
.FlinkUserCodeClassLoaders.ResolveOrder Class resolution order for Flink URLClassLoader
.InstantiationUtil.ClassLoaderObjectInputStream A custom ObjectInputStream that can load classes using a specific ClassLoader.LinkedOptionalMap A LinkedOptionalMap is an order preserving map (likeLinkedHashMap
) where keys have a unique string name, but are optionally present, and the values are optional.LinkedOptionalMap.ConsumerWithException AConsumer
that throws exceptions.LinkedOptionalMap.KeyValue Key-value pairs stored by the underlying map.LinkedOptionalMap.MergeResult The result of merging twoLinkedOptionalMap
s usingLinkedOptionalMap.mergeRightIntoLeft(LinkedOptionalMap, LinkedOptionalMap)
.LongValueSequenceIterator TheLongValueSequenceIterator
is an iterator that returns a sequence of numbers (asLongValue
)s.MdcUtils.MdcCloseable AutoCloseable
that restores theMDC
contents on close.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.Port Port wrapper class which holds aFileLock
until it releases.NetUtils.SocketFactory A factory for a local socket from port number.NumberSequenceIterator TheNumberSequenceIterator
is an iterator that returns a sequence of numbers (asLong
)s.OperatingSystem An enumeration indicating the operating system that the JVM runs on.OptionalConsumer Utility class which allows to run code depending on whether the optional has a value or is empty.OptionalFailure Wrapper around an object representing either a success (with a given value) or a failure cause.OutputTag AnOutputTag
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.ProcessorArchitecture The processor architecture of the this system.ProcessorArchitecture.MemoryAddressSize The memory address size of the processor.Reference Wrapper class that allows to express whether the value is borrowed or owned.ReflectionUtil.FullTypeInfo Container for the full type information of a type.ResourceGuard.Lease A lease is issued by theResourceGuard
as result of calls toResourceGuard.acquireResource()
.SerializedValue This class is used to transfer (via serialization) objects whose classes are not available in the system class loader.SimpleUserCodeClassLoader SimpleUserCodeClassLoader
implementation which assumes that the provided class loader will never be released and, hence, will never execute the release hooks.SplittableIterator Abstract base class for iterators that can split themselves into multiple disjoint iterators.StateMigrationException Base class for state migration related exceptions.TemporaryClassLoaderContext Sets a context class loader in a "try-with-resources" pattern.TernaryBoolean A ternary boolean, which can have the values 'true', 'false', or 'undefined'.UserCodeClassLoader UserCodeClassLoader allows to register release hooks for a user code class loader.Utils.ChecksumHashCode Accumulator ofUtils.ChecksumHashCode
.Visitable This interface marks types as visitable during a traversal.Visitor A visitor encapsulates functionality that is applied to each node in the process of a traversal of a tree or DAG.WrappingProxy Interface for objects that wrap another object and proxy (possibly a subset) of the methods of that object.